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

A

abortTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
absoluteFromFraction(double, long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
AbstractBounds - Class in org.apache.cassandra.dht
 
AbstractBounds(Token, Token, IPartitioner) - Constructor for class org.apache.cassandra.dht.AbstractBounds
 
AbstractByteOrderedPartitioner - Class in org.apache.cassandra.dht
 
AbstractByteOrderedPartitioner() - Constructor for class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
AbstractCache - Class in org.apache.cassandra.cache
 
AbstractCache() - Constructor for class org.apache.cassandra.cache.AbstractCache
 
AbstractCassandraDaemon - Class in org.apache.cassandra.service
The CassandraDaemon is an abstraction for a Cassandra daemon service, which defines not only a way to activate and deactivate it, but also hooks into its lifecycle methods (see AbstractCassandraDaemon.setup(), AbstractCassandraDaemon.start(), AbstractCassandraDaemon.stop() and AbstractCassandraDaemon.setup()).
AbstractCassandraDaemon() - Constructor for class org.apache.cassandra.service.AbstractCassandraDaemon
 
AbstractCassandraDaemon.CleaningThreadPool - Class in org.apache.cassandra.service
A subclass of Java's ThreadPoolExecutor which implements Jetty's ThreadPool interface (for integration with Avro), and performs ClientState cleanup.
AbstractCassandraDaemon.CleaningThreadPool(ThreadLocal<ClientState>, int, int) - Constructor for class org.apache.cassandra.service.AbstractCassandraDaemon.CleaningThreadPool
 
AbstractColumnIterator - Class in org.apache.cassandra.db.filter
 
AbstractColumnIterator() - Constructor for class org.apache.cassandra.db.filter.AbstractColumnIterator
 
AbstractCommitLogExecutorService - Class in org.apache.cassandra.db.commitlog
 
AbstractCommitLogExecutorService() - Constructor for class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
AbstractCompactedRow - Class in org.apache.cassandra.io
a CompactedRow is an object that takes a bunch of rows (keys + columnfamilies) and can write a compacted version of those rows to an output stream.
AbstractCompactedRow(DecoratedKey) - Constructor for class org.apache.cassandra.io.AbstractCompactedRow
 
AbstractDataInput - Class in org.apache.cassandra.io.util
 
AbstractDataInput() - Constructor for class org.apache.cassandra.io.util.AbstractDataInput
 
AbstractEndpointSnitch - Class in org.apache.cassandra.locator
 
AbstractEndpointSnitch() - Constructor for class org.apache.cassandra.locator.AbstractEndpointSnitch
 
AbstractNetworkTopologySnitch - Class in org.apache.cassandra.locator
An endpoint snitch tells Cassandra information about network topology that it can use to route requests more efficiently.
AbstractNetworkTopologySnitch() - Constructor for class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
 
AbstractReplicationStrategy - Class in org.apache.cassandra.locator
A abstract parent for all replication strategies.
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 ByteBuffer.
AbstractType() - Constructor for class org.apache.cassandra.db.marshal.AbstractType
 
AbstractWriteResponseHandler - Class in org.apache.cassandra.service
 
AbstractWriteResponseHandler(Collection<InetAddress>, Multimap<InetAddress, InetAddress>, ConsistencyLevel) - Constructor for class org.apache.cassandra.service.AbstractWriteResponseHandler
 
acceptImpl() - Method in class org.apache.cassandra.thrift.TCustomServerSocket
 
ACCESS_FILENAME_PROPERTY - Static variable in class org.apache.cassandra.auth.SimpleAuthority
 
acquireLocks() - Method in class org.apache.cassandra.db.migration.Migration
 
activate() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
A convenience method to initialize and start the daemon in one shot.
activate() - Method in interface org.apache.cassandra.service.CassandraDaemon
A convenience method to initialize and start the daemon in one shot.
add(RowMutation, Object) - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
add(CommitLog.LogRecordAdder) - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
submits the adder for execution and blocks for it to be synced, if necessary
add(ColumnFamily) - Method in class org.apache.cassandra.db.RowMutation
 
add(QueryPath, ByteBuffer, long, int) - Method in class org.apache.cassandra.db.RowMutation
 
add(QueryPath, ByteBuffer, long) - Method in class org.apache.cassandra.db.RowMutation
 
add(Iterable<SSTableReader>) - Method in class org.apache.cassandra.io.sstable.SSTableTracker
 
add(IMessageSink) - Static method in class org.apache.cassandra.net.sink.SinkManager
 
add(AbstractCompactedRow) - Method in class org.apache.cassandra.service.AntiEntropyService.Validator
Called (in order) for every row present in the CF.
add(double) - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
add(ByteBuffer) - Method in class org.apache.cassandra.utils.BloomFilter
 
add(double) - Method in class org.apache.cassandra.utils.BoundedStatsDeque
 
add(long) - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
add(ByteBuffer) - Method in class org.apache.cassandra.utils.Filter
 
add(ByteBuffer) - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
addAll(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamily
 
addAll(Iterator<MerkleTree.RowHash>) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
addBootstrapToken(Token, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
addColumn(IColumn) - Method in class org.apache.cassandra.db.Column
 
addColumn(QueryPath, ByteBuffer, long) - Method in class org.apache.cassandra.db.ColumnFamily
 
addColumn(QueryPath, ByteBuffer, long, int) - Method in class org.apache.cassandra.db.ColumnFamily
 
addColumn(ByteBuffer, Column) - Method in class org.apache.cassandra.db.ColumnFamily
 
addColumn(IColumn) - Method in class org.apache.cassandra.db.ColumnFamily
 
addColumn(IColumn) - Method in interface org.apache.cassandra.db.IColumn
 
addColumn(IColumn) - Method in interface org.apache.cassandra.db.IColumnContainer
 
addColumn(IColumn) - Method in class org.apache.cassandra.db.SuperColumn
 
AddColumnFamily - Class in org.apache.cassandra.db.migration
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
AddColumnFamily() - Constructor for class org.apache.cassandra.db.migration.AddColumnFamily
Required no-arg constructor
AddColumnFamily(CFMetaData) - Constructor for class org.apache.cassandra.db.migration.AddColumnFamily
 
addEntry(DecoratedKey, long) - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
addFalsePositive() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
addFiles(Collection<PendingFile>) - Method in class org.apache.cassandra.streaming.StreamInSession
 
addFilesToStream(List<PendingFile>) - Method in class org.apache.cassandra.streaming.StreamOutSession
 
addHash(MerkleTree.RowHash) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
addIndex(ColumnDefinition) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
AddKeyspace - Class in org.apache.cassandra.db.migration
 
AddKeyspace() - Constructor for class org.apache.cassandra.db.migration.AddKeyspace
Required no-arg constructor
AddKeyspace(KSMetaData) - Constructor for class org.apache.cassandra.db.migration.AddKeyspace
 
addLatency(InetAddress, double) - Method in class org.apache.cassandra.net.MessagingService
 
addLeavingEndpoint(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
addLocalApplicationState(ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.Gossiper
 
addMicro(long) - Method in class org.apache.cassandra.utils.LatencyTracker
 
addNano(long) - Method in class org.apache.cassandra.utils.LatencyTracker
takes nanoseconds
addPotentialBoundary(long) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile.Builder
Adds a position that would be a safe place for a segment boundary in the file.
addPotentialBoundary(long) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
Adds a position that would be a safe place for a segment boundary in the file.
address - Variable in class org.apache.cassandra.dht.BootStrapper
 
addSavedEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
Add an endpoint we knew about previously, but whose state is unknown
addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
addToCf_defs(CfDef) - Method in class org.apache.cassandra.thrift.KsDef
 
addToColumn_metadata(ColumnDef) - Method in class org.apache.cassandra.thrift.CfDef
 
addToColumn_names(ByteBuffer) - Method in class org.apache.cassandra.thrift.SlicePredicate
 
addToColumns(ColumnOrSuperColumn) - Method in class org.apache.cassandra.thrift.KeySlice
 
addToColumns(Column) - Method in class org.apache.cassandra.thrift.SuperColumn
 
addToEndpoints(String) - Method in class org.apache.cassandra.thrift.TokenRange
 
addToExpressions(IndexExpression) - Method in class org.apache.cassandra.thrift.IndexClause
 
addToKeys(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
addToKeys(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
addTombstone(QueryPath, ByteBuffer, long) - Method in class org.apache.cassandra.db.ColumnFamily
 
addTombstone(QueryPath, int, long) - Method in class org.apache.cassandra.db.ColumnFamily
 
addTombstone(ByteBuffer, int, long) - Method in class org.apache.cassandra.db.ColumnFamily
 
addToSuccess(KsDef) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
addToSuccess(TokenRange) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
addToSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
addToSuccess(KeySlice) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
addToSuccess(KeySlice) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
addToSuccess(ColumnOrSuperColumn) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
addTruePositive() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
afterExecute(Runnable, Throwable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
afterExecute(Runnable, Throwable) - Method in class org.apache.cassandra.service.AbstractCassandraDaemon.CleaningThreadPool
 
AIOExecutorService - Class in org.apache.cassandra.concurrent
 
AIOExecutorService(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.apache.cassandra.concurrent.AIOExecutorService
 
ALL - Static variable in enum org.apache.cassandra.auth.Permission
 
all() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
all() - Static method in class org.apache.cassandra.db.Table
 
allKeySamples() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
AllowAllAuthenticator - Class in org.apache.cassandra.auth
 
AllowAllAuthenticator() - Constructor for class org.apache.cassandra.auth.AllowAllAuthenticator
 
AllowAllAuthority - Class in org.apache.cassandra.auth
 
AllowAllAuthority() - Constructor for class org.apache.cassandra.auth.AllowAllAuthority
 
alwaysMatchingBloomFilter() - Static method in class org.apache.cassandra.utils.LegacyBloomFilter
 
and(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
andNot(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
andNotCount(OpenBitSet, OpenBitSet) - Static method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the popcount or cardinality of "a and not b" or "intersection(a, not(b))".
announce() - Method in class org.apache.cassandra.db.migration.Migration
 
announce(UUID, Set<InetAddress>) - Static method in class org.apache.cassandra.service.MigrationManager
actively announce my version to a set of hosts via rpc.
AntiEntropyService - Class in org.apache.cassandra.service
AntiEntropyService encapsulates "validating" (hashing) individual column families, exchanging MerkleTrees with remote nodes via a TreeRequest/Response conversation, and then triggering repairs for disagreeing ranges.
AntiEntropyService() - Constructor for class org.apache.cassandra.service.AntiEntropyService
Protected constructor.
AntiEntropyService.Differencer - Class in org.apache.cassandra.service
Runs on the node that initiated a request to compare two trees, and launch repairs for disagreeing ranges.
AntiEntropyService.Differencer(AntiEntropyService.TreeRequest, MerkleTree, MerkleTree) - Constructor for class org.apache.cassandra.service.AntiEntropyService.Differencer
 
AntiEntropyService.TreeRequest - Class in org.apache.cassandra.service
A triple of table, cf and address that represents a location we have an outstanding TreeRequest for.
AntiEntropyService.TreeRequest(String, InetAddress, AntiEntropyService.CFPair) - Constructor for class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
AntiEntropyService.TreeRequestVerbHandler - Class in org.apache.cassandra.service
Handler for requests from remote nodes to generate a valid tree.
AntiEntropyService.TreeRequestVerbHandler() - Constructor for class org.apache.cassandra.service.AntiEntropyService.TreeRequestVerbHandler
 
AntiEntropyService.TreeResponseVerbHandler - Class in org.apache.cassandra.service
Handler for responses from remote nodes which contain a valid tree.
AntiEntropyService.TreeResponseVerbHandler() - Constructor for class org.apache.cassandra.service.AntiEntropyService.TreeResponseVerbHandler
 
AntiEntropyService.Validator - Class in org.apache.cassandra.service
A Strategy to handle building and validating a merkle tree for a column family.
append(AbstractCompactedRow) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
append(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
append(DecoratedKey, ByteBuffer) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
ApplicationState - Enum in org.apache.cassandra.gms
 
apply(CfDef) - Method in class org.apache.cassandra.config.CFMetaData
 
apply() - Method in class org.apache.cassandra.db.migration.Migration
apply changes
apply() - Method in class org.apache.cassandra.db.RowMutation
 
apply(RowMutation, Object, boolean) - Method in class org.apache.cassandra.db.Table
This method adds the row to the Commit Log associated with this table.
apply() - Method in class org.apache.cassandra.db.Truncation
This is equivalent to calling commit.
apply(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader.Operator
 
applyImplicitDefaults(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
applies implicit defaults to cf definition.
applyImplicitDefaults(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
applies implicit defaults to cf definition.
applyMigrations(UUID, UUID) - Static method in class org.apache.cassandra.service.MigrationManager
gets called during startup if we notice a mismatch between the current migration version and the one saved.
applyModels() - Method in class org.apache.cassandra.db.migration.AddColumnFamily
 
applyModels() - Method in class org.apache.cassandra.db.migration.AddKeyspace
 
applyModels() - Method in class org.apache.cassandra.db.migration.DropColumnFamily
 
applyModels() - Method in class org.apache.cassandra.db.migration.DropKeyspace
 
applyModels() - Method in class org.apache.cassandra.db.migration.RenameColumnFamily
Deprecated.  
applyModels() - Method in class org.apache.cassandra.db.migration.RenameKeyspace
Deprecated.  
applyUnsafe() - Method in class org.apache.cassandra.db.RowMutation
 
argumentExplanations - Variable in class org.apache.cassandra.cli.CliUserHelp
 
arrayCopy(ByteBuffer, int, byte[], int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
asByteArray() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
asByteArray() - Method in class org.apache.cassandra.io.util.OutputBuffer
 
AsciiType - Class in org.apache.cassandra.db.marshal
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
assureSufficientLiveNodes(Collection<InetAddress>) - Method in class org.apache.cassandra.service.DatacenterReadCallback
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
assureSufficientLiveNodes() - Method in interface org.apache.cassandra.service.IWriteResponseHandler
 
assureSufficientLiveNodes(Collection<InetAddress>) - Method in class org.apache.cassandra.service.ReadCallback
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.WriteResponseHandler
 
asTemporary(boolean) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
atomicSetMax(AtomicInteger, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
atomicSetMax(AtomicLong, long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
auth_request - Variable in class org.apache.cassandra.thrift.Cassandra.login_args
 
authenticate(Map<? extends CharSequence, ? extends CharSequence>) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
authenticate(Map<? extends CharSequence, ? extends CharSequence>) - Method in interface org.apache.cassandra.auth.IAuthenticator
 
authenticate(Map<? extends CharSequence, ? extends CharSequence>) - Method in class org.apache.cassandra.auth.SimpleAuthenticator
 
AuthenticatedUser - Class in org.apache.cassandra.auth
An authenticated user and her groups.
AuthenticatedUser(String) - Constructor for class org.apache.cassandra.auth.AuthenticatedUser
 
AuthenticatedUser(String, Set<String>) - Constructor for class org.apache.cassandra.auth.AuthenticatedUser
 
AuthenticationException - Exception in org.apache.cassandra.thrift
invalid authentication request (invalid keyspace, user does not exist, or credentials invalid)
AuthenticationException() - Constructor for exception org.apache.cassandra.thrift.AuthenticationException
 
AuthenticationException(String) - Constructor for exception org.apache.cassandra.thrift.AuthenticationException
 
AuthenticationException(AuthenticationException) - Constructor for exception org.apache.cassandra.thrift.AuthenticationException
Performs a deep copy on other.
AuthenticationException._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
AuthenticationRequest - Class in org.apache.cassandra.thrift
Authentication requests can contain any data, dependent on the IAuthenticator used
AuthenticationRequest() - Constructor for class org.apache.cassandra.thrift.AuthenticationRequest
 
AuthenticationRequest(Map<String, String>) - Constructor for class org.apache.cassandra.thrift.AuthenticationRequest
 
AuthenticationRequest(AuthenticationRequest) - Constructor for class org.apache.cassandra.thrift.AuthenticationRequest
Performs a deep copy on other.
AuthenticationRequest._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
authenticator - Variable in class org.apache.cassandra.config.Config
 
authnx - Variable in class org.apache.cassandra.thrift.Cassandra.login_result
 
authority - Variable in class org.apache.cassandra.config.Config
 
AuthorizationException - Exception in org.apache.cassandra.thrift
invalid authorization request (user does not have access to keyspace)
AuthorizationException() - Constructor for exception org.apache.cassandra.thrift.AuthorizationException
 
AuthorizationException(String) - Constructor for exception org.apache.cassandra.thrift.AuthorizationException
 
AuthorizationException(AuthorizationException) - Constructor for exception org.apache.cassandra.thrift.AuthorizationException
Performs a deep copy on other.
AuthorizationException._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
authorize(AuthenticatedUser, List<Object>) - Method in class org.apache.cassandra.auth.AllowAllAuthority
 
authorize(AuthenticatedUser, List<Object>) - Method in interface org.apache.cassandra.auth.IAuthority
 
authorize(AuthenticatedUser, List<Object>) - Method in class org.apache.cassandra.auth.SimpleAuthority
 
authzx - Variable in class org.apache.cassandra.thrift.Cassandra.login_result
 
auto_bootstrap - Variable in class org.apache.cassandra.config.Config
 
AVRO_ID - Static variable in class org.apache.cassandra.hadoop.streaming.AvroResolver
 
AvroOutputReader - Class in org.apache.cassandra.hadoop.streaming
An OutputReader that reads sequential StreamingMutations (from Cassandra's Avro client API), and converts them to the objects used by CassandraOutputFormat.
AvroOutputReader() - Constructor for class org.apache.cassandra.hadoop.streaming.AvroOutputReader
 
AvroRecordFactory - Class in org.apache.cassandra.avro
 
AvroRecordFactory() - Constructor for class org.apache.cassandra.avro.AvroRecordFactory
 
AvroResolver - Class in org.apache.cassandra.hadoop.streaming
Resolves AVRO_ID to the appropriate OutputReader and K/V classes for Cassandra output.
AvroResolver() - Constructor for class org.apache.cassandra.hadoop.streaming.AvroResolver
 
AvroValidation - Class in org.apache.cassandra.avro
The Avro analogue to org.apache.cassandra.service.ThriftValidation
AvroValidation() - Constructor for class org.apache.cassandra.avro.AvroValidation
 
await() - Method in class org.apache.cassandra.utils.SimpleCondition
 
await(long, TimeUnit) - Method in class org.apache.cassandra.utils.SimpleCondition
 
awaitNanos(long) - Method in class org.apache.cassandra.utils.SimpleCondition
 
awaitTermination(long, TimeUnit) - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Blocks until all tasks have completed execution after a shutdown request, or the timeout occurs, or the current thread is interrupted, whichever happens first.
awaitTermination(long, TimeUnit) - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
awaitTermination() - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
Blocks until shutdown is complete.
awaitUninterruptibly() - Method in class org.apache.cassandra.utils.SimpleCondition
 
awaitUntil(Date) - Method in class org.apache.cassandra.utils.SimpleCondition
 

B

batch - Variable in class org.apache.cassandra.cli.CliSessionState
 
batch_mutate(List<MutationsMapEntry>, ConsistencyLevel) - Method in class org.apache.cassandra.avro.CassandraServer
 
batch_mutate(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.batch_mutate_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
batch_mutate(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.batch_mutate_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
batch_mutate(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
batch_mutate(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
Mutate many columns or super columns for many row keys.
batch_mutate(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
BATCH_THRESHOLD - Static variable in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
 
BatchCommitLogExecutorServiceMBean - Interface in org.apache.cassandra.db.commitlog
 
beforeApplyModels() - Method in class org.apache.cassandra.db.migration.DropColumnFamily
 
beforeApplyModels() - Method in class org.apache.cassandra.db.migration.DropKeyspace
 
beforeApplyModels() - Method in class org.apache.cassandra.db.migration.Migration
override this to perform logic before writing the migration or applying it.
beforeApplyModels() - Method in class org.apache.cassandra.db.migration.UpdateColumnFamily
 
begin() - Method in class org.apache.cassandra.streaming.StreamOutSession
 
BigIntegerToken - Class in org.apache.cassandra.dht
 
BigIntegerToken(BigInteger) - Constructor for class org.apache.cassandra.dht.BigIntegerToken
 
BigIntegerToken(String) - Constructor for class org.apache.cassandra.dht.BigIntegerToken
 
binary_memtable_throughput_in_mb - Variable in class org.apache.cassandra.config.Config
 
BinaryMemtable - Class in org.apache.cassandra.db
 
BinaryMemtable(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.BinaryMemtable
 
BinaryVerbHandler - Class in org.apache.cassandra.db
 
BinaryVerbHandler() - Constructor for class org.apache.cassandra.db.BinaryVerbHandler
 
bits - Variable in class org.apache.cassandra.utils.obs.OpenBitSet
 
bits2words(long) - Static method in class org.apache.cassandra.utils.obs.OpenBitSet
returns the number of 64 bit words it would take to hold numBits
bitset - Variable in class org.apache.cassandra.utils.BloomFilter
 
blockfor - Variable in class org.apache.cassandra.service.ReadCallback
 
BloomFilter - Class in org.apache.cassandra.utils
 
BloomFilterTracker - Class in org.apache.cassandra.io.sstable
 
BloomFilterTracker() - Constructor for class org.apache.cassandra.io.sstable.BloomFilterTracker
 
boolSize_ - Static variable in class org.apache.cassandra.db.DBConstants
 
bootstrap() - Method in class org.apache.cassandra.dht.BootStrapper
 
BootStrapper - Class in org.apache.cassandra.dht
 
BootStrapper(InetAddress, Token, TokenMetadata) - Constructor for class org.apache.cassandra.dht.BootStrapper
 
BootStrapper.BootstrapTokenVerbHandler - Class in org.apache.cassandra.dht
 
BootStrapper.BootstrapTokenVerbHandler() - Constructor for class org.apache.cassandra.dht.BootStrapper.BootstrapTokenVerbHandler
 
bootstrapping(Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
BoundedStatsDeque - Class in org.apache.cassandra.utils
not threadsafe.
BoundedStatsDeque(int) - Constructor for class org.apache.cassandra.utils.BoundedStatsDeque
 
Bounds - Class in org.apache.cassandra.dht
 
Bounds(Token, Token) - Constructor for class org.apache.cassandra.dht.Bounds
 
BufferedRandomAccessFile - Class in org.apache.cassandra.io.util
A BufferedRandomAccessFile is like a RandomAccessFile, but it uses a private buffer so that most operations do not require a disk access.
BufferedRandomAccessFile(String, String) - Constructor for class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
BufferedRandomAccessFile(String, String, int) - Constructor for class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
BufferedRandomAccessFile(File, String) - Constructor for class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
BufferedRandomAccessFile(File, String, int) - Constructor for class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
BufferedRandomAccessFile(File, String, int, boolean) - Constructor for class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
BufferedRandomAccessFile.BufferedRandomAccessFileMark - Class in org.apache.cassandra.io.util
Class to hold a mark to the position of the file
BufferedRandomAccessFile.BufferedRandomAccessFileMark(long) - Constructor for class org.apache.cassandra.io.util.BufferedRandomAccessFile.BufferedRandomAccessFileMark
 
BufferedSegmentedFile - Class in org.apache.cassandra.io.util
 
BufferedSegmentedFile(String, long) - Constructor for class org.apache.cassandra.io.util.BufferedSegmentedFile
 
BufferedSegmentedFile.Builder - Class in org.apache.cassandra.io.util
 
BufferedSegmentedFile.Builder() - Constructor for class org.apache.cassandra.io.util.BufferedSegmentedFile.Builder
 
BufferForColumn() - Method in class org.apache.cassandra.thrift.ColumnPath
 
BufferForColumn_name() - Method in class org.apache.cassandra.thrift.IndexExpression
 
BufferForEnd_key() - Method in class org.apache.cassandra.thrift.KeyRange
 
BufferForFinish() - Method in class org.apache.cassandra.thrift.SliceRange
 
BufferForKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
BufferForKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
BufferForKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
BufferForKey() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
BufferForKey() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
BufferForKey() - Method in class org.apache.cassandra.thrift.KeyCount
 
BufferForKey() - Method in class org.apache.cassandra.thrift.KeySlice
 
BufferForName() - Method in class org.apache.cassandra.thrift.Column
 
BufferForName() - Method in class org.apache.cassandra.thrift.ColumnDef
 
BufferForName() - Method in class org.apache.cassandra.thrift.SuperColumn
 
BufferForStart() - Method in class org.apache.cassandra.thrift.SliceRange
 
BufferForStart_key() - Method in class org.apache.cassandra.thrift.IndexClause
 
BufferForStart_key() - Method in class org.apache.cassandra.thrift.KeyRange
 
BufferForSuper_column() - Method in class org.apache.cassandra.thrift.ColumnParent
 
BufferForSuper_column() - Method in class org.apache.cassandra.thrift.ColumnPath
 
BufferForSuper_column() - Method in class org.apache.cassandra.thrift.Deletion
 
BufferForValue() - Method in class org.apache.cassandra.thrift.Column
 
BufferForValue() - Method in class org.apache.cassandra.thrift.IndexExpression
 
bufIn_ - Variable in class org.apache.cassandra.db.ReadVerbHandler.ReadContext
 
bufOut_ - Variable in class org.apache.cassandra.db.ReadVerbHandler.ReadContext
 
build() - Method in class org.apache.cassandra.db.Table.IndexBuilder
 
build() - Method in class org.apache.cassandra.io.sstable.SSTableWriter.Builder
 
buildSecondaryIndexes(Collection<SSTableReader>, SortedSet<ByteBuffer>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
BYTE_MASK - Static variable in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
ByteBufferUtil - Class in org.apache.cassandra.utils
Utility methods to make ByteBuffers less painful The following should illustrate the different ways byte buffers can be used public void testArrayOffet() { byte[] b = "test_slice_array".getBytes(); ByteBuffer bb = ByteBuffer.allocate(1024); assert bb.position() == 0; assert bb.limit() == 1024; assert bb.capacity() == 1024; bb.put(b); assert bb.position() == b.length; assert bb.remaining() == bb.limit() - bb.position(); ByteBuffer bb2 = bb.slice(); assert bb2.position() == 0; //slice should begin at other buffers current position assert bb2.arrayOffset() == bb.position(); //to match the position in the underlying array one needs to //track arrayOffset assert bb2.limit()+bb2.arrayOffset() == bb.limit(); assert bb2.remaining() == bb.remaining(); } }
ByteBufferUtil() - Constructor for class org.apache.cassandra.utils.ByteBufferUtil
 
ByteOrderedPartitioner - Class in org.apache.cassandra.dht
 
ByteOrderedPartitioner() - Constructor for class org.apache.cassandra.dht.ByteOrderedPartitioner
 
bytes(String) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(long) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytesOnDisk() - Method in class org.apache.cassandra.io.sstable.SSTable
 
bytesPastMark() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
bytesPastMark(FileMark) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
bytesPastMark(FileMark) - Method in interface org.apache.cassandra.io.util.FileDataInput
 
bytesPastMark(FileMark) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
bytesRemaining() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
bytesRemaining() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
bytesRemaining() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
bytesToHex(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytesToHex(byte...) - Static method in class org.apache.cassandra.utils.FBUtilities
 
BytesToken - Class in org.apache.cassandra.dht
 
BytesToken(ByteBuffer) - Constructor for class org.apache.cassandra.dht.BytesToken
 
BytesToken(byte[]) - Constructor for class org.apache.cassandra.dht.BytesToken
 
BytesType - Class in org.apache.cassandra.db.marshal
 

C

cacheEndpoint(Token, ArrayList<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
cacheKey(DecoratedKey, Long) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
CacheWriter<K,V> - Class in org.apache.cassandra.io.sstable
 
CacheWriter(String, JMXInstrumentedCache<K, V>, File, Function<K, ByteBuffer>) - Constructor for class org.apache.cassandra.io.sstable.CacheWriter
 
calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
calculate the natural endpoints for the given token
calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.LocalStrategy
 
calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
 
calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.SimpleStrategy
 
calculatePendingRanges(AbstractReplicationStrategy, String) - Static method in class org.apache.cassandra.service.StorageService
 
capacity() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the current capacity in bits (1 greater than the index of the last bit)
cardinality() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
Cassandra - Class in org.apache.cassandra.thrift
 
Cassandra() - Constructor for class org.apache.cassandra.thrift.Cassandra
 
Cassandra.AsyncClient - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
Cassandra.AsyncClient.batch_mutate_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.batch_mutate_call(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.batch_mutate_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.batch_mutate_call
 
Cassandra.AsyncClient.describe_cluster_name_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.describe_cluster_name_call(AsyncMethodCallback<Cassandra.AsyncClient.describe_cluster_name_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_cluster_name_call
 
Cassandra.AsyncClient.describe_keyspace_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.describe_keyspace_call(String, AsyncMethodCallback<Cassandra.AsyncClient.describe_keyspace_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_keyspace_call
 
Cassandra.AsyncClient.describe_keyspaces_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.describe_keyspaces_call(AsyncMethodCallback<Cassandra.AsyncClient.describe_keyspaces_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_keyspaces_call
 
Cassandra.AsyncClient.describe_partitioner_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.describe_partitioner_call(AsyncMethodCallback<Cassandra.AsyncClient.describe_partitioner_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_partitioner_call
 
Cassandra.AsyncClient.describe_ring_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.describe_ring_call(String, AsyncMethodCallback<Cassandra.AsyncClient.describe_ring_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_ring_call
 
Cassandra.AsyncClient.describe_schema_versions_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.describe_schema_versions_call(AsyncMethodCallback<Cassandra.AsyncClient.describe_schema_versions_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_schema_versions_call
 
Cassandra.AsyncClient.describe_snitch_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.describe_snitch_call(AsyncMethodCallback<Cassandra.AsyncClient.describe_snitch_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_snitch_call
 
Cassandra.AsyncClient.describe_splits_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.describe_splits_call(String, String, String, int, AsyncMethodCallback<Cassandra.AsyncClient.describe_splits_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_splits_call
 
Cassandra.AsyncClient.describe_version_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.describe_version_call(AsyncMethodCallback<Cassandra.AsyncClient.describe_version_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_version_call
 
Cassandra.AsyncClient.Factory - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.Factory
 
Cassandra.AsyncClient.get_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.get_call(ByteBuffer, ColumnPath, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.get_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_call
 
Cassandra.AsyncClient.get_count_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.get_count_call(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.get_count_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_count_call
 
Cassandra.AsyncClient.get_indexed_slices_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.get_indexed_slices_call(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.get_indexed_slices_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_indexed_slices_call
 
Cassandra.AsyncClient.get_range_slices_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.get_range_slices_call(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.get_range_slices_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_range_slices_call
 
Cassandra.AsyncClient.get_slice_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.get_slice_call(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.get_slice_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_slice_call
 
Cassandra.AsyncClient.insert_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.insert_call(ByteBuffer, ColumnParent, Column, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.insert_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.insert_call
 
Cassandra.AsyncClient.login_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.login_call(AuthenticationRequest, AsyncMethodCallback<Cassandra.AsyncClient.login_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.login_call
 
Cassandra.AsyncClient.multiget_count_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.multiget_count_call(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.multiget_count_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.multiget_count_call
 
Cassandra.AsyncClient.multiget_slice_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.multiget_slice_call(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.multiget_slice_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.multiget_slice_call
 
Cassandra.AsyncClient.remove_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.remove_call(ByteBuffer, ColumnPath, long, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.remove_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.remove_call
 
Cassandra.AsyncClient.set_keyspace_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.set_keyspace_call(String, AsyncMethodCallback<Cassandra.AsyncClient.set_keyspace_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.set_keyspace_call
 
Cassandra.AsyncClient.system_add_column_family_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.system_add_column_family_call(CfDef, AsyncMethodCallback<Cassandra.AsyncClient.system_add_column_family_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_add_column_family_call
 
Cassandra.AsyncClient.system_add_keyspace_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.system_add_keyspace_call(KsDef, AsyncMethodCallback<Cassandra.AsyncClient.system_add_keyspace_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_add_keyspace_call
 
Cassandra.AsyncClient.system_drop_column_family_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.system_drop_column_family_call(String, AsyncMethodCallback<Cassandra.AsyncClient.system_drop_column_family_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_drop_column_family_call
 
Cassandra.AsyncClient.system_drop_keyspace_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.system_drop_keyspace_call(String, AsyncMethodCallback<Cassandra.AsyncClient.system_drop_keyspace_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_drop_keyspace_call
 
Cassandra.AsyncClient.system_update_column_family_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.system_update_column_family_call(CfDef, AsyncMethodCallback<Cassandra.AsyncClient.system_update_column_family_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_update_column_family_call
 
Cassandra.AsyncClient.system_update_keyspace_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.system_update_keyspace_call(KsDef, AsyncMethodCallback<Cassandra.AsyncClient.system_update_keyspace_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_update_keyspace_call
 
Cassandra.AsyncClient.truncate_call - Class in org.apache.cassandra.thrift
 
Cassandra.AsyncClient.truncate_call(String, AsyncMethodCallback<Cassandra.AsyncClient.truncate_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.cassandra.thrift.Cassandra.AsyncClient.truncate_call
 
Cassandra.AsyncIface - Interface in org.apache.cassandra.thrift
 
Cassandra.batch_mutate_args - Class in org.apache.cassandra.thrift
 
Cassandra.batch_mutate_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
Cassandra.batch_mutate_args(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
Cassandra.batch_mutate_args(Cassandra.batch_mutate_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
Performs a deep copy on other.
Cassandra.batch_mutate_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.batch_mutate_result - Class in org.apache.cassandra.thrift
 
Cassandra.batch_mutate_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
Cassandra.batch_mutate_result(InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
Cassandra.batch_mutate_result(Cassandra.batch_mutate_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
Performs a deep copy on other.
Cassandra.batch_mutate_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.Client - Class in org.apache.cassandra.thrift
 
Cassandra.Client(TProtocol) - Constructor for class org.apache.cassandra.thrift.Cassandra.Client
 
Cassandra.Client(TProtocol, TProtocol) - Constructor for class org.apache.cassandra.thrift.Cassandra.Client
 
Cassandra.Client.Factory - Class in org.apache.cassandra.thrift
 
Cassandra.Client.Factory() - Constructor for class org.apache.cassandra.thrift.Cassandra.Client.Factory
 
Cassandra.describe_cluster_name_args - Class in org.apache.cassandra.thrift
 
Cassandra.describe_cluster_name_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
 
Cassandra.describe_cluster_name_args(Cassandra.describe_cluster_name_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
Performs a deep copy on other.
Cassandra.describe_cluster_name_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.describe_cluster_name_result - Class in org.apache.cassandra.thrift
 
Cassandra.describe_cluster_name_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
Cassandra.describe_cluster_name_result(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
Cassandra.describe_cluster_name_result(Cassandra.describe_cluster_name_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
Performs a deep copy on other.
Cassandra.describe_cluster_name_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.describe_keyspace_args - Class in org.apache.cassandra.thrift
 
Cassandra.describe_keyspace_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
Cassandra.describe_keyspace_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
Cassandra.describe_keyspace_args(Cassandra.describe_keyspace_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
Performs a deep copy on other.
Cassandra.describe_keyspace_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.describe_keyspace_result - Class in org.apache.cassandra.thrift
 
Cassandra.describe_keyspace_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
Cassandra.describe_keyspace_result(KsDef, NotFoundException, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
Cassandra.describe_keyspace_result(Cassandra.describe_keyspace_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
Performs a deep copy on other.
Cassandra.describe_keyspace_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.describe_keyspaces_args - Class in org.apache.cassandra.thrift
 
Cassandra.describe_keyspaces_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
 
Cassandra.describe_keyspaces_args(Cassandra.describe_keyspaces_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
Performs a deep copy on other.
Cassandra.describe_keyspaces_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.describe_keyspaces_result - Class in org.apache.cassandra.thrift
 
Cassandra.describe_keyspaces_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
Cassandra.describe_keyspaces_result(List<KsDef>, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
Cassandra.describe_keyspaces_result(Cassandra.describe_keyspaces_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
Performs a deep copy on other.
Cassandra.describe_keyspaces_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.describe_partitioner_args - Class in org.apache.cassandra.thrift
 
Cassandra.describe_partitioner_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
 
Cassandra.describe_partitioner_args(Cassandra.describe_partitioner_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
Performs a deep copy on other.
Cassandra.describe_partitioner_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.describe_partitioner_result - Class in org.apache.cassandra.thrift
 
Cassandra.describe_partitioner_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
Cassandra.describe_partitioner_result(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
Cassandra.describe_partitioner_result(Cassandra.describe_partitioner_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
Performs a deep copy on other.
Cassandra.describe_partitioner_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.describe_ring_args - Class in org.apache.cassandra.thrift
 
Cassandra.describe_ring_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
Cassandra.describe_ring_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
Cassandra.describe_ring_args(Cassandra.describe_ring_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_ring_args
Performs a deep copy on other.
Cassandra.describe_ring_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.describe_ring_result - Class in org.apache.cassandra.thrift
 
Cassandra.describe_ring_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
Cassandra.describe_ring_result(List<TokenRange>, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
Cassandra.describe_ring_result(Cassandra.describe_ring_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_ring_result
Performs a deep copy on other.
Cassandra.describe_ring_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.describe_schema_versions_args - Class in org.apache.cassandra.thrift
 
Cassandra.describe_schema_versions_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
 
Cassandra.describe_schema_versions_args(Cassandra.describe_schema_versions_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
Performs a deep copy on other.
Cassandra.describe_schema_versions_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.describe_schema_versions_result - Class in org.apache.cassandra.thrift
 
Cassandra.describe_schema_versions_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
Cassandra.describe_schema_versions_result(Map<String, List<String>>, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
Cassandra.describe_schema_versions_result(Cassandra.describe_schema_versions_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
Performs a deep copy on other.
Cassandra.describe_schema_versions_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.describe_snitch_args - Class in org.apache.cassandra.thrift
 
Cassandra.describe_snitch_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
 
Cassandra.describe_snitch_args(Cassandra.describe_snitch_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
Performs a deep copy on other.
Cassandra.describe_snitch_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.describe_snitch_result - Class in org.apache.cassandra.thrift
 
Cassandra.describe_snitch_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
Cassandra.describe_snitch_result(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
Cassandra.describe_snitch_result(Cassandra.describe_snitch_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
Performs a deep copy on other.
Cassandra.describe_snitch_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.describe_splits_args - Class in org.apache.cassandra.thrift
 
Cassandra.describe_splits_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
Cassandra.describe_splits_args(String, String, String, int) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
Cassandra.describe_splits_args(Cassandra.describe_splits_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_args
Performs a deep copy on other.
Cassandra.describe_splits_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.describe_splits_result - Class in org.apache.cassandra.thrift
 
Cassandra.describe_splits_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
Cassandra.describe_splits_result(List<String>) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
Cassandra.describe_splits_result(Cassandra.describe_splits_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_splits_result
Performs a deep copy on other.
Cassandra.describe_splits_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.describe_version_args - Class in org.apache.cassandra.thrift
 
Cassandra.describe_version_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_version_args
 
Cassandra.describe_version_args(Cassandra.describe_version_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_version_args
Performs a deep copy on other.
Cassandra.describe_version_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.describe_version_result - Class in org.apache.cassandra.thrift
 
Cassandra.describe_version_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
Cassandra.describe_version_result(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
Cassandra.describe_version_result(Cassandra.describe_version_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.describe_version_result
Performs a deep copy on other.
Cassandra.describe_version_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.get_args - Class in org.apache.cassandra.thrift
 
Cassandra.get_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_args
 
Cassandra.get_args(ByteBuffer, ColumnPath, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_args
 
Cassandra.get_args(Cassandra.get_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_args
Performs a deep copy on other.
Cassandra.get_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.get_count_args - Class in org.apache.cassandra.thrift
 
Cassandra.get_count_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_args
 
Cassandra.get_count_args(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_args
 
Cassandra.get_count_args(Cassandra.get_count_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_args
Performs a deep copy on other.
Cassandra.get_count_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.get_count_result - Class in org.apache.cassandra.thrift
 
Cassandra.get_count_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_result
 
Cassandra.get_count_result(int, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_result
 
Cassandra.get_count_result(Cassandra.get_count_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_count_result
Performs a deep copy on other.
Cassandra.get_count_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.get_indexed_slices_args - Class in org.apache.cassandra.thrift
 
Cassandra.get_indexed_slices_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
Cassandra.get_indexed_slices_args(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
Cassandra.get_indexed_slices_args(Cassandra.get_indexed_slices_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
Performs a deep copy on other.
Cassandra.get_indexed_slices_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.get_indexed_slices_result - Class in org.apache.cassandra.thrift
 
Cassandra.get_indexed_slices_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
Cassandra.get_indexed_slices_result(List<KeySlice>, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
Cassandra.get_indexed_slices_result(Cassandra.get_indexed_slices_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
Performs a deep copy on other.
Cassandra.get_indexed_slices_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.get_range_slices_args - Class in org.apache.cassandra.thrift
 
Cassandra.get_range_slices_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
Cassandra.get_range_slices_args(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
Cassandra.get_range_slices_args(Cassandra.get_range_slices_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
Performs a deep copy on other.
Cassandra.get_range_slices_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.get_range_slices_result - Class in org.apache.cassandra.thrift
 
Cassandra.get_range_slices_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
Cassandra.get_range_slices_result(List<KeySlice>, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
Cassandra.get_range_slices_result(Cassandra.get_range_slices_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
Performs a deep copy on other.
Cassandra.get_range_slices_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.get_result - Class in org.apache.cassandra.thrift
 
Cassandra.get_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_result
 
Cassandra.get_result(ColumnOrSuperColumn, InvalidRequestException, NotFoundException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_result
 
Cassandra.get_result(Cassandra.get_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_result
Performs a deep copy on other.
Cassandra.get_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.get_slice_args - Class in org.apache.cassandra.thrift
 
Cassandra.get_slice_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
Cassandra.get_slice_args(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
Cassandra.get_slice_args(Cassandra.get_slice_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_args
Performs a deep copy on other.
Cassandra.get_slice_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.get_slice_result - Class in org.apache.cassandra.thrift
 
Cassandra.get_slice_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
Cassandra.get_slice_result(List<ColumnOrSuperColumn>, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
Cassandra.get_slice_result(Cassandra.get_slice_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.get_slice_result
Performs a deep copy on other.
Cassandra.get_slice_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.Iface - Interface in org.apache.cassandra.thrift
 
Cassandra.insert_args - Class in org.apache.cassandra.thrift
 
Cassandra.insert_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_args
 
Cassandra.insert_args(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_args
 
Cassandra.insert_args(Cassandra.insert_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_args
Performs a deep copy on other.
Cassandra.insert_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.insert_result - Class in org.apache.cassandra.thrift
 
Cassandra.insert_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_result
 
Cassandra.insert_result(InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_result
 
Cassandra.insert_result(Cassandra.insert_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.insert_result
Performs a deep copy on other.
Cassandra.insert_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.login_args - Class in org.apache.cassandra.thrift
 
Cassandra.login_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.login_args
 
Cassandra.login_args(AuthenticationRequest) - Constructor for class org.apache.cassandra.thrift.Cassandra.login_args
 
Cassandra.login_args(Cassandra.login_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.login_args
Performs a deep copy on other.
Cassandra.login_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.login_result - Class in org.apache.cassandra.thrift
 
Cassandra.login_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.login_result
 
Cassandra.login_result(AuthenticationException, AuthorizationException) - Constructor for class org.apache.cassandra.thrift.Cassandra.login_result
 
Cassandra.login_result(Cassandra.login_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.login_result
Performs a deep copy on other.
Cassandra.login_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.multiget_count_args - Class in org.apache.cassandra.thrift
 
Cassandra.multiget_count_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
Cassandra.multiget_count_args(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
Cassandra.multiget_count_args(Cassandra.multiget_count_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_count_args
Performs a deep copy on other.
Cassandra.multiget_count_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.multiget_count_result - Class in org.apache.cassandra.thrift
 
Cassandra.multiget_count_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
Cassandra.multiget_count_result(Map<ByteBuffer, Integer>, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
Cassandra.multiget_count_result(Cassandra.multiget_count_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_count_result
Performs a deep copy on other.
Cassandra.multiget_count_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.multiget_slice_args - Class in org.apache.cassandra.thrift
 
Cassandra.multiget_slice_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
Cassandra.multiget_slice_args(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
Cassandra.multiget_slice_args(Cassandra.multiget_slice_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
Performs a deep copy on other.
Cassandra.multiget_slice_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.multiget_slice_result - Class in org.apache.cassandra.thrift
 
Cassandra.multiget_slice_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
Cassandra.multiget_slice_result(Map<ByteBuffer, List<ColumnOrSuperColumn>>, InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
Cassandra.multiget_slice_result(Cassandra.multiget_slice_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
Performs a deep copy on other.
Cassandra.multiget_slice_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.Processor - Class in org.apache.cassandra.thrift
 
Cassandra.Processor(Cassandra.Iface) - Constructor for class org.apache.cassandra.thrift.Cassandra.Processor
 
Cassandra.Processor.ProcessFunction - Interface in org.apache.cassandra.thrift
 
Cassandra.remove_args - Class in org.apache.cassandra.thrift
 
Cassandra.remove_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_args
 
Cassandra.remove_args(ByteBuffer, ColumnPath, long, ConsistencyLevel) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_args
 
Cassandra.remove_args(Cassandra.remove_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_args
Performs a deep copy on other.
Cassandra.remove_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.remove_result - Class in org.apache.cassandra.thrift
 
Cassandra.remove_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_result
 
Cassandra.remove_result(InvalidRequestException, UnavailableException, TimedOutException) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_result
 
Cassandra.remove_result(Cassandra.remove_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.remove_result
Performs a deep copy on other.
Cassandra.remove_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.set_keyspace_args - Class in org.apache.cassandra.thrift
 
Cassandra.set_keyspace_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
Cassandra.set_keyspace_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
Cassandra.set_keyspace_args(Cassandra.set_keyspace_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
Performs a deep copy on other.
Cassandra.set_keyspace_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.set_keyspace_result - Class in org.apache.cassandra.thrift
 
Cassandra.set_keyspace_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
Cassandra.set_keyspace_result(InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
Cassandra.set_keyspace_result(Cassandra.set_keyspace_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
Performs a deep copy on other.
Cassandra.set_keyspace_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.system_add_column_family_args - Class in org.apache.cassandra.thrift
 
Cassandra.system_add_column_family_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
Cassandra.system_add_column_family_args(CfDef) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
Cassandra.system_add_column_family_args(Cassandra.system_add_column_family_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
Performs a deep copy on other.
Cassandra.system_add_column_family_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.system_add_column_family_result - Class in org.apache.cassandra.thrift
 
Cassandra.system_add_column_family_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
Cassandra.system_add_column_family_result(String, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
Cassandra.system_add_column_family_result(Cassandra.system_add_column_family_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
Performs a deep copy on other.
Cassandra.system_add_column_family_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.system_add_keyspace_args - Class in org.apache.cassandra.thrift
 
Cassandra.system_add_keyspace_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
Cassandra.system_add_keyspace_args(KsDef) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
Cassandra.system_add_keyspace_args(Cassandra.system_add_keyspace_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
Performs a deep copy on other.
Cassandra.system_add_keyspace_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.system_add_keyspace_result - Class in org.apache.cassandra.thrift
 
Cassandra.system_add_keyspace_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
Cassandra.system_add_keyspace_result(String, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
Cassandra.system_add_keyspace_result(Cassandra.system_add_keyspace_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
Performs a deep copy on other.
Cassandra.system_add_keyspace_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.system_drop_column_family_args - Class in org.apache.cassandra.thrift
 
Cassandra.system_drop_column_family_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
Cassandra.system_drop_column_family_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
Cassandra.system_drop_column_family_args(Cassandra.system_drop_column_family_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
Performs a deep copy on other.
Cassandra.system_drop_column_family_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.system_drop_column_family_result - Class in org.apache.cassandra.thrift
 
Cassandra.system_drop_column_family_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
Cassandra.system_drop_column_family_result(String, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
Cassandra.system_drop_column_family_result(Cassandra.system_drop_column_family_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
Performs a deep copy on other.
Cassandra.system_drop_column_family_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.system_drop_keyspace_args - Class in org.apache.cassandra.thrift
 
Cassandra.system_drop_keyspace_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
Cassandra.system_drop_keyspace_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
Cassandra.system_drop_keyspace_args(Cassandra.system_drop_keyspace_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
Performs a deep copy on other.
Cassandra.system_drop_keyspace_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.system_drop_keyspace_result - Class in org.apache.cassandra.thrift
 
Cassandra.system_drop_keyspace_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
Cassandra.system_drop_keyspace_result(String, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
Cassandra.system_drop_keyspace_result(Cassandra.system_drop_keyspace_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
Performs a deep copy on other.
Cassandra.system_drop_keyspace_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.system_update_column_family_args - Class in org.apache.cassandra.thrift
 
Cassandra.system_update_column_family_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
Cassandra.system_update_column_family_args(CfDef) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
Cassandra.system_update_column_family_args(Cassandra.system_update_column_family_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
Performs a deep copy on other.
Cassandra.system_update_column_family_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.system_update_column_family_result - Class in org.apache.cassandra.thrift
 
Cassandra.system_update_column_family_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
Cassandra.system_update_column_family_result(String, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
Cassandra.system_update_column_family_result(Cassandra.system_update_column_family_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
Performs a deep copy on other.
Cassandra.system_update_column_family_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.system_update_keyspace_args - Class in org.apache.cassandra.thrift
 
Cassandra.system_update_keyspace_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
Cassandra.system_update_keyspace_args(KsDef) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
Cassandra.system_update_keyspace_args(Cassandra.system_update_keyspace_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
Performs a deep copy on other.
Cassandra.system_update_keyspace_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.system_update_keyspace_result - Class in org.apache.cassandra.thrift
 
Cassandra.system_update_keyspace_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
Cassandra.system_update_keyspace_result(String, InvalidRequestException) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
Cassandra.system_update_keyspace_result(Cassandra.system_update_keyspace_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
Performs a deep copy on other.
Cassandra.system_update_keyspace_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.truncate_args - Class in org.apache.cassandra.thrift
 
Cassandra.truncate_args() - Constructor for class org.apache.cassandra.thrift.Cassandra.truncate_args
 
Cassandra.truncate_args(String) - Constructor for class org.apache.cassandra.thrift.Cassandra.truncate_args
 
Cassandra.truncate_args(Cassandra.truncate_args) - Constructor for class org.apache.cassandra.thrift.Cassandra.truncate_args
Performs a deep copy on other.
Cassandra.truncate_args._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Cassandra.truncate_result - Class in org.apache.cassandra.thrift
 
Cassandra.truncate_result() - Constructor for class org.apache.cassandra.thrift.Cassandra.truncate_result
 
Cassandra.truncate_result(InvalidRequestException, UnavailableException) - Constructor for class org.apache.cassandra.thrift.Cassandra.truncate_result
 
Cassandra.truncate_result(Cassandra.truncate_result) - Constructor for class org.apache.cassandra.thrift.Cassandra.truncate_result
Performs a deep copy on other.
Cassandra.truncate_result._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CassandraDaemon - Class in org.apache.cassandra.avro
The Avro analogue to org.apache.cassandra.service.CassandraDaemon.
CassandraDaemon() - Constructor for class org.apache.cassandra.avro.CassandraDaemon
 
CassandraDaemon - Interface in org.apache.cassandra.service
The CassandraDaemon interface captures the lifecycle of a Cassandra daemon that runs on a single node.
CassandraDaemon - Class in org.apache.cassandra.thrift
This class supports two methods for creating a Cassandra node daemon, invoking the class's main method, and using the jsvc wrapper from commons-daemon, (for more information on using this class with the jsvc wrapper, see the Commons Daemon documentation).
CassandraDaemon() - Constructor for class org.apache.cassandra.thrift.CassandraDaemon
 
CassandraServer - Class in org.apache.cassandra.avro
 
CassandraServer() - Constructor for class org.apache.cassandra.avro.CassandraServer
 
CassandraServer - Class in org.apache.cassandra.thrift
 
CassandraServer() - Constructor for class org.apache.cassandra.thrift.CassandraServer
 
cf - Variable in class org.apache.cassandra.db.Row
 
cf - Variable in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
cf_def - Variable in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
cf_def - Variable in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
cf_defs - Variable in class org.apache.cassandra.thrift.KsDef
 
CfDef - Class in org.apache.cassandra.thrift
 
CfDef() - Constructor for class org.apache.cassandra.thrift.CfDef
 
CfDef(String, String) - Constructor for class org.apache.cassandra.thrift.CfDef
 
CfDef(CfDef) - Constructor for class org.apache.cassandra.thrift.CfDef
Performs a deep copy on other.
CfDef._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
cfId - Variable in class org.apache.cassandra.config.CFMetaData
 
cfId - Variable in exception org.apache.cassandra.db.UnserializableColumnFamilyException
 
CFMetaData - Class in org.apache.cassandra.config
 
CFMetaData(String, String, ColumnFamilyType, AbstractType, AbstractType, String, double, double, double, int, AbstractType, int, int, int, int, int, Integer, Double, Map<ByteBuffer, ColumnDefinition>) - Constructor for class org.apache.cassandra.config.CFMetaData
 
cfMetaData() - Method in class org.apache.cassandra.config.KSMetaData
 
cfName - Variable in class org.apache.cassandra.config.CFMetaData
 
cfname - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
cfName - Variable in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
cfname - Variable in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
cfs - Variable in class org.apache.cassandra.db.Memtable
 
cfs - Variable in class org.apache.cassandra.io.sstable.SSTableWriter.Builder
 
cfType - Variable in class org.apache.cassandra.config.CFMetaData
 
CHAR_MASK - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
check_schema_agreement() - Method in class org.apache.cassandra.avro.CassandraServer
 
checkAllColumnFamilies() - Method in class org.apache.cassandra.db.CompactionManager
 
checkHealth() - Static method in class org.apache.cassandra.db.SystemTable
One of three things will happen if you try to read the system table: 1.
checkKeyspaceAndLoginAuthorized(Permission) - Method in class org.apache.cassandra.avro.CassandraServer
 
checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Check for validity of the output-specification for the job.
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Deprecated. 
CHUNK_SIZE - Static variable in class org.apache.cassandra.streaming.FileStreamTask
 
classForName(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
cleanup() - Method in class org.apache.cassandra.io.sstable.SSTableDeletingReference
 
cleanupIndexEntry(ColumnFamilyStore, ByteBuffer, IColumn) - Static method in class org.apache.cassandra.db.Table
 
cleanupJob(JobContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
clear() - Method in class org.apache.cassandra.cache.InstrumentedCache
 
clear() - Method in class org.apache.cassandra.db.ColumnFamily
 
clear(String) - Static method in class org.apache.cassandra.db.Table
 
clear() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
clear() - Static method in class org.apache.cassandra.net.sink.SinkManager
 
clear() - Method in exception org.apache.cassandra.thrift.AuthenticationException
 
clear() - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
clear() - Method in exception org.apache.cassandra.thrift.AuthorizationException
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.login_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
clear() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
clear() - Method in class org.apache.cassandra.thrift.CfDef
 
clear() - Method in class org.apache.cassandra.thrift.Column
 
clear() - Method in class org.apache.cassandra.thrift.ColumnDef
 
clear() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
clear() - Method in class org.apache.cassandra.thrift.ColumnParent
 
clear() - Method in class org.apache.cassandra.thrift.ColumnPath
 
clear() - Method in class org.apache.cassandra.thrift.Deletion
 
clear() - Method in class org.apache.cassandra.thrift.IndexClause
 
clear() - Method in class org.apache.cassandra.thrift.IndexExpression
 
clear() - Method in exception org.apache.cassandra.thrift.InvalidRequestException
 
clear() - Method in class org.apache.cassandra.thrift.KeyCount
 
clear() - Method in class org.apache.cassandra.thrift.KeyRange
 
clear() - Method in class org.apache.cassandra.thrift.KeySlice
 
clear() - Method in class org.apache.cassandra.thrift.KsDef
 
clear() - Method in class org.apache.cassandra.thrift.Mutation
 
clear() - Method in exception org.apache.cassandra.thrift.NotFoundException
 
clear() - Method in class org.apache.cassandra.thrift.SlicePredicate
 
clear() - Method in class org.apache.cassandra.thrift.SliceRange
 
clear() - Method in class org.apache.cassandra.thrift.SuperColumn
 
clear() - Method in exception org.apache.cassandra.thrift.TimedOutException
 
clear() - Method in class org.apache.cassandra.thrift.TokenRange
 
clear() - Method in exception org.apache.cassandra.thrift.UnavailableException
 
clear() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
clear() - Method in class org.apache.cassandra.utils.BloomFilter
 
clear() - Method in class org.apache.cassandra.utils.BoundedStatsDeque
 
clear() - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
clear(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
clears a bit, allowing access beyond the current set size without changing the size.
clear(int, int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Clears a range of bits.
clear(long, long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Clears a range of bits.
clearEndpointCache() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
clearGlobalSnapshot() - Method in class org.apache.cassandra.tools.ClusterCmd
Remove all the existing snapshots from all (live) nodes in the cluster
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.
clearTableDefinition(KSMetaData, UUID) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
clearUnsafe() - Method in class org.apache.cassandra.io.sstable.SSTableTracker
 
clearUnsafe() - Method in class org.apache.cassandra.locator.TokenMetadata
used by tests
CLibrary - Class in org.apache.cassandra.utils
 
CliClient - Class in org.apache.cassandra.cli
 
CliClient(CliSessionState, Cassandra.Client) - Constructor for class org.apache.cassandra.cli.CliClient
 
CliClient.Function - Enum in org.apache.cassandra.cli
Available value conversion functions Used by convertValueByFunction(Tree functionCall) method
CliCompiler - Class in org.apache.cassandra.cli
 
CliCompiler() - Constructor for class org.apache.cassandra.cli.CliCompiler
 
CliCompiler.ANTLRNoCaseStringStream - Class in org.apache.cassandra.cli
 
CliCompiler.ANTLRNoCaseStringStream(String) - Constructor for class org.apache.cassandra.cli.CliCompiler.ANTLRNoCaseStringStream
 
CliCompleter - Class in org.apache.cassandra.cli
 
CliCompleter() - Constructor for class org.apache.cassandra.cli.CliCompleter
 
clientMode - Variable in class org.apache.cassandra.db.migration.Migration
 
clientState - Variable in class org.apache.cassandra.avro.CassandraServer
 
ClientState - Class in org.apache.cassandra.service
A container for per-client, thread-local state that Avro/Thrift threads must hold.
ClientState() - Constructor for class org.apache.cassandra.service.ClientState
Construct a new, empty ClientState: can be reused after logout() or reset().
clientState - Variable in class org.apache.cassandra.thrift.CassandraServer
 
CliMain - Class in org.apache.cassandra.cli
Cassandra Command Line Interface (CLI) Main
CliMain() - Constructor for class org.apache.cassandra.cli.CliMain
 
CliOptions - Class in org.apache.cassandra.cli
Used to process, and act upon the arguments passed to the CLI.
CliOptions() - Constructor for class org.apache.cassandra.cli.CliOptions
 
CliSessionState - Class in org.apache.cassandra.cli
Used to hold the state for the CLI.
CliSessionState() - Constructor for class org.apache.cassandra.cli.CliSessionState
 
CliUserHelp - Class in org.apache.cassandra.cli
 
CliUserHelp() - Constructor for class org.apache.cassandra.cli.CliUserHelp
 
CliUserHelp.ColumnFamilyArgument - Enum in org.apache.cassandra.cli
 
CliUtils - Class in org.apache.cassandra.cli
 
CliUtils() - Constructor for class org.apache.cassandra.cli.CliUtils
 
clone(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
clone() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
cloneAfterAllLeft() - Method in class org.apache.cassandra.locator.TokenMetadata
Create a copy of TokenMetadata with tokenToEndpointMap reflecting situation after all current leave operations have finished.
cloneMe() - Method in class org.apache.cassandra.db.ColumnFamily
 
cloneMe() - Method in class org.apache.cassandra.db.SuperColumn
 
cloneMeShallow() - Method in class org.apache.cassandra.db.ColumnFamily
 
cloneMeShallow() - Method in class org.apache.cassandra.db.SuperColumn
 
cloneOnlyTokenMap() - Method in class org.apache.cassandra.locator.TokenMetadata
Create a copy of TokenMetadata with only tokenToEndpointMap.
close() - Method in interface org.apache.cassandra.db.columniterator.IColumnIterator
clean up any open resources
close() - Method in class org.apache.cassandra.db.columniterator.SimpleAbstractColumnIterator
 
close() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
close() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
close() - Method in class org.apache.cassandra.db.filter.AbstractColumnIterator
 
close() - Method in class org.apache.cassandra.db.RowIterator
 
close() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
close() - Method in class org.apache.cassandra.io.CompactionIterator
 
close() - Method in class org.apache.cassandra.io.sstable.KeyIterator
 
close() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
close() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
close() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
close() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
close() - Method in class org.apache.cassandra.streaming.StreamOutSession
 
close() - Method in class org.apache.cassandra.tools.ClusterCmd
 
close() - Method in class org.apache.cassandra.tools.NodeProbe
 
CloseableIterator<T> - Interface in org.apache.cassandra.utils
 
closeAndOpenReader() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
closeAndOpenReader(long) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
closeIfFinished() - Method in class org.apache.cassandra.streaming.StreamInSession
 
closeQuietly(Closeable) - Static method in class org.apache.cassandra.io.util.FileUtils
 
cluster_name - Variable in class org.apache.cassandra.config.Config
 
ClusterCmd - Class in org.apache.cassandra.tools
JMX cluster wide operations for Cassandra.
ClusterCmd(String, int) - Constructor for class org.apache.cassandra.tools.ClusterCmd
Creates a ClusterProbe using the specified JMX host and port.
ClusterCmd(String) - Constructor for class org.apache.cassandra.tools.ClusterCmd
Creates a ClusterProbe using the specified JMX host and default port.
CMD_TYPE_GET_SLICE - Static variable in class org.apache.cassandra.db.ReadCommand
 
CMD_TYPE_GET_SLICE_BY_NAMES - Static variable in class org.apache.cassandra.db.ReadCommand
 
CollatingOrderPreservingPartitioner - Class in org.apache.cassandra.dht
 
CollatingOrderPreservingPartitioner() - Constructor for class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
collectCollatedColumns(ColumnFamily, Iterator<IColumn>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
collectReducedColumns(IColumnContainer, Iterator<IColumn>, int) - Method in interface org.apache.cassandra.db.filter.IFilter
collects columns from reducedColumns into returnCF.
collectReducedColumns(IColumnContainer, Iterator<IColumn>, int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
collectReducedColumns(IColumnContainer, Iterator<IColumn>, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
Column - Class in org.apache.cassandra.db
Column is immutable, which prevents all kinds of confusion in a multithreaded environment.
Column(ByteBuffer, ByteBuffer) - Constructor for class org.apache.cassandra.db.Column
 
Column(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.Column
 
column(ByteBuffer) - Static method in class org.apache.cassandra.db.filter.QueryPath
 
column - Variable in class org.apache.cassandra.thrift.Cassandra.insert_args
 
Column - Class in org.apache.cassandra.thrift
Basic unit of data within a ColumnFamily.
Column() - Constructor for class org.apache.cassandra.thrift.Column
 
Column(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.thrift.Column
 
Column(Column) - Constructor for class org.apache.cassandra.thrift.Column
Performs a deep copy on other.
column - Variable in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
column - Variable in class org.apache.cassandra.thrift.ColumnPath
 
Column._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
column_families - Variable in class org.apache.cassandra.config.RawKeyspace
Deprecated.  
column_family - Variable in class org.apache.cassandra.db.IndexScanCommand
 
column_family - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
column_family - Variable in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
column_family - Variable in class org.apache.cassandra.thrift.ColumnParent
 
column_family - Variable in class org.apache.cassandra.thrift.ColumnPath
 
column_index_size_in_kb - Variable in class org.apache.cassandra.config.Config
 
column_metadata - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
column_metadata - Variable in class org.apache.cassandra.thrift.CfDef
 
column_name - Variable in class org.apache.cassandra.thrift.IndexExpression
 
column_names - Variable in class org.apache.cassandra.thrift.SlicePredicate
 
column_or_supercolumn - Variable in class org.apache.cassandra.thrift.Mutation
 
column_parent - Variable in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
column_parent - Variable in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
column_parent - Variable in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
column_parent - Variable in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
column_parent - Variable in class org.apache.cassandra.thrift.Cassandra.insert_args
 
column_parent - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
column_parent - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
column_path - Variable in class org.apache.cassandra.thrift.Cassandra.get_args
 
column_path - Variable in class org.apache.cassandra.thrift.Cassandra.remove_args
 
column_predicate - Variable in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
column_type - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
column_type - Variable in class org.apache.cassandra.thrift.CfDef
 
columnCount() - Method in class org.apache.cassandra.io.AbstractCompactedRow
 
columnCount() - Method in class org.apache.cassandra.io.LazilyCompactedRow
 
columnCount() - Method in class org.apache.cassandra.io.PrecompactedRow
 
columnCount - Variable in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
ColumnDef - Class in org.apache.cassandra.thrift
 
ColumnDef() - Constructor for class org.apache.cassandra.thrift.ColumnDef
 
ColumnDef(ByteBuffer, String) - Constructor for class org.apache.cassandra.thrift.ColumnDef
 
ColumnDef(ColumnDef) - Constructor for class org.apache.cassandra.thrift.ColumnDef
Performs a deep copy on other.
ColumnDef._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ColumnDefinition - Class in org.apache.cassandra.config
 
ColumnDefinition(ByteBuffer, String, IndexType, String) - Constructor for class org.apache.cassandra.config.ColumnDefinition
 
ColumnFamily - Class in org.apache.cassandra.db
 
ColumnFamily(ColumnFamilyType, AbstractType, AbstractType, Integer) - Constructor for class org.apache.cassandra.db.ColumnFamily
 
columnFamily - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
columnFamily - Variable in class org.apache.cassandra.db.TruncateResponse
 
columnFamily - Variable in class org.apache.cassandra.db.Truncation
 
ColumnFamilyInputFormat - Class in org.apache.cassandra.hadoop
Hadoop InputFormat allowing map/reduce against Cassandra rows within one ColumnFamily.
ColumnFamilyInputFormat() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
 
columnFamilyName - Variable in class org.apache.cassandra.db.filter.QueryPath
 
ColumnFamilyNotDefinedException - Exception in org.apache.cassandra.db
 
ColumnFamilyNotDefinedException(String) - Constructor for exception org.apache.cassandra.db.ColumnFamilyNotDefinedException
 
ColumnFamilyOutputFormat - Class in org.apache.cassandra.hadoop
The ColumnFamilyOutputFormat acts as a Hadoop-specific OutputFormat that allows reduce tasks to store keys (and corresponding values) as Cassandra rows (and respective columns) in a given ColumnFamily.
ColumnFamilyOutputFormat() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
 
ColumnFamilyOutputFormat.NullOutputCommitter - Class in org.apache.cassandra.hadoop
An OutputCommitter that does nothing.
ColumnFamilyOutputFormat.NullOutputCommitter() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
ColumnFamilyRecordReader - Class in org.apache.cassandra.hadoop
 
ColumnFamilyRecordReader() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
ColumnFamilySerializer - Class in org.apache.cassandra.db
 
ColumnFamilySerializer() - Constructor for class org.apache.cassandra.db.ColumnFamilySerializer
 
ColumnFamilySplit - Class in org.apache.cassandra.hadoop
 
ColumnFamilySplit(String, String, String[]) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
 
ColumnFamilySplit() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
 
ColumnFamilyStore - Class in org.apache.cassandra.db
 
ColumnFamilyStoreMBean - Interface in org.apache.cassandra.db
The MBean interface for ColumnFamilyStore
columnFamilyStores - Variable in class org.apache.cassandra.db.Table
 
ColumnFamilyType - Enum in org.apache.cassandra.db
column family type enum
ColumnIndexer - Class in org.apache.cassandra.db
Help to create an index for a column family based on size of columns
ColumnIndexer() - Constructor for class org.apache.cassandra.db.ColumnIndexer
 
columnName - Variable in class org.apache.cassandra.db.filter.QueryPath
 
columnNames - Variable in class org.apache.cassandra.db.SliceByNamesReadCommand
 
ColumnOrSuperColumn - Class in org.apache.cassandra.thrift
Methods for fetching rows/records from Cassandra will return either a single instance of ColumnOrSuperColumn or a list of ColumnOrSuperColumns (get_slice()).
ColumnOrSuperColumn() - Constructor for class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
ColumnOrSuperColumn(ColumnOrSuperColumn) - Constructor for class org.apache.cassandra.thrift.ColumnOrSuperColumn
Performs a deep copy on other.
ColumnOrSuperColumn._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ColumnParent - Class in org.apache.cassandra.thrift
ColumnParent is used when selecting groups of columns from the same ColumnFamily.
ColumnParent() - Constructor for class org.apache.cassandra.thrift.ColumnParent
 
ColumnParent(String) - Constructor for class org.apache.cassandra.thrift.ColumnParent
 
ColumnParent(ColumnParent) - Constructor for class org.apache.cassandra.thrift.ColumnParent
Performs a deep copy on other.
ColumnParent._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ColumnPath - Class in org.apache.cassandra.thrift
The ColumnPath is the path to a single column in Cassandra.
ColumnPath() - Constructor for class org.apache.cassandra.thrift.ColumnPath
 
ColumnPath(String) - Constructor for class org.apache.cassandra.thrift.ColumnPath
 
ColumnPath(ColumnPath) - Constructor for class org.apache.cassandra.thrift.ColumnPath
Performs a deep copy on other.
ColumnPath._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
columns - Variable in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
columns - Variable in class org.apache.cassandra.db.filter.NamesQueryFilter
 
columns - Variable in class org.apache.cassandra.thrift.KeySlice
 
columns - Variable in class org.apache.cassandra.thrift.SuperColumn
 
ColumnSerializer - Class in org.apache.cassandra.db
 
ColumnSerializer() - Constructor for class org.apache.cassandra.db.ColumnSerializer
 
ColumnSortedMap - Class in org.apache.cassandra.io.util
Facade over a DataInput that contains IColumns in sorted order.
ColumnSortedMap(Comparator<ByteBuffer>, ColumnSerializer, DataInput, int) - Constructor for class org.apache.cassandra.io.util.ColumnSortedMap
 
commandType - Variable in class org.apache.cassandra.db.ReadCommand
 
comment - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
comment - Variable in class org.apache.cassandra.thrift.CfDef
 
CommitLog - Class in org.apache.cassandra.db.commitlog
 
commitlog_directory - Variable in class org.apache.cassandra.config.Config
 
commitlog_rotation_threshold_in_mb - Variable in class org.apache.cassandra.config.Config
 
commitlog_sync - Variable in class org.apache.cassandra.config.Config
 
commitlog_sync_batch_window_in_ms - Variable in class org.apache.cassandra.config.Config
 
commitlog_sync_period_in_ms - Variable in class org.apache.cassandra.config.Config
 
CommitLogHeader - Class in org.apache.cassandra.db.commitlog
 
CommitLogSegment - Class in org.apache.cassandra.db.commitlog
 
CommitLogSegment() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegment
 
CommitLogSegment.CommitLogContext - Class in org.apache.cassandra.db.commitlog
 
CommitLogSegment.CommitLogContext(long) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogContext
 
commitTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
compact(Token) - Method in class org.apache.cassandra.utils.MerkleTree
Compacts the smallest subranges evenly split by the given token into a single range.
COMPACTED_MARKER - Static variable in class org.apache.cassandra.io.sstable.Component
 
CompactEndpointSerializationHelper - Class in org.apache.cassandra.net
 
CompactEndpointSerializationHelper() - Constructor for class org.apache.cassandra.net.CompactEndpointSerializationHelper
 
compaction_thread_priority - Variable in class org.apache.cassandra.config.Config
 
CompactionIterator - Class in org.apache.cassandra.io
 
CompactionIterator(ColumnFamilyStore, Iterable<SSTableReader>, int, boolean) - Constructor for class org.apache.cassandra.io.CompactionIterator
 
CompactionIterator(ColumnFamilyStore, Iterator, int, boolean) - Constructor for class org.apache.cassandra.io.CompactionIterator
 
CompactionManager - Class in org.apache.cassandra.db
 
CompactionManager() - Constructor for class org.apache.cassandra.db.CompactionManager
 
CompactionManagerMBean - Interface in org.apache.cassandra.db
 
comparator - Variable in class org.apache.cassandra.config.CFMetaData
 
comparator - Static variable in class org.apache.cassandra.db.DecoratedKey
 
comparator() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
comparator_type - Variable in class org.apache.cassandra.thrift.CfDef
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
compare(Token, Token) - Static method in class org.apache.cassandra.dht.Range
 
compare(File, File) - Method in class org.apache.cassandra.io.util.FileUtils.FileComparator
 
compare(byte[], ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
compare(ByteBuffer, byte[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
compare_subcolumns_with - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
compare_with - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
 
compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
 
compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
compares two endpoints in relation to the target endpoint, returning as Comparator.compare would
compareEndpointStartup(InetAddress, InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
determine which endpoint started up earlier
compareTo(DecoratedKey) - Method in class org.apache.cassandra.db.DecoratedKey
 
compareTo(Memtable) - Method in class org.apache.cassandra.db.Memtable
Compares two Memtable based on creation time.
compareTo(Token<BigInteger>) - Method in class org.apache.cassandra.dht.BigIntegerToken
 
compareTo(Token<byte[]>) - Method in class org.apache.cassandra.dht.BytesToken
 
compareTo(Token<ByteBuffer>) - Method in class org.apache.cassandra.dht.LocalToken
 
compareTo(Range) - Method in class org.apache.cassandra.dht.Range
 
compareTo(Token<String>) - Method in class org.apache.cassandra.dht.StringToken
 
compareTo(Token<T>) - Method in class org.apache.cassandra.dht.Token
This determines the comparison for node destination purposes.
compareTo(GossipDigest) - Method in class org.apache.cassandra.gms.GossipDigest
 
compareTo(VersionedValue) - Method in class org.apache.cassandra.gms.VersionedValue
 
compareTo(IndexSummary.KeyPosition) - Method in class org.apache.cassandra.io.sstable.IndexSummary.KeyPosition
 
compareTo(SSTableIdentityIterator) - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
compareTo(SSTableReader) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
compareTo(AuthenticationException) - Method in exception org.apache.cassandra.thrift.AuthenticationException
 
compareTo(AuthenticationRequest) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
compareTo(AuthorizationException) - Method in exception org.apache.cassandra.thrift.AuthorizationException
 
compareTo(Cassandra.batch_mutate_args) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
compareTo(Cassandra.batch_mutate_result) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
compareTo(Cassandra.describe_cluster_name_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
 
compareTo(Cassandra.describe_cluster_name_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
compareTo(Cassandra.describe_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
compareTo(Cassandra.describe_keyspace_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
compareTo(Cassandra.describe_keyspaces_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
 
compareTo(Cassandra.describe_keyspaces_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
compareTo(Cassandra.describe_partitioner_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
 
compareTo(Cassandra.describe_partitioner_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
compareTo(Cassandra.describe_ring_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
compareTo(Cassandra.describe_ring_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
compareTo(Cassandra.describe_schema_versions_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
 
compareTo(Cassandra.describe_schema_versions_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
compareTo(Cassandra.describe_snitch_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
 
compareTo(Cassandra.describe_snitch_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
compareTo(Cassandra.describe_splits_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
compareTo(Cassandra.describe_splits_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
compareTo(Cassandra.describe_version_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
 
compareTo(Cassandra.describe_version_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
compareTo(Cassandra.get_args) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
compareTo(Cassandra.get_count_args) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
compareTo(Cassandra.get_count_result) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
compareTo(Cassandra.get_indexed_slices_args) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
compareTo(Cassandra.get_indexed_slices_result) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
compareTo(Cassandra.get_range_slices_args) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
compareTo(Cassandra.get_range_slices_result) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
compareTo(Cassandra.get_result) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
compareTo(Cassandra.get_slice_args) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
compareTo(Cassandra.get_slice_result) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
compareTo(Cassandra.insert_args) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
compareTo(Cassandra.insert_result) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
compareTo(Cassandra.login_args) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
 
compareTo(Cassandra.login_result) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
compareTo(Cassandra.multiget_count_args) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
compareTo(Cassandra.multiget_count_result) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
compareTo(Cassandra.multiget_slice_args) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
compareTo(Cassandra.multiget_slice_result) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
compareTo(Cassandra.remove_args) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
compareTo(Cassandra.remove_result) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
compareTo(Cassandra.set_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
compareTo(Cassandra.set_keyspace_result) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
compareTo(Cassandra.system_add_column_family_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
compareTo(Cassandra.system_add_column_family_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
compareTo(Cassandra.system_add_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
compareTo(Cassandra.system_add_keyspace_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
compareTo(Cassandra.system_drop_column_family_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
compareTo(Cassandra.system_drop_column_family_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
compareTo(Cassandra.system_drop_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
compareTo(Cassandra.system_drop_keyspace_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
compareTo(Cassandra.system_update_column_family_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
compareTo(Cassandra.system_update_column_family_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
compareTo(Cassandra.system_update_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
compareTo(Cassandra.system_update_keyspace_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
compareTo(Cassandra.truncate_args) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
compareTo(Cassandra.truncate_result) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
compareTo(CfDef) - Method in class org.apache.cassandra.thrift.CfDef
 
compareTo(Column) - Method in class org.apache.cassandra.thrift.Column
 
compareTo(ColumnDef) - Method in class org.apache.cassandra.thrift.ColumnDef
 
compareTo(ColumnOrSuperColumn) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
compareTo(ColumnParent) - Method in class org.apache.cassandra.thrift.ColumnParent
 
compareTo(ColumnPath) - Method in class org.apache.cassandra.thrift.ColumnPath
 
compareTo(Deletion) - Method in class org.apache.cassandra.thrift.Deletion
 
compareTo(IndexClause) - Method in class org.apache.cassandra.thrift.IndexClause
 
compareTo(IndexExpression) - Method in class org.apache.cassandra.thrift.IndexExpression
 
compareTo(InvalidRequestException) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
 
compareTo(KeyCount) - Method in class org.apache.cassandra.thrift.KeyCount
 
compareTo(KeyRange) - Method in class org.apache.cassandra.thrift.KeyRange
 
compareTo(KeySlice) - Method in class org.apache.cassandra.thrift.KeySlice
 
compareTo(KsDef) - Method in class org.apache.cassandra.thrift.KsDef
 
compareTo(Mutation) - Method in class org.apache.cassandra.thrift.Mutation
 
compareTo(NotFoundException) - Method in exception org.apache.cassandra.thrift.NotFoundException
 
compareTo(SlicePredicate) - Method in class org.apache.cassandra.thrift.SlicePredicate
 
compareTo(SliceRange) - Method in class org.apache.cassandra.thrift.SliceRange
 
compareTo(SuperColumn) - Method in class org.apache.cassandra.thrift.SuperColumn
 
compareTo(TimedOutException) - Method in exception org.apache.cassandra.thrift.TimedOutException
 
compareTo(TokenRange) - Method in class org.apache.cassandra.thrift.TokenRange
 
compareTo(UnavailableException) - Method in exception org.apache.cassandra.thrift.UnavailableException
 
compareUnsigned(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
compareUnsigned(byte[], byte[], int, int, int, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
compileQuery(String) - Static method in class org.apache.cassandra.cli.CliCompiler
 
complete() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
complete(String) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile.Builder
Called after all potential boundaries have been added to apply this Builder to a concrete file on disk.
complete(String) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
Called after all potential boundaries have been added to apply this Builder to a concrete file on disk.
complete() - Method in class org.apache.cassandra.service.AntiEntropyService.Validator
Registers the newly created tree for rendezvous in Stage.ANTIENTROPY.
completedTaskCount - Variable in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
Component - Class in org.apache.cassandra.io.sstable
SSTables are made up of multiple components in separate files.
Component(Component.Type) - Constructor for class org.apache.cassandra.io.sstable.Component
 
Component(Component.Type, int) - Constructor for class org.apache.cassandra.io.sstable.Component
 
component - Variable in class org.apache.cassandra.streaming.PendingFile
 
COMPONENT_DATA - Static variable in class org.apache.cassandra.io.sstable.SSTable
 
COMPONENT_FILTER - Static variable in class org.apache.cassandra.io.sstable.SSTable
 
COMPONENT_INDEX - Static variable in class org.apache.cassandra.io.sstable.SSTable
 
COMPONENT_STATS - Static variable in class org.apache.cassandra.io.sstable.SSTable
 
components - Variable in class org.apache.cassandra.io.sstable.SSTable
 
components - Variable in class org.apache.cassandra.io.sstable.SSTableDeletingReference
 
COMPRESSION - Static variable in class org.apache.cassandra.net.ProtocolHeader
 
computeNext() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
computeNext() - Method in class org.apache.cassandra.io.sstable.KeyIterator
 
computeNext() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRangeIterator
Find the next TreeRange.
computeNext() - Method in class org.apache.cassandra.utils.ReducingIterator
 
concurrent_reads - Variable in class org.apache.cassandra.config.Config
 
concurrent_writes - Variable in class org.apache.cassandra.config.Config
 
condition - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
condition - Variable in class org.apache.cassandra.service.ReadCallback
 
condition - Variable in class org.apache.cassandra.service.TruncateResponseHandler
 
Config - Class in org.apache.cassandra.config
 
Config() - Constructor for class org.apache.cassandra.config.Config
 
Config.CommitLogSync - Enum in org.apache.cassandra.config
 
Config.DiskAccessMode - Enum in org.apache.cassandra.config
 
Config.RequestSchedulerId - Enum in org.apache.cassandra.config
 
ConfigHelper - Class in org.apache.cassandra.hadoop
 
ConfigHelper() - Constructor for class org.apache.cassandra.hadoop.ConfigHelper
 
configOptions - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
ConfigurationException - Exception in org.apache.cassandra.config
 
ConfigurationException(String) - Constructor for exception org.apache.cassandra.config.ConfigurationException
 
ConfigurationException(String, Exception) - Constructor for exception org.apache.cassandra.config.ConfigurationException
 
confirmReplication(InetAddress) - Method in class org.apache.cassandra.service.StorageService
 
connect(String, int) - Static method in class org.apache.cassandra.cli.CliMain
Establish a thrift connection to cassandra instance
consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.get_args
 
consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.insert_args
 
consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
consistency_level - Variable in class org.apache.cassandra.thrift.Cassandra.remove_args
 
consistencyLevel - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
ConsistencyLevel - Enum in org.apache.cassandra.thrift
The ConsistencyLevel is an enum that controls both read and write behavior based on in your storage-conf.xml.
CONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
 
Constants - Class in org.apache.cassandra.thrift
 
Constants() - Constructor for class org.apache.cassandra.thrift.Constants
 
construct(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
Constructs an instance of the given class, which must have a no-arg constructor.
constructStreamHeader(StreamHeader, boolean) - Method in class org.apache.cassandra.net.MessagingService
 
contains(Token) - Method in class org.apache.cassandra.dht.AbstractBounds
 
contains(Token) - Method in class org.apache.cassandra.dht.Bounds
 
contains(Token, Token, Token) - Static method in class org.apache.cassandra.dht.Range
 
contains(Range) - Method in class org.apache.cassandra.dht.Range
 
contains(Token) - Method in class org.apache.cassandra.dht.Range
Helps determine if a given point on the DHT ring is contained in the range in question.
containsKey(Object) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
containsKey(K) - Method in class org.apache.cassandra.utils.ExpiringMap
 
containsValue(Object) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
contents() - Method in class org.apache.cassandra.db.Memtable
 
Context - Class in org.apache.cassandra.concurrent
Context object adding a collection of key/value pairs into ThreadLocalContext.
Context() - Constructor for class org.apache.cassandra.concurrent.Context
 
Converter - Class in org.apache.cassandra.config
Deprecated. Yaml configuration for Keyspaces and ColumnFamilies is deprecated in 0.7
Converter() - Constructor for class org.apache.cassandra.config.Converter
Deprecated.  
convertFromDiskFormat(ByteBuffer) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
convertFromDiskFormat(ByteBuffer) - Method in interface org.apache.cassandra.dht.IPartitioner
 
convertFromDiskFormat(ByteBuffer) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
convertFromDiskFormat(ByteBuffer) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
convertFromDiskFormat(ByteBuffer) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
convertOldStrategyName(String) - Static method in class org.apache.cassandra.config.KSMetaData
 
convertToAvro(CFMetaData) - Static method in class org.apache.cassandra.config.CFMetaData
 
convertToAvro(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
 
convertToThrift(CFMetaData) - Static method in class org.apache.cassandra.config.CFMetaData
 
convict(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
This method is part of IFailureDetectionEventListener interface.
convict(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetectionEventListener
Convict the specified endpoint.
convict(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureNotification
 
convict(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
called from gossiper when it notices a node is not responding.
copy() - Method in class org.apache.cassandra.db.ReadCommand
 
copy() - Method in class org.apache.cassandra.db.SliceByNamesReadCommand
 
copy() - Method in class org.apache.cassandra.db.SliceFromReadCommand
 
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.thrift.IndexClause
 
count - Variable in class org.apache.cassandra.thrift.KeyCount
 
count - Variable in class org.apache.cassandra.thrift.KeyRange
 
count - Variable in class org.apache.cassandra.thrift.SliceRange
 
countPendingHints() - Method in class org.apache.cassandra.db.HintedHandOffManager
 
countPendingHints() - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
List all the endpoints that this node has hints for, and count the number of hints for each such endpoint.
create(Integer) - Static method in class org.apache.cassandra.db.ColumnFamily
 
create(String, String) - Static method in class org.apache.cassandra.db.ColumnFamily
 
create(CFMetaData) - Static method in class org.apache.cassandra.db.ColumnFamily
 
create(String) - Static method in enum org.apache.cassandra.db.ColumnFamilyType
 
create() - Static method in class org.apache.cassandra.locator.EndpointSnitchInfo
 
create(Collection<InetAddress>, Multimap<InetAddress, InetAddress>, ConsistencyLevel, String) - Static method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
create(Collection<InetAddress>, Multimap<InetAddress, InetAddress>, ConsistencyLevel, String) - Static method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
create(Collection<InetAddress>, Multimap<InetAddress, InetAddress>, ConsistencyLevel, String) - Static method in class org.apache.cassandra.service.WriteResponseHandler
 
create(InetAddress) - Static method in class org.apache.cassandra.service.WriteResponseHandler
 
create(InetAddress, Runnable) - Static method in class org.apache.cassandra.streaming.StreamInSession
 
create(String, InetAddress, Runnable) - Static method in class org.apache.cassandra.streaming.StreamOutSession
 
create(String, InetAddress, long) - Static method in class org.apache.cassandra.streaming.StreamOutSession
 
create(String, InetAddress, long, Runnable) - Static method in class org.apache.cassandra.streaming.StreamOutSession
 
create(X, Y) - Static method in class org.apache.cassandra.utils.Pair
 
createAllDirectories() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
Creates all storage-related directories.
createArray(int, Schema) - Static method in class org.apache.cassandra.io.SerDeUtils
Create a generic array of the given type and size.
createAuthenticatedClient(TSocket, Configuration) - Static method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Return a client based on the given socket that points to the configured keyspace, and is logged in with the configured credentials.
createBuilder(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTableWriter
 
createColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
createColumnFamilyStore(Table, String) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
createColumnFamilyStore(Table, String, IPartitioner, CFMetaData) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
createDataInputStream(ByteBuffer) - Static method in class org.apache.cassandra.io.SerDeUtils
 
createDirectory(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createFile(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createFrom(Token) - Method in class org.apache.cassandra.dht.AbstractBounds
 
createFrom(Token) - Method in class org.apache.cassandra.dht.Bounds
 
createFrom(Token) - Method in class org.apache.cassandra.dht.Range
 
createHardLink(File, File) - Static method in class org.apache.cassandra.utils.CLibrary
Create a hard link for a given file.
createIndexBuilder(ColumnFamilyStore, SortedSet<ByteBuffer>, ReducingKeyIterator) - Method in class org.apache.cassandra.db.Table
 
createLinks(String) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
 
createReplicationStrategy(KSMetaData) - Method in class org.apache.cassandra.db.Table
 
createReplicationStrategy(String, Class<? extends AbstractReplicationStrategy>, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
createReplicationStrategy(String, String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
credentials - Variable in class org.apache.cassandra.thrift.AuthenticationRequest
 
CURRENT_VERSION - Static variable in class org.apache.cassandra.io.sstable.Descriptor
 
CustomTThreadPoolServer - Class in org.apache.cassandra.thrift
Slightly modified version of the Apache Thrift TThreadPoolServer.
CustomTThreadPoolServer(TProcessorFactory, TServerSocket, TTransportFactory, TTransportFactory, TProtocolFactory, TProtocolFactory, CustomTThreadPoolServer.Options, ExecutorService) - Constructor for class org.apache.cassandra.thrift.CustomTThreadPoolServer
 
CustomTThreadPoolServer.Options - Class in org.apache.cassandra.thrift
 
CustomTThreadPoolServer.Options() - Constructor for class org.apache.cassandra.thrift.CustomTThreadPoolServer.Options
 

D

D_COLDEF_INDEXNAME - Static variable in class org.apache.cassandra.avro.CassandraServer
 
D_COLDEF_INDEXTYPE - Static variable in class org.apache.cassandra.avro.CassandraServer
 
DATA - Static variable in class org.apache.cassandra.io.sstable.Component
 
data_file_directories - Variable in class org.apache.cassandra.config.Config
 
DatabaseDescriptor - Class in org.apache.cassandra.config
 
DatabaseDescriptor() - Constructor for class org.apache.cassandra.config.DatabaseDescriptor
 
datacenter(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
DatacenterReadCallback<T> - Class in org.apache.cassandra.service
Datacenter Quorum response handler blocks for a quorum of responses from the local DC
DatacenterReadCallback(IResponseResolver<T>, ConsistencyLevel, String) - Constructor for class org.apache.cassandra.service.DatacenterReadCallback
 
DatacenterSyncWriteResponseHandler - Class in org.apache.cassandra.service
This class blocks for a quorum of responses _in all datacenters_ (CL.EACH_QUORUM).
DatacenterSyncWriteResponseHandler(Collection<InetAddress>, Multimap<InetAddress, InetAddress>, ConsistencyLevel, String) - Constructor for class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
DatacenterWriteResponseHandler - Class in org.apache.cassandra.service
This class blocks for a quorum of responses _in the local datacenter only_ (CL.LOCAL_QUORUM).
DatacenterWriteResponseHandler(Collection<InetAddress>, Multimap<InetAddress, InetAddress>, ConsistencyLevel, String) - Constructor for class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
DataOutputBuffer - Class in org.apache.cassandra.io.util
An implementation of the DataOutputStream interface.
DataOutputBuffer() - Constructor for class org.apache.cassandra.io.util.DataOutputBuffer
 
DataOutputBuffer(int) - Constructor for class org.apache.cassandra.io.util.DataOutputBuffer
 
dataSize - Variable in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
DBConstants - Class in org.apache.cassandra.db
 
DBConstants() - Constructor for class org.apache.cassandra.db.DBConstants
 
deactivate() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
A convenience method to stop and destroy the daemon in one shot.
deactivate() - Method in interface org.apache.cassandra.service.CassandraDaemon
A convenience method to stop and destroy the daemon in one shot.
debug - Variable in class org.apache.cassandra.cli.CliSessionState
 
DebuggableThreadPoolExecutor - Class in org.apache.cassandra.concurrent
 
DebuggableThreadPoolExecutor(String, int) - Constructor for class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
DebuggableThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
decodeKey(IPartitioner, Descriptor, ByteBuffer) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
Conditionally use the deprecated 'IPartitioner.convertFromDiskFormat' method.
decommission() - Method in class org.apache.cassandra.service.StorageService
 
decommission() - Method in interface org.apache.cassandra.service.StorageServiceMBean
transfer this node's data to other machines and remove it from service.
decommission() - Method in class org.apache.cassandra.tools.NodeProbe
 
decompose(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
decomposes a uuid into raw bytes.
DecoratedKey<T extends Token> - Class in org.apache.cassandra.db
Represents a decorated key, handy for certain operations where just working with strings gets slow.
DecoratedKey(T, ByteBuffer) - Constructor for class org.apache.cassandra.db.DecoratedKey
 
decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
decorateKey(ByteBuffer) - Method in interface org.apache.cassandra.dht.IPartitioner
Transform key to object representation of the on-disk format.
decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
decorateTask(Runnable, RunnableScheduledFuture<V>) - Method in class org.apache.cassandra.concurrent.RetryingScheduledThreadPoolExecutor
 
deepCopy() - Method in class org.apache.cassandra.db.Column
 
deepCopy() - Method in class org.apache.cassandra.db.DeletedColumn
 
deepCopy() - Method in class org.apache.cassandra.db.ExpiringColumn
 
deepCopy() - Method in interface org.apache.cassandra.db.IColumn
clones the column, making copies of any underlying byte buffers
deepCopy() - Method in class org.apache.cassandra.db.RowMutation
 
deepCopy() - Method in class org.apache.cassandra.db.SuperColumn
 
deepCopy() - Method in exception org.apache.cassandra.thrift.AuthenticationException
 
deepCopy() - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
deepCopy() - Method in exception org.apache.cassandra.thrift.AuthorizationException
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.login_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
deepCopy() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
deepCopy() - Method in class org.apache.cassandra.thrift.CfDef
 
deepCopy() - Method in class org.apache.cassandra.thrift.Column
 
deepCopy() - Method in class org.apache.cassandra.thrift.ColumnDef
 
deepCopy() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
deepCopy() - Method in class org.apache.cassandra.thrift.ColumnParent
 
deepCopy() - Method in class org.apache.cassandra.thrift.ColumnPath
 
deepCopy() - Method in class org.apache.cassandra.thrift.Deletion
 
deepCopy() - Method in class org.apache.cassandra.thrift.IndexClause
 
deepCopy() - Method in class org.apache.cassandra.thrift.IndexExpression
 
deepCopy() - Method in exception org.apache.cassandra.thrift.InvalidRequestException
 
deepCopy() - Method in class org.apache.cassandra.thrift.KeyCount
 
deepCopy() - Method in class org.apache.cassandra.thrift.KeyRange
 
deepCopy() - Method in class org.apache.cassandra.thrift.KeySlice
 
deepCopy() - Method in class org.apache.cassandra.thrift.KsDef
 
deepCopy() - Method in class org.apache.cassandra.thrift.Mutation
 
deepCopy() - Method in exception org.apache.cassandra.thrift.NotFoundException
 
deepCopy() - Method in class org.apache.cassandra.thrift.SlicePredicate
 
deepCopy() - Method in class org.apache.cassandra.thrift.SliceRange
 
deepCopy() - Method in class org.apache.cassandra.thrift.SuperColumn
 
deepCopy() - Method in exception org.apache.cassandra.thrift.TimedOutException
 
deepCopy() - Method in class org.apache.cassandra.thrift.TokenRange
 
deepCopy() - Method in exception org.apache.cassandra.thrift.UnavailableException
 
deepCopyColumn(IColumn) - Method in class org.apache.cassandra.db.ColumnFamily
Used to force copy an existing column
DEFAULT_BUFFER_SIZE - Static variable in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
DEFAULT_CONCURENCY_LEVEL - Static variable in class org.apache.cassandra.cache.InstrumentedCache
 
DEFAULT_GC_GRACE_SECONDS - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_KEY_CACHE_SAVE_PERIOD_IN_SECONDS - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_KEY_CACHE_SIZE - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MAX_COMPACTION_THRESHOLD - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MEMTABLE_LIFETIME_IN_MINS - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MEMTABLE_OPERATIONS_IN_MILLIONS - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MEMTABLE_THROUGHPUT_IN_MB - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MIN_COMPACTION_THRESHOLD - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_READ_REPAIR_CHANCE - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_ROW_CACHE_SAVE_PERIOD_IN_SECONDS - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_ROW_CACHE_SIZE - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_SYSTEM_MEMTABLE_THROUGHPUT_IN_MB - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_THROTTLE_LIMIT - Static variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
default_validation_class - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
default_validation_class - Variable in class org.apache.cassandra.thrift.CfDef
 
DEFAULT_WEIGHT - Static variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
default_weight - Variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
DefaultDouble - Class in org.apache.cassandra.utils
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
DefaultDouble(double) - Constructor for class org.apache.cassandra.utils.DefaultDouble
 
DefaultInteger - Class in org.apache.cassandra.utils
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
DefaultInteger(int) - Constructor for class org.apache.cassandra.utils.DefaultInteger
 
defaultUser() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
defaultUser() - Method in interface org.apache.cassandra.auth.IAuthenticator
 
defaultUser() - Method in class org.apache.cassandra.auth.SimpleAuthenticator
 
DEFINITION_SCHEMA_COLUMN_NAME - Static variable in class org.apache.cassandra.db.DefsTable
 
DefinitionsAnnounceVerbHandler - Class in org.apache.cassandra.db
 
DefinitionsAnnounceVerbHandler() - Constructor for class org.apache.cassandra.db.DefinitionsAnnounceVerbHandler
 
DefinitionsUpdateResponseVerbHandler - Class in org.apache.cassandra.db
 
DefinitionsUpdateResponseVerbHandler() - Constructor for class org.apache.cassandra.db.DefinitionsUpdateResponseVerbHandler
 
deflate() - Method in class org.apache.cassandra.config.CFMetaData
 
deflate() - Method in class org.apache.cassandra.config.ColumnDefinition
 
deflate() - Method in class org.apache.cassandra.config.KSMetaData
 
defreezeBloomFilter(FileDataInput, boolean) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
De-freeze the bloom filter.
DefsTable - Class in org.apache.cassandra.db
 
DefsTable() - Constructor for class org.apache.cassandra.db.DefsTable
 
delete(int, long) - Method in class org.apache.cassandra.db.ColumnFamily
Deprecated. 
delete(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamily
 
delete(QueryPath, long) - Method in class org.apache.cassandra.db.RowMutation
 
delete(Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.SSTable
We use a ReferenceQueue to manage deleting files that have been compacted and for which no more SSTable references exist.
delete(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
delete(List<String>) - Static method in class org.apache.cassandra.io.util.FileUtils
 
delete(File[]) - Static method in class org.apache.cassandra.io.util.FileUtils
 
DeletedColumn - Class in org.apache.cassandra.db
 
DeletedColumn(ByteBuffer, int, long) - Constructor for class org.apache.cassandra.db.DeletedColumn
 
DeletedColumn(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.DeletedColumn
 
deleteHintsForEndpoint(String) - Method in class org.apache.cassandra.db.HintedHandOffManager
 
deleteHintsForEndpoint(InetAddress) - Method in class org.apache.cassandra.db.HintedHandOffManager
 
deleteHintsForEndpoint(String) - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
Nuke all hints from this node to `ep`.
deleteOnCleanup() - Method in class org.apache.cassandra.io.sstable.SSTableDeletingReference
 
deleteRecursive(File) - Static method in class org.apache.cassandra.io.util.FileUtils
Deletes all files and subdirectories under "dir".
deleteWithConfirm(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
deleteWithConfirm(File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
Deletion - Class in org.apache.cassandra.thrift
 
Deletion() - Constructor for class org.apache.cassandra.thrift.Deletion
 
Deletion(long) - Constructor for class org.apache.cassandra.thrift.Deletion
 
Deletion(Deletion) - Constructor for class org.apache.cassandra.thrift.Deletion
Performs a deep copy on other.
deletion - Variable in class org.apache.cassandra.thrift.Mutation
 
Deletion._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DELETION_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
 
DeletionService - Class in org.apache.cassandra.io
 
DeletionService() - Constructor for class org.apache.cassandra.io.DeletionService
 
DELIMITER - Static variable in class org.apache.cassandra.gms.VersionedValue
 
DELIMITER_STR - Static variable in class org.apache.cassandra.gms.VersionedValue
 
deliverHints(InetAddress) - Method in class org.apache.cassandra.db.HintedHandOffManager
 
deliverHints(String) - Method in class org.apache.cassandra.db.HintedHandOffManager
 
deliverHints(InetAddress) - Method in class org.apache.cassandra.service.StorageService
Deliver hints to the specified node when it has crashed and come back up/ marked as alive after a network partition
deliverHints(String) - Method in class org.apache.cassandra.service.StorageService
 
deliverHints(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
force hint delivery to an endpoint
depth - Variable in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
deque - Variable in class org.apache.cassandra.utils.BoundedStatsDeque
 
desc - Variable in class org.apache.cassandra.io.sstable.SSTableDeletingReference
 
desc - Variable in class org.apache.cassandra.streaming.PendingFile
 
describe_cluster_name() - Method in class org.apache.cassandra.avro.CassandraServer
 
describe_cluster_name(AsyncMethodCallback<Cassandra.AsyncClient.describe_cluster_name_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
describe_cluster_name(AsyncMethodCallback<Cassandra.AsyncClient.describe_cluster_name_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
describe_cluster_name() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
describe_cluster_name() - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
get the cluster name
describe_cluster_name() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_keyspace(CharSequence) - Method in class org.apache.cassandra.avro.CassandraServer
 
describe_keyspace(String, AsyncMethodCallback<Cassandra.AsyncClient.describe_keyspace_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
describe_keyspace(String, AsyncMethodCallback<Cassandra.AsyncClient.describe_keyspace_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
describe_keyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
describe_keyspace(String) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
describe specified keyspace
describe_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_keyspaces() - Method in class org.apache.cassandra.avro.CassandraServer
 
describe_keyspaces(AsyncMethodCallback<Cassandra.AsyncClient.describe_keyspaces_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
describe_keyspaces(AsyncMethodCallback<Cassandra.AsyncClient.describe_keyspaces_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
describe_keyspaces() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
describe_keyspaces() - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
list the defined keyspaces in this cluster
describe_keyspaces() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_partitioner() - Method in class org.apache.cassandra.avro.CassandraServer
 
describe_partitioner(AsyncMethodCallback<Cassandra.AsyncClient.describe_partitioner_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
describe_partitioner(AsyncMethodCallback<Cassandra.AsyncClient.describe_partitioner_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
describe_partitioner() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
describe_partitioner() - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
returns the partitioner used by this cluster
describe_partitioner() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_ring(CharSequence) - Method in class org.apache.cassandra.avro.CassandraServer
 
describe_ring(String, AsyncMethodCallback<Cassandra.AsyncClient.describe_ring_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
describe_ring(String, AsyncMethodCallback<Cassandra.AsyncClient.describe_ring_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
describe_ring(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
describe_ring(String) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
get the token ring: a map of ranges to host addresses, represented as a set of TokenRange instead of a map from range to list of endpoints, because you can't use Thrift structs as map keys: https://issues.apache.org/jira/browse/THRIFT-162 for the same reason, we can't return a set here, even though order is neither important nor predictable.
describe_ring(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_schema_versions(AsyncMethodCallback<Cassandra.AsyncClient.describe_schema_versions_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
describe_schema_versions(AsyncMethodCallback<Cassandra.AsyncClient.describe_schema_versions_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
describe_schema_versions() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
describe_schema_versions() - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
for each schema version present in the cluster, returns a list of nodes at that version.
describe_schema_versions() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_snitch(AsyncMethodCallback<Cassandra.AsyncClient.describe_snitch_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
describe_snitch(AsyncMethodCallback<Cassandra.AsyncClient.describe_snitch_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
describe_snitch() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
describe_snitch() - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
returns the snitch used by this cluster
describe_snitch() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_splits(CharSequence, CharSequence, CharSequence, int) - Method in class org.apache.cassandra.avro.CassandraServer
 
describe_splits(String, String, String, int, AsyncMethodCallback<Cassandra.AsyncClient.describe_splits_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
describe_splits(String, String, String, int, AsyncMethodCallback<Cassandra.AsyncClient.describe_splits_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
describe_splits(String, String, String, int) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
describe_splits(String, String, String, int) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
experimental API for hadoop/parallel query support.
describe_splits(String, String, String, int) - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_version() - Method in class org.apache.cassandra.avro.CassandraServer
 
describe_version(AsyncMethodCallback<Cassandra.AsyncClient.describe_version_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
describe_version(AsyncMethodCallback<Cassandra.AsyncClient.describe_version_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
describe_version() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
describe_version() - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
get the thrift api version
describe_version() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
describeOwnership(List<Token>) - Method in interface org.apache.cassandra.dht.IPartitioner
Calculate the deltas between tokens in the ring in order to compare relative sizes.
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
describeSchemaVersions() - Static method in class org.apache.cassandra.service.StorageProxy
initiate a request/response session with each live node to check whether or not everybody is using the same migration id.
Descriptor - Class in org.apache.cassandra.io.sstable
A SSTable is described by the keyspace and column family it contains data for, a generation (where higher generations contain more recent data) and an alphabetic version string.
Descriptor(File, String, String, int, boolean) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
A descriptor that assumes CURRENT_VERSION.
Descriptor(String, File, String, String, int, boolean) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
 
descriptor - Variable in class org.apache.cassandra.io.sstable.SSTable
 
deserialize(DataInput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserialize(DataInput) - Method in class org.apache.cassandra.db.ColumnSerializer
 
deserialize(DataInputStream) - Static method in class org.apache.cassandra.db.filter.QueryPath
 
deserialize(ByteBuffer) - Static method in class org.apache.cassandra.db.migration.Migration
 
deserialize(DataInputStream) - Method in class org.apache.cassandra.db.RowMutation.RowMutationSerializer
 
deserialize(DataInputStream) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
 
deserialize(DataInputStream) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
 
deserialize(DataInput) - 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(Schema, ByteBuffer, T) - Static method in class org.apache.cassandra.io.SerDeUtils
Deserializes a single object based on the given Schema.
deserialize(FileDataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
deserialize(DataInputStream) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
 
deserialize(DataInputStream) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequestVerbHandler
 
deserialize(DataInputStream) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeResponseVerbHandler
 
deserialize(DataInputStream) - Method in class org.apache.cassandra.streaming.PendingFile.PendingFileSerializer
 
deserialize(DataInputStream) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
deserialize(TDeserializer, TBase, DataInput) - Static method in class org.apache.cassandra.utils.FBUtilities
 
deserializeColumns(DataInput, ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserializeFromSSTableNoColumns(ColumnFamily, DataInput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserializeIndex(FileDataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
Deserialize the index into a structure and return it
deserializeWithSchema(ByteBuffer, T) - Static method in class org.apache.cassandra.io.SerDeUtils
Deserializes a single object as stored along with its Schema by serialize(T).
destroy() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Clean up all resources obtained during the lifetime of the daemon.
destroy() - Method in interface org.apache.cassandra.service.CassandraDaemon
Clean up all resources obtained during the lifetime of the daemon.
DestructivePQIterator<T> - Class in org.apache.cassandra.utils
 
DestructivePQIterator(PriorityQueue<T>) - Constructor for class org.apache.cassandra.utils.DestructivePQIterator
 
details_ - Variable in class org.apache.cassandra.net.Header
 
determineBlockFor(ConsistencyLevel, String) - Method in class org.apache.cassandra.service.DatacenterReadCallback
 
determineBlockFor(String) - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
determineBlockFor(ConsistencyLevel, String) - Method in class org.apache.cassandra.service.ReadCallback
 
determineBlockFor(String) - Method in class org.apache.cassandra.service.WriteResponseHandler
 
diff(IColumn) - Method in class org.apache.cassandra.db.Column
 
diff(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamily
 
diff(ColumnFamily, ColumnFamily) - Static method in class org.apache.cassandra.db.ColumnFamily
 
diff(IColumn) - Method in interface org.apache.cassandra.db.IColumn
 
diff(IColumn) - Method in class org.apache.cassandra.db.SuperColumn
 
difference(MerkleTree, MerkleTree) - Static method in class org.apache.cassandra.utils.MerkleTree
 
differences - Variable in class org.apache.cassandra.service.AntiEntropyService.Differencer
 
digest(ColumnFamily) - Static method in class org.apache.cassandra.db.ColumnFamily
 
digest() - Method in class org.apache.cassandra.db.ReadResponse
 
DigestMismatchException - Exception in org.apache.cassandra.service
 
DigestMismatchException(DecoratedKey, ByteBuffer, ByteBuffer) - Constructor for exception org.apache.cassandra.service.DigestMismatchException
 
directory - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
dirtyString() - Method in class org.apache.cassandra.db.commitlog.CommitLogHeader
 
disableAutoCompaction() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
disableAutoCompaction() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Disable automatic compaction.
disableAutoCompaction() - Method in class org.apache.cassandra.db.CompactionManager
 
discardCompletedSegments(Integer, CommitLogSegment.CommitLogContext) - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
disconnect() - Static method in class org.apache.cassandra.cli.CliMain
Disconnect thrift connection to cassandra instance
disk_access_mode - Variable in class org.apache.cassandra.config.Config
 
dispatch(Runnable) - Method in class org.apache.cassandra.service.AbstractCassandraDaemon.CleaningThreadPool
 
doVerb(Message, String) - Method in class org.apache.cassandra.db.BinaryVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.db.DefinitionsAnnounceVerbHandler
someone is announcing their schema version.
doVerb(Message, String) - Method in class org.apache.cassandra.db.DefinitionsUpdateResponseVerbHandler
someone sent me their data definitions
doVerb(Message, String) - Method in class org.apache.cassandra.db.ReadRepairVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.db.ReadVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.db.RowMutationVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.db.SchemaCheckVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.db.TruncateVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.dht.BootStrapper.BootstrapTokenVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.gms.GossipDigestAck2VerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.gms.GossipDigestAckVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.gms.GossipDigestSynVerbHandler
 
doVerb(Message, String) - Method in interface org.apache.cassandra.net.IVerbHandler
This method delivers a message to the implementing class (if the implementing class was registered by a call to MessagingService.registerVerbHandlers).
doVerb(Message, String) - Method in class org.apache.cassandra.net.ResponseVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequestVerbHandler
Trigger a validation compaction which will return the tree upon completion.
doVerb(Message, String) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeResponseVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.service.IndexScanVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.service.RangeSliceVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.streaming.ReplicationFinishedVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.streaming.StreamReplyVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.streaming.StreamRequestVerbHandler
 
drain() - Method in class org.apache.cassandra.service.StorageService
shuts node off to writes, empties memtables and the commit log.
drain() - Method in interface org.apache.cassandra.service.StorageServiceMBean
makes node unavailable for writes, flushes memtables and replays commitlog.
drain() - Method in class org.apache.cassandra.tools.NodeProbe
 
dropCf(Integer) - Method in class org.apache.cassandra.db.Table
 
DropColumnFamily - Class in org.apache.cassandra.db.migration
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
DropColumnFamily() - Constructor for class org.apache.cassandra.db.migration.DropColumnFamily
Required no-arg constructor
DropColumnFamily(String, String) - Constructor for class org.apache.cassandra.db.migration.DropColumnFamily
 
DropKeyspace - Class in org.apache.cassandra.db.migration
 
DropKeyspace() - Constructor for class org.apache.cassandra.db.migration.DropKeyspace
Required no-arg constructor
DropKeyspace(String) - Constructor for class org.apache.cassandra.db.migration.DropKeyspace
 
dumpInterArrivalTimes() - Method in class org.apache.cassandra.gms.FailureDetector
Dump the inter arrival times for examination if necessary.
dumpInterArrivalTimes() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
dumpTimings(String) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
dumpTimings(String) - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
dumpToStorage(UUID) - Static method in class org.apache.cassandra.db.DefsTable
dumps current keyspace definitions to storage
dynamic_snitch - Variable in class org.apache.cassandra.config.Config
 
dynamic_snitch_badness_threshold - Variable in class org.apache.cassandra.config.Config
 
dynamic_snitch_reset_interval_in_ms - Variable in class org.apache.cassandra.config.Config
 
dynamic_snitch_update_interval_in_ms - Variable in class org.apache.cassandra.config.Config
 
DynamicEndpointSnitch - Class in org.apache.cassandra.locator
A dynamic snitch that sorts endpoints by latency with an adapted phi failure detector
DynamicEndpointSnitch(IEndpointSnitch) - Constructor for class org.apache.cassandra.locator.DynamicEndpointSnitch
 
DynamicEndpointSnitchMBean - Interface in org.apache.cassandra.locator
 

E

ec2region - Variable in class org.apache.cassandra.locator.Ec2Snitch
 
Ec2Snitch - Class in org.apache.cassandra.locator
A snitch that assumes an EC2 region is a DC and an EC2 availability_zone is a rack.
Ec2Snitch() - Constructor for class org.apache.cassandra.locator.Ec2Snitch
 
ec2zone - Variable in class org.apache.cassandra.locator.Ec2Snitch
 
echoData(DataOutput) - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
EmbeddedCassandraService - Class in org.apache.cassandra.service
An embedded, in-memory cassandra storage service that listens on the thrift interface as configured in cassandra.yaml This kind of service is useful when running unit tests of services using cassandra for example.
EmbeddedCassandraService() - Constructor for class org.apache.cassandra.service.EmbeddedCassandraService
 
EMPTY_BYTE_BUFFER - Static variable in class org.apache.cassandra.utils.ByteBufferUtil
 
EMPTY_ROW - Static variable in class org.apache.cassandra.service.AntiEntropyService.Validator
 
encodedUTF8Length(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
end_key - Variable in class org.apache.cassandra.thrift.KeyRange
 
end_token - Variable in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
end_token - Variable in class org.apache.cassandra.thrift.KeyRange
 
end_token - Variable in class org.apache.cassandra.thrift.TokenRange
 
endpoint - Variable in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
endpoint_snitch - Variable in class org.apache.cassandra.config.Config
 
endpoints - Variable in class org.apache.cassandra.thrift.TokenRange
 
EndpointSnitchInfo - Class in org.apache.cassandra.locator
 
EndpointSnitchInfo() - Constructor for class org.apache.cassandra.locator.EndpointSnitchInfo
 
EndpointSnitchInfoMBean - Interface in org.apache.cassandra.locator
MBean exposing standard Snitch info
EndpointState - Class in org.apache.cassandra.gms
This abstraction represents both the HeartBeatState and the ApplicationState in an EndpointState instance.
ensureCapacity(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Ensure that the long[] is big enough to hold numBits, expanding it if necessary.
ensureCapacityWords(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Expand the long[] with the size given as a number of words (64 bit longs).
entrySet() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
entrySet() - Method in class org.apache.cassandra.locator.TokenMetadata
 
enumeratekeys(String, PrintStream) - Static method in class org.apache.cassandra.tools.SSTableExport
Enumerate row keys from an SSTableReader and write the result to a PrintStream.
EQ - Static variable in class org.apache.cassandra.io.sstable.SSTableReader.Operator
 
equals(Object) - Method in class org.apache.cassandra.config.CFMetaData
 
equals(Object) - Method in class org.apache.cassandra.config.ColumnDefinition
 
equals(Object) - Method in class org.apache.cassandra.config.KSMetaData
 
equals(Object) - Method in class org.apache.cassandra.db.Column
 
equals(Object) - Method in class org.apache.cassandra.db.ColumnFamily
 
equals(Object) - Method in class org.apache.cassandra.db.DecoratedKey
 
equals(Object) - Method in class org.apache.cassandra.dht.AbstractBounds
 
equals(Object) - Method in class org.apache.cassandra.dht.Bounds
 
equals(Object) - Method in class org.apache.cassandra.dht.BytesToken
 
equals(Object) - Method in class org.apache.cassandra.dht.LocalToken
 
equals(Object) - Method in class org.apache.cassandra.dht.Range
 
equals(Object) - Method in class org.apache.cassandra.dht.Token
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.Component
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
equals(Object) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
equals(Object) - Method in class org.apache.cassandra.streaming.PendingFile
 
equals(Object) - Method in exception org.apache.cassandra.thrift.AuthenticationException
 
equals(AuthenticationException) - Method in exception org.apache.cassandra.thrift.AuthenticationException
 
equals(Object) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
equals(AuthenticationRequest) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
equals(Object) - Method in exception org.apache.cassandra.thrift.AuthorizationException
 
equals(AuthorizationException) - Method in exception org.apache.cassandra.thrift.AuthorizationException
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
equals(Cassandra.batch_mutate_args) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
equals(Cassandra.batch_mutate_result) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
 
equals(Cassandra.describe_cluster_name_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
equals(Cassandra.describe_cluster_name_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
equals(Cassandra.describe_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
equals(Cassandra.describe_keyspace_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
 
equals(Cassandra.describe_keyspaces_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
equals(Cassandra.describe_keyspaces_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
 
equals(Cassandra.describe_partitioner_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
equals(Cassandra.describe_partitioner_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
equals(Cassandra.describe_ring_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
equals(Cassandra.describe_ring_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
 
equals(Cassandra.describe_schema_versions_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
equals(Cassandra.describe_schema_versions_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
 
equals(Cassandra.describe_snitch_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
equals(Cassandra.describe_snitch_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
equals(Cassandra.describe_splits_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
equals(Cassandra.describe_splits_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
 
equals(Cassandra.describe_version_args) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
equals(Cassandra.describe_version_result) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
equals(Cassandra.get_args) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
equals(Cassandra.get_count_args) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
equals(Cassandra.get_count_result) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
equals(Cassandra.get_indexed_slices_args) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
equals(Cassandra.get_indexed_slices_result) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
equals(Cassandra.get_range_slices_args) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
equals(Cassandra.get_range_slices_result) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
equals(Cassandra.get_result) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
equals(Cassandra.get_slice_args) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
equals(Cassandra.get_slice_result) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
equals(Cassandra.insert_args) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
equals(Cassandra.insert_result) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
 
equals(Cassandra.login_args) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
equals(Cassandra.login_result) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
equals(Cassandra.multiget_count_args) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
equals(Cassandra.multiget_count_result) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
equals(Cassandra.multiget_slice_args) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
equals(Cassandra.multiget_slice_result) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
equals(Cassandra.remove_args) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
equals(Cassandra.remove_result) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
equals(Cassandra.set_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
equals(Cassandra.set_keyspace_result) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
equals(Cassandra.system_add_column_family_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
equals(Cassandra.system_add_column_family_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
equals(Cassandra.system_add_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
equals(Cassandra.system_add_keyspace_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
equals(Cassandra.system_drop_column_family_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
equals(Cassandra.system_drop_column_family_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
equals(Cassandra.system_drop_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
equals(Cassandra.system_drop_keyspace_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
equals(Cassandra.system_update_column_family_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
equals(Cassandra.system_update_column_family_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
equals(Cassandra.system_update_keyspace_args) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
equals(Cassandra.system_update_keyspace_result) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
equals(Cassandra.truncate_args) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
equals(Object) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
equals(Cassandra.truncate_result) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
equals(Object) - Method in class org.apache.cassandra.thrift.CfDef
 
equals(CfDef) - Method in class org.apache.cassandra.thrift.CfDef
 
equals(Object) - Method in class org.apache.cassandra.thrift.Column
 
equals(Column) - Method in class org.apache.cassandra.thrift.Column
 
equals(Object) - Method in class org.apache.cassandra.thrift.ColumnDef
 
equals(ColumnDef) - Method in class org.apache.cassandra.thrift.ColumnDef
 
equals(Object) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
equals(ColumnOrSuperColumn) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
equals(Object) - Method in class org.apache.cassandra.thrift.ColumnParent
 
equals(ColumnParent) - Method in class org.apache.cassandra.thrift.ColumnParent
 
equals(Object) - Method in class org.apache.cassandra.thrift.ColumnPath
 
equals(ColumnPath) - Method in class org.apache.cassandra.thrift.ColumnPath
 
equals(Object) - Method in class org.apache.cassandra.thrift.Deletion
 
equals(Deletion) - Method in class org.apache.cassandra.thrift.Deletion
 
equals(Object) - Method in class org.apache.cassandra.thrift.IndexClause
 
equals(IndexClause) - Method in class org.apache.cassandra.thrift.IndexClause
 
equals(Object) - Method in class org.apache.cassandra.thrift.IndexExpression
 
equals(IndexExpression) - Method in class org.apache.cassandra.thrift.IndexExpression
 
equals(Object) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
 
equals(InvalidRequestException) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
 
equals(Object) - Method in class org.apache.cassandra.thrift.KeyCount
 
equals(KeyCount) - Method in class org.apache.cassandra.thrift.KeyCount
 
equals(Object) - Method in class org.apache.cassandra.thrift.KeyRange
 
equals(KeyRange) - Method in class org.apache.cassandra.thrift.KeyRange
 
equals(Object) - Method in class org.apache.cassandra.thrift.KeySlice
 
equals(KeySlice) - Method in class org.apache.cassandra.thrift.KeySlice
 
equals(Object) - Method in class org.apache.cassandra.thrift.KsDef
 
equals(KsDef) - Method in class org.apache.cassandra.thrift.KsDef
 
equals(Object) - Method in class org.apache.cassandra.thrift.Mutation
 
equals(Mutation) - Method in class org.apache.cassandra.thrift.Mutation
 
equals(Object) - Method in exception org.apache.cassandra.thrift.NotFoundException
 
equals(NotFoundException) - Method in exception org.apache.cassandra.thrift.NotFoundException
 
equals(Object) - Method in class org.apache.cassandra.thrift.SlicePredicate
 
equals(SlicePredicate) - Method in class org.apache.cassandra.thrift.SlicePredicate
 
equals(Object) - Method in class org.apache.cassandra.thrift.SliceRange
 
equals(SliceRange) - Method in class org.apache.cassandra.thrift.SliceRange
 
equals(Object) - Method in class org.apache.cassandra.thrift.SuperColumn
 
equals(SuperColumn) - Method in class org.apache.cassandra.thrift.SuperColumn
 
equals(Object) - Method in exception org.apache.cassandra.thrift.TimedOutException
 
equals(TimedOutException) - Method in exception org.apache.cassandra.thrift.TimedOutException
 
equals(Object) - Method in class org.apache.cassandra.thrift.TokenRange
 
equals(TokenRange) - Method in class org.apache.cassandra.thrift.TokenRange
 
equals(Object) - Method in exception org.apache.cassandra.thrift.UnavailableException
 
equals(UnavailableException) - Method in exception org.apache.cassandra.thrift.UnavailableException
 
equals(Object) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
returns true if both sets have the same bits set
equals(Object) - Method in class org.apache.cassandra.utils.Pair
 
err - Variable in class org.apache.cassandra.cli.CliSessionState
 
estimatedColumnCount - Variable in class org.apache.cassandra.io.sstable.SSTable
 
EstimatedHistogram - Class in org.apache.cassandra.utils
 
EstimatedHistogram() - Constructor for class org.apache.cassandra.utils.EstimatedHistogram
 
EstimatedHistogram(int) - Constructor for class org.apache.cassandra.utils.EstimatedHistogram
 
EstimatedHistogram(long[], long[]) - Constructor for class org.apache.cassandra.utils.EstimatedHistogram
 
EstimatedHistogram.EstimatedHistogramSerializer - Class in org.apache.cassandra.utils
 
EstimatedHistogram.EstimatedHistogramSerializer() - Constructor for class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
estimatedKeys() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
estimatedKeys() - Method in class org.apache.cassandra.io.sstable.SSTableTracker
 
estimatedRowSize - Variable in class org.apache.cassandra.io.sstable.SSTable
 
estimateKeys() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
estimateKeys() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
execute(Runnable) - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Executes the given command at some time in the future.
executeCLIStatement(String) - Method in class org.apache.cassandra.cli.CliClient
 
executeDelete(String) - Static method in class org.apache.cassandra.io.DeletionService
 
executor - Static variable in class org.apache.cassandra.io.DeletionService
 
expandingWordNum(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
EXPIRATION_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
 
ExpiringColumn - Class in org.apache.cassandra.db
Alternative to Column that have an expiring time.
ExpiringColumn(ByteBuffer, ByteBuffer, long, int) - Constructor for class org.apache.cassandra.db.ExpiringColumn
 
ExpiringColumn(ByteBuffer, ByteBuffer, long, int, int) - Constructor for class org.apache.cassandra.db.ExpiringColumn
 
ExpiringMap<K,V> - Class in org.apache.cassandra.utils
 
ExpiringMap(long) - Constructor for class org.apache.cassandra.utils.ExpiringMap
 
ExpiringMap(long, Function<Pair<K, V>, ?>) - Constructor for class org.apache.cassandra.utils.ExpiringMap
 
export(String, PrintStream, Collection<String>, String[]) - Static method in class org.apache.cassandra.tools.SSTableExport
Export specific rows from an SSTable and write the resulting JSON to a PrintStream.
export(String, PrintStream, String[]) - Static method in class org.apache.cassandra.tools.SSTableExport
Export an SSTable and write the resulting JSON to a PrintStream.
export(String, String[]) - Static method in class org.apache.cassandra.tools.SSTableExport
Export an SSTable and write the resulting JSON to standard out.
exportSchema() - Method in class org.apache.cassandra.service.StorageService
 
exportSchema() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Introduced in 0.7 to allow schema yaml to be exported.
exportSchemaToYAML() - Method in class org.apache.cassandra.tools.NodeProbe
 
expressions - Variable in class org.apache.cassandra.thrift.IndexClause
 

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
 
fastClear(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
clears a bit.
fastClear(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
clears a bit.
fastFlip(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
flips a bit.
fastFlip(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
flips a bit.
fastGet(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns true or false for the specified bit index.
fastGet(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns true or false for the specified bit index.
fastSet(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Sets the bit at the specified index.
fastSet(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Sets the bit at the specified index.
FBUtilities - Class in org.apache.cassandra.utils
 
FBUtilities() - Constructor for class org.apache.cassandra.utils.FBUtilities
 
fcntl(int, int, long) - Static method in class org.apache.cassandra.utils.CLibrary
 
fieldForId(int) - Method in exception org.apache.cassandra.thrift.AuthenticationException
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
fieldForId(int) - Method in exception org.apache.cassandra.thrift.AuthorizationException
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.CfDef
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Column
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.ColumnDef
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.ColumnParent
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.ColumnPath
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Deletion
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.IndexClause
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.IndexExpression
 
fieldForId(int) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.KeyCount
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.KeyRange
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.KeySlice
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.KsDef
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.Mutation
 
fieldForId(int) - Method in exception org.apache.cassandra.thrift.NotFoundException
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.SlicePredicate
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.SliceRange
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.SuperColumn
 
fieldForId(int) - Method in exception org.apache.cassandra.thrift.TimedOutException
 
fieldForId(int) - Method in class org.apache.cassandra.thrift.TokenRange
 
fieldForId(int) - Method in exception org.apache.cassandra.thrift.UnavailableException
 
file - Variable in class org.apache.cassandra.streaming.StreamHeader
file being sent on initial stream
FILE_BUFFER_SIZE - Static variable in class org.apache.cassandra.io.CompactionIterator
 
FileDataInput - Interface in org.apache.cassandra.io.util
 
FileMark - Interface in org.apache.cassandra.io.util
 
filename - Variable in class org.apache.cassandra.cli.CliSessionState
 
filenameFor(Component) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
filenameFor(String) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
FileStreamTask - Class in org.apache.cassandra.streaming
 
FileStreamTask(StreamHeader, InetAddress) - Constructor for class org.apache.cassandra.streaming.FileStreamTask
 
FileUtils - Class in org.apache.cassandra.io.util
 
FileUtils() - Constructor for class org.apache.cassandra.io.util.FileUtils
 
FileUtils.FileComparator - Class in org.apache.cassandra.io.util
 
FileUtils.FileComparator() - Constructor for class org.apache.cassandra.io.util.FileUtils.FileComparator
 
filter - Variable in class org.apache.cassandra.db.filter.QueryFilter
 
FILTER - Static variable in class org.apache.cassandra.io.sstable.Component
 
Filter - Class in org.apache.cassandra.utils
 
Filter() - Constructor for class org.apache.cassandra.utils.Filter
 
filterSuperColumn(SuperColumn, int) - Method in class org.apache.cassandra.db.columniterator.IdentityQueryFilter
 
filterSuperColumn(SuperColumn, int) - Method in interface org.apache.cassandra.db.filter.IFilter
subcolumns of a supercolumn are unindexed, so to pick out parts of those we operate in-memory.
filterSuperColumn(SuperColumn, int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
filterSuperColumn(SuperColumn, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
findByName(String) - Static method in enum org.apache.cassandra.thrift.AuthenticationException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.AuthenticationRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.AuthorizationException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.login_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.login_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.CfDef._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Column._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.ColumnDef._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.ColumnOrSuperColumn._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.ColumnParent._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.ColumnPath._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Deletion._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.IndexClause._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.IndexExpression._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.InvalidRequestException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.KeyCount._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.KeyRange._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.KeySlice._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.KsDef._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.Mutation._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.NotFoundException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.SlicePredicate._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.SliceRange._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.SuperColumn._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.TimedOutException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.TokenRange._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.cassandra.thrift.UnavailableException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.AuthenticationException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.AuthenticationRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.AuthorizationException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.login_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.login_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.CfDef._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Column._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.ColumnDef._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.ColumnOrSuperColumn._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.ColumnParent._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.ColumnPath._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Deletion._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.IndexClause._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.IndexExpression._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.InvalidRequestException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.KeyCount._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.KeyRange._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.KeySlice._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.KsDef._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.Mutation._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.NotFoundException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.SlicePredicate._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.SliceRange._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.SuperColumn._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.TimedOutException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.TokenRange._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.cassandra.thrift.UnavailableException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.AuthenticationException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.AuthenticationRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.AuthorizationException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.login_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.login_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.CfDef._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Column._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.ColumnDef._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.ColumnOrSuperColumn._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.ColumnParent._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.ColumnPath._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Deletion._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.IndexClause._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.IndexExpression._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.InvalidRequestException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.KeyCount._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.KeyRange._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.KeySlice._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.KsDef._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.Mutation._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.NotFoundException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.SlicePredicate._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.SliceRange._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.SuperColumn._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.TimedOutException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.TokenRange._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.cassandra.thrift.UnavailableException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByValue(int) - Static method in enum org.apache.cassandra.thrift.ConsistencyLevel
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.cassandra.thrift.IndexOperator
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.cassandra.thrift.IndexType
Find a the enum type by its integer value, as defined in the Thrift IDL.
finish - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
finish - Variable in class org.apache.cassandra.db.SliceFromReadCommand
 
finish - Variable in class org.apache.cassandra.thrift.SliceRange
 
finishBootstrapping() - Method in class org.apache.cassandra.service.StorageService
 
finished(PendingFile, PendingFile) - Method in class org.apache.cassandra.streaming.StreamInSession
 
firstKey() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
firstName - Variable in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
firstToken(ArrayList<Token>, Token) - Static method in class org.apache.cassandra.locator.TokenMetadata
 
firstTokenIndex(ArrayList, Token, boolean) - Static method in class org.apache.cassandra.locator.TokenMetadata
 
fixMaxId() - Static method in class org.apache.cassandra.config.CFMetaData
 
flip(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
flips a bit, expanding the set size if necessary
flip(long, long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Flips a range of bits, expanding the set size if necessary
flipAndGet(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
flips a bit and returns the resulting bit value.
flipAndGet(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
flips a bit and returns the resulting bit value.
flush() - Method in class org.apache.cassandra.db.Table
 
flush() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
flush_largest_memtables_at - Variable in class org.apache.cassandra.config.Config
 
flushAndSignal(CountDownLatch, ExecutorService, ExecutorService) - Method in class org.apache.cassandra.db.BinaryMemtable
 
flushAndSignal(CountDownLatch, ExecutorService, ExecutorService) - Method in interface org.apache.cassandra.db.IFlushable
 
flushAndSignal(CountDownLatch, ExecutorService, ExecutorService) - Method in class org.apache.cassandra.db.Memtable
 
flushLargestMemtables() - Method in class org.apache.cassandra.service.StorageService
Flushes the two largest memtables by ops and by throughput
forceBlockingFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceCleanup() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceCleanup() - Method in class org.apache.cassandra.db.Table
Do a cleanup of keys that do not belong locally.
forceCompaction() - Method in class org.apache.cassandra.db.Table
 
forceFilterFailures() - Method in class org.apache.cassandra.io.sstable.SSTableReader
For testing purposes only.
forceFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceFlush() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Triggers an immediate memtable flush.
forceFlushBinary() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceFlushIfExpired() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceMajorCompaction() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceMajorCompaction() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
force a major compaction of this column family
forceRemoveCompletion() - Method in class org.apache.cassandra.service.StorageService
Force a remove operation to complete.
forceRemoveCompletion() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Force a remove operation to finish.
forceRemoveCompletion() - Method in class org.apache.cassandra.tools.NodeProbe
 
forceTableCleanup(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceTableCleanup(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Trigger a cleanup of keys on a single keyspace
forceTableCleanup(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceTableCompaction(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceTableCompaction(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Forces major compaction of a single keyspace
forceTableCompaction(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceTableFlush(String, String...) - Method in class org.apache.cassandra.service.StorageService
Flush all memtables for a table and column families.
forceTableFlush(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Flush all memtables for the given column families, or all columnfamilies for the given table if none are explicitly listed.
forceTableFlush(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceTableRepair(String, String...) - Method in class org.apache.cassandra.service.StorageService
Trigger proactive repair for a table and column families.
forceTableRepair(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Triggers proactive repair for given column families, or all columnfamilies for the given table if none are explicitly listed.
forceTableRepair(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceUserDefinedCompaction(String, String) - Method in class org.apache.cassandra.db.CompactionManager
 
forceUserDefinedCompaction(String, String) - Method in interface org.apache.cassandra.db.CompactionManagerMBean
Triggers the compaction of user specified sstables.
FORWARD_HEADER - Static variable in class org.apache.cassandra.db.RowMutation
 
framed - Variable in class org.apache.cassandra.cli.CliSessionState
 
fromByteArray(ByteBuffer) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
fromColumnDef(ColumnDef) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
fromColumnDef(ColumnDef) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
fromColumnDef(List<ColumnDef>) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
fromColumnDefs(Iterable<ColumnDef>) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
fromFilename(File, String) - Static method in class org.apache.cassandra.io.sstable.Component
Filename of the form "/-[tmp-][-]-", where is of the form "[-]".
fromFilename(String) - Static method in class org.apache.cassandra.io.sstable.Descriptor
 
fromFilename(File, String) - Static method in class org.apache.cassandra.io.sstable.Descriptor
Filename of the form "/-[tmp-][-]-"
fromString(String) - Method in class org.apache.cassandra.db.marshal.AbstractType
get a byte representation of the given string.
fromString(String) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.BytesType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.LongType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
fromString(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
FULLY_INCONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
 

G

gc_grace_seconds - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
gc_grace_seconds - Variable in class org.apache.cassandra.thrift.CfDef
 
gcBefore() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
GCInspector - Class in org.apache.cassandra.service
 
GCInspector() - Constructor for class org.apache.cassandra.service.GCInspector
 
GE - Static variable in class org.apache.cassandra.io.sstable.SSTableReader.Operator
 
generation - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
get(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.avro.CassandraServer
 
get(K) - Method in class org.apache.cassandra.cache.InstrumentedCache
 
get(Object) - Method in class org.apache.cassandra.concurrent.Context
 
get(Object) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
get(long, TimeUnit) - Method in interface org.apache.cassandra.net.IAsyncResult
Same operation as the above get() but allows the calling thread to specify a timeout.
get() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
get() - Method in interface org.apache.cassandra.service.IWriteResponseHandler
 
get() - Method in class org.apache.cassandra.service.ReadCallback
 
get() - Method in class org.apache.cassandra.service.RepairCallback
The main difference between this and ReadCallback is, ReadCallback has a ConsistencyLevel it needs to achieve.
get() - Method in class org.apache.cassandra.service.TruncateResponseHandler
 
get(InetAddress, long) - Static method in class org.apache.cassandra.streaming.StreamInSession
 
get(InetAddress, long) - Static method in class org.apache.cassandra.streaming.StreamOutSession
 
get(ByteBuffer, ColumnPath, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.get_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
get(ByteBuffer, ColumnPath, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.get_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
get(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
get(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
Get the Column or SuperColumn at the given column_path.
get(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
get(boolean) - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
get(K) - Method in class org.apache.cassandra.utils.ExpiringMap
 
get(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns true or false for the specified bit index.
get(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns true or false for the specified bit index
get_count(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.avro.CassandraServer
 
get_count(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.get_count_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
get_count(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.get_count_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
get_count(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
get_count(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
returns the number of columns matching predicate for a particular key, ColumnFamily and optionally SuperColumn.
get_count(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.avro.CassandraServer
 
get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.get_indexed_slices_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.get_indexed_slices_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
Returns the subset of columns specified in SlicePredicate for the rows matching the IndexClause
get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
get_range_slices(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel) - Method in class org.apache.cassandra.avro.CassandraServer
 
get_range_slices(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.get_range_slices_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
get_range_slices(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.get_range_slices_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
get_range_slices(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
get_range_slices(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
returns a subset of columns for a contiguous range of keys.
get_range_slices(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
get_slice(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.avro.CassandraServer
 
get_slice(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.get_slice_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
get_slice(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.get_slice_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
get_slice(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
get_slice(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
Get the group of columns contained by column_parent (either a ColumnFamily name or a ColumnFamily/SuperColumn name pair) specified by the given SlicePredicate.
get_slice(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
getActiveCount() - Method in interface org.apache.cassandra.concurrent.IExecutorMBean
Get the current number of running tasks
getActiveCount() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
Get the current number of running tasks
getAddressRanges(TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getAddressRanges() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getAge(K) - Method in class org.apache.cassandra.utils.ExpiringMap
 
getAllDataFileLocations() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getAllDataFileLocationsForTable(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
Get a list of data directories for a given table
getAllEndpointStates() - Method in class org.apache.cassandra.gms.FailureDetector
 
getAllEndpointStates() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
getAllRanges(List<Token>) - Method in class org.apache.cassandra.service.StorageService
Get all ranges that span the ring given a set of tokens.
getAllSSTables() - Method in class org.apache.cassandra.db.Table
 
getAndSet(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Sets a bit and returns the previous value.
getAndSet(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Sets a bit and returns the previous value.
getApplicationState(ApplicationState) - Method in class org.apache.cassandra.gms.EndpointState
 
getApplicationStateMap() - Method in class org.apache.cassandra.gms.EndpointState
Deprecated. 
getApproximateKeyCount(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
getArray(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
You should almost never use this.
getArray(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.Factory
 
getAttributeValue(Node, String) - Static method in class org.apache.cassandra.utils.XMLUtils
 
getAuth_request() - Method in class org.apache.cassandra.thrift.Cassandra.login_args
 
getAuthenticator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getAuthnx() - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
getAuthority() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getAuthzx() - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
getBadnessThreshold() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getBadnessThreshold() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
getBalancedToken(TokenMetadata, Map<InetAddress, Double>) - Static method in class org.apache.cassandra.dht.BootStrapper
 
getBit(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
returns 1 if the bit is set, 0 if not.
getBits(int, int, int) - Static method in class org.apache.cassandra.net.MessagingService
 
getBits() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Expert: returns the long[] storing the bits
getBitSet() - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
getBloomFilter() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getBloomFilterFalsePositives() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getBloomFilterFalsePositives() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getBloomFilterFalseRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getBMTThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBootstrapToken(TokenMetadata, Map<InetAddress, Double>) - Static method in class org.apache.cassandra.dht.BootStrapper
if initialtoken was specified, use that.
getBootstrapToken() - Method in class org.apache.cassandra.service.StorageService
return a token to which if a node bootstraps it will get about 1/2 of this node's range
getBootstrapTokens() - Method in class org.apache.cassandra.locator.TokenMetadata
caller should not modify bootstrapTokens
getBucketOffsets() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
getBuilder(Config.DiskAccessMode) - Static method in class org.apache.cassandra.io.util.SegmentedFile
 
getBuiltIndexes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Returns a list of the names of the built column indexes for current store
getBuiltIndexes() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Returns a list of the names of the built column indexes for current store
getBytesCompacted() - Method in class org.apache.cassandra.db.CompactionManager
 
getBytesCompacted() - Method in interface org.apache.cassandra.db.CompactionManagerMBean
 
getBytesComplete() - Method in class org.apache.cassandra.db.Table.IndexBuilder
 
getBytesComplete() - Method in class org.apache.cassandra.io.CompactionIterator
 
getBytesComplete() - Method in interface org.apache.cassandra.io.ICompactionInfo
 
getBytesComplete() - Method in class org.apache.cassandra.io.sstable.CacheWriter
 
getBytesComplete() - Method in class org.apache.cassandra.io.sstable.SSTableWriter.Builder
 
getBytesRead() - Method in class org.apache.cassandra.io.sstable.KeyIterator
 
getBytesRead() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
getBytesTotalInProgress() - Method in class org.apache.cassandra.db.CompactionManager
 
getBytesTotalInProgress() - Method in interface org.apache.cassandra.db.CompactionManagerMBean
 
getCache() - Method in interface org.apache.cassandra.cache.IAggregatableCacheProvider
 
getCachedEndpoints(Token) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getCachedPosition(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getCapacity() - Method in class org.apache.cassandra.cache.InstrumentedCache
 
getCapacity() - Method in interface org.apache.cassandra.cache.JMXInstrumentedCacheMBean
 
getCF(Integer) - Static method in class org.apache.cassandra.config.CFMetaData
 
getCf_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
getCf_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
getCf_defs() - Method in class org.apache.cassandra.thrift.KsDef
 
getCf_defsIterator() - Method in class org.apache.cassandra.thrift.KsDef
 
getCf_defsSize() - Method in class org.apache.cassandra.thrift.KsDef
 
getCFMetaData(String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCFMetaData(Integer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCFMetaData(Descriptor) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCfName() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
getCfname() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
getCfNamesByKeySpace(KsDef) - Static method in class org.apache.cassandra.cli.CliUtils
Returns set of column family names in specified keySpace.
getCfsProxy(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getClass(String) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getClient(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.Client.Factory
 
getClusterName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCollatingIterator(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.CompactionIterator
 
getCollatingIterator() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getColumn(Tree, int) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.ColumnFamily
 
getColumn() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
getColumn() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
getColumn() - Method in class org.apache.cassandra.thrift.ColumnPath
 
getColumn_family() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
getColumn_family() - Method in class org.apache.cassandra.thrift.ColumnParent
 
getColumn_family() - Method in class org.apache.cassandra.thrift.ColumnPath
 
getColumn_metadata() - Method in class org.apache.cassandra.config.CFMetaData
 
getColumn_metadata() - Method in class org.apache.cassandra.thrift.CfDef
 
getColumn_metadataIterator() - Method in class org.apache.cassandra.thrift.CfDef
 
getColumn_metadataSize() - Method in class org.apache.cassandra.thrift.CfDef
 
getColumn_name() - Method in class org.apache.cassandra.thrift.IndexExpression
 
getColumn_names() - Method in class org.apache.cassandra.thrift.SlicePredicate
 
getColumn_namesIterator() - Method in class org.apache.cassandra.thrift.SlicePredicate
 
getColumn_namesSize() - Method in class org.apache.cassandra.thrift.SlicePredicate
 
getColumn_or_supercolumn() - Method in class org.apache.cassandra.thrift.Mutation
 
getColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
getColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
getColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
getColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
getColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
getColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
getColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
getColumn_path() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
getColumn_path() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
getColumn_predicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
getColumn_type() - Method in class org.apache.cassandra.thrift.CfDef
 
getColumnComparator(AbstractType) - Method in interface org.apache.cassandra.db.filter.IFilter
 
getColumnComparator(AbstractType) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getColumnComparator(AbstractType) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getColumnComparator() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getColumnFamilies() - Method in class org.apache.cassandra.db.RowMutation
 
getColumnFamily(Tree, List<CfDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getColumnFamily(String, List<CfDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getColumnFamily(DecoratedKey, QueryPath, ByteBuffer, ByteBuffer, boolean, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getColumnFamily(QueryFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
get a list of columns starting from a given column, in a specified order.
getColumnFamily() - Method in interface org.apache.cassandra.db.columniterator.IColumnIterator
returns the CF of the column being iterated.
getColumnFamily() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
getColumnFamily() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
getColumnFamily(DecoratedKey) - Method in class org.apache.cassandra.db.Memtable
 
getColumnFamily() - Method in class org.apache.cassandra.io.sstable.CacheWriter
 
getColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
getColumnFamilyInProgress() - Method in class org.apache.cassandra.db.CompactionManager
 
getColumnFamilyInProgress() - Method in interface org.apache.cassandra.db.CompactionManagerMBean
 
getColumnFamilyName() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getColumnFamilyName() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getColumnFamilyName() - Method in class org.apache.cassandra.db.filter.QueryFilter
 
getColumnFamilyName() - Method in class org.apache.cassandra.db.ReadCommand
 
getColumnFamilyName() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getColumnFamilyStore(String) - Method in class org.apache.cassandra.db.Table
 
getColumnFamilyStoreMBeanProxies() - Method in class org.apache.cassandra.tools.NodeProbe
 
getColumnFamilyStores() - Method in class org.apache.cassandra.db.Table
 
getColumnFamilyType(String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getColumnFamilyType() - Method in class org.apache.cassandra.db.ColumnFamily
 
getColumnFamilyWithColumns() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
getColumnIndexSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getColumnNames() - Method in class org.apache.cassandra.db.ColumnFamily
 
getColumns() - Method in class org.apache.cassandra.thrift.KeySlice
 
getColumns() - Method in class org.apache.cassandra.thrift.SuperColumn
 
getColumnSerializer() - Method in class org.apache.cassandra.db.ColumnFamily
FIXME: Gross.
getColumnSerializer() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getColumnsIterator() - Method in class org.apache.cassandra.thrift.KeySlice
 
getColumnsIterator() - Method in class org.apache.cassandra.thrift.SuperColumn
 
getColumnsMap() - Method in class org.apache.cassandra.db.ColumnFamily
 
getColumnsSize() - Method in class org.apache.cassandra.thrift.KeySlice
 
getColumnsSize() - Method in class org.apache.cassandra.thrift.SuperColumn
 
getColumnsString(Collection<IColumn>) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
getCommandCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getCommandCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Completed tasks for Command(Mutations, Read etc) TCP Connections
getCommandPendingTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getCommandPendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Pending tasks for Command(Mutations, Read etc) TCP Connections
getComment() - Method in class org.apache.cassandra.config.CFMetaData
 
getComment() - Method in class org.apache.cassandra.thrift.CfDef
 
getCommitLogLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCommitLogSync() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCommitLogSyncBatchWindow() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCommitLogSyncPeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCompactedRow() - Method in class org.apache.cassandra.io.CompactionIterator
 
getCompactionLock() - Method in class org.apache.cassandra.db.CompactionManager
 
getCompactionManagerProxy() - Method in class org.apache.cassandra.tools.NodeProbe
 
getCompactionThreadPriority() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCompactionThreshold(PrintStream, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
Get the compaction threshold
getCompactionType() - Method in class org.apache.cassandra.db.CompactionManager
 
getCompactionType() - Method in interface org.apache.cassandra.db.CompactionManagerMBean
 
getComparator(CharSequence) - 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() - Method in class org.apache.cassandra.io.LazilyCompactedRow
 
getComparator(AbstractType) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
 
getComparator() - Method in interface org.apache.cassandra.io.util.IIterableColumns
 
getComparator(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
getComparator_type() - Method in class org.apache.cassandra.thrift.CfDef
 
getComparatorFor(String, String, ByteBuffer) - Static method in class org.apache.cassandra.db.ColumnFamily
 
getCompletedMesssages() - Method in class org.apache.cassandra.net.OutboundTcpConnection
 
getCompletedTasks() - Method in interface org.apache.cassandra.concurrent.IExecutorMBean
Get the number of completed tasks
getCompletedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
Get the number of completed tasks
getCompletedTasks() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
Get the number of completed tasks
getCompletedTasks() - Method in class org.apache.cassandra.db.CompactionManager
 
getCompletedTasks() - Method in interface org.apache.cassandra.db.CompactionManagerMBean
 
getConcurrentReaders() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConcurrentWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConnection(InetAddress, Message) - Method in class org.apache.cassandra.net.MessagingService
 
getConnectionPool(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
getConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
getConsistencyThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getContext() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getContext() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getContextMapping(PendingFile) - Static method in class org.apache.cassandra.streaming.StreamIn
Translates remote files to local files by creating a local sstable per remote sstable.
getCorePoolSize() - Method in interface org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutorMBean
 
getCount() - Method in class org.apache.cassandra.thrift.IndexClause
 
getCount() - Method in class org.apache.cassandra.thrift.KeyCount
 
getCount() - Method in class org.apache.cassandra.thrift.KeyRange
 
getCount() - Method in class org.apache.cassandra.thrift.SliceRange
 
getCredentials() - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
getCredentialsSize() - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
getCurrentGenerationNumber(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
getCurrentGenerationNumber() - Method in class org.apache.cassandra.service.StorageService
 
getCurrentGenerationNumber() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Return the generation value for this node.
getCurrentGenerationNumber() - Method in class org.apache.cassandra.tools.NodeProbe
 
getCurrentKey() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
getCurrentKey() - Method in class org.apache.cassandra.hadoop.streaming.AvroOutputReader
 
getCurrentOperations() - Method in class org.apache.cassandra.db.Memtable
 
getCurrentThroughput() - Method in class org.apache.cassandra.db.Memtable
 
getCurrentValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
getCurrentValue() - Method in class org.apache.cassandra.hadoop.streaming.AvroOutputReader
 
getData() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
Returns the current contents of the buffer.
getData() - Method in class org.apache.cassandra.io.util.OutputBuffer
 
getData() - Method in interface org.apache.cassandra.service.IResponseResolver
returns the data response without comparing with any digests
getData() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
getData() - Method in class org.apache.cassandra.service.ReadResponseResolver
 
getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
Return the data center for which an endpoint resides in
getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.Ec2Snitch
 
getDatacenter(String) - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
 
getDatacenter(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
Provides the Datacenter name depending on the respective snitch used, given the hostname/ip
getDatacenter(InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
returns a String representing the datacenter this endpoint belongs to
getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
Return the data center for which an endpoint resides in
getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.RackInferringSnitch
 
getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.SimpleSnitch
 
getDatacenters() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
getDataFileLocation(long) - Method in class org.apache.cassandra.db.Table
 
getDataFileLocationForTable(String, long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDefault_validation_class() - Method in class org.apache.cassandra.thrift.CfDef
 
getDefaultValidator() - Method in class org.apache.cassandra.config.CFMetaData
 
getDefsVersion() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDeletion() - Method in class org.apache.cassandra.thrift.Mutation
 
getDestinations() - Static method in class org.apache.cassandra.streaming.StreamOutSession
 
getDirectScanner(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader
Direct I/O SSTableScanner
getDiskAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDrainProgress() - Method in class org.apache.cassandra.service.StorageService
 
getDrainProgress() - Method in interface org.apache.cassandra.service.StorageServiceMBean
get the progress of a drain operation
getDynamicBadnessThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDynamicResetInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDynamicUpdateInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getEnd_key() - Method in class org.apache.cassandra.thrift.KeyRange
 
getEnd_token() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
getEnd_token() - Method in class org.apache.cassandra.thrift.KeyRange
 
getEnd_token() - Method in class org.apache.cassandra.thrift.TokenRange
 
getEndpoint(Range) - Method in class org.apache.cassandra.client.RingCache
ListMultimap promises to return a List for get(K)
getEndpoint(ByteBuffer) - Method in class org.apache.cassandra.client.RingCache
 
getEndpoint(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getEndpointDowntime(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
getEndpointInfo(InetAddress) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
Get the raw information about an end point
getEndpoints() - Method in class org.apache.cassandra.thrift.TokenRange
 
getEndpoints(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getEndpointsIterator() - Method in class org.apache.cassandra.thrift.TokenRange
 
getEndpointSnitch() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getEndpointsSize() - Method in class org.apache.cassandra.thrift.TokenRange
 
getEndpointStateForEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
getEndpointStates() - Method in class org.apache.cassandra.gms.Gossiper
 
getEndToken() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
getEntryIterator(DecoratedKey) - Method in class org.apache.cassandra.db.Memtable
 
getEstimatedColumnCount() - Method in class org.apache.cassandra.db.ColumnFamily
 
getEstimatedColumnCount() - Method in class org.apache.cassandra.io.LazilyCompactedRow
 
getEstimatedColumnCount() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getEstimatedColumnCount() - Method in interface org.apache.cassandra.io.util.IIterableColumns
 
getEstimatedColumnCountHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getEstimatedColumnCountHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getEstimatedRowSize() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getEstimatedRowSizeHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getEstimatedRowSizeHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getExpressions() - Method in class org.apache.cassandra.thrift.IndexClause
 
getExpressionsIterator() - Method in class org.apache.cassandra.thrift.IndexClause
 
getExpressionsSize() - Method in class org.apache.cassandra.thrift.IndexClause
 
getFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getfd(FileDescriptor) - Static method in class org.apache.cassandra.utils.CLibrary
Get system file descriptor from FileDescriptor object.
getFieldName() - Method in enum org.apache.cassandra.thrift.AuthenticationException._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.AuthenticationRequest._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.AuthorizationException._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_version_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_version_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_count_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_count_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_slice_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.get_slice_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.insert_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.insert_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.login_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.login_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.remove_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.remove_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.truncate_args._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Cassandra.truncate_result._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.CfDef._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Column._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.ColumnDef._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.ColumnOrSuperColumn._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.ColumnParent._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.ColumnPath._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Deletion._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.IndexClause._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.IndexExpression._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.InvalidRequestException._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.KeyCount._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.KeyRange._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.KeySlice._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.KsDef._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.Mutation._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.NotFoundException._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.SlicePredicate._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.SliceRange._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.SuperColumn._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.TimedOutException._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.TokenRange._Fields
 
getFieldName() - Method in enum org.apache.cassandra.thrift.UnavailableException._Fields
 
getFieldValue(AuthenticationException._Fields) - Method in exception org.apache.cassandra.thrift.AuthenticationException
 
getFieldValue(AuthenticationRequest._Fields) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
getFieldValue(AuthorizationException._Fields) - Method in exception org.apache.cassandra.thrift.AuthorizationException
 
getFieldValue(Cassandra.batch_mutate_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
getFieldValue(Cassandra.batch_mutate_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
getFieldValue(Cassandra.describe_cluster_name_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
 
getFieldValue(Cassandra.describe_cluster_name_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
getFieldValue(Cassandra.describe_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
getFieldValue(Cassandra.describe_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
getFieldValue(Cassandra.describe_keyspaces_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
 
getFieldValue(Cassandra.describe_keyspaces_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
getFieldValue(Cassandra.describe_partitioner_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
 
getFieldValue(Cassandra.describe_partitioner_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
getFieldValue(Cassandra.describe_ring_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
getFieldValue(Cassandra.describe_ring_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
getFieldValue(Cassandra.describe_schema_versions_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
 
getFieldValue(Cassandra.describe_schema_versions_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
getFieldValue(Cassandra.describe_snitch_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
 
getFieldValue(Cassandra.describe_snitch_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
getFieldValue(Cassandra.describe_splits_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
getFieldValue(Cassandra.describe_splits_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
getFieldValue(Cassandra.describe_version_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
 
getFieldValue(Cassandra.describe_version_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
getFieldValue(Cassandra.get_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
getFieldValue(Cassandra.get_count_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
getFieldValue(Cassandra.get_count_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
getFieldValue(Cassandra.get_indexed_slices_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
getFieldValue(Cassandra.get_indexed_slices_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
getFieldValue(Cassandra.get_range_slices_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
getFieldValue(Cassandra.get_range_slices_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
getFieldValue(Cassandra.get_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
getFieldValue(Cassandra.get_slice_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
getFieldValue(Cassandra.get_slice_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
getFieldValue(Cassandra.insert_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
getFieldValue(Cassandra.insert_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
getFieldValue(Cassandra.login_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
 
getFieldValue(Cassandra.login_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
getFieldValue(Cassandra.multiget_count_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
getFieldValue(Cassandra.multiget_count_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
getFieldValue(Cassandra.multiget_slice_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
getFieldValue(Cassandra.multiget_slice_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
getFieldValue(Cassandra.remove_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
getFieldValue(Cassandra.remove_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
getFieldValue(Cassandra.set_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
getFieldValue(Cassandra.set_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
getFieldValue(Cassandra.system_add_column_family_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
getFieldValue(Cassandra.system_add_column_family_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
getFieldValue(Cassandra.system_add_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
getFieldValue(Cassandra.system_add_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
getFieldValue(Cassandra.system_drop_column_family_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
getFieldValue(Cassandra.system_drop_column_family_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
getFieldValue(Cassandra.system_drop_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
getFieldValue(Cassandra.system_drop_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
getFieldValue(Cassandra.system_update_column_family_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
getFieldValue(Cassandra.system_update_column_family_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
getFieldValue(Cassandra.system_update_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
getFieldValue(Cassandra.system_update_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
getFieldValue(Cassandra.truncate_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
getFieldValue(Cassandra.truncate_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
getFieldValue(CfDef._Fields) - Method in class org.apache.cassandra.thrift.CfDef
 
getFieldValue(Column._Fields) - Method in class org.apache.cassandra.thrift.Column
 
getFieldValue(ColumnDef._Fields) - Method in class org.apache.cassandra.thrift.ColumnDef
 
getFieldValue(ColumnOrSuperColumn._Fields) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
getFieldValue(ColumnParent._Fields) - Method in class org.apache.cassandra.thrift.ColumnParent
 
getFieldValue(ColumnPath._Fields) - Method in class org.apache.cassandra.thrift.ColumnPath
 
getFieldValue(Deletion._Fields) - Method in class org.apache.cassandra.thrift.Deletion
 
getFieldValue(IndexClause._Fields) - Method in class org.apache.cassandra.thrift.IndexClause
 
getFieldValue(IndexExpression._Fields) - Method in class org.apache.cassandra.thrift.IndexExpression
 
getFieldValue(InvalidRequestException._Fields) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
 
getFieldValue(KeyCount._Fields) - Method in class org.apache.cassandra.thrift.KeyCount
 
getFieldValue(KeyRange._Fields) - Method in class org.apache.cassandra.thrift.KeyRange
 
getFieldValue(KeySlice._Fields) - Method in class org.apache.cassandra.thrift.KeySlice
 
getFieldValue(KsDef._Fields) - Method in class org.apache.cassandra.thrift.KsDef
 
getFieldValue(Mutation._Fields) - Method in class org.apache.cassandra.thrift.Mutation
 
getFieldValue(NotFoundException._Fields) - Method in exception org.apache.cassandra.thrift.NotFoundException
 
getFieldValue(SlicePredicate._Fields) - Method in class org.apache.cassandra.thrift.SlicePredicate
 
getFieldValue(SliceRange._Fields) - Method in class org.apache.cassandra.thrift.SliceRange
 
getFieldValue(SuperColumn._Fields) - Method in class org.apache.cassandra.thrift.SuperColumn
 
getFieldValue(TimedOutException._Fields) - Method in exception org.apache.cassandra.thrift.TimedOutException
 
getFieldValue(TokenRange._Fields) - Method in class org.apache.cassandra.thrift.TokenRange
 
getFieldValue(UnavailableException._Fields) - Method in exception org.apache.cassandra.thrift.UnavailableException
 
getFileDataInput(DecoratedKey, int) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getFileLength() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
getFilename() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getFilename() - Method in class org.apache.cassandra.streaming.PendingFile
 
getFilePointer() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
getFilePointer() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
getFilePointer() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
getFiles(String, String) - Static method in class org.apache.cassandra.db.DefsTable
gets all the files that belong to a given column family.
getFilesDestinedFor(InetAddress) - Method in class org.apache.cassandra.tools.NodeProbe
 
getFilter(SlicePredicate, AbstractType) - Static method in class org.apache.cassandra.db.filter.QueryFilter
 
getFilter(long, int) - Static method in class org.apache.cassandra.utils.BloomFilter
 
getFilter(long, double) - Static method in class org.apache.cassandra.utils.BloomFilter
 
getFilter(long, int) - Static method in class org.apache.cassandra.utils.LegacyBloomFilter
 
getFilter(long, double) - Static method in class org.apache.cassandra.utils.LegacyBloomFilter
 
getFinish() - Method in class org.apache.cassandra.thrift.SliceRange
 
getFlushLargestMemtablesAt() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFlushLock() - Static method in class org.apache.cassandra.db.Table
 
getFlushPath() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getFlushWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFrom() - Method in interface org.apache.cassandra.net.IAsyncResult
 
getFrom() - Method in class org.apache.cassandra.net.Message
 
getFunctionNames() - Static method in enum org.apache.cassandra.cli.CliClient.Function
 
getGc_grace_seconds() - Method in class org.apache.cassandra.thrift.CfDef
 
getGcGraceSeconds() - Method in class org.apache.cassandra.config.CFMetaData
 
getHashBuckets(ByteBuffer) - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
getHasToken() - Method in class org.apache.cassandra.gms.EndpointState
 
getHeader() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getHeader(String) - Method in class org.apache.cassandra.net.Message
 
getHeaderPath() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getHeaderPathFromSegment(CommitLogSegment) - Static method in class org.apache.cassandra.db.commitlog.CommitLogHeader
 
getHeaderPathFromSegmentPath(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogHeader
 
getHeapMemoryUsage() - Method in class org.apache.cassandra.tools.NodeProbe
 
getHintedEndpoints(Collection<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
returns Multimap of {live destination: ultimate targets}, where if target is not the same as the destination, it is a "hinted" write, and will need to be sent to the ultimate target when it becomes alive again.
getHintedHandoffEnabled() - Method in class org.apache.cassandra.service.StorageProxy
 
getHintedHandoffEnabled() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getHits() - Method in class org.apache.cassandra.cache.InstrumentedCache
 
getHits() - Method in interface org.apache.cassandra.cache.JMXInstrumentedCacheMBean
total cache hit count since cache creation
getHost() - Method in class org.apache.cassandra.streaming.StreamInSession
 
getHost() - Method in class org.apache.cassandra.streaming.StreamOutSession
 
getId(String, String) - Static method in class org.apache.cassandra.config.CFMetaData
 
getId() - Method in class org.apache.cassandra.thrift.CfDef
 
getIdentityFilter(DecoratedKey, QueryPath) - Static method in class org.apache.cassandra.db.filter.QueryFilter
return a QueryFilter object that includes every column in the row.
getIdleThreads() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon.CleaningThreadPool
 
getIncomingFiles(String) - Method in class org.apache.cassandra.streaming.StreamingService
details about incoming streams.
getIncomingFiles(String) - Method in interface org.apache.cassandra.streaming.StreamingServiceMBean
details about incoming streams
getIncomingFiles(InetAddress) - Static method in class org.apache.cassandra.streaming.StreamInSession
query the status of incoming files.
getIncomingFiles(InetAddress) - Method in class org.apache.cassandra.tools.NodeProbe
 
getIndex_clause() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
getIndex_name() - Method in class org.apache.cassandra.thrift.ColumnDef
 
getIndex_type() - Method in class org.apache.cassandra.thrift.ColumnDef
 
getIndexAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getIndexedColumnFamilyStore(ByteBuffer) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getIndexedColumns() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getIndexedReadBufferSizeInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getIndexInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getIndexKeyFor(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getIndexName() - Method in class org.apache.cassandra.config.ColumnDefinition
 
getIndexOperator(String) - Static method in class org.apache.cassandra.cli.CliUtils
Returns IndexOperator from string representation
getIndexPositions() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
getIndexType() - Method in class org.apache.cassandra.config.ColumnDefinition
 
getInitialAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInitialToken() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInMemoryCompactionLimit() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInputColumnFamily(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputKeyspace(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputKeyspacePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputKeyspaceUserName(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputProtocol() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
getInputSlicePredicate(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputSplitSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInternal(K) - Method in class org.apache.cassandra.cache.InstrumentedCache
 
getInternalReply(byte[]) - Method in class org.apache.cassandra.net.Message
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
getIre() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
getIterator(Collection<Memtable>, Collection<SSTableReader>, DecoratedKey, DecoratedKey, QueryFilter, AbstractType, ColumnFamilyStore) - Static method in class org.apache.cassandra.db.RowIteratorFactory
Get a row iterator over the provided memtables and sstables, between the provided keys and filtered by the queryfilter.
getJmxName() - Method in enum org.apache.cassandra.concurrent.Stage
 
getJmxType() - Method in enum org.apache.cassandra.concurrent.Stage
 
getJobJarLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getJobTrackerAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getJoiningNodes() - Method in class org.apache.cassandra.service.StorageService
 
getJoiningNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve the list of nodes currently bootstrapping into the ring.
getJoiningNodes() - Method in class org.apache.cassandra.tools.NodeProbe
 
getKey(Tree) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getKey() - Method in interface org.apache.cassandra.db.columniterator.IColumnIterator
 
getKey() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
getKey() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
getKey() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
getKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
getKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
getKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
getKey() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
getKey() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
getKey() - Method in class org.apache.cassandra.thrift.KeyCount
 
getKey() - Method in class org.apache.cassandra.thrift.KeySlice
 
getKey_cache_save_period_in_seconds() - Method in class org.apache.cassandra.thrift.CfDef
 
getKey_cache_size() - Method in class org.apache.cassandra.thrift.CfDef
 
getKeyAsBytes(String, Tree) - Method in class org.apache.cassandra.cli.CliClient
 
getKeyCache() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getKeyCache() - Method in class org.apache.cassandra.io.sstable.SSTableTracker
 
getKeyCacheCapacity() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getKeyCacheMBean(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getKeyCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.config.CFMetaData
 
getKeyCacheSize() - Method in class org.apache.cassandra.config.CFMetaData
 
getKeyCacheSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getKeyCacheWriter() - Method in class org.apache.cassandra.io.sstable.SSTableTracker
 
getKeys() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
getKeys() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
getKeys_per_split() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
getKeySamples() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getKeysCachedFor(String, String, long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getKeySet() - Method in class org.apache.cassandra.cache.InstrumentedCache
 
getKeysIterator() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
getKeysIterator() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
getKeySpace() - Method in class org.apache.cassandra.cli.CliClient
 
getKeySpace(Tree, List<KsDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getKeySpace(String, List<KsDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getKeyspace() - Method in class org.apache.cassandra.service.ClientState
 
getKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
getKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
getKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
getKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
getKeyspace() - Method in class org.apache.cassandra.thrift.CfDef
 
getKeyspaces() - Method in class org.apache.cassandra.service.StorageService
 
getKeyspaces() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getKeyspaces() - Method in class org.apache.cassandra.tools.NodeProbe
 
getKeysSize() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
getKeysSize() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
getKs_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
getKs_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
getKSMetaData(String) - Method in class org.apache.cassandra.cli.CliClient
 
getKSMetaData(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getLastMigrationId() - Static method in class org.apache.cassandra.db.migration.Migration
 
getLastOutput() - Method in class org.apache.cassandra.hadoop.streaming.AvroOutputReader
 
getLeavingEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
caller should not modify leavingEndpoints
getLeavingNodes() - Method in class org.apache.cassandra.service.StorageService
 
getLeavingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve the list of nodes currently leaving the ring.
getLeavingNodes() - Method in class org.apache.cassandra.tools.NodeProbe
 
getLength() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
getLength() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
Returns the length of the valid data currently in the buffer.
getLength() - Method in class org.apache.cassandra.io.util.OutputBuffer
 
getLifetimeReadLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getLifetimeReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getLifetimeWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getLifetimeWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getListenAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getLiveDiskSpaceUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getLiveDiskSpaceUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getLiveMembers() - Method in class org.apache.cassandra.gms.Gossiper
 
getLiveNaturalEndpoints(String, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
This method attempts to return N endpoints that are responsible for storing the specified key i.e for replication.
getLiveNaturalEndpoints(String, Token) - Method in class org.apache.cassandra.service.StorageService
 
getLiveNodes() - Method in class org.apache.cassandra.service.StorageService
 
getLiveNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve the list of live nodes in the cluster, where "liveness" is determined by the failure detector of the node being queried.
getLiveNodes() - Method in class org.apache.cassandra.tools.NodeProbe
 
getLiveSize() - Method in class org.apache.cassandra.io.sstable.SSTableTracker
 
getLiveSSTableCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getLiveSSTableCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getLoad() - Method in class org.apache.cassandra.service.StorageService
raw load value
getLoad() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Numeric load value.
getLoadInfo() - Method in class org.apache.cassandra.service.StorageLoadBalancer
 
getLoadMap() - Method in class org.apache.cassandra.service.StorageService
 
getLoadMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Human-readable load value.
getLoadMap() - Method in class org.apache.cassandra.tools.NodeProbe
 
getLoadString() - Method in class org.apache.cassandra.service.StorageService
 
getLoadString() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Human-readable load value
getLoadString() - Method in class org.apache.cassandra.tools.NodeProbe
 
getLocalAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.Column
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.ColumnFamily
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.DeletedColumn
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.ExpiringColumn
 
getLocalDeletionTime() - Method in interface org.apache.cassandra.db.IColumn
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.SuperColumn
 
getLocalMigrations(UUID, UUID) - Static method in class org.apache.cassandra.db.migration.Migration
load serialized migrations.
getLocalPrimaryRange() - Method in class org.apache.cassandra.service.StorageService
 
getLocalRanges(String) - Method in class org.apache.cassandra.service.StorageService
 
getLocalToken() - Method in class org.apache.cassandra.service.StorageService
 
getLocations() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.Column
 
getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.ColumnFamily
 
getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.DeletedColumn
 
getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.ExpiringColumn
 
getMarkedForDeleteAt() - Method in interface org.apache.cassandra.db.IColumn
 
getMarkedForDeleteAt() - Method in interface org.apache.cassandra.db.IColumnContainer
 
getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.SuperColumn
 
getMax_compaction_threshold() - Method in class org.apache.cassandra.thrift.CfDef
 
getMaxCompactionThreshold() - Method in class org.apache.cassandra.config.CFMetaData
 
getMaxHintWindow() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getMaxHintWindow() - Method in class org.apache.cassandra.service.StorageProxy
 
getMaxHintWindow() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getMaximumCompactionThreshold() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMaximumCompactionThreshold() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Gets the maximum number of sstables in queue before compaction kicks off
getMaxRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMaxRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
return the size of the largest compacted row
getMeanColumns() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMeanRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMeanRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
return the mean size of the rows compacted
getMemtable_flush_after_mins() - Method in class org.apache.cassandra.thrift.CfDef
 
getMemtable_operations_in_millions() - Method in class org.apache.cassandra.thrift.CfDef
 
getMemtable_throughput_in_mb() - Method in class org.apache.cassandra.thrift.CfDef
 
getMemtableColumnIterator(ColumnFamily, DecoratedKey, AbstractType) - Method in interface org.apache.cassandra.db.filter.IFilter
returns an iterator that returns columns from the given memtable matching the Filter criteria in sorted order.
getMemtableColumnIterator(ColumnFamily, DecoratedKey, AbstractType) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getMemtableColumnIterator(Memtable, AbstractType) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
getMemtableColumnIterator(ColumnFamily, DecoratedKey, AbstractType) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
getMemtableColumnIterator(ColumnFamily, DecoratedKey, AbstractType) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getMemtableColumnsCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMemtableColumnsCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Returns the total number of columns present in the memtable.
getMemtableDataSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMemtableDataSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Returns the total amount of data stored in the memtable, including column related overhead.
getMemtableFlushAfterMins() - Method in class org.apache.cassandra.config.CFMetaData
 
getMemtableFlushAfterMins() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMemtableFlushAfterMins() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getMemtableOperationsInMillions() - Method in class org.apache.cassandra.config.CFMetaData
 
getMemtableOperationsInMillions() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMemtableOperationsInMillions() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getMemtablesPendingFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMemtableSwitchCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMemtableSwitchCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Returns the number of times that a flush has resulted in the memtable being switched out.
getMemtableThroughputInMb() - Method in class org.apache.cassandra.config.CFMetaData
 
getMemtableThroughputInMB() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMemtableThroughputInMB() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getMessage() - Method in class org.apache.cassandra.db.IndexScanCommand
 
getMessage() - Method in class org.apache.cassandra.db.RangeSliceCommand
 
getMessageBody() - Method in class org.apache.cassandra.net.Message
 
getMessageCount() - Method in interface org.apache.cassandra.service.IResponseResolver
 
getMessageCount() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
getMessageCount() - Method in class org.apache.cassandra.service.ReadResponseResolver
 
getMessages() - Method in interface org.apache.cassandra.service.IResponseResolver
 
getMessages() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
getMessages() - Method in class org.apache.cassandra.service.ReadResponseResolver
 
getMessageType() - Method in class org.apache.cassandra.net.Message
 
getMin_compaction_threshold() - Method in class org.apache.cassandra.thrift.CfDef
 
getMinCompactionThreshold() - Method in class org.apache.cassandra.config.CFMetaData
 
getMinimumCompactionThreshold() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMinimumCompactionThreshold() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Gets the minimum number of sstables in queue before compaction kicks off
getMinimumToken() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
getMinimumToken() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getMinimumToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
getMinimumToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getMinimumToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getMinRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMinRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
return the size of the smallest compacted row
getMsProxy() - Method in class org.apache.cassandra.tools.NodeProbe
 
getMutation_map() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
getMutation_mapSize() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
getName() - Method in class org.apache.cassandra.thrift.CfDef
 
getName() - Method in class org.apache.cassandra.thrift.Column
 
getName() - Method in class org.apache.cassandra.thrift.ColumnDef
 
getName() - Method in class org.apache.cassandra.thrift.KsDef
 
getName() - Method in class org.apache.cassandra.thrift.SuperColumn
 
getNamesFilter(DecoratedKey, QueryPath, SortedSet<ByteBuffer>) - Static method in class org.apache.cassandra.db.filter.QueryFilter
 
getNamesFilter(DecoratedKey, QueryPath, ByteBuffer) - Static method in class org.apache.cassandra.db.filter.QueryFilter
convenience method for creating a name filter matching a single column
getNamesIterator(DecoratedKey, ColumnFamily, NamesQueryFilter) - Static method in class org.apache.cassandra.db.Memtable
 
getNaturalEndpoints(Token) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
get the (possibly cached) endpoints that should store the given Token Note that while the endpoints are conceptually a Set (no duplicates will be included), we return a List to avoid an extra allocation when sorting by proximity later
getNaturalEndpoints(String, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
This method returns the N endpoints that are responsible for storing the specified key i.e for replication.
getNaturalEndpoints(String, byte[]) - Method in class org.apache.cassandra.service.StorageService
 
getNaturalEndpoints(String, Token) - Method in class org.apache.cassandra.service.StorageService
This method returns the N endpoints that are responsible for storing the specified key i.e for replication.
getNaturalEndpoints(String, byte[]) - Method in interface org.apache.cassandra.service.StorageServiceMBean
This method returns the N endpoints that are responsible for storing the specified key i.e for replication.
getNextAvailableDataLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNextVersion() - Static method in class org.apache.cassandra.gms.VersionGenerator
 
getNfe() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
getNfe() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
getNodeProbe() - Method in class org.apache.cassandra.cli.CliSessionState
 
getNodeValue(String) - Method in class org.apache.cassandra.utils.XMLUtils
 
getNodeValues(String) - Method in class org.apache.cassandra.utils.XMLUtils
 
getNonSystemTables() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNumWords() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Expert: gets the number of longs in the array that are in use
getObjectCount() - Method in interface org.apache.cassandra.cache.IAggregatableCacheProvider
 
getOp() - Method in class org.apache.cassandra.thrift.IndexExpression
 
getOpCount() - Method in class org.apache.cassandra.utils.LatencyTracker
 
getOperationMode() - Method in class org.apache.cassandra.service.StorageService
 
getOperationMode() - Method in interface org.apache.cassandra.service.StorageServiceMBean
get the operational mode (leaving, joining, normal, decommissioned, client)
getOperationMode() - Method in class org.apache.cassandra.tools.NodeProbe
 
getOutgoingFiles(String) - Method in class org.apache.cassandra.streaming.StreamingService
outgoing streams
getOutgoingFiles(String) - Method in interface org.apache.cassandra.streaming.StreamingServiceMBean
outgoing streams
getOutgoingFiles(InetAddress) - Static method in class org.apache.cassandra.streaming.StreamOutSession
 
getOutputColumnFamily(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
The OutputCommitter for this format does not write any data to the DFS.
getOutputKeyspace(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputKeyspacePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputKeyspaceUserName(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputProtocol() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
getOwnership() - Method in class org.apache.cassandra.service.StorageService
 
getOwnership() - Method in interface org.apache.cassandra.service.StorageServiceMBean
given a list of tokens (representing the nodes in the cluster), returns a mapping from "token -> %age of cluster owned by that token"
getOwnership() - Method in class org.apache.cassandra.tools.NodeProbe
 
getPartitioner() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPartitioner(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getPartitioner() - Static method in class org.apache.cassandra.service.StorageService
 
getPath() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getPath() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
getPath() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
getPath() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
getPath() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
getPendingAddressRanges(TokenMetadata, Token, InetAddress) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getPendingMessages() - Method in class org.apache.cassandra.net.OutboundTcpConnection
 
getPendingRanges(String) - Method in class org.apache.cassandra.locator.TokenMetadata
a mutable map may be returned but caller should not modify it
getPendingRanges(String, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getPendingRangeToEndpointMap(String) - Method in class org.apache.cassandra.service.StorageService
 
getPendingRangeToEndpointMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve a map of pending ranges to endpoints that describe the ring topology
getPendingTasks() - Method in interface org.apache.cassandra.concurrent.IExecutorMBean
Get the number of tasks waiting to be executed
getPendingTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
Get the number of tasks waiting to be executed
getPendingTasks() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getPendingTasks() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getPendingTasks() - Method in class org.apache.cassandra.db.CompactionManager
 
getPendingTasks() - Method in interface org.apache.cassandra.db.CompactionManagerMBean
 
getPhiConvictThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPhiConvictThreshold() - Method in class org.apache.cassandra.gms.FailureDetector
 
getPhiConvictThreshold() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
getPosition(DecoratedKey, SSTableReader.Operator) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getPosition() - Method in class org.apache.cassandra.io.util.AbstractDataInput
 
getPosition() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
getPositionsForRanges(Collection<Range>) - Method in class org.apache.cassandra.io.sstable.SSTableReader
Determine the minimal set of sections that can be extracted from this SSTable to cover the given ranges.
getPredecessor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
getPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
getPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
getPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
getPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
getPredicate() - Method in class org.apache.cassandra.thrift.Deletion
 
getPrimaryRangeFor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getPrimaryRangeForEndpoint(InetAddress) - Method in class org.apache.cassandra.service.StorageService
Get the primary range for the specified endpoint.
getProgress() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
getProtectedField(Class, String) - Static method in class org.apache.cassandra.utils.FBUtilities
Used to get access to protected/private field of the specified class
getProtocol(TTransport) - Method in class org.apache.cassandra.thrift.TBinaryProtocol.Factory
 
getRack(InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
Return the rack for which an endpoint resides in
getRack(InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getRack(InetAddress) - Method in class org.apache.cassandra.locator.Ec2Snitch
 
getRack(String) - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
 
getRack(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
Provides the Rack name depending on the respective snitch used, given the host name/ip
getRack(InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
returns a String repesenting the rack this endpoint belongs to
getRack(InetAddress) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
Return the rack for which an endpoint resides in
getRack(InetAddress) - Method in class org.apache.cassandra.locator.RackInferringSnitch
 
getRack(InetAddress) - Method in class org.apache.cassandra.locator.SimpleSnitch
 
getRandomToken() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
getRandomToken() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getRandomToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
getRandomToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getRandomToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getRange(ByteBuffer) - Method in class org.apache.cassandra.client.RingCache
 
getRange() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
getRangeAddresses(TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getRangeBatchSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
The number of rows to request with each get range slices request.
getRangeOperations() - Method in class org.apache.cassandra.service.StorageProxy
 
getRangeOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRangeSlice(ByteBuffer, AbstractBounds, int, IFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Fetch a range of rows and columns from memtables/sstables.
getRangeSlice(RangeSliceCommand, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
 
getRangeToAddressMap(String) - Method in class org.apache.cassandra.service.StorageService
 
getRangeToEndpointMap(String) - Method in class org.apache.cassandra.service.StorageService
for a keyspace, return the ranges and corresponding hosts for a given keyspace.
getRangeToEndpointMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve a map of range to end points that describe the ring topology of a Cassandra cluster.
getRawCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
raw cached row -- does not fetch the row if it is not present.
getRead_repair_chance() - Method in class org.apache.cassandra.thrift.CfDef
 
getReadCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getReadCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getReadOperations() - Method in class org.apache.cassandra.service.StorageProxy
 
getReadOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getReadRepairChance() - Method in class org.apache.cassandra.config.CFMetaData
 
getRecentBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getRecentBloomFilterFalsePositives() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentBloomFilterFalsePositives() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentBloomFilterFalseRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getRecentFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getRecentHitRate() - Method in class org.apache.cassandra.cache.InstrumentedCache
 
getRecentHitRate() - Method in interface org.apache.cassandra.cache.JMXInstrumentedCacheMBean
hits / requests since the last time getHitRate was called.
getRecentLatencyHistogramMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
 
getRecentLatencyMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
returns microseconds
getRecentRangeLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentRangeLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRecentRangeLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentRangeLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRecentReadLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentReadLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRecentReadLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentReadLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentReadLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentReadLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRecentSSTablesPerReadHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentSSTablesPerReadHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getRecentWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRecentWriteLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentWriteLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentWriteLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentWriteLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Deprecated. 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Get the RecordWriter for the given task.
getReduceCacheCapacityTo() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getReduceCacheSizesAt() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getReduced() - Method in class org.apache.cassandra.io.CompactionIterator
 
getReduced() - Method in class org.apache.cassandra.utils.ReducingIterator
return the last object computed by reduce
getRegisteredCallbackAge(String) - Method in class org.apache.cassandra.net.MessagingService
 
getReleaseVersion() - Method in class org.apache.cassandra.service.StorageService
 
getReleaseVersion() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Fetch a string representation of the Cassandra version.
getReleaseVersion() - Method in class org.apache.cassandra.tools.NodeProbe
 
getReleaseVersionString() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getRemovalStatus() - Method in class org.apache.cassandra.service.StorageService
Get the status of a token removal.
getRemovalStatus() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Get the status of a token removal.
getRemovalStatus() - Method in class org.apache.cassandra.tools.NodeProbe
 
getRepairSession(String, String...) - Method in class org.apache.cassandra.service.AntiEntropyService
Requests repairs for the given table and column families, and blocks until all repairs have been completed.
getReplication_factor() - Method in class org.apache.cassandra.thrift.KsDef
 
getReplicationFactor() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getReplicationFactor() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
getReplicationFactor(String) - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
getReplicationStrategy() - Method in class org.apache.cassandra.db.Table
 
getReply(Message) - Method in class org.apache.cassandra.db.RangeSliceReply
 
getReply(InetAddress, byte[]) - Method in class org.apache.cassandra.net.Message
 
getRequestedNodeList(String) - Method in class org.apache.cassandra.utils.XMLUtils
 
getRequests() - Method in class org.apache.cassandra.cache.InstrumentedCache
 
getRequests() - Method in interface org.apache.cassandra.cache.JMXInstrumentedCacheMBean
total request count since cache creation
getRequestScheduler() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRequestSchedulerId() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRequestSchedulerOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getResetInterval() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getResetInterval() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
getResponse(ReadCommand, Row) - Static method in class org.apache.cassandra.db.ReadVerbHandler
 
getResponseCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getResponseCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Completed tasks for Response(GOSSIP & RESPONSE) TCP Connections
getResponsePendingTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getResponsePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Pending tasks for Response(GOSSIP & RESPONSE) TCP Connections
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.batch_mutate_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_cluster_name_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_keyspace_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_keyspaces_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_partitioner_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_ring_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_schema_versions_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_snitch_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_splits_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_version_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_count_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_indexed_slices_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_range_slices_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_slice_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.insert_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.login_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.multiget_count_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.multiget_slice_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.remove_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.set_keyspace_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_add_column_family_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_add_keyspace_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_drop_column_family_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_drop_keyspace_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_update_column_family_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_update_keyspace_call
 
getResult() - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.truncate_call
 
getReverseComparator() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
getReverseSortedColumns() - Method in class org.apache.cassandra.db.ColumnFamily
 
getRow(Table) - Method in class org.apache.cassandra.db.ReadCommand
 
getRow(Table) - Method in class org.apache.cassandra.db.SliceByNamesReadCommand
 
getRow(Table) - Method in class org.apache.cassandra.db.SliceFromReadCommand
 
getRow(QueryFilter) - Method in class org.apache.cassandra.db.Table
 
getRow_cache_save_period_in_seconds() - Method in class org.apache.cassandra.thrift.CfDef
 
getRow_cache_size() - Method in class org.apache.cassandra.thrift.CfDef
 
getRowCache() - Method in class org.apache.cassandra.io.sstable.SSTableTracker
 
getRowCacheCapacity() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRowCacheMBean(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getRowCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.config.CFMetaData
 
getRowCacheSize() - Method in class org.apache.cassandra.config.CFMetaData
 
getRowCacheSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRowCacheWriter() - Method in class org.apache.cassandra.io.sstable.SSTableTracker
 
getRowMutation(String, ByteBuffer, Map<String, List<ColumnOrSuperColumn>>) - Static method in class org.apache.cassandra.db.RowMutation
 
getRowMutationFromMutations(String, ByteBuffer, Map<String, List<Mutation>>) - Static method in class org.apache.cassandra.db.RowMutation
 
getRowsCachedFor(String, String, long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcKeepAlive() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcPort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcPort(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getRpcRecvBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcSendBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSavedCachesLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSavedToken() - Static method in class org.apache.cassandra.db.SystemTable
 
getScanner(int, QueryFilter) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getScanners() - Method in class org.apache.cassandra.io.CompactionIterator
 
getSchedulingValue() - Method in class org.apache.cassandra.service.ClientState
 
getScores() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getScores() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
getSeeds() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSegment() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogContext
 
getSegment(long, int) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile
 
getSegment(long, int) - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile
 
getSegment(long, int) - Method in class org.apache.cassandra.io.util.SegmentedFile
 
getSerializedBuffer() - Method in class org.apache.cassandra.db.RowMutation
 
getSerializedKeyCachePath(String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSerializedRowCachePath(String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSessionId() - Method in class org.apache.cassandra.streaming.StreamInSession
 
getSessionId() - Method in class org.apache.cassandra.streaming.StreamOutSession
 
getSize() - Method in class org.apache.cassandra.cache.InstrumentedCache
 
getSize() - Method in interface org.apache.cassandra.cache.JMXInstrumentedCacheMBean
 
getSlice_range() - Method in class org.apache.cassandra.thrift.SlicePredicate
 
getSlicedReadBufferSizeInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSliceFilter(DecoratedKey, QueryPath, ByteBuffer, ByteBuffer, boolean, int) - Static method in class org.apache.cassandra.db.filter.QueryFilter
 
getSliceIterator(DecoratedKey, ColumnFamily, SliceQueryFilter, AbstractType) - Static method in class org.apache.cassandra.db.Memtable
obtain an iterator of columns in this memtable in the specified order starting from a given column.
getSnapshotPath(String, String, String) - Static method in class org.apache.cassandra.db.Table
 
getSortedColumns() - Method in class org.apache.cassandra.db.ColumnFamily
 
getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
 
getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
Sorts the Collection of node addresses by proximity to the given address
getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
returns a new List sorted by proximity to the given endpoint
getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.SimpleSnitch
 
getSources() - Static method in class org.apache.cassandra.streaming.StreamInSession
query method to determine which hosts are streaming to this node.
getSplits(JobContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
 
getSplits(String, String, Range, int) - Method in class org.apache.cassandra.service.StorageService
 
getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey) - Method in interface org.apache.cassandra.db.filter.IFilter
Get an iterator that returns columns from the given SSTable using the opened file matching the Filter criteria in sorted order.
getSSTableColumnIterator(SSTableReader, DecoratedKey) - Method in interface org.apache.cassandra.db.filter.IFilter
returns an iterator that returns columns from the given SSTable matching the Filter criteria in sorted order.
getSSTableColumnIterator(SSTableReader, DecoratedKey) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getSSTableColumnIterator(SSTableReader) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
getSSTableColumnIterator(SSTableReader, DecoratedKey) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getSSTables() - Method in class org.apache.cassandra.io.sstable.SSTableTracker
 
getSSTablesPerReadHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getSSTablesPerReadHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getStage(Stage) - Static method in class org.apache.cassandra.concurrent.StageManager
Retrieve a stage from the StageManager
getStart() - Method in class org.apache.cassandra.thrift.SliceRange
 
getStart_key() - Method in class org.apache.cassandra.thrift.IndexClause
 
getStart_key() - Method in class org.apache.cassandra.thrift.KeyRange
 
getStart_token() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
getStart_token() - Method in class org.apache.cassandra.thrift.KeyRange
 
getStart_token() - Method in class org.apache.cassandra.thrift.TokenRange
 
getStartToken() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
getStatus() - Method in class org.apache.cassandra.streaming.StreamingService
 
getStatus() - Method in interface org.apache.cassandra.streaming.StreamingServiceMBean
What's currently happening wrt streaming.
getStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getStrategy_class() - Method in class org.apache.cassandra.thrift.KsDef
 
getStrategy_options() - Method in class org.apache.cassandra.thrift.KsDef
 
getStrategy_optionsSize() - Method in class org.apache.cassandra.thrift.KsDef
 
getStreamDestinations() - Method in class org.apache.cassandra.streaming.StreamingService
hosts receiving outgoing streams.
getStreamDestinations() - Method in interface org.apache.cassandra.streaming.StreamingServiceMBean
hosts recieving outgoing streams
getStreamDestinations() - Method in class org.apache.cassandra.tools.NodeProbe
 
getStreamSources() - Method in class org.apache.cassandra.streaming.StreamingService
hosts sending incoming streams
getStreamSources() - Method in interface org.apache.cassandra.streaming.StreamingServiceMBean
hosts sending incoming streams.
getStreamSources() - Method in class org.apache.cassandra.tools.NodeProbe
 
getString(AbstractType) - Method in class org.apache.cassandra.db.Column
 
getString(AbstractType) - Method in class org.apache.cassandra.db.ExpiringColumn
 
getString(AbstractType) - Method in interface org.apache.cassandra.db.IColumn
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
get a string representation of the bytes suitable for log messages
getString(Collection<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
getString(AbstractType) - Method in class org.apache.cassandra.db.SuperColumn
 
getSubColumn(ByteBuffer) - Method in class org.apache.cassandra.db.Column
 
getSubColumn(ByteBuffer) - Method in interface org.apache.cassandra.db.IColumn
 
getSubColumn(ByteBuffer) - Method in class org.apache.cassandra.db.SuperColumn
 
getSubColumns() - Method in class org.apache.cassandra.db.Column
 
getSubColumns() - Method in interface org.apache.cassandra.db.IColumn
 
getSubColumns() - Method in class org.apache.cassandra.db.SuperColumn
 
getSubComparator(String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSubComparator() - Method in class org.apache.cassandra.db.ColumnFamily
 
getSubcomparator_type() - Method in class org.apache.cassandra.thrift.CfDef
 
getSubsnitchClassName() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getSubsnitchClassName() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
getSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
getSuccessIterator() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
getSuccessIterator() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
getSuccessIterator() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
getSuccessIterator() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
getSuccessIterator() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
getSuccessIterator() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
getSuccessor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getSuccessor(InetAddress) - Method in class org.apache.cassandra.service.StorageService
 
getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
getSuccessSize() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
getSuper_column() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
getSuper_column() - Method in class org.apache.cassandra.thrift.ColumnParent
 
getSuper_column() - Method in class org.apache.cassandra.thrift.ColumnPath
 
getSuper_column() - Method in class org.apache.cassandra.thrift.Deletion
 
getTable() - Method in class org.apache.cassandra.db.RowMutation
 
getTableDefinition(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTableMetaData(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTableName() - Method in class org.apache.cassandra.db.Memtable
 
getTableName() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getTables() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTaskType() - Method in class org.apache.cassandra.db.Table.IndexBuilder
 
getTaskType() - Method in class org.apache.cassandra.io.CompactionIterator
 
getTaskType() - Method in interface org.apache.cassandra.io.ICompactionInfo
 
getTaskType() - Method in class org.apache.cassandra.io.sstable.CacheWriter
 
getTaskType() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
getTaskType() - Method in class org.apache.cassandra.io.sstable.SSTableWriter.Builder
 
getTe() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
getTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
getTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
getTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
getTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
getTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
getTe() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
getTe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
getTe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
getTe() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
getTempSSTablePath(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getThreadPoolMBeanProxies() - Method in class org.apache.cassandra.tools.NodeProbe
 
getThreads() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon.CleaningThreadPool
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.AuthenticationException._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.AuthenticationRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.AuthorizationException._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_version_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.describe_version_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_count_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_count_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_slice_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.get_slice_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.insert_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.insert_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.login_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.login_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.remove_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.remove_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.truncate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Cassandra.truncate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.CfDef._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Column._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.ColumnDef._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.ColumnOrSuperColumn._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.ColumnParent._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.ColumnPath._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Deletion._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.IndexClause._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.IndexExpression._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.InvalidRequestException._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.KeyCount._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.KeyRange._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.KeySlice._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.KsDef._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.Mutation._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.NotFoundException._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.SlicePredicate._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.SliceRange._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.SuperColumn._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.TimedOutException._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.TokenRange._Fields
 
getThriftFieldId() - Method in enum org.apache.cassandra.thrift.UnavailableException._Fields
 
getThriftFramedTransportSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getThriftMaxMessageLength() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTimestamp() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
getTimestamp() - Method in class org.apache.cassandra.thrift.Column
 
getTimestamp() - Method in class org.apache.cassandra.thrift.Deletion
 
getTimestampedSnapshotName(String) - Static method in class org.apache.cassandra.db.Table
 
getTimeToLive() - Method in class org.apache.cassandra.db.ExpiringColumn
 
getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
getToken(ByteBuffer) - Method in interface org.apache.cassandra.dht.IPartitioner
 
getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getToken(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getToken() - Method in class org.apache.cassandra.service.StorageService
 
getToken() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Fetch a string representation of the token.
getToken() - Method in class org.apache.cassandra.tools.NodeProbe
 
getTokenFactory() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
getTokenFactory() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getTokenFactory() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
getTokenFactory() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getTokenFactory() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getTokenMetadata() - Method in class org.apache.cassandra.service.StorageService
 
getTokenToEndpointMap() - Method in class org.apache.cassandra.locator.TokenMetadata
Return the Token to Endpoint map for all the node in the cluster, including bootstrapping ones.
getTokenToEndpointMap() - Method in class org.apache.cassandra.service.StorageService
 
getTokenToEndpointMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve a map of tokens to endpoints, including the bootstrapping ones.
getTokenToEndpointMap() - Method in class org.apache.cassandra.tools.NodeProbe
 
getTotalBytes() - Method in class org.apache.cassandra.db.Table.IndexBuilder
 
getTotalBytes() - Method in class org.apache.cassandra.io.CompactionIterator
 
getTotalBytes() - Method in interface org.apache.cassandra.io.ICompactionInfo
 
getTotalBytes() - Method in class org.apache.cassandra.io.sstable.CacheWriter
 
getTotalBytes() - Method in class org.apache.cassandra.io.sstable.KeyIterator
 
getTotalBytes() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
getTotalBytes(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.SSTable
 
getTotalBytes() - Method in class org.apache.cassandra.io.sstable.SSTableWriter.Builder
 
getTotalDiskSpaceUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTotalDiskSpaceUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getTotalLatencyHistogramMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
 
getTotalLatencyMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
returns microseconds
getTotalRangeLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalRangeLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalRangeLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalRangeLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalReadLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalReadLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTotalReadLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getTotalReadLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalReadLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalSize() - Method in class org.apache.cassandra.io.sstable.SSTableTracker
 
getTotalWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalWriteLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTotalWriteLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getTotalWriteLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalWriteLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getTtl() - Method in class org.apache.cassandra.thrift.Column
 
getTypeByFunction(String) - Static method in class org.apache.cassandra.cli.CliClient
Get AbstractType by function name
getUe() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
getUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
getUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
getUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
getUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
getUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
getUe() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
getUe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
getUe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
getUe() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
getUe() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
getUnreachableMembers() - Method in class org.apache.cassandra.gms.Gossiper
 
getUnreachableNodes() - Method in class org.apache.cassandra.service.StorageService
 
getUnreachableNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve the list of unreachable nodes in the cluster, as determined by this node's failure detector.
getUnreachableNodes() - Method in class org.apache.cassandra.tools.NodeProbe
 
getUpdateInterval() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getUpdateInterval() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
getUptime() - Method in class org.apache.cassandra.tools.NodeProbe
 
getUsername() - Method in class org.apache.cassandra.cli.CliClient
 
getUUID(ByteBuffer) - Static method in class org.apache.cassandra.utils.UUIDGen
creates a type 1 uuid from raw bytes.
getValidation_class() - Method in class org.apache.cassandra.thrift.ColumnDef
 
getValidator() - Method in enum org.apache.cassandra.cli.CliClient.Function
 
getValidColumnFamilies(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
getValue() - Method in class org.apache.cassandra.thrift.Column
 
getValue() - Method in enum org.apache.cassandra.thrift.ConsistencyLevel
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class org.apache.cassandra.thrift.IndexExpression
 
getValue() - Method in enum org.apache.cassandra.thrift.IndexOperator
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.cassandra.thrift.IndexType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValueValidator(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
 
getValueValidator(String, String, ByteBuffer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getVerb() - Method in class org.apache.cassandra.net.Message
 
getVerbHandler(StorageService.Verb) - Method in class org.apache.cassandra.net.MessagingService
This method returns the verb handler associated with the registered verb.
getVersion() - Method in class org.apache.cassandra.db.migration.Migration
 
getVersion(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
getWhy() - Method in exception org.apache.cassandra.thrift.AuthenticationException
 
getWhy() - Method in exception org.apache.cassandra.thrift.AuthorizationException
 
getWhy() - Method in exception org.apache.cassandra.thrift.InvalidRequestException
 
getWriteCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getWriteCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getWriteEndpoints(Token, String, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.TokenMetadata
write endpoints may be different from read endpoints, because read endpoints only need care about the "natural" nodes for a token, but write endpoints also need to account for nodes that are bootstrapping into the ring, and write data there too so that they stay up to date during the bootstrap process.
getWriteOperations() - Method in class org.apache.cassandra.service.StorageProxy
 
getWriteOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getWriteResponseHandler(Collection<InetAddress>, Multimap<InetAddress, InetAddress>, ConsistencyLevel) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getWriteResponseHandler(Collection<InetAddress>, Multimap<InetAddress, InetAddress>, ConsistencyLevel) - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
This method will generate the QRH object and returns.
GossipDigest - Class in org.apache.cassandra.gms
Contains information about a specified list of Endpoints and the largest version of the state they have generated as known by the local endpoint.
GossipDigestAck2VerbHandler - Class in org.apache.cassandra.gms
 
GossipDigestAck2VerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestAck2VerbHandler
 
GossipDigestAckVerbHandler - Class in org.apache.cassandra.gms
 
GossipDigestAckVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestAckVerbHandler
 
GossipDigestSynVerbHandler - Class in org.apache.cassandra.gms
 
GossipDigestSynVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestSynVerbHandler
 
Gossiper - Class in org.apache.cassandra.gms
This module is responsible for Gossiping information for the local endpoint.
gossiperStarting() - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
 
gossiperStarting() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
gossiperStarting() - Method in class org.apache.cassandra.locator.Ec2Snitch
 
gossiperStarting() - Method in interface org.apache.cassandra.locator.IEndpointSnitch
called after Gossiper instance exists immediately before it starts gossiping
groups - Variable in class org.apache.cassandra.auth.AuthenticatedUser
 
GT - Static variable in class org.apache.cassandra.io.sstable.SSTableReader.Operator
 
guid() - Static method in class org.apache.cassandra.utils.GuidGenerator
 
guidAsBytes() - Static method in class org.apache.cassandra.utils.GuidGenerator
 
GuidGenerator - Class in org.apache.cassandra.utils
 
GuidGenerator() - Constructor for class org.apache.cassandra.utils.GuidGenerator
 
guidToString(byte[]) - Static method in class org.apache.cassandra.utils.GuidGenerator
 

H

handleMessage(Message, String, InetAddress) - Method in interface org.apache.cassandra.net.sink.IMessageSink
 
hasColumnFamilyAccess(String, Permission) - Method in class org.apache.cassandra.service.ClientState
Confirms that the client thread has the given Permission in the context of the given ColumnFamily and the current keyspace.
hasColumnFamilyListAccess(Permission) - Method in class org.apache.cassandra.service.ClientState
Confirms that the client thread has the given Permission for the ColumnFamily list of the current keyspace.
hasEncodedKeys - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
hash(String, byte[]) - Static method in class org.apache.cassandra.net.MessagingService
 
hash(ByteBuffer...) - Static method in class org.apache.cassandra.utils.FBUtilities
 
hash(Range) - Method in class org.apache.cassandra.utils.MerkleTree
Hash the given range in the tree.
hash - Variable in class org.apache.cassandra.utils.MerkleTree.RowHash
 
hash(byte[]) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
hash() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
hash32(ByteBuffer, int, int, int) - Static method in class org.apache.cassandra.utils.MurmurHash
 
hash64(ByteBuffer, int, int, long) - Static method in class org.apache.cassandra.utils.MurmurHash
 
hashCode() - Method in class org.apache.cassandra.config.CFMetaData
 
hashCode() - Method in class org.apache.cassandra.config.ColumnDefinition
 
hashCode() - Method in class org.apache.cassandra.config.KSMetaData
 
hashCode() - Method in class org.apache.cassandra.db.Column
 
hashCode() - Method in class org.apache.cassandra.db.ColumnFamily
 
hashCode() - Method in class org.apache.cassandra.db.DecoratedKey
 
hashCode() - Method in class org.apache.cassandra.dht.AbstractBounds
 
hashCode() - Method in class org.apache.cassandra.dht.BytesToken
 
hashCode() - Method in class org.apache.cassandra.dht.LocalToken
 
hashCode() - Method in class org.apache.cassandra.dht.Token
 
hashCode - Variable in class org.apache.cassandra.io.sstable.Component
 
hashCode() - Method in class org.apache.cassandra.io.sstable.Component
 
hashCode() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
hashCode() - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
hashCode() - Method in class org.apache.cassandra.streaming.PendingFile
 
hashCode() - Method in exception org.apache.cassandra.thrift.AuthenticationException
 
hashCode() - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
hashCode() - Method in exception org.apache.cassandra.thrift.AuthorizationException
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.login_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
hashCode() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
hashCode() - Method in class org.apache.cassandra.thrift.CfDef
 
hashCode() - Method in class org.apache.cassandra.thrift.Column
 
hashCode() - Method in class org.apache.cassandra.thrift.ColumnDef
 
hashCode() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
hashCode() - Method in class org.apache.cassandra.thrift.ColumnParent
 
hashCode() - Method in class org.apache.cassandra.thrift.ColumnPath
 
hashCode() - Method in class org.apache.cassandra.thrift.Deletion
 
hashCode() - Method in class org.apache.cassandra.thrift.IndexClause
 
hashCode() - Method in class org.apache.cassandra.thrift.IndexExpression
 
hashCode() - Method in exception org.apache.cassandra.thrift.InvalidRequestException
 
hashCode() - Method in class org.apache.cassandra.thrift.KeyCount
 
hashCode() - Method in class org.apache.cassandra.thrift.KeyRange
 
hashCode() - Method in class org.apache.cassandra.thrift.KeySlice
 
hashCode() - Method in class org.apache.cassandra.thrift.KsDef
 
hashCode() - Method in class org.apache.cassandra.thrift.Mutation
 
hashCode() - Method in exception org.apache.cassandra.thrift.NotFoundException
 
hashCode() - Method in class org.apache.cassandra.thrift.SlicePredicate
 
hashCode() - Method in class org.apache.cassandra.thrift.SliceRange
 
hashCode() - Method in class org.apache.cassandra.thrift.SuperColumn
 
hashCode() - Method in exception org.apache.cassandra.thrift.TimedOutException
 
hashCode() - Method in class org.apache.cassandra.thrift.TokenRange
 
hashCode() - Method in exception org.apache.cassandra.thrift.UnavailableException
 
hashCode() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
hashCode() - Method in class org.apache.cassandra.utils.Pair
 
hashdepth - Variable in class org.apache.cassandra.utils.MerkleTree
 
hashToBigInteger(ByteBuffer) - Static method in class org.apache.cassandra.utils.FBUtilities
 
hasIntRowSize - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
hasKeyspaceListAccess(Permission) - Method in class org.apache.cassandra.service.ClientState
Confirms that the client thread has the given Permission for the Keyspace list.
hasNext() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
hasNext() - Method in class org.apache.cassandra.db.RowIterator
 
hasNext() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
hasNext() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
hasNext() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
hasNext() - Method in class org.apache.cassandra.utils.DestructivePQIterator
 
hasStringsInBloomFilter - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
hasUnreclaimedSpace() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
Header - Class in org.apache.cassandra.net
 
HeaderTypes - Class in org.apache.cassandra.net
 
HeaderTypes() - Constructor for class org.apache.cassandra.net.HeaderTypes
 
headMap(ByteBuffer) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
hexToBytes(String) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
hexToBytes(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
HINT - Static variable in class org.apache.cassandra.db.RowMutation
 
hinted_handoff_enabled - Variable in class org.apache.cassandra.config.Config
 
hintedEndpoints - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
hintedHandoffEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
HintedHandOffManager - Class in org.apache.cassandra.db
For each endpoint for which we have hints, there is a row in the system hints CF.
HintedHandOffManager() - Constructor for class org.apache.cassandra.db.HintedHandOffManager
 
HintedHandOffManagerMBean - Interface in org.apache.cassandra.db
 
HINTS_CF - Static variable in class org.apache.cassandra.db.HintedHandOffManager
 
HintsCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
HISTORYFILE - Static variable in class org.apache.cassandra.cli.CliMain
 
hostName - Variable in class org.apache.cassandra.cli.CliSessionState
 

I

IAggregatableCacheProvider<K,V> - Interface in org.apache.cassandra.cache
 
IAsyncCallback - Interface in org.apache.cassandra.net
implementors of IAsyncCallback need to make sure that any public methods are threadsafe with respect to response() being called from the message service.
IAsyncResult - Interface in org.apache.cassandra.net
 
IAuthenticator - Interface in org.apache.cassandra.auth
 
IAuthority - Interface in org.apache.cassandra.auth
Cassandra's resource hierarchy looks something like: {{/cassandra/keyspaces/$ks_name/...}} In table form: /cassandra/ - no checked permissions - String * Separates Cassandra-internal resources from resources that might be provided by plugins.
IColumn - Interface in org.apache.cassandra.db
 
IColumnContainer - Interface in org.apache.cassandra.db
 
IColumnIterator - Interface in org.apache.cassandra.db.columniterator
 
ICommitLogExecutorService - Interface in org.apache.cassandra.db.commitlog
Like ExecutorService, but customized for batch and periodic commitlog execution.
ICompactionInfo - Interface in org.apache.cassandra.io
 
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.NamedThreadFactory
 
id() - Method in class org.apache.cassandra.db.ColumnFamily
 
id - Variable in class org.apache.cassandra.io.sstable.Component
 
id - Variable in class org.apache.cassandra.thrift.CfDef
 
IdentityQueryFilter - Class in org.apache.cassandra.db.columniterator
 
IdentityQueryFilter() - Constructor for class org.apache.cassandra.db.columniterator.IdentityQueryFilter
Only for use in testing; will read entire CF into memory.
IEndpointSnitch - Interface in org.apache.cassandra.locator
This interface helps determine location of node in the data center relative to another node.
IEndpointStateChangeSubscriber - Interface in org.apache.cassandra.gms
This is called by an instance of the IEndpointStateChangePublisher to notify interested parties about changes in the the state associated with any endpoint.
IExecutorMBean - Interface in org.apache.cassandra.concurrent
 
IFailureDetectionEventListener - Interface in org.apache.cassandra.gms
Implemented by the Gossiper to convict an endpoint based on the PHI calculated by the Failure Detector on the inter-arrival times of the heart beats.
IFailureDetector - Interface in org.apache.cassandra.gms
An interface that provides an application with the ability to query liveness information of a node in the cluster.
IFailureNotification - Interface in org.apache.cassandra.gms
 
IFilter - Interface in org.apache.cassandra.db.filter
Given an implementation-specific description of what columns to look for, provides methods to extract the desired columns from a Memtable, SSTable, or SuperColumn.
IFlushable - Interface in org.apache.cassandra.db
 
IIterableColumns - Interface in org.apache.cassandra.io.util
 
ILatencySubscriber - Interface in org.apache.cassandra.locator
 
IMessageCallback - Interface in org.apache.cassandra.net
 
IMessageSink - Interface in org.apache.cassandra.net.sink
 
importJson(String, String, String, String) - Static method in class org.apache.cassandra.tools.SSTableImport
Convert a JSON formatted file to an SSTable.
importSorted(String, ColumnFamily, String, IPartitioner<?>) - Static method in class org.apache.cassandra.tools.SSTableImport
 
in - Variable in class org.apache.cassandra.cli.CliSessionState
 
in_memory_compaction_limit_in_mb - Variable in class org.apache.cassandra.config.Config
 
IncomingStreamReader - Class in org.apache.cassandra.streaming
 
IncomingStreamReader(StreamHeader, SocketChannel) - Constructor for class org.apache.cassandra.streaming.IncomingStreamReader
 
IncomingTcpConnection - Class in org.apache.cassandra.net
 
IncomingTcpConnection(Socket) - Constructor for class org.apache.cassandra.net.IncomingTcpConnection
 
incrementAndGetGeneration() - Static method in class org.apache.cassandra.db.SystemTable
 
incrementDroppedMessages(StorageService.Verb) - Method in class org.apache.cassandra.net.MessagingService
 
incrementRowid() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
INDEX_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
index_clause - Variable in class org.apache.cassandra.db.IndexScanCommand
 
index_clause - Variable in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
index_interval - Variable in class org.apache.cassandra.config.Config
 
index_name - Variable in class org.apache.cassandra.config.RawColumnDefinition
 
index_name - Variable in class org.apache.cassandra.thrift.ColumnDef
 
index_type - Variable in class org.apache.cassandra.config.RawColumnDefinition
 
index_type - Variable in class org.apache.cassandra.thrift.ColumnDef
 
IndexCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
IndexClause - Class in org.apache.cassandra.thrift
 
IndexClause() - Constructor for class org.apache.cassandra.thrift.IndexClause
 
IndexClause(List<IndexExpression>, ByteBuffer, int) - Constructor for class org.apache.cassandra.thrift.IndexClause
 
IndexClause(IndexClause) - Constructor for class org.apache.cassandra.thrift.IndexClause
Performs a deep copy on other.
IndexClause._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
IndexExpression - Class in org.apache.cassandra.thrift
 
IndexExpression() - Constructor for class org.apache.cassandra.thrift.IndexExpression
 
IndexExpression(ByteBuffer, IndexOperator, ByteBuffer) - Constructor for class org.apache.cassandra.thrift.IndexExpression
 
IndexExpression(IndexExpression) - Constructor for class org.apache.cassandra.thrift.IndexExpression
Performs a deep copy on other.
IndexExpression._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
indexFor(ByteBuffer, List<IndexHelper.IndexInfo>, AbstractType, boolean) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
the index of the IndexInfo in which @name will be found.
IndexHelper - Class in org.apache.cassandra.io.sstable
Provides helper to serialize, deserialize and use column indexes.
IndexHelper() - Constructor for class org.apache.cassandra.io.sstable.IndexHelper
 
IndexHelper.IndexInfo - Class in org.apache.cassandra.io.sstable
 
IndexHelper.IndexInfo(ByteBuffer, ByteBuffer, long, long) - Constructor for class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
indexName(String, ColumnDefinition) - Static method in class org.apache.cassandra.config.CFMetaData
convention for nameing secondary indexes.
IndexOperator - Enum in org.apache.cassandra.thrift
 
indexPosition - Variable in class org.apache.cassandra.io.sstable.IndexSummary.KeyPosition
 
IndexScanCommand - Class in org.apache.cassandra.db
 
IndexScanCommand(String, String, IndexClause, SlicePredicate, AbstractBounds) - Constructor for class org.apache.cassandra.db.IndexScanCommand
 
IndexScanVerbHandler - Class in org.apache.cassandra.service
 
IndexScanVerbHandler() - Constructor for class org.apache.cassandra.service.IndexScanVerbHandler
 
IndexSummary - Class in org.apache.cassandra.io.sstable
Two approaches to building an IndexSummary: 1.
IndexSummary(long) - Constructor for class org.apache.cassandra.io.sstable.IndexSummary
 
IndexSummary.KeyPosition - Class in org.apache.cassandra.io.sstable
This is a simple container for the index Key and its corresponding position in the index file.
IndexSummary.KeyPosition(DecoratedKey, long) - Constructor for class org.apache.cassandra.io.sstable.IndexSummary.KeyPosition
 
IndexType - Enum in org.apache.cassandra.thrift
 
inFileMode() - Method in class org.apache.cassandra.cli.CliSessionState
 
inflate(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
 
inflate(ColumnDef) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
inflate(KsDef) - Static method in class org.apache.cassandra.config.KSMetaData
 
init(String[]) - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Initialize the Cassandra Daemon based on the given Commons Daemon-specific arguments.
init(String[]) - Method in interface org.apache.cassandra.service.CassandraDaemon
Initialize the Cassandra Daemon based on the given Commons Daemon-specific arguments.
init() - Method in class org.apache.cassandra.utils.MerkleTree
Initializes this tree by splitting it until hashdepth is reached, or until an additional level of splits would violate maxsize.
initCf(Integer, String) - Method in class org.apache.cassandra.db.Table
adds a cf to internal structures, ends up creating disk files).
initClient() - Method in class org.apache.cassandra.service.StorageService
 
initial_token - Variable in class org.apache.cassandra.config.Config
 
INITIAL_VERSION - Static variable in class org.apache.cassandra.config.DatabaseDescriptor
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
initialize(PipeMapRed) - Method in class org.apache.cassandra.hadoop.streaming.AvroOutputReader
 
initializeNodeUnsafe(InetAddress, int) - Method in class org.apache.cassandra.gms.Gossiper
This should *only* be used for testing purposes.
initRowCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
initServer() - Method in class org.apache.cassandra.service.StorageService
 
injectPreProcessed(ReadResponse) - Method in class org.apache.cassandra.service.ReadResponseResolver
hack so local reads don't force de/serialization of an extra real Message
inputStream(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Method in class org.apache.cassandra.avro.CassandraServer
 
insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.insert_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.insert_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
Insert a Column at the given column_parent.column_family and optional column_parent.super_column.
insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
instance - Static variable in class org.apache.cassandra.db.commitlog.CommitLog
 
instance - Static variable in class org.apache.cassandra.db.CompactionManager
 
instance - Static variable in class org.apache.cassandra.db.HintedHandOffManager
 
instance - Static variable in class org.apache.cassandra.db.marshal.AsciiType
 
instance - Static variable in class org.apache.cassandra.db.marshal.BytesType
 
instance - Static variable in class org.apache.cassandra.db.marshal.IntegerType
 
instance - Static variable in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
instance - Static variable in class org.apache.cassandra.db.marshal.LongType
 
instance - Static variable in class org.apache.cassandra.db.marshal.TimeUUIDType
 
instance - Static variable in class org.apache.cassandra.db.marshal.UTF8Type
 
instance - Static variable in class org.apache.cassandra.gms.FailureDetector
 
instance - Static variable in class org.apache.cassandra.gms.Gossiper
 
instance() - Static method in class org.apache.cassandra.net.MessagingService
 
instance - Static variable in class org.apache.cassandra.service.AntiEntropyService
 
instance - Static variable in class org.apache.cassandra.service.GCInspector
 
instance - Static variable in class org.apache.cassandra.service.StorageLoadBalancer
 
instance - Static variable in class org.apache.cassandra.service.StorageService
 
instance - Static variable in class org.apache.cassandra.streaming.StreamingService
 
InstrumentedCache<K,V> - Class in org.apache.cassandra.cache
 
InstrumentedCache(int) - Constructor for class org.apache.cassandra.cache.InstrumentedCache
 
InstrumentedCache(int, int) - Constructor for class org.apache.cassandra.cache.InstrumentedCache
 
IntegerType - Class in org.apache.cassandra.db.marshal
 
interpret(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
 
interpret(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
This method is invoked by any entity wanting to interrogate the status of an endpoint.
intersect(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
this = this AND other
intersectionCount(OpenBitSet, OpenBitSet) - Static method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the popcount or cardinality of the intersection of the two sets.
intersectionWith(Range) - Method in class org.apache.cassandra.dht.Range
 
intersects(Range) - Method in class org.apache.cassandra.dht.Range
 
intersects(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
returns true if the sets have any elements in common
intervalInMillis_ - Static variable in class org.apache.cassandra.gms.Gossiper
 
intSize_ - Static variable in class org.apache.cassandra.db.DBConstants
 
invalidate(Token) - Method in class org.apache.cassandra.utils.MerkleTree
Invalidates the ranges containing the given token.
invalidateCachedTokenEndpointValues() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
invalidateCaches() - Method in class org.apache.cassandra.locator.TokenMetadata
 
invalidateKeyCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
invalidateKeyCache() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
invalidate the key cache; for use after invalidating row cache
invalidateKeyCaches(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
invalidateKeyCaches(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
invalidateKeyCaches(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
invalidateRowCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
invalidateRowCache() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
invalidate the row cache; for use after bulk loading via BinaryMemtable
invalidateRowCaches(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
invalidateRowCaches(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
invalidateRowCaches(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
InvalidRequestException - Exception in org.apache.cassandra.thrift
Invalid request could mean keyspace or column family does not exist, required parameters are missing, or a parameter is malformed.
InvalidRequestException() - Constructor for exception org.apache.cassandra.thrift.InvalidRequestException
 
InvalidRequestException(String) - Constructor for exception org.apache.cassandra.thrift.InvalidRequestException
 
InvalidRequestException(InvalidRequestException) - Constructor for exception org.apache.cassandra.thrift.InvalidRequestException
Performs a deep copy on other.
InvalidRequestException._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
invalids(Range) - Method in class org.apache.cassandra.utils.MerkleTree
Returns a lazy iterator of invalid TreeRanges that need to be filled in order to make the given Range valid.
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
 
iprot_ - Variable in class org.apache.cassandra.thrift.Cassandra.Client
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.get_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.insert_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.remove_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
ire - Variable in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
IRequestScheduler - Interface in org.apache.cassandra.scheduler
Implementors of IRequestScheduler must provide a constructor taking a RequestSchedulerOptions object.
IResponseResolver<T> - Interface in org.apache.cassandra.service
 
isAlive() - Method in class org.apache.cassandra.gms.EndpointState
 
isAlive(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
 
isAlive(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
Failure Detector's knowledge of whether a node is up or down.
isAutoBootstrap() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isBootstrapMode() - Method in class org.apache.cassandra.service.StorageService
 
isBootstrapped() - Static method in class org.apache.cassandra.db.SystemTable
 
isCapacitySetManually() - Method in class org.apache.cassandra.cache.InstrumentedCache
 
isClean() - Method in class org.apache.cassandra.db.BinaryMemtable
 
isClean() - Method in class org.apache.cassandra.db.Memtable
 
isClientMode() - Method in class org.apache.cassandra.service.StorageService
 
isCompressed_ - Variable in class org.apache.cassandra.net.ProtocolHeader
 
isConnected() - Static method in class org.apache.cassandra.cli.CliMain
Checks whether the thrift client is connected.
isDataPresent() - Method in interface org.apache.cassandra.service.IResponseResolver
 
isDataPresent() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
isDataPresent() - Method in class org.apache.cassandra.service.ReadResponseResolver
 
isDigestQuery() - Method in class org.apache.cassandra.db.ReadCommand
 
isDigestQuery() - Method in class org.apache.cassandra.db.ReadResponse
 
isEmpty() - Method in class org.apache.cassandra.db.DecoratedKey
 
isEmpty() - Method in class org.apache.cassandra.db.RowMutation
 
isEmpty() - Method in class org.apache.cassandra.io.AbstractCompactedRow
 
isEmpty() - Method in class org.apache.cassandra.io.LazilyCompactedRow
 
isEmpty() - Method in class org.apache.cassandra.io.PrecompactedRow
 
isEmpty() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
isEmpty() - Method in class org.apache.cassandra.utils.ExpiringMap
 
isEmpty() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns true if there are no set bits
isEnabled() - Method in class org.apache.cassandra.gms.Gossiper
 
isEOF() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
isEOF() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
isEOF() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
isEqual(SSTableIdentityIterator, SSTableIdentityIterator) - Method in class org.apache.cassandra.io.CompactionIterator
 
isEqual(T1, T1) - Method in class org.apache.cassandra.utils.ReducingIterator
override this if the keys you want to base the reduce on are not the same as the object itself (but can be generated from it)
isExists(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
isExpired() - Method in class org.apache.cassandra.db.Memtable
 
isFromTheFuture() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
isHintedHandoffEnabled() - Static method in class org.apache.cassandra.service.StorageProxy
 
isIndex() - Method in class org.apache.cassandra.db.ColumnFamilyStore
true if this CFS contains secondary index data
isIndexBuilt() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Check if index is already built for current store
isIndexBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemTable
 
isInitialized() - Method in class org.apache.cassandra.service.StorageService
 
isInitialized() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isInitialized() - Method in class org.apache.cassandra.tools.NodeProbe
 
isInvalid() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isJoined() - Method in class org.apache.cassandra.service.StorageService
 
isJoined() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isKeyInRemainingSSTables(DecoratedKey, Set<SSTable>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Uses bloom filters to check if key may be present in any sstable in this ColumnFamilyStore, minus a set of provided ones.
isKnownEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
isLatestVersion - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
isLeaving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
isLegalName(String) - Static method in class org.apache.cassandra.db.migration.Migration
 
isLive() - Method in class org.apache.cassandra.db.Column
 
isLive() - Method in interface org.apache.cassandra.db.IColumn
For a simple column, live == !isMarkedForDelete.
isLive() - Method in class org.apache.cassandra.db.SuperColumn
 
isLowOnThreads() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon.CleaningThreadPool
 
isMarkedForDelete() - Method in class org.apache.cassandra.db.Column
 
isMarkedForDelete() - Method in class org.apache.cassandra.db.ColumnFamily
 
isMarkedForDelete() - Method in class org.apache.cassandra.db.DeletedColumn
 
isMarkedForDelete() - Method in class org.apache.cassandra.db.ExpiringColumn
 
isMarkedForDelete() - Method in interface org.apache.cassandra.db.IColumn
 
isMarkedForDelete() - Method in interface org.apache.cassandra.db.IColumnContainer
 
isMarkedForDelete() - Method in class org.apache.cassandra.db.SuperColumn
 
isMember(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
isModified() - Method in class org.apache.cassandra.utils.DefaultDouble
 
isModified() - Method in class org.apache.cassandra.utils.DefaultInteger
 
isPresent(ByteBuffer) - Method in class org.apache.cassandra.utils.BloomFilter
 
isPresent(ByteBuffer) - Method in class org.apache.cassandra.utils.Filter
 
isPresent(ByteBuffer) - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
isRelevant(IColumn, IColumnContainer, int) - Static method in class org.apache.cassandra.db.filter.QueryFilter
 
isReversed() - Method in class org.apache.cassandra.thrift.SliceRange
 
isRPCServerRunning() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Returns whether the underlying RPC server is running or not.
isRPCServerRunning() - Method in interface org.apache.cassandra.service.CassandraDaemon
 
isRPCServerRunning() - Method in class org.apache.cassandra.service.StorageService
 
isRPCServerRunning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isRunning - Variable in class org.apache.cassandra.service.AbstractCassandraDaemon
 
isSet(AuthenticationException._Fields) - Method in exception org.apache.cassandra.thrift.AuthenticationException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(AuthenticationRequest._Fields) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(AuthorizationException._Fields) - Method in exception org.apache.cassandra.thrift.AuthorizationException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.batch_mutate_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.batch_mutate_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_cluster_name_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_cluster_name_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_keyspaces_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_keyspaces_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_partitioner_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_partitioner_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_ring_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_ring_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_schema_versions_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_schema_versions_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_snitch_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_snitch_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_splits_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_splits_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_version_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.describe_version_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.get_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.get_count_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.get_count_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.get_indexed_slices_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.get_indexed_slices_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.get_range_slices_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.get_range_slices_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.get_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.get_slice_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.get_slice_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.insert_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.insert_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.login_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.login_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.multiget_count_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.multiget_count_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.multiget_slice_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.multiget_slice_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.remove_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.remove_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.set_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.set_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.system_add_column_family_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.system_add_column_family_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.system_add_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.system_add_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.system_drop_column_family_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.system_drop_column_family_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.system_drop_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.system_drop_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.system_update_column_family_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.system_update_column_family_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.system_update_keyspace_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.system_update_keyspace_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.truncate_args._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Cassandra.truncate_result._Fields) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(CfDef._Fields) - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Column._Fields) - Method in class org.apache.cassandra.thrift.Column
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ColumnDef._Fields) - Method in class org.apache.cassandra.thrift.ColumnDef
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ColumnOrSuperColumn._Fields) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ColumnParent._Fields) - Method in class org.apache.cassandra.thrift.ColumnParent
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(ColumnPath._Fields) - Method in class org.apache.cassandra.thrift.ColumnPath
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Deletion._Fields) - Method in class org.apache.cassandra.thrift.Deletion
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(IndexClause._Fields) - Method in class org.apache.cassandra.thrift.IndexClause
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(IndexExpression._Fields) - Method in class org.apache.cassandra.thrift.IndexExpression
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(InvalidRequestException._Fields) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(KeyCount._Fields) - Method in class org.apache.cassandra.thrift.KeyCount
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(KeyRange._Fields) - Method in class org.apache.cassandra.thrift.KeyRange
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(KeySlice._Fields) - Method in class org.apache.cassandra.thrift.KeySlice
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(KsDef._Fields) - Method in class org.apache.cassandra.thrift.KsDef
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(Mutation._Fields) - Method in class org.apache.cassandra.thrift.Mutation
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(NotFoundException._Fields) - Method in exception org.apache.cassandra.thrift.NotFoundException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(SlicePredicate._Fields) - Method in class org.apache.cassandra.thrift.SlicePredicate
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(SliceRange._Fields) - Method in class org.apache.cassandra.thrift.SliceRange
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(SuperColumn._Fields) - Method in class org.apache.cassandra.thrift.SuperColumn
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(TimedOutException._Fields) - Method in exception org.apache.cassandra.thrift.TimedOutException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(TokenRange._Fields) - Method in class org.apache.cassandra.thrift.TokenRange
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(UnavailableException._Fields) - Method in exception org.apache.cassandra.thrift.UnavailableException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSetAuth_request() - Method in class org.apache.cassandra.thrift.Cassandra.login_args
Returns true if field auth_request is set (has been asigned a value) and false otherwise
isSetAuthnx() - Method in class org.apache.cassandra.thrift.Cassandra.login_result
Returns true if field authnx is set (has been asigned a value) and false otherwise
isSetAuthzx() - Method in class org.apache.cassandra.thrift.Cassandra.login_result
Returns true if field authzx is set (has been asigned a value) and false otherwise
isSetCf_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
Returns true if field cf_def is set (has been asigned a value) and false otherwise
isSetCf_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
Returns true if field cf_def is set (has been asigned a value) and false otherwise
isSetCf_defs() - Method in class org.apache.cassandra.thrift.KsDef
Returns true if field cf_defs is set (has been asigned a value) and false otherwise
isSetCfName() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
Returns true if field cfName is set (has been asigned a value) and false otherwise
isSetCfname() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
Returns true if field cfname is set (has been asigned a value) and false otherwise
isSetColumn() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
Returns true if field column is set (has been asigned a value) and false otherwise
isSetColumn() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
Returns true if field column is set (has been asigned a value) and false otherwise
isSetColumn() - Method in class org.apache.cassandra.thrift.ColumnPath
Returns true if field column is set (has been asigned a value) and false otherwise
isSetColumn_family() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
Returns true if field column_family is set (has been asigned a value) and false otherwise
isSetColumn_family() - Method in class org.apache.cassandra.thrift.ColumnParent
Returns true if field column_family is set (has been asigned a value) and false otherwise
isSetColumn_family() - Method in class org.apache.cassandra.thrift.ColumnPath
Returns true if field column_family is set (has been asigned a value) and false otherwise
isSetColumn_metadata() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field column_metadata is set (has been asigned a value) and false otherwise
isSetColumn_name() - Method in class org.apache.cassandra.thrift.IndexExpression
Returns true if field column_name is set (has been asigned a value) and false otherwise
isSetColumn_names() - Method in class org.apache.cassandra.thrift.SlicePredicate
Returns true if field column_names is set (has been asigned a value) and false otherwise
isSetColumn_or_supercolumn() - Method in class org.apache.cassandra.thrift.Mutation
Returns true if field column_or_supercolumn is set (has been asigned a value) and false otherwise
isSetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
Returns true if field column_parent is set (has been asigned a value) and false otherwise
isSetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
Returns true if field column_parent is set (has been asigned a value) and false otherwise
isSetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
Returns true if field column_parent is set (has been asigned a value) and false otherwise
isSetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
Returns true if field column_parent is set (has been asigned a value) and false otherwise
isSetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
Returns true if field column_parent is set (has been asigned a value) and false otherwise
isSetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
Returns true if field column_parent is set (has been asigned a value) and false otherwise
isSetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
Returns true if field column_parent is set (has been asigned a value) and false otherwise
isSetColumn_path() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
Returns true if field column_path is set (has been asigned a value) and false otherwise
isSetColumn_path() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
Returns true if field column_path is set (has been asigned a value) and false otherwise
isSetColumn_predicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
Returns true if field column_predicate is set (has been asigned a value) and false otherwise
isSetColumn_type() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field column_type is set (has been asigned a value) and false otherwise
isSetColumns() - Method in class org.apache.cassandra.thrift.KeySlice
Returns true if field columns is set (has been asigned a value) and false otherwise
isSetColumns() - Method in class org.apache.cassandra.thrift.SuperColumn
Returns true if field columns is set (has been asigned a value) and false otherwise
isSetComment() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field comment is set (has been asigned a value) and false otherwise
isSetComparator_type() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field comparator_type is set (has been asigned a value) and false otherwise
isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
Returns true if field consistency_level is set (has been asigned a value) and false otherwise
isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
Returns true if field consistency_level is set (has been asigned a value) and false otherwise
isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
Returns true if field consistency_level is set (has been asigned a value) and false otherwise
isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
Returns true if field consistency_level is set (has been asigned a value) and false otherwise
isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
Returns true if field consistency_level is set (has been asigned a value) and false otherwise
isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
Returns true if field consistency_level is set (has been asigned a value) and false otherwise
isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
Returns true if field consistency_level is set (has been asigned a value) and false otherwise
isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
Returns true if field consistency_level is set (has been asigned a value) and false otherwise
isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
Returns true if field consistency_level is set (has been asigned a value) and false otherwise
isSetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
Returns true if field consistency_level is set (has been asigned a value) and false otherwise
isSetCount() - Method in class org.apache.cassandra.thrift.IndexClause
Returns true if field count is set (has been asigned a value) and false otherwise
isSetCount() - Method in class org.apache.cassandra.thrift.KeyCount
Returns true if field count is set (has been asigned a value) and false otherwise
isSetCount() - Method in class org.apache.cassandra.thrift.KeyRange
Returns true if field count is set (has been asigned a value) and false otherwise
isSetCount() - Method in class org.apache.cassandra.thrift.SliceRange
Returns true if field count is set (has been asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.cassandra.thrift.AuthenticationRequest
Returns true if field credentials is set (has been asigned a value) and false otherwise
isSetDefault_validation_class() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field default_validation_class is set (has been asigned a value) and false otherwise
isSetDeletion() - Method in class org.apache.cassandra.thrift.Mutation
Returns true if field deletion is set (has been asigned a value) and false otherwise
isSetEnd_key() - Method in class org.apache.cassandra.thrift.KeyRange
Returns true if field end_key is set (has been asigned a value) and false otherwise
isSetEnd_token() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
Returns true if field end_token is set (has been asigned a value) and false otherwise
isSetEnd_token() - Method in class org.apache.cassandra.thrift.KeyRange
Returns true if field end_token is set (has been asigned a value) and false otherwise
isSetEnd_token() - Method in class org.apache.cassandra.thrift.TokenRange
Returns true if field end_token is set (has been asigned a value) and false otherwise
isSetEndpoints() - Method in class org.apache.cassandra.thrift.TokenRange
Returns true if field endpoints is set (has been asigned a value) and false otherwise
isSetExpressions() - Method in class org.apache.cassandra.thrift.IndexClause
Returns true if field expressions is set (has been asigned a value) and false otherwise
isSetFinish() - Method in class org.apache.cassandra.thrift.SliceRange
Returns true if field finish is set (has been asigned a value) and false otherwise
isSetGc_grace_seconds() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field gc_grace_seconds is set (has been asigned a value) and false otherwise
isSetId() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field id is set (has been asigned a value) and false otherwise
isSetIndex_clause() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
Returns true if field index_clause is set (has been asigned a value) and false otherwise
isSetIndex_name() - Method in class org.apache.cassandra.thrift.ColumnDef
Returns true if field index_name is set (has been asigned a value) and false otherwise
isSetIndex_type() - Method in class org.apache.cassandra.thrift.ColumnDef
Returns true if field index_type is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetIre() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
Returns true if field ire is set (has been asigned a value) and false otherwise
isSetKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
Returns true if field key is set (has been asigned a value) and false otherwise
isSetKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
Returns true if field key is set (has been asigned a value) and false otherwise
isSetKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
Returns true if field key is set (has been asigned a value) and false otherwise
isSetKey() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
Returns true if field key is set (has been asigned a value) and false otherwise
isSetKey() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
Returns true if field key is set (has been asigned a value) and false otherwise
isSetKey() - Method in class org.apache.cassandra.thrift.KeyCount
Returns true if field key is set (has been asigned a value) and false otherwise
isSetKey() - Method in class org.apache.cassandra.thrift.KeySlice
Returns true if field key is set (has been asigned a value) and false otherwise
isSetKey_cache_save_period_in_seconds() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field key_cache_save_period_in_seconds is set (has been asigned a value) and false otherwise
isSetKey_cache_size() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field key_cache_size is set (has been asigned a value) and false otherwise
isSetKeys() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
Returns true if field keys is set (has been asigned a value) and false otherwise
isSetKeys() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
Returns true if field keys is set (has been asigned a value) and false otherwise
isSetKeys_per_split() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
Returns true if field keys_per_split is set (has been asigned a value) and false otherwise
isSetKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
Returns true if field keyspace is set (has been asigned a value) and false otherwise
isSetKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
Returns true if field keyspace is set (has been asigned a value) and false otherwise
isSetKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
Returns true if field keyspace is set (has been asigned a value) and false otherwise
isSetKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
Returns true if field keyspace is set (has been asigned a value) and false otherwise
isSetKeyspace() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field keyspace is set (has been asigned a value) and false otherwise
isSetKs_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
Returns true if field ks_def is set (has been asigned a value) and false otherwise
isSetKs_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
Returns true if field ks_def is set (has been asigned a value) and false otherwise
isSetMax_compaction_threshold() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field max_compaction_threshold is set (has been asigned a value) and false otherwise
isSetMemtable_flush_after_mins() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field memtable_flush_after_mins is set (has been asigned a value) and false otherwise
isSetMemtable_operations_in_millions() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field memtable_operations_in_millions is set (has been asigned a value) and false otherwise
isSetMemtable_throughput_in_mb() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field memtable_throughput_in_mb is set (has been asigned a value) and false otherwise
isSetMin_compaction_threshold() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field min_compaction_threshold is set (has been asigned a value) and false otherwise
isSetMutation_map() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
Returns true if field mutation_map is set (has been asigned a value) and false otherwise
isSetName() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field name is set (has been asigned a value) and false otherwise
isSetName() - Method in class org.apache.cassandra.thrift.Column
Returns true if field name is set (has been asigned a value) and false otherwise
isSetName() - Method in class org.apache.cassandra.thrift.ColumnDef
Returns true if field name is set (has been asigned a value) and false otherwise
isSetName() - Method in class org.apache.cassandra.thrift.KsDef
Returns true if field name is set (has been asigned a value) and false otherwise
isSetName() - Method in class org.apache.cassandra.thrift.SuperColumn
Returns true if field name is set (has been asigned a value) and false otherwise
isSetNfe() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
Returns true if field nfe is set (has been asigned a value) and false otherwise
isSetNfe() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
Returns true if field nfe is set (has been asigned a value) and false otherwise
isSetOp() - Method in class org.apache.cassandra.thrift.IndexExpression
Returns true if field op is set (has been asigned a value) and false otherwise
isSetPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
Returns true if field predicate is set (has been asigned a value) and false otherwise
isSetPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
Returns true if field predicate is set (has been asigned a value) and false otherwise
isSetPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
Returns true if field predicate is set (has been asigned a value) and false otherwise
isSetPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
Returns true if field predicate is set (has been asigned a value) and false otherwise
isSetPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
Returns true if field predicate is set (has been asigned a value) and false otherwise
isSetPredicate() - Method in class org.apache.cassandra.thrift.Deletion
Returns true if field predicate is set (has been asigned a value) and false otherwise
isSetRange() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
Returns true if field range is set (has been asigned a value) and false otherwise
isSetRead_repair_chance() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field read_repair_chance is set (has been asigned a value) and false otherwise
isSetReplication_factor() - Method in class org.apache.cassandra.thrift.KsDef
Returns true if field replication_factor is set (has been asigned a value) and false otherwise
isSetReversed() - Method in class org.apache.cassandra.thrift.SliceRange
Returns true if field reversed is set (has been asigned a value) and false otherwise
isSetRow_cache_save_period_in_seconds() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field row_cache_save_period_in_seconds is set (has been asigned a value) and false otherwise
isSetRow_cache_size() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field row_cache_size is set (has been asigned a value) and false otherwise
isSetSlice_range() - Method in class org.apache.cassandra.thrift.SlicePredicate
Returns true if field slice_range is set (has been asigned a value) and false otherwise
isSetStart() - Method in class org.apache.cassandra.thrift.SliceRange
Returns true if field start is set (has been asigned a value) and false otherwise
isSetStart_key() - Method in class org.apache.cassandra.thrift.IndexClause
Returns true if field start_key is set (has been asigned a value) and false otherwise
isSetStart_key() - Method in class org.apache.cassandra.thrift.KeyRange
Returns true if field start_key is set (has been asigned a value) and false otherwise
isSetStart_token() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
Returns true if field start_token is set (has been asigned a value) and false otherwise
isSetStart_token() - Method in class org.apache.cassandra.thrift.KeyRange
Returns true if field start_token is set (has been asigned a value) and false otherwise
isSetStart_token() - Method in class org.apache.cassandra.thrift.TokenRange
Returns true if field start_token is set (has been asigned a value) and false otherwise
isSetStrategy_class() - Method in class org.apache.cassandra.thrift.KsDef
Returns true if field strategy_class is set (has been asigned a value) and false otherwise
isSetStrategy_options() - Method in class org.apache.cassandra.thrift.KsDef
Returns true if field strategy_options is set (has been asigned a value) and false otherwise
isSetSubcomparator_type() - Method in class org.apache.cassandra.thrift.CfDef
Returns true if field subcomparator_type is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuper_column() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
Returns true if field super_column is set (has been asigned a value) and false otherwise
isSetSuper_column() - Method in class org.apache.cassandra.thrift.ColumnParent
Returns true if field super_column is set (has been asigned a value) and false otherwise
isSetSuper_column() - Method in class org.apache.cassandra.thrift.ColumnPath
Returns true if field super_column is set (has been asigned a value) and false otherwise
isSetSuper_column() - Method in class org.apache.cassandra.thrift.Deletion
Returns true if field super_column is set (has been asigned a value) and false otherwise
isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
Returns true if field te is set (has been asigned a value) and false otherwise
isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
Returns true if field te is set (has been asigned a value) and false otherwise
isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
Returns true if field te is set (has been asigned a value) and false otherwise
isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
Returns true if field te is set (has been asigned a value) and false otherwise
isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
Returns true if field te is set (has been asigned a value) and false otherwise
isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
Returns true if field te is set (has been asigned a value) and false otherwise
isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
Returns true if field te is set (has been asigned a value) and false otherwise
isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
Returns true if field te is set (has been asigned a value) and false otherwise
isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
Returns true if field te is set (has been asigned a value) and false otherwise
isSetTe() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
Returns true if field te is set (has been asigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
Returns true if field timestamp is set (has been asigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.cassandra.thrift.Column
Returns true if field timestamp is set (has been asigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.cassandra.thrift.Deletion
Returns true if field timestamp is set (has been asigned a value) and false otherwise
isSetTtl() - Method in class org.apache.cassandra.thrift.Column
Returns true if field ttl is set (has been asigned a value) and false otherwise
isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
Returns true if field ue is set (has been asigned a value) and false otherwise
isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
Returns true if field ue is set (has been asigned a value) and false otherwise
isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
Returns true if field ue is set (has been asigned a value) and false otherwise
isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
Returns true if field ue is set (has been asigned a value) and false otherwise
isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
Returns true if field ue is set (has been asigned a value) and false otherwise
isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
Returns true if field ue is set (has been asigned a value) and false otherwise
isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
Returns true if field ue is set (has been asigned a value) and false otherwise
isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
Returns true if field ue is set (has been asigned a value) and false otherwise
isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
Returns true if field ue is set (has been asigned a value) and false otherwise
isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
Returns true if field ue is set (has been asigned a value) and false otherwise
isSetUe() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
Returns true if field ue is set (has been asigned a value) and false otherwise
isSetValidation_class() - Method in class org.apache.cassandra.thrift.ColumnDef
Returns true if field validation_class is set (has been asigned a value) and false otherwise
isSetValue() - Method in class org.apache.cassandra.thrift.Column
Returns true if field value is set (has been asigned a value) and false otherwise
isSetValue() - Method in class org.apache.cassandra.thrift.IndexExpression
Returns true if field value is set (has been asigned a value) and false otherwise
isSetWhy() - Method in exception org.apache.cassandra.thrift.AuthenticationException
Returns true if field why is set (has been asigned a value) and false otherwise
isSetWhy() - Method in exception org.apache.cassandra.thrift.AuthorizationException
Returns true if field why is set (has been asigned a value) and false otherwise
isSetWhy() - Method in exception org.apache.cassandra.thrift.InvalidRequestException
Returns true if field why is set (has been asigned a value) and false otherwise
isShutdown() - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Returns true if this executor has been shut down.
isShutdown() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
isSignaled() - Method in class org.apache.cassandra.utils.SimpleCondition
 
isSnapshotBeforeCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isStreamingMode_ - Variable in class org.apache.cassandra.net.ProtocolHeader
 
isSuccess() - Method in class org.apache.cassandra.db.WriteResponse
 
isSuper() - Method in class org.apache.cassandra.db.ColumnFamily
 
isTerminated() - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Returns true if all tasks have completed following shut down.
isTerminated() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
isThriftFramed() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isTokenInRanges(Token, Iterable<Range>) - Static method in class org.apache.cassandra.dht.Range
 
isWrapAround(Token, Token) - Static method in class org.apache.cassandra.dht.Range
Tells if the given range is a wrap around.
isWrapAround() - Method in class org.apache.cassandra.dht.Range
 
iterator() - Method in class org.apache.cassandra.db.ColumnFamily
 
iterator() - Method in class org.apache.cassandra.io.LazilyCompactedRow
 
iterator() - Method in class org.apache.cassandra.io.sstable.SSTableTracker
 
iterator(long, int) - Method in class org.apache.cassandra.io.util.SegmentedFile
 
iterator() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
iterator() - Method in class org.apache.cassandra.utils.BoundedStatsDeque
 
iterator() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRangeIterator
 
iterator() - Method in class org.apache.cassandra.utils.ReducingIterator
 
IVerbHandler - Interface in org.apache.cassandra.net
IVerbHandler provides the method that all verb handlers need to implement.
IWriteResponseHandler - Interface in org.apache.cassandra.service
 

J

JMXConfigurableThreadPoolExecutor - Class in org.apache.cassandra.concurrent
 
JMXConfigurableThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, NamedThreadFactory, String) - Constructor for class org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutor
 
JMXConfigurableThreadPoolExecutorMBean - Interface in org.apache.cassandra.concurrent
 
JMXEnabledThreadPoolExecutor - Class in org.apache.cassandra.concurrent
This is a wrapper class for the ScheduledThreadPoolExecutor.
JMXEnabledThreadPoolExecutor(String) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(String, String) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(String, int) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, NamedThreadFactory, String) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(Stage) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutorMBean - Interface in org.apache.cassandra.concurrent
 
JMXInstrumentedCache<K,V> - Class in org.apache.cassandra.cache
 
JMXInstrumentedCache(String, String, int) - Constructor for class org.apache.cassandra.cache.JMXInstrumentedCache
 
JMXInstrumentedCacheMBean - Interface in org.apache.cassandra.cache
 
jmxPort - Variable in class org.apache.cassandra.cli.CliSessionState
 
job_jar_file_location - Variable in class org.apache.cassandra.config.Config
 
job_tracker_host - Variable in class org.apache.cassandra.config.Config
 
join() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon.CleaningThreadPool
 
joinRing() - Method in class org.apache.cassandra.service.StorageService
 
joinRing() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 

K

KEEPALIVE - Static variable in class org.apache.cassandra.concurrent.StageManager
 
key - Variable in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
key - Variable in class org.apache.cassandra.db.DecoratedKey
 
key - Variable in class org.apache.cassandra.db.filter.QueryFilter
 
key - Variable in class org.apache.cassandra.db.ReadCommand
 
key - Variable in class org.apache.cassandra.db.Row
 
key() - Method in class org.apache.cassandra.db.RowMutation
 
key() - Method in class org.apache.cassandra.db.WriteResponse
 
key - Variable in class org.apache.cassandra.io.AbstractCompactedRow
 
key - Variable in class org.apache.cassandra.io.sstable.IndexSummary.KeyPosition
 
key - Variable in class org.apache.cassandra.thrift.Cassandra.get_args
 
key - Variable in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
key - Variable in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
key - Variable in class org.apache.cassandra.thrift.Cassandra.insert_args
 
key - Variable in class org.apache.cassandra.thrift.Cassandra.remove_args
 
key - Variable in class org.apache.cassandra.thrift.KeyCount
 
key - Variable in class org.apache.cassandra.thrift.KeySlice
 
key_cache_save_period_in_seconds - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
key_cache_save_period_in_seconds - Variable in class org.apache.cassandra.thrift.CfDef
 
key_cache_size - Variable in class org.apache.cassandra.thrift.CfDef
 
KeyCount - Class in org.apache.cassandra.thrift
 
KeyCount() - Constructor for class org.apache.cassandra.thrift.KeyCount
 
KeyCount(ByteBuffer, int) - Constructor for class org.apache.cassandra.thrift.KeyCount
 
KeyCount(KeyCount) - Constructor for class org.apache.cassandra.thrift.KeyCount
Performs a deep copy on other.
KeyCount._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyIterator - Class in org.apache.cassandra.io.sstable
 
KeyIterator(Descriptor) - Constructor for class org.apache.cassandra.io.sstable.KeyIterator
 
KeyRange - Class in org.apache.cassandra.thrift
The semantics of start keys and tokens are slightly different.
KeyRange() - Constructor for class org.apache.cassandra.thrift.KeyRange
 
KeyRange(int) - Constructor for class org.apache.cassandra.thrift.KeyRange
 
KeyRange(KeyRange) - Constructor for class org.apache.cassandra.thrift.KeyRange
Performs a deep copy on other.
KeyRange._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
keys - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
keys - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
keys_cached - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
keys_per_split - Variable in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
keySet() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
keySet() - Method in class org.apache.cassandra.utils.ExpiringMap
 
KeySlice - Class in org.apache.cassandra.thrift
A KeySlice is key followed by the data it maps to.
KeySlice() - Constructor for class org.apache.cassandra.thrift.KeySlice
 
KeySlice(ByteBuffer, List<ColumnOrSuperColumn>) - Constructor for class org.apache.cassandra.thrift.KeySlice
 
KeySlice(KeySlice) - Constructor for class org.apache.cassandra.thrift.KeySlice
Performs a deep copy on other.
KeySlice._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
keyspace - Variable in class org.apache.cassandra.cli.CliSessionState
 
keyspace - Variable in class org.apache.cassandra.db.IndexScanCommand
 
keyspace - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
keyspace - Variable in class org.apache.cassandra.db.TruncateResponse
 
keyspace - Variable in class org.apache.cassandra.db.Truncation
 
keyspace - Variable in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
keyspace - Variable in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
keyspace - Variable in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
keyspace - Variable in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
keyspace - Variable in class org.apache.cassandra.thrift.CfDef
 
KeyspaceNotDefinedException - Exception in org.apache.cassandra.avro
 
KeyspaceNotDefinedException(Utf8) - Constructor for exception org.apache.cassandra.avro.KeyspaceNotDefinedException
 
KeyspaceNotDefinedException - Exception in org.apache.cassandra.db
 
KeyspaceNotDefinedException(String) - Constructor for exception org.apache.cassandra.db.KeyspaceNotDefinedException
 
KEYSPACES - Static variable in class org.apache.cassandra.auth.Resources
 
keyspaces - Variable in class org.apache.cassandra.config.Config
 
keyspaces - Variable in class org.apache.cassandra.service.StorageService.Keyspaces
 
KEYSPACES_WRITE_PROPERTY - Static variable in class org.apache.cassandra.auth.SimpleAuthority
 
ks_def - Variable in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
ks_def - Variable in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
KsDef - Class in org.apache.cassandra.thrift
 
KsDef() - Constructor for class org.apache.cassandra.thrift.KsDef
 
KsDef(String, String, int, List<CfDef>) - Constructor for class org.apache.cassandra.thrift.KsDef
 
KsDef(KsDef) - Constructor for class org.apache.cassandra.thrift.KsDef
Performs a deep copy on other.
KsDef._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KSMetaData - Class in org.apache.cassandra.config
 
KSMetaData(String, Class<? extends AbstractReplicationStrategy>, Map<String, String>, int, CFMetaData...) - Constructor for class org.apache.cassandra.config.KSMetaData
 
ksname - Variable in class org.apache.cassandra.io.sstable.Descriptor
 

L

LA(int) - Method in class org.apache.cassandra.cli.CliCompiler.ANTLRNoCaseStringStream
 
last - Variable in class org.apache.cassandra.utils.ReducingIterator
 
LAST_MIGRATION_KEY - Static variable in class org.apache.cassandra.db.migration.Migration
 
lastIndexOf(ByteBuffer, byte, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
ByteBuffer adaptation of org.apache.commons.lang.ArrayUtils.lastIndexOf method
lastKey() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
lastName - Variable in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
lastVersion - Variable in class org.apache.cassandra.db.migration.Migration
 
LatencyTracker - Class in org.apache.cassandra.utils
 
LatencyTracker() - Constructor for class org.apache.cassandra.utils.LatencyTracker
 
LazilyCompactedRow - Class in org.apache.cassandra.io
LazilyCompactedRow only computes the row bloom filter and column index in memory (at construction time); it does this by reading one column at a time from each of the rows being compacted, and merging them as it does so.
LazilyCompactedRow(ColumnFamilyStore, List<SSTableIdentityIterator>, boolean, int) - Constructor for class org.apache.cassandra.io.LazilyCompactedRow
 
leaving(Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
left - Variable in class org.apache.cassandra.dht.AbstractBounds
 
left(Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
left - Variable in class org.apache.cassandra.utils.Pair
 
LEGACY_VERSION - Static variable in class org.apache.cassandra.io.sstable.Descriptor
 
LegacyBloomFilter - Class in org.apache.cassandra.utils
 
length() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
length() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
length() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
length - Variable in class org.apache.cassandra.io.util.SegmentedFile
 
length() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
LexicalUUIDType - Class in org.apache.cassandra.db.marshal
 
listen(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
Listen on the specified port.
listen_address - Variable in class org.apache.cassandra.config.Config
 
listenAddr - Variable in class org.apache.cassandra.service.AbstractCassandraDaemon
 
listEndpointsPendingHints() - Method in class org.apache.cassandra.db.HintedHandOffManager
 
listEndpointsPendingHints() - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
List all the endpoints that this node has hints for.
listenPort - Variable in class org.apache.cassandra.service.AbstractCassandraDaemon
 
load(double) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
loadBalance() - Method in class org.apache.cassandra.service.StorageService
 
loadBalance() - Method in interface org.apache.cassandra.service.StorageServiceMBean
This node will unload its data onto its neighbors, and bootstrap to share the range of the most-loaded node in the ring.
loadBalance() - Method in class org.apache.cassandra.tools.NodeProbe
 
loadFromStorage(UUID) - Static method in class org.apache.cassandra.db.DefsTable
loads a version of keyspace definitions from storage
loadSchemaFromYAML() - Method in class org.apache.cassandra.service.StorageService
load schema from yaml.
loadSchemaFromYAML() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Introduced in 0.7 to allow nodes to load their existing yaml defined schemas.
loadSchemaFromYAML() - Method in class org.apache.cassandra.tools.NodeProbe
Deprecated. 
loadSchemas() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
load keyspace (table) definitions, but do not initialize the table instances.
loadTokens() - Static method in class org.apache.cassandra.db.SystemTable
Return a map of stored tokens to IP addresses
LocalByPartionerType<T extends Token> - Class in org.apache.cassandra.db.marshal
for sorting columns representing row keys in the row ordering as determined by a partitioner.
LocalByPartionerType(IPartitioner<T>) - Constructor for class org.apache.cassandra.db.marshal.LocalByPartionerType
 
LocalPartitioner - Class in org.apache.cassandra.dht
 
LocalPartitioner(AbstractType) - Constructor for class org.apache.cassandra.dht.LocalPartitioner
 
LocalStrategy - Class in org.apache.cassandra.locator
 
LocalStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.LocalStrategy
 
LocalToken - Class in org.apache.cassandra.dht
 
LocalToken(AbstractType, ByteBuffer) - Constructor for class org.apache.cassandra.dht.LocalToken
 
log() - Static method in class org.apache.cassandra.utils.StatusLogger
 
logger - Static variable in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
logger - Static variable in class org.apache.cassandra.db.migration.Migration
 
logger - Static variable in class org.apache.cassandra.gms.EndpointState
 
logger - Static variable in class org.apache.cassandra.locator.Ec2Snitch
 
logger - Static variable in class org.apache.cassandra.service.ReadCallback
 
logger - Static variable in class org.apache.cassandra.service.TruncateResponseHandler
 
logger - Static variable in class org.apache.cassandra.service.WriteResponseHandler
 
login(AuthenticationRequest) - Method in class org.apache.cassandra.avro.CassandraServer
 
login(Map<? extends CharSequence, ? extends CharSequence>) - Method in class org.apache.cassandra.service.ClientState
Attempts to login this client with the given credentials map.
login(AuthenticationRequest, AsyncMethodCallback<Cassandra.AsyncClient.login_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
login(AuthenticationRequest, AsyncMethodCallback<Cassandra.AsyncClient.login_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
login(AuthenticationRequest) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
login(AuthenticationRequest) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
 
login(AuthenticationRequest) - Method in class org.apache.cassandra.thrift.CassandraServer
 
logout() - Method in class org.apache.cassandra.service.ClientState
 
longSize_ - Static variable in class org.apache.cassandra.db.DBConstants
 
LongType - Class in org.apache.cassandra.db.marshal
 
ltree - Variable in class org.apache.cassandra.service.AntiEntropyService.Differencer
 

M

main(String[]) - Static method in class org.apache.cassandra.avro.CassandraDaemon
 
main(String[]) - Static method in class org.apache.cassandra.cli.CliMain
 
main(String[]) - Static method in class org.apache.cassandra.config.Converter
Deprecated.  
main(String[]) - Static method in class org.apache.cassandra.gms.FailureDetector
 
main(String[]) - Static method in class org.apache.cassandra.thrift.CassandraDaemon
 
main(String[]) - Static method in class org.apache.cassandra.tools.ClusterCmd
 
main(String[]) - Static method in class org.apache.cassandra.tools.NodeCmd
 
main(String[]) - Static method in class org.apache.cassandra.tools.SchemaTool
 
main(String[]) - Static method in class org.apache.cassandra.tools.SSTableExport
Given arguments specifying an SSTable, and optionally an output file, export the contents of the SSTable to JSON.
main(String[]) - Static method in class org.apache.cassandra.tools.SSTableImport
Converts JSON to an SSTable file.
makeColumns(Message) - Static method in class org.apache.cassandra.service.MigrationManager
 
makeCombinedName(String, String) - Static method in class org.apache.cassandra.db.HintedHandOffManager
 
makeReadMessage() - Method in class org.apache.cassandra.db.ReadCommand
 
makeRowMutationMessage() - Method in class org.apache.cassandra.db.RowMutation
 
makeRowMutationMessage(StorageService.Verb) - Method in class org.apache.cassandra.db.RowMutation
 
makeTruncateResponseMessage(Message, TruncateResponse) - Static method in class org.apache.cassandra.db.TruncateResponse
 
makeTruncationMessage() - Method in class org.apache.cassandra.db.Truncation
 
makeType1UUIDFromHost(InetAddress) - Static method in class org.apache.cassandra.utils.UUIDGen
creates a type1 uuid but substitutes hash of the IP where the mac would go.
makeWriteResponseMessage(Message, WriteResponse) - Static method in class org.apache.cassandra.db.WriteResponse
 
map(CFMetaData) - Static method in class org.apache.cassandra.config.CFMetaData
adds this cfm to the map.
MappedFileDataInput - Class in org.apache.cassandra.io.util
 
MappedFileDataInput(FileInputStream, String, int) - Constructor for class org.apache.cassandra.io.util.MappedFileDataInput
 
MappedFileDataInput(MappedByteBuffer, String, int) - Constructor for class org.apache.cassandra.io.util.MappedFileDataInput
 
mark() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
mark() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
mark() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
mark() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
markCompacted() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
markCompacted(Collection<SSTableReader>) - Method in class org.apache.cassandra.io.sstable.SSTableTracker
 
markForDeleteAt(int, long) - Method in class org.apache.cassandra.db.SuperColumn
Deprecated. 
markSupported() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
MarshalException - Exception in org.apache.cassandra.db.marshal
 
MarshalException(String) - Constructor for exception org.apache.cassandra.db.marshal.MarshalException
 
MarshalException(String, Throwable) - Constructor for exception org.apache.cassandra.db.marshal.MarshalException
 
max() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
max_compaction_threshold - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
max_compaction_threshold - Variable in class org.apache.cassandra.thrift.CfDef
 
MAX_CONNECT_ATTEMPTS - Static variable in class org.apache.cassandra.streaming.FileStreamTask
 
max_hint_window_in_ms - Variable in class org.apache.cassandra.config.Config
 
max_keys - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
MAX_NAME_LENGTH - Static variable in interface org.apache.cassandra.db.IColumn
 
MAX_RETRIES - Static variable in class org.apache.cassandra.io.DeletionService
 
MAX_SEGMENT_SIZE - Static variable in class org.apache.cassandra.io.util.MmappedSegmentedFile
 
MAX_UNSIGNED_SHORT - Static variable in class org.apache.cassandra.utils.FBUtilities
 
maxDataAge - Variable in class org.apache.cassandra.io.sstable.SSTableReader
maxDataAge is a timestamp in local server time (e.g.
maxsize() - Method in class org.apache.cassandra.utils.MerkleTree
 
maxsize(long) - Method in class org.apache.cassandra.utils.MerkleTree
 
maxWorkerThreads - Variable in class org.apache.cassandra.thrift.CustomTThreadPoolServer.Options
 
maybeAddEntry(DecoratedKey, long) - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
maybeAddLatency(IMessageCallback, InetAddress, double) - Method in class org.apache.cassandra.net.MessagingService
Track latency information for the dynamic snitch
maybeLoad() - Static method in class org.apache.cassandra.utils.Mx4jTool
Starts a JMX over http interface if and mx4j-tools.jar is in the classpath.
maybeScheduleRepairs(ColumnFamily, String, DecoratedKey, List<ColumnFamily>, List<InetAddress>) - Static method in class org.apache.cassandra.service.ReadResponseResolver
For each row version, compare with resolved (the superset of all row versions); if it is missing anything, send a mutation to the endpoint it come from.
MBEAN_OBJECT_NAME - Static variable in class org.apache.cassandra.db.CompactionManager
 
MBEAN_OBJECT_NAME - Static variable in class org.apache.cassandra.streaming.StreamingService
 
mean() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
median() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
Memtable - Class in org.apache.cassandra.db
 
Memtable(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.Memtable
 
memtable_flush_after_mins - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
memtable_flush_after_mins - Variable in class org.apache.cassandra.thrift.CfDef
 
memtable_flush_writers - Variable in class org.apache.cassandra.config.Config
 
memtable_operations_in_millions - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
memtable_operations_in_millions - Variable in class org.apache.cassandra.thrift.CfDef
 
memtable_throughput_in_mb - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
memtable_throughput_in_mb - Variable in class org.apache.cassandra.thrift.CfDef
 
MerkleTree - Class in org.apache.cassandra.utils
A MerkleTree implemented as a binary tree.
MerkleTree(IPartitioner, byte, long) - Constructor for class org.apache.cassandra.utils.MerkleTree
 
MerkleTree.RowHash - Class in org.apache.cassandra.utils
Hash value representing a row, to be used to pass hashes to the MerkleTree.
MerkleTree.RowHash(Token, byte[]) - Constructor for class org.apache.cassandra.utils.MerkleTree.RowHash
 
MerkleTree.TreeRange - Class in org.apache.cassandra.utils
The public interface to a range in the tree.
MerkleTree.TreeRangeIterator - Class in org.apache.cassandra.utils
Performs a depth-first, inorder traversal of invalid nodes under the given root and intersecting the given range.
Message - Class in org.apache.cassandra.net
 
Message(InetAddress, StorageService.Verb, byte[]) - Constructor for class org.apache.cassandra.net.Message
 
MessageDeliveryTask - Class in org.apache.cassandra.net
 
MessageDeliveryTask(Message, String) - Constructor for class org.apache.cassandra.net.MessageDeliveryTask
 
MessagingService - Class in org.apache.cassandra.net
 
MessagingServiceMBean - Interface in org.apache.cassandra.net
MBean exposing MessagingService metrics.
metadata() - Method in class org.apache.cassandra.db.ColumnFamily
 
metadata - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
metadata - Variable in class org.apache.cassandra.io.sstable.SSTable
 
metaDataMap - Static variable in exception org.apache.cassandra.thrift.AuthenticationException
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.AuthenticationRequest
 
metaDataMap - Static variable in exception org.apache.cassandra.thrift.AuthorizationException
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_version_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.get_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.get_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.insert_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.insert_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.login_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.login_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.remove_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.remove_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.CfDef
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Column
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.ColumnDef
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.ColumnParent
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.ColumnPath
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Deletion
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.IndexClause
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.IndexExpression
 
metaDataMap - Static variable in exception org.apache.cassandra.thrift.InvalidRequestException
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.KeyCount
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.KeyRange
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.KeySlice
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.KsDef
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.Mutation
 
metaDataMap - Static variable in exception org.apache.cassandra.thrift.NotFoundException
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.SlicePredicate
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.SliceRange
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.SuperColumn
 
metaDataMap - Static variable in exception org.apache.cassandra.thrift.TimedOutException
 
metaDataMap - Static variable in class org.apache.cassandra.thrift.TokenRange
 
metaDataMap - Static variable in exception org.apache.cassandra.thrift.UnavailableException
 
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
midpoint(Token, Token) - Method in interface org.apache.cassandra.dht.IPartitioner
Calculate a Token representing the approximate "middle" of the given range.
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
midpoint(BigInteger, BigInteger, int) - Static method in class org.apache.cassandra.utils.FBUtilities
Given two bit arrays represented as BigIntegers, containing the given number of significant bits, calculate a midpoint.
Migration - Class in org.apache.cassandra.db.migration
A migration represents a single metadata mutation (cf dropped, added, etc.).
Migration() - Constructor for class org.apache.cassandra.db.migration.Migration
Subclasses must have a matching constructor
migration(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
MigrationManager - Class in org.apache.cassandra.service
 
MigrationManager() - Constructor for class org.apache.cassandra.service.MigrationManager
 
MIGRATIONS_CF - Static variable in class org.apache.cassandra.db.migration.Migration
 
MIGRATIONS_KEY - Static variable in class org.apache.cassandra.db.migration.Migration
 
MigrationsCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
min() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
min_compaction_threshold - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
min_compaction_threshold - Variable in class org.apache.cassandra.thrift.CfDef
 
MIN_WORKER_THREADS - Static variable in class org.apache.cassandra.service.AbstractCassandraDaemon
 
MINIMUM - Static variable in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
MINIMUM - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
MINIMUM - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 
minWorkerThreads - Variable in class org.apache.cassandra.thrift.CustomTThreadPoolServer.Options
 
MmappedSegmentedFile - Class in org.apache.cassandra.io.util
 
MmappedSegmentedFile(String, long, SegmentedFile.Segment[]) - Constructor for class org.apache.cassandra.io.util.MmappedSegmentedFile
 
modifications_ - Variable in class org.apache.cassandra.db.RowMutation
 
mostRecentLiveChangeAt() - Method in class org.apache.cassandra.db.Column
 
mostRecentLiveChangeAt() - Method in interface org.apache.cassandra.db.IColumn
 
mostRecentLiveChangeAt() - Method in class org.apache.cassandra.db.SuperColumn
 
move(String) - Method in class org.apache.cassandra.service.StorageService
 
move(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
move(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
multiget_count(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.avro.CassandraServer
 
multiget_count(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.multiget_count_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
multiget_count(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.multiget_count_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
multiget_count(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
multiget_count(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
Perform a get_count in parallel on the given list keys.
multiget_count(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
multiget_slice(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.avro.CassandraServer
 
multiget_slice(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.multiget_slice_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
multiget_slice(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.multiget_slice_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
multiget_slice(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
multiget_slice(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
Performs a get_slice for column_parent and predicate for the given keys in parallel.
multiget_slice(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
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
 
mutate(List<RowMutation>, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
Use this method to have these RowMutations applied across all replicas.
Mutation - Class in org.apache.cassandra.thrift
A Mutation is either an insert, represented by filling column_or_supercolumn, or a deletion, represented by filling the deletion attribute.
Mutation() - Constructor for class org.apache.cassandra.thrift.Mutation
 
Mutation(Mutation) - Constructor for class org.apache.cassandra.thrift.Mutation
Performs a deep copy on other.
Mutation._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
mutation_map - Variable in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
Mx4jTool - Class in org.apache.cassandra.utils
If mx4j-tools is in the classpath call maybeLoad to load the HTTP interface of mx4j.
Mx4jTool() - Constructor for class org.apache.cassandra.utils.Mx4jTool
 

N

n - Variable in class org.apache.cassandra.concurrent.NamedThreadFactory
 
name - Variable in class org.apache.cassandra.config.ColumnDefinition
 
name - Variable in class org.apache.cassandra.config.KSMetaData
 
name - Variable in class org.apache.cassandra.config.RawColumnDefinition
 
name - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
name - Variable in class org.apache.cassandra.config.RawKeyspace
Deprecated.  
name - Variable in class org.apache.cassandra.db.Column
 
name() - Method in class org.apache.cassandra.db.Column
 
name() - Method in interface org.apache.cassandra.db.IColumn
 
name() - Method in class org.apache.cassandra.db.SuperColumn
 
name - Variable in class org.apache.cassandra.db.Table
 
name() - Method in class org.apache.cassandra.io.sstable.Component
 
name - Variable in class org.apache.cassandra.thrift.CfDef
 
name - Variable in class org.apache.cassandra.thrift.Column
 
name - Variable in class org.apache.cassandra.thrift.ColumnDef
 
name - Variable in class org.apache.cassandra.thrift.KsDef
 
name - Variable in class org.apache.cassandra.thrift.SuperColumn
 
NAME_VALIDATOR_REGEX - Static variable in class org.apache.cassandra.db.migration.Migration
 
NamedThreadFactory - Class in org.apache.cassandra.concurrent
This class is an implementation of the ThreadFactory interface.
NamedThreadFactory(String) - Constructor for class org.apache.cassandra.concurrent.NamedThreadFactory
 
NamedThreadFactory(String, int) - Constructor for class org.apache.cassandra.concurrent.NamedThreadFactory
 
NamesQueryFilter - Class in org.apache.cassandra.db.filter
 
NamesQueryFilter(SortedSet<ByteBuffer>) - Constructor for class org.apache.cassandra.db.filter.NamesQueryFilter
 
NamesQueryFilter(ByteBuffer) - Constructor for class org.apache.cassandra.db.filter.NamesQueryFilter
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
NetworkTopologyStrategy - Class in org.apache.cassandra.locator
This Replication Strategy takes a property file that gives the intended replication factor in each datacenter.
NetworkTopologyStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.NetworkTopologyStrategy
 
newColumn(ByteBuffer, ByteBuffer, long) - Static method in class org.apache.cassandra.avro.AvroRecordFactory
 
newColumn(byte[], byte[], long) - Static method in class org.apache.cassandra.avro.AvroRecordFactory
 
newColumnOrSuperColumn(Column) - Static method in class org.apache.cassandra.avro.AvroRecordFactory
 
newColumnOrSuperColumn(SuperColumn) - Static method in class org.apache.cassandra.avro.AvroRecordFactory
 
newColumnParent(String, byte[]) - Static method in class org.apache.cassandra.avro.AvroRecordFactory
 
newColumnPath(String, ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.avro.AvroRecordFactory
 
newColumnPath(String, byte[], byte[]) - Static method in class org.apache.cassandra.avro.AvroRecordFactory
 
newCoscsMapEntry(ByteBuffer, GenericArray<ColumnOrSuperColumn>) - Static method in class org.apache.cassandra.avro.AvroRecordFactory
 
newIndexedColumnFamily(ByteBuffer) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
newIndexMetadata(String, String, ColumnDefinition, AbstractType) - Static method in class org.apache.cassandra.config.CFMetaData
 
newKeySlice(ByteBuffer, List<ColumnOrSuperColumn>) - Static method in class org.apache.cassandra.avro.AvroRecordFactory
 
newPartitioner(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newSince(long) - Method in class org.apache.cassandra.io.sstable.SSTableReader
Tests if the sstable contains data newer than the given age param (in localhost currentMilli time).
newSuperColumn(ByteBuffer, List<Column>) - Static method in class org.apache.cassandra.avro.AvroRecordFactory
 
newSuperColumn(byte[], List<Column>) - Static method in class org.apache.cassandra.avro.AvroRecordFactory
 
newThread(Runnable) - Method in class org.apache.cassandra.concurrent.NamedThreadFactory
 
newVersion - Variable in class org.apache.cassandra.db.migration.Migration
 
next() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
next() - Method in class org.apache.cassandra.db.RowIterator
 
next() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
next() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
next() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
next() - Method in class org.apache.cassandra.utils.DestructivePQIterator
 
nextKeyValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
nextSetBit(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the index of the first set bit starting at the index specified.
nextSetBit(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the index of the first set bit starting at the index specified.
nfe - Variable in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
nfe - Variable in class org.apache.cassandra.thrift.Cassandra.get_result
 
NodeCmd - Class in org.apache.cassandra.tools
 
NodeCmd(NodeProbe) - Constructor for class org.apache.cassandra.tools.NodeCmd
 
NodeCmd.NodeCommand - Enum in org.apache.cassandra.tools
 
NodeProbe - Class in org.apache.cassandra.tools
JMX client operations for Cassandra.
NodeProbe(String, int, String, String) - Constructor for class org.apache.cassandra.tools.NodeProbe
Creates a NodeProbe using the specified JMX host, port, username, and password.
NodeProbe(String, int) - Constructor for class org.apache.cassandra.tools.NodeProbe
Creates a NodeProbe using the specified JMX host and port.
NodeProbe(String) - Constructor for class org.apache.cassandra.tools.NodeProbe
Creates a NodeProbe using the specified JMX host and default port.
NONE - Static variable in enum org.apache.cassandra.auth.Permission
 
normal(Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
normalize(Collection<? extends AbstractBounds>) - Static method in class org.apache.cassandra.dht.AbstractBounds
 
NoScheduler - Class in org.apache.cassandra.scheduler
This is basically not having a scheduler, the requests are processed as normally would be handled by the JVM.
NoScheduler(RequestSchedulerOptions) - Constructor for class org.apache.cassandra.scheduler.NoScheduler
 
NoScheduler() - Constructor for class org.apache.cassandra.scheduler.NoScheduler
 
NotFoundException - Exception in org.apache.cassandra.thrift
A specific column was requested that does not exist.
NotFoundException() - Constructor for exception org.apache.cassandra.thrift.NotFoundException
 
NotFoundException(NotFoundException) - Constructor for exception org.apache.cassandra.thrift.NotFoundException
Performs a deep copy on other.
NotFoundException._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
numColumnSpecifiers(Tree) - Static method in class org.apache.cassandra.cli.CliCompiler
 

O

offset - Variable in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
OldNetworkTopologyStrategy - Class in org.apache.cassandra.locator
This Replication Strategy returns the nodes responsible for a given key but respects rack awareness.
OldNetworkTopologyStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.OldNetworkTopologyStrategy
 
onAlive(InetAddress, EndpointState) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.MigrationManager
gets called after a this node joins a cluster
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageLoadBalancer
 
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.MigrationManager
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.StorageLoadBalancer
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.StorageService
 
onDead(InetAddress, EndpointState) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.MigrationManager
 
onDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageLoadBalancer
 
onDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onJoin(InetAddress, EndpointState) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
Use to inform interested parties about the change in the state for specified endpoint
onJoin(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.MigrationManager
I'm not going to act here.
onJoin(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageLoadBalancer
 
onJoin(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onRemove(InetAddress) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onRemove(InetAddress) - Method in class org.apache.cassandra.service.MigrationManager
 
onRemove(InetAddress) - Method in class org.apache.cassandra.service.StorageLoadBalancer
 
onRemove(InetAddress) - Method in class org.apache.cassandra.service.StorageService
 
op - Variable in class org.apache.cassandra.thrift.IndexExpression
 
open(String) - Static method in class org.apache.cassandra.db.Table
 
open(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
open(Descriptor, Set<Component>, CFMetaData, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
open(Descriptor, Set<Component>, Set<DecoratedKey>, SSTableTracker, CFMetaData, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
OpenBitSet - Class in org.apache.cassandra.utils.obs
An "open" BitSet implementation that allows direct access to the array of words storing the bits.
OpenBitSet(long) - Constructor for class org.apache.cassandra.utils.obs.OpenBitSet
Constructs an OpenBitSet large enough to hold numBits.
OpenBitSet() - Constructor for class org.apache.cassandra.utils.obs.OpenBitSet
 
OpenBitSet(long[], int) - Constructor for class org.apache.cassandra.utils.obs.OpenBitSet
Constructs an OpenBitSet from an existing long[].
OpenBitSet(BitSet) - Constructor for class org.apache.cassandra.utils.obs.OpenBitSet
Contructs an OpenBitset from a BitSet
oprot_ - Variable in class org.apache.cassandra.thrift.Cassandra.Client
 
or(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
OrderPreservingPartitioner - Class in org.apache.cassandra.dht
 
OrderPreservingPartitioner() - Constructor for class org.apache.cassandra.dht.OrderPreservingPartitioner
 
org.apache.cassandra.auth - package org.apache.cassandra.auth
 
org.apache.cassandra.avro - package org.apache.cassandra.avro
 
org.apache.cassandra.cache - package org.apache.cassandra.cache
 
org.apache.cassandra.cli - package org.apache.cassandra.cli
 
org.apache.cassandra.client - package org.apache.cassandra.client
 
org.apache.cassandra.concurrent - package org.apache.cassandra.concurrent
 
org.apache.cassandra.config - package org.apache.cassandra.config
 
org.apache.cassandra.db - package org.apache.cassandra.db
 
org.apache.cassandra.db.columniterator - package org.apache.cassandra.db.columniterator
 
org.apache.cassandra.db.commitlog - package org.apache.cassandra.db.commitlog
 
org.apache.cassandra.db.filter - package org.apache.cassandra.db.filter
 
org.apache.cassandra.db.marshal - package org.apache.cassandra.db.marshal
 
org.apache.cassandra.db.migration - package org.apache.cassandra.db.migration
 
org.apache.cassandra.dht - package org.apache.cassandra.dht
 
org.apache.cassandra.gms - package org.apache.cassandra.gms
 
org.apache.cassandra.hadoop - package org.apache.cassandra.hadoop
 
org.apache.cassandra.hadoop.streaming - package org.apache.cassandra.hadoop.streaming
 
org.apache.cassandra.io - package org.apache.cassandra.io
 
org.apache.cassandra.io.sstable - package org.apache.cassandra.io.sstable
 
org.apache.cassandra.io.util - package org.apache.cassandra.io.util
 
org.apache.cassandra.locator - package org.apache.cassandra.locator
 
org.apache.cassandra.net - package org.apache.cassandra.net
 
org.apache.cassandra.net.io - package org.apache.cassandra.net.io
 
org.apache.cassandra.net.sink - package org.apache.cassandra.net.sink
 
org.apache.cassandra.scheduler - package org.apache.cassandra.scheduler
 
org.apache.cassandra.service - package org.apache.cassandra.service
 
org.apache.cassandra.streaming - package org.apache.cassandra.streaming
 
org.apache.cassandra.thrift - package org.apache.cassandra.thrift
 
org.apache.cassandra.tools - package org.apache.cassandra.tools
 
org.apache.cassandra.utils - package org.apache.cassandra.utils
 
org.apache.cassandra.utils.obs - package org.apache.cassandra.utils.obs
 
out - Variable in class org.apache.cassandra.cli.CliSessionState
 
OutboundTcpConnection - Class in org.apache.cassandra.net
 
OutboundTcpConnection(InetAddress) - Constructor for class org.apache.cassandra.net.OutboundTcpConnection
 
OutputBuffer - Class in org.apache.cassandra.io.util
Extends ByteArrayOutputStream to minimize copies.
OutputBuffer() - Constructor for class org.apache.cassandra.io.util.OutputBuffer
 
OutputBuffer(int) - Constructor for class org.apache.cassandra.io.util.OutputBuffer
 

P

packIt(byte[], boolean) - Method in class org.apache.cassandra.net.MessagingService
 
Pair<T1,T2> - Class in org.apache.cassandra.utils
 
Pair(T1, T2) - Constructor for class org.apache.cassandra.utils.Pair
 
parseDoubleOrPercent(String) - Static method in class org.apache.cassandra.utils.FBUtilities
Parses a string representing either a fraction, absolute value or percentage.
PARTIALLY_INCONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
 
partitioner - Variable in class org.apache.cassandra.config.Config
 
partitioner - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
partitioner - Variable in class org.apache.cassandra.dht.AbstractBounds
 
partitioner - Variable in class org.apache.cassandra.io.sstable.SSTable
 
partitioner() - Method in class org.apache.cassandra.utils.MerkleTree
 
partitioner(IPartitioner) - Method in class org.apache.cassandra.utils.MerkleTree
TODO: Find another way to use the local partitioner after serialization.
passiveAnnounce() - Method in class org.apache.cassandra.db.migration.Migration
 
passiveAnnounce(UUID) - Static method in class org.apache.cassandra.service.MigrationManager
announce my version passively over gossip
PASSWD_FILENAME_PROPERTY - Static variable in class org.apache.cassandra.auth.SimpleAuthenticator
 
password - Variable in class org.apache.cassandra.cli.CliSessionState
 
PASSWORD_KEY - Static variable in class org.apache.cassandra.auth.SimpleAuthenticator
 
path - Variable in class org.apache.cassandra.db.filter.QueryFilter
 
path - Variable in class org.apache.cassandra.io.util.SegmentedFile
 
PendingFile - Class in org.apache.cassandra.streaming
Represents portions of a file to be streamed between nodes.
PendingFile(Descriptor, PendingFile) - Constructor for class org.apache.cassandra.streaming.PendingFile
 
PendingFile(SSTable, Descriptor, String, List<Pair<Long, Long>>) - Constructor for class org.apache.cassandra.streaming.PendingFile
 
PendingFile.PendingFileSerializer - Class in org.apache.cassandra.streaming
 
PendingFile.PendingFileSerializer() - Constructor for class org.apache.cassandra.streaming.PendingFile.PendingFileSerializer
 
pendingFiles - Variable in class org.apache.cassandra.streaming.StreamHeader
files to add to the session
pendingRangeChanges(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
performCleanup(ColumnFamilyStore) - Method in class org.apache.cassandra.db.CompactionManager
 
performMajor(ColumnFamilyStore) - Method in class org.apache.cassandra.db.CompactionManager
 
PeriodicCommitLogExecutorServiceMBean - Interface in org.apache.cassandra.db.commitlog
 
Permission - Enum in org.apache.cassandra.auth
An enum encapsulating the set of possible permissions that an authenticated user can have for a resource.
phi_convict_threshold - Variable in class org.apache.cassandra.config.Config
 
PMODE_PROPERTY - Static variable in class org.apache.cassandra.auth.SimpleAuthenticator
 
position - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogContext
 
posix_fadvise(int, int, int, int) - Static method in class org.apache.cassandra.utils.CLibrary
 
possibleCommitLogFile(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
postFlushExecutor - Static variable in class org.apache.cassandra.db.ColumnFamilyStore
 
PrecompactedRow - Class in org.apache.cassandra.io
PrecompactedRow merges its rows in its constructor in memory.
PrecompactedRow(DecoratedKey, DataOutputBuffer) - Constructor for class org.apache.cassandra.io.PrecompactedRow
 
PrecompactedRow(ColumnFamilyStore, List<SSTableIdentityIterator>, boolean, int) - Constructor for class org.apache.cassandra.io.PrecompactedRow
 
predicate - Variable in class org.apache.cassandra.db.IndexScanCommand
 
predicate - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
predicate - Variable in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
predicate - Variable in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
predicate - Variable in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
predicate - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
predicate - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
predicate - Variable in class org.apache.cassandra.thrift.Deletion
 
prepare(ColumnFamilyStore) - Method in class org.apache.cassandra.service.AntiEntropyService.Validator
 
preprocess(Message) - Method in interface org.apache.cassandra.service.IResponseResolver
 
preprocess(Message) - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
preprocess(Message) - Method in class org.apache.cassandra.service.ReadResponseResolver
 
preservesOrder() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
preservesOrder() - Method in interface org.apache.cassandra.dht.IPartitioner
 
preservesOrder() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
preservesOrder() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
preservesOrder() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
PRIMARY_INDEX - Static variable in class org.apache.cassandra.io.sstable.Component
 
printCmdHelp(Tree, CliSessionState) - Method in class org.apache.cassandra.cli.CliUserHelp
 
printColumnFamilyStats(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
printCompactionStats(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
printEndpoints(String, String) - Method in class org.apache.cassandra.tools.ClusterCmd
 
printInfo(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
Write node information.
printNetworkStats(InetAddress, PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
printPendingRanges() - Method in class org.apache.cassandra.locator.TokenMetadata
 
printReleaseVersion(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
printRemovalStatus(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
printRing(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
Write a textual representation of the Cassandra ring.
printThreadPoolStats(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
process(TProtocol, TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.Processor
 
process(int, TProtocol, TProtocol) - Method in interface org.apache.cassandra.thrift.Cassandra.Processor.ProcessFunction
 
processArgs(CliSessionState, String[]) - Method in class org.apache.cassandra.cli.CliOptions
 
processClientMessage(Message, String, InetAddress) - Static method in class org.apache.cassandra.net.sink.SinkManager
 
processMap_ - Variable in class org.apache.cassandra.thrift.Cassandra.Processor
 
processServerMessage(Message, String) - Static method in class org.apache.cassandra.net.sink.SinkManager
 
processStatement(String) - Static method in class org.apache.cassandra.cli.CliMain
 
progress - Variable in class org.apache.cassandra.streaming.PendingFile
 
PropertyFileSnitch - Class in org.apache.cassandra.locator
Used to determine if two IP's are in the same datacenter or on the same rack.
PropertyFileSnitch() - Constructor for class org.apache.cassandra.locator.PropertyFileSnitch
 
ProtocolHeader - Class in org.apache.cassandra.net
 
ProtocolHeader() - Constructor for class org.apache.cassandra.net.ProtocolHeader
 
purge(CFMetaData) - Static method in class org.apache.cassandra.config.CFMetaData
used for evicting cf data out of static tracking collections.
purgeIncompatibleHints() - Static method in class org.apache.cassandra.db.SystemTable
 
pushMigrations(UUID, UUID, InetAddress) - Static method in class org.apache.cassandra.service.MigrationManager
pushes migrations from this host to another host
put(K, V) - Method in class org.apache.cassandra.cache.InstrumentedCache
 
put(Object, Object) - Method in class org.apache.cassandra.concurrent.Context
 
put(ByteBuffer, IColumn) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
put(K, V) - Method in class org.apache.cassandra.utils.ExpiringMap
 
putAll(Map<? extends ByteBuffer, ? extends IColumn>) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
putColumn(IColumn) - Method in class org.apache.cassandra.db.SuperColumn
 
putToCredentials(String, String) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
putToMutation_map(ByteBuffer, Map<String, List<Mutation>>) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
putToStrategy_options(String, String) - Method in class org.apache.cassandra.thrift.KsDef
 
putToSuccess(String, List<String>) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
putToSuccess(ByteBuffer, int) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
putToSuccess(ByteBuffer, List<ColumnOrSuperColumn>) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 

Q

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

R

rack(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
RackInferringSnitch - Class in org.apache.cassandra.locator
A simple endpoint snitch implementation that assumes datacenter and rack information is encoded in the 2nd and 3rd octets of the ip address, respectively.
RackInferringSnitch() - Constructor for class org.apache.cassandra.locator.RackInferringSnitch
 
RandomPartitioner - Class in org.apache.cassandra.dht
This class generates a BigIntegerToken using MD5 hash.
RandomPartitioner() - Constructor for class org.apache.cassandra.dht.RandomPartitioner
 
range - Variable in class org.apache.cassandra.db.IndexScanCommand
 
range - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
Range - Class in org.apache.cassandra.dht
A representation of the range that a node is responsible for on the DHT ring.
Range(Token, Token) - Constructor for class org.apache.cassandra.dht.Range
 
Range(Token, Token, IPartitioner) - Constructor for class org.apache.cassandra.dht.Range
 
range - Variable in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
rangeSet(Range...) - Static method in class org.apache.cassandra.dht.Range
 
RangeSliceCommand - Class in org.apache.cassandra.db
 
RangeSliceCommand(String, ColumnParent, SlicePredicate, AbstractBounds, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
 
RangeSliceCommand(String, String, ByteBuffer, SlicePredicate, AbstractBounds, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
 
RangeSliceReply - Class in org.apache.cassandra.db
 
RangeSliceReply(List<Row>) - Constructor for class org.apache.cassandra.db.RangeSliceReply
 
RangeSliceResponseResolver - Class in org.apache.cassandra.service
Turns RangeSliceReply objects into row (string -> CF) maps, resolving to the most recent ColumnFamily and setting up read repairs as necessary.
RangeSliceResponseResolver(String, List<InetAddress>) - Constructor for class org.apache.cassandra.service.RangeSliceResponseResolver
 
RangeSliceVerbHandler - Class in org.apache.cassandra.service
 
RangeSliceVerbHandler() - Constructor for class org.apache.cassandra.service.RangeSliceVerbHandler
 
RawColumnDefinition - Class in org.apache.cassandra.config
 
RawColumnDefinition() - Constructor for class org.apache.cassandra.config.RawColumnDefinition
 
RawColumnFamily - Class in org.apache.cassandra.config
Deprecated. Yaml configuration for Keyspaces and ColumnFamilies is deprecated in 0.7
RawColumnFamily() - Constructor for class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
RawKeyspace - Class in org.apache.cassandra.config
Deprecated. Yaml configuration for Keyspaces and ColumnFamilies is deprecated in 0.7
RawKeyspace() - Constructor for class org.apache.cassandra.config.RawKeyspace
Deprecated.  
read(Message) - Static method in class org.apache.cassandra.db.IndexScanCommand
 
read(Message) - Static method in class org.apache.cassandra.db.RangeSliceCommand
 
read(byte[]) - Static method in class org.apache.cassandra.db.RangeSliceReply
 
read(DataInput) - Static method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
read() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
read(byte[]) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
read(byte[], int, int) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
read() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
read(List<ReadCommand>, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
Performs the actual reading of a row out of the StorageService, fetching a specific set of column names from a given column family.
read() - Method in class org.apache.cassandra.streaming.IncomingStreamReader
 
read(TProtocol) - Method in exception org.apache.cassandra.thrift.AuthenticationException
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
read(TProtocol) - Method in exception org.apache.cassandra.thrift.AuthorizationException
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.CfDef
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Column
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.ColumnDef
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.ColumnParent
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.ColumnPath
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Deletion
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.IndexClause
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.IndexExpression
 
read(TProtocol) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.KeyCount
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.KeyRange
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.KeySlice
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.KsDef
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.Mutation
 
read(TProtocol) - Method in exception org.apache.cassandra.thrift.NotFoundException
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.SlicePredicate
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.SliceRange
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.SuperColumn
 
read(TProtocol) - Method in exception org.apache.cassandra.thrift.TimedOutException
 
read(TProtocol) - Method in class org.apache.cassandra.thrift.TokenRange
 
read(TProtocol) - Method in exception org.apache.cassandra.thrift.UnavailableException
 
read_repair_chance - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
read_repair_chance - Variable in class org.apache.cassandra.thrift.CfDef
 
readBoolean() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a boolean from the current position in this file.
readByte() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads an 8-bit byte from the current position in this file.
readBytes(int) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
readBytes(int) - Method in interface org.apache.cassandra.io.util.FileDataInput
Read length bytes from current file position
readBytes(int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
Does the same thing as readFully do but without copying data (thread safe)
ReadCallback<T> - Class in org.apache.cassandra.service
 
ReadCallback(IResponseResolver<T>, ConsistencyLevel, String) - Constructor for class org.apache.cassandra.service.ReadCallback
Constructor when response count has to be calculated and blocked for.
readChar() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a 16-bit character from the current position in this file.
readColumnFamily(List<ReadCommand>, ConsistencyLevel) - Method in class org.apache.cassandra.avro.CassandraServer
 
readColumnFamily(List<ReadCommand>, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
ReadCommand - Class in org.apache.cassandra.db
 
ReadCommand(String, ByteBuffer, QueryPath, byte) - Constructor for class org.apache.cassandra.db.ReadCommand
 
readDouble() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a 64-bit double from the current position in this file.
readFields(DataInput) - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
readFloat() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a 32-bit float from the current position in this file.
readFully(byte[]) - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads bytes from this file into buffer.
readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.AbstractDataInput
Read bytes from this file into buffer starting at offset offset.
readFully(byte[]) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
readInt() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a 32-bit integer from the current position in this file.
readKeyValue() - Method in class org.apache.cassandra.hadoop.streaming.AvroOutputReader
 
readLine() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a line of text form the current position in this file.
readLong() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a 64-bit long from the current position in this file.
ReadRepairVerbHandler - Class in org.apache.cassandra.db
 
ReadRepairVerbHandler() - Constructor for class org.apache.cassandra.db.ReadRepairVerbHandler
 
ReadResponse - Class in org.apache.cassandra.db
 
ReadResponse(ByteBuffer) - Constructor for class org.apache.cassandra.db.ReadResponse
 
ReadResponse(Row) - Constructor for class org.apache.cassandra.db.ReadResponse
 
ReadResponseResolver - Class in org.apache.cassandra.service
Turns ReadResponse messages into Row objects, resolving to the most recent version and setting up read repairs as necessary.
ReadResponseResolver(String, ByteBuffer) - Constructor for class org.apache.cassandra.service.ReadResponseResolver
 
readRowSize(DataInput, Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
readSavedCache(File) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
readShort() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a 16-bit short from the current position in this file.
readTablesFromYaml() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
reads xml.
readUnsignedByte() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads an unsigned 8-bit byte from the current position in this file and returns it as an integer.
readUnsignedShort() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads an unsigned 16-bit short from the current position in this file and returns it as an integer.
readUTF() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a string that is encoded in modified UTF-8 from this file.
ReadVerbHandler - Class in org.apache.cassandra.db
 
ReadVerbHandler() - Constructor for class org.apache.cassandra.db.ReadVerbHandler
 
ReadVerbHandler.ReadContext - Class in org.apache.cassandra.db
 
ReadVerbHandler.ReadContext() - Constructor for class org.apache.cassandra.db.ReadVerbHandler.ReadContext
 
readWithLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
readWithShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
receive(Message, String) - Method in class org.apache.cassandra.net.MessagingService
 
receiveTiming(InetAddress, Double) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
receiveTiming(InetAddress, Double) - Method in interface org.apache.cassandra.locator.ILatencySubscriber
 
RECOMMENDED_DEPTH - Static variable in class org.apache.cassandra.utils.MerkleTree
 
reconcile(IColumn) - Method in class org.apache.cassandra.db.Column
 
reconcile(IColumn) - Method in interface org.apache.cassandra.db.IColumn
 
reconcile(IColumn) - Method in class org.apache.cassandra.db.SuperColumn
 
recover() - Static method in class org.apache.cassandra.db.commitlog.CommitLog
 
recover(File[]) - Static method in class org.apache.cassandra.db.commitlog.CommitLog
 
rectify(UUID, InetAddress) - Static method in class org.apache.cassandra.service.MigrationManager
will either push or pull an updating depending on who is behind.
recv_batch_mutate() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_describe_cluster_name() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_describe_keyspace() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_describe_keyspaces() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_describe_partitioner() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_describe_ring() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_describe_schema_versions() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_describe_snitch() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_describe_splits() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_describe_version() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_get() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_get_count() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_get_indexed_slices() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_get_range_slices() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_get_slice() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_insert() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_login() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_multiget_count() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_multiget_slice() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_remove() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_set_keyspace() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_system_add_column_family() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_system_add_keyspace() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_system_drop_column_family() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_system_drop_keyspace() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_system_update_column_family() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_system_update_keyspace() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
recv_truncate() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
reduce(SSTableIdentityIterator) - Method in class org.apache.cassandra.io.CompactionIterator
 
reduce(T1) - Method in class org.apache.cassandra.utils.ReducingIterator
combine this object with the previous ones.
reduce_cache_capacity_to - Variable in class org.apache.cassandra.config.Config
 
reduce_cache_sizes_at - Variable in class org.apache.cassandra.config.Config
 
reduceCacheSizes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
sets each cache's maximum capacity to 75% of its current size
reduceCacheSizes() - Method in class org.apache.cassandra.service.StorageService
 
ReducingIterator<T1,T2> - Class in org.apache.cassandra.utils
reduces equal values from the source iterator to a single (optionally transformed) instance.
ReducingIterator(Iterator<T1>) - Constructor for class org.apache.cassandra.utils.ReducingIterator
 
ReducingKeyIterator - Class in org.apache.cassandra.io.sstable
 
ReducingKeyIterator(Collection<SSTableReader>) - Constructor for class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
refreshEndpointMap() - Method in class org.apache.cassandra.client.RingCache
 
register(IEndpointStateChangeSubscriber) - Method in class org.apache.cassandra.gms.Gossiper
Register for interesting state changes.
register(AbstractReplicationStrategy) - Method in class org.apache.cassandra.locator.TokenMetadata
 
register(ILatencySubscriber) - Method in class org.apache.cassandra.net.MessagingService
 
registerDaemon(CassandraDaemon) - Method in class org.apache.cassandra.service.StorageService
 
registerFailureDetectionEventListener(IFailureDetectionEventListener) - Method in class org.apache.cassandra.gms.FailureDetector
 
registerFailureDetectionEventListener(IFailureDetectionEventListener) - Method in interface org.apache.cassandra.gms.IFailureDetector
Register interest for Failure Detector events.
registerMBean(Object) - Static method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
registerMBean() - Method in class org.apache.cassandra.db.HintedHandOffManager
 
registerVerbHandlers(StorageService.Verb, IVerbHandler) - Method in class org.apache.cassandra.net.MessagingService
Register a verb and the corresponding verb handler with the Messaging Service.
release() - Method in interface org.apache.cassandra.scheduler.IRequestScheduler
A convenience method for indicating when a particular request has completed processing, and before a return to the client
release() - Method in class org.apache.cassandra.scheduler.NoScheduler
 
release() - Method in class org.apache.cassandra.scheduler.RoundRobinScheduler
 
releaseLocks() - Method in class org.apache.cassandra.db.migration.Migration
 
releaseVersion() - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
reload() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
reloadCf(Integer) - Method in class org.apache.cassandra.db.Table
 
reloadConfiguration() - Method in class org.apache.cassandra.locator.PropertyFileSnitch
 
remove(ByteBuffer, ColumnPath, long, ConsistencyLevel) - Method in class org.apache.cassandra.avro.CassandraServer
 
remove(K) - Method in class org.apache.cassandra.cache.InstrumentedCache
 
remove(Object) - Method in class org.apache.cassandra.concurrent.Context
 
remove(ByteBuffer) - Method in class org.apache.cassandra.db.ColumnFamily
 
remove() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
remove() - Method in class org.apache.cassandra.db.filter.AbstractColumnIterator
 
remove() - Method in class org.apache.cassandra.db.RowIterator
 
remove(ByteBuffer) - Method in class org.apache.cassandra.db.SuperColumn
 
remove(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
 
remove(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
remove endpoint from failure detector
remove() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
remove() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
remove() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
remove(Object) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
remove(ByteBuffer, ColumnPath, long, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.remove_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
remove(ByteBuffer, ColumnPath, long, ConsistencyLevel, AsyncMethodCallback<Cassandra.AsyncClient.remove_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
remove(ByteBuffer, ColumnPath, long, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
remove(ByteBuffer, ColumnPath, long, ConsistencyLevel) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
Remove data from the row specified by key at the granularity specified by column_path, and the given timestamp.
remove(ByteBuffer, ColumnPath, long, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
remove() - Method in class org.apache.cassandra.utils.DestructivePQIterator
 
remove(K) - Method in class org.apache.cassandra.utils.ExpiringMap
 
remove(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Remove all elements set in other.
removeAllSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
removeBootstrapToken(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
 
REMOVED_TOKEN - Static variable in class org.apache.cassandra.gms.VersionedValue
 
removeDeleted(ColumnFamily, int) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
removeDeletedCF(ColumnFamily, int) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
removedNonlocal(Token, Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
removeEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
Removes the endpoint completely from Gossip
removeEndpoint(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
removeHeader(String) - Method in class org.apache.cassandra.net.Message
 
removeRegisteredCallback(String) - Method in class org.apache.cassandra.net.MessagingService
 
removeToken(Token) - Static method in class org.apache.cassandra.db.SystemTable
Remove stored token being used by another node
removeToken(String) - Method in class org.apache.cassandra.service.StorageService
Remove a node that has died, attempting to restore the replica count.
removeToken(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
removeToken removes token (and all data associated with enpoint that had it) from the ring
removeToken(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
REMOVING_TOKEN - Static variable in class org.apache.cassandra.gms.VersionedValue
 
removingNonlocal(Token, Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
rename(CFMetaData, String) - Static method in class org.apache.cassandra.config.CFMetaData
clones an existing CFMetaData using the same id.
renameCf(Integer, String) - Method in class org.apache.cassandra.db.Table
basically a combined drop and add
RenameColumnFamily - Class in org.apache.cassandra.db.migration
Deprecated. 
RenameColumnFamily() - Constructor for class org.apache.cassandra.db.migration.RenameColumnFamily
Deprecated. Required no-arg constructor
RenameColumnFamily(String, String, String) - Constructor for class org.apache.cassandra.db.migration.RenameColumnFamily
Deprecated.  
renameHints(String, String) - Static method in class org.apache.cassandra.db.HintedHandOffManager
called when a keyspace is dropped or rename.
RenameKeyspace - Class in org.apache.cassandra.db.migration
Deprecated. 
RenameKeyspace() - Constructor for class org.apache.cassandra.db.migration.RenameKeyspace
Deprecated. Required no-arg constructor
RenameKeyspace(String, String) - Constructor for class org.apache.cassandra.db.migration.RenameKeyspace
Deprecated.  
renameSSTables(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
renameTable(CFMetaData, String) - Static method in class org.apache.cassandra.config.CFMetaData
clones existing CFMetaData.
renameWithConfirm(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
renameWithConfirm(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
RepairCallback<T> - Class in org.apache.cassandra.service
 
RepairCallback(IResponseResolver<T>, List<InetAddress>) - Constructor for class org.apache.cassandra.service.RepairCallback
 
replace(Collection<SSTableReader>, Iterable<SSTableReader>) - Method in class org.apache.cassandra.io.sstable.SSTableTracker
 
replica_placement_strategy - Variable in class org.apache.cassandra.config.RawKeyspace
Deprecated.  
replication_factor - Variable in class org.apache.cassandra.config.RawKeyspace
Deprecated.  
replication_factor - Variable in class org.apache.cassandra.thrift.KsDef
 
replicationFactor - Variable in class org.apache.cassandra.config.KSMetaData
 
ReplicationFinishedVerbHandler - Class in org.apache.cassandra.streaming
 
ReplicationFinishedVerbHandler() - Constructor for class org.apache.cassandra.streaming.ReplicationFinishedVerbHandler
 
ReplicationStrategy - Class in org.apache.cassandra.config
 
ReplicationStrategy() - Constructor for class org.apache.cassandra.config.ReplicationStrategy
 
report(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
 
report(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
This method is invoked by the receiver of the heartbeat.
representJavaBeanProperty(Object, Property, Object, Tag) - Method in class org.apache.cassandra.utils.SkipNullRepresenter
 
request - Variable in class org.apache.cassandra.service.AntiEntropyService.Differencer
 
request - Variable in class org.apache.cassandra.service.AntiEntropyService.Validator
 
request_scheduler - Variable in class org.apache.cassandra.config.Config
 
request_scheduler_id - Variable in class org.apache.cassandra.config.Config
 
request_scheduler_options - Variable in class org.apache.cassandra.config.Config
 
REQUEST_TIMEOUT - Static variable in class org.apache.cassandra.service.AntiEntropyService
 
requestGC() - Method in class org.apache.cassandra.service.StorageService
 
requestRanges(InetAddress, String, Collection<Range>) - Static method in class org.apache.cassandra.streaming.StreamIn
Request ranges to be transferred from source to local node
requestRanges(InetAddress, String, Collection<Range>, Runnable) - Static method in class org.apache.cassandra.streaming.StreamIn
 
RequestSchedulerOptions - Class in org.apache.cassandra.config
 
RequestSchedulerOptions() - Constructor for class org.apache.cassandra.config.RequestSchedulerOptions
 
reset() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
reset() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
reset() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
reset(FileMark) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
reset() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
Resets the buffer to empty.
reset(FileMark) - Method in interface org.apache.cassandra.io.util.FileDataInput
 
reset(FileMark) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
reset() - Method in class org.apache.cassandra.service.ClientState
 
reset() - Method in class org.apache.cassandra.utils.SimpleCondition
 
resetUnsafe() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
resolve(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamily
 
resolve(String) - Method in class org.apache.cassandra.hadoop.streaming.AvroResolver
 
resolve() - Method in interface org.apache.cassandra.service.IResponseResolver
This Method resolves the responses that are passed in .
resolve() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
resolve() - Method in class org.apache.cassandra.service.ReadResponseResolver
 
resolver - Variable in class org.apache.cassandra.service.ReadCallback
 
Resources - Class in org.apache.cassandra.auth
Constants related to Cassandra's resource hierarchy.
Resources() - Constructor for class org.apache.cassandra.auth.Resources
 
resourceToFile(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
ResourceWatcher - Class in org.apache.cassandra.utils
 
ResourceWatcher() - Constructor for class org.apache.cassandra.utils.ResourceWatcher
 
ResourceWatcher.WatchedResource - Class in org.apache.cassandra.utils
 
ResourceWatcher.WatchedResource(String, Runnable) - Constructor for class org.apache.cassandra.utils.ResourceWatcher.WatchedResource
 
response(Message) - Method in interface org.apache.cassandra.net.IAsyncCallback
 
response(Message) - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
null message means "response from local write"
response(Message) - Method in class org.apache.cassandra.service.DatacenterReadCallback
 
response(ReadResponse) - Method in class org.apache.cassandra.service.DatacenterReadCallback
 
response(Message) - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
response(Message) - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
response(Message) - Method in class org.apache.cassandra.service.ReadCallback
 
response(ReadResponse) - Method in class org.apache.cassandra.service.ReadCallback
 
response(Message) - Method in class org.apache.cassandra.service.RepairCallback
 
response(Message) - Method in class org.apache.cassandra.service.TruncateResponseHandler
 
response(Message) - Method in class org.apache.cassandra.service.WriteResponseHandler
 
responses - Variable in class org.apache.cassandra.service.RangeSliceResponseResolver
 
responses - Variable in class org.apache.cassandra.service.TruncateResponseHandler
 
responses - Variable in class org.apache.cassandra.service.WriteResponseHandler
 
ResponseVerbHandler - Class in org.apache.cassandra.net
 
ResponseVerbHandler() - Constructor for class org.apache.cassandra.net.ResponseVerbHandler
 
result(Message) - Method in interface org.apache.cassandra.net.IAsyncResult
Store the result obtained for the submitted task.
retry(PendingFile) - Method in class org.apache.cassandra.streaming.StreamInSession
 
retry() - Method in class org.apache.cassandra.streaming.StreamOutSession
 
RETRY_DELAY - Static variable in class org.apache.cassandra.io.sstable.SSTableDeletingReference
 
RetryingScheduledThreadPoolExecutor - Class in org.apache.cassandra.concurrent
 
RetryingScheduledThreadPoolExecutor(String, int) - Constructor for class org.apache.cassandra.concurrent.RetryingScheduledThreadPoolExecutor
 
RetryingScheduledThreadPoolExecutor(int, String, int) - Constructor for class org.apache.cassandra.concurrent.RetryingScheduledThreadPoolExecutor
 
RetryingScheduledThreadPoolExecutor(String) - Constructor for class org.apache.cassandra.concurrent.RetryingScheduledThreadPoolExecutor
 
reversed - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
reversed - Variable in class org.apache.cassandra.db.SliceFromReadCommand
 
reversed - Variable in class org.apache.cassandra.thrift.SliceRange
 
revive(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureNotification
 
right - Variable in class org.apache.cassandra.dht.AbstractBounds
 
right - Variable in class org.apache.cassandra.utils.Pair
 
RING_DELAY - Static variable in class org.apache.cassandra.service.StorageService
 
RingCache - Class in org.apache.cassandra.client
A class for caching the ring map at the client.
RingCache(String, IPartitioner, String, int) - Constructor for class org.apache.cassandra.client.RingCache
 
ringIterator(ArrayList<Token>, Token, boolean) - Static method in class org.apache.cassandra.locator.TokenMetadata
iterator over the Tokens in the given ring, starting with the token for the node owning start (which does not have to be a Token in the ring)
rm - Variable in class org.apache.cassandra.db.migration.Migration
 
ROOT - Static variable in class org.apache.cassandra.auth.Resources
 
RoundRobinScheduler - Class in org.apache.cassandra.scheduler
A very basic Round Robin implementation of the RequestScheduler.
RoundRobinScheduler(RequestSchedulerOptions) - Constructor for class org.apache.cassandra.scheduler.RoundRobinScheduler
 
row() - Method in class org.apache.cassandra.db.ReadResponse
 
Row - Class in org.apache.cassandra.db
 
Row(DecoratedKey, ColumnFamily) - Constructor for class org.apache.cassandra.db.Row
 
row_cache_save_period_in_seconds - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
row_cache_save_period_in_seconds - Variable in class org.apache.cassandra.thrift.CfDef
 
row_cache_size - Variable in class org.apache.cassandra.thrift.CfDef
 
RowIterator - Class in org.apache.cassandra.db
Row iterator that allows us to close the underlying iterators.
RowIterator(ReducingIterator<IColumnIterator, Row>, List<Iterator<IColumnIterator>>) - Constructor for class org.apache.cassandra.db.RowIterator
 
RowIteratorFactory - Class in org.apache.cassandra.db
 
RowIteratorFactory() - Constructor for class org.apache.cassandra.db.RowIteratorFactory
 
RowMutation - Class in org.apache.cassandra.db
 
RowMutation(String, ByteBuffer) - Constructor for class org.apache.cassandra.db.RowMutation
 
RowMutation(String, Row) - Constructor for class org.apache.cassandra.db.RowMutation
 
RowMutation(String, ByteBuffer, Map<Integer, ColumnFamily>) - Constructor for class org.apache.cassandra.db.RowMutation
 
RowMutation.RowMutationSerializer - Class in org.apache.cassandra.db
 
RowMutation.RowMutationSerializer() - Constructor for class org.apache.cassandra.db.RowMutation.RowMutationSerializer
 
RowMutationVerbHandler - Class in org.apache.cassandra.db
 
RowMutationVerbHandler() - Constructor for class org.apache.cassandra.db.RowMutationVerbHandler
 
rows - Variable in class org.apache.cassandra.db.RangeSliceReply
 
rows - Variable in class org.apache.cassandra.io.CompactionIterator
 
rows_cached - Variable in class org.apache.cassandra.config.RawColumnFamily
Deprecated.  
rpc_address - Variable in class org.apache.cassandra.config.Config
 
rpc_keepalive - Variable in class org.apache.cassandra.config.Config
 
rpc_port - Variable in class org.apache.cassandra.config.Config
 
rpc_recv_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
 
rpc_send_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
 
rpc_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
rtree - Variable in class org.apache.cassandra.service.AntiEntropyService.Differencer
 
run() - Method in class org.apache.cassandra.net.IncomingTcpConnection
A new connection will either stream or message for its entire lifetime: because streaming bypasses the InputStream implementations to use sendFile, we cannot begin buffering until we've determined the type of the connection.
run() - Method in class org.apache.cassandra.net.MessageDeliveryTask
 
run() - Method in class org.apache.cassandra.net.OutboundTcpConnection
 
run() - Method in class org.apache.cassandra.service.AntiEntropyService.Differencer
Compares our trees, and triggers repairs for any ranges that mismatch.
run() - Method in class org.apache.cassandra.service.AntiEntropyService.Validator
Called after the validation lifecycle to respond with the now valid tree.
run() - Method in class org.apache.cassandra.utils.ResourceWatcher.WatchedResource
 
run() - Method in class org.apache.cassandra.utils.WrappedRunnable
 
runMayThrow() - Method in class org.apache.cassandra.streaming.FileStreamTask
 
runMayThrow() - Method in class org.apache.cassandra.utils.WrappedRunnable
 

S

saveCache() - Method in class org.apache.cassandra.io.sstable.CacheWriter
 
saveCaches() - Method in class org.apache.cassandra.service.StorageService
 
saveCaches() - Method in interface org.apache.cassandra.service.StorageServiceMBean
save row and key caches
saved_caches_directory - Variable in class org.apache.cassandra.config.Config
 
scan(IndexClause, AbstractBounds, IFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
scan(String, String, IndexClause, SlicePredicate, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
 
scheduledTasks - Static variable in class org.apache.cassandra.service.StorageService
 
SCHEMA_CF - Static variable in class org.apache.cassandra.db.migration.Migration
 
schema_mwt - Variable in class org.apache.cassandra.cli.CliSessionState
 
SchemaCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
SchemaCheckVerbHandler - Class in org.apache.cassandra.db
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
SchemaCheckVerbHandler() - Constructor for class org.apache.cassandra.db.SchemaCheckVerbHandler
 
SchemaTool - Class in org.apache.cassandra.tools
 
SchemaTool() - Constructor for class org.apache.cassandra.tools.SchemaTool
 
scrubDataDirectories(String, String) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
Removes unnecessary files from the cf directory at startup: these include temp files, orphans, zero-length files and compacted sstables.
sections - Variable in class org.apache.cassandra.streaming.PendingFile
 
seeds - Variable in class org.apache.cassandra.config.Config
 
seek(long) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
seekInternal(int) - Method in class org.apache.cassandra.io.util.AbstractDataInput
 
seekInternal(int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
seekTo(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
SegmentedFile - Class in org.apache.cassandra.io.util
Abstracts a read-only file that has been split into segments, each of which can be represented by an independent FileDataInput.
SegmentedFile.Builder - Class in org.apache.cassandra.io.util
Collects potential segmentation points in an underlying file, and builds a SegmentedFile to represent it.
SegmentedFile.Builder() - Constructor for class org.apache.cassandra.io.util.SegmentedFile.Builder
 
send_batch_mutate(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_describe_cluster_name() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_describe_keyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_describe_keyspaces() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_describe_partitioner() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_describe_ring(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_describe_schema_versions() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_describe_snitch() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_describe_splits(String, String, String, int) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_describe_version() - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_get(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_get_count(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_get_range_slices(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_get_slice(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_login(AuthenticationRequest) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_multiget_count(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_multiget_slice(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_remove(ByteBuffer, ColumnPath, long, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_set_keyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_system_add_column_family(CfDef) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_system_add_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_system_drop_column_family(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_system_drop_keyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_system_update_column_family(CfDef) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_system_update_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
send_truncate(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
sendOneWay(Message, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
sendReply(Message, String, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
sendRR(Message, InetAddress, IMessageCallback) - Method in class org.apache.cassandra.net.MessagingService
Send a message to a given endpoint.
sendRR(Message, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
seqid_ - Variable in class org.apache.cassandra.thrift.Cassandra.Client
 
SerDeUtils - Class in org.apache.cassandra.io
Static serialization/deserialization utility functions, intended to eventually replace ICompactSerializers.
SerDeUtils() - Constructor for class org.apache.cassandra.io.SerDeUtils
 
serialize(ColumnFamily, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serialize(IIterableColumns, DataOutput) - Static method in class org.apache.cassandra.db.ColumnIndexer
Given a column family this, function creates an in-memory structure that represents the column index for the column family, and subsequently writes it to disk.
serialize(IColumn, DataOutput) - Method in class org.apache.cassandra.db.ColumnSerializer
 
serialize(DataOutputStream) - Method in class org.apache.cassandra.db.filter.QueryPath
 
serialize() - Method in class org.apache.cassandra.db.migration.Migration
 
serialize(RowMutation, DataOutputStream) - Method in class org.apache.cassandra.db.RowMutation.RowMutationSerializer
 
serialize(TruncateResponse, DataOutputStream) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
 
serialize(WriteResponse, DataOutputStream) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
 
serialize(Token, DataOutput) - 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(T) - Static method in class org.apache.cassandra.io.SerDeUtils
Serializes a single object.
serialize(DataOutput) - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
serialize(InetAddress, DataOutputStream) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
 
serialize(AntiEntropyService.TreeRequest, DataOutputStream) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequestVerbHandler
 
serialize(AntiEntropyService.Validator, DataOutputStream) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeResponseVerbHandler
 
serialize(PendingFile, DataOutputStream) - Method in class org.apache.cassandra.streaming.PendingFile.PendingFileSerializer
 
serialize(EstimatedHistogram, DataOutputStream) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
serialize(TSerializer, TBase, DataOutput) - Static method in class org.apache.cassandra.utils.FBUtilities
 
serializeCFInfo(ColumnFamily, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializedSize() - Method in class org.apache.cassandra.db.Column
 
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.sstable.IndexHelper.IndexInfo
 
serializeForSSTable(ColumnFamily, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializeInternal(IIterableColumns, DataOutput) - Static method in class org.apache.cassandra.db.ColumnIndexer
 
serializer() - Static method in class org.apache.cassandra.db.Column
 
serializer() - Static method in class org.apache.cassandra.db.ColumnFamily
 
serializer - Static variable in class org.apache.cassandra.db.commitlog.CommitLogHeader
 
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.RowMutation
 
serializer(AbstractType) - Static method in class org.apache.cassandra.db.SuperColumn
 
serializer() - Static method in class org.apache.cassandra.db.TruncateResponse
 
serializer() - Static method in class org.apache.cassandra.db.Truncation
 
serializer() - Static method in class org.apache.cassandra.db.WriteResponse
 
serializer() - Static method in class org.apache.cassandra.dht.AbstractBounds
 
serializer() - Static method in class org.apache.cassandra.dht.Token
 
serializer() - Static method in class org.apache.cassandra.gms.EndpointState
 
serializer() - Static method in class org.apache.cassandra.gms.GossipDigest
 
serializer - Static variable in class org.apache.cassandra.gms.VersionedValue
 
serializer() - Static method in class org.apache.cassandra.net.Message
 
SERIALIZER - Static variable in class org.apache.cassandra.net.ProtocolHeader
 
SERIALIZER - Static variable in class org.apache.cassandra.service.AntiEntropyService.TreeRequestVerbHandler
 
SERIALIZER - Static variable in class org.apache.cassandra.service.AntiEntropyService.TreeResponseVerbHandler
 
serializer() - Static method in class org.apache.cassandra.streaming.PendingFile
 
serializer() - Static method in class org.apache.cassandra.streaming.StreamHeader
 
serializer() - Static method in class org.apache.cassandra.utils.BloomFilter
 
serializer - Static variable in class org.apache.cassandra.utils.EstimatedHistogram
 
serializer() - Static method in class org.apache.cassandra.utils.LegacyBloomFilter
 
SerializerType - Enum in org.apache.cassandra.net.io
 
serializerType_ - Variable in class org.apache.cassandra.net.ProtocolHeader
 
serializeWithIndexes(ColumnFamily, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializeWithSchema(T) - Static method in class org.apache.cassandra.io.SerDeUtils
Serializes a single object along with its Schema.
serialVersionUID - Static variable in class org.apache.cassandra.dht.Range
 
serialVersionUID - Static variable in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
serve() - Method in class org.apache.cassandra.thrift.CustomTThreadPoolServer
 
sessionid - Variable in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
sessionId - Variable in class org.apache.cassandra.streaming.StreamHeader
session is tuple of (host, sessionid)
sessionState - Static variable in class org.apache.cassandra.cli.CliMain
 
set(double) - Method in class org.apache.cassandra.utils.DefaultDouble
 
set(int) - Method in class org.apache.cassandra.utils.DefaultInteger
 
set(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
sets a bit, expanding the set size if necessary
set(long, long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Sets a range of bits, expanding the set size if necessary
set_keyspace(CharSequence) - Method in class org.apache.cassandra.avro.CassandraServer
 
set_keyspace(String, AsyncMethodCallback<Cassandra.AsyncClient.set_keyspace_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
set_keyspace(String, AsyncMethodCallback<Cassandra.AsyncClient.set_keyspace_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
set_keyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
set_keyspace(String) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
 
set_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
setAuth_request(AuthenticationRequest) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
 
setAuth_requestIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
 
setAuthnx(AuthenticationException) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
setAuthnxIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
setAuthzx(AuthorizationException) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
setAuthzxIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
setBits(long[]) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Expert: sets a new long[] to use as the bit storage
setBootstrapped(boolean) - Static method in class org.apache.cassandra.db.SystemTable
 
setCacheCapacities(String, String, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
 
setCapacity(int) - Method in class org.apache.cassandra.cache.InstrumentedCache
 
setCapacity(int) - Method in interface org.apache.cassandra.cache.JMXInstrumentedCacheMBean
 
setCf_def(CfDef) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
setCf_def(CfDef) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
setCf_defIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
setCf_defIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
setCf_defs(List<CfDef>) - Method in class org.apache.cassandra.thrift.KsDef
 
setCf_defsIsSet(boolean) - Method in class org.apache.cassandra.thrift.KsDef
 
setCfName(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
setCfname(String) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
setCfNameIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
setCfnameIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
setColumn(Column) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
setColumn(Column) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
setColumn(byte[]) - Method in class org.apache.cassandra.thrift.ColumnPath
 
setColumn(ByteBuffer) - Method in class org.apache.cassandra.thrift.ColumnPath
 
setColumn_family(String) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
setColumn_family(String) - Method in class org.apache.cassandra.thrift.ColumnParent
 
setColumn_family(String) - Method in class org.apache.cassandra.thrift.ColumnPath
 
setColumn_familyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
setColumn_familyIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnParent
 
setColumn_familyIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnPath
 
setColumn_metadata(List<ColumnDef>) - Method in class org.apache.cassandra.thrift.CfDef
 
setColumn_metadataIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setColumn_name(byte[]) - Method in class org.apache.cassandra.thrift.IndexExpression
 
setColumn_name(ByteBuffer) - Method in class org.apache.cassandra.thrift.IndexExpression
 
setColumn_nameIsSet(boolean) - Method in class org.apache.cassandra.thrift.IndexExpression
 
setColumn_names(List<ByteBuffer>) - Method in class org.apache.cassandra.thrift.SlicePredicate
 
setColumn_namesIsSet(boolean) - Method in class org.apache.cassandra.thrift.SlicePredicate
 
setColumn_or_supercolumn(ColumnOrSuperColumn) - Method in class org.apache.cassandra.thrift.Mutation
 
setColumn_or_supercolumnIsSet(boolean) - Method in class org.apache.cassandra.thrift.Mutation
 
setColumn_parent(ColumnParent) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
setColumn_parent(ColumnParent) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
setColumn_parent(ColumnParent) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
setColumn_parent(ColumnParent) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
setColumn_parent(ColumnParent) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
setColumn_parent(ColumnParent) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
setColumn_parent(ColumnParent) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
setColumn_parentIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
setColumn_parentIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
setColumn_parentIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
setColumn_parentIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
setColumn_parentIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
setColumn_parentIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
setColumn_parentIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
setColumn_path(ColumnPath) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
setColumn_path(ColumnPath) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
setColumn_pathIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
setColumn_pathIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
setColumn_predicate(SlicePredicate) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
setColumn_predicateIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
setColumn_type(String) - Method in class org.apache.cassandra.thrift.CfDef
 
setColumn_typeIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setColumnIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
setColumnIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
setColumnIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnPath
 
setColumns(List<ColumnOrSuperColumn>) - Method in class org.apache.cassandra.thrift.KeySlice
 
setColumns(List<Column>) - Method in class org.apache.cassandra.thrift.SuperColumn
 
setColumnsIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeySlice
 
setColumnsIsSet(boolean) - Method in class org.apache.cassandra.thrift.SuperColumn
 
setComment(String) - Method in class org.apache.cassandra.thrift.CfDef
 
setCommentIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setCompactionThreshold(String, String, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
Set the compaction threshold
setComparator_type(String) - Method in class org.apache.cassandra.thrift.CfDef
 
setComparator_typeIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
setConsistency_level(ConsistencyLevel) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
setConsistency_levelIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
setCorePoolSize(int) - Method in interface org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutorMBean
 
setCount(int) - Method in class org.apache.cassandra.thrift.IndexClause
 
setCount(int) - Method in class org.apache.cassandra.thrift.KeyCount
 
setCount(int) - Method in class org.apache.cassandra.thrift.KeyRange
 
setCount(int) - Method in class org.apache.cassandra.thrift.SliceRange
 
setCountIsSet(boolean) - Method in class org.apache.cassandra.thrift.IndexClause
 
setCountIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeyCount
 
setCountIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeyRange
 
setCountIsSet(boolean) - Method in class org.apache.cassandra.thrift.SliceRange
 
setCredentials(Map<String, String>) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
setCredentialsIsSet(boolean) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
setCurrentFile(PendingFile) - Method in class org.apache.cassandra.streaming.StreamInSession
 
setDefault_validation_class(String) - Method in class org.apache.cassandra.thrift.CfDef
 
setDefault_validation_classIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setDeletion(Deletion) - Method in class org.apache.cassandra.thrift.Mutation
 
setDeletionIsSet(boolean) - Method in class org.apache.cassandra.thrift.Mutation
 
setDigestQuery(boolean) - Method in class org.apache.cassandra.db.ReadCommand
 
setDynamicBadnessThreshold(Double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setDynamicResetInterval(Integer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setDynamicUpdateInterval(Integer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setEnd_key(byte[]) - Method in class org.apache.cassandra.thrift.KeyRange
 
setEnd_key(ByteBuffer) - Method in class org.apache.cassandra.thrift.KeyRange
 
setEnd_keyIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeyRange
 
setEnd_token(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
setEnd_token(String) - Method in class org.apache.cassandra.thrift.KeyRange
 
setEnd_token(String) - Method in class org.apache.cassandra.thrift.TokenRange
 
setEnd_tokenIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
setEnd_tokenIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeyRange
 
setEnd_tokenIsSet(boolean) - Method in class org.apache.cassandra.thrift.TokenRange
 
setEndpoints(List<String>) - Method in class org.apache.cassandra.thrift.TokenRange
 
setEndpointsIsSet(boolean) - Method in class org.apache.cassandra.thrift.TokenRange
 
setEndpointSnitch(IEndpointSnitch) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setErr(PrintStream) - Method in class org.apache.cassandra.cli.CliSessionState
 
setExpressions(List<IndexExpression>) - Method in class org.apache.cassandra.thrift.IndexClause
 
setExpressionsIsSet(boolean) - Method in class org.apache.cassandra.thrift.IndexClause
 
setFieldValue(AuthenticationException._Fields, Object) - Method in exception org.apache.cassandra.thrift.AuthenticationException
 
setFieldValue(AuthenticationRequest._Fields, Object) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
setFieldValue(AuthorizationException._Fields, Object) - Method in exception org.apache.cassandra.thrift.AuthorizationException
 
setFieldValue(Cassandra.batch_mutate_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
setFieldValue(Cassandra.batch_mutate_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
setFieldValue(Cassandra.describe_cluster_name_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
 
setFieldValue(Cassandra.describe_cluster_name_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
setFieldValue(Cassandra.describe_keyspace_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
setFieldValue(Cassandra.describe_keyspace_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
setFieldValue(Cassandra.describe_keyspaces_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
 
setFieldValue(Cassandra.describe_keyspaces_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
setFieldValue(Cassandra.describe_partitioner_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
 
setFieldValue(Cassandra.describe_partitioner_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
setFieldValue(Cassandra.describe_ring_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
setFieldValue(Cassandra.describe_ring_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
setFieldValue(Cassandra.describe_schema_versions_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
 
setFieldValue(Cassandra.describe_schema_versions_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
setFieldValue(Cassandra.describe_snitch_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
 
setFieldValue(Cassandra.describe_snitch_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
setFieldValue(Cassandra.describe_splits_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
setFieldValue(Cassandra.describe_splits_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
setFieldValue(Cassandra.describe_version_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
 
setFieldValue(Cassandra.describe_version_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
setFieldValue(Cassandra.get_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
setFieldValue(Cassandra.get_count_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
setFieldValue(Cassandra.get_count_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
setFieldValue(Cassandra.get_indexed_slices_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
setFieldValue(Cassandra.get_indexed_slices_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
setFieldValue(Cassandra.get_range_slices_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
setFieldValue(Cassandra.get_range_slices_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
setFieldValue(Cassandra.get_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
setFieldValue(Cassandra.get_slice_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
setFieldValue(Cassandra.get_slice_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
setFieldValue(Cassandra.insert_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
setFieldValue(Cassandra.insert_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
setFieldValue(Cassandra.login_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
 
setFieldValue(Cassandra.login_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
setFieldValue(Cassandra.multiget_count_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
setFieldValue(Cassandra.multiget_count_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
setFieldValue(Cassandra.multiget_slice_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
setFieldValue(Cassandra.multiget_slice_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
setFieldValue(Cassandra.remove_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
setFieldValue(Cassandra.remove_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
setFieldValue(Cassandra.set_keyspace_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
setFieldValue(Cassandra.set_keyspace_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
setFieldValue(Cassandra.system_add_column_family_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
setFieldValue(Cassandra.system_add_column_family_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
setFieldValue(Cassandra.system_add_keyspace_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
setFieldValue(Cassandra.system_add_keyspace_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
setFieldValue(Cassandra.system_drop_column_family_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
setFieldValue(Cassandra.system_drop_column_family_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
setFieldValue(Cassandra.system_drop_keyspace_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
setFieldValue(Cassandra.system_drop_keyspace_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
setFieldValue(Cassandra.system_update_column_family_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
setFieldValue(Cassandra.system_update_column_family_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
setFieldValue(Cassandra.system_update_keyspace_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
setFieldValue(Cassandra.system_update_keyspace_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
setFieldValue(Cassandra.truncate_args._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
setFieldValue(Cassandra.truncate_result._Fields, Object) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
setFieldValue(CfDef._Fields, Object) - Method in class org.apache.cassandra.thrift.CfDef
 
setFieldValue(Column._Fields, Object) - Method in class org.apache.cassandra.thrift.Column
 
setFieldValue(ColumnDef._Fields, Object) - Method in class org.apache.cassandra.thrift.ColumnDef
 
setFieldValue(ColumnOrSuperColumn._Fields, Object) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
setFieldValue(ColumnParent._Fields, Object) - Method in class org.apache.cassandra.thrift.ColumnParent
 
setFieldValue(ColumnPath._Fields, Object) - Method in class org.apache.cassandra.thrift.ColumnPath
 
setFieldValue(Deletion._Fields, Object) - Method in class org.apache.cassandra.thrift.Deletion
 
setFieldValue(IndexClause._Fields, Object) - Method in class org.apache.cassandra.thrift.IndexClause
 
setFieldValue(IndexExpression._Fields, Object) - Method in class org.apache.cassandra.thrift.IndexExpression
 
setFieldValue(InvalidRequestException._Fields, Object) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
 
setFieldValue(KeyCount._Fields, Object) - Method in class org.apache.cassandra.thrift.KeyCount
 
setFieldValue(KeyRange._Fields, Object) - Method in class org.apache.cassandra.thrift.KeyRange
 
setFieldValue(KeySlice._Fields, Object) - Method in class org.apache.cassandra.thrift.KeySlice
 
setFieldValue(KsDef._Fields, Object) - Method in class org.apache.cassandra.thrift.KsDef
 
setFieldValue(Mutation._Fields, Object) - Method in class org.apache.cassandra.thrift.Mutation
 
setFieldValue(NotFoundException._Fields, Object) - Method in exception org.apache.cassandra.thrift.NotFoundException
 
setFieldValue(SlicePredicate._Fields, Object) - Method in class org.apache.cassandra.thrift.SlicePredicate
 
setFieldValue(SliceRange._Fields, Object) - Method in class org.apache.cassandra.thrift.SliceRange
 
setFieldValue(SuperColumn._Fields, Object) - Method in class org.apache.cassandra.thrift.SuperColumn
 
setFieldValue(TimedOutException._Fields, Object) - Method in exception org.apache.cassandra.thrift.TimedOutException
 
setFieldValue(TokenRange._Fields, Object) - Method in class org.apache.cassandra.thrift.TokenRange
 
setFieldValue(UnavailableException._Fields, Object) - Method in exception org.apache.cassandra.thrift.UnavailableException
 
setFinish(byte[]) - Method in class org.apache.cassandra.thrift.SliceRange
 
setFinish(ByteBuffer) - Method in class org.apache.cassandra.thrift.SliceRange
 
setFinishIsSet(boolean) - Method in class org.apache.cassandra.thrift.SliceRange
 
setGc_grace_seconds(int) - Method in class org.apache.cassandra.thrift.CfDef
 
setGc_grace_secondsIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setHasToken(boolean) - Method in class org.apache.cassandra.gms.EndpointState
 
setHeader(String, byte[]) - Method in class org.apache.cassandra.net.Message
 
setHintedHandoffEnabled(boolean) - Method in class org.apache.cassandra.service.StorageProxy
 
setHintedHandoffEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
setId(int) - Method in class org.apache.cassandra.thrift.CfDef
 
setIdIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setIndex_clause(IndexClause) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
setIndex_clauseIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
setIndex_name(String) - Method in class org.apache.cassandra.thrift.ColumnDef
 
setIndex_nameIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnDef
 
setIndex_type(IndexType) - Method in class org.apache.cassandra.thrift.ColumnDef
 
setIndex_typeIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnDef
 
setIndexBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemTable
 
setIndexName(String) - Method in class org.apache.cassandra.config.ColumnDefinition
 
setIndexRemoved(String, String) - Static method in class org.apache.cassandra.db.SystemTable
 
setIndexType(IndexType) - Method in class org.apache.cassandra.config.ColumnDefinition
 
setInitialAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setInputColumnFamily(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the keyspace and column family for the input of this job.
setInputSlicePredicate(Configuration, SlicePredicate) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the predicate that determines what columns will be selected from each row.
setInputSplitSize(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the size of the input split.
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
setIre(InvalidRequestException) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
setIreIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
setKey(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
setKey(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
setKey(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
setKey(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
setKey(byte[]) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
setKey(byte[]) - Method in class org.apache.cassandra.thrift.KeyCount
 
setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.KeyCount
 
setKey(byte[]) - Method in class org.apache.cassandra.thrift.KeySlice
 
setKey(ByteBuffer) - Method in class org.apache.cassandra.thrift.KeySlice
 
setKey_cache_save_period_in_seconds(int) - Method in class org.apache.cassandra.thrift.CfDef
 
setKey_cache_save_period_in_secondsIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setKey_cache_size(double) - Method in class org.apache.cassandra.thrift.CfDef
 
setKey_cache_sizeIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setKeyCountToImport(Integer) - Static method in class org.apache.cassandra.tools.SSTableImport
Used by test framework to set key count
setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeyCount
 
setKeyIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeySlice
 
setKeys(List<ByteBuffer>) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
setKeys(List<ByteBuffer>) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
setKeys_per_split(int) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
setKeys_per_splitIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
setKeysIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
setKeysIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
setKeySpace(String) - Method in class org.apache.cassandra.cli.CliClient
 
setKeyspace(String) - Method in class org.apache.cassandra.service.ClientState
 
setKeyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
setKeyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
setKeyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
setKeyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
setKeyspace(String) - Method in class org.apache.cassandra.thrift.CfDef
 
setKeyspaceIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
setKeyspaceIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
setKeyspaceIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
setKeyspaceIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
setKeyspaceIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setKs_def(KsDef) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
setKs_def(KsDef) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
setKs_defIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
setKs_defIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
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
setMax_compaction_threshold(int) - Method in class org.apache.cassandra.thrift.CfDef
 
setMax_compaction_thresholdIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setMaxHintWindow(int) - Method in class org.apache.cassandra.service.StorageProxy
 
setMaxHintWindow(int) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
setMaximumCompactionThreshold(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setMaximumCompactionThreshold(int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Sets the maximum number of sstables in queue before compaction kicks off
setMemtable_flush_after_mins(int) - Method in class org.apache.cassandra.thrift.CfDef
 
setMemtable_flush_after_minsIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setMemtable_operations_in_millions(double) - Method in class org.apache.cassandra.thrift.CfDef
 
setMemtable_operations_in_millionsIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setMemtable_throughput_in_mb(int) - Method in class org.apache.cassandra.thrift.CfDef
 
setMemtable_throughput_in_mbIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setMemtableFlushAfterMins(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setMemtableFlushAfterMins(int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
setMemtableOperationsInMillions(double) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setMemtableOperationsInMillions(double) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
setMemtableThroughputInMB(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setMemtableThroughputInMB(int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
setMin_compaction_threshold(int) - Method in class org.apache.cassandra.thrift.CfDef
 
setMin_compaction_thresholdIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setMinimumCompactionThreshold(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setMinimumCompactionThreshold(int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Sets the minimum number of sstables in queue before compaction kicks off
setMutation_map(Map<ByteBuffer, Map<String, List<Mutation>>>) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
setMutation_mapIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
setName(String) - Method in class org.apache.cassandra.thrift.CfDef
 
setName(byte[]) - Method in class org.apache.cassandra.thrift.Column
 
setName(ByteBuffer) - Method in class org.apache.cassandra.thrift.Column
 
setName(byte[]) - Method in class org.apache.cassandra.thrift.ColumnDef
 
setName(ByteBuffer) - Method in class org.apache.cassandra.thrift.ColumnDef
 
setName(String) - Method in class org.apache.cassandra.thrift.KsDef
 
setName(byte[]) - Method in class org.apache.cassandra.thrift.SuperColumn
 
setName(ByteBuffer) - Method in class org.apache.cassandra.thrift.SuperColumn
 
setNameIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setNameIsSet(boolean) - Method in class org.apache.cassandra.thrift.Column
 
setNameIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnDef
 
setNameIsSet(boolean) - Method in class org.apache.cassandra.thrift.KsDef
 
setNameIsSet(boolean) - Method in class org.apache.cassandra.thrift.SuperColumn
 
setNfe(NotFoundException) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
setNfe(NotFoundException) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
setNfeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
setNfeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
setNumWords(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Expert: sets the number of longs in the array that are in use
setOp(IndexOperator) - Method in class org.apache.cassandra.thrift.IndexExpression
 
setOpIsSet(boolean) - Method in class org.apache.cassandra.thrift.IndexExpression
 
setOut(PrintStream) - Method in class org.apache.cassandra.cli.CliSessionState
 
setOutputColumnFamily(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the keyspace and column family for the output of this job.
setPartitioner(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setPendingRanges(String, Multimap<Range, InetAddress>) - Method in class org.apache.cassandra.locator.TokenMetadata
 
setPhiConvictThreshold(int) - Method in class org.apache.cassandra.gms.FailureDetector
 
setPhiConvictThreshold(int) - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
setPredicate(SlicePredicate) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
setPredicate(SlicePredicate) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
setPredicate(SlicePredicate) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
setPredicate(SlicePredicate) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
setPredicate(SlicePredicate) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
setPredicate(SlicePredicate) - Method in class org.apache.cassandra.thrift.Deletion
 
setPredicateIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
setPredicateIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
setPredicateIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
setPredicateIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
setPredicateIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
setPredicateIsSet(boolean) - Method in class org.apache.cassandra.thrift.Deletion
 
setRange(KeyRange) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
setRangeBatchSize(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
The number of rows to request with each get range slices request.
setRangeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
setRead_repair_chance(double) - Method in class org.apache.cassandra.thrift.CfDef
 
setRead_repair_chanceIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setReplication_factor(int) - Method in class org.apache.cassandra.thrift.KsDef
 
setReplication_factorIsSet(boolean) - Method in class org.apache.cassandra.thrift.KsDef
 
setReversed(boolean) - Method in class org.apache.cassandra.thrift.SliceRange
 
setReversedIsSet(boolean) - Method in class org.apache.cassandra.thrift.SliceRange
 
setRow_cache_save_period_in_seconds(int) - Method in class org.apache.cassandra.thrift.CfDef
 
setRow_cache_save_period_in_secondsIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setRow_cache_size(double) - Method in class org.apache.cassandra.thrift.CfDef
 
setRow_cache_sizeIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setRpcPort(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setSegmentSize(int) - Static method in class org.apache.cassandra.db.commitlog.CommitLog
 
setSlice_range(SliceRange) - Method in class org.apache.cassandra.thrift.SlicePredicate
 
setSlice_rangeIsSet(boolean) - Method in class org.apache.cassandra.thrift.SlicePredicate
 
setStart(byte[]) - Method in class org.apache.cassandra.thrift.SliceRange
 
setStart(ByteBuffer) - Method in class org.apache.cassandra.thrift.SliceRange
 
setStart_key(byte[]) - Method in class org.apache.cassandra.thrift.IndexClause
 
setStart_key(ByteBuffer) - Method in class org.apache.cassandra.thrift.IndexClause
 
setStart_key(byte[]) - Method in class org.apache.cassandra.thrift.KeyRange
 
setStart_key(ByteBuffer) - Method in class org.apache.cassandra.thrift.KeyRange
 
setStart_keyIsSet(boolean) - Method in class org.apache.cassandra.thrift.IndexClause
 
setStart_keyIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeyRange
 
setStart_token(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
setStart_token(String) - Method in class org.apache.cassandra.thrift.KeyRange
 
setStart_token(String) - Method in class org.apache.cassandra.thrift.TokenRange
 
setStart_tokenIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
setStart_tokenIsSet(boolean) - Method in class org.apache.cassandra.thrift.KeyRange
 
setStart_tokenIsSet(boolean) - Method in class org.apache.cassandra.thrift.TokenRange
 
setStartIsSet(boolean) - Method in class org.apache.cassandra.thrift.SliceRange
 
setStrategy_class(String) - Method in class org.apache.cassandra.thrift.KsDef
 
setStrategy_classIsSet(boolean) - Method in class org.apache.cassandra.thrift.KsDef
 
setStrategy_options(Map<String, String>) - Method in class org.apache.cassandra.thrift.KsDef
 
setStrategy_optionsIsSet(boolean) - Method in class org.apache.cassandra.thrift.KsDef
 
setSubcomparator_type(String) - Method in class org.apache.cassandra.thrift.CfDef
 
setSubcomparator_typeIsSet(boolean) - Method in class org.apache.cassandra.thrift.CfDef
 
setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
setSuccess(KsDef) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
setSuccess(List<KsDef>) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
setSuccess(List<TokenRange>) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
setSuccess(Map<String, List<String>>) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
setSuccess(List<String>) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
setSuccess(int) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
setSuccess(List<KeySlice>) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
setSuccess(List<KeySlice>) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
setSuccess(ColumnOrSuperColumn) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
setSuccess(List<ColumnOrSuperColumn>) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
setSuccess(Map<ByteBuffer, Integer>) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
setSuccess(Map<ByteBuffer, List<ColumnOrSuperColumn>>) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
setSuccess(String) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
setSuccessIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
setSuper_column(SuperColumn) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
setSuper_column(byte[]) - Method in class org.apache.cassandra.thrift.ColumnParent
 
setSuper_column(ByteBuffer) - Method in class org.apache.cassandra.thrift.ColumnParent
 
setSuper_column(byte[]) - Method in class org.apache.cassandra.thrift.ColumnPath
 
setSuper_column(ByteBuffer) - Method in class org.apache.cassandra.thrift.ColumnPath
 
setSuper_column(byte[]) - Method in class org.apache.cassandra.thrift.Deletion
 
setSuper_column(ByteBuffer) - Method in class org.apache.cassandra.thrift.Deletion
 
setSuper_columnIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
setSuper_columnIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnParent
 
setSuper_columnIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnPath
 
setSuper_columnIsSet(boolean) - Method in class org.apache.cassandra.thrift.Deletion
 
setTable(String) - Method in class org.apache.cassandra.streaming.StreamInSession
 
setTableDefinition(KSMetaData, UUID) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
setTe(TimedOutException) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
setTeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
setTimestamp(long) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
setTimestamp(long) - Method in class org.apache.cassandra.thrift.Column
 
setTimestamp(long) - Method in class org.apache.cassandra.thrift.Deletion
 
setTimestampIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
setTimestampIsSet(boolean) - Method in class org.apache.cassandra.thrift.Column
 
setTimestampIsSet(boolean) - Method in class org.apache.cassandra.thrift.Deletion
 
setToken(Token) - Method in class org.apache.cassandra.service.StorageService
This method updates the local token on disk
setTrackedBy(SSTableTracker) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
setTtl(int) - Method in class org.apache.cassandra.thrift.Column
 
setTtlIsSet(boolean) - Method in class org.apache.cassandra.thrift.Column
 
setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
setUe(UnavailableException) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
setUeIsSet(boolean) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
setup() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
This is a hook for concrete daemons to initialize themselves suitably.
setupJob(JobContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
setupTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
setUsername(String) - Method in class org.apache.cassandra.cli.CliClient
 
setValidation_class(String) - Method in class org.apache.cassandra.thrift.ColumnDef
 
setValidation_classIsSet(boolean) - Method in class org.apache.cassandra.thrift.ColumnDef
 
setValue(byte[]) - Method in class org.apache.cassandra.thrift.Column
 
setValue(ByteBuffer) - Method in class org.apache.cassandra.thrift.Column
 
setValue(byte[]) - Method in class org.apache.cassandra.thrift.IndexExpression
 
setValue(ByteBuffer) - Method in class org.apache.cassandra.thrift.IndexExpression
 
setValueIsSet(boolean) - Method in class org.apache.cassandra.thrift.Column
 
setValueIsSet(boolean) - Method in class org.apache.cassandra.thrift.IndexExpression
 
setVersion(InetAddress, int) - Method in class org.apache.cassandra.gms.Gossiper
 
setWhy(String) - Method in exception org.apache.cassandra.thrift.AuthenticationException
 
setWhy(String) - Method in exception org.apache.cassandra.thrift.AuthorizationException
 
setWhy(String) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
 
setWhyIsSet(boolean) - Method in exception org.apache.cassandra.thrift.AuthenticationException
 
setWhyIsSet(boolean) - Method in exception org.apache.cassandra.thrift.AuthorizationException
 
setWhyIsSet(boolean) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
 
shortSize_ - Static variable in class org.apache.cassandra.db.DBConstants
 
shouldAddEntry() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
shouldHint(InetAddress) - Static method in class org.apache.cassandra.service.StorageProxy
 
shutdown() - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
shutdown() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
shutdown() - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
shuts down the CommitLogExecutor in an orderly fashion
shutdown() - Method in class org.apache.cassandra.net.MessagingService
 
shutdown() - Method in class org.apache.cassandra.utils.ExpiringMap
 
shutdownBlocking() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
shutdownNow() - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Attempts to stop all actively executing tasks, halts the processing of waiting tasks, and returns a list of the tasks that were awaiting execution.
shutdownNow() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
shutdownNow() - Static method in class org.apache.cassandra.concurrent.StageManager
This method shuts down all registered stages.
shutdownNow() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
signal() - Method in class org.apache.cassandra.utils.SimpleCondition
 
signalAll() - Method in class org.apache.cassandra.utils.SimpleCondition
 
SimpleAbstractColumnIterator - Class in org.apache.cassandra.db.columniterator
 
SimpleAbstractColumnIterator() - Constructor for class org.apache.cassandra.db.columniterator.SimpleAbstractColumnIterator
 
SimpleAuthenticator - Class in org.apache.cassandra.auth
 
SimpleAuthenticator() - Constructor for class org.apache.cassandra.auth.SimpleAuthenticator
 
SimpleAuthenticator.PasswordMode - Enum in org.apache.cassandra.auth
 
SimpleAuthority - Class in org.apache.cassandra.auth
 
SimpleAuthority() - Constructor for class org.apache.cassandra.auth.SimpleAuthority
 
SimpleCondition - Class in org.apache.cassandra.utils
 
SimpleCondition() - Constructor for class org.apache.cassandra.utils.SimpleCondition
 
SimpleSnitch - Class in org.apache.cassandra.locator
A simple endpoint snitch implementation that treats Strategy order as proximity, allowing non-read-repaired reads to prefer a single endpoint, which improves cache locality.
SimpleSnitch() - Constructor for class org.apache.cassandra.locator.SimpleSnitch
 
SimpleStrategy - Class in org.apache.cassandra.locator
This class returns the nodes responsible for a given key but does not respect rack awareness.
SimpleStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.SimpleStrategy
 
singleton(T) - Static method in class org.apache.cassandra.utils.FBUtilities
 
SinkManager - Class in org.apache.cassandra.net.sink
 
SinkManager() - Constructor for class org.apache.cassandra.net.sink.SinkManager
 
size() - Method in class org.apache.cassandra.db.Column
 
size() - Method in class org.apache.cassandra.db.ExpiringColumn
 
size() - Method in interface org.apache.cassandra.db.IColumn
 
size() - Method in class org.apache.cassandra.db.SuperColumn
This calculates the exact size of the sub columns on the fly
size() - Method in class org.apache.cassandra.io.sstable.SSTableTracker
 
size() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
size - Variable in class org.apache.cassandra.streaming.PendingFile
 
size() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
size() - Method in class org.apache.cassandra.utils.BoundedStatsDeque
 
size() - Method in class org.apache.cassandra.utils.ExpiringMap
 
size() - Method in class org.apache.cassandra.utils.MerkleTree
The number of distinct ranges contained in this tree.
size() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the current capacity of this set.
sizeMemtableOperations(int) - Static method in class org.apache.cassandra.config.CFMetaData
 
sizeMemtableThroughput() - Static method in class org.apache.cassandra.config.CFMetaData
 
skipBloomFilter(FileDataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
Skip the bloom filter
skipBytes(int) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
skipBytes(int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
skipIndex(FileDataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
Skip the index
SkipNullRepresenter - Class in org.apache.cassandra.utils
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
SkipNullRepresenter() - Constructor for class org.apache.cassandra.utils.SkipNullRepresenter
 
skipShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
slice_range - Variable in class org.apache.cassandra.thrift.SlicePredicate
 
SliceByNamesReadCommand - Class in org.apache.cassandra.db
 
SliceByNamesReadCommand(String, ByteBuffer, ColumnParent, Collection<ByteBuffer>) - Constructor for class org.apache.cassandra.db.SliceByNamesReadCommand
 
SliceByNamesReadCommand(String, ByteBuffer, QueryPath, Collection<ByteBuffer>) - Constructor for class org.apache.cassandra.db.SliceByNamesReadCommand
 
sliced_buffer_size_in_kb - Variable in class org.apache.cassandra.config.Config
 
SliceFromReadCommand - Class in org.apache.cassandra.db
 
SliceFromReadCommand(String, ByteBuffer, ColumnParent, ByteBuffer, ByteBuffer, boolean, int) - Constructor for class org.apache.cassandra.db.SliceFromReadCommand
 
SliceFromReadCommand(String, ByteBuffer, QueryPath, ByteBuffer, ByteBuffer, boolean, int) - Constructor for class org.apache.cassandra.db.SliceFromReadCommand
 
SlicePredicate - Class in org.apache.cassandra.thrift
A SlicePredicate is similar to a mathematic predicate (see http://en.wikipedia.org/wiki/Predicate_(mathematical_logic)), which is described as "a property that the elements of a set have in common." SlicePredicate's in Cassandra are described with either a list of column_names or a SliceRange.
SlicePredicate() - Constructor for class org.apache.cassandra.thrift.SlicePredicate
 
SlicePredicate(SlicePredicate) - Constructor for class org.apache.cassandra.thrift.SlicePredicate
Performs a deep copy on other.
SlicePredicate._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
SliceQueryFilter - Class in org.apache.cassandra.db.filter
 
SliceQueryFilter(ByteBuffer, ByteBuffer, boolean, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
 
SliceRange - Class in org.apache.cassandra.thrift
A slice range is a structure that stores basic range, ordering and limit information for a query that will return multiple columns.
SliceRange() - Constructor for class org.apache.cassandra.thrift.SliceRange
 
SliceRange(ByteBuffer, ByteBuffer, boolean, int) - Constructor for class org.apache.cassandra.thrift.SliceRange
 
SliceRange(SliceRange) - Constructor for class org.apache.cassandra.thrift.SliceRange
Performs a deep copy on other.
SliceRange._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
snapshot(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Take a snap shot of this columnfamily store.
snapshot(String) - Method in class org.apache.cassandra.db.Table
Take a snapshot of the entire set of column families with a given timestamp.
snapshot_before_compaction - Variable in class org.apache.cassandra.config.Config
 
snitch - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
 
sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
Sorts the List of node addresses by proximity to the given address
sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
sortByProximity(InetAddress, List<InetAddress>) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
This method will sort the List by proximity to the given address.
sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.SimpleSnitch
 
sortedTokens() - Method in class org.apache.cassandra.locator.TokenMetadata
 
sortSampledKeys(List<DecoratedKey>, Range) - Static method in class org.apache.cassandra.utils.FBUtilities
 
source - Variable in class org.apache.cassandra.utils.ReducingIterator
 
spaceReclaimed(long) - Method in class org.apache.cassandra.io.sstable.SSTableTracker
 
split(Token) - Method in class org.apache.cassandra.dht.AbstractBounds
Given token T and AbstractBounds ?L,R], returns Pair(?L,T], ?T,R]) (where ? means that the same type of Bounds is returned -- Range or Bounds -- as the original.) The original AbstractBounds must contain the token T.
split(Token) - Method in class org.apache.cassandra.utils.MerkleTree
Splits the range containing the given token, if no tree limits would be violated.
SSTable - Class in org.apache.cassandra.io.sstable
This class is built on top of the SequenceFile.
SSTable(Descriptor, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.SSTable
 
SSTable(Descriptor, Set<Component>, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.SSTable
 
SSTable(Descriptor, Set<Component>, CFMetaData, IPartitioner, EstimatedHistogram, EstimatedHistogram) - Constructor for class org.apache.cassandra.io.sstable.SSTable
 
sstable - Variable in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
SSTableDeletingReference - Class in org.apache.cassandra.io.sstable
 
SSTableExport - Class in org.apache.cassandra.tools
Export SSTables to JSON format.
SSTableExport() - Constructor for class org.apache.cassandra.tools.SSTableExport
 
SSTableIdentityIterator - Class in org.apache.cassandra.io.sstable
 
SSTableIdentityIterator(SSTableReader, BufferedRandomAccessFile, DecoratedKey, long, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
Used to iterate through the columns of a row.
SSTableImport - Class in org.apache.cassandra.tools
Create SSTables from JSON input
SSTableImport() - Constructor for class org.apache.cassandra.tools.SSTableImport
 
SSTableNamesIterator - Class in org.apache.cassandra.db.columniterator
 
SSTableNamesIterator(SSTableReader, DecoratedKey, SortedSet<ByteBuffer>) - Constructor for class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
SSTableNamesIterator(SSTableReader, FileDataInput, DecoratedKey, SortedSet<ByteBuffer>) - Constructor for class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
SSTableReader - Class in org.apache.cassandra.io.sstable
SSTableReaders are open()ed by Table.onStart; after that they are created by SSTableWriter.renameAndOpen.
SSTableReader.Operator - Class in org.apache.cassandra.io.sstable
TODO: Move someplace reusable
SSTableReader.Operator() - Constructor for class org.apache.cassandra.io.sstable.SSTableReader.Operator
 
SSTableScanner - Class in org.apache.cassandra.io.sstable
 
SSTableSliceIterator - Class in org.apache.cassandra.db.columniterator
A Column Iterator over SSTable
SSTableSliceIterator(SSTableReader, DecoratedKey, ByteBuffer, ByteBuffer, boolean) - Constructor for class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
SSTableSliceIterator(SSTableReader, FileDataInput, DecoratedKey, ByteBuffer, ByteBuffer, boolean) - Constructor for class org.apache.cassandra.db.columniterator.SSTableSliceIterator
An iterator for a slice within an SSTable
SSTableTracker - Class in org.apache.cassandra.io.sstable
 
SSTableTracker(String, String) - Constructor for class org.apache.cassandra.io.sstable.SSTableTracker
 
SSTableWriter - Class in org.apache.cassandra.io.sstable
 
SSTableWriter(String, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableWriter
 
SSTableWriter(String, long, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.SSTableWriter
 
SSTableWriter.Builder - Class in org.apache.cassandra.io.sstable
Removes the given SSTable from temporary status and opens it, rebuilding the bloom filter and row index from the data file.
SSTableWriter.Builder(Descriptor) - Constructor for class org.apache.cassandra.io.sstable.SSTableWriter.Builder
 
Stage - Enum in org.apache.cassandra.concurrent
 
StageManager - Class in org.apache.cassandra.concurrent
This class manages executor services for Messages recieved: each Message requests running on a specific "stage" for concurrency control; hence the Map approach, even though stages (executors) are not created dynamically.
StageManager() - Constructor for class org.apache.cassandra.concurrent.StageManager
 
start - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
start - Variable in class org.apache.cassandra.db.SliceFromReadCommand
 
start(InetAddress, int) - Method in class org.apache.cassandra.gms.Gossiper
Start the gossiper with the generation # retrieved from the System table
start() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Start the Cassandra Daemon, assuming that it has already been initialized via AbstractCassandraDaemon.init(String[]) Hook for JSVC
start() - Method in interface org.apache.cassandra.service.CassandraDaemon
Start the Cassandra Daemon, assuming that it has already been initialized, via either CassandraDaemon.init(String[]) or #load(String[]).
start() - Method in class org.apache.cassandra.service.EmbeddedCassandraService
 
start() - Method in class org.apache.cassandra.service.GCInspector
 
start - Variable in class org.apache.cassandra.thrift.SliceRange
 
start_key - Variable in class org.apache.cassandra.thrift.IndexClause
 
start_key - Variable in class org.apache.cassandra.thrift.KeyRange
 
start_token - Variable in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
start_token - Variable in class org.apache.cassandra.thrift.KeyRange
 
start_token - Variable in class org.apache.cassandra.thrift.TokenRange
 
startBroadcasting() - Method in class org.apache.cassandra.service.StorageLoadBalancer
 
startGossiping() - Method in class org.apache.cassandra.service.StorageService
 
startGossiping() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
startGossiping() - Method in class org.apache.cassandra.tools.NodeProbe
 
startNext() - Method in class org.apache.cassandra.streaming.StreamOutSession
 
startRPCServer() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Start the underlying RPC server in idempotent manner.
startRPCServer() - Method in interface org.apache.cassandra.service.CassandraDaemon
 
startRPCServer() - Method in class org.apache.cassandra.service.StorageService
 
startRPCServer() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
startServer() - Method in class org.apache.cassandra.avro.CassandraDaemon
 
startServer() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Start the underlying RPC server.
startServer() - Method in class org.apache.cassandra.thrift.CassandraDaemon
 
startThriftServer() - Method in class org.apache.cassandra.tools.NodeProbe
 
startTime - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
state() - Method in class org.apache.cassandra.avro.CassandraServer
 
state() - Method in class org.apache.cassandra.thrift.CassandraServer
 
STATS - Static variable in class org.apache.cassandra.io.sstable.Component
 
STATUS_BOOTSTRAPPING - Static variable in class org.apache.cassandra.gms.VersionedValue
 
STATUS_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
STATUS_LEAVING - Static variable in class org.apache.cassandra.gms.VersionedValue
 
STATUS_LEFT - Static variable in class org.apache.cassandra.gms.VersionedValue
 
STATUS_NORMAL - Static variable in class org.apache.cassandra.gms.VersionedValue
 
StatusCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
StatusLogger - Class in org.apache.cassandra.utils
 
StatusLogger() - Constructor for class org.apache.cassandra.utils.StatusLogger
 
stdev() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
stop() - Method in class org.apache.cassandra.gms.Gossiper
 
stop() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Stop the daemon, ideally in an idempotent manner.
stop() - Method in interface org.apache.cassandra.service.CassandraDaemon
Stop the daemon, ideally in an idempotent manner.
stop() - Method in class org.apache.cassandra.thrift.CustomTThreadPoolServer
 
stopClient() - Method in class org.apache.cassandra.service.StorageService
 
stopGossiping() - Method in class org.apache.cassandra.service.StorageService
 
stopGossiping() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
stopGossiping() - Method in class org.apache.cassandra.tools.NodeProbe
 
stopRPCServer() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Stop the underlying RPC server in idempotent manner.
stopRPCServer() - Method in interface org.apache.cassandra.service.CassandraDaemon
 
stopRPCServer() - Method in class org.apache.cassandra.service.StorageService
 
stopRPCServer() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
stopServer() - Method in class org.apache.cassandra.avro.CassandraDaemon
 
stopServer() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Stop the underlying RPC server.
stopServer() - Method in class org.apache.cassandra.thrift.CassandraDaemon
 
stopThriftServer() - Method in class org.apache.cassandra.tools.NodeProbe
 
stopTimeoutUnit - Variable in class org.apache.cassandra.thrift.CustomTThreadPoolServer.Options
 
stopTimeoutVal - Variable in class org.apache.cassandra.thrift.CustomTThreadPoolServer.Options
 
storage_port - Variable in class org.apache.cassandra.config.Config
 
StorageLoadBalancer - Class in org.apache.cassandra.service
 
StorageProxy - Class in org.apache.cassandra.service
 
StorageProxyMBean - Interface in org.apache.cassandra.service
 
StorageService - Class in org.apache.cassandra.service
 
StorageService() - Constructor for class org.apache.cassandra.service.StorageService
 
StorageService.Keyspaces - Class in org.apache.cassandra.service
 
StorageService.Keyspaces() - Constructor for class org.apache.cassandra.service.StorageService.Keyspaces
 
StorageService.Verb - Enum in org.apache.cassandra.service
 
StorageServiceMBean - Interface in org.apache.cassandra.service
 
strategy_class - Variable in class org.apache.cassandra.config.ReplicationStrategy
 
strategy_class - Variable in class org.apache.cassandra.thrift.KsDef
 
strategy_options - Variable in class org.apache.cassandra.config.RawKeyspace
Deprecated.  
strategy_options - Variable in class org.apache.cassandra.config.ReplicationStrategy
 
strategy_options - Variable in class org.apache.cassandra.thrift.KsDef
 
strategyClass - Variable in class org.apache.cassandra.config.KSMetaData
 
strategyOptions - Variable in class org.apache.cassandra.config.KSMetaData
 
stream(StreamHeader, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
Stream a file from source to destination.
StreamHeader - Class in org.apache.cassandra.streaming
 
StreamHeader(String, long, PendingFile) - Constructor for class org.apache.cassandra.streaming.StreamHeader
 
StreamHeader(String, long, PendingFile, Collection<PendingFile>) - Constructor for class org.apache.cassandra.streaming.StreamHeader
 
StreamIn - Class in org.apache.cassandra.streaming
for streaming data from other nodes in to this one.
StreamIn() - Constructor for class org.apache.cassandra.streaming.StreamIn
 
StreamingService - Class in org.apache.cassandra.streaming
 
StreamingServiceMBean - Interface in org.apache.cassandra.streaming
 
StreamInSession - Class in org.apache.cassandra.streaming
each context gets its own StreamInSession.
StreamOut - Class in org.apache.cassandra.streaming
This class handles streaming data from one node to another.
StreamOut() - Constructor for class org.apache.cassandra.streaming.StreamOut
 
StreamOutSession - Class in org.apache.cassandra.streaming
This class manages the streaming of multiple files one after the other.
StreamReplyVerbHandler - Class in org.apache.cassandra.streaming
 
StreamReplyVerbHandler() - Constructor for class org.apache.cassandra.streaming.StreamReplyVerbHandler
 
StreamRequestVerbHandler - Class in org.apache.cassandra.streaming
This verb handler handles the StreamRequestMessage that is sent by the node requesting range transfer.
StreamRequestVerbHandler() - Constructor for class org.apache.cassandra.streaming.StreamRequestVerbHandler
 
string(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
string(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
string(ByteBuffer, int, int, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
string(ByteBuffer, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
stringifyFileSize(double) - Static method in class org.apache.cassandra.io.util.FileUtils
 
StringToken - Class in org.apache.cassandra.dht
 
StringToken(String) - Constructor for class org.apache.cassandra.dht.StringToken
 
subcolumnComparator - Variable in class org.apache.cassandra.config.CFMetaData
 
subcomparator_type - Variable in class org.apache.cassandra.thrift.CfDef
 
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.AddColumnFamily
 
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.AddKeyspace
 
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.DropColumnFamily
 
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.DropKeyspace
 
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.Migration
Deflate this Migration into an Avro object.
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.RenameColumnFamily
Deprecated.  
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.RenameKeyspace
Deprecated.  
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.UpdateColumnFamily
 
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.UpdateKeyspace
 
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.AddColumnFamily
 
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.AddKeyspace
 
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.DropColumnFamily
 
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.DropKeyspace
 
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.Migration
Inflate this Migration from an Avro object: called after the required no-arg constructor.
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.RenameColumnFamily
Deprecated.  
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.RenameKeyspace
Deprecated.  
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.UpdateColumnFamily
 
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.UpdateKeyspace
 
subMap(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
submit(Callable<T>) - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Submits a value-returning task for execution and returns a Future representing the pending results of the task.
submit(Runnable, T) - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Submits a Runnable task for execution and returns a Future representing that task.
submit(Runnable) - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Submits a Runnable task for execution and returns a Future representing that task.
submit(Callable<T>) - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
 
submitCacheWrite(CacheWriter) - Method in class org.apache.cassandra.db.CompactionManager
 
submitIndexBuild(ColumnFamilyStore, Table.IndexBuilder) - Method in class org.apache.cassandra.db.CompactionManager
 
submitKeyCacheWrite() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
submitMajor(ColumnFamilyStore, long, int) - Method in class org.apache.cassandra.db.CompactionManager
 
submitMinorIfNeeded(ColumnFamilyStore) - Method in class org.apache.cassandra.db.CompactionManager
Call this whenever a compaction might be needed on the given columnfamily.
submitRowCacheWrite() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
submitSSTableBuild(Descriptor) - Method in class org.apache.cassandra.db.CompactionManager
 
submitValidation(ColumnFamilyStore, AntiEntropyService.Validator) - Method in class org.apache.cassandra.db.CompactionManager
 
subsnitch - Variable in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
success - Variable in class org.apache.cassandra.db.TruncateResponse
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.get_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
success - Variable in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
sum() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
sumOfDeviations() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
super_column - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
super_column - Variable in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
super_column - Variable in class org.apache.cassandra.thrift.ColumnParent
 
super_column - Variable in class org.apache.cassandra.thrift.ColumnPath
 
super_column - Variable in class org.apache.cassandra.thrift.Deletion
 
SuperColumn - Class in org.apache.cassandra.db
 
SuperColumn(ByteBuffer, AbstractType) - Constructor for class org.apache.cassandra.db.SuperColumn
 
SuperColumn - Class in org.apache.cassandra.thrift
A named list of columns.
SuperColumn() - Constructor for class org.apache.cassandra.thrift.SuperColumn
 
SuperColumn(ByteBuffer, List<Column>) - Constructor for class org.apache.cassandra.thrift.SuperColumn
 
SuperColumn(SuperColumn) - Constructor for class org.apache.cassandra.thrift.SuperColumn
Performs a deep copy on other.
SuperColumn._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
superColumnName - Variable in class org.apache.cassandra.db.filter.QueryPath
 
sync() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
sync() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
system_add_column_family(CfDef) - Method in class org.apache.cassandra.avro.CassandraServer
 
system_add_column_family(CfDef, AsyncMethodCallback<Cassandra.AsyncClient.system_add_column_family_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
system_add_column_family(CfDef, AsyncMethodCallback<Cassandra.AsyncClient.system_add_column_family_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
system_add_column_family(CfDef) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
system_add_column_family(CfDef) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
adds a column family.
system_add_column_family(CfDef) - Method in class org.apache.cassandra.thrift.CassandraServer
 
system_add_keyspace(KsDef) - Method in class org.apache.cassandra.avro.CassandraServer
 
system_add_keyspace(KsDef, AsyncMethodCallback<Cassandra.AsyncClient.system_add_keyspace_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
system_add_keyspace(KsDef, AsyncMethodCallback<Cassandra.AsyncClient.system_add_keyspace_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
system_add_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
system_add_keyspace(KsDef) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
adds a keyspace and any column families that are part of it.
system_add_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.CassandraServer
 
system_drop_column_family(CharSequence) - Method in class org.apache.cassandra.avro.CassandraServer
 
system_drop_column_family(String, AsyncMethodCallback<Cassandra.AsyncClient.system_drop_column_family_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
system_drop_column_family(String, AsyncMethodCallback<Cassandra.AsyncClient.system_drop_column_family_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
system_drop_column_family(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
system_drop_column_family(String) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
drops a column family.
system_drop_column_family(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
system_drop_keyspace(CharSequence) - Method in class org.apache.cassandra.avro.CassandraServer
 
system_drop_keyspace(String, AsyncMethodCallback<Cassandra.AsyncClient.system_drop_keyspace_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
system_drop_keyspace(String, AsyncMethodCallback<Cassandra.AsyncClient.system_drop_keyspace_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
system_drop_keyspace(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
system_drop_keyspace(String) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
drops a keyspace and any column families that are part of it.
system_drop_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
SYSTEM_TABLE - Static variable in class org.apache.cassandra.db.Table
 
system_update_column_family(CfDef) - Method in class org.apache.cassandra.avro.CassandraServer
 
system_update_column_family(CfDef, AsyncMethodCallback<Cassandra.AsyncClient.system_update_column_family_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
system_update_column_family(CfDef, AsyncMethodCallback<Cassandra.AsyncClient.system_update_column_family_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
system_update_column_family(CfDef) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
system_update_column_family(CfDef) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
updates properties of a column family.
system_update_column_family(CfDef) - Method in class org.apache.cassandra.thrift.CassandraServer
 
system_update_keyspace(KsDef) - Method in class org.apache.cassandra.avro.CassandraServer
 
system_update_keyspace(KsDef, AsyncMethodCallback<Cassandra.AsyncClient.system_update_keyspace_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
system_update_keyspace(KsDef, AsyncMethodCallback<Cassandra.AsyncClient.system_update_keyspace_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
system_update_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
system_update_keyspace(KsDef) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
updates properties of a keyspace.
system_update_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.CassandraServer
update an existing keyspace, but do not allow column family modifications.
SystemTable - Class in org.apache.cassandra.db
 
SystemTable() - Constructor for class org.apache.cassandra.db.SystemTable
 

T

table - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
table - Variable in class org.apache.cassandra.db.ReadCommand
 
Table - Class in org.apache.cassandra.db
 
table() - Method in class org.apache.cassandra.db.WriteResponse
 
table - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
table - Variable in class org.apache.cassandra.streaming.StreamHeader
 
table - Variable in class org.apache.cassandra.streaming.StreamOutSession
 
Table.IndexBuilder - Class in org.apache.cassandra.db
 
Table.IndexBuilder(ColumnFamilyStore, SortedSet<ByteBuffer>, ReducingKeyIterator) - Constructor for class org.apache.cassandra.db.Table.IndexBuilder
 
tableName - Variable in class org.apache.cassandra.config.CFMetaData
 
tailMap(ByteBuffer) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
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.
takeGlobalSnapshot(String) - Method in class org.apache.cassandra.tools.ClusterCmd
Take a snapshot of all tables on all (live) nodes in the cluster
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.
TASK_ID - Static variable in class org.apache.cassandra.net.HeaderTypes
 
TASK_PROFILE_CHAIN - Static variable in class org.apache.cassandra.net.HeaderTypes
 
TBinaryProtocol - Class in org.apache.cassandra.thrift
TODO This was added to support writeBinary on direct buffers for CASSANDRA-1714; we can remove it once we upgrade to Thrift 0.7, which incorporates the patch (THRIFT-883).
TBinaryProtocol(TTransport) - Constructor for class org.apache.cassandra.thrift.TBinaryProtocol
 
TBinaryProtocol(TTransport, boolean, boolean) - Constructor for class org.apache.cassandra.thrift.TBinaryProtocol
 
TBinaryProtocol.Factory - Class in org.apache.cassandra.thrift
 
TBinaryProtocol.Factory() - Constructor for class org.apache.cassandra.thrift.TBinaryProtocol.Factory
 
TBinaryProtocol.Factory(boolean, boolean) - Constructor for class org.apache.cassandra.thrift.TBinaryProtocol.Factory
 
TBinaryProtocol.Factory(boolean, boolean, int) - Constructor for class org.apache.cassandra.thrift.TBinaryProtocol.Factory
 
TCustomServerSocket - Class in org.apache.cassandra.thrift
Extends Thrift's TServerSocket to allow customization of various desirable TCP properties.
TCustomServerSocket(InetSocketAddress, boolean, Integer, Integer) - Constructor for class org.apache.cassandra.thrift.TCustomServerSocket
Allows fine-tuning of the server socket including keep-alive, reuse of addresses, send and receive buffer sizes.
te - Variable in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
te - Variable in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
te - Variable in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
te - Variable in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
te - Variable in class org.apache.cassandra.thrift.Cassandra.get_result
 
te - Variable in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
te - Variable in class org.apache.cassandra.thrift.Cassandra.insert_result
 
te - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
te - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
te - Variable in class org.apache.cassandra.thrift.Cassandra.remove_result
 
TEMPFILE_MARKER - Static variable in class org.apache.cassandra.io.sstable.SSTable
 
temporary - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
thrift_framed_transport_size_in_mb - Variable in class org.apache.cassandra.config.Config
 
thrift_max_message_length_in_mb - Variable in class org.apache.cassandra.config.Config
 
thriftifyColumns(Collection<IColumn>, boolean) - Method in class org.apache.cassandra.thrift.CassandraServer
 
thriftifySubColumns(Collection<IColumn>) - Method in class org.apache.cassandra.thrift.CassandraServer
 
thriftPort - Variable in class org.apache.cassandra.cli.CliSessionState
 
ThriftValidation - Class in org.apache.cassandra.thrift
 
ThriftValidation() - Constructor for class org.apache.cassandra.thrift.ThriftValidation
 
throttle_limit - Variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
TimedOutException - Exception in org.apache.cassandra.thrift
RPC timeout was exceeded.
TimedOutException() - Constructor for exception org.apache.cassandra.thrift.TimedOutException
 
TimedOutException(TimedOutException) - Constructor for exception org.apache.cassandra.thrift.TimedOutException
Performs a deep copy on other.
TimedOutException._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
timestamp - Variable in class org.apache.cassandra.db.Column
 
timestamp() - Method in class org.apache.cassandra.db.Column
 
timestamp() - Method in interface org.apache.cassandra.db.IColumn
 
timestamp() - Method in class org.apache.cassandra.db.SuperColumn
 
timestamp - Variable in class org.apache.cassandra.thrift.Cassandra.remove_args
 
timestamp - Variable in class org.apache.cassandra.thrift.Column
 
timestamp - Variable in class org.apache.cassandra.thrift.Deletion
 
timestampMicros() - Static method in class org.apache.cassandra.utils.FBUtilities
 
TimeUUIDType - Class in org.apache.cassandra.db.marshal
 
toByteArray(Token<T>) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
toByteBuffer(long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
toInt(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Convert a byte buffer to an integer.
token - Variable in class org.apache.cassandra.db.DecoratedKey
 
token - Variable in class org.apache.cassandra.dht.BootStrapper
 
Token<T> - Class in org.apache.cassandra.dht
 
Token(T) - Constructor for class org.apache.cassandra.dht.Token
 
token - Variable in class org.apache.cassandra.dht.Token
 
token - Variable in class org.apache.cassandra.utils.MerkleTree.RowHash
 
Token.TokenFactory<T> - Class in org.apache.cassandra.dht
 
Token.TokenFactory() - Constructor for class org.apache.cassandra.dht.Token.TokenFactory
 
Token.TokenSerializer - Class in org.apache.cassandra.dht
 
Token.TokenSerializer() - Constructor for class org.apache.cassandra.dht.Token.TokenSerializer
 
tokenMetadata - Variable in class org.apache.cassandra.dht.BootStrapper
 
TokenMetadata - Class in org.apache.cassandra.locator
 
TokenMetadata() - Constructor for class org.apache.cassandra.locator.TokenMetadata
 
TokenMetadata(BiMap<Token, InetAddress>) - Constructor for class org.apache.cassandra.locator.TokenMetadata
 
TokenRange - Class in org.apache.cassandra.thrift
 
TokenRange() - Constructor for class org.apache.cassandra.thrift.TokenRange
 
TokenRange(String, String, List<String>) - Constructor for class org.apache.cassandra.thrift.TokenRange
 
TokenRange(TokenRange) - Constructor for class org.apache.cassandra.thrift.TokenRange
Performs a deep copy on other.
TokenRange._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
toString() - Method in class org.apache.cassandra.auth.AuthenticatedUser
 
toString(List<Object>) - Static method in class org.apache.cassandra.auth.Resources
 
toString() - Method in class org.apache.cassandra.config.CFMetaData
 
toString() - Method in class org.apache.cassandra.config.ColumnDefinition
 
toString() - Method in class org.apache.cassandra.config.KSMetaData
 
toString() - Method in class org.apache.cassandra.db.ColumnFamily
 
toString() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
toString() - Method in class org.apache.cassandra.db.commitlog.CommitLogHeader
 
toString() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogContext
 
toString() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
toString() - Method in class org.apache.cassandra.db.DecoratedKey
 
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.migration.AddColumnFamily
 
toString() - Method in class org.apache.cassandra.db.migration.AddKeyspace
 
toString() - Method in class org.apache.cassandra.db.migration.DropColumnFamily
 
toString() - Method in class org.apache.cassandra.db.migration.DropKeyspace
 
toString() - Method in class org.apache.cassandra.db.migration.RenameColumnFamily
Deprecated.  
toString() - Method in class org.apache.cassandra.db.migration.RenameKeyspace
Deprecated.  
toString() - Method in class org.apache.cassandra.db.migration.UpdateColumnFamily
 
toString() - Method in class org.apache.cassandra.db.migration.UpdateKeyspace
 
toString() - Method in class org.apache.cassandra.db.RangeSliceCommand
 
toString() - Method in class org.apache.cassandra.db.RangeSliceReply
 
toString() - Method in class org.apache.cassandra.db.Row
 
toString() - Method in class org.apache.cassandra.db.RowMutation
 
toString(boolean) - Method in class org.apache.cassandra.db.RowMutation
 
toString() - Method in class org.apache.cassandra.db.SliceByNamesReadCommand
 
toString() - Method in class org.apache.cassandra.db.SliceFromReadCommand
 
toString() - Method in class org.apache.cassandra.db.Truncation
 
toString() - Method in class org.apache.cassandra.dht.Bounds
 
toString() - Method in class org.apache.cassandra.dht.BytesToken
 
toString() - Method in class org.apache.cassandra.dht.LocalToken
 
toString() - Method in class org.apache.cassandra.dht.Range
 
toString(Token<T>) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
toString() - Method in class org.apache.cassandra.dht.Token
 
toString() - Method in class org.apache.cassandra.gms.FailureDetector
 
toString() - Method in class org.apache.cassandra.gms.GossipDigest
 
toString() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
toString() - Method in class org.apache.cassandra.io.sstable.Component
 
toString() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
toString() - Method in class org.apache.cassandra.io.sstable.IndexSummary.KeyPosition
 
toString() - Method in class org.apache.cassandra.io.sstable.SSTable
 
toString() - Method in class org.apache.cassandra.locator.TokenMetadata
 
toString() - Method in class org.apache.cassandra.net.Message
 
toString() - Method in class org.apache.cassandra.service.AntiEntropyService.Differencer
 
toString() - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
toString() - Method in class org.apache.cassandra.streaming.PendingFile
 
toString() - Method in exception org.apache.cassandra.thrift.AuthenticationException
 
toString() - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
toString() - Method in exception org.apache.cassandra.thrift.AuthorizationException
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.login_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
toString() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
toString() - Method in class org.apache.cassandra.thrift.CfDef
 
toString() - Method in class org.apache.cassandra.thrift.Column
 
toString() - Method in class org.apache.cassandra.thrift.ColumnDef
 
toString() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
toString() - Method in class org.apache.cassandra.thrift.ColumnParent
 
toString() - Method in class org.apache.cassandra.thrift.ColumnPath
 
toString() - Method in class org.apache.cassandra.thrift.Deletion
 
toString() - Method in class org.apache.cassandra.thrift.IndexClause
 
toString() - Method in class org.apache.cassandra.thrift.IndexExpression
 
toString() - Method in exception org.apache.cassandra.thrift.InvalidRequestException
 
toString() - Method in class org.apache.cassandra.thrift.KeyCount
 
toString() - Method in class org.apache.cassandra.thrift.KeyRange
 
toString() - Method in class org.apache.cassandra.thrift.KeySlice
 
toString() - Method in class org.apache.cassandra.thrift.KsDef
 
toString() - Method in class org.apache.cassandra.thrift.Mutation
 
toString() - Method in exception org.apache.cassandra.thrift.NotFoundException
 
toString() - Method in class org.apache.cassandra.thrift.SlicePredicate
 
toString() - Method in class org.apache.cassandra.thrift.SliceRange
 
toString() - Method in class org.apache.cassandra.thrift.SuperColumn
 
toString() - Method in exception org.apache.cassandra.thrift.TimedOutException
 
toString() - Method in class org.apache.cassandra.thrift.TokenRange
 
toString() - Method in exception org.apache.cassandra.thrift.UnavailableException
 
toString(Map<?, ?>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
toString() - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
toString() - Method in class org.apache.cassandra.utils.MerkleTree.RowHash
 
toString() - Method in class org.apache.cassandra.utils.MerkleTree
 
toString() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
toString() - Method in class org.apache.cassandra.utils.Pair
 
toUTF8Bytes(UUID) - Static method in class org.apache.cassandra.db.migration.Migration
 
transferRanges(InetAddress, String, Collection<Range>, Runnable) - Static method in class org.apache.cassandra.streaming.StreamOut
Split out files for all tables on disk locally for each range and then stream them to the target endpoint.
transferRangesForRequest(StreamOutSession, Collection<Range>) - Static method in class org.apache.cassandra.streaming.StreamOut
Split out files for all tables on disk locally for each range and then stream them to the target endpoint.
transferSSTables(StreamOutSession, Collection<SSTableReader>, Collection<Range>) - Static method in class org.apache.cassandra.streaming.StreamOut
Transfers matching portions of a group of sstables from a single table to the target endpoint.
tree - Variable in class org.apache.cassandra.service.AntiEntropyService.Validator
 
trimTrailingZeros() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Lowers numWords, the number of words in use, by checking for trailing zero words.
truncate(CharSequence) - Method in class org.apache.cassandra.avro.CassandraServer
 
truncate() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Truncate practically deletes the entire column family's data
truncate(String) - Method in class org.apache.cassandra.db.Table
Performs a synchronous truncate operation, effectively deleting all data from the column family cfname
truncate(String, long) - Static method in class org.apache.cassandra.io.util.FileUtils
 
truncate(String, String) - Method in class org.apache.cassandra.service.StorageService
 
truncate(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Truncates (deletes) the given columnFamily from the provided keyspace.
truncate(String, AsyncMethodCallback<Cassandra.AsyncClient.truncate_call>) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient
 
truncate(String, AsyncMethodCallback<Cassandra.AsyncClient.truncate_call>) - Method in interface org.apache.cassandra.thrift.Cassandra.AsyncIface
 
truncate(String) - Method in class org.apache.cassandra.thrift.Cassandra.Client
 
truncate(String) - Method in interface org.apache.cassandra.thrift.Cassandra.Iface
Truncate will mark and entire column family as deleted.
truncate(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
truncate(String, String) - Method in class org.apache.cassandra.tools.ClusterCmd
 
truncate(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
truncateBlocking(String, String) - Static method in class org.apache.cassandra.service.StorageProxy
Performs the truncate operatoin, which effectively deletes all data from the column family cfname
TruncateResponse - Class in org.apache.cassandra.db
This message is sent back the truncate operation and basically specifies if the truncate succeeded.
TruncateResponse(String, String, boolean) - Constructor for class org.apache.cassandra.db.TruncateResponse
 
TruncateResponse.TruncateResponseSerializer - Class in org.apache.cassandra.db
 
TruncateResponse.TruncateResponseSerializer() - Constructor for class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
 
TruncateResponseHandler - Class in org.apache.cassandra.service
 
TruncateResponseHandler(int) - Constructor for class org.apache.cassandra.service.TruncateResponseHandler
 
TruncateVerbHandler - Class in org.apache.cassandra.db
Handles the TRUNCATE verb
TruncateVerbHandler() - Constructor for class org.apache.cassandra.db.TruncateVerbHandler
 
Truncation - Class in org.apache.cassandra.db
A truncate operation descriptor
Truncation(String, String) - Constructor for class org.apache.cassandra.db.Truncation
 
tryComponentFromFilename(File, String) - Static method in class org.apache.cassandra.io.sstable.SSTable
 
tryFcntl(int, int, int) - Static method in class org.apache.cassandra.utils.CLibrary
 
tryMlockall() - Static method in class org.apache.cassandra.utils.CLibrary
 
trySkipCache(int, int, int) - Static method in class org.apache.cassandra.utils.CLibrary
 
tsSize_ - Static variable in class org.apache.cassandra.db.DBConstants
 
ttl - Variable in class org.apache.cassandra.thrift.Column
 
TWO - Static variable in class org.apache.cassandra.utils.FBUtilities
 
type - Variable in class org.apache.cassandra.io.sstable.Component
 

U

ue - Variable in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
ue - Variable in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
ue - Variable in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
ue - Variable in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
ue - Variable in class org.apache.cassandra.thrift.Cassandra.get_result
 
ue - Variable in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
ue - Variable in class org.apache.cassandra.thrift.Cassandra.insert_result
 
ue - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
ue - Variable in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
ue - Variable in class org.apache.cassandra.thrift.Cassandra.remove_result
 
ue - Variable in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
UnavailableException - Exception in org.apache.cassandra.thrift
Not all the replicas required could be created and/or read.
UnavailableException() - Constructor for exception org.apache.cassandra.thrift.UnavailableException
 
UnavailableException(UnavailableException) - Constructor for exception org.apache.cassandra.thrift.UnavailableException
Performs a deep copy on other.
UnavailableException._Fields - Enum in org.apache.cassandra.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
unescapeSQLString(String) - Static method in class org.apache.cassandra.cli.CliUtils
Strips leading and trailing "'" characters, and handles and escaped characters such as \n, \r, etc.
union(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
this = this OR other
unionCount(OpenBitSet, OpenBitSet) - Static method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the popcount or cardinality of the union of the two sets.
unregister(IEndpointStateChangeSubscriber) - Method in class org.apache.cassandra.gms.Gossiper
Unregister interest for state changes.
unregister(AbstractReplicationStrategy) - Method in class org.apache.cassandra.locator.TokenMetadata
 
unregisterFailureDetectionEventListener(IFailureDetectionEventListener) - Method in class org.apache.cassandra.gms.FailureDetector
 
unregisterFailureDetectionEventListener(IFailureDetectionEventListener) - Method in interface org.apache.cassandra.gms.IFailureDetector
Un-register interest for Failure Detector events.
unregisterMBean() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
UnserializableColumnFamilyException - Exception in org.apache.cassandra.db
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
UnserializableColumnFamilyException(String, int) - Constructor for exception org.apache.cassandra.db.UnserializableColumnFamilyException
 
unsetAuth_request() - Method in class org.apache.cassandra.thrift.Cassandra.login_args
 
unsetAuthnx() - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
unsetAuthzx() - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
unsetCf_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
unsetCf_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
unsetCf_defs() - Method in class org.apache.cassandra.thrift.KsDef
 
unsetCfName() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
unsetCfname() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
unsetColumn() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
unsetColumn() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
unsetColumn() - Method in class org.apache.cassandra.thrift.ColumnPath
 
unsetColumn_family() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
unsetColumn_family() - Method in class org.apache.cassandra.thrift.ColumnParent
 
unsetColumn_family() - Method in class org.apache.cassandra.thrift.ColumnPath
 
unsetColumn_metadata() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetColumn_name() - Method in class org.apache.cassandra.thrift.IndexExpression
 
unsetColumn_names() - Method in class org.apache.cassandra.thrift.SlicePredicate
 
unsetColumn_or_supercolumn() - Method in class org.apache.cassandra.thrift.Mutation
 
unsetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
unsetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
unsetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
unsetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
unsetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
unsetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
unsetColumn_parent() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
unsetColumn_path() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
unsetColumn_path() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
unsetColumn_predicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
unsetColumn_type() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetColumns() - Method in class org.apache.cassandra.thrift.KeySlice
 
unsetColumns() - Method in class org.apache.cassandra.thrift.SuperColumn
 
unsetComment() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetComparator_type() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
unsetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
unsetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
unsetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
unsetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
unsetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
unsetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
unsetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
unsetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
unsetConsistency_level() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
unsetCount() - Method in class org.apache.cassandra.thrift.IndexClause
 
unsetCount() - Method in class org.apache.cassandra.thrift.KeyCount
 
unsetCount() - Method in class org.apache.cassandra.thrift.KeyRange
 
unsetCount() - Method in class org.apache.cassandra.thrift.SliceRange
 
unsetCredentials() - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
unsetDefault_validation_class() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetDeletion() - Method in class org.apache.cassandra.thrift.Mutation
 
unsetEnd_key() - Method in class org.apache.cassandra.thrift.KeyRange
 
unsetEnd_token() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
unsetEnd_token() - Method in class org.apache.cassandra.thrift.KeyRange
 
unsetEnd_token() - Method in class org.apache.cassandra.thrift.TokenRange
 
unsetEndpoints() - Method in class org.apache.cassandra.thrift.TokenRange
 
unsetExpressions() - Method in class org.apache.cassandra.thrift.IndexClause
 
unsetFinish() - Method in class org.apache.cassandra.thrift.SliceRange
 
unsetGc_grace_seconds() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetId() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetIndex_clause() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
unsetIndex_name() - Method in class org.apache.cassandra.thrift.ColumnDef
 
unsetIndex_type() - Method in class org.apache.cassandra.thrift.ColumnDef
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
unsetIre() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
unsetKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
unsetKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
unsetKey() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
unsetKey() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
unsetKey() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
unsetKey() - Method in class org.apache.cassandra.thrift.KeyCount
 
unsetKey() - Method in class org.apache.cassandra.thrift.KeySlice
 
unsetKey_cache_save_period_in_seconds() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetKey_cache_size() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetKeys() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
unsetKeys() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
unsetKeys_per_split() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
unsetKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
unsetKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
unsetKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
unsetKeyspace() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
unsetKeyspace() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetKs_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
unsetKs_def() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
unsetMax_compaction_threshold() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetMemtable_flush_after_mins() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetMemtable_operations_in_millions() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetMemtable_throughput_in_mb() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetMin_compaction_threshold() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetMutation_map() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
unsetName() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetName() - Method in class org.apache.cassandra.thrift.Column
 
unsetName() - Method in class org.apache.cassandra.thrift.ColumnDef
 
unsetName() - Method in class org.apache.cassandra.thrift.KsDef
 
unsetName() - Method in class org.apache.cassandra.thrift.SuperColumn
 
unsetNfe() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
unsetNfe() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
unsetOp() - Method in class org.apache.cassandra.thrift.IndexExpression
 
unsetPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
unsetPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
unsetPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
unsetPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
unsetPredicate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
unsetPredicate() - Method in class org.apache.cassandra.thrift.Deletion
 
unsetRange() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
unsetRead_repair_chance() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetReplication_factor() - Method in class org.apache.cassandra.thrift.KsDef
 
unsetReversed() - Method in class org.apache.cassandra.thrift.SliceRange
 
unsetRow_cache_save_period_in_seconds() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetRow_cache_size() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetSlice_range() - Method in class org.apache.cassandra.thrift.SlicePredicate
 
unsetStart() - Method in class org.apache.cassandra.thrift.SliceRange
 
unsetStart_key() - Method in class org.apache.cassandra.thrift.IndexClause
 
unsetStart_key() - Method in class org.apache.cassandra.thrift.KeyRange
 
unsetStart_token() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
unsetStart_token() - Method in class org.apache.cassandra.thrift.KeyRange
 
unsetStart_token() - Method in class org.apache.cassandra.thrift.TokenRange
 
unsetStrategy_class() - Method in class org.apache.cassandra.thrift.KsDef
 
unsetStrategy_options() - Method in class org.apache.cassandra.thrift.KsDef
 
unsetSubcomparator_type() - Method in class org.apache.cassandra.thrift.CfDef
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
unsetSuccess() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
unsetSuper_column() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
unsetSuper_column() - Method in class org.apache.cassandra.thrift.ColumnParent
 
unsetSuper_column() - Method in class org.apache.cassandra.thrift.ColumnPath
 
unsetSuper_column() - Method in class org.apache.cassandra.thrift.Deletion
 
unsetTe() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
unsetTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
unsetTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
unsetTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
unsetTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
unsetTe() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
unsetTe() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
unsetTe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
unsetTe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
unsetTe() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
unsetTimestamp() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
unsetTimestamp() - Method in class org.apache.cassandra.thrift.Column
 
unsetTimestamp() - Method in class org.apache.cassandra.thrift.Deletion
 
unsetTtl() - Method in class org.apache.cassandra.thrift.Column
 
unsetUe() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
unsetUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
unsetUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
unsetUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
unsetUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
unsetUe() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
unsetUe() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
unsetUe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
unsetUe() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
unsetUe() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
unsetUe() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
unsetValidation_class() - Method in class org.apache.cassandra.thrift.ColumnDef
 
unsetValue() - Method in class org.apache.cassandra.thrift.Column
 
unsetValue() - Method in class org.apache.cassandra.thrift.IndexExpression
 
unsetWhy() - Method in exception org.apache.cassandra.thrift.AuthenticationException
 
unsetWhy() - Method in exception org.apache.cassandra.thrift.AuthorizationException
 
unsetWhy() - Method in exception org.apache.cassandra.thrift.InvalidRequestException
 
unwrap() - Method in class org.apache.cassandra.dht.AbstractBounds
 
unwrap() - Method in class org.apache.cassandra.dht.Bounds
 
unwrap() - Method in class org.apache.cassandra.dht.Range
 
update(MessageDigest) - Method in class org.apache.cassandra.io.AbstractCompactedRow
update @param digest with the data bytes of the row (not including row key or row size)
update(MessageDigest) - Method in class org.apache.cassandra.io.LazilyCompactedRow
 
update(MessageDigest) - Method in class org.apache.cassandra.io.PrecompactedRow
 
updateCacheSizes() - Method in class org.apache.cassandra.io.sstable.SSTableTracker
Resizes the key and row caches based on the current key estimate.
updateCapacity(int) - Method in class org.apache.cassandra.cache.InstrumentedCache
 
UpdateColumnFamily - Class in org.apache.cassandra.db.migration
todo: doesn't work with secondary indices yet.
UpdateColumnFamily() - Constructor for class org.apache.cassandra.db.migration.UpdateColumnFamily
 
UpdateColumnFamily(CfDef) - Constructor for class org.apache.cassandra.db.migration.UpdateColumnFamily
assumes validation has already happened.
updateCompletor(Set<String>) - Static method in class org.apache.cassandra.cli.CliMain
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.Column
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.ColumnFamily
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.ExpiringColumn
 
updateDigest(MessageDigest) - Method in interface org.apache.cassandra.db.IColumn
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.SuperColumn
 
UpdateKeyspace - Class in org.apache.cassandra.db.migration
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
UpdateKeyspace() - Constructor for class org.apache.cassandra.db.migration.UpdateKeyspace
Required no-arg constructor
UpdateKeyspace(KSMetaData) - Constructor for class org.apache.cassandra.db.migration.UpdateKeyspace
create migration based on thrift parameters
updateNormalToken(Token, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
updateSnitch(String, Boolean, Integer, Integer, Double) - Method in class org.apache.cassandra.service.StorageService
 
updateSnitch(String, Boolean, Integer, Integer, Double) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Change endpointsnitch class and dynamic-ness (and dynamic attributes) at runtime
updateToken(InetAddress, Token) - Static method in class org.apache.cassandra.db.SystemTable
Record token being used by another node
updateToken(Token) - Static method in class org.apache.cassandra.db.SystemTable
This method is used to update the System Table with the new token for this node
useEfficientCrossDCWrites() - Method in class org.apache.cassandra.service.StorageService
 
username - Variable in class org.apache.cassandra.auth.AuthenticatedUser
 
username - Variable in class org.apache.cassandra.cli.CliSessionState
 
USERNAME_KEY - Static variable in class org.apache.cassandra.auth.SimpleAuthenticator
 
usesOldBloomFilter - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
UTF8Type - Class in org.apache.cassandra.db.marshal
 
UUIDGen - Class in org.apache.cassandra.utils
Generates type 1 (time-based) UUIDs
UUIDGen() - Constructor for class org.apache.cassandra.utils.UUIDGen
 

V

validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
validate() - Method in exception org.apache.cassandra.thrift.AuthenticationException
 
validate() - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
validate() - Method in exception org.apache.cassandra.thrift.AuthorizationException
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.login_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
validate() - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
validate() - Method in class org.apache.cassandra.thrift.CfDef
 
validate() - Method in class org.apache.cassandra.thrift.Column
 
validate() - Method in class org.apache.cassandra.thrift.ColumnDef
 
validate() - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
validate() - Method in class org.apache.cassandra.thrift.ColumnParent
 
validate() - Method in class org.apache.cassandra.thrift.ColumnPath
 
validate() - Method in class org.apache.cassandra.thrift.Deletion
 
validate() - Method in class org.apache.cassandra.thrift.IndexClause
 
validate() - Method in class org.apache.cassandra.thrift.IndexExpression
 
validate() - Method in exception org.apache.cassandra.thrift.InvalidRequestException
 
validate() - Method in class org.apache.cassandra.thrift.KeyCount
 
validate() - Method in class org.apache.cassandra.thrift.KeyRange
 
validate() - Method in class org.apache.cassandra.thrift.KeySlice
 
validate() - Method in class org.apache.cassandra.thrift.KsDef
 
validate() - Method in class org.apache.cassandra.thrift.Mutation
 
validate() - Method in exception org.apache.cassandra.thrift.NotFoundException
 
validate() - Method in class org.apache.cassandra.thrift.SlicePredicate
 
validate() - Method in class org.apache.cassandra.thrift.SliceRange
 
validate() - Method in class org.apache.cassandra.thrift.SuperColumn
 
validate() - Method in exception org.apache.cassandra.thrift.TimedOutException
 
validate() - Method in class org.apache.cassandra.thrift.TokenRange
 
validate() - Method in exception org.apache.cassandra.thrift.UnavailableException
 
validateCfDef(CfDef) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateColumn(String, ColumnParent, Column) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateColumnFamily(String, String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateColumnOrSuperColumn(String, String, ColumnOrSuperColumn) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateColumns(String, ColumnParent, Iterable<ByteBuffer>) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllAuthority
 
validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthenticator
 
validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthority
 
validateConfiguration() - Method in class org.apache.cassandra.auth.SimpleAuthenticator
 
validateConfiguration() - Method in class org.apache.cassandra.auth.SimpleAuthority
 
validateCurrentFile(String) - Method in class org.apache.cassandra.streaming.StreamOutSession
 
validateDeletion(String, String, Deletion) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateIndexClauses(String, String, IndexClause) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateIndexType(ColumnDef) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
validateKeyRange(KeyRange) - Static method in class org.apache.cassandra.avro.AvroValidation
 
validateKeyRange(KeyRange) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateMagic(int) - Static method in class org.apache.cassandra.net.MessagingService
 
validateMemtableSettings(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
 
validateMemtableSettings(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
 
validateMinMaxCompactionThresholds(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
 
validateMinMaxCompactionThresholds(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
 
validateMutation(String, String, Mutation) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validatePredicate(String, ColumnParent, SlicePredicate) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateRange(String, ColumnParent, SliceRange) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateSlicePredicate(String, String, ByteBuffer, SlicePredicate) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateTable(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validation_class - Variable in class org.apache.cassandra.thrift.ColumnDef
 
validator - Variable in class org.apache.cassandra.config.ColumnDefinition
 
validator_class - Variable in class org.apache.cassandra.config.RawColumnDefinition
 
value - Variable in class org.apache.cassandra.db.Column
 
value() - Method in class org.apache.cassandra.db.Column
 
value() - Method in interface org.apache.cassandra.db.IColumn
 
value() - Method in class org.apache.cassandra.db.SuperColumn
 
value - Variable in class org.apache.cassandra.gms.VersionedValue
 
value - Variable in class org.apache.cassandra.thrift.Column
 
value - Variable in class org.apache.cassandra.thrift.IndexExpression
 
value() - Method in class org.apache.cassandra.utils.DefaultDouble
 
value() - Method in class org.apache.cassandra.utils.DefaultInteger
 
valueFactory - Variable in class org.apache.cassandra.service.StorageService
 
valueOf(String) - Static method in enum org.apache.cassandra.auth.Permission
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.auth.SimpleAuthenticator.PasswordMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cli.CliClient.Function
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cli.CliUserHelp.ColumnFamilyArgument
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.concurrent.Stage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.Config.CommitLogSync
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.Config.DiskAccessMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.Config.RequestSchedulerId
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.ColumnFamilyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.gms.ApplicationState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.net.io.SerializerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.service.StorageService.Verb
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.AuthenticationException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.AuthenticationRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.AuthorizationException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.login_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.login_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.CfDef._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Column._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.ColumnDef._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.ColumnOrSuperColumn._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.ColumnParent._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.ColumnPath._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.ConsistencyLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Deletion._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.IndexClause._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.IndexExpression._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.IndexOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.IndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.InvalidRequestException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.KeyCount._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.KeyRange._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.KeySlice._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.KsDef._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.Mutation._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.NotFoundException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.SlicePredicate._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.SliceRange._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.SuperColumn._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.TimedOutException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.TokenRange._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.UnavailableException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.tools.NodeCmd.NodeCommand
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.cassandra.auth.Permission
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.auth.SimpleAuthenticator.PasswordMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.cli.CliClient.Function
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.cli.CliUserHelp.ColumnFamilyArgument
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.concurrent.Stage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.config.Config.CommitLogSync
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.config.Config.DiskAccessMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.config.Config.RequestSchedulerId
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.db.ColumnFamilyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.gms.ApplicationState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
values() - Static method in enum org.apache.cassandra.net.io.SerializerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.service.StorageService.Verb
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.AuthenticationException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.AuthenticationRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.AuthorizationException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.batch_mutate_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspace_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_partitioner_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_ring_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_snitch_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_splits_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.describe_version_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.get_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.get_count_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.get_range_slices_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.get_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.get_slice_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.insert_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.login_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.login_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_count_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.multiget_slice_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.remove_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.set_keyspace_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_column_family_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_column_family_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Cassandra.truncate_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.CfDef._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Column._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.ColumnDef._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.ColumnOrSuperColumn._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.ColumnParent._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.ColumnPath._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.ConsistencyLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Deletion._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.IndexClause._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.IndexExpression._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.IndexOperator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.IndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.InvalidRequestException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.KeyCount._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.KeyRange._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.KeySlice._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.KsDef._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.Mutation._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.NotFoundException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.SlicePredicate._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.SliceRange._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.SuperColumn._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.TimedOutException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.TokenRange._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.UnavailableException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.tools.NodeCmd.NodeCommand
Returns an array containing the constants of this enum type, in the order they are declared.
variance() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
verbose - Variable in class org.apache.cassandra.cli.CliSessionState
 
VERBS - Static variable in class org.apache.cassandra.service.StorageService
 
verbStages - Static variable in class org.apache.cassandra.service.StorageService
 
version - Variable in class org.apache.cassandra.gms.VersionedValue
 
version - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
VERSION - Static variable in class org.apache.cassandra.net.ProtocolHeader
 
VERSION - Static variable in class org.apache.cassandra.thrift.Constants
 
version_ - Static variable in class org.apache.cassandra.net.MessagingService
 
version_ - Variable in class org.apache.cassandra.net.ProtocolHeader
 
VersionedValue - Class in org.apache.cassandra.gms
This abstraction represents the state associated with a particular node which an application wants to make available to the rest of the nodes in the cluster.
VersionedValue.VersionedValueFactory - Class in org.apache.cassandra.gms
 
VersionedValue.VersionedValueFactory(IPartitioner) - Constructor for class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
VersionGenerator - Class in org.apache.cassandra.gms
A unique version number generator for any state that is generated by the local node.
VersionGenerator() - Constructor for class org.apache.cassandra.gms.VersionGenerator
 

W

waitFor() - Static method in class org.apache.cassandra.io.DeletionService
 
waitFor() - Method in class org.apache.cassandra.net.MessagingService
blocks until the processing pools are empty and done.
waitForLoadInfo() - Method in class org.apache.cassandra.service.StorageLoadBalancer
Wait for at least BROADCAST_INTERVAL ms, to give all nodes enough time to report in.
waitOnFutures(Iterable<Future<?>>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
waitUntilListening() - Method in class org.apache.cassandra.net.MessagingService
 
watch(String, Runnable, int) - Static method in class org.apache.cassandra.utils.ResourceWatcher
 
weights - Variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
why - Variable in exception org.apache.cassandra.thrift.AuthenticationException
 
why - Variable in exception org.apache.cassandra.thrift.AuthorizationException
 
why - Variable in exception org.apache.cassandra.thrift.InvalidRequestException
 
width - Variable in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
wlen - Variable in class org.apache.cassandra.utils.obs.OpenBitSet
 
WrappedRunnable - Class in org.apache.cassandra.utils
 
WrappedRunnable() - Constructor for class org.apache.cassandra.utils.WrappedRunnable
 
write(RowMutation, Object) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
write(DataOutput) - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
write(DataOutput) - Method in class org.apache.cassandra.io.AbstractCompactedRow
write the row (size + column index + filter + column data, but NOT row key) to @param out
write(DataOutput) - Method in class org.apache.cassandra.io.LazilyCompactedRow
 
write(DataOutput) - Method in class org.apache.cassandra.io.PrecompactedRow
 
write(int) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
write(byte[]) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
write(byte[], int, int) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
write(DataInput, int) - Method in class org.apache.cassandra.io.util.OutputBuffer
 
write(ByteBuffer) - Method in class org.apache.cassandra.net.OutboundTcpConnection
 
write(TProtocol) - Method in exception org.apache.cassandra.thrift.AuthenticationException
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.AuthenticationRequest
 
write(TProtocol) - Method in exception org.apache.cassandra.thrift.AuthorizationException
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.batch_mutate_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_cluster_name_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspace_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_keyspaces_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_partitioner_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_ring_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_schema_versions_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_snitch_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_splits_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.describe_version_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_count_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_indexed_slices_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_range_slices_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.get_slice_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.insert_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.insert_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.login_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.login_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_count_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.multiget_slice_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.remove_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.remove_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.set_keyspace_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_column_family_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_add_keyspace_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_column_family_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_drop_keyspace_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_column_family_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.system_update_keyspace_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_args
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.truncate_result
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.CfDef
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Column
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.ColumnDef
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.ColumnOrSuperColumn
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.ColumnParent
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.ColumnPath
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Deletion
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.IndexClause
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.IndexExpression
 
write(TProtocol) - Method in exception org.apache.cassandra.thrift.InvalidRequestException
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.KeyCount
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.KeyRange
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.KeySlice
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.KsDef
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.Mutation
 
write(TProtocol) - Method in exception org.apache.cassandra.thrift.NotFoundException
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.SlicePredicate
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.SliceRange
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.SuperColumn
 
write(TProtocol) - Method in exception org.apache.cassandra.thrift.TimedOutException
 
write(TProtocol) - Method in class org.apache.cassandra.thrift.TokenRange
 
write(TProtocol) - Method in exception org.apache.cassandra.thrift.UnavailableException
 
write(ByteBuffer, DataOutput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.batch_mutate_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_cluster_name_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_keyspace_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_keyspaces_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_partitioner_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_ring_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_schema_versions_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_snitch_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_splits_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.describe_version_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_count_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_indexed_slices_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_range_slices_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.get_slice_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.insert_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.login_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.multiget_count_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.multiget_slice_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.remove_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.set_keyspace_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_add_column_family_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_add_keyspace_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_drop_column_family_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_drop_keyspace_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_update_column_family_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.system_update_keyspace_call
 
write_args(TProtocol) - Method in class org.apache.cassandra.thrift.Cassandra.AsyncClient.truncate_call
 
writeBinary(ByteBuffer) - Method in class org.apache.cassandra.thrift.TBinaryProtocol
 
writeEndpoints - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
writeHeader() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
WriteResponse - Class in org.apache.cassandra.db
 
WriteResponse(String, ByteBuffer, boolean) - Constructor for class org.apache.cassandra.db.WriteResponse
 
WriteResponse.WriteResponseSerializer - Class in org.apache.cassandra.db
 
WriteResponse.WriteResponseSerializer() - Constructor for class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
 
WriteResponseHandler - Class in org.apache.cassandra.service
Handles blocking writes for ONE, ANY, QUORUM, and ALL consistency levels.
WriteResponseHandler(Collection<InetAddress>, Multimap<InetAddress, InetAddress>, ConsistencyLevel, String) - Constructor for class org.apache.cassandra.service.WriteResponseHandler
 
WriteResponseHandler(InetAddress) - Constructor for class org.apache.cassandra.service.WriteResponseHandler
 
writeWithLength(ByteBuffer, DataOutput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
writeWithShortLength(ByteBuffer, DataOutput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 

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
 
xor(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
this = this XOR other
xorCount(OpenBitSet, OpenBitSet) - Static method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the popcount or cardinality of the exclusive-or of the two sets.

Z

ZERO - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 

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

Copyright © 2011 The Apache Software Foundation