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

A

A - Static variable in class org.apache.cassandra.cql.CqlLexer
 
A - Static variable in class org.apache.cassandra.cql.CqlParser
 
a - Variable in class org.apache.cassandra.cql.Operation
 
A - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
A - Static variable in class org.apache.cassandra.cql3.CqlParser
 
abort() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
After failure, attempt to close the index writer and data file before deleting all temp components for the sstable
abortTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
 
abortTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
AbstractBounds<T extends RingPosition> - Class in org.apache.cassandra.dht
 
AbstractBounds(T, T, IPartitioner) - Constructor for class org.apache.cassandra.dht.AbstractBounds
 
AbstractBounds.AbstractBoundsSerializer - Class in org.apache.cassandra.dht
 
AbstractBounds.AbstractBoundsSerializer() - Constructor for class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
 
AbstractByteOrderedPartitioner - Class in org.apache.cassandra.dht
 
AbstractByteOrderedPartitioner() - Constructor for class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
AbstractCassandraDaemon - Class in org.apache.cassandra.service
The CassandraDaemon is an abstraction for a Cassandra daemon service, which defines not only a way to activate and deactivate it, but also hooks into its lifecycle methods (see AbstractCassandraDaemon.setup(), AbstractCassandraDaemon.start(), AbstractCassandraDaemon.stop() and AbstractCassandraDaemon.setup()).
AbstractCassandraDaemon() - Constructor for class org.apache.cassandra.service.AbstractCassandraDaemon
 
AbstractCassandraDaemon.CleaningThreadPool - Class in org.apache.cassandra.service
A subclass of Java's ThreadPoolExecutor which implements Jetty's ThreadPool interface (for integration with Avro), and performs ClientState cleanup.
AbstractCassandraDaemon.CleaningThreadPool(ThreadLocal<ClientState>, int, int) - Constructor for class org.apache.cassandra.service.AbstractCassandraDaemon.CleaningThreadPool
 
AbstractColumnContainer - Class in org.apache.cassandra.db
 
AbstractColumnContainer(ISortedColumns) - Constructor for class org.apache.cassandra.db.AbstractColumnContainer
 
AbstractColumnIterator - Class in org.apache.cassandra.db.filter
 
AbstractColumnIterator() - Constructor for class org.apache.cassandra.db.filter.AbstractColumnIterator
 
AbstractCommitLogExecutorService - Class in org.apache.cassandra.db.commitlog
 
AbstractCommitLogExecutorService() - Constructor for class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
AbstractCommutativeType - Class in org.apache.cassandra.db.marshal
 
AbstractCommutativeType() - Constructor for class org.apache.cassandra.db.marshal.AbstractCommutativeType
 
AbstractCompactedRow - Class in org.apache.cassandra.db.compaction
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.db.compaction.AbstractCompactedRow
 
AbstractCompactionIterable - Class in org.apache.cassandra.db.compaction
 
AbstractCompactionIterable(CompactionController, OperationType, List<ICompactionScanner>) - Constructor for class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
AbstractCompactionStrategy - Class in org.apache.cassandra.db.compaction
Pluggable compaction strategy determines how SSTables get merged.
AbstractCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
AbstractCompactionTask - Class in org.apache.cassandra.db.compaction
 
AbstractCompactionTask(ColumnFamilyStore, Collection<SSTableReader>) - Constructor for class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
AbstractCompositeType - Class in org.apache.cassandra.db.marshal
A class avoiding class duplication between CompositeType and DynamicCompositeType.
AbstractCompositeType() - Constructor for class org.apache.cassandra.db.marshal.AbstractCompositeType
 
AbstractCompositeType.CompositeComponent - Class in org.apache.cassandra.db.marshal
 
AbstractCompositeType.CompositeComponent(AbstractType, ByteBuffer) - Constructor for class org.apache.cassandra.db.marshal.AbstractCompositeType.CompositeComponent
 
AbstractCompositeType.ParsedComparator - Interface in org.apache.cassandra.db.marshal
 
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
 
AbstractJdbcType<T> - Class in org.apache.cassandra.cql.jdbc
 
AbstractJdbcType() - Constructor for class org.apache.cassandra.cql.jdbc.AbstractJdbcType
 
AbstractJdbcUUID - Class in org.apache.cassandra.cql.jdbc
 
AbstractJdbcUUID() - Constructor for class org.apache.cassandra.cql.jdbc.AbstractJdbcUUID
 
AbstractModification - Class in org.apache.cassandra.cql
 
AbstractModification(String, String, String, Attributes) - Constructor for class org.apache.cassandra.cql.AbstractModification
 
AbstractModification(String, String, String, ConsistencyLevel, Long, int) - Constructor for class org.apache.cassandra.cql.AbstractModification
 
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
 
AbstractPartitioner<T extends Token> - Class in org.apache.cassandra.dht
 
AbstractPartitioner() - Constructor for class org.apache.cassandra.dht.AbstractPartitioner
 
AbstractReplicationStrategy - Class in org.apache.cassandra.locator
A abstract parent for all replication strategies.
AbstractRowResolver - Class in org.apache.cassandra.service
 
AbstractRowResolver(ByteBuffer, String) - Constructor for class org.apache.cassandra.service.AbstractRowResolver
 
AbstractSSTableSimpleWriter - Class in org.apache.cassandra.io.sstable
 
AbstractSSTableSimpleWriter(File, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
AbstractStatsDeque - Class in org.apache.cassandra.utils
 
AbstractStatsDeque() - Constructor for class org.apache.cassandra.utils.AbstractStatsDeque
 
AbstractStreamSession - Class in org.apache.cassandra.streaming
 
AbstractStreamSession(String, Pair<InetAddress, Long>, IStreamCallback) - Constructor for class org.apache.cassandra.streaming.AbstractStreamSession
 
AbstractThreadUnsafeSortedColumns - Class in org.apache.cassandra.db
 
AbstractThreadUnsafeSortedColumns() - Constructor for class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
 
AbstractType<T> - Class in org.apache.cassandra.db.marshal
Specifies a Comparator for a specific type of ByteBuffer.
AbstractType() - Constructor for class org.apache.cassandra.db.marshal.AbstractType
 
AbstractWriteResponseHandler - Class in org.apache.cassandra.service
 
AbstractWriteResponseHandler(Collection<InetAddress>, ConsistencyLevel, Runnable) - Constructor for class org.apache.cassandra.service.AbstractWriteResponseHandler
 
acceptImpl() - Method in class org.apache.cassandra.thrift.TCustomNonblockingServerSocket
 
acceptImpl() - Method in class org.apache.cassandra.thrift.TCustomServerSocket
 
ackCon - Variable in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
acquireReference() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
acquireReferences(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
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.
activeSegment - Variable in class org.apache.cassandra.db.commitlog.CommitLog
 
activeSegments() - Method in class org.apache.cassandra.db.commitlog.CommitLog
Used by tests.
adaptor - Variable in class org.apache.cassandra.cli.CliParser
 
add(ByteBuffer) - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
Add a new ByteBuffer as the next component for this name.
add(Term, Relation.Type, List<ByteBuffer>) - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
Add a new Term as the next component for this name.
add(RowMutation) - Method in class org.apache.cassandra.db.commitlog.CommitLog
Add a RowMutation to the commit log.
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(SSTableReader) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
add(Term, Relation.Type, List<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
add(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
add(ColumnFamily) - Method in class org.apache.cassandra.db.RowMutation
 
add(QueryPath, ByteBuffer, long, int) - Method in class org.apache.cassandra.db.RowMutation
 
add(QueryPath, ByteBuffer, long) - Method in class org.apache.cassandra.db.RowMutation
 
add(IMessageSink) - Static method in class org.apache.cassandra.net.sink.SinkManager
 
add(R) - Method in class org.apache.cassandra.service.AntiEntropyService.RequestCoordinator
 
add(AbstractCompactedRow) - Method in class org.apache.cassandra.service.AntiEntropyService.Validator
Called (in order) for every row present in the CF.
add(ByteBuffer, ColumnParent, CounterColumn, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
add(double) - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
add(ByteBuffer) - Method in class org.apache.cassandra.utils.BloomFilter
 
add(double) - Method in class org.apache.cassandra.utils.BoundedStatsDeque
 
add(long) - Method in class org.apache.cassandra.utils.EstimatedHistogram
Increments the count of the bucket closest to n, rounding UP.
add(ByteBuffer) - Method in class org.apache.cassandra.utils.Filter
 
add(ByteBuffer) - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
addAll(AbstractColumnContainer, Allocator, Function<IColumn, IColumn>) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
addAll(AbstractColumnContainer, Allocator) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
addAll(ISortedColumns, Allocator, Function<IColumn, IColumn>) - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
 
addAll(ISortedColumns, Allocator, Function<IColumn, IColumn>) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
addAll(ISortedColumns, Allocator, Function<IColumn, IColumn>) - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
addAll(IMutation) - Method in class org.apache.cassandra.db.CounterMutation
 
addAll(IMutation) - Method in interface org.apache.cassandra.db.IMutation
 
addAll(ISortedColumns, Allocator, Function<IColumn, IColumn>) - Method in interface org.apache.cassandra.db.ISortedColumns
Adds the columns without necessarily computing the size delta
addAll(IMutation) - Method in class org.apache.cassandra.db.RowMutation
 
addAll(ISortedColumns, Allocator, Function<IColumn, IColumn>) - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
We need to go through each column in the column container and resolve it before adding
addAll(ISortedColumns, Allocator, Function<IColumn, IColumn>) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
We need to go through each column in the column container and resolve it before adding
addAll(Iterator<MerkleTree.RowHash>) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
addAllWithSCCopy(ColumnFamily, Allocator) - Method in class org.apache.cassandra.db.ColumnFamily
Same as addAll() but do a cloneMe of SuperColumn if necessary to avoid keeping references to the structure (see #3957).
addAllWithSizeDelta(AbstractColumnContainer, Allocator, Function<IColumn, IColumn>) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
addAllWithSizeDelta(ISortedColumns, Allocator, Function<IColumn, IColumn>) - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
 
addAllWithSizeDelta(ISortedColumns, Allocator, Function<IColumn, IColumn>) - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
addAllWithSizeDelta(ISortedColumns, Allocator, Function<IColumn, IColumn>) - Method in interface org.apache.cassandra.db.ISortedColumns
Adds all the columns of a given column map to this column map.
addAllWithSizeDelta(ISortedColumns, Allocator, Function<IColumn, IColumn>) - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
addAncestor(int) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
addBootstrapToken(Token, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
addCallback(IMessageCallback, Message, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
addCallback(IMessageCallback, Message, InetAddress, long) - Method in class org.apache.cassandra.net.MessagingService
 
addColumn(Term, String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
Map a column name to a validator for its value
addColumn(IColumn) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
addColumn(IColumn, Allocator) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
addColumn(IColumn, Allocator) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
AddColumn throws an exception if the column added does not sort after the last column in the map.
addColumn(IColumn, Allocator) - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
addColumn(IColumn) - Method in class org.apache.cassandra.db.Column
 
addColumn(IColumn, Allocator) - 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 interface org.apache.cassandra.db.IColumn
 
addColumn(IColumn, Allocator) - Method in interface org.apache.cassandra.db.IColumn
 
addColumn(IColumn) - Method in interface org.apache.cassandra.db.IColumnContainer
 
addColumn(IColumn, Allocator) - Method in interface org.apache.cassandra.db.IColumnContainer
 
addColumn(IColumn, Allocator) - Method in interface org.apache.cassandra.db.ISortedColumns
Adds a column to this column map.
addColumn(IColumn, Allocator) - Method in class org.apache.cassandra.db.SuperColumn
 
addColumn(IColumn, Allocator) - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
addColumn(IColumn, Allocator) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
addColumn(ByteBuffer, ByteBuffer, long) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
Insert a new "regular" column to the current row (and super column if applicable).
addColumnAlias(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement.RawStatement
 
addColumnCount(long) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
addColumnDefinition(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
 
addColumnFamily() - Method in class org.apache.cassandra.cli.CliParser
 
AddColumnFamily - Class in org.apache.cassandra.db.migration.avro
 
AddColumnFamily() - Constructor for class org.apache.cassandra.db.migration.avro.AddColumnFamily
 
addColumnOrSuperColumn(String, ColumnOrSuperColumn) - Method in class org.apache.cassandra.db.RowMutation
 
addCompressionRatio(long, long) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
Ratio is compressed/uncompressed and it is if you have 1.x then compression isn't helping
addCounter(QueryPath, long) - Method in class org.apache.cassandra.db.ColumnFamily
 
addCounter(QueryPath, long) - Method in class org.apache.cassandra.db.RowMutation
 
addCounterColumn(ByteBuffer, long) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
Insert a new counter column to the current row (and super column if applicable).
addDefaultIndexNames() - Method in class org.apache.cassandra.config.CFMetaData
Convert a null index_name to appropriate default name according to column status
addDefinition(ColumnIdentifier, String) - Method in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement.RawStatement
 
added - Variable in class org.apache.cassandra.notifications.SSTableAddedNotification
 
added - Variable in class org.apache.cassandra.notifications.SSTableListChangedNotification
 
addEntry(DecoratedKey<?>, long) - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
addExpireTimeForEndpoint(InetAddress, long) - Method in class org.apache.cassandra.gms.Gossiper
 
addExpireTimeIfFound(InetAddress, long) - Method in class org.apache.cassandra.service.StorageService
 
addExpiringColumn(ByteBuffer, ByteBuffer, long, int, long) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
Insert a new expiring column to the current row (and super column if applicable).
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
 
addIndexedColumn(ColumnDefinition) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
Adds and builds a index for a column
addInitialSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
 
addInValue(Term) - Method in class org.apache.cassandra.cql3.Relation
 
addKeyspace() - Method in class org.apache.cassandra.cli.CliParser
 
AddKeyspace - Class in org.apache.cassandra.db.migration.avro
 
AddKeyspace() - Constructor for class org.apache.cassandra.db.migration.avro.AddKeyspace
 
addLatency(InetAddress, double) - Method in class org.apache.cassandra.net.MessagingService
 
addLeavingEndpoint(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
addLocalApplicationState(ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.Gossiper
 
addMicro(long) - Method in class org.apache.cassandra.utils.LatencyTracker
 
addMovingEndpoint(Token, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
Add a new moving endpoint
addNano(long) - Method in class org.apache.cassandra.utils.LatencyTracker
takes nanoseconds
addOption(String, String, String, String) - Method in class org.apache.cassandra.tools.BulkLoader.CmdLineOptions
Add option with argument and argument name
addOption(String, String, String) - Method in class org.apache.cassandra.tools.BulkLoader.CmdLineOptions
Add option without argument
addOrGet(String) - Method in class org.apache.cassandra.db.RowMutation
 
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.CompressedSegmentedFile.Builder
Adds a position that would be a safe place for a segment boundary in the file.
addPotentialBoundary(long) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
Adds a position that would be a safe place for a segment boundary in the file.
addProperty(String, String) - Method in class org.apache.cassandra.cql.CFPropDefs
Map a keyword to the corresponding value
addProperty(String, String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
Map a keyword to the corresponding value
addProperty(String, String) - Method in class org.apache.cassandra.cql3.CFPropDefs
 
addProperty(String, String) - Method in class org.apache.cassandra.cql3.KSPropDefs
 
addProperty(String, String) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
 
addProperty(String, String) - Method in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement.RawStatement
 
addRangeForEndpoint(Range<Token>, InetAddress) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
 
addRanges(String, Collection<Range<Token>>) - Method in class org.apache.cassandra.dht.RangeStreamer
 
addRecognitionError(String) - Method in class org.apache.cassandra.cql3.CqlParser
 
address - Variable in class org.apache.cassandra.dht.BootStrapper
 
addRowSize(long) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
addSavedEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
Add an endpoint we knew about previously, but whose state is unknown
addSeed(InetAddress) - Method in class org.apache.cassandra.locator.SimpleSeedProvider
 
addSourceFilter(RangeStreamer.ISourceFilter) - Method in class org.apache.cassandra.dht.RangeStreamer
 
addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
addSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
addSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
 
addSystemTable(KSMetaData) - Method in class org.apache.cassandra.config.Schema
Add a new system table
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
 
addToTotalBytesCompacted(long) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
 
addTruePositive() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
advance() - Method in class org.apache.cassandra.utils.MergeIterator.Candidate
 
advertiseRemoving(InetAddress, Token, Token) - Method in class org.apache.cassandra.gms.Gossiper
This method will begin removing an existing endpoint from the cluster by spoofing its state This should never be called unless this coordinator has had 'removetoken' invoked
advertiseTokenRemoved(InetAddress, Token) - Method in class org.apache.cassandra.gms.Gossiper
Handles switching the endpoint's state from REMOVING_TOKEN to REMOVED_TOKEN This should only be called after advertiseRemoving
afterExecute(Runnable, Throwable) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
 
afterExecute(Runnable, Throwable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
afterExecute(Runnable, Throwable) - Method in class org.apache.cassandra.service.AbstractCassandraDaemon.CleaningThreadPool
 
algorithm - Variable in class org.apache.cassandra.config.EncryptionOptions
 
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
 
allocate(int, int) - Static method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
allocate(int, int, Allocator) - Static method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
allocate(long) - Static method in class org.apache.cassandra.io.util.Memory
 
allocate(int) - Method in class org.apache.cassandra.utils.Allocator
 
allocate(int) - Method in class org.apache.cassandra.utils.HeapAllocator
 
allocate(int) - Method in class org.apache.cassandra.utils.SlabAllocator
 
allocator - Variable in class org.apache.cassandra.db.commitlog.CommitLog
 
Allocator - Class in org.apache.cassandra.utils
 
Allocator() - Constructor for class org.apache.cassandra.utils.Allocator
 
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
 
allowedKeywords - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
allowedKeywords - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
allUserDefined() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
Alnum - Static variable in class org.apache.cassandra.cli.CliLexer
 
Alnum - Static variable in class org.apache.cassandra.cli.CliParser
 
alterKeyspaceStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
AlterKeyspaceStatement - Class in org.apache.cassandra.cql3.statements
 
AlterKeyspaceStatement(String, KSPropDefs) - Constructor for class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
 
AlterTableStatement - Class in org.apache.cassandra.cql
 
AlterTableStatement(String, AlterTableStatement.OperationType, String) - Constructor for class org.apache.cassandra.cql.AlterTableStatement
 
AlterTableStatement(String, AlterTableStatement.OperationType, String, String) - Constructor for class org.apache.cassandra.cql.AlterTableStatement
 
AlterTableStatement(String, AlterTableStatement.OperationType, String, String, Map<String, String>) - Constructor for class org.apache.cassandra.cql.AlterTableStatement
 
alterTableStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
alterTableStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
AlterTableStatement - Class in org.apache.cassandra.cql3.statements
 
AlterTableStatement(CFName, AlterTableStatement.Type, ColumnIdentifier, String, CFPropDefs) - Constructor for class org.apache.cassandra.cql3.statements.AlterTableStatement
 
AlterTableStatement.OperationType - Enum in org.apache.cassandra.cql
 
AlterTableStatement.Type - Enum in org.apache.cassandra.cql3.statements
 
alwaysMatchingBloomFilter() - Static method in class org.apache.cassandra.utils.LegacyBloomFilter
 
ancestors - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
 
ancestors - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
AND - Static variable in class org.apache.cassandra.cli.CliLexer
 
AND - Static variable in class org.apache.cassandra.cli.CliParser
 
and(Term) - Method in class org.apache.cassandra.cql.SelectExpression
Add an additional column name to a SelectExpression.
and(Relation) - Method in class org.apache.cassandra.cql.WhereClause
Add an additional relation to this WHERE clause.
and(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
andKeyEquals(Term) - Method in class org.apache.cassandra.cql.WhereClause
The same as KEY = to avoid using Relation object
announceColumnFamilyDrop(String, String) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceColumnFamilyUpdate(CFMetaData) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceKeyspaceDrop(String) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceKeyspaceUpdate(KSMetaData) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceMigration() - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
 
announceMigration() - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
 
announceMigration() - Method in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement
 
announceMigration() - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
 
announceMigration() - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
 
announceMigration() - Method in class org.apache.cassandra.cql3.statements.DropColumnFamilyStatement
 
announceMigration() - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
 
announceMigration() - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
 
announceMigration() - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
 
announceNewColumnFamily(CFMetaData) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceNewKeyspace(KSMetaData) - Static method in class org.apache.cassandra.service.MigrationManager
 
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.CFPair - Class in org.apache.cassandra.service
A tuple of table and cf.
AntiEntropyService.CFPair(String, String) - Constructor for class org.apache.cassandra.service.AntiEntropyService.CFPair
 
AntiEntropyService.RepairFuture - Class in org.apache.cassandra.service
 
AntiEntropyService.RequestCoordinator<R> - Class in org.apache.cassandra.service
 
AntiEntropyService.RequestCoordinator(boolean) - Constructor for class org.apache.cassandra.service.AntiEntropyService.RequestCoordinator
 
AntiEntropyService.TreeRequest - Class in org.apache.cassandra.service
A tuple of table, cf, address and range that represents a location we have an outstanding TreeRequest for.
AntiEntropyService.TreeRequest(String, InetAddress, Range<Token>, 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.
AntiEntropyService.Validator(AntiEntropyService.TreeRequest) - Constructor for class org.apache.cassandra.service.AntiEntropyService.Validator
 
API_VERSION - Static variable in class org.apache.cassandra.cli.CliLexer
 
API_VERSION - Static variable in class org.apache.cassandra.cli.CliParser
 
append(AbstractCompactedRow) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
append(DecoratedKey<?>, ColumnFamily) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
append(DecoratedKey<?>, ByteBuffer) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
appendFromStream(DecoratedKey<?>, CFMetaData, long, DataInput) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
ApplicationState - Enum in org.apache.cassandra.gms
 
apply(CFMetaData) - Method in class org.apache.cassandra.config.CFMetaData
Updates CFMetaData in-place to match cf_def *Note*: This method left public only for DefsTest, don't use directly!
apply(ColumnDefinition, AbstractType<?>) - Method in class org.apache.cassandra.config.ColumnDefinition
 
apply(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Insert/Update the column family for this key.
apply() - Method in class org.apache.cassandra.db.CounterMutation
 
apply() - Method in interface org.apache.cassandra.db.IMutation
 
apply() - Method in class org.apache.cassandra.db.RowMutation
 
apply(RowMutation, boolean) - Method in class org.apache.cassandra.db.Table
 
apply(RowMutation, boolean, boolean) - Method in class org.apache.cassandra.db.Table
This method adds the row to the Commit Log associated with this table.
apply(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader.Operator
 
apply(IMutation, Collection<InetAddress>, IWriteResponseHandler, String, ConsistencyLevel) - Method in interface org.apache.cassandra.service.StorageProxy.WritePerformer
 
applyCounterMutationOnCoordinator(CounterMutation, String) - Static method in class org.apache.cassandra.service.StorageProxy
 
applyCounterMutationOnLeader(CounterMutation, String, Runnable) - Static method in class org.apache.cassandra.service.StorageProxy
 
applyImplicitDefaults(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
applies implicit defaults to cf definition.
applyIndexUpdates(ByteBuffer, ColumnFamily, SortedSet<ByteBuffer>, ColumnFamily) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
Removes obsolete index entries and creates new ones for the given row key and mutated columns.
applyIndexUpdates(ByteBuffer, ColumnFamily, SortedSet<ByteBuffer>, ColumnFamily) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
Removes obsolete index entries and creates new ones for the given row key and mutated columns.
applyPropertiesTo(CFMetaData) - Method in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement
 
applyPropertiesToCFMetadata(CFMetaData, CFPropDefs) - Static method in class org.apache.cassandra.cql.AlterTableStatement
 
applyToCFMetadata(CFMetaData) - Method in class org.apache.cassandra.cql3.CFPropDefs
 
applyUnsafe() - Method in class org.apache.cassandra.db.RowMutation
 
archivePending - Variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
archiver - Variable in class org.apache.cassandra.db.commitlog.CommitLog
 
ARRAY - Static variable in class org.apache.cassandra.cli.CliLexer
 
ARRAY - Static variable in class org.apache.cassandra.cli.CliParser
 
ArrayBackedSortedColumns - Class in org.apache.cassandra.db
A ISortedColumns backed by an ArrayList.
arrayConstruct() - Method in class org.apache.cassandra.cli.CliParser
 
arrayCopy(ByteBuffer, int, byte[], int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
arrayCopy(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Transfer bytes from one ByteBuffer to another.
ascii(String, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
AsciiType - Class in org.apache.cassandra.db.marshal
 
asKSMetadata(String) - Method in class org.apache.cassandra.cql3.KSPropDefs
 
asKSMetadataUpdate(KSMetaData) - Method in class org.apache.cassandra.cql3.KSPropDefs
 
asList() - Method in class org.apache.cassandra.dht.Range
 
asMap() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
ASSUME - Static variable in class org.apache.cassandra.cli.CliLexer
 
ASSUME - Static variable in class org.apache.cassandra.cli.CliParser
 
assumeStatement() - Method in class org.apache.cassandra.cli.CliParser
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.DatacenterReadCallback
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
assureSufficientLiveNodes() - Method in interface org.apache.cassandra.service.IWriteResponseHandler
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.ReadCallback
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.WriteResponseHandler
 
asTemporary(boolean) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
asThriftOptions() - Method in class org.apache.cassandra.io.compress.CompressionParameters
 
AsyncRepairCallback - Class in org.apache.cassandra.service
 
AsyncRepairCallback(RowRepairResolver, int) - Constructor for class org.apache.cassandra.service.AsyncRepairCallback
 
AtomicSortedColumns - Class in org.apache.cassandra.db
A thread-safe and atomic ISortedColumns implementation.
attr_name() - Method in class org.apache.cassandra.cli.CliParser
 
Attributes - Class in org.apache.cassandra.cql
Class to contain attributes for statements
Attributes() - Constructor for class org.apache.cassandra.cql.Attributes
 
Attributes(ConsistencyLevel, Long, int) - Constructor for class org.apache.cassandra.cql.Attributes
 
Attributes - Class in org.apache.cassandra.cql3
Utility class for the Parser to gather attributes for modification statements.
Attributes() - Constructor for class org.apache.cassandra.cql3.Attributes
 
attrValue() - Method in class org.apache.cassandra.cli.CliParser
 
attrValueDouble() - Method in class org.apache.cassandra.cli.CliParser
 
attrValueInt() - Method in class org.apache.cassandra.cli.CliParser
 
attrValueString() - Method in class org.apache.cassandra.cli.CliParser
 
authenticate(Map<? extends CharSequence, ? extends CharSequence>) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
authenticate(Map<? extends CharSequence, ? extends CharSequence>) - Method in interface org.apache.cassandra.auth.IAuthenticator
 
AuthenticatedUser - Class in org.apache.cassandra.auth
An authenticated user and her groups.
AuthenticatedUser(String) - Constructor for class org.apache.cassandra.auth.AuthenticatedUser
 
AuthenticatedUser(String, Set<String>) - Constructor for class org.apache.cassandra.auth.AuthenticatedUser
 
authenticator - Variable in class org.apache.cassandra.config.Config
 
authority - Variable in class org.apache.cassandra.config.Config
 
authorize(AuthenticatedUser, List<Object>) - Method in class org.apache.cassandra.auth.AllowAllAuthority
 
authorize(AuthenticatedUser, List<Object>) - Method in interface org.apache.cassandra.auth.IAuthority
 
auto_bootstrap - Variable in class org.apache.cassandra.config.Config
 
auto_snapshot - Variable in class org.apache.cassandra.config.Config
 
AutoSavingCache<K extends CacheKey,V> - Class in org.apache.cassandra.cache
 
AutoSavingCache(ICache<K, V>, CacheService.CacheType) - Constructor for class org.apache.cassandra.cache.AutoSavingCache
 
AutoSavingCache.Writer - Class in org.apache.cassandra.cache
 
AutoSavingCache.Writer(int) - Constructor for class org.apache.cassandra.cache.AutoSavingCache.Writer
 
available() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
Returns the number of bytes that are available before this stream will block.
AVERAGE_KEY_CACHE_ROW_SIZE - Static variable in class org.apache.cassandra.service.CacheService
 
aVeryLongTime - Static variable in class org.apache.cassandra.gms.Gossiper
 
Avro - Class in org.apache.cassandra.config
methods to load schema definitions from old-style Avro serialization
Avro() - Constructor for class org.apache.cassandra.config.Avro
 
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.db.commitlog.AbstractCommitLogExecutorService
 
awaitTermination() - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
Returns when the allocator thread terminates.
awaitTermination() - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
Blocks until shutdown is complete.
awaitUninterruptibly() - Method in class org.apache.cassandra.utils.SimpleCondition
 
awaitUntil(Date) - Method in class org.apache.cassandra.utils.SimpleCondition
 

B

B - Static variable in class org.apache.cassandra.cql.CqlLexer
 
B - Static variable in class org.apache.cassandra.cql.CqlParser
 
b - Variable in class org.apache.cassandra.cql.Operation
 
B - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
B - Static variable in class org.apache.cassandra.cql3.CqlParser
 
BACKUPS_SUBDIR - Static variable in class org.apache.cassandra.db.Directories
 
banner - Variable in class org.apache.cassandra.cli.CliUserHelp
 
baseCfs - Variable in class org.apache.cassandra.db.index.SecondaryIndex
Base CF that has many indexes
baseCfs - Variable in class org.apache.cassandra.db.index.SecondaryIndexManager
The underlying column family containing the source data for these indexes
baseCfs - Variable in class org.apache.cassandra.db.index.SecondaryIndexSearcher
 
baseType - Variable in class org.apache.cassandra.db.marshal.ReversedType
 
batch - Variable in class org.apache.cassandra.cli.CliSessionState
 
batch_mutate(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
BATCH_THRESHOLD - Static variable in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
 
batchOpen(Set<Map.Entry<Descriptor, Set<Component>>>, Set<DecoratedKey>, DataTracker, CFMetaData, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
BatchStatement - Class in org.apache.cassandra.cql
A BATCH statement parsed from a CQL query.
BatchStatement(List<AbstractModification>, Attributes) - Constructor for class org.apache.cassandra.cql.BatchStatement
Creates a new BatchStatement from a list of statements and a Thrift consistency level.
batchStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
batchStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
BatchStatement - Class in org.apache.cassandra.cql3.statements
A BATCH statement parsed from a CQL query.
BatchStatement(List<ModificationStatement>, Attributes) - Constructor for class org.apache.cassandra.cql3.statements.BatchStatement
Creates a new BatchStatement from a list of statements and a Thrift consistency level.
batchStatementObjective() - Method in class org.apache.cassandra.cql.CqlParser
 
batchStatementObjective() - Method in class org.apache.cassandra.cql3.CqlParser
 
begin() - Method in class org.apache.cassandra.streaming.StreamOutSession
 
beginCompaction(CompactionInfo.Holder) - Method in interface org.apache.cassandra.db.compaction.CompactionManager.CompactionExecutorStatsCollector
 
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
 
BigLongArray - Class in org.apache.cassandra.utils
A GC friendly long[].
BigLongArray(int) - Constructor for class org.apache.cassandra.utils.BigLongArray
 
BigLongArray(int, int) - Constructor for class org.apache.cassandra.utils.BigLongArray
 
bindIndex - Variable in class org.apache.cassandra.cql3.Term
 
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
 
blockForWrites() - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
blockingExecutionHandler - Static variable in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
bloom_filter_fp_chance - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
bloomFilter - Variable in class org.apache.cassandra.db.ColumnIndexer.RowHeader
 
BloomFilter - Class in org.apache.cassandra.utils
 
bloomFilterFpChance(Double) - Method in class org.apache.cassandra.config.CFMetaData
 
BloomFilterSerializer - Class in org.apache.cassandra.utils
 
BloomFilterSerializer() - Constructor for class org.apache.cassandra.utils.BloomFilterSerializer
 
BloomFilterTracker - Class in org.apache.cassandra.io.sstable
 
BloomFilterTracker() - Constructor for class org.apache.cassandra.io.sstable.BloomFilterTracker
 
bool(String, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
BooleanType - Class in org.apache.cassandra.db.marshal
 
boolSize - Static variable in class org.apache.cassandra.db.DBConstants
 
bootstrap() - Method in class org.apache.cassandra.dht.BootStrapper
 
bootstrapComplete() - Static method in class org.apache.cassandra.db.SystemTable
 
bootstrapInProgress() - Static method in class org.apache.cassandra.db.SystemTable
 
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
bounded threadsafe deque
BoundedStatsDeque(int) - Constructor for class org.apache.cassandra.utils.BoundedStatsDeque
 
boundNames - Variable in class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
 
Bounds<T extends RingPosition> - Class in org.apache.cassandra.dht
AbstractBounds containing both its endpoints: [left, right].
Bounds(T, T) - Constructor for class org.apache.cassandra.dht.Bounds
 
boundTerms - Variable in class org.apache.cassandra.cql.CQLStatement
 
broadcast_address - Variable in class org.apache.cassandra.config.Config
 
broadcastAddress - Variable in class org.apache.cassandra.streaming.StreamHeader
Address of the sender
buf - Variable in class org.apache.cassandra.io.util.FastByteArrayInputStream
The byte array containing the bytes to stream over.
buf - Variable in class org.apache.cassandra.io.util.FastByteArrayOutputStream
The byte array containing the bytes written.
buffer - Variable in class org.apache.cassandra.io.compress.ICompressor.WrappedArray
 
buffer - Variable in class org.apache.cassandra.io.util.RandomAccessReader
 
buffer - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
bufferCursor() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
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
 
bufferOffset - Variable in class org.apache.cassandra.io.util.RandomAccessReader
 
bufferOffset - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
build() - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
Build the column name.
build() - Method in class org.apache.cassandra.db.index.SecondaryIndexBuilder
 
build() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
buildAsEndOfRange() - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
Build the column name so that the result sorts at the end of the range represented by this (uncomplete) column name.
buildAsEndOfRange() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
buildIndexAsync() - Method in class org.apache.cassandra.db.index.SecondaryIndex
Builds the index using the data in the underlying CF, non blocking
buildIndexBlocking() - Method in class org.apache.cassandra.db.index.SecondaryIndex
Builds the index using the data in the underlying CFS Blocks till it's complete
buildIntervalTree(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.DataTracker
 
bulkLoad(String) - Method in class org.apache.cassandra.service.StorageService
 
bulkLoad(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
BulkLoader - Class in org.apache.cassandra.tools
 
BulkLoader() - Constructor for class org.apache.cassandra.tools.BulkLoader
 
BulkLoader.CmdLineOptions - Class in org.apache.cassandra.tools
 
BulkLoader.CmdLineOptions() - Constructor for class org.apache.cassandra.tools.BulkLoader.CmdLineOptions
 
BulkOutputFormat - Class in org.apache.cassandra.hadoop
 
BulkOutputFormat() - Constructor for class org.apache.cassandra.hadoop.BulkOutputFormat
 
BulkOutputFormat.NullOutputCommitter - Class in org.apache.cassandra.hadoop
 
BulkOutputFormat.NullOutputCommitter() - Constructor for class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
 
BY - Static variable in class org.apache.cassandra.cli.CliLexer
 
BY - Static variable in class org.apache.cassandra.cli.CliParser
 
BYTE_MASK - Static variable in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
ByteBufferUtil - Class in org.apache.cassandra.utils
Utility methods to make ByteBuffers less painful The following should illustrate the different ways byte buffers can be used public void testArrayOffet() { byte[] b = "test_slice_array".getBytes(); ByteBuffer bb = ByteBuffer.allocate(1024); assert bb.position() == 0; assert bb.limit() == 1024; assert bb.capacity() == 1024; bb.put(b); assert bb.position() == b.length; assert bb.remaining() == bb.limit() - bb.position(); ByteBuffer bb2 = bb.slice(); assert bb2.position() == 0; //slice should begin at other buffers current position assert bb2.arrayOffset() == bb.position(); //to match the position in the underlying array one needs to //track arrayOffset assert bb2.limit()+bb2.arrayOffset() == bb.limit(); assert bb2.remaining() == bb.remaining(); } }
ByteBufferUtil() - Constructor for class org.apache.cassandra.utils.ByteBufferUtil
 
ByteOrderedPartitioner - Class in org.apache.cassandra.dht
 
ByteOrderedPartitioner() - Constructor for class org.apache.cassandra.dht.ByteOrderedPartitioner
 
bytes(String) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Encode a String in a ByteBuffer using UTF_8.
bytes(String, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Encode a String in a ByteBuffer using the provided charset.
bytes(int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(long) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(float) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(double) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes() - Method in class org.apache.cassandra.utils.NodeId
 
bytesCompare(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.BytesType
 
bytesOnDisk() - Method in class org.apache.cassandra.io.sstable.SSTable
 
bytesPastMark(FileMark) - Method in interface org.apache.cassandra.io.util.FileDataInput
 
bytesPastMark(FileMark) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
bytesPastMark() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
bytesPastMark(FileMark) - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
bytesRead - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
BytesReadTracker - Class in org.apache.cassandra.utils
This class is to track bytes read from given DataInput
BytesReadTracker(DataInput) - Constructor for class org.apache.cassandra.utils.BytesReadTracker
 
bytesRemaining() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
bytesRemaining() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
bytesRemaining() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
bytesToHex(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytesToHex(byte...) - Static method in class org.apache.cassandra.utils.Hex
 
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
 
bytesUsed() - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
 

C

C - Static variable in class org.apache.cassandra.cql.CqlLexer
 
C - Static variable in class org.apache.cassandra.cql.CqlParser
 
C - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
C - Static variable in class org.apache.cassandra.cql3.CqlParser
 
CACHE_FLUSH_INTERVAL_IN_BYTES - Static variable in class org.apache.cassandra.io.util.RandomAccessReader
 
cacheEndpoint(Token, ArrayList<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
CacheKey - Interface in org.apache.cassandra.cache
 
cacheKey(DecoratedKey, Long) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
CacheService - Class in org.apache.cassandra.service
 
CacheService.CacheType - Enum in org.apache.cassandra.service
 
CacheServiceMBean - Interface in org.apache.cassandra.service
 
cacheType - Variable in class org.apache.cassandra.cache.AutoSavingCache
 
cacheType() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
 
caching(CFMetaData.Caching) - Method in class org.apache.cassandra.config.CFMetaData
 
caching - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
CachingMessageProducer - Class in org.apache.cassandra.net
 
CachingMessageProducer(MessageProducer) - Constructor for class org.apache.cassandra.net.CachingMessageProducer
 
calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
calculate the natural endpoints for the given token
calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.LocalStrategy
 
calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
 
calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.SimpleStrategy
 
calculatePendingRanges(AbstractReplicationStrategy, String) - Static method in class org.apache.cassandra.service.StorageService
 
calculateStreamAndFetchRanges(Collection<Range<Token>>, Collection<Range<Token>>) - Method in class org.apache.cassandra.service.StorageService
Calculate pair of ranges to stream/fetch for given two range collections (current ranges for table and ranges after move to new token)
callback - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
callback - Variable in class org.apache.cassandra.streaming.AbstractStreamSession
 
cancel(boolean) - Method in class org.apache.cassandra.concurrent.CreationTimeAwareFuture
 
cancel() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
cancel() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
 
cancel(boolean) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.LoaderFuture
 
capacity() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
capacity() - Method in interface org.apache.cassandra.cache.ICache
 
capacity() - Method in class org.apache.cassandra.cache.SerializingCache
 
capacity() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the current capacity in bits (1 greater than the index of the last bit)
cardinality() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
CASSANDRA_HADOOP_MAX_KEY_SIZE - Static variable in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
 
CASSANDRA_HADOOP_MAX_KEY_SIZE_DEFAULT - Static variable in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
 
CASSANDRA_HADOOP_MAX_KEY_SIZE_DEFAULT - Static variable in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
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.thrift
 
CassandraServer() - Constructor for class org.apache.cassandra.thrift.CassandraServer
 
CassandraStorage - Class in org.apache.cassandra.hadoop.pig
A LoadStoreFunc for retrieving data from and storing data to Cassandra A row from a standard CF will be returned as nested tuples: (key, ((name1, val1), (name2, val2))).
CassandraStorage() - Constructor for class org.apache.cassandra.hadoop.pig.CassandraStorage
 
CassandraStorage(int) - Constructor for class org.apache.cassandra.hadoop.pig.CassandraStorage
 
cf - Variable in class org.apache.cassandra.db.migration.avro.AddColumnFamily
 
cf - Variable in class org.apache.cassandra.db.Row
 
cf - Variable in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
cf_defs - Variable in class org.apache.cassandra.db.migration.avro.KsDef
 
cfamColumns(CreateColumnFamilyStatement.RawStatement) - Method in class org.apache.cassandra.cql3.CqlParser
 
cfamDefinition(CreateColumnFamilyStatement.RawStatement) - Method in class org.apache.cassandra.cql3.CqlParser
 
cfamOrdering(CreateColumnFamilyStatement.RawStatement) - Method in class org.apache.cassandra.cql3.CqlParser
 
cfamProperty(CreateColumnFamilyStatement.RawStatement) - Method in class org.apache.cassandra.cql3.CqlParser
 
cfDef - Variable in class org.apache.cassandra.cql3.statements.SelectStatement
 
CfDef - Class in org.apache.cassandra.db.migration.avro
 
CfDef() - Constructor for class org.apache.cassandra.db.migration.avro.CfDef
 
CFDefinition - Class in org.apache.cassandra.cql3
Holds metadata on a CF preprocessed for use by CQL queries.
CFDefinition(CFMetaData) - Constructor for class org.apache.cassandra.cql3.CFDefinition
 
CFDefinition.Name - Class in org.apache.cassandra.cql3
 
CFDefinition.Name.Kind - Enum in org.apache.cassandra.cql3
 
cfFromAvro(CfDef) - Static method in class org.apache.cassandra.config.Avro
Deprecated. 
cfId - Variable in class org.apache.cassandra.cache.RowCacheKey
 
cfId - Variable in class org.apache.cassandra.config.CFMetaData
 
cfId - Variable in exception org.apache.cassandra.db.UnknownColumnFamilyException
 
cfm - Variable in class org.apache.cassandra.cql3.CFDefinition
 
CFMetaData - Class in org.apache.cassandra.config
 
CFMetaData(String, String, ColumnFamilyType, AbstractType<?>, AbstractType<?>) - Constructor for class org.apache.cassandra.config.CFMetaData
 
cfMetaData() - Method in class org.apache.cassandra.config.KSMetaData
 
CFMetaData.Caching - Enum in org.apache.cassandra.config
 
cfName - Variable in class org.apache.cassandra.config.CFMetaData
 
CFName - Class in org.apache.cassandra.cql3
 
CFName() - Constructor for class org.apache.cassandra.cql3.CFName
 
cfName - Variable in class org.apache.cassandra.cql3.statements.CFStatement
 
cfname - Variable in class org.apache.cassandra.db.migration.avro.DropColumnFamily
 
cfname - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
cfOrKsName(CFName, boolean) - Method in class org.apache.cassandra.cql3.CqlParser
 
CFPropDefs - Class in org.apache.cassandra.cql
 
CFPropDefs() - Constructor for class org.apache.cassandra.cql.CFPropDefs
 
CFPropDefs - Class in org.apache.cassandra.cql3
 
CFPropDefs() - Constructor for class org.apache.cassandra.cql3.CFPropDefs
 
cfs - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
cfs - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
cfs - Variable in class org.apache.cassandra.db.compaction.CompactionController
 
cfs - Variable in class org.apache.cassandra.db.compaction.Scrubber
 
cfs - Variable in class org.apache.cassandra.db.filter.ExtendedFilter
 
cfs - Variable in class org.apache.cassandra.db.Memtable
 
CFStatement - Class in org.apache.cassandra.cql3.statements
Abstract class for statements that apply on a given column family.
CFStatement(CFName) - Constructor for class org.apache.cassandra.cql3.statements.CFStatement
 
cfstore - Variable in class org.apache.cassandra.db.DataTracker
 
cfType - Variable in class org.apache.cassandra.config.CFMetaData
 
channel - Variable in class org.apache.cassandra.io.util.RandomAccessReader
 
CHAR_MASK - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
CharacterEscapeSequence - Static variable in class org.apache.cassandra.cli.CliLexer
 
CharacterEscapeSequence - Static variable in class org.apache.cassandra.cli.CliParser
 
checkAccess(ClientState) - Method in interface org.apache.cassandra.cql3.CQLStatement
Perform any access verification necessary for the statement.
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement.RawStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropColumnFamilyStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.GrantStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListGrantsStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.RevokeStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.UseStatement
 
checkHealth() - Static method in class org.apache.cassandra.db.SystemTable
One of three things will happen if you try to read the system table: 1.
checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
Deprecated. 
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. 
checkSchema(ResourceSchema) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
CHUNK_LENGTH_KB - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
 
CHUNK_SIZE - Static variable in class org.apache.cassandra.streaming.FileStreamTask
 
chunkFor(long) - Method in class org.apache.cassandra.io.compress.CompressionMetadata
Get a chunk of compressed data (offset, length) corresponding to given position
chunkLength() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
 
chunkLength() - Method in class org.apache.cassandra.io.compress.CompressionParameters
 
chunkOffsetBy(int) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
Get a chunk offset by it's index.
cident() - Method in class org.apache.cassandra.cql3.CqlParser
 
cidentList() - Method in class org.apache.cassandra.cql3.CqlParser
 
cipher_suites - Variable in class org.apache.cassandra.config.EncryptionOptions
 
class_name - Variable in class org.apache.cassandra.config.SeedProviderDef
 
classForName(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
classname - Variable in class org.apache.cassandra.db.migration.avro.Migration
 
clean(MappedByteBuffer) - Static method in class org.apache.cassandra.io.util.FileUtils
 
cleanup() - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile
 
cleanup() - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
 
cleanup() - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile
 
cleanup() - Method in class org.apache.cassandra.io.util.SegmentedFile
Do whatever action is needed to reclaim ressources used by this SegmentedFile.
cleanupJob(JobContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
 
cleanupJob(JobContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
cleanupOnFailure(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
clear() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
clear() - Method in interface org.apache.cassandra.cache.ICache
 
clear() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
clear() - Method in class org.apache.cassandra.cache.SerializingCache
 
clear() - Method in class org.apache.cassandra.config.Schema
Clear all KS/CF metadata and reset version.
clear() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
clear() - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
clear() - Method in class org.apache.cassandra.db.ColumnFamily
 
clear() - Method in interface org.apache.cassandra.db.ISortedColumns
Clear this column map, removing all columns.
clear(String) - Static method in class org.apache.cassandra.db.Table
 
clear(String, Schema) - Static method in class org.apache.cassandra.db.Table
 
clear() - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
clear() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
clear(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
 
clear(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
Clear any existing interval timings for this endpoint
clear() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
clear() - Static method in class org.apache.cassandra.net.sink.SinkManager
 
clear() - Method in class org.apache.cassandra.service.SocketSessionManagementService
 
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(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
clears a bit.
clear(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
clears a bit.
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.
clear_snapshot - Variable in class org.apache.cassandra.db.SnapshotCommand
 
clearAllDelta(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Remove all the delta of a context (i.e, set an empty header).
clearCallbacksUnsafe() - Method in class org.apache.cassandra.net.MessagingService
 
clearEndpointCache() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
clearSnapshot(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
clearSnapshot(String) - Method in class org.apache.cassandra.db.Directories
 
clearSnapshot(String) - Method in class org.apache.cassandra.db.Table
Clear all the snapshots for a given table.
clearSnapshot(String, String...) - Method in class org.apache.cassandra.service.StorageService
Remove the snapshot with the given name from the given tables.
clearSnapshot(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Remove the snapshot with the given name from the given tables.
clearSnapshot(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
Remove all the existing snapshots.
clearTableDefinition(KSMetaData) - Method in class org.apache.cassandra.config.Schema
Remove table definition from system
clearUnsafe() - Method in class org.apache.cassandra.db.ColumnFamilyStore
For testing.
clearUnsafe() - Method in class org.apache.cassandra.locator.TokenMetadata
used by tests
cLevel - Variable in class org.apache.cassandra.cql.AbstractModification
 
cLevel - Variable in class org.apache.cassandra.cql3.Attributes
 
cLevel - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement
 
CLibrary - Class in org.apache.cassandra.utils
 
CliClient - Class in org.apache.cassandra.cli
 
CliClient(CliSessionState, Cassandra.Client) - Constructor for class org.apache.cassandra.cli.CliClient
 
CliClient.ColumnFamilyArgument - Enum in org.apache.cassandra.cli
 
CliClient.Function - Enum in org.apache.cassandra.cli
Available value conversion functions Used by convertValueByFunction(Tree functionCall) method
CliCommandHelp - Class in org.apache.cassandra.cli
 
CliCommandHelp() - Constructor for class org.apache.cassandra.cli.CliCommandHelp
 
CliCompiler - Class in org.apache.cassandra.cli
 
CliCompiler() - Constructor for class org.apache.cassandra.cli.CliCompiler
 
CliCompiler.ANTLRNoCaseStringStream - Class in org.apache.cassandra.cli
 
CliCompiler.ANTLRNoCaseStringStream(String) - Constructor for class org.apache.cassandra.cli.CliCompiler.ANTLRNoCaseStringStream
 
CliCompleter - Class in org.apache.cassandra.cli
 
CliCompleter() - Constructor for class org.apache.cassandra.cli.CliCompleter
 
ClientRequestMetrics - Class in org.apache.cassandra.metrics
 
ClientRequestMetrics() - Constructor for class org.apache.cassandra.metrics.ClientRequestMetrics
 
ClientState - Class in org.apache.cassandra.service
A container for per-client, thread-local state that Avro/Thrift threads must hold.
ClientState() - Constructor for class org.apache.cassandra.service.ClientState
Construct a new, empty ClientState: can be reused after logout() or reset().
clientState - Variable in class org.apache.cassandra.thrift.CassandraServer
 
CliLexer - Class in org.apache.cassandra.cli
 
CliLexer() - Constructor for class org.apache.cassandra.cli.CliLexer
 
CliLexer(CharStream) - Constructor for class org.apache.cassandra.cli.CliLexer
 
CliLexer(CharStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cli.CliLexer
 
CliMain - Class in org.apache.cassandra.cli
Cassandra Command Line Interface (CLI) Main
CliMain() - Constructor for class org.apache.cassandra.cli.CliMain
 
CliOptions - Class in org.apache.cassandra.cli
Used to process, and act upon the arguments passed to the CLI.
CliOptions() - Constructor for class org.apache.cassandra.cli.CliOptions
 
CliParser - Class in org.apache.cassandra.cli
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
CliParser(TokenStream) - Constructor for class org.apache.cassandra.cli.CliParser
 
CliParser(TokenStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cli.CliParser
 
CliParser.addColumnFamily_return - Class in org.apache.cassandra.cli
 
CliParser.addColumnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.addColumnFamily_return
 
CliParser.addKeyspace_return - Class in org.apache.cassandra.cli
 
CliParser.addKeyspace_return() - Constructor for class org.apache.cassandra.cli.CliParser.addKeyspace_return
 
CliParser.arrayConstruct_return - Class in org.apache.cassandra.cli
 
CliParser.arrayConstruct_return() - Constructor for class org.apache.cassandra.cli.CliParser.arrayConstruct_return
 
CliParser.assumeStatement_return - Class in org.apache.cassandra.cli
 
CliParser.assumeStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.assumeStatement_return
 
CliParser.attr_name_return - Class in org.apache.cassandra.cli
 
CliParser.attr_name_return() - Constructor for class org.apache.cassandra.cli.CliParser.attr_name_return
 
CliParser.attrValue_return - Class in org.apache.cassandra.cli
 
CliParser.attrValue_return() - Constructor for class org.apache.cassandra.cli.CliParser.attrValue_return
 
CliParser.attrValueDouble_return - Class in org.apache.cassandra.cli
 
CliParser.attrValueDouble_return() - Constructor for class org.apache.cassandra.cli.CliParser.attrValueDouble_return
 
CliParser.attrValueInt_return - Class in org.apache.cassandra.cli
 
CliParser.attrValueInt_return() - Constructor for class org.apache.cassandra.cli.CliParser.attrValueInt_return
 
CliParser.attrValueString_return - Class in org.apache.cassandra.cli
 
CliParser.attrValueString_return() - Constructor for class org.apache.cassandra.cli.CliParser.attrValueString_return
 
CliParser.columnFamily_return - Class in org.apache.cassandra.cli
 
CliParser.columnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnFamily_return
 
CliParser.columnFamilyExpr_return - Class in org.apache.cassandra.cli
 
CliParser.columnFamilyExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnFamilyExpr_return
 
CliParser.columnLimitExpr_return - Class in org.apache.cassandra.cli
 
CliParser.columnLimitExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnLimitExpr_return
 
CliParser.columnName_return - Class in org.apache.cassandra.cli
 
CliParser.columnName_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnName_return
 
CliParser.columnOrSuperColumn_return - Class in org.apache.cassandra.cli
 
CliParser.columnOrSuperColumn_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnOrSuperColumn_return
 
CliParser.command_return - Class in org.apache.cassandra.cli
 
CliParser.command_return() - Constructor for class org.apache.cassandra.cli.CliParser.command_return
 
CliParser.comparator_return - Class in org.apache.cassandra.cli
 
CliParser.comparator_return() - Constructor for class org.apache.cassandra.cli.CliParser.comparator_return
 
CliParser.connectStatement_return - Class in org.apache.cassandra.cli
 
CliParser.connectStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.connectStatement_return
 
CliParser.consistencyLevelStatement_return - Class in org.apache.cassandra.cli
 
CliParser.consistencyLevelStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.consistencyLevelStatement_return
 
CliParser.countStatement_return - Class in org.apache.cassandra.cli
 
CliParser.countStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.countStatement_return
 
CliParser.delColumnFamily_return - Class in org.apache.cassandra.cli
 
CliParser.delColumnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.delColumnFamily_return
 
CliParser.delKeyspace_return - Class in org.apache.cassandra.cli
 
CliParser.delKeyspace_return() - Constructor for class org.apache.cassandra.cli.CliParser.delKeyspace_return
 
CliParser.delStatement_return - Class in org.apache.cassandra.cli
 
CliParser.delStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.delStatement_return
 
CliParser.describeCluster_return - Class in org.apache.cassandra.cli
 
CliParser.describeCluster_return() - Constructor for class org.apache.cassandra.cli.CliParser.describeCluster_return
 
CliParser.describeTable_return - Class in org.apache.cassandra.cli
 
CliParser.describeTable_return() - Constructor for class org.apache.cassandra.cli.CliParser.describeTable_return
 
CliParser.dropIndex_return - Class in org.apache.cassandra.cli
 
CliParser.dropIndex_return() - Constructor for class org.apache.cassandra.cli.CliParser.dropIndex_return
 
CliParser.entityName_return - Class in org.apache.cassandra.cli
 
CliParser.entityName_return() - Constructor for class org.apache.cassandra.cli.CliParser.entityName_return
 
CliParser.exitStatement_return - Class in org.apache.cassandra.cli
 
CliParser.exitStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.exitStatement_return
 
CliParser.functionArgument_return - Class in org.apache.cassandra.cli
 
CliParser.functionArgument_return() - Constructor for class org.apache.cassandra.cli.CliParser.functionArgument_return
 
CliParser.functionCall_return - Class in org.apache.cassandra.cli
 
CliParser.functionCall_return() - Constructor for class org.apache.cassandra.cli.CliParser.functionCall_return
 
CliParser.getCondition_return - Class in org.apache.cassandra.cli
 
CliParser.getCondition_return() - Constructor for class org.apache.cassandra.cli.CliParser.getCondition_return
 
CliParser.getStatement_return - Class in org.apache.cassandra.cli
 
CliParser.getStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.getStatement_return
 
CliParser.hashConstruct_return - Class in org.apache.cassandra.cli
 
CliParser.hashConstruct_return() - Constructor for class org.apache.cassandra.cli.CliParser.hashConstruct_return
 
CliParser.hashElementPair_return - Class in org.apache.cassandra.cli
 
CliParser.hashElementPair_return() - Constructor for class org.apache.cassandra.cli.CliParser.hashElementPair_return
 
CliParser.helpStatement_return - Class in org.apache.cassandra.cli
 
CliParser.helpStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.helpStatement_return
 
CliParser.host_name_return - Class in org.apache.cassandra.cli
 
CliParser.host_name_return() - Constructor for class org.apache.cassandra.cli.CliParser.host_name_return
 
CliParser.host_return - Class in org.apache.cassandra.cli
 
CliParser.host_return() - Constructor for class org.apache.cassandra.cli.CliParser.host_return
 
CliParser.incrementValue_return - Class in org.apache.cassandra.cli
 
CliParser.incrementValue_return() - Constructor for class org.apache.cassandra.cli.CliParser.incrementValue_return
 
CliParser.incrStatement_return - Class in org.apache.cassandra.cli
 
CliParser.incrStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.incrStatement_return
 
CliParser.ip_address_return - Class in org.apache.cassandra.cli
 
CliParser.ip_address_return() - Constructor for class org.apache.cassandra.cli.CliParser.ip_address_return
 
CliParser.keyRangeExpr_return - Class in org.apache.cassandra.cli
 
CliParser.keyRangeExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.keyRangeExpr_return
 
CliParser.keyspace_return - Class in org.apache.cassandra.cli
 
CliParser.keyspace_return() - Constructor for class org.apache.cassandra.cli.CliParser.keyspace_return
 
CliParser.keyspaceNewName_return - Class in org.apache.cassandra.cli
 
CliParser.keyspaceNewName_return() - Constructor for class org.apache.cassandra.cli.CliParser.keyspaceNewName_return
 
CliParser.keyValuePair_return - Class in org.apache.cassandra.cli
 
CliParser.keyValuePair_return() - Constructor for class org.apache.cassandra.cli.CliParser.keyValuePair_return
 
CliParser.keyValuePairExpr_return - Class in org.apache.cassandra.cli
 
CliParser.keyValuePairExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.keyValuePairExpr_return
 
CliParser.listStatement_return - Class in org.apache.cassandra.cli
 
CliParser.listStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.listStatement_return
 
CliParser.newColumnFamily_return - Class in org.apache.cassandra.cli
 
CliParser.newColumnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.newColumnFamily_return
 
CliParser.operator_return - Class in org.apache.cassandra.cli
 
CliParser.operator_return() - Constructor for class org.apache.cassandra.cli.CliParser.operator_return
 
CliParser.password_return - Class in org.apache.cassandra.cli
 
CliParser.password_return() - Constructor for class org.apache.cassandra.cli.CliParser.password_return
 
CliParser.port_return - Class in org.apache.cassandra.cli
 
CliParser.port_return() - Constructor for class org.apache.cassandra.cli.CliParser.port_return
 
CliParser.replica_placement_strategy_return - Class in org.apache.cassandra.cli
 
CliParser.replica_placement_strategy_return() - Constructor for class org.apache.cassandra.cli.CliParser.replica_placement_strategy_return
 
CliParser.reversedExpr_return - Class in org.apache.cassandra.cli
 
CliParser.reversedExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.reversedExpr_return
 
CliParser.root_return - Class in org.apache.cassandra.cli
 
CliParser.root_return() - Constructor for class org.apache.cassandra.cli.CliParser.root_return
 
CliParser.rowKey_return - Class in org.apache.cassandra.cli
 
CliParser.rowKey_return() - Constructor for class org.apache.cassandra.cli.CliParser.rowKey_return
 
CliParser.rowLimitExpr_return - Class in org.apache.cassandra.cli
 
CliParser.rowLimitExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.rowLimitExpr_return
 
CliParser.rowValue_return - Class in org.apache.cassandra.cli
 
CliParser.rowValue_return() - Constructor for class org.apache.cassandra.cli.CliParser.rowValue_return
 
CliParser.setStatement_return - Class in org.apache.cassandra.cli
 
CliParser.setStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.setStatement_return
 
CliParser.showClusterName_return - Class in org.apache.cassandra.cli
 
CliParser.showClusterName_return() - Constructor for class org.apache.cassandra.cli.CliParser.showClusterName_return
 
CliParser.showKeyspaces_return - Class in org.apache.cassandra.cli
 
CliParser.showKeyspaces_return() - Constructor for class org.apache.cassandra.cli.CliParser.showKeyspaces_return
 
CliParser.showSchema_return - Class in org.apache.cassandra.cli
 
CliParser.showSchema_return() - Constructor for class org.apache.cassandra.cli.CliParser.showSchema_return
 
CliParser.showStatement_return - Class in org.apache.cassandra.cli
 
CliParser.showStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.showStatement_return
 
CliParser.showVersion_return - Class in org.apache.cassandra.cli
 
CliParser.showVersion_return() - Constructor for class org.apache.cassandra.cli.CliParser.showVersion_return
 
CliParser.statement_return - Class in org.apache.cassandra.cli
 
CliParser.statement_return() - Constructor for class org.apache.cassandra.cli.CliParser.statement_return
 
CliParser.truncateStatement_return - Class in org.apache.cassandra.cli
 
CliParser.truncateStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.truncateStatement_return
 
CliParser.typeIdentifier_return - Class in org.apache.cassandra.cli
 
CliParser.typeIdentifier_return() - Constructor for class org.apache.cassandra.cli.CliParser.typeIdentifier_return
 
CliParser.updateColumnFamily_return - Class in org.apache.cassandra.cli
 
CliParser.updateColumnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.updateColumnFamily_return
 
CliParser.updateKeyspace_return - Class in org.apache.cassandra.cli
 
CliParser.updateKeyspace_return() - Constructor for class org.apache.cassandra.cli.CliParser.updateKeyspace_return
 
CliParser.useKeyspace_return - Class in org.apache.cassandra.cli
 
CliParser.useKeyspace_return() - Constructor for class org.apache.cassandra.cli.CliParser.useKeyspace_return
 
CliParser.username_return - Class in org.apache.cassandra.cli
 
CliParser.username_return() - Constructor for class org.apache.cassandra.cli.CliParser.username_return
 
CliParser.value_return - Class in org.apache.cassandra.cli
 
CliParser.value_return() - Constructor for class org.apache.cassandra.cli.CliParser.value_return
 
CliSessionState - Class in org.apache.cassandra.cli
Used to hold the state for the CLI.
CliSessionState() - Constructor for class org.apache.cassandra.cli.CliSessionState
 
CliUserHelp - Class in org.apache.cassandra.cli
 
CliUserHelp() - Constructor for class org.apache.cassandra.cli.CliUserHelp
 
CliUtils - Class in org.apache.cassandra.cli
 
CliUtils() - Constructor for class org.apache.cassandra.cli.CliUtils
 
clone() - Method in class org.apache.cassandra.config.CFMetaData
 
clone() - Method in class org.apache.cassandra.config.ColumnDefinition
 
clone(ByteBuffer) - Method in class org.apache.cassandra.utils.Allocator
Allocate a slice of the given length.
clone(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
cloneAfterAllLeft() - Method in class org.apache.cassandra.locator.TokenMetadata
Create a copy of TokenMetadata with tokenToEndpointMap reflecting situation after all current leave operations have finished.
cloneAfterAllSettled() - Method in class org.apache.cassandra.locator.TokenMetadata
Create a copy of TokenMetadata with tokenToEndpointMap reflecting situation after all current leave and move operations have finished.
cloneMe() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
cloneMe() - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
cloneMe() - Method in class org.apache.cassandra.db.ColumnFamily
 
cloneMe() - Method in interface org.apache.cassandra.db.ISortedColumns
Shallow cloning of the column map.
cloneMe() - Method in class org.apache.cassandra.db.SuperColumn
 
cloneMe() - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
cloneMe() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
cloneMeShallow(ISortedColumns.Factory, boolean) - Method in class org.apache.cassandra.db.ColumnFamily
 
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.
cloneWith(KSMetaData, Iterable<CFMetaData>) - Static method in class org.apache.cassandra.config.KSMetaData
 
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 the segment file.
close() - Method in class org.apache.cassandra.db.compaction.Scrubber
 
close() - Method in class org.apache.cassandra.db.filter.AbstractColumnIterator
 
close() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
close() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
close() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
Close this writer.
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.sstable.SSTableSimpleUnsortedWriter
 
close() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleWriter
 
close() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
Closes this stream and frees resources associated with this stream.
close() - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
Closes this stream.
close(Iterable<? extends Closeable>) - Static method in class org.apache.cassandra.io.util.FileUtils
 
close() - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
close() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
close() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
close(boolean) - Method in class org.apache.cassandra.streaming.AbstractStreamSession
 
close() - Method in class org.apache.cassandra.streaming.FileStreamTask
 
close() - Method in class org.apache.cassandra.thrift.TCustomServerSocket
 
close() - Method in class org.apache.cassandra.thrift.TCustomSocket
Closes the socket.
close() - Method in class org.apache.cassandra.tools.NodeProbe
 
close(int) - Static method in class org.apache.cassandra.utils.CLibrary
 
close() - Method in class org.apache.cassandra.utils.MergeIterator
 
close() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
May be overridden by implementations that require cleaning up after use
CloseableIterator<T> - Interface in org.apache.cassandra.utils
 
closeableIterator(Iterator<T>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
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
 
closeInternal(boolean) - Method in class org.apache.cassandra.streaming.AbstractStreamSession
 
closeInternal(boolean) - Method in class org.apache.cassandra.streaming.StreamInSession
 
closeInternal(boolean) - Method in class org.apache.cassandra.streaming.StreamOutSession
 
closeQuietly(Closeable) - Static method in class org.apache.cassandra.io.util.FileUtils
 
cluster_name - Variable in class org.apache.cassandra.config.Config
 
CMD_TYPE_GET_SLICE - Static variable in class org.apache.cassandra.db.ReadCommand
 
CMD_TYPE_GET_SLICE_BY_NAMES - Static variable in class org.apache.cassandra.db.ReadCommand
 
cmdCon - Variable in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
collateColumns(ColumnFamily, List<? extends CloseableIterator<IColumn>>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
CollatingOrderPreservingPartitioner - Class in org.apache.cassandra.dht
 
CollatingOrderPreservingPartitioner() - Constructor for class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
CollationController - Class in org.apache.cassandra.db
 
CollationController(ColumnFamilyStore, boolean, QueryFilter, int) - Constructor for class org.apache.cassandra.db.CollationController
 
collectReducedColumns(IColumnContainer, Iterator<IColumn>, int) - Method in interface org.apache.cassandra.db.filter.IFilter
collects columns from reducedColumns into returnCF.
collectReducedColumns(IColumnContainer, Iterator<IColumn>, int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
collectReducedColumns(IColumnContainer, Iterator<IColumn>, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
COLUMN - Static variable in class org.apache.cassandra.cli.CliLexer
 
COLUMN - Static variable in class org.apache.cassandra.cli.CliParser
 
Column - Class in org.apache.cassandra.db
Column is immutable, which prevents all kinds of confusion in a multithreaded environment.
Column(ByteBuffer, ByteBuffer) - Constructor for class org.apache.cassandra.db.Column
 
Column(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.Column
 
column(ByteBuffer) - Static method in class org.apache.cassandra.db.filter.QueryPath
 
column_aliases - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
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.db.SnapshotCommand
 
column_index_size_in_kb - Variable in class org.apache.cassandra.config.Config
 
column_metadata - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
column_type - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
columnAliases(List<ByteBuffer>) - Method in class org.apache.cassandra.config.CFMetaData
 
columnComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
columnCount() - Method in class org.apache.cassandra.db.compaction.AbstractCompactedRow
 
columnCount() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
columnCount() - Method in class org.apache.cassandra.db.compaction.PrecompactedRow
 
columnCount() - Method in class org.apache.cassandra.db.EchoedRow
 
ColumnDef - Class in org.apache.cassandra.db.migration.avro
 
ColumnDef() - Constructor for class org.apache.cassandra.db.migration.avro.ColumnDef
 
ColumnDefinition - Class in org.apache.cassandra.config
 
ColumnDefinition(ByteBuffer, AbstractType<?>, IndexType, Map<String, String>, String, Integer) - Constructor for class org.apache.cassandra.config.ColumnDefinition
 
columnDefs - Variable in class org.apache.cassandra.db.index.SecondaryIndex
The column definitions which this index is responsible for
columnFamily() - Method in class org.apache.cassandra.cli.CliParser
 
columnFamily - Variable in class org.apache.cassandra.cql.AbstractModification
 
columnFamily - Variable in class org.apache.cassandra.cql.AlterTableStatement
 
columnFamily() - Method in class org.apache.cassandra.cql3.statements.CFStatement
 
columnFamily() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
ColumnFamily - Class in org.apache.cassandra.db
 
ColumnFamily(CFMetaData, ISortedColumns) - 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
 
columnFamily - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
columnFamilyExpr() - Method in class org.apache.cassandra.cli.CliParser
 
ColumnFamilyInputFormat - Class in org.apache.cassandra.hadoop
Hadoop InputFormat allowing map/reduce against Cassandra rows within one ColumnFamily.
ColumnFamilyInputFormat() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
 
columnFamilyName() - Method in class org.apache.cassandra.cql3.CqlParser
 
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
 
ColumnFamilyRecordReader(int) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
ColumnFamilySerializer - Class in org.apache.cassandra.db
 
ColumnFamilySerializer() - Constructor for class org.apache.cassandra.db.ColumnFamilySerializer
 
ColumnFamilySplit - Class in org.apache.cassandra.hadoop
 
ColumnFamilySplit(String, String, String[]) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
 
ColumnFamilySplit() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
 
ColumnFamilyStore - Class in org.apache.cassandra.db
 
ColumnFamilyStore.AbstractScanIterator - Class in org.apache.cassandra.db
 
ColumnFamilyStore.AbstractScanIterator() - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.AbstractScanIterator
 
ColumnFamilyStore.ViewFragment - Class in org.apache.cassandra.db
 
ColumnFamilyStore.ViewFragment(List<SSTableReader>, Iterable<Memtable>) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
 
ColumnFamilyStoreMBean - Interface in org.apache.cassandra.db
The MBean interface for ColumnFamilyStore
ColumnFamilyType - Enum in org.apache.cassandra.db
column family type enum
columnFromAvro(ColumnDef) - Static method in class org.apache.cassandra.config.Avro
Deprecated. 
ColumnIdentifier - Class in org.apache.cassandra.cql3
Represents an identifer for a CQL column definition.
ColumnIdentifier(String, boolean) - Constructor for class org.apache.cassandra.cql3.ColumnIdentifier
 
ColumnIdentifier(ByteBuffer, AbstractType) - Constructor for class org.apache.cassandra.cql3.ColumnIdentifier
 
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
 
ColumnIndexer.RowHeader - Class in org.apache.cassandra.db
Holds information about serialized index and bloom filter
ColumnIndexer.RowHeader(BloomFilter, List<IndexHelper.IndexInfo>) - Constructor for class org.apache.cassandra.db.ColumnIndexer.RowHeader
 
columnLimitExpr() - Method in class org.apache.cassandra.cli.CliParser
 
columnMetadata(Map<ByteBuffer, ColumnDefinition>) - Method in class org.apache.cassandra.config.CFMetaData
 
columnMetadata(ColumnDefinition...) - Method in class org.apache.cassandra.config.CFMetaData
 
columnName() - Method in class org.apache.cassandra.cli.CliParser
 
columnName - Variable in class org.apache.cassandra.cql.AlterTableStatement
 
columnName - Variable in class org.apache.cassandra.cql3.statements.AlterTableStatement
 
columnName - Variable in class org.apache.cassandra.db.filter.QueryPath
 
ColumnNameBuilder - Interface in org.apache.cassandra.cql3
Build a potentially composite column name.
columnNames - Variable in class org.apache.cassandra.db.SliceByNamesReadCommand
 
columnOrSuperColumn() - Method in class org.apache.cassandra.cli.CliParser
 
columnReverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
columns - Variable in class org.apache.cassandra.cql3.CFDefinition
 
columns - Variable in class org.apache.cassandra.db.AbstractColumnContainer
 
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.db.index.SecondaryIndexSearcher
 
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, IColumnSerializer.Flag, int) - Constructor for class org.apache.cassandra.io.util.ColumnSortedMap
 
command() - Method in class org.apache.cassandra.cli.CliParser
 
commands - Variable in class org.apache.cassandra.cli.CliUserHelp
 
commandType - Variable in class org.apache.cassandra.db.ReadCommand
 
COMMENT - Static variable in class org.apache.cassandra.cli.CliLexer
 
COMMENT - Static variable in class org.apache.cassandra.cli.CliParser
 
comment(String) - Method in class org.apache.cassandra.config.CFMetaData
 
COMMENT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
COMMENT - Static variable in class org.apache.cassandra.cql.CqlParser
 
COMMENT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
COMMENT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
comment - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
CommitLog - Class in org.apache.cassandra.db.commitlog
 
commitlog_directory - Variable in class org.apache.cassandra.config.Config
 
commitlog_segment_size_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
 
commitlog_total_space_in_mb - Variable in class org.apache.cassandra.config.Config
 
CommitLogAllocator - Class in org.apache.cassandra.db.commitlog
Performs the pre-allocation of commit log segments in a background thread.
CommitLogAllocator() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogAllocator
 
CommitLogArchiver - Class in org.apache.cassandra.db.commitlog
 
CommitLogArchiver() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
CommitLogMBean - Interface in org.apache.cassandra.db.commitlog
 
CommitLogReplayer - Class in org.apache.cassandra.db.commitlog
 
CommitLogReplayer() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
CommitLogSegment - Class in org.apache.cassandra.db.commitlog
 
commitTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
 
commitTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
compact() - Method in class org.apache.cassandra.db.HintedHandOffManager
 
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_OPTIONS_PREFIX - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
COMPACTION_OPTIONS_PREFIX - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
compaction_preheat_key_cache - Variable in class org.apache.cassandra.config.Config
 
compaction_strategy - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
compaction_strategy_options - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
compaction_throughput_mb_per_sec - Variable in class org.apache.cassandra.config.Config
 
CompactionController - Class in org.apache.cassandra.db.compaction
Manage compaction options.
CompactionController(ColumnFamilyStore, Collection<SSTableReader>, int, boolean) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
 
CompactionController(ColumnFamilyStore, int, boolean, IntervalTree<SSTableReader>, boolean) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
 
CompactionInfo - Class in org.apache.cassandra.db.compaction
Implements serializable to allow structured info to be returned via JMX.
CompactionInfo(CFMetaData, OperationType, long, long) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
 
CompactionInfo.Holder - Class in org.apache.cassandra.db.compaction
 
CompactionInfo.Holder() - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo.Holder
 
CompactionInterruptedException - Exception in org.apache.cassandra.db.compaction
 
CompactionInterruptedException(CompactionInfo) - Constructor for exception org.apache.cassandra.db.compaction.CompactionInterruptedException
 
CompactionIterable - Class in org.apache.cassandra.db.compaction
 
CompactionIterable(OperationType, List<ICompactionScanner>, CompactionController) - Constructor for class org.apache.cassandra.db.compaction.CompactionIterable
 
CompactionIterable.Reducer - Class in org.apache.cassandra.db.compaction
 
CompactionIterable.Reducer() - Constructor for class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
 
CompactionManager - Class in org.apache.cassandra.db.compaction
A singleton which manages a private executor of ongoing compactions.
CompactionManager() - Constructor for class org.apache.cassandra.db.compaction.CompactionManager
 
CompactionManager.CompactionExecutorStatsCollector - Interface in org.apache.cassandra.db.compaction
 
CompactionManagerMBean - Interface in org.apache.cassandra.db.compaction
 
compactionStrategyClass - Variable in class org.apache.cassandra.config.CFMetaData
 
compactionStrategyClass(Class<? extends AbstractCompactionStrategy>) - Method in class org.apache.cassandra.config.CFMetaData
 
compactionStrategyClass - Variable in class org.apache.cassandra.cql.CFPropDefs
 
compactionStrategyOptions - Variable in class org.apache.cassandra.config.CFMetaData
 
compactionStrategyOptions(Map<String, String>) - Method in class org.apache.cassandra.config.CFMetaData
 
compactionStrategyOptions - Variable in class org.apache.cassandra.cql.CFPropDefs
 
compactionStrategyOptions - Variable in class org.apache.cassandra.cql3.CFPropDefs
 
CompactionTask - Class in org.apache.cassandra.db.compaction
 
CompactionTask(ColumnFamilyStore, Collection<SSTableReader>, int) - Constructor for class org.apache.cassandra.db.compaction.CompactionTask
 
compactionType - Variable in class org.apache.cassandra.db.compaction.CompactionTask
 
compactionType - Variable in class org.apache.cassandra.notifications.SSTableListChangedNotification
 
comparator() - Method in class org.apache.cassandra.cli.CliParser
 
comparator - Variable in class org.apache.cassandra.config.CFMetaData
 
comparator - Static variable in class org.apache.cassandra.db.commitlog.ReplayPosition
 
comparator - Static variable in class org.apache.cassandra.db.DecoratedKey
 
comparator - Variable in class org.apache.cassandra.db.marshal.AbstractCompositeType.CompositeComponent
 
comparator() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
comparator_type - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
comparators - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
comparators - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
comparatorType() - Method in class org.apache.cassandra.cql.CqlParser
 
comparatorType() - Method in class org.apache.cassandra.cql3.CqlParser
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BooleanType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DateType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
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.ReversedType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
compare(File, File) - Method in class org.apache.cassandra.io.util.FileUtils.FileComparator
 
compare(byte[], ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
compare(ByteBuffer, byte[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
 
compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
 
compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
compares two endpoints in relation to the target endpoint, returning as Comparator.compare would
compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.SimpleSnitch
 
compareEndpointStartup(InetAddress, InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
determine which endpoint started up earlier
compareIdTo(CounterContext.ContextState) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
compareSubArrays(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Compare two ByteBuffer at specified offsets for length.
compareTo(RowCacheKey) - Method in class org.apache.cassandra.cache.RowCacheKey
 
compareTo(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
compareTo(ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition
 
compareTo(RowPosition) - Method in class org.apache.cassandra.db.DecoratedKey
 
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<T>) - 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(RowPosition) - Method in class org.apache.cassandra.dht.Token.KeyBound
 
compareTo(GossipDigest) - Method in class org.apache.cassandra.gms.GossipDigest
 
compareTo(VersionedValue) - Method in class org.apache.cassandra.gms.VersionedValue
 
compareTo(SSTableIdentityIterator) - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
compareTo(MergeIterator.Candidate<In>) - Method in class org.apache.cassandra.utils.MergeIterator.Candidate
 
compareTo(NodeId) - Method in class org.apache.cassandra.utils.NodeId
 
compareTo(SemanticVersion) - Method in class org.apache.cassandra.utils.SemanticVersion
 
compareUnsigned(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
compareUnsigned(byte[], byte[], int, int, int, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
COMPIDENT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
COMPIDENT - Static variable in class org.apache.cassandra.cql.CqlParser
 
compileQuery(String) - Static method in class org.apache.cassandra.cli.CliCompiler
 
complete() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
complete(String) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile.Builder
Called after all potential boundaries have been added to apply this Builder to a concrete file on disk.
complete(String) - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile.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.
completed(R) - Method in class org.apache.cassandra.service.AntiEntropyService.RequestCoordinator
 
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_DIGEST - 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
 
componentCount() - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
Returns the number of component already added to this builder.
componentCount() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
componentIndex - Variable in class org.apache.cassandra.config.ColumnDefinition
 
components - Variable in class org.apache.cassandra.io.sstable.SSTable
 
components - Variable in class org.apache.cassandra.io.sstable.SSTableDeletingTask
 
compose(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcAscii
 
compose(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcBoolean
 
compose(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcBytes
 
compose(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcDate
 
compose(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcDecimal
 
compose(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcDouble
 
compose(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcFloat
 
compose(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcInt32
 
compose(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcInteger
 
compose(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcLexicalUUID
 
compose(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcLong
 
compose(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcTimeUUID
 
compose(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcUTF8
 
compose(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcUUID
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BooleanType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DateType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
CompositeType - Class in org.apache.cassandra.db.marshal
 
CompositeType.Builder - Class in org.apache.cassandra.db.marshal
 
CompositeType.Builder(CompositeType) - Constructor for class org.apache.cassandra.db.marshal.CompositeType.Builder
 
compress(byte[], int, int, ICompressor.WrappedArray, int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
compress(byte[], int, int, ICompressor.WrappedArray, int) - Method in interface org.apache.cassandra.io.compress.ICompressor
 
compress(byte[], int, int, ICompressor.WrappedArray, int) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
 
compressedFileLength - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
 
CompressedRandomAccessReader - Class in org.apache.cassandra.io.compress
 
CompressedRandomAccessReader(String, CompressionMetadata, boolean) - Constructor for class org.apache.cassandra.io.compress.CompressedRandomAccessReader
 
CompressedSegmentedFile - Class in org.apache.cassandra.io.util
 
CompressedSegmentedFile(String, CompressionMetadata) - Constructor for class org.apache.cassandra.io.util.CompressedSegmentedFile
 
CompressedSegmentedFile.Builder - Class in org.apache.cassandra.io.util
 
CompressedSegmentedFile.Builder() - Constructor for class org.apache.cassandra.io.util.CompressedSegmentedFile.Builder
 
CompressedSequentialWriter - Class in org.apache.cassandra.io.compress
 
CompressedSequentialWriter(File, String, boolean, CompressionParameters, SSTableMetadata.Collector) - Constructor for class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
CompressedSequentialWriter.CompressedFileWriterMark - Class in org.apache.cassandra.io.compress
Class to hold a mark to the position of the file
CompressedSequentialWriter.CompressedFileWriterMark(long, long, int, int) - Constructor for class org.apache.cassandra.io.compress.CompressedSequentialWriter.CompressedFileWriterMark
 
compression - Variable in class org.apache.cassandra.io.sstable.SSTable
 
COMPRESSION_INFO - Static variable in class org.apache.cassandra.io.sstable.Component
 
compression_options - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
COMPRESSION_PARAMETERS_PREFIX - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
COMPRESSION_PARAMETERS_PREFIX - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
CompressionMetadata - Class in org.apache.cassandra.io.compress
Holds metadata about compressed file
CompressionMetadata.Chunk - Class in org.apache.cassandra.io.compress
Holds offset and length of the file chunk
CompressionMetadata.Chunk(long, int) - Constructor for class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
 
CompressionMetadata.Writer - Class in org.apache.cassandra.io.compress
 
CompressionMetadata.Writer(String) - Constructor for class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
compressionParameters - Variable in class org.apache.cassandra.config.CFMetaData
 
compressionParameters(CompressionParameters) - Method in class org.apache.cassandra.config.CFMetaData
 
compressionParameters() - Method in class org.apache.cassandra.config.CFMetaData
 
compressionParameters - Variable in class org.apache.cassandra.cql.CFPropDefs
 
compressionParameters - Variable in class org.apache.cassandra.cql3.CFPropDefs
 
CompressionParameters - Class in org.apache.cassandra.io.compress
 
CompressionParameters(String, Integer, Map<String, String>) - Constructor for class org.apache.cassandra.io.compress.CompressionParameters
 
CompressionParameters(ICompressor) - Constructor for class org.apache.cassandra.io.compress.CompressionParameters
 
CompressionParameters(ICompressor, Integer, Map<String, String>) - Constructor for class org.apache.cassandra.io.compress.CompressionParameters
 
compressionRatio - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
compressionRatio - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
 
compressor() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
 
computeExpireTime() - Static method in class org.apache.cassandra.gms.Gossiper
 
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.
computeOldShardMerger(ByteBuffer, List<NodeId.NodeIdRecord>, long) - Method in class org.apache.cassandra.db.context.CounterContext
Compute a new context such that if applied to context yields the same total but with old local node ids nulified and there content merged to the current localNodeId.
concatWithIndexes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
concurrent_compactors - Variable in class org.apache.cassandra.config.Config
 
concurrent_reads - Variable in class org.apache.cassandra.config.Config
 
concurrent_replicates - Variable in class org.apache.cassandra.config.Config
 
concurrent_writes - Variable in class org.apache.cassandra.config.Config
 
ConcurrentLinkedHashCache<K,V> - Class in org.apache.cassandra.cache
Wrapper so CLHM can implement ICache interface.
ConcurrentLinkedHashCache(ConcurrentLinkedHashMap<K, V>) - Constructor for class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
ConcurrentLinkedHashCacheProvider - Class in org.apache.cassandra.cache
 
ConcurrentLinkedHashCacheProvider() - Constructor for class org.apache.cassandra.cache.ConcurrentLinkedHashCacheProvider
 
CONDITION - Static variable in class org.apache.cassandra.cli.CliLexer
 
CONDITION - Static variable in class org.apache.cassandra.cli.CliParser
 
condition - Variable in class org.apache.cassandra.service.ReadCallback
 
condition - Variable in class org.apache.cassandra.service.TruncateResponseHandler
 
CONDITIONS - Static variable in class org.apache.cassandra.cli.CliLexer
 
CONDITIONS - Static variable in class org.apache.cassandra.cli.CliParser
 
CONFIG - Static variable in class org.apache.cassandra.cli.CliLexer
 
CONFIG - Static variable in class org.apache.cassandra.cli.CliParser
 
Config - Class in org.apache.cassandra.config
 
Config() - Constructor for class org.apache.cassandra.config.Config
 
Config.CommitLogSync - Enum in org.apache.cassandra.config
 
Config.DiskAccessMode - Enum in org.apache.cassandra.config
 
Config.RequestSchedulerId - Enum in org.apache.cassandra.config
 
ConfigHelper - Class in org.apache.cassandra.hadoop
 
ConfigHelper() - Constructor for class org.apache.cassandra.hadoop.ConfigHelper
 
configOptions - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
ConfigurationException - Exception in org.apache.cassandra.config
 
ConfigurationException(String) - Constructor for exception org.apache.cassandra.config.ConfigurationException
 
ConfigurationException(String, Exception) - Constructor for exception org.apache.cassandra.config.ConfigurationException
 
confirmReplication(InetAddress) - Method in class org.apache.cassandra.service.StorageService
 
CONNECT - Static variable in class org.apache.cassandra.cli.CliLexer
 
connect(String, int) - Static method in class org.apache.cassandra.cli.CliMain
Establish a thrift connection to cassandra instance
CONNECT - Static variable in class org.apache.cassandra.cli.CliParser
 
connectStatement() - Method in class org.apache.cassandra.cli.CliParser
 
consistency - Variable in class org.apache.cassandra.cql.BatchStatement
 
consistency() - Method in class org.apache.cassandra.db.CounterMutation
 
CONSISTENCYLEVEL - Static variable in class org.apache.cassandra.cli.CliLexer
 
CONSISTENCYLEVEL - Static variable in class org.apache.cassandra.cli.CliParser
 
consistencyLevel - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
consistencyLevelStatement() - Method in class org.apache.cassandra.cli.CliParser
 
CONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
 
construct(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
Constructs an instance of the given class, which must have a no-arg constructor.
constructStreamHeader(StreamHeader, boolean, int) - Method in class org.apache.cassandra.net.MessagingService
 
contains(ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
Check to see if a certain ReplayPosition is contained by this segment file.
contains(T) - Method in class org.apache.cassandra.dht.AbstractBounds
 
contains(T) - Method in class org.apache.cassandra.dht.Bounds
 
contains(T) - Method in class org.apache.cassandra.dht.ExcludingBounds
 
contains(T) - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
contains(T, T, T) - Static method in class org.apache.cassandra.dht.Range
 
contains(Range<T>) - Method in class org.apache.cassandra.dht.Range
 
contains(T) - Method in class org.apache.cassandra.dht.Range
Helps determine if a given point on the DHT ring is contained in the range in question.
contains(Comparable) - Method in class org.apache.cassandra.utils.IntervalTree.Interval
 
containsCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
containsKey(K) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
containsKey(K) - Method in interface org.apache.cassandra.cache.ICache
 
containsKey(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
containsKey(K) - Method in class org.apache.cassandra.cache.SerializingCache
 
containsKey(Object) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
containsKey(K) - Method in class org.apache.cassandra.utils.ExpiringMap
 
containsTimestamp() - Method in class org.apache.cassandra.io.sstable.Descriptor
Versions [h..hc] contained a timestamp value that was computed incorrectly, ignoring row tombstones.
containsValue(Object) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
contents() - Method in class org.apache.cassandra.db.Memtable
 
context - Variable in class org.apache.cassandra.db.context.CounterContext.ContextState
 
context - Variable in class org.apache.cassandra.streaming.AbstractStreamSession
 
contextManager - Static variable in class org.apache.cassandra.db.CounterColumn
 
controller - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
CONVERT_TO_TYPE - Static variable in class org.apache.cassandra.cli.CliLexer
 
CONVERT_TO_TYPE - Static variable in class org.apache.cassandra.cli.CliParser
 
convertFromDiskFormat(ByteBuffer) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
convertFromDiskFormat(ByteBuffer) - Method in interface org.apache.cassandra.dht.IPartitioner
Deprecated. Used by SSTables before version 'e'. Convert the on disk representation to a DecoratedKey object
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
 
convict(InetAddress, double) - Method in class org.apache.cassandra.gms.Gossiper
This method is part of IFailureDetectionEventListener interface.
convict(InetAddress, double) - 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.
convict(InetAddress, double) - Method in class org.apache.cassandra.streaming.AbstractStreamSession
 
copy() - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
Clone this builder.
copy() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
copy() - Method in class org.apache.cassandra.db.ReadCommand
 
copy() - Method in class org.apache.cassandra.db.RetriedSliceFromReadCommand
 
copy() - Method in class org.apache.cassandra.db.SliceByNamesReadCommand
 
copy() - Method in class org.apache.cassandra.db.SliceFromReadCommand
 
copyTo(CounterContext.ContextState) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
CorruptedBlockException - Exception in org.apache.cassandra.io.compress
 
CorruptedBlockException(String, CompressionMetadata.Chunk) - Constructor for exception org.apache.cassandra.io.compress.CorruptedBlockException
 
CorruptedBlockException(String, long, int) - Constructor for exception org.apache.cassandra.io.compress.CorruptedBlockException
 
COUNT - Static variable in class org.apache.cassandra.cli.CliLexer
 
COUNT - Static variable in class org.apache.cassandra.cli.CliParser
 
count - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
count - Variable in class org.apache.cassandra.db.SliceFromReadCommand
 
count - Variable in class org.apache.cassandra.io.util.FastByteArrayInputStream
The total number of bytes initially available in the byte array buf.
count - Variable in class org.apache.cassandra.io.util.FastByteArrayOutputStream
The number of bytes written.
count() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
COUNTER_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
 
COUNTER_UPDATE_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
 
CounterColumn - Class in org.apache.cassandra.db
A column that represents a partitioned counter.
CounterColumn(ByteBuffer, long, long) - Constructor for class org.apache.cassandra.db.CounterColumn
 
CounterColumn(ByteBuffer, long, long, long) - Constructor for class org.apache.cassandra.db.CounterColumn
 
CounterColumn(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.CounterColumn
 
CounterColumn(ByteBuffer, ByteBuffer, long, long) - Constructor for class org.apache.cassandra.db.CounterColumn
 
CounterColumnType - Class in org.apache.cassandra.db.marshal
 
CounterContext - Class in org.apache.cassandra.db.context
An implementation of a partitioned counter context.
CounterContext() - Constructor for class org.apache.cassandra.db.context.CounterContext
 
CounterContext.ContextState - Class in org.apache.cassandra.db.context
Helper class to work on contexts (works by iterating over them).
CounterContext.ContextState(ByteBuffer, int) - Constructor for class org.apache.cassandra.db.context.CounterContext.ContextState
 
CounterContext.ContextState(ByteBuffer) - Constructor for class org.apache.cassandra.db.context.CounterContext.ContextState
 
CounterMutation - Class in org.apache.cassandra.db
 
CounterMutation(RowMutation, ConsistencyLevel) - Constructor for class org.apache.cassandra.db.CounterMutation
 
CounterMutationVerbHandler - Class in org.apache.cassandra.db
 
CounterMutationVerbHandler() - Constructor for class org.apache.cassandra.db.CounterMutationVerbHandler
 
CounterUpdateColumn - Class in org.apache.cassandra.db
A counter update while it hasn't been applied yet by the leader replica.
CounterUpdateColumn(ByteBuffer, long, long) - Constructor for class org.apache.cassandra.db.CounterUpdateColumn
 
CounterUpdateColumn(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.CounterUpdateColumn
 
countPendingHints() - Method in class org.apache.cassandra.db.HintedHandOffManager
 
countPendingHints() - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
List all the endpoints that this node has hints for, and count the number of hints for each such endpoint.
countStatement() - Method in class org.apache.cassandra.cli.CliParser
 
CQL_VERSION - Static variable in class org.apache.cassandra.cql.QueryProcessor
 
CQL_VERSION - Static variable in class org.apache.cassandra.cql3.QueryProcessor
 
CqlLexer - Class in org.apache.cassandra.cql
 
CqlLexer() - Constructor for class org.apache.cassandra.cql.CqlLexer
 
CqlLexer(CharStream) - Constructor for class org.apache.cassandra.cql.CqlLexer
 
CqlLexer(CharStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cql.CqlLexer
 
CqlLexer - Class in org.apache.cassandra.cql3
 
CqlLexer() - Constructor for class org.apache.cassandra.cql3.CqlLexer
 
CqlLexer(CharStream) - Constructor for class org.apache.cassandra.cql3.CqlLexer
 
CqlLexer(CharStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cql3.CqlLexer
 
CqlParser - Class in org.apache.cassandra.cql
 
CqlParser(TokenStream) - Constructor for class org.apache.cassandra.cql.CqlParser
 
CqlParser(TokenStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cql.CqlParser
 
CqlParser - Class in org.apache.cassandra.cql3
 
CqlParser(TokenStream) - Constructor for class org.apache.cassandra.cql3.CqlParser
 
CqlParser(TokenStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cql3.CqlParser
 
CqlParser.comparatorType_return - Class in org.apache.cassandra.cql
 
CqlParser.comparatorType_return() - Constructor for class org.apache.cassandra.cql.CqlParser.comparatorType_return
 
CQLStatement - Class in org.apache.cassandra.cql
 
CQLStatement(StatementType, Object, int) - Constructor for class org.apache.cassandra.cql.CQLStatement
 
cqlStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
CQLStatement - Interface in org.apache.cassandra.cql3
 
CRC_CHECK_CHANCE - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
 
crcChance - Variable in class org.apache.cassandra.io.compress.CompressionParameters
 
create(long) - Static method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
Initialize a cache with weigher = Weighers.singleton() and initial capacity 0
create(long, Weigher<V>) - Static method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
Initialize a cache with initial capacity set to 0
create(long, boolean) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCacheProvider
 
create(long, boolean) - Method in interface org.apache.cassandra.cache.IRowCacheProvider
 
create(long, boolean) - Method in class org.apache.cassandra.cache.SerializingCacheProvider
 
CREATE - Static variable in class org.apache.cassandra.cli.CliLexer
 
CREATE - Static variable in class org.apache.cassandra.cli.CliParser
 
create(String, long, String...) - Static method in class org.apache.cassandra.db.Column
 
create(int, long, String...) - Static method in class org.apache.cassandra.db.Column
 
create(boolean, long, String...) - Static method in class org.apache.cassandra.db.Column
 
create(double, long, String...) - Static method in class org.apache.cassandra.db.Column
 
create(ByteBuffer, long, String...) - Static method in class org.apache.cassandra.db.Column
 
create(Integer) - Static method in class org.apache.cassandra.db.ColumnFamily
 
create(Integer, ISortedColumns.Factory) - 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(CFMetaData, ISortedColumns.Factory) - Static method in class org.apache.cassandra.db.ColumnFamily
 
create(CFMetaData, ISortedColumns.Factory, boolean) - Static method in class org.apache.cassandra.db.ColumnFamily
 
create(String) - Static method in enum org.apache.cassandra.db.ColumnFamilyType
 
create(ColumnFamilyStore, int, Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
 
create(long, Allocator) - Method in class org.apache.cassandra.db.context.CounterContext
Creates an initial counter context with an initial value for the local node.
create(NodeId, long, long, boolean) - Method in class org.apache.cassandra.db.context.CounterContext
 
create(ByteBuffer, ByteBuffer, long, long, IColumnSerializer.Flag) - Static method in class org.apache.cassandra.db.CounterColumn
 
create(int, long, String...) - Static method in class org.apache.cassandra.db.DeletedColumn
 
create(String, String) - Static method in class org.apache.cassandra.db.Directories
 
create(ByteBuffer, ByteBuffer, long, int, int, int, IColumnSerializer.Flag) - Static method in class org.apache.cassandra.db.ExpiringColumn
 
create(ColumnFamilyStore, IFilter, List<IndexExpression>, int, boolean, boolean) - Static method in class org.apache.cassandra.db.filter.ExtendedFilter
 
create(AbstractType<?>, boolean) - Method in interface org.apache.cassandra.db.ISortedColumns.Factory
Returns a (initially empty) column map whose columns are sorted according to the provided comparator.
create(String) - Static method in class org.apache.cassandra.io.compress.CompressionMetadata
Create metadata about given compressed file including uncompressed data length, chunk size and list of the chunk offsets of the compressed data.
create(Map<? extends CharSequence, ? extends CharSequence>) - Static method in class org.apache.cassandra.io.compress.CompressionParameters
 
create(Map<String, String>) - Static method in class org.apache.cassandra.io.compress.DeflateCompressor
 
create(Map<String, String>) - Static method in class org.apache.cassandra.io.compress.SnappyCompressor
 
create() - Static method in class org.apache.cassandra.locator.EndpointSnitchInfo
 
create(Collection<InetAddress>, ConsistencyLevel, String, Runnable) - Static method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
create(Collection<InetAddress>, ConsistencyLevel, String, Runnable) - Static method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
create(Collection<InetAddress>, ConsistencyLevel, String, Runnable) - Static method in class org.apache.cassandra.service.WriteResponseHandler
 
create(InetAddress) - Static method in class org.apache.cassandra.service.WriteResponseHandler
 
create(InetAddress, InetAddress, String, String, Collection<Range<Token>>, Runnable) - Static method in class org.apache.cassandra.streaming.StreamingRepairTask
 
create(InetAddress, IStreamCallback) - Static method in class org.apache.cassandra.streaming.StreamInSession
 
create(String, InetAddress, IStreamCallback) - 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, IStreamCallback) - 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.
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.
createCfamColumns(CreateColumnFamilyStatement) - Method in class org.apache.cassandra.cql.CqlParser
 
createCfamColumnValidator() - Method in class org.apache.cassandra.cql.CqlParser
 
createCfamKeywordArgument() - Method in class org.apache.cassandra.cql.CqlParser
 
createCollector() - Static method in class org.apache.cassandra.io.sstable.SSTableMetadata
 
createColumn(ByteBuffer, ByteBuffer, long) - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
create commutative column
createColumn(ByteBuffer, ByteBuffer, long) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
create commutative column
createColumnFamilyStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
CreateColumnFamilyStatement - Class in org.apache.cassandra.cql
A CREATE COLUMNFAMILY parsed from a CQL query statement.
CreateColumnFamilyStatement(String) - Constructor for class org.apache.cassandra.cql.CreateColumnFamilyStatement
 
createColumnFamilyStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
CreateColumnFamilyStatement - Class in org.apache.cassandra.cql3.statements
A CREATE COLUMNFAMILY parsed from a CQL query statement.
CreateColumnFamilyStatement(CFName, CFPropDefs) - Constructor for class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement
 
CreateColumnFamilyStatement.RawStatement - Class in org.apache.cassandra.cql3.statements
 
CreateColumnFamilyStatement.RawStatement(CFName) - Constructor for class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement.RawStatement
 
createColumnFamilyStore(Table, String, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
createColumnFamilyStore(Table, String, IPartitioner, CFMetaData) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
createCompactionStrategy(String) - Static method in class org.apache.cassandra.config.CFMetaData
 
createCompactionStrategyInstance(ColumnFamilyStore) - Method in class org.apache.cassandra.config.CFMetaData
 
createCompactionWriter(long, File, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
createConnection(Configuration, String, Integer) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
createDefaultInstance() - Static method in class org.apache.cassandra.io.sstable.SSTableMetadata
 
createDirectory(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createDirectory(File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createFlushWriter(long, long, ReplayPosition) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
createHardLink(File, File) - Static method in class org.apache.cassandra.utils.CLibrary
Create a hard link for a given file.
createHardLinkWithExec(File, File) - Static method in class org.apache.cassandra.utils.CLibrary
 
createIndexStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
CreateIndexStatement - Class in org.apache.cassandra.cql
A CREATE INDEX statement parsed from a CQL query.
CreateIndexStatement(String, String, Term) - Constructor for class org.apache.cassandra.cql.CreateIndexStatement
 
createIndexStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
CreateIndexStatement - Class in org.apache.cassandra.cql3.statements
A CREATE INDEX statement parsed from a CQL query.
CreateIndexStatement(CFName, String, ColumnIdentifier) - Constructor for class org.apache.cassandra.cql3.statements.CreateIndexStatement
 
createInRelation(ColumnIdentifier) - Static method in class org.apache.cassandra.cql3.Relation
 
createInstance(ColumnFamilyStore, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.SecondaryIndex
This is the primary way to create a secondary index instance for a CF column.
createKey() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
createKeyspaceStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
CreateKeyspaceStatement - Class in org.apache.cassandra.cql
A CREATE KEYSPACE statement parsed from a CQL query.
CreateKeyspaceStatement(String, Map<String, String>) - Constructor for class org.apache.cassandra.cql.CreateKeyspaceStatement
Creates a new CreateKeyspaceStatement instance for a given keyspace name and keyword arguments.
createKeyspaceStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
CreateKeyspaceStatement - Class in org.apache.cassandra.cql3.statements
A CREATE KEYSPACE statement parsed from a CQL query.
CreateKeyspaceStatement(String, KSPropDefs) - Constructor for class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
Creates a new CreateKeyspaceStatement instance for a given keyspace name and keyword arguments.
createLinks(String) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
 
createReplicationStrategy(KSMetaData) - Method in class org.apache.cassandra.db.Table
 
createReplicationStrategy(String, Class<? extends AbstractReplicationStrategy>, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
createReplicationStrategy(String, String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
createSecondaryIndexSearcher(Set<ByteBuffer>) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
createSecondaryIndexSearcher(Set<ByteBuffer>) - Method in class org.apache.cassandra.db.index.SecondaryIndex
Called at query time Creates a implementation specific searcher instance for this index type
createValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
createWithFixedPoolSize(String, int) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
Returns a ThreadPoolExecutor with a fixed number of threads.
createWithMaximumPoolSize(String, int, int, TimeUnit) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
Returns a ThreadPoolExecutor with a fixed maximum number of threads, but whose threads are terminated when idle for too long.
creationTime() - Method in class org.apache.cassandra.db.Memtable
 
CreationTimeAwareFuture<V> - Class in org.apache.cassandra.concurrent
Decorates FutureTask
CreationTimeAwareFuture(Future<V>) - Constructor for class org.apache.cassandra.concurrent.CreationTimeAwareFuture
 
current - Variable in class org.apache.cassandra.io.util.RandomAccessReader
 
current - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
CURRENT_VERSION - Static variable in class org.apache.cassandra.io.sstable.Descriptor
 
currentKey - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
currentSuperColumn - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
CUSTOM_INDEX_OPTION_NAME - Static variable in class org.apache.cassandra.db.index.SecondaryIndex
 
CustomTHsHaServer - Class in org.apache.cassandra.thrift
This is a interim solution till THRIFT-1167 gets committed...
CustomTHsHaServer(TNonblockingServer.Args, ExecutorService, int) - Constructor for class org.apache.cassandra.thrift.CustomTHsHaServer
All the arguments to Non Blocking Server will apply here.
CustomTHsHaServer.Invocation - Class in org.apache.cassandra.thrift
Save the remote socket as a thead local for future use of client state.
CustomTHsHaServer.Invocation(TNonblockingServer.FrameBuffer, CustomTHsHaServer.SelectorThread) - Constructor for class org.apache.cassandra.thrift.CustomTHsHaServer.Invocation
 
CustomTHsHaServer.SelectorThread - Class in org.apache.cassandra.thrift
IO Threads will perform expensive IO operations...
CustomTHsHaServer.SelectorThread(String) - Constructor for class org.apache.cassandra.thrift.CustomTHsHaServer.SelectorThread
 
CustomTNonBlockingServer - Class in org.apache.cassandra.thrift
 
CustomTNonBlockingServer(TNonblockingServer.Args) - Constructor for class org.apache.cassandra.thrift.CustomTNonBlockingServer
 
CustomTThreadPoolServer - Class in org.apache.cassandra.thrift
Slightly modified version of the Apache Thrift TThreadPoolServer.
CustomTThreadPoolServer(TThreadPoolServer.Args, ExecutorService) - Constructor for class org.apache.cassandra.thrift.CustomTThreadPoolServer
 

D

D - Static variable in class org.apache.cassandra.cql.CqlLexer
 
D - Static variable in class org.apache.cassandra.cql.CqlParser
 
D - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
D - Static variable in class org.apache.cassandra.cql3.CqlParser
 
DATA - Static variable in class org.apache.cassandra.io.sstable.Component
 
Data - Variable in class org.apache.cassandra.utils.IntervalTree.Interval
 
data_file_directories - Variable in class org.apache.cassandra.config.Config
 
DatabaseDescriptor - Class in org.apache.cassandra.config
 
DatabaseDescriptor() - Constructor for class org.apache.cassandra.config.DatabaseDescriptor
 
datacenter(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
DatacenterReadCallback<T> - Class in org.apache.cassandra.service
Datacenter Quorum response handler blocks for a quorum of responses from the local DC
DatacenterReadCallback(IResponseResolver, ConsistencyLevel, IReadCommand, List<InetAddress>) - Constructor for class org.apache.cassandra.service.DatacenterReadCallback
 
DatacenterSyncWriteResponseHandler - Class in org.apache.cassandra.service
This class blocks for a quorum of responses _in all datacenters_ (CL.EACH_QUORUM).
DatacenterSyncWriteResponseHandler(Collection<InetAddress>, ConsistencyLevel, String, Runnable) - 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>, ConsistencyLevel, String, Runnable) - Constructor for class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
dataFileLocations - Static variable in class org.apache.cassandra.db.Directories
 
dataLength - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
 
DataOutputBuffer - Class in org.apache.cassandra.io.util
An implementation of the DataOutputStream interface using a FastByteArrayOutputStream and exposing its buffer so copies can be avoided.
DataOutputBuffer() - Constructor for class org.apache.cassandra.io.util.DataOutputBuffer
 
DataOutputBuffer(int) - Constructor for class org.apache.cassandra.io.util.DataOutputBuffer
 
dataSize - Variable in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
DataTracker - Class in org.apache.cassandra.db
 
DataTracker(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.DataTracker
 
dateStringToTimestamp(String) - Static method in class org.apache.cassandra.db.marshal.DateType
 
DateType - Class in org.apache.cassandra.db.marshal
 
DBConstants - Class in org.apache.cassandra.db
 
DBConstants() - Constructor for class org.apache.cassandra.db.DBConstants
 
dclocal_read_repair_chance - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
dcLocalReadRepairChance(double) - Method in class org.apache.cassandra.config.CFMetaData
 
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
 
debug(String) - Method in interface org.apache.cassandra.utils.OutputHandler
 
debug(String) - Method in class org.apache.cassandra.utils.OutputHandler.LogOutput
 
debug - Variable in class org.apache.cassandra.utils.OutputHandler.SystemOutput
 
debug(String) - Method in class org.apache.cassandra.utils.OutputHandler.SystemOutput
 
DebuggableScheduledThreadPoolExecutor - Class in org.apache.cassandra.concurrent
Like DebuggableThreadPoolExecutor, DebuggableScheduledThreadPoolExecutor always logs exceptions from the tasks it is given, even if Future.get is never called elsewhere.
DebuggableScheduledThreadPoolExecutor(int, String, int) - Constructor for class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
 
DebuggableScheduledThreadPoolExecutor(String) - Constructor for class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
 
DebuggableThreadPoolExecutor - Class in org.apache.cassandra.concurrent
This class encorporates some Executor best practices for Cassandra.
DebuggableThreadPoolExecutor(String, int) - Constructor for class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
DebuggableThreadPoolExecutor(int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
DebuggableThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
DecimalDigit - Static variable in class org.apache.cassandra.cli.CliLexer
 
DecimalDigit - Static variable in class org.apache.cassandra.cli.CliParser
 
DecimalType - Class in org.apache.cassandra.db.marshal
 
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(T) - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcType
 
decompose(String) - Method in class org.apache.cassandra.cql.jdbc.JdbcAscii
 
decompose(Boolean) - Method in class org.apache.cassandra.cql.jdbc.JdbcBoolean
 
decompose(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcBytes
 
decompose(Date) - Method in class org.apache.cassandra.cql.jdbc.JdbcDate
 
decompose(BigDecimal) - Method in class org.apache.cassandra.cql.jdbc.JdbcDecimal
The bytes of the ByteBuffer are made up of 4 bytes of int containing the scale followed by the n bytes it takes to store a BigInteger.
decompose(Double) - Method in class org.apache.cassandra.cql.jdbc.JdbcDouble
 
decompose(Float) - Method in class org.apache.cassandra.cql.jdbc.JdbcFloat
 
decompose(Integer) - Method in class org.apache.cassandra.cql.jdbc.JdbcInt32
 
decompose(BigInteger) - Method in class org.apache.cassandra.cql.jdbc.JdbcInteger
 
decompose(UUID) - Method in class org.apache.cassandra.cql.jdbc.JdbcLexicalUUID
 
decompose(Long) - Method in class org.apache.cassandra.cql.jdbc.JdbcLong
 
decompose(UUID) - Method in class org.apache.cassandra.cql.jdbc.JdbcTimeUUID
 
decompose(String) - Method in class org.apache.cassandra.cql.jdbc.JdbcUTF8
 
decompose(UUID) - Method in class org.apache.cassandra.cql.jdbc.JdbcUUID
 
decompose(Long) - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
 
decompose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
decompose(T) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
decompose(String) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
decompose(Boolean) - Method in class org.apache.cassandra.db.marshal.BooleanType
 
decompose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
 
decompose(Date) - Method in class org.apache.cassandra.db.marshal.DateType
 
decompose(BigDecimal) - Method in class org.apache.cassandra.db.marshal.DecimalType
The bytes of the ByteBuffer are made up of 4 bytes of int containing the scale followed by the n bytes it takes to store a BigInteger.
decompose(Double) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
decompose(Float) - Method in class org.apache.cassandra.db.marshal.FloatType
 
decompose(Integer) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
decompose(BigInteger) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
decompose(UUID) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
decompose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
decompose(Long) - Method in class org.apache.cassandra.db.marshal.LongType
 
decompose(T) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
decompose(UUID) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
decompose(String) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
decompose(UUID) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
decompose(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
decomposes a uuid into raw bytes.
deconstruct(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
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
 
DECR - Static variable in class org.apache.cassandra.cli.CliLexer
 
DECR - Static variable in class org.apache.cassandra.cli.CliParser
 
decrementActiveStreamsOutbound() - Method in class org.apache.cassandra.net.MessagingService
 
DEFAULT_BF_FP_CHANCE - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_BUFFER_SIZE - Static variable in class org.apache.cassandra.io.util.RandomAccessReader
 
DEFAULT_CACHING_STRATEGY - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_CHUNK_LENGTH - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
 
DEFAULT_COMPACTION_STRATEGY_CLASS - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_COMPRESSOR - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_CONCURENCY_LEVEL - Static variable in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
DEFAULT_CQL_VERSION - Static variable in class org.apache.cassandra.service.ClientState
 
DEFAULT_CRC_CHECK_CHANCE - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
 
DEFAULT_DCLOCAL_READ_REPAIR_CHANCE - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_GC_GRACE_SECONDS - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_KEY_NAME - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_KEY_NAME - Static variable in class org.apache.cassandra.cql.QueryProcessor
 
DEFAULT_MAX_COMPACTION_THRESHOLD - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MIN_COMPACTION_THRESHOLD - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MIN_SSTABLE_SIZE - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
DEFAULT_READ_REPAIR_CHANCE - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_REPLICATE_ON_WRITE - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_THROTTLE_LIMIT - Static variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
default_validation_class - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
DEFAULT_WEIGHT - Static variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
default_weight - Variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
defaultConsistency - Static variable in class org.apache.cassandra.cql.AbstractModification
 
defaultConsistency - Static variable in class org.apache.cassandra.cql3.statements.ModificationStatement
 
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
 
defaultValidator(AbstractType<?>) - Method in class org.apache.cassandra.config.CFMetaData
 
DEFINITION_SCHEMA_COLUMN_NAME - Static variable in class org.apache.cassandra.db.DefsTable
 
DefinitionsUpdateVerbHandler - Class in org.apache.cassandra.db
Called when node receives updated schema state from the schema migration coordinator node.
DefinitionsUpdateVerbHandler() - Constructor for class org.apache.cassandra.db.DefinitionsUpdateVerbHandler
 
definitionType - Static variable in class org.apache.cassandra.cql3.CFDefinition
 
DeflateCompressor - Class in org.apache.cassandra.io.compress
 
defreezeBloomFilter(FileDataInput, boolean) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
 
defreezeBloomFilter(FileDataInput, long, boolean) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
De-freeze the bloom filter.
DefsTable - Class in org.apache.cassandra.db
SCHEMA_{KEYSPACES, COLUMNFAMILIES, COLUMNS}_CF are used to store Keyspace/ColumnFamily attributes to make schema load/distribution easy, it replaces old mechanism when local migrations where serialized, stored in system.Migrations and used for schema distribution.
DefsTable() - Constructor for class org.apache.cassandra.db.DefsTable
 
DEL - Static variable in class org.apache.cassandra.cli.CliLexer
 
DEL - Static variable in class org.apache.cassandra.cli.CliParser
 
delColumnFamily() - Method in class org.apache.cassandra.cli.CliParser
 
delete(int, long) - Method in class org.apache.cassandra.db.AbstractColumnContainer
Deprecated. 
delete(AbstractColumnContainer) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
delete(ISortedColumns.DeletionInfo) - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
 
delete(ISortedColumns.DeletionInfo) - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
delete(ISortedColumns.DeletionInfo) - Method in interface org.apache.cassandra.db.ISortedColumns
 
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(File[]) - Static method in class org.apache.cassandra.io.util.FileUtils
 
deleteAsync(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
deleteColumn(DecoratedKey<?>, ByteBuffer, IColumn) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
deleteColumn(DecoratedKey<?>, ByteBuffer, IColumn) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
Delete a column from the index
deleteColumnOrSuperColumn(String, Deletion) - Method in class org.apache.cassandra.db.RowMutation
 
DeletedColumn - Class in org.apache.cassandra.db
 
DeletedColumn(ByteBuffer, int, long) - Constructor for class org.apache.cassandra.db.DeletedColumn
 
DeletedColumn(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.DeletedColumn
 
deleteFromIndex(DecoratedKey<?>, List<IColumn>) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
cleans up deleted columns from cassandra cleanup compaction
deleteFromIndexes(DecoratedKey<?>, List<IColumn>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
Delete all columns from all indexes for this row
deleteFromSchema(RowMutation, String, AbstractType<?>, long) - Method in class org.apache.cassandra.config.ColumnDefinition
Drop specified column from the schema using given row.
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`.
deleteRecursive(File) - Static method in class org.apache.cassandra.io.util.FileUtils
Deletes all files and subdirectories under "dir".
deleteStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
DeleteStatement - Class in org.apache.cassandra.cql
A DELETE parsed from a CQL query statement.
DeleteStatement(List<Term>, String, String, String, List<Term>, Attributes) - Constructor for class org.apache.cassandra.cql.DeleteStatement
 
deleteStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
DeleteStatement - Class in org.apache.cassandra.cql3.statements
A DELETE parsed from a CQL query statement.
DeleteStatement(CFName, List<ColumnIdentifier>, List<Relation>, Attributes) - Constructor for class org.apache.cassandra.cql3.statements.DeleteStatement
 
deleteWithConfirm(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
deleteWithConfirm(File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
DELETION_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
 
DELIMITER - Static variable in class org.apache.cassandra.gms.VersionedValue
 
DELIMITER_STR - Static variable in class org.apache.cassandra.gms.VersionedValue
 
deliverHints(String) - Method in class org.apache.cassandra.service.StorageService
 
delKeyspace() - Method in class org.apache.cassandra.cli.CliParser
 
delStatement() - Method in class org.apache.cassandra.cli.CliParser
 
delta() - Method in class org.apache.cassandra.db.CounterUpdateColumn
 
depth - Variable in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
deque - Variable in class org.apache.cassandra.utils.BoundedStatsDeque
 
desc - Variable in class org.apache.cassandra.io.sstable.SSTableDeletingTask
 
desc - Variable in class org.apache.cassandra.streaming.PendingFile
 
DESCRIBE - Static variable in class org.apache.cassandra.cli.CliLexer
 
DESCRIBE - Static variable in class org.apache.cassandra.cli.CliParser
 
describe_cluster_name() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_keyspaces() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_partitioner() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_ring(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_schema_versions() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_snitch() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_splits(String, String, String, int) - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_token_map() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_version() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describeCluster() - Method in class org.apache.cassandra.cli.CliParser
 
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
describeOwnership(List<Token>) - Method in interface org.apache.cassandra.dht.IPartitioner
Calculate the deltas between tokens in the ring in order to compare relative sizes.
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
describeRing(String) - Method in class org.apache.cassandra.service.StorageService
The TokenRange for a given keyspace.
describeRing(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
describeRingJMX(String) - Method in class org.apache.cassandra.service.StorageService
The same as describeRing(String) but converts TokenRange to the String for JMX compatibility
describeRingJMX(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
The same as describeRing(String) but converts TokenRange to the String for JMX compatibility
describeSchemaVersions() - Static method in class org.apache.cassandra.service.StorageProxy
initiate a request/response session with each live node to check whether or not everybody is using the same migration id.
describeTable() - Method in class org.apache.cassandra.cli.CliParser
 
Descriptor - Class in org.apache.cassandra.io.sstable
A SSTable is described by the keyspace and column family it contains data for, a generation (where higher generations contain more recent data) and an alphabetic version string.
Descriptor(File, String, String, int, boolean) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
A descriptor that assumes CURRENT_VERSION.
Descriptor(String, File, String, String, int, boolean) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
 
descriptor - Variable in class org.apache.cassandra.io.sstable.SSTable
 
deserialize(DataInput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserialize(DataInput, IColumnSerializer.Flag, ISortedColumns.Factory) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserialize(DataInput) - Method in class org.apache.cassandra.db.ColumnSerializer
 
deserialize(DataInput, IColumnSerializer.Flag) - Method in class org.apache.cassandra.db.ColumnSerializer
 
deserialize(DataInput, IColumnSerializer.Flag, int) - Method in class org.apache.cassandra.db.ColumnSerializer
 
deserialize(DataInput) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
 
deserialize(DataInput) - Static method in class org.apache.cassandra.db.filter.QueryPath
 
deserialize(DataInput, int, IColumnSerializer.Flag, ISortedColumns.Factory) - Method in class org.apache.cassandra.db.Row.RowSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.db.Row.RowSerializer
 
deserialize(DataInput, int, IColumnSerializer.Flag) - Method in class org.apache.cassandra.db.RowMutation.RowMutationSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.db.RowMutation.RowMutationSerializer
 
deserialize(DataInput) - Method in class org.apache.cassandra.db.RowPosition.RowPositionSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
 
deserialize(DataInput) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
 
deserialize(DataInput, IColumnSerializer.Flag, int) - Method in interface org.apache.cassandra.io.IColumnSerializer
 
deserialize(DataInput) - Method in interface org.apache.cassandra.io.ISerializer
Deserialize from the specified DataInput instance.
deserialize(DataInput, int) - Method in interface org.apache.cassandra.io.IVersionedSerializer
Deserialize into the specified DataInputStream instance.
deserialize(FileDataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
deserialize(Descriptor) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.SSTableMetadataSerializer
 
deserialize(DataInputStream, Descriptor) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.SSTableMetadataSerializer
 
deserialize(DataInput) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequestVerbHandler
 
deserialize(DataInputStream, int) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeResponseVerbHandler
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.streaming.PendingFile.PendingFileSerializer
 
deserialize(DataInput) - Method in class org.apache.cassandra.utils.BloomFilterSerializer
 
deserialize(DataInput) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
deserialize(TDeserializer, TBase, DataInput) - Static method in class org.apache.cassandra.utils.FBUtilities
 
deserialize(DataInputStream) - Method in class org.apache.cassandra.utils.LegacyBloomFilterSerializer
 
deserialize(DataInputStream, int) - Method in class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
 
deserializeAvro(Schema, ByteBuffer, T) - Static method in class org.apache.cassandra.db.DefsTable
Deserialize a single object based on the given Schema.
deserializeColumnFamilies(Row) - Static method in class org.apache.cassandra.config.KSMetaData
Deserialize ColumnFamilies from low-level schema representation, all of them belong to the same keyspace
deserializeColumns(DataInput, ColumnFamily, IColumnSerializer.Flag) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserializeColumns(DataInput, ColumnFamily, int, IColumnSerializer.Flag) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserializeFixingTimestamps(DataInput, int) - Method in class org.apache.cassandra.db.RowMutation.RowMutationSerializer
Used only by o.a.c.service.MigrationManager to fix possibly broken System.nanoTime() timestamps of the schema migrations from remote nodes
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
deserializeMigrationMessage(byte[], int) - Static method in class org.apache.cassandra.service.MigrationManager
Deserialize migration message considering data compatibility starting from version 1.1
destination - Variable in class org.apache.cassandra.db.compaction.Scrubber
 
destroy() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Clean up all resources obtained during the lifetime of the daemon.
destroy() - Method in interface org.apache.cassandra.service.CassandraDaemon
Clean up all resources obtained during the lifetime of the daemon.
DestructivePQIterator<T> - Class in org.apache.cassandra.utils
 
DestructivePQIterator(PriorityQueue<T>) - Constructor for class org.apache.cassandra.utils.DestructivePQIterator
 
details_ - Variable in class org.apache.cassandra.net.Header
 
determineBlockFor(ConsistencyLevel, String) - Method in class org.apache.cassandra.service.DatacenterReadCallback
 
determineBlockFor(String) - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
determineBlockFor(ConsistencyLevel, String) - Method in class org.apache.cassandra.service.ReadCallback
 
determineBlockFor(String) - Method in class org.apache.cassandra.service.WriteResponseHandler
 
dfa1 - Variable in class org.apache.cassandra.cql.CqlLexer
 
dfa1 - Variable in class org.apache.cassandra.cql.CqlParser
 
dfa1 - Variable in class org.apache.cassandra.cql3.CqlLexer
 
dfa10 - Variable in class org.apache.cassandra.cql.CqlParser
 
dfa13 - Variable in class org.apache.cassandra.cql.CqlParser
 
dfa14 - Variable in class org.apache.cassandra.cql3.CqlLexer
 
dfa15 - Variable in class org.apache.cassandra.cql.CqlLexer
 
dfa18 - Variable in class org.apache.cassandra.cli.CliLexer
 
dfa2 - Variable in class org.apache.cassandra.cli.CliParser
 
dfa2 - Variable in class org.apache.cassandra.cql3.CqlParser
 
dfa43 - Variable in class org.apache.cassandra.cql.CqlParser
 
dfa54 - Variable in class org.apache.cassandra.cql.CqlParser
 
dfa6 - Variable in class org.apache.cassandra.cli.CliParser
 
dfa7 - Variable in class org.apache.cassandra.cql.CqlLexer
 
diff(IColumn) - Method in class org.apache.cassandra.db.Column
 
diff(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamily
 
diff(ColumnFamily, ColumnFamily) - Static method in class org.apache.cassandra.db.ColumnFamily
 
diff(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Determine the count relationship between two contexts.
diff(ByteBuffer, ByteBuffer) - Method in interface org.apache.cassandra.db.context.IContext
Determine the relationship between two contexts.
diff(IColumn) - Method in class org.apache.cassandra.db.CounterColumn
 
diff(IColumn) - Method in class org.apache.cassandra.db.CounterUpdateColumn
 
diff(IColumn) - Method in interface org.apache.cassandra.db.IColumn
 
diff(IColumn) - Method in class org.apache.cassandra.db.SuperColumn
 
difference(MerkleTree, MerkleTree) - Static method in class org.apache.cassandra.utils.MerkleTree
 
differenceToFetch(Range<T>) - Method in class org.apache.cassandra.dht.Range
Calculate set of the difference ranges of given two ranges (as current (A, B] and rhs is (C, D]) which node will need to fetch when moving to a given new token
digest(ColumnFamily) - Static method in class org.apache.cassandra.db.ColumnFamily
 
digest() - Method in class org.apache.cassandra.db.ReadResponse
 
DIGEST - Static variable in class org.apache.cassandra.io.sstable.Component
 
digest() - Method in class org.apache.cassandra.io.util.SequentialWriter
Return the digest associated to this file or null if no digest was created.
DigestMismatchException - Exception in org.apache.cassandra.service
 
DigestMismatchException(DecoratedKey<?>, ByteBuffer, ByteBuffer) - Constructor for exception org.apache.cassandra.service.DigestMismatchException
 
Digit - Static variable in class org.apache.cassandra.cli.CliLexer
 
Digit - Static variable in class org.apache.cassandra.cli.CliParser
 
DIGIT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
DIGIT - Static variable in class org.apache.cassandra.cql.CqlParser
 
DIGIT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
DIGIT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
directories - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
Directories - Class in org.apache.cassandra.db
Encapsulate handling of paths to the data files.
Directories.SSTableLister - Class in org.apache.cassandra.db
 
Directories.SSTableLister() - Constructor for class org.apache.cassandra.db.Directories.SSTableLister
 
directory - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
directory - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
dirtyString() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
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.compaction.CompactionManager
 
discard(boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
Completely discards a segment file by deleting it.
discardCompletedSegments(Integer, ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLog
Modifies the per-CF dirty cursors of any commit log segments for the column family according to the position given.
discardSSTables(long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Discard all SSTables that were created before given timestamp.
disconnect() - Static method in class org.apache.cassandra.cli.CliMain
Disconnect thrift connection to cassandra instance
disk_access_mode - Variable in class org.apache.cassandra.config.Config
 
displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql.CqlLexer
 
displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql.CqlParser
 
displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql3.CqlLexer
 
displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql3.CqlParser
 
double_(String, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
DoubleLiteral - Static variable in class org.apache.cassandra.cli.CliLexer
 
DoubleLiteral - Static variable in class org.apache.cassandra.cli.CliParser
 
DoubleType - Class in org.apache.cassandra.db.marshal
 
doVerb(Message, String) - Method in class org.apache.cassandra.db.CounterMutationVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.db.DefinitionsUpdateVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.db.MigrationRequestVerbHandler
 
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 class org.apache.cassandra.gms.GossipShutdownVerbHandler
 
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
Deprecated.  
doVerb(Message, String) - Method in class org.apache.cassandra.service.RangeSliceVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.service.SnapshotVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.streaming.ReplicationFinishedVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.streaming.StreamingRepairTask.StreamingRepairRequest
 
doVerb(Message, String) - Method in class org.apache.cassandra.streaming.StreamingRepairTask.StreamingRepairResponse
 
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
 
DROP - Static variable in class org.apache.cassandra.cli.CliLexer
 
DROP - Static variable in class org.apache.cassandra.cli.CliParser
 
dropCf(Integer) - Method in class org.apache.cassandra.db.Table
 
DropColumnFamily - Class in org.apache.cassandra.db.migration.avro
 
DropColumnFamily() - Constructor for class org.apache.cassandra.db.migration.avro.DropColumnFamily
 
dropColumnFamilyStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
dropColumnFamilyStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
DropColumnFamilyStatement - Class in org.apache.cassandra.cql3.statements
 
DropColumnFamilyStatement(CFName) - Constructor for class org.apache.cassandra.cql3.statements.DropColumnFamilyStatement
 
dropFromSchema(long) - Method in class org.apache.cassandra.config.CFMetaData
Remove all CF attributes from schema
dropFromSchema(long) - Method in class org.apache.cassandra.config.KSMetaData
 
dropIndex() - Method in class org.apache.cassandra.cli.CliParser
 
dropIndexStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
DropIndexStatement - Class in org.apache.cassandra.cql
 
DropIndexStatement(String) - Constructor for class org.apache.cassandra.cql.DropIndexStatement
 
dropIndexStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
DropIndexStatement - Class in org.apache.cassandra.cql3.statements
 
DropIndexStatement(String) - Constructor for class org.apache.cassandra.cql3.statements.DropIndexStatement
 
DropKeyspace - Class in org.apache.cassandra.db.migration.avro
 
DropKeyspace() - Constructor for class org.apache.cassandra.db.migration.avro.DropKeyspace
 
dropKeyspaceStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
dropKeyspaceStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
DropKeyspaceStatement - Class in org.apache.cassandra.cql3.statements
 
DropKeyspaceStatement(String) - Constructor for class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
 
DROPPABLE_VERBS - Static variable in class org.apache.cassandra.net.MessagingService
Verbs it's okay to drop if the request has been queued longer than RPC_TIMEOUT.
dst - Variable in class org.apache.cassandra.streaming.StreamingRepairTask
 
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(Collection<KSMetaData>) - Static method in class org.apache.cassandra.db.DefsTable
 
duplicate() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
durable_writes - Variable in class org.apache.cassandra.db.migration.avro.KsDef
 
durableWrites - Variable in class org.apache.cassandra.config.KSMetaData
 
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
 
DynamicCompositeType - Class in org.apache.cassandra.db.marshal
 
DynamicEndpointSnitch - Class in org.apache.cassandra.locator
A dynamic snitch that sorts endpoints by latency with an adapted phi failure detector
DynamicEndpointSnitch(IEndpointSnitch) - Constructor for class org.apache.cassandra.locator.DynamicEndpointSnitch
 
DynamicEndpointSnitchMBean - Interface in org.apache.cassandra.locator
 

E

E - Static variable in class org.apache.cassandra.cql.CqlLexer
 
E - Static variable in class org.apache.cassandra.cql.CqlParser
 
E - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
E - Static variable in class org.apache.cassandra.cql3.CqlParser
 
Ec2MultiRegionSnitch - Class in org.apache.cassandra.locator
1) Snitch will automatically set the public IP by querying the AWS API 2) Snitch will set the private IP as a Gossip application state.
Ec2MultiRegionSnitch() - Constructor for class org.apache.cassandra.locator.Ec2MultiRegionSnitch
 
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
 
EchoedRow - Class in org.apache.cassandra.db
A CompactedRow implementation that just echos the original row bytes without deserializing.
EchoedRow(SSTableIdentityIterator) - Constructor for class org.apache.cassandra.db.EchoedRow
 
effectiveOwnership(String) - Method in class org.apache.cassandra.service.StorageService
 
effectiveOwnership(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Effective ownership is % of the data each node owns given the keyspace we calculate the percentage using replication factor.
effectiveOwnership(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
elementIdx() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
EmbeddedCassandraService - Class in org.apache.cassandra.service
An embedded, in-memory cassandra storage service that listens on the thrift interface as configured in cassandra.yaml This kind of service is useful when running unit tests of services using cassandra for example.
EmbeddedCassandraService() - Constructor for class org.apache.cassandra.service.EmbeddedCassandraService
 
emit(Token) - Method in class org.apache.cassandra.cql.CqlLexer
 
emit(Token) - Method in class org.apache.cassandra.cql3.CqlLexer
 
EMPTY_BYTE_BUFFER - Static variable in class org.apache.cassandra.utils.ByteBufferUtil
 
EMPTY_PARSER - Static variable in class org.apache.cassandra.db.marshal.TypeParser
 
EMPTY_ROW - Static variable in class org.apache.cassandra.service.AntiEntropyService.Validator
 
emptyFilter() - Static method in class org.apache.cassandra.utils.BloomFilter
 
emptyVersion - Static variable in class org.apache.cassandra.config.Schema
 
enableAutoCompaction() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
enableReserveSegmentCreation() - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
Throws a flag that enables the behavior of keeping at least one spare segment available at all times.
encloses(Interval) - Method in class org.apache.cassandra.utils.IntervalTree.Interval
 
encodedUTF8Length(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
encryption_options - Variable in class org.apache.cassandra.config.Config
 
EncryptionOptions - Class in org.apache.cassandra.config
 
EncryptionOptions() - Constructor for class org.apache.cassandra.config.EncryptionOptions
 
EncryptionOptions.InternodeEncryption - Enum in org.apache.cassandra.config
 
END_OF_SEGMENT_MARKER - Static variable in class org.apache.cassandra.db.commitlog.CommitLog
 
END_OF_SEGMENT_MARKER_SIZE - Static variable in class org.apache.cassandra.db.commitlog.CommitLog
 
endpoint - Variable in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
endpoint_snitch - Variable in class org.apache.cassandra.config.Config
 
EndpointSnitchInfo - Class in org.apache.cassandra.locator
 
EndpointSnitchInfo() - Constructor for class org.apache.cassandra.locator.EndpointSnitchInfo
 
EndpointSnitchInfoMBean - Interface in org.apache.cassandra.locator
MBean exposing standard Snitch info
EndpointState - Class in org.apache.cassandra.gms
This abstraction represents both the HeartBeatState and the ApplicationState in an EndpointState instance.
endStmnt() - Method in class org.apache.cassandra.cql.CqlParser
 
enqueue(Message, String) - Method in class org.apache.cassandra.net.OutboundTcpConnection
 
entityName() - Method in class org.apache.cassandra.cli.CliParser
 
entriesSize - Variable in class org.apache.cassandra.db.ColumnIndexer.RowHeader
 
entrySet() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
enumeratekeys(Descriptor, PrintStream) - Static method in class org.apache.cassandra.tools.SSTableExport
Enumerate row keys from an SSTableReader and write the result to a PrintStream.
EOF - Static variable in class org.apache.cassandra.cli.CliLexer
 
EOF - Static variable in class org.apache.cassandra.cli.CliParser
 
EOF - Static variable in class org.apache.cassandra.cql.CqlLexer
 
EOF - Static variable in class org.apache.cassandra.cql.CqlParser
 
EOF - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
EOF - Static variable in class org.apache.cassandra.cql3.CqlParser
 
EQ - Static variable in class org.apache.cassandra.io.sstable.SSTableReader.Operator
 
equals(Object) - Method in class org.apache.cassandra.cache.KeyCacheKey
 
equals(Object) - Method in class org.apache.cassandra.cache.RowCacheKey
 
equals(Object) - Method in class org.apache.cassandra.cache.RowCacheSentinel
 
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.cql.Term
 
equals(Object) - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
equals(Object) - Method in class org.apache.cassandra.cql3.statements.Selector.WithFunction
 
equals(Object) - Method in class org.apache.cassandra.cql3.Term
 
equals(Object) - Method in class org.apache.cassandra.db.Column
 
equals(Object) - Method in class org.apache.cassandra.db.ColumnFamily
 
equals(Object) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition
 
equals(Object) - Method in class org.apache.cassandra.db.CounterColumn
 
equals(Object) - Method in class org.apache.cassandra.db.DecoratedKey
 
equals(Object) - Method in class org.apache.cassandra.db.ExpiringColumn
 
equals(Object) - Method in class org.apache.cassandra.db.SuperColumn
 
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.ExcludingBounds
 
equals(Object) - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
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.dht.Token.KeyBound
 
equals(Object) - Method in class org.apache.cassandra.io.compress.CompressionParameters
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.Component
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
equals(Object) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
equals(Object) - Method in class org.apache.cassandra.streaming.PendingFile
 
equals(Object) - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
equals(Object) - Method in class org.apache.cassandra.utils.NodeId
 
equals(Object) - Method in class org.apache.cassandra.utils.NodeId.NodeIdRecord
 
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
 
equals(Object) - Method in class org.apache.cassandra.utils.SemanticVersion
 
err - Variable in class org.apache.cassandra.cli.CliSessionState
 
EscapeCharacter - Static variable in class org.apache.cassandra.cli.CliLexer
 
EscapeCharacter - Static variable in class org.apache.cassandra.cli.CliParser
 
EscapeSequence - Static variable in class org.apache.cassandra.cli.CliLexer
 
EscapeSequence - Static variable in class org.apache.cassandra.cli.CliParser
 
escapeSQLString(String) - Static method in class org.apache.cassandra.cli.CliUtils
 
estimatedColumnCount - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
estimatedColumnCount(EstimatedHistogram) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
estimatedColumnCount - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
 
EstimatedHistogram - Class in org.apache.cassandra.utils
 
EstimatedHistogram() - Constructor for class org.apache.cassandra.utils.EstimatedHistogram
 
EstimatedHistogram(int) - Constructor for class org.apache.cassandra.utils.EstimatedHistogram
 
EstimatedHistogram(long[], long[]) - Constructor for class org.apache.cassandra.utils.EstimatedHistogram
 
EstimatedHistogram.EstimatedHistogramSerializer - Class in org.apache.cassandra.utils
 
EstimatedHistogram.EstimatedHistogramSerializer() - Constructor for class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
estimatedKeys() - Method in class org.apache.cassandra.db.DataTracker
 
estimatedKeys() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
estimatedKeys - Variable in class org.apache.cassandra.streaming.PendingFile
 
estimatedKeysForRanges(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
estimatedRemainingTasks - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
estimatedRowSize - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
estimatedRowSize(EstimatedHistogram) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
estimatedRowSize - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
 
estimateKeys() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
estimateKeys() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
estimateSizeToSave(Set<K>) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
ExcludingBounds<T extends RingPosition> - Class in org.apache.cassandra.dht
AbstractBounds containing neither of its endpoints: (left, right).
ExcludingBounds(T, T) - Constructor for class org.apache.cassandra.dht.ExcludingBounds
 
exec(ProcessBuilder) - Static method in class org.apache.cassandra.utils.FBUtilities
Starts and waits for the given @param pb to finish.
execute(ClientState, List<ByteBuffer>) - Method in interface org.apache.cassandra.cql3.CQLStatement
Execute the statement and return the resulting result or null if there is no result.
execute(ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement.RawStatement
 
execute(ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.GrantStatement
 
execute(ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.ListGrantsStatement
 
execute(ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
execute(ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.RevokeStatement
 
execute(ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
 
execute(ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
execute(ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
 
execute(ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.UseStatement
 
execute(CompactionManager.CompactionExecutorStatsCollector) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
execute(CompactionManager.CompactionExecutorStatsCollector) - Method in class org.apache.cassandra.db.compaction.CompactionTask
For internal use and testing only.
execute(CompactionManager.CompactionExecutorStatsCollector) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
 
execute_cql_query(ByteBuffer, Compression) - Method in class org.apache.cassandra.thrift.CassandraServer
 
execute_prepared_cql_query(int, List<ByteBuffer>) - Method in class org.apache.cassandra.thrift.CassandraServer
 
executeCLIStatement(String) - Method in class org.apache.cassandra.cli.CliClient
 
executor - Variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
exhausted - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
 
EXIT - Static variable in class org.apache.cassandra.cli.CliLexer
 
EXIT - Static variable in class org.apache.cassandra.cli.CliParser
 
exitStatement() - Method in class org.apache.cassandra.cli.CliParser
 
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(Descriptor, 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(Descriptor, PrintStream, String[]) - Static method in class org.apache.cassandra.tools.SSTableExport
Export an SSTable and write the resulting JSON to a PrintStream.
export(Descriptor, String[]) - Static method in class org.apache.cassandra.tools.SSTableExport
Export an SSTable and write the resulting JSON to standard out.
ExtendedFilter - Class in org.apache.cassandra.db.filter
Extends a column filter (IFilter) to include a number of IndexExpression.
ExtendedFilter(ColumnFamilyStore, IFilter, int, boolean, boolean) - Constructor for class org.apache.cassandra.db.filter.ExtendedFilter
 
extendedTerm() - Method in class org.apache.cassandra.cql3.CqlParser
 
EXTENSION - Static variable in class org.apache.cassandra.db.compaction.LeveledManifest
 
extractExpireTime(String[]) - Method in class org.apache.cassandra.service.StorageService
 
extractKeyAliasFromColumns(CFMetaData) - Method in class org.apache.cassandra.cql.SelectStatement
 
extractKeysFromColumns(CFMetaData) - Method in class org.apache.cassandra.cql.WhereClause
 
extractThrowable(Runnable) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 

F

F - Static variable in class org.apache.cassandra.cql.CqlLexer
 
F - Static variable in class org.apache.cassandra.cql.CqlParser
 
F - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
F - Static variable in class org.apache.cassandra.cql3.CqlParser
 
factory - Static variable in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
factory() - Static method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
factory - Static variable in class org.apache.cassandra.db.AtomicSortedColumns
 
factory() - Static method in class org.apache.cassandra.db.AtomicSortedColumns
 
factory - Static variable in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
factory() - Static method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
factory - Static variable in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
factory() - Static method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
FailureDetector - Class in org.apache.cassandra.gms
This FailureDetector is an implementation of the paper titled "The Phi Accrual Failure Detector" by Hayashibara.
FailureDetector() - Constructor for class org.apache.cassandra.gms.FailureDetector
 
FailureDetectorMBean - Interface in org.apache.cassandra.gms
 
FAMILY - Static variable in class org.apache.cassandra.cli.CliLexer
 
FAMILY - Static variable in class org.apache.cassandra.cli.CliParser
 
FastByteArrayInputStream - Class in org.apache.cassandra.io.util
A specialized InputStream for reading the contents of a byte array.
FastByteArrayInputStream(byte[]) - Constructor for class org.apache.cassandra.io.util.FastByteArrayInputStream
Constructs a new ByteArrayInputStream on the byte array buf.
FastByteArrayInputStream(byte[], int, int) - Constructor for class org.apache.cassandra.io.util.FastByteArrayInputStream
Constructs a new ByteArrayInputStream on the byte array buf with the initial position set to offset and the number of bytes available set to offset + length.
FastByteArrayOutputStream - Class in org.apache.cassandra.io.util
A specialized OutputStream for class for writing content to an (internal) byte array.
FastByteArrayOutputStream() - Constructor for class org.apache.cassandra.io.util.FastByteArrayOutputStream
Constructs a new ByteArrayOutputStream with a default size of 32 bytes.
FastByteArrayOutputStream(int) - Constructor for class org.apache.cassandra.io.util.FastByteArrayOutputStream
Constructs a new ByteArrayOutputStream with a default size of size bytes.
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
 
fetch() - Method in class org.apache.cassandra.dht.RangeStreamer
 
fetchSegment() - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
Fetches an empty segment file.
FILE - Static variable in class org.apache.cassandra.cli.CliLexer
 
FILE - Static variable in class org.apache.cassandra.cli.CliParser
 
file - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
 
file - Variable in class org.apache.cassandra.streaming.StreamHeader
file being sent on initial stream
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(ColumnFamilyStore.AbstractScanIterator, ExtendedFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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
 
filterSuspectSSTables(Collection<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
Filters SSTables that are to be blacklisted from the given collection
finalizeHeader(long, int) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
finalizeMetadata(String) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
findMinMedianMax(List<Interval>) - Method in class org.apache.cassandra.utils.IntervalTree.IntervalNode
 
findSupportingVersion(SemanticVersion...) - Method in class org.apache.cassandra.utils.SemanticVersion
Returns a version that is backward compatible with this version amongst a list of provided version, or null if none can be found.
finish - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
finish - Variable in class org.apache.cassandra.db.SliceFromReadCommand
 
finishBootstrapping() - Method in class org.apache.cassandra.service.StorageService
 
finishCompaction(CompactionInfo.Holder) - Method in interface org.apache.cassandra.db.compaction.CompactionManager.CompactionExecutorStatsCollector
 
finished(PendingFile, SSTableReader) - Method in class org.apache.cassandra.streaming.StreamInSession
 
finishedAt - Variable in class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
 
finishStartup() - Static method in class org.apache.cassandra.db.SystemTable
 
first - Variable in class org.apache.cassandra.io.sstable.SSTable
 
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
 
fixCFMaxId() - Method in class org.apache.cassandra.config.Schema
This gets called after initialization to make sure that id generation happens properly.
fixSchemaNanoTimestamps() - Static method in class org.apache.cassandra.db.DefsTable
 
flag - Variable in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
flip(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
flips a bit.
flip(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
flips a bit.
flipAndGet(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
flips a bit and returns the resulting bit value.
flipAndGet(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
flips a bit and returns the resulting bit value.
FLOAT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
FLOAT - Static variable in class org.apache.cassandra.cql.CqlParser
 
FLOAT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
FLOAT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FloatType - Class in org.apache.cassandra.db.marshal
 
flush() - Method in class org.apache.cassandra.db.Table
 
flush() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
flush() - Method in class org.apache.cassandra.io.util.SequentialWriter
If buffer is dirty, flush it's contents to the operating system.
flush_largest_memtables_at - Variable in class org.apache.cassandra.config.Config
 
flushAndSignal(CountDownLatch, ExecutorService, Future<ReplayPosition>) - Method in class org.apache.cassandra.db.Memtable
 
flushData() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
flushData() - Method in class org.apache.cassandra.io.util.SequentialWriter
Override this method instead of overriding flush()
flushIndexesBlocking() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
Flush all indexes to disk
flushInProgress - Static variable in class org.apache.cassandra.cache.AutoSavingCache
True if a cache flush is currently executing: only one may execute at a time.
flushInternal() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
flushLargestMemtables() - Method in class org.apache.cassandra.service.StorageService
Flushes the two largest memtables by ops and by throughput
FOLLOW_102_in_termPairWithOperation3001 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_103_in_termPairWithOperation3042 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_105_in_connectStatement665 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_105_in_connectStatement711 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_106_in_describeCluster2782 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_106_in_helpStatement873 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_107_in_helpStatement955 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_107_in_showClusterName2317 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_108_in_helpStatement1562 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_109_in_assumeStatement2235 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_109_in_consistencyLevelStatement2277 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_109_in_getStatement1639 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_110_in_getStatement1699 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_111_in_keyValuePair2949 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_111_in_setStatement1870 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_111_in_setStatement1881 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_112_in_batchStatement1459 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_112_in_batchStatement1470 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_112_in_query75 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_113_in_cfamColumns1743 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_113_in_cfamDefinition1655 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_113_in_cfamProperty1817 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_113_in_createIndexStatement1911 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_113_in_extendedTerm2903 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_113_in_insertStatement1043 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_113_in_insertStatement999 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_113_in_relation3457 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_113_in_relation3512 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_113_in_selector768 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_113_in_selector786 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_113_in_selectStatement561 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_114_in_cfamColumns1763 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_114_in_cfamDefinition1671 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_114_in_cfamProperty1830 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_114_in_createIndexStatement1917 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_114_in_extendedTerm2909 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_114_in_insertStatement1021 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_114_in_insertStatement1064 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_114_in_relation3463 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_114_in_relation3532 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_114_in_selector774 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_114_in_selector792 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_114_in_selectStatement567 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_115_in_cfamColumns1752 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_115_in_cfamDefinition1662 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_115_in_cfamProperty1823 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_115_in_cidentList2871 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_115_in_insertStatement1010 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_115_in_insertStatement1053 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_115_in_relation3521 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_115_in_selectClause703 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_115_in_selectStatement639 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_115_in_updateStatement1286 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_116_in_dropIndex2588 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_116_in_host_name3965 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_116_in_selectClause719 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_116_in_selectCountClause833 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_117_in_arrayConstruct3034 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_117_in_cfamProperty1785 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_117_in_columnFamilyExpr3170 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_117_in_columnFamilyExpr3187 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_117_in_columnFamilyExpr3209 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_117_in_keyRangeExpr3278 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_117_in_property3267 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_117_in_termPairWithOperation3089 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_118_in_arrayConstruct3039 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_118_in_columnFamilyName2763 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_118_in_hashConstruct3087 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_119_in_arrayConstruct3044 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_119_in_columnFamilyExpr3174 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_119_in_columnFamilyExpr3193 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_119_in_columnFamilyExpr3215 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_119_in_keyRangeExpr3297 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_119_in_termPairWithOperation3123 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_120_in_hashConstruct3082 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_120_in_termPairWithOperation3158 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_121_in_hashConstruct3093 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_121_in_propertyKey3310 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_122_in_hashElementPair3131 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_122_in_keyRangeExpr3287 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_123_in_columnLimitExpr3372 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_124_in_reversedExpr3416 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_125_in_functionCall3818 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_126_in_functionCall3823 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_81_in_createColumnFamilyStatement1897 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_81_in_createIndexStatement2177 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_81_in_deleteStatement1637 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_81_in_insertStatement841 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_81_in_insertStatement883 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_81_in_selectStatement339 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_81_in_updateStatement1424 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_81_in_whereClause713 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_82_in_createColumnFamilyStatement1912 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_82_in_createIndexStatement2183 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_82_in_deleteStatement1645 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_82_in_insertStatement861 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_82_in_insertStatement901 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_82_in_selectStatement345 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_82_in_updateStatement1432 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_82_in_whereClause751 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_83_in_deleteStatement1523 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_83_in_insertStatement811 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_83_in_selectStatement388 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_83_in_truncateStatement3185 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_83_in_updateStatement1260 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_84_in_createColumnFamilyStatement1904 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_84_in_insertStatement849 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_84_in_insertStatement891 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_84_in_selectExpression579 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_84_in_termList2881 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_84_in_updateStatement1314 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_84_in_whereClause740 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_85_in_selectExpression617 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_86_in_batchStatement1123 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_86_in_batchStatement1134 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_86_in_endStmnt3224 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_87_in_alterTableStatement2586 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_87_in_alterTableStatement2623 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_87_in_createColumnFamilyStatement1937 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_87_in_createColumnFamilyStatement1969 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_87_in_createKeyspaceStatement1753 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_87_in_createKeyspaceStatement1799 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_87_in_deleteStatement1580 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_87_in_termPair2914 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_87_in_termPairWithOperation2967 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_87_in_updateStatement1340 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_addColumnFamily_in_statement504 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_addKeyspace_in_statement496 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_alterKeyspaceStatement_in_cqlStatement480 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_alterTableStatement_in_cqlStatement391 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_alterTableStatement_in_query214 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_AND_in_getStatement1704 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_AND_in_keyValuePairExpr2883 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_API_VERSION_in_helpStatement1044 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_API_VERSION_in_showVersion2627 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_arrayConstruct_in_attrValue2983 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_ASSUME_in_assumeStatement2227 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_ASSUME_in_helpStatement1489 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_assumeStatement_in_statement616 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_attr_name_in_keyValuePair2947 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_attrValue_in_keyValuePair2951 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_attrValueDouble_in_attrValue3015 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_attrValueInt_in_attrValue3007 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_attrValueString_in_attrValue2999 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_batchStatement_in_cqlStatement188 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_batchStatement_in_query105 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_batchStatementObjective_in_batchStatement1121 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_batchStatementObjective_in_batchStatement1132 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_batchStatementObjective_in_batchStatement1457 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_batchStatementObjective_in_batchStatement1468 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_BY_in_incrStatement1936 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_BY_in_incrStatement1979 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_cfamColumns_in_cfamDefinition1657 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamColumns_in_cfamDefinition1664 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamDefinition_in_createColumnFamilyStatement1636 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamOrdering_in_cfamProperty1819 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamOrdering_in_cfamProperty1825 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamProperty_in_cfamDefinition1683 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamProperty_in_cfamDefinition1690 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfOrKsName_in_columnFamilyName2760 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfOrKsName_in_columnFamilyName2767 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfOrKsName_in_keyspaceName2726 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_alterTableStatement2035 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_alterTableStatement2063 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_alterTableStatement2095 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_cfamColumns1716 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_cfamColumns1747 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_cfamColumns1756 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_cfamOrdering1858 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_cidentList2866 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_cidentList2875 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_createIndexStatement1915 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_insertStatement1003 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_insertStatement1014 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_orderByClause934 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_propertyKey3304 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_propertyKey3314 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_relation3419 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_relation3461 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_relation3500 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_selector744 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_selector772 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_selector790 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_termPairWithOperation3087 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_termPairWithOperation3119 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cidentList_in_deleteStatement1349 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cidentList_in_selectCountClause823 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_COLUMN_in_addColumnFamily2388 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COLUMN_in_delColumnFamily2542 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COLUMN_in_helpStatement1129 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COLUMN_in_helpStatement1160 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COLUMN_in_helpStatement1219 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COLUMN_in_updateColumnFamily2465 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_assumeStatement2229 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_columnFamilyExpr3168 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_delColumnFamily2546 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_dropIndex2586 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_getStatement1697 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_listStatement2141 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_truncateStatement2194 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_countStatement2028 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_delStatement2064 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_getStatement1636 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_incrStatement1933 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_incrStatement1976 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_setStatement1868 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyName_in_alterTableStatement2017 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_createColumnFamilyStatement1626 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_createIndexStatement1909 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_deleteStatement1366 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_dropColumnFamilyStatement2235 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_grantStatement2375 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_insertStatement987 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_revokeStatement2481 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_selectStatement584 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_truncateStatement2307 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_updateStatement1258 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnLimitExpr_in_listStatement2149 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnName_in_dropIndex2590 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnOrSuperColumn_in_columnFamilyExpr3191 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnOrSuperColumn_in_columnFamilyExpr3213 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnOrSuperColumn_in_getCondition1766 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_comparatorType_in_alterTableStatement2041 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_alterTableStatement2067 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_alterTableStatement2418 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_comparatorType_in_alterTableStatement2490 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_comparatorType_in_cfamColumns1720 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_createCfamColumnValidator2062 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_comparatorType_in_createCfamKeywordArgument2095 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_CONNECT_in_connectStatement661 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CONNECT_in_connectStatement707 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CONNECT_in_helpStatement791 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_connectStatement_in_statement456 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CONSISTENCYLEVEL_in_consistencyLevelStatement2275 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CONSISTENCYLEVEL_in_helpStatement1515 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_consistencyLevelStatement_in_statement624 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COUNT_in_countStatement2026 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COUNT_in_helpStatement1409 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_countStatement_in_statement472 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_cqlStatement_in_query72 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_CREATE_in_addColumnFamily2386 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CREATE_in_addKeyspace2348 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CREATE_in_helpStatement1070 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CREATE_in_helpStatement1127 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_createCfamColumns_in_createColumnFamilyStatement1899 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createCfamColumns_in_createColumnFamilyStatement1906 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createCfamColumnValidator_in_createCfamColumns2019 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createCfamColumnValidator_in_createCfamColumns2035 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createCfamKeywordArgument_in_alterTableStatement2590 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createCfamKeywordArgument_in_alterTableStatement2627 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createCfamKeywordArgument_in_createColumnFamilyStatement1941 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createCfamKeywordArgument_in_createColumnFamilyStatement1973 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createColumnFamilyStatement_in_cqlStatement307 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_createColumnFamilyStatement_in_query162 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createIndexStatement_in_cqlStatement319 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_createIndexStatement_in_query172 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createKeyspaceStatement_in_cqlStatement290 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_createKeyspaceStatement_in_query152 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_DECR_in_helpStatement1356 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DECR_in_incrStatement1974 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DEL_in_delStatement2062 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DEL_in_helpStatement1382 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_delColumnFamily_in_statement528 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_deleteStatement_in_batchStatementObjective1209 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_deleteStatement_in_batchStatementObjective1543 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_deleteStatement_in_cqlStatement214 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_deleteStatement_in_query140 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_delKeyspace_in_statement536 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_delStatement_in_statement552 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DESCRIBE_in_describeCluster2780 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DESCRIBE_in_describeTable2735 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DESCRIBE_in_helpStatement845 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DESCRIBE_in_helpStatement871 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_describeCluster_in_statement488 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_describeTable_in_statement480 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DoubleLiteral_in_attrValueDouble3527 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DROP_in_delColumnFamily2540 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DROP_in_delKeyspace2502 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DROP_in_dropIndex2580 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DROP_in_helpStatement1188 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DROP_in_helpStatement1217 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DROP_in_helpStatement1248 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_dropColumnFamilyStatement_in_cqlStatement356 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_dropColumnFamilyStatement_in_query204 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_dropIndex_in_statement632 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_dropIndexStatement_in_cqlStatement370 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_dropIndexStatement_in_query182 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_dropKeyspaceStatement_in_cqlStatement338 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_dropKeyspaceStatement_in_query194 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_alterTableStatement2640 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_batchStatement1152 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_createColumnFamilyStatement1995 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_createIndexStatement2185 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_createKeyspaceStatement1832 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_dropColumnFamilyStatement2691 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_dropIndexStatement2241 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_dropKeyspaceStatement2292 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_query142 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_query83 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_query95 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_selectStatement483 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_truncateStatement3207 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_useStatement258 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_entityName_in_assumeStatement2237 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_entityName_in_columnFamily3654 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_entityName_in_columnName3444 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_entityName_in_keyRangeExpr3284 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_entityName_in_keyRangeExpr3291 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_entityName_in_keyspace3543 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_entityName_in_keyspaceNewName3571 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_entityName_in_keyValuePairExpr2878 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_entityName_in_newColumnFamily3618 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_EOF_in_endStmnt3228 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_EOF_in_query79 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_EOF_in_root440 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_EXIT_in_exitStatement1611 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_EXIT_in_helpStatement899 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_exitStatement_in_statement464 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_extendedTerm_in_relation3488 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_FAMILY_in_addColumnFamily2390 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_FAMILY_in_delColumnFamily2544 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_FAMILY_in_helpStatement1131 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_FAMILY_in_helpStatement1162 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_FAMILY_in_helpStatement1221 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_FAMILY_in_updateColumnFamily2467 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_FLOAT_in_term2818 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_functionArgument_in_functionCall3820 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_functionCall_in_columnOrSuperColumn3907 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_functionCall_in_rowKey3715 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_functionCall_in_rowValue3753 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_functionCall_in_value3795 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_GET_in_getStatement1634 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_GET_in_getStatement1695 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_GET_in_helpStatement1276 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_getCondition_in_getStatement1701 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_getCondition_in_getStatement1706 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_getStatement_in_statement560 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_grantStatement_in_cqlStatement411 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_hashConstruct_in_arrayConstruct3037 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_hashConstruct_in_attrValue2991 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_hashConstruct_in_rowValue3757 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_hashElementPair_in_hashConstruct3084 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_hashElementPair_in_hashConstruct3089 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1008 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1040 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1068 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1097 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1125 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1156 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1186 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1215 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1246 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1274 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1301 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1328 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1354 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1380 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1407 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1434 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1461 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1487 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1513 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1539 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement762 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement764 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement789 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement816 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement843 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement869 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement897 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement924 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement951 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement979 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_helpStatement_in_statement568 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_host_in_connectStatement663 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_host_name_in_host3929 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IDENT_in_cfOrKsName2788 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IDENT_in_cident2649 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IDENT_in_createIndexStatement1901 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IDENT_in_createIndexStatement2155 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_IDENT_in_dropIndexStatement2272 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IDENT_in_term2812 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_Identifier_in_assumeStatement2233 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_attr_name3458 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_columnOrSuperColumn3891 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_command3604 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_consistencyLevelStatement2281 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_functionCall3816 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_host_name3962 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_host_name3967 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_rowKey3699 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_rowValue3737 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_username3627 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_value3779 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_INCR_in_helpStatement1330 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_INCR_in_incrStatement1931 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_incrementValue_in_incrStatement1940 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_incrementValue_in_incrStatement1983 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_incrStatement_in_statement584 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_INDEX_in_dropIndex2582 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_INDEX_in_helpStatement1250 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_insertStatement_in_batchStatementObjective1183 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_insertStatement_in_batchStatementObjective1517 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_insertStatement_in_cqlStatement138 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_insertStatement_in_query81 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_INTEGER_in_intTerm2943 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_INTEGER_in_intTerm3051 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_INTEGER_in_selectCountClause855 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_INTEGER_in_selectExpression530 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_INTEGER_in_selectStatement466 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_INTEGER_in_selectStatement662 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_INTEGER_in_term2800 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_INTEGER_in_usingClauseDeleteObjective1024 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_INTEGER_in_usingClauseDeleteObjective1187 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_INTEGER_in_usingClauseObjective1057 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_INTEGER_in_usingClauseObjective1220 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IntegerNegativeLiteral_in_columnOrSuperColumn3899 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerNegativeLiteral_in_rowKey3711 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerNegativeLiteral_in_rowValue3749 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerNegativeLiteral_in_value3787 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_columnLimitExpr3376 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_columnOrSuperColumn3895 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_getStatement1650 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_getStatement1715 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_port4029 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_rowKey3707 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_rowLimitExpr3338 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_rowValue3745 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_setStatement1885 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_value3783 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_intTerm_in_termPairWithOperation3047 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_intTerm_in_termPairWithOperation3131 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_intTerm_in_termPairWithOperation3163 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ip_address_in_connectStatement709 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IP_ADDRESS_in_ip_address3990 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_K_ADD_in_alterTableStatement2057 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ADD_in_alterTableStatement2434 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_ALTER_in_alterKeyspaceStatement1957 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALTER_in_alterTableStatement2011 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALTER_in_alterTableStatement2031 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALTER_in_alterTableStatement2326 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_ALTER_in_alterTableStatement2360 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_AND_in_alterTableStatement2611 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_AND_in_cfamDefinition1688 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AND_in_createColumnFamilyStatement1957 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_AND_in_createKeyspaceStatement1785 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_AND_in_properties3240 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AND_in_usingClause1113 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AND_in_usingClause950 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_AND_in_usingClauseDelete1145 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AND_in_usingClauseDelete982 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_AND_in_whereClause676 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_AND_in_whereClause898 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_APPLY_in_batchStatement1148 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_APPLY_in_batchStatement1484 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ASC_in_cfamOrdering1861 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ASC_in_orderByClause939 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BATCH_in_batchStatement1099 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_BATCH_in_batchStatement1150 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_BATCH_in_batchStatement1435 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BATCH_in_batchStatement1486 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BEGIN_in_batchStatement1097 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_BEGIN_in_batchStatement1433 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BY_in_cfamProperty1815 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BY_in_selectStatement632 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CLUSTERING_in_cfamProperty1811 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COLUMNFAMILY_in_alterTableStatement2013 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COLUMNFAMILY_in_alterTableStatement2328 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_COLUMNFAMILY_in_createColumnFamilyStatement1622 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COLUMNFAMILY_in_createColumnFamilyStatement1869 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_COLUMNFAMILY_in_dropColumnFamilyStatement2231 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COLUMNFAMILY_in_dropColumnFamilyStatement2673 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_COMPACT_in_cfamProperty1799 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CONSISTENCY_in_selectStatement422 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_CONSISTENCY_in_selectStatement596 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CONSISTENCY_in_usingClauseDeleteObjective1007 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_CONSISTENCY_in_usingClauseDeleteObjective1170 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COUNT_in_selectStatement337 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_COUNT_in_selectStatement559 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CREATE_in_createColumnFamilyStatement1620 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CREATE_in_createColumnFamilyStatement1867 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_CREATE_in_createIndexStatement1894 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CREATE_in_createIndexStatement2148 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_CREATE_in_createKeyspaceStatement1578 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CREATE_in_createKeyspaceStatement1708 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_DELETE_in_deleteStatement1343 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DELETE_in_deleteStatement1474 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_DESC_in_cfamOrdering1865 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DESC_in_orderByClause943 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DROP_in_alterTableStatement2090 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DROP_in_alterTableStatement2506 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_DROP_in_dropColumnFamilyStatement2229 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DROP_in_dropColumnFamilyStatement2671 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_DROP_in_dropIndexStatement2221 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_DROP_in_dropIndexStatement2266 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DROP_in_dropKeyspaceStatement2198 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DROP_in_dropKeyspaceStatement2272 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_FIRST_in_selectExpression524 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_FOR_in_listGrantsStatement2540 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FROM_in_deleteStatement1362 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FROM_in_deleteStatement1506 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_FROM_in_revokeStatement2489 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FROM_in_selectStatement371 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_FROM_in_selectStatement580 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_GRANT_in_grantStatement2341 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_GRANT_in_grantStatement2414 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_GRANTS_in_listGrantsStatement2538 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IN_in_deleteStatement1635 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_IN_in_relation3502 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IN_in_updateStatement1422 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_IN_in_whereClause711 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_INDEX_in_createIndexStatement1896 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_INDEX_in_createIndexStatement2150 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_INDEX_in_dropIndexStatement2223 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_INDEX_in_dropIndexStatement2268 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_INSERT_in_insertStatement792 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_INSERT_in_insertStatement981 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_INTO_in_insertStatement794 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_INTO_in_insertStatement983 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEY_in_cfamColumns1727 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEY_in_cfamColumns1741 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEY_in_createCfamColumns2039 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_KEY_in_term2788 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_KEYSPACE_in_alterKeyspaceStatement1959 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEYSPACE_in_createKeyspaceStatement1580 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEYSPACE_in_createKeyspaceStatement1710 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_KEYSPACE_in_dropKeyspaceStatement2200 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEYSPACE_in_dropKeyspaceStatement2274 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_LEVEL_in_selectStatement424 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_LEVEL_in_selectStatement598 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_LEVEL_in_usingClauseDeleteObjective1009 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_LEVEL_in_usingClauseDeleteObjective1172 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_LIMIT_in_selectStatement462 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_LIMIT_in_selectStatement658 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_LIST_in_listGrantsStatement2536 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ON_in_createIndexStatement1905 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ON_in_createIndexStatement2159 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_ON_in_grantStatement2361 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ON_in_revokeStatement2469 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_OPTION_in_grantStatement2416 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ORDER_in_cfamProperty1813 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ORDER_in_selectStatement630 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_PRIMARY_in_cfamColumns1725 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_PRIMARY_in_cfamColumns1739 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_PRIMARY_in_createCfamColumns2037 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_REVERSED_in_selectExpression545 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_REVOKE_in_revokeStatement2451 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_SELECT_in_selectStatement289 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_SELECT_in_selectStatement548 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_SET_in_updateStatement1280 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_SET_in_updateStatement1308 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_STORAGE_in_cfamProperty1801 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TIMESTAMP_in_usingClauseDeleteObjective1020 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_TIMESTAMP_in_usingClauseDeleteObjective1183 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TO_in_grantStatement2383 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TOKEN_in_extendedTerm2901 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TOKEN_in_relation3455 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TRUNCATE_in_truncateStatement2303 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TRUNCATE_in_truncateStatement3166 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_TTL_in_selector784 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TTL_in_usingClauseObjective1053 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_TTL_in_usingClauseObjective1216 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TYPE_in_alterTableStatement2037 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TYPE_in_alterTableStatement2414 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_UPDATE_in_updateStatement1243 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_UPDATE_in_updateStatement1254 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USE_in_useStatement238 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_USE_in_useStatement510 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USING_in_selectStatement420 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_USING_in_selectStatement594 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USING_in_usingClause1106 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USING_in_usingClause943 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_USING_in_usingClauseDelete1138 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USING_in_usingClauseDelete975 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_VALUES_in_insertStatement1031 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_VALUES_in_insertStatement871 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_WHERE_in_deleteStatement1388 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WHERE_in_deleteStatement1573 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_WHERE_in_selectStatement443 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_WHERE_in_selectStatement613 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WHERE_in_updateStatement1299 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WHERE_in_updateStatement1331 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_WITH_in_alterKeyspaceStatement1973 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WITH_in_alterTableStatement2135 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WITH_in_alterTableStatement2557 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_WITH_in_cfamDefinition1681 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WITH_in_createColumnFamilyStatement1925 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_WITH_in_createKeyspaceStatement1592 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WITH_in_createKeyspaceStatement1738 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_WITH_in_grantStatement2412 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WRITETIME_in_selector766 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_keyRangeExpr_in_listStatement2143 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_addKeyspace2350 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_delKeyspace2504 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyspace_in_delKeyspace2506 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyspace_in_describeTable2738 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_helpStatement1072 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_helpStatement1101 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_helpStatement1190 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyspace_in_showSchema2697 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_updateKeyspace2428 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyspace_in_useKeyspace2815 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyspaceName_in_alterKeyspaceStatement1963 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_keyspaceName_in_createKeyspaceStatement1584 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_keyspaceName_in_dropKeyspaceStatement2204 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_keyspaceName_in_useStatement514 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_KEYSPACES_in_helpStatement983 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACES_in_showKeyspaces2660 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyValuePair_in_keyValuePairExpr2890 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyValuePairExpr_in_addColumnFamily2392 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyValuePairExpr_in_addKeyspace2352 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyValuePairExpr_in_updateColumnFamily2469 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyValuePairExpr_in_updateKeyspace2430 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_LIMIT_in_getStatement1646 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_LIMIT_in_getStatement1711 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_LIMIT_in_rowLimitExpr3334 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_LIST_in_helpStatement1436 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_LIST_in_listStatement2139 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_listGrantsStatement_in_cqlStatement460 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_listStatement_in_statement600 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_native_type_in_comparatorType3555 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_native_type_in_unreserved_keyword3942 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ON_in_dropIndex2584 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_operator_in_getCondition1768 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_orderByClause_in_selectStatement634 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_orderByClause_in_selectStatement641 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_password_in_connectStatement672 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_password_in_connectStatement718 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_password_in_useKeyspace2826 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_permission_in_grantStatement2353 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_permission_in_revokeStatement2461 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_port_in_connectStatement667 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_port_in_connectStatement713 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_properties_in_alterKeyspaceStatement1975 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_properties_in_alterTableStatement2138 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_properties_in_createKeyspaceStatement1594 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_property_in_properties3236 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_property_in_properties3242 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_propertyKey_in_cfamProperty1783 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_propertyKey_in_property3265 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_propertyValue_in_cfamProperty1789 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_propertyValue_in_property3271 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QMARK_in_intTerm3063 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QMARK_in_term2835 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_QMARK_in_term2989 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QUIT_in_exitStatement1597 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_QUIT_in_helpStatement926 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_QUOTED_NAME_in_cfOrKsName2813 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QUOTED_NAME_in_cident2674 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_RANGEOP_in_selectExpression601 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_relation_in_whereClause660 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_relation_in_whereClause680 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_relation_in_whereClause893 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_relation_in_whereClause902 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_reversedExpr_in_columnLimitExpr3378 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_revokeStatement_in_cqlStatement436 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_rowKey_in_columnFamilyExpr3172 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_rowKey_in_hashElementPair3129 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_rowLimitExpr_in_listStatement2146 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_rowValue_in_hashElementPair3133 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SCHEMA_in_helpStatement1012 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SCHEMA_in_showSchema2694 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_selectClause_in_selectStatement554 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_selectCountClause_in_selectStatement565 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_selectExpression_in_selectStatement305 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_selectExpression_in_selectStatement343 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_selector_in_selectClause698 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_selector_in_selectClause707 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_selectStatement_in_cqlStatement113 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_selectStatement_in_query69 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_SEMICOLON_in_root437 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_alterTableStatement2332 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_alterTableStatement2382 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_alterTableStatement2456 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_alterTableStatement2528 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_alterTableStatement2578 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_alterTableStatement2615 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_attrValueInt0 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_attrValueString3475 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_comparatorType0 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createCfamKeywordArgument2107 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createColumnFamilyStatement1873 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createColumnFamilyStatement1929 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createColumnFamilyStatement1961 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createIndexStatement2163 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createKeyspaceStatement1714 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createKeyspaceStatement1743 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createKeyspaceStatement1757 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createKeyspaceStatement1789 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createKeyspaceStatement1803 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_deleteStatement1511 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_deleteStatement1529 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_dropColumnFamilyStatement2677 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_dropIndexStatement2227 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_dropKeyspaceStatement2278 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_entityName3667 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_functionArgument0 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_grantStatement2397 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_SET_in_helpStatement1303 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_incrementValue0 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_insertStatement799 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_insertStatement817 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_listGrantsStatement2544 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_set_in_native_type3595 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_set_in_operator0 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_permission2575 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_set_in_propertyValue3344 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_set_in_relation3114 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_relation3423 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_set_in_relation3467 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_set_in_revokeStatement2501 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_set_in_selectStatement376 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_selectStatement394 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_SET_in_setStatement1866 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_term2962 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_set_in_truncateStatement3171 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_truncateStatement3191 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_typeIdentifier0 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_unreserved_keyword3798 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_set_in_updateStatement1248 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_updateStatement1266 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_useStatement242 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_setStatement_in_statement576 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_helpStatement1010 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_helpStatement1042 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_helpStatement953 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_helpStatement981 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_showClusterName2315 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_showKeyspaces2658 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_showSchema2692 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_showVersion2625 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_showClusterName_in_showStatement2098 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_showKeyspaces_in_showStatement2114 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_showSchema_in_showStatement2122 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_showStatement_in_statement592 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_showVersion_in_showStatement2106 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_statement_in_root435 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_STRING_LITERAL_in_comparatorType3570 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_STRING_LITERAL_in_createCfamColumnValidator2072 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_STRING_LITERAL_in_term2794 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_StringLiteral_in_columnOrSuperColumn3903 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_StringLiteral_in_comparator3585 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_StringLiteral_in_password3639 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_StringLiteral_in_replica_placement_strategy3557 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_StringLiteral_in_rowKey3703 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_StringLiteral_in_rowValue3741 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_StringLiteral_in_value3791 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_term_in_createCfamColumns2015 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_createCfamColumns2031 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_createIndexStatement2181 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_deleteStatement1577 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_deleteStatement1584 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_extendedTerm2907 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_extendedTerm2921 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_insertStatement1047 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_insertStatement1057 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_insertStatement845 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_insertStatement853 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_insertStatement887 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_insertStatement895 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_relation3110 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_relation3136 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_relation3445 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_relation3516 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_relation3525 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_selectExpression562 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_selectExpression583 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_selectExpression599 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_selectExpression605 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_termList2876 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_termList2885 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_termPair2912 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_termPair2918 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_termPairWithOperation2965 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_termPairWithOperation2972 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_termPairWithOperation2997 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_termPairWithOperation3006 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_termPairWithOperation3103 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_updateStatement1337 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_updateStatement1344 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_whereClause696 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_whereClause717 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_whereClause744 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_termList_in_deleteStatement1490 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_termList_in_deleteStatement1641 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_termList_in_updateStatement1428 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_termPairWithOperation_in_updateStatement1282 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_termPairWithOperation_in_updateStatement1288 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_termPairWithOperation_in_updateStatement1310 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_termPairWithOperation_in_updateStatement1316 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_TRUNCATE_in_helpStatement1463 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_TRUNCATE_in_truncateStatement2192 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_truncateStatement_in_cqlStatement267 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_truncateStatement_in_query130 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_truncateStatement_in_statement608 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_TTL_in_setStatement1879 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_typeIdentifier_in_getStatement1641 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_unreserved_keyword_in_cfOrKsName2832 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unreserved_keyword_in_cident2693 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unreserved_keyword_in_propertyValue3370 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_UPDATE_in_helpStatement1099 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_UPDATE_in_helpStatement1158 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_UPDATE_in_updateColumnFamily2463 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_UPDATE_in_updateKeyspace2426 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_updateColumnFamily_in_statement520 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_updateKeyspace_in_statement512 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_updateStatement_in_batchStatementObjective1196 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_updateStatement_in_batchStatementObjective1530 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_updateStatement_in_cqlStatement163 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_updateStatement_in_query93 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_USE_in_helpStatement818 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_USE_in_useKeyspace2813 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_useKeyspace_in_statement544 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_username_in_connectStatement670 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_username_in_connectStatement716 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_username_in_useKeyspace2819 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_useStatement_in_cqlStatement239 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_useStatement_in_query115 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_usingClause_in_batchStatement1103 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_usingClause_in_batchStatement1439 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClause_in_insertStatement1076 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClause_in_insertStatement913 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_usingClause_in_updateStatement1268 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClause_in_updateStatement1292 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_usingClauseDelete_in_deleteStatement1376 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClauseDelete_in_deleteStatement1555 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_usingClauseDeleteObjective_in_usingClauseDelete1140 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClauseDeleteObjective_in_usingClauseDelete1148 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClauseDeleteObjective_in_usingClauseDelete977 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_usingClauseDeleteObjective_in_usingClauseDelete985 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_usingClauseDeleteObjective_in_usingClauseObjective1044 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_usingClauseDeleteObjective_in_usingClauseObjective1207 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClauseObjective_in_usingClause1108 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClauseObjective_in_usingClause1116 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClauseObjective_in_usingClause945 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_usingClauseObjective_in_usingClause953 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_UUID_in_term2806 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_value_in_getCondition1770 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_value_in_setStatement1874 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_whereClause_in_deleteStatement1392 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_whereClause_in_selectStatement445 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_whereClause_in_selectStatement617 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_whereClause_in_updateStatement1303 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_WITH_in_keyValuePairExpr2887 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_WITH_in_setStatement1877 - Static variable in class org.apache.cassandra.cli.CliParser
 
forceBlockingFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceBlockingFlush() - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
forceBlockingFlush() - Method in class org.apache.cassandra.db.index.SecondaryIndex
Forces this indexes in memory data to disk
forceCleanup(NodeId.OneShotRenewer) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceCleanup(NodeId.OneShotRenewer) - Method in class org.apache.cassandra.db.Table
Do a cleanup of keys that do not belong locally.
forceConviction(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
 
forceConviction(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
force conviction of endpoint in the failure detector
forceFilterFailures() - Method in class org.apache.cassandra.io.sstable.SSTableReader
For testing purposes only.
forceFlush() - 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
forceNewSegment() - Method in class org.apache.cassandra.db.commitlog.CommitLog
Forces a new segment file to be allocated and activated.
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, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
Trigger proactive repair for a table and column families.
forceTableRepair(Range<Token>, String, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceTableRepair(String, boolean, 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, boolean, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceTableRepairPrimaryRange(String, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceTableRepairPrimaryRange(String, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Triggers proactive repair but only for the node primary range.
forceTableRepairPrimaryRange(String, boolean, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceTableRepairRange(String, String, String, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceTableRepairRange(String, String, String, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Perform repair of a specific range.
forceTableRepairRange(String, String, String, boolean, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceTerminateAllRepairSessions() - Method in class org.apache.cassandra.service.StorageService
 
forceTerminateAllRepairSessions() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
forceUserDefinedCompaction(String, String) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
forceUserDefinedCompaction(String, String) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Triggers the compaction of user specified sstables.
forKey(ByteBuffer, IPartitioner) - Static method in class org.apache.cassandra.db.RowPosition
 
forProgress(long, long) - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
forString(String) - Static method in enum org.apache.cassandra.cql3.Relation.Type
 
FORWARD_HEADER - Static variable in class org.apache.cassandra.db.RowMutation
 
framed - Variable in class org.apache.cassandra.cli.CliSessionState
 
free() - Method in class org.apache.cassandra.io.util.Memory
 
FreeableMemory - Class in org.apache.cassandra.cache
 
FreeableMemory(long) - Constructor for class org.apache.cassandra.cache.FreeableMemory
 
freshSegment() - Static method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
from - Variable in class org.apache.cassandra.net.IncomingTcpConnection
 
fromByteArray(ByteBuffer) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
fromBytes(byte[], int) - Static method in class org.apache.cassandra.db.RowMutation
 
fromFilename(File, String) - Static method in class org.apache.cassandra.io.sstable.Component
Filename of the form "/-[tmp-][-]-",
fromFilename(String) - Static method in class org.apache.cassandra.io.sstable.Descriptor
 
fromFilename(File, String) - Static method in class org.apache.cassandra.io.sstable.Descriptor
Filename of the form "--[tmp-][-]-"
fromInt(int) - Static method in class org.apache.cassandra.utils.NodeId
Function for test purposes, do not use otherwise.
fromJsonList(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
fromJsonMap(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
fromSchema(UntypedResultSet.Row) - Static method in class org.apache.cassandra.config.CFMetaData
Deserialize CF metadata from low-level representation
fromSchema(Row, CFMetaData) - Static method in class org.apache.cassandra.config.ColumnDefinition
Deserialize columns from low-level representation
fromSchema(Row, Iterable<CFMetaData>) - Static method in class org.apache.cassandra.config.KSMetaData
Deserialize only Keyspace attributes without nested ColumnFamilies
fromSchema(Row, Row) - Static method in class org.apache.cassandra.config.KSMetaData
Deserialize Keyspace with nested ColumnFamilies
fromSorted(SortedMap<ByteBuffer, IColumn>, boolean) - Method in interface org.apache.cassandra.db.ISortedColumns.Factory
Returns a column map whose columns are sorted according to the comparator of the provided sorted map (which thus, is assumed to _not_ be sorted by natural order) and that initially contains the columns in the provided sorted map.
fromString(String) - Static method in enum org.apache.cassandra.config.CFMetaData.Caching
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
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.BooleanType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.BytesType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.DateType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.FloatType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
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.ReversedType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
fromString(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
fromThrift(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
 
fromThrift(ColumnDef) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
fromThrift(List<ColumnDef>) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
fromThrift(KsDef, CFMetaData...) - Static method in class org.apache.cassandra.config.KSMetaData
 
fsync(int) - Static method in class org.apache.cassandra.utils.CLibrary
 
fullRange - Variable in class org.apache.cassandra.utils.MerkleTree
The top level range that this MerkleTree covers.
FULLY_INCONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
 
function() - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
function() - Method in interface org.apache.cassandra.cql3.statements.Selector
 
function() - Method in class org.apache.cassandra.cql3.statements.Selector.WithFunction
 
FUNCTION_CALL - Static variable in class org.apache.cassandra.cli.CliLexer
 
FUNCTION_CALL - Static variable in class org.apache.cassandra.cli.CliParser
 
functionArgument() - Method in class org.apache.cassandra.cli.CliParser
 
functionCall() - Method in class org.apache.cassandra.cli.CliParser
 

G

G - Static variable in class org.apache.cassandra.cql.CqlLexer
 
G - Static variable in class org.apache.cassandra.cql.CqlParser
 
G - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
G - Static variable in class org.apache.cassandra.cql3.CqlParser
 
GC_ALL - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
 
gc_grace_seconds - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
gcBefore() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
gcBefore - Variable in class org.apache.cassandra.db.compaction.CompactionController
 
gcBefore - Variable in class org.apache.cassandra.db.compaction.CompactionTask
 
gcGraceSeconds(int) - Method in class org.apache.cassandra.config.CFMetaData
 
GCInspector - Class in org.apache.cassandra.service
 
GCInspector() - Constructor for class org.apache.cassandra.service.GCInspector
 
GE - Static variable in class org.apache.cassandra.io.sstable.SSTableReader.Operator
 
generate() - Static method in class org.apache.cassandra.utils.NodeId
 
generateCFMetadataUpdate(String) - Method in class org.apache.cassandra.cql.DropIndexStatement
 
generation - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
get(K) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
get(K) - Method in interface org.apache.cassandra.cache.ICache
 
get(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
get(Object) - Method in class org.apache.cassandra.cache.SerializingCache
 
GET - Static variable in class org.apache.cassandra.cli.CliLexer
 
GET - Static variable in class org.apache.cassandra.cli.CliParser
 
get(long, TimeUnit) - Method in class org.apache.cassandra.concurrent.CreationTimeAwareFuture
 
get() - Method in class org.apache.cassandra.concurrent.CreationTimeAwareFuture
 
get(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.CFDefinition
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.AddColumnFamily
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.AddKeyspace
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.CfDef
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.ColumnDef
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.DropColumnFamily
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.DropKeyspace
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.KsDef
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.Migration
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.UpdateColumnFamily
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.UpdateKeyspace
 
get() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.LoaderFuture
 
get(long, TimeUnit) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.LoaderFuture
 
get(Object) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
get(long, TimeUnit) - Method in interface org.apache.cassandra.net.IAsyncResult
Same operation as the above get() but allows the calling thread to specify a timeout.
get() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
get() - Method in interface org.apache.cassandra.service.IWriteResponseHandler
 
get() - Method in class org.apache.cassandra.service.ReadCallback
 
get() - Method in class org.apache.cassandra.service.RepairCallback
 
get(SocketAddress) - Method in class org.apache.cassandra.service.SocketSessionManagementService
 
get() - Method in class org.apache.cassandra.service.TruncateResponseHandler
 
get(InetAddress, long) - Static method in class org.apache.cassandra.streaming.StreamInSession
 
get(InetAddress, long) - Static method in class org.apache.cassandra.streaming.StreamOutSession
 
get(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
get(int) - Method in class org.apache.cassandra.utils.BigLongArray
 
get(K) - Method in class org.apache.cassandra.utils.ExpiringMap
 
get(List<? extends CloseableIterator<In>>, Comparator<In>, MergeIterator.Reducer<In, Out>) - Static method in class org.apache.cassandra.utils.MergeIterator
 
get(Token) - Method in class org.apache.cassandra.utils.MerkleTree
For testing purposes.
get(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns true or false for the specified bit index.
get(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns true or false for the specified bit index.
get_count(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
get_paged_slice(String, KeyRange, ByteBuffer, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
get_range_slices(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
get_slice(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
getAbstractType() - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
 
getActiveCompactions() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getActiveCount() - Method in interface org.apache.cassandra.concurrent.IExecutorMBean
Get the current number of running tasks
getActiveSegmentNames() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getActiveSegmentNames() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
 
getActiveSegments() - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
 
getActiveStreamsOutbound() - Method in class org.apache.cassandra.net.MessagingService
The count of active outbound stream tasks.
getAddressRanges(TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getAddressRanges() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getAdjustedTimestamp(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
Returns a milliseconds-since-epoch value for a type-1 UUID.
getAge(K) - Method in class org.apache.cassandra.utils.ExpiringMap
 
getAliasParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
 
getAllDataFileLocations() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getAllDataFileLocations() - Method in class org.apache.cassandra.service.StorageService
 
getAllDataFileLocations() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Get the list of all data file locations from conf
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
 
getAncestors() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getAndAppendNextComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
getAndAppendNextComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
getAndAppendNextComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
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
 
getArchivingSegmentNames() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getArchivingSegmentNames() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
 
getArray(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
You should almost never use this.
getAsToken(AbstractType<?>, List<ByteBuffer>, IPartitioner<?>) - Method in class org.apache.cassandra.cql3.Term
 
getAuthenticator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getAuthority() - Method in class org.apache.cassandra.auth.IAuthorityContainer
 
getAuthority() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getAuthorityContainer() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBackingFiles() - Method in interface org.apache.cassandra.db.compaction.ICompactionScanner
 
getBackingFiles() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
getBackupsDirectory(Descriptor) - Static method in class org.apache.cassandra.db.Directories
 
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
 
getBaseCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndex
 
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
 
getBitSet() - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
getBloomFilter() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getBloomFilterDiskSpaceUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getBloomFilterDiskSpaceUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getBloomFilterFalsePositives() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getBloomFilterFalsePositives() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getBloomFilterFalsePositives() - Method in class org.apache.cassandra.db.DataTracker
 
getBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getBloomFilterFalseRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.DataTracker
 
getBloomFilterFpChance() - Method in class org.apache.cassandra.config.CFMetaData
 
getBloomFilterSerializedSize() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getBoolean(String, Boolean) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
 
getBoolean(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getBootstrapState() - Static method in class org.apache.cassandra.db.SystemTable
 
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
getBoundsTerms() - Method in interface org.apache.cassandra.cql3.CQLStatement
Returns the number of bound terms in this statement.
getBoundsTerms() - Method in class org.apache.cassandra.cql3.statements.GrantStatement
 
getBoundsTerms() - Method in class org.apache.cassandra.cql3.statements.ParsedStatement
 
getBoundsTerms() - Method in class org.apache.cassandra.cql3.statements.RevokeStatement
 
getBoundsTerms() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
getBroadcastAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBroadcastAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getBucketOffsets() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
getBuckets(boolean) - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
getBuilder(Config.DiskAccessMode) - Static method in class org.apache.cassandra.io.util.SegmentedFile
 
getBuiltIndexes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getBuiltIndexes() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Returns a list of the names of the built column indexes for current store
getBuiltIndexes() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
getByte(long) - Method in class org.apache.cassandra.cache.FreeableMemory
 
getByte(long) - Method in class org.apache.cassandra.io.util.Memory
 
getByteBuffer(AbstractType<?>, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.Term
Returns the typed value, serialized to a ByteBuffer according to a comparator/validator.
getByteBuffer() - Method in class org.apache.cassandra.cql.Term
Returns the typed value, serialized to a ByteBuffer.
getByteBuffer(AbstractType<?>, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.Term
Returns the typed value, serialized to a ByteBuffer according to a comparator/validator.
getBytes(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getBytes(ByteBuffer, int) - Static method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
getBytes(long, byte[], int, int) - Method in class org.apache.cassandra.io.util.Memory
Transfers count bytes from Memory starting at memoryOffset to buffer starting at bufferOffset
getBytesComplete() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getBytesRead() - Method in class org.apache.cassandra.io.sstable.KeyIterator
 
getBytesRead() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
getBytesRead() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
getCachedEndpoints(Token) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getCachedPosition(DecoratedKey, boolean) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getCachePath(String, String) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
getCacheServiceMBean() - Method in class org.apache.cassandra.tools.NodeProbe
 
getCaching() - Method in class org.apache.cassandra.config.CFMetaData
 
getCapacity() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
getCF(Integer) - Method in class org.apache.cassandra.config.Schema
 
getCfDef() - Method in class org.apache.cassandra.config.CFMetaData
 
getCFMetaData(String, String) - Method in class org.apache.cassandra.config.Schema
Given a table name & column family name, get the column family meta data.
getCFMetaData(Integer) - Method in class org.apache.cassandra.config.Schema
Get ColumnFamily metadata by its identifier
getCFMetaData(Descriptor) - Method in class org.apache.cassandra.config.Schema
 
getCFMetaData(String) - Method in class org.apache.cassandra.cql.AlterTableStatement
 
getCFMetaData(String, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
Returns a CFMetaData instance based on the parameters parsed from this CREATE statement, or defaults where applicable.
getCFMetaData() - Method in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement
Returns a CFMetaData instance based on the parameters parsed from this CREATE statement, or defaults where applicable.
getCFMetaData() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
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
 
getClause() - Method in class org.apache.cassandra.db.filter.ExtendedFilter
 
getClientFromInputAddressList(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getClientFromOutputAddressList(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getClock() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
getClusterName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getColumn(Tree, int) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
getColumn(ByteBuffer) - Method in interface org.apache.cassandra.db.ISortedColumns
Get a column given its name, returning null if the column is not present.
getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
getColumn_metadata() - Method in class org.apache.cassandra.config.CFMetaData
 
getColumnAliases() - Method in class org.apache.cassandra.config.CFMetaData
 
getColumnByIdxName(String) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
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
 
getColumnCount() - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
getColumnCount() - Method in interface org.apache.cassandra.db.columniterator.ICountableColumnIterator
 
getColumnCount() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
getColumnDefinition(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
 
getColumnDefinitionComparator(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
 
getColumnDefinitionComparator(Integer) - Method in class org.apache.cassandra.config.CFMetaData
 
getColumnDefinitionForIndex(String) - Method in class org.apache.cassandra.config.CFMetaData
 
getColumnFamilies() - Method in class org.apache.cassandra.db.RowMutation
 
getColumnFamily(Tree, List<CfDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getColumnFamily(String, List<CfDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getColumnFamily() - Method in class org.apache.cassandra.cql.AbstractModification
 
getColumnFamily() - Method in class org.apache.cassandra.cql.CreateIndexStatement
Column family namespace.
getColumnFamily() - Method in class org.apache.cassandra.cql.SelectStatement
 
getColumnFamily() - Method in class org.apache.cassandra.cql.UpdateStatement
 
getColumnFamily() - Method in class org.apache.cassandra.cql3.CFName
 
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(QueryFilter, ISortedColumns.Factory) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getColumnFamily() - Method in interface org.apache.cassandra.db.columniterator.IColumnIterator
 
getColumnFamily() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
getColumnFamily() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
getColumnFamily() - Method in class org.apache.cassandra.db.compaction.CompactionController
 
getColumnFamily() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getColumnFamily(DecoratedKey) - Method in class org.apache.cassandra.db.Memtable
 
getColumnFamily(Integer) - Method in class org.apache.cassandra.db.RowMutation
 
getColumnFamily() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
getColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
getColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
 
getColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleWriter
 
getColumnFamilyIds() - Method in class org.apache.cassandra.db.CounterMutation
 
getColumnFamilyIds() - Method in interface org.apache.cassandra.db.IMutation
 
getColumnFamilyIds() - Method in class org.apache.cassandra.db.RowMutation
 
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() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
getColumnFamilyStore(String) - Method in class org.apache.cassandra.db.Table
 
getColumnFamilyStore(Integer) - Method in class org.apache.cassandra.db.Table
 
getColumnFamilyStoreMBeanProxies() - Method in class org.apache.cassandra.tools.NodeProbe
 
getColumnFamilyStores() - Method in class org.apache.cassandra.db.Table
 
getColumnFamilyType(String, String) - Method in class org.apache.cassandra.config.Schema
Get type of the ColumnFamily but it's keyspace/name
getColumnFamilyWithColumns() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
getColumnFinish() - Method in class org.apache.cassandra.cql.SelectStatement
 
getColumnIndexSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getColumnName() - Method in class org.apache.cassandra.cql.CreateIndexStatement
Column name to index.
getColumnNameBuilder() - Method in class org.apache.cassandra.cql3.CFDefinition
 
getColumnNames() - Method in class org.apache.cassandra.cql.SelectStatement
 
getColumnNames() - Method in class org.apache.cassandra.cql.UpdateStatement
 
getColumnNames() - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
getColumnNames() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
getColumnNames() - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
getColumnNames() - Method in interface org.apache.cassandra.db.ISortedColumns
Returns a set with the names of columns in this column map.
getColumnNames() - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
getColumnNames() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
getColumnRelations() - Method in class org.apache.cassandra.cql.SelectStatement
 
getColumnRelations() - Method in class org.apache.cassandra.cql.WhereClause
 
getColumns() - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
 
getColumns() - Method in class org.apache.cassandra.cql.DeleteStatement
 
getColumns() - Method in class org.apache.cassandra.cql.SelectExpression
 
getColumns() - Method in class org.apache.cassandra.cql.UpdateStatement
 
getColumnSerializer() - Method in class org.apache.cassandra.config.CFMetaData
 
getColumnSerializer() - Method in class org.apache.cassandra.db.ColumnFamily
 
getColumnsLimit() - Method in class org.apache.cassandra.cql.SelectExpression
 
getColumnsLimit() - Method in class org.apache.cassandra.cql.SelectStatement
 
getColumnsString(Collection<IColumn>) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
getColumnStart() - Method in class org.apache.cassandra.cql.SelectStatement
 
getColumnValues() - Method in class org.apache.cassandra.cql.UpdateStatement
 
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
getCommandDroppedTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getCommandDroppedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Dropped tasks for Command(Mutations, Read etc) TCP Connections
getCommandPendingTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getCommandPendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Pending tasks for Command(Mutations, Read etc) TCP Connections
getComment() - Method in class org.apache.cassandra.config.CFMetaData
 
getCommitLogLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCommitLogLocation() - Method in class org.apache.cassandra.service.StorageService
 
getCommitLogLocation() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Get location of the commit log
getCommitLogSegmentSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
size of commitlog segments to allocate
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(List<SSTableIdentityIterator>) - Method in class org.apache.cassandra.db.compaction.CompactionController
 
getCompactedRow(SSTableIdentityIterator) - Method in class org.apache.cassandra.db.compaction.CompactionController
convenience method for single-sstable compactions
getCompactionCandidates() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
getCompactionInfo() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
 
getCompactionInfo() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
getCompactionInfo() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
 
getCompactionInfo() - Method in class org.apache.cassandra.db.index.SecondaryIndexBuilder
 
getCompactionLock() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getCompactionManagerProxy() - Method in class org.apache.cassandra.tools.NodeProbe
 
getCompactions() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getCompactions() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
List of running compaction objects.
getCompactionStrategy() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getCompactionStrategyClass() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getCompactionStrategyClass() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Gets the compaction strategy class name
getCompactionSummary() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getCompactionSummary() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
List of running compaction summary strings.
getCompactionThreshold(PrintStream, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
Get the compaction threshold
getCompactionThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
 
getCompactionThroughputMbPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCompactionThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
 
getCompactionThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getComparator(String, String) - Method in class org.apache.cassandra.config.Schema
Get column comparator for ColumnFamily but it's keyspace/name
getComparator() - Method in class org.apache.cassandra.cql.CFPropDefs
 
getComparator(String) - Method in class org.apache.cassandra.cql.SelectStatement
 
getComparator(String) - Method in class org.apache.cassandra.cql.UpdateStatement
 
getComparator() - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
getComparator() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
getComparator() - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
getComparator() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getComparator() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
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.ThreadSafeSortedColumns
 
getComparator() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
getComparator(AbstractType<?>, boolean) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
 
getComparator() - Method in interface org.apache.cassandra.io.util.IIterableColumns
 
getComparatorFor(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
 
getComparatorFor(String, String, ByteBuffer) - Static method in class org.apache.cassandra.db.ColumnFamily
 
getComparatorSerializedSize() - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
 
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.commitlog.CommitLog
 
getCompletedTasks() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
Get the number of completed tasks
getCompletedTasks() - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
Get the number of completed tasks
getCompletedTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getCompletedTasks() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
 
getCompressedBuilder() - Static method in class org.apache.cassandra.io.util.SegmentedFile
 
getCompressionMetadata() - Method in class org.apache.cassandra.io.sstable.SSTableReader
Returns the compression metadata for this sstable.
getCompressionParameters() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getCompressionParameters() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Get the compression parameters
getCompressionRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getCompressionRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getCompressionRatio() - Method in class org.apache.cassandra.db.DataTracker
 
getCompressionRatio() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getConcurrentCompactors() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConcurrentReaders() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConcurrentReplicators() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConcurrentWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCondition() - Method in class org.apache.cassandra.cli.CliParser
 
getConnection(InetAddress, Message) - Method in class org.apache.cassandra.net.MessagingService
 
getConnectionPool(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
getConsistencyLevel() - Method in class org.apache.cassandra.cql.AbstractModification
 
getConsistencyLevel() - Method in class org.apache.cassandra.cql.Attributes
 
getConsistencyLevel() - Method in class org.apache.cassandra.cql.BatchStatement
 
getConsistencyLevel() - Method in class org.apache.cassandra.cql.SelectStatement
 
getConsistencyLevel() - Method in class org.apache.cassandra.cql.UpdateStatement
Returns the consistency level of this UPDATE statement, either one parsed from the CQL statement, or the default level otherwise.
getConsistencyLevel() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
getContext() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getContext() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getContextMapping(PendingFile) - Static method in class org.apache.cassandra.streaming.StreamIn
Translates remote files to local files by creating a local sstable per remote sstable.
getCorePoolSize() - Method in interface org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutorMBean
 
getCount() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
getCQL3Prepared() - Method in class org.apache.cassandra.service.ClientState
 
getCQLSupportedVersion() - Static method in class org.apache.cassandra.service.ClientState
 
getCQLVersion() - Method in class org.apache.cassandra.service.ClientState
 
getCurrentGenerationNumber(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
getCurrentGenerationNumber(String) - Method in class org.apache.cassandra.gms.Gossiper
 
getCurrentGenerationNumber(String) - Method in interface org.apache.cassandra.gms.GossiperMBean
 
getCurrentGenerationNumber() - Method in class org.apache.cassandra.service.StorageService
 
getCurrentGenerationNumber() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Return the generation value for this node.
getCurrentGenerationNumber() - Method in class org.apache.cassandra.tools.NodeProbe
 
getCurrentKey() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
getCurrentLocalNodeId() - Static method in class org.apache.cassandra.db.SystemTable
Read the current local node id from the system table or null if no such node id is recorded.
getCurrentlyBlockedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
getCurrentlyBlockedTasks() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
Get the number of tasks currently blocked, waiting to be accepted by the executor (because all threads are busy and the backing queue is full).
getCurrentPosition() - Method in interface org.apache.cassandra.db.compaction.ICompactionScanner
 
getCurrentPosition() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
getCurrentValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
getData() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
Returns the current contents of the buffer.
getData() - Method in interface org.apache.cassandra.service.IResponseResolver
returns the data response without comparing with any digests
getData() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
getData() - Method in class org.apache.cassandra.service.RowDigestResolver
Special case of resolve() so that CL.ONE reads never throw DigestMismatchException in the foreground
getData() - Method in class org.apache.cassandra.service.RowRepairResolver
 
getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
Return the data center for which an endpoint resides in
getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.Ec2Snitch
 
getDatacenter(String) - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
 
getDatacenter(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
Provides the Datacenter name depending on the respective snitch used, given the hostname/ip
getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
Return the data center for which an endpoint resides in
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
 
getDataCenter() - Method in class org.apache.cassandra.tools.NodeProbe
 
getDatacenters() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
getDataTracker() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Package protected for access from the CompactionManager.
getDcLocalReadRepair() - Method in class org.apache.cassandra.config.CFMetaData
 
getDefaultCallbackTimeout() - Static method in class org.apache.cassandra.net.MessagingService
 
getDefaultIndexName(String, AbstractType<?>, ByteBuffer) - Static method in class org.apache.cassandra.config.CFMetaData
 
getDefaultValidator() - Method in class org.apache.cassandra.config.CFMetaData
 
getDeletionInfo() - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
 
getDeletionInfo() - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
getDeletionInfo() - Method in interface org.apache.cassandra.db.ISortedColumns
 
getDestinations() - Static method in class org.apache.cassandra.streaming.StreamOutSession
 
getDirectoryForNewSSTables(long) - Method in class org.apache.cassandra.db.Directories
 
getDirectScanner() - Method in class org.apache.cassandra.io.sstable.SSTableReader
Direct I/O SSTableScanner
getDirectScanner(Range<Token>) - Method in class org.apache.cassandra.io.sstable.SSTableReader
Direct I/O SSTableScanner over a defined range of tokens.
getDirtyCFIDs() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getDiskAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDouble(String, Double) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
 
getDouble(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
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
getDroppedMessages() - Method in class org.apache.cassandra.net.MessagingService
 
getDroppedMessages() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
dropped message counts for server lifetime
getDroppedMessages() - Method in class org.apache.cassandra.net.OutboundTcpConnection
 
getDroppedMessages() - Method in class org.apache.cassandra.tools.NodeProbe
 
getDynamicBadnessThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDynamicResetInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDynamicUpdateInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getEncryptionOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getEndpoint(Range<Token>) - 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
 
getEndpoint() - Method in class org.apache.cassandra.tools.NodeProbe
 
getEndpointDowntime(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
getEndpointDowntime(String) - Method in class org.apache.cassandra.gms.Gossiper
 
getEndpointDowntime(String) - Method in interface org.apache.cassandra.gms.GossiperMBean
 
getEndpointInfo(InetAddress) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
Get the raw information about an end point
getEndpoints(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getEndpointSnitch() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getEndpointSnitchInfoProxy() - Method in class org.apache.cassandra.tools.NodeProbe
 
getEndpointState(String) - Method in class org.apache.cassandra.gms.FailureDetector
 
getEndpointState(String) - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
getEndpointStateForEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
getEndpointStates() - Method in class org.apache.cassandra.gms.Gossiper
 
getEndpointToRangesMap() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
 
getEndToken() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
getEntity() - Method in class org.apache.cassandra.cql.Relation
 
getEntity() - Method in class org.apache.cassandra.cql3.Relation
 
getEntryIterator(RowPosition, RowPosition) - Method in class org.apache.cassandra.db.Memtable
 
getEstimatedColumnCount() - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
getEstimatedColumnCount() - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
 
getEstimatedColumnCount() - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
getEstimatedColumnCount() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
getEstimatedColumnCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getEstimatedColumnCount() - Method in interface org.apache.cassandra.io.util.IIterableColumns
 
getEstimatedColumnCountHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getEstimatedColumnCountHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getEstimatedColumnCountHistogram() - Method in class org.apache.cassandra.db.DataTracker
 
getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
getEstimatedRowSize() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getEstimatedRowSizeHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getEstimatedRowSizeHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getEstimatedRowSizeHistogram() - Method in class org.apache.cassandra.db.DataTracker
 
getEstimatedTasks() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
getExceptionCount() - Method in class org.apache.cassandra.service.StorageService
 
getExceptionCount() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getExceptionCount() - Method in class org.apache.cassandra.tools.NodeProbe
 
getExpectedCompactedFileSize(Iterable<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Calculate expected file size of SSTable after compaction.
getExpireTimeForEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
getExtraFilter(ColumnFamily) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
Returns a filter to query the columns from the clause that the initial slice filter may not have caught.
getFactory() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
getFactory() - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
getFactory() - Method in interface org.apache.cassandra.db.ISortedColumns
Returns the factory used for this ISortedColumns implementation.
getFactory() - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
getFactory() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
getFailedHosts() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.LoaderFuture
 
getFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getfd(FileDescriptor) - Static method in class org.apache.cassandra.utils.CLibrary
Get system file descriptor from FileDescriptor object.
getFileDataInput(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
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.SSTableWriter
 
getFilePointer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
getFilePointer() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
getFiles() - Method in class org.apache.cassandra.streaming.StreamOutSession
 
getFilesDestinedFor(InetAddress) - Method in class org.apache.cassandra.tools.NodeProbe
 
getFilter(SlicePredicate, AbstractType<?>) - Static method in class org.apache.cassandra.db.filter.QueryFilter
 
getFilter(long, int) - Static method in class org.apache.cassandra.utils.BloomFilter
 
getFilter(long, double) - Static method in class org.apache.cassandra.utils.BloomFilter
 
getFilter(long, int) - Static method in class org.apache.cassandra.utils.LegacyBloomFilter
 
getFilter(long, double) - Static method in class org.apache.cassandra.utils.LegacyBloomFilter
 
getFinish() - Method in class org.apache.cassandra.cql.SelectExpression
 
getFinishKey() - Method in class org.apache.cassandra.cql.WhereClause
 
getFlushLargestMemtablesAt() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFlushPath(long, String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getFlushQueueSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFlushWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFrom() - Method in interface org.apache.cassandra.net.IAsyncResult
 
getFrom() - Method in class org.apache.cassandra.net.Message
 
getFullColumnFamily() - Method in class org.apache.cassandra.db.compaction.PrecompactedRow
 
getFunctionNames() - Static method in enum org.apache.cassandra.cli.CliClient.Function
 
getGcGraceSeconds() - Method in class org.apache.cassandra.config.CFMetaData
 
getGossipInfo() - Method in class org.apache.cassandra.tools.NodeProbe
 
getGrammarFileName() - Method in class org.apache.cassandra.cli.CliLexer
 
getGrammarFileName() - Method in class org.apache.cassandra.cli.CliParser
 
getGrammarFileName() - Method in class org.apache.cassandra.cql.CqlLexer
 
getGrammarFileName() - Method in class org.apache.cassandra.cql.CqlParser
 
getGrammarFileName() - Method in class org.apache.cassandra.cql3.CqlLexer
 
getGrammarFileName() - Method in class org.apache.cassandra.cql3.CqlParser
 
getHashBuckets(ByteBuffer) - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
getHeader(String) - Method in class org.apache.cassandra.net.Message
 
getHeapMemoryUsage() - Method in class org.apache.cassandra.tools.NodeProbe
 
getHintedHandoffEnabled() - Method in class org.apache.cassandra.service.StorageProxy
 
getHintedHandoffEnabled() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getHintedHandoffThrottleDelay() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getHintsInProgress() - Method in class org.apache.cassandra.service.StorageProxy
 
getHintsInProgress() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getHits() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
getHost() - Method in class org.apache.cassandra.streaming.AbstractStreamSession
 
getId(String, String) - Method in class org.apache.cassandra.config.Schema
Lookup keyspace/ColumnFamily identifier
getId() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getIdentityFilter(DecoratedKey<?>, QueryPath) - Static method in class org.apache.cassandra.db.filter.QueryFilter
return a QueryFilter object that includes every column in the row.
getIncomingFiles(String) - Method in class org.apache.cassandra.streaming.StreamingService
details about incoming streams.
getIncomingFiles(String) - Method in interface org.apache.cassandra.streaming.StreamingServiceMBean
details about incoming streams
getIncomingFiles(InetAddress) - Static method in class org.apache.cassandra.streaming.StreamInSession
query the status of incoming files.
getIncomingFiles(InetAddress) - Method in class org.apache.cassandra.tools.NodeProbe
 
getIndexAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getIndexCfs() - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
getIndexCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndex
Allow access to the underlying column family store if there is one
getIndexedColumns() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
getIndexedIterator(AbstractBounds<RowPosition>, ExtendedFilter) - Method in class org.apache.cassandra.db.index.keys.KeysSearcher
 
getIndexes() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
getIndexesBackedByCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
getIndexesNotBackedByCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
getIndexForColumn(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
getIndexInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getIndexKeyFor(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
Returns the decoratedKey for a column value
getIndexName() - Method in class org.apache.cassandra.config.ColumnDefinition
 
getIndexName() - Method in class org.apache.cassandra.cql.CreateIndexStatement
Index name (or null).
getIndexName() - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
getIndexName() - Method in class org.apache.cassandra.db.index.SecondaryIndex
 
getIndexOperator(String) - Static method in class org.apache.cassandra.cli.CliUtils
Returns IndexOperator from string representation
getIndexOptions() - Method in class org.apache.cassandra.config.ColumnDefinition
 
getIndexType() - Method in class org.apache.cassandra.config.ColumnDefinition
 
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
 
getInputFormat() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
getInputInitialAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputIsWide(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputKeyRange(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
may be null if unset
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
 
getInputPartitioner(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputRpcPort(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputSlicePredicate(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputSplitSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputTransportFactory(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.CompositeType
 
getInstance(List<AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.CompositeType
 
getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
getInstance(Map<Byte, AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.ReversedType
 
getInstance(AbstractType<T>) - Static method in class org.apache.cassandra.db.marshal.ReversedType
 
getInt(String, Integer) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
 
getInt(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getInternal(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
getInternalReply(byte[], int) - Method in class org.apache.cassandra.net.Message
 
getIntersectingIntervals(List<Interval>) - Method in class org.apache.cassandra.utils.IntervalTree.IntervalNode
 
getInValues() - Method in class org.apache.cassandra.cql3.Relation
 
getIterator(Iterable<Memtable>, Collection<SSTableReader>, RowPosition, RowPosition, QueryFilter, ColumnFamilyStore) - Static method in class org.apache.cassandra.db.RowIteratorFactory
Get a row iterator over the provided memtables and sstables, between the provided keys and filtered by the queryfilter.
getJdbcType() - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcType
 
getJdbcType() - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcUUID
 
getJdbcType() - Method in class org.apache.cassandra.cql.jdbc.JdbcAscii
 
getJdbcType() - Method in class org.apache.cassandra.cql.jdbc.JdbcBoolean
 
getJdbcType() - Method in class org.apache.cassandra.cql.jdbc.JdbcBytes
 
getJdbcType() - Method in class org.apache.cassandra.cql.jdbc.JdbcDate
 
getJdbcType() - Method in class org.apache.cassandra.cql.jdbc.JdbcDecimal
 
getJdbcType() - Method in class org.apache.cassandra.cql.jdbc.JdbcDouble
 
getJdbcType() - Method in class org.apache.cassandra.cql.jdbc.JdbcFloat
 
getJdbcType() - Method in class org.apache.cassandra.cql.jdbc.JdbcInt32
 
getJdbcType() - Method in class org.apache.cassandra.cql.jdbc.JdbcInteger
 
getJdbcType() - Method in class org.apache.cassandra.cql.jdbc.JdbcLong
 
getJdbcType() - Method in class org.apache.cassandra.cql.jdbc.JdbcUTF8
 
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
 
getKeyAlias() - Method in class org.apache.cassandra.config.CFMetaData
 
getKeyAlias() - Method in class org.apache.cassandra.cql.SelectStatement
 
getKeyAlias() - Method in class org.apache.cassandra.cql.WhereClause
 
getKeyAsBytes(String, Tree) - Method in class org.apache.cassandra.cli.CliClient
 
getKeyCache() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getKeyCacheCapacityInBytes() - Method in class org.apache.cassandra.service.CacheService
 
getKeyCacheCapacityInBytes() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getKeyCacheCapacityInMB() - Method in class org.apache.cassandra.service.CacheService
 
getKeyCacheCapacityInMB() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getKeyCacheHits() - Method in class org.apache.cassandra.service.CacheService
 
getKeyCacheHits() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getKeyCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getKeyCacheRecentHitRate() - Method in class org.apache.cassandra.service.CacheService
 
getKeyCacheRecentHitRate() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getKeyCacheRequests() - Method in class org.apache.cassandra.service.CacheService
 
getKeyCacheRequests() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getKeyCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getKeyCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
 
getKeyCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getKeyCacheSize() - Method in class org.apache.cassandra.service.CacheService
 
getKeyCacheSize() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getKeyCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getKeyFinish() - Method in class org.apache.cassandra.cql.SelectStatement
 
getKeyName() - Method in class org.apache.cassandra.config.CFMetaData
 
getKeys() - Method in class org.apache.cassandra.cql.DeleteStatement
 
getKeys() - Method in class org.apache.cassandra.cql.SelectStatement
 
getKeys() - Method in class org.apache.cassandra.cql.UpdateStatement
 
getKeys() - Method in class org.apache.cassandra.cql.WhereClause
 
getKeys() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
getKeySamples() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getKeySamples(Range<Token>) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getKeySet() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
getKeySpace() - Method in class org.apache.cassandra.cli.CliClient
 
getKeySpace(Tree, List<KsDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getKeySpace(String, List<KsDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getKeyspace() - Method in class org.apache.cassandra.cql.AbstractModification
 
getKeyspace() - Method in class org.apache.cassandra.cql.SelectStatement
 
getKeyspace() - Method in class org.apache.cassandra.cql3.CFName
 
getKeyspace() - Method in class org.apache.cassandra.db.compaction.CompactionController
 
getKeyspace() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getKeyspace() - Method in class org.apache.cassandra.db.RangeSliceCommand
 
getKeyspace() - Method in class org.apache.cassandra.db.ReadCommand
 
getKeyspace() - Method in class org.apache.cassandra.service.ClientState
 
getKeyspace() - Method in interface org.apache.cassandra.service.IReadCommand
 
getKeySpaceDef(String, List<KsDef>) - Static method in class org.apache.cassandra.cli.CliUtils
Parse the statement from cli and return KsDef
getKeyspaces() - Method in class org.apache.cassandra.service.StorageService
 
getKeyspaces() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getKeyspaces() - Method in class org.apache.cassandra.tools.NodeProbe
 
getKeyStart() - Method in class org.apache.cassandra.cql.SelectStatement
 
getKeyType() - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
 
getKeyType(String) - Method in class org.apache.cassandra.cql.UpdateStatement
 
getKeyValidator() - Method in class org.apache.cassandra.config.CFMetaData
 
getKeyValueParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
 
getKSMetaData(String) - Method in class org.apache.cassandra.cli.CliClient
 
getKSMetaData(String) - Method in class org.apache.cassandra.config.Schema
Get metadata about table by its name
getLastMigrationId() - Static method in class org.apache.cassandra.service.MigrationManager
Deprecated. 
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
 
getLeftIntervals(List<Interval>) - Method in class org.apache.cassandra.utils.IntervalTree.IntervalNode
 
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.
getLengthInBytes() - Method in interface org.apache.cassandra.db.compaction.ICompactionScanner
 
getLengthInBytes() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
getLevel(int) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
getLevelCount() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
getLevelSize(int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
getLevelSize(int) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
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
 
getLimit() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
getListenAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getLiveColumnCount() - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
getLiveColumnCount() - Method in class org.apache.cassandra.db.Row
 
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, RingPosition) - Method in class org.apache.cassandra.service.StorageService
 
getLiveNodes() - Method in class org.apache.cassandra.service.StorageService
 
getLiveNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve the list of live nodes in the cluster, where "liveness" is determined by the failure detector of the node being queried.
getLiveNodes() - Method in class org.apache.cassandra.tools.NodeProbe
 
getLiveSize() - Method in class org.apache.cassandra.db.DataTracker
 
getLiveSize() - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
getLiveSize() - Method in class org.apache.cassandra.db.index.SecondaryIndex
Get current amount of memory this index is consuming (in bytes)
getLiveSize() - Method in class org.apache.cassandra.db.Memtable
 
getLiveSSTableCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getLiveSSTableCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getLoad() - Method in class org.apache.cassandra.service.StorageService
raw load value
getLoad() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Numeric load value.
getLoadInfo() - Method in class org.apache.cassandra.service.LoadBroadcaster
 
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
 
getLoadYaml() - Static method in class org.apache.cassandra.config.Config
 
getLocalAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
Please use getBroadcastAddress instead.
getLocalDeletionTime() - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.Column
 
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
 
getLocalId() - Static method in class org.apache.cassandra.utils.NodeId
 
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
 
getLocationWithMaximumAvailableSpace(long) - Method in class org.apache.cassandra.db.Directories
 
getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.Column
 
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
 
getMaxCompactionThreshold() - Method in class org.apache.cassandra.config.CFMetaData
 
getMaxDataAge(Collection<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
 
getMaxHintsInProgress() - Method in class org.apache.cassandra.service.StorageProxy
 
getMaxHintsInProgress() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
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
 
getMaximalTask(int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getMaximalTask(int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
getMaximalTask(int) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
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
getMaxLiveColumns() - Method in class org.apache.cassandra.service.AbstractRowResolver
 
getMaxLiveColumns() - Method in interface org.apache.cassandra.service.IResponseResolver
 
getMaxLiveColumns() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
getMaxLiveColumns() - Method in class org.apache.cassandra.service.RepairCallback
 
getMaxLiveColumns() - Method in class org.apache.cassandra.service.RowRepairResolver
 
getMaxRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMaxRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getMaxRowSize() - Method in class org.apache.cassandra.db.DataTracker
 
getMaxSizeFile(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMaxSSTableSize() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getMaxSSTableSize() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
getMaxSSTableSize() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
getMaxStreamingRetries() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getMaxTimestamp() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getMeanColumns() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMeanColumns() - Method in class org.apache.cassandra.db.DataTracker
 
getMeanRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMeanRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getMeanRowSize() - Method in class org.apache.cassandra.db.DataTracker
 
getMemtable() - Method in class org.apache.cassandra.db.DataTracker
 
getMemtableColumnIterator(ColumnFamily, DecoratedKey<?>) - 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<?>) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getMemtableColumnIterator(Memtable) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
getMemtableColumnIterator(ColumnFamily, DecoratedKey<?>) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
getMemtableColumnIterator(ColumnFamily, DecoratedKey<?>) - 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.
getMemtablesPendingFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMemtablesPendingFlush() - Method in class org.apache.cassandra.db.DataTracker
 
getMemtableSwitchCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMemtableSwitchCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Returns the number of times that a flush has resulted in the memtable being switched out.
getMessage() - Method in exception org.apache.cassandra.auth.PermissionDenied
 
getMessage(Integer) - Method in class org.apache.cassandra.db.IndexScanCommand
 
getMessage(Integer) - Method in class org.apache.cassandra.db.RangeSliceCommand
 
getMessage(Integer) - Method in class org.apache.cassandra.db.ReadCommand
 
getMessage(Integer) - Method in class org.apache.cassandra.db.RowMutation
 
getMessage(StorageService.Verb, int) - Method in class org.apache.cassandra.db.RowMutation
 
getMessage(Integer) - Method in class org.apache.cassandra.db.SnapshotCommand
 
getMessage(Integer) - Method in class org.apache.cassandra.db.Truncation
 
getMessage(Integer) - Method in class org.apache.cassandra.net.CachingMessageProducer
 
getMessage(Integer) - Method in interface org.apache.cassandra.net.MessageProducer
 
getMessageBody() - Method in class org.apache.cassandra.net.Message
 
getMessages() - Method in class org.apache.cassandra.service.AbstractRowResolver
 
getMessages() - Method in interface org.apache.cassandra.service.IResponseResolver
 
getMessages() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
getMessageType() - Method in class org.apache.cassandra.net.Message
 
getMinCompactionThreshold() - Method in class org.apache.cassandra.config.CFMetaData
 
getMinimalKey(DecoratedKey<?>) - Static method in class org.apache.cassandra.io.sstable.SSTable
If the given @param key occupies only part of a larger buffer, allocate a new buffer that is only as large as necessary.
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
 
getMinRowSize() - Method in class org.apache.cassandra.db.DataTracker
 
getMinSSTableSize() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
getMovingEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
Endpoints which are migrating to the new tokens
getMovingNodes() - Method in class org.apache.cassandra.service.StorageService
 
getMovingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve the list of nodes currently moving in the ring.
getMovingNodes() - Method in class org.apache.cassandra.tools.NodeProbe
 
getMutations(String, ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.BatchStatement
 
getMutations(ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
getMutations(ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
 
getMutations(ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
Convert statement into a list of mutations to apply on the server
getMutations(ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
Convert statement into a list of mutations to apply on the server
getName() - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
Name of the column family to create
getName() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
 
getName() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getNameComparatorForResultSet(CFDefinition.Name) - Method in class org.apache.cassandra.cql3.CFDefinition
 
getNameForSystemTable(ByteBuffer) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
 
getNameForSystemTable(ByteBuffer) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
 
getNameForSystemTable(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
Return the unique name for this index and column to be stored in the SystemTable that tracks if each column is built
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(RingPosition) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
get the (possibly cached) endpoints that should store the given Token.
getNaturalEndpoints(String, String, String) - Method in class org.apache.cassandra.service.StorageService
This method returns the N endpoints that are responsible for storing the specified key i.e for replication.
getNaturalEndpoints(String, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
 
getNaturalEndpoints(String, RingPosition) - 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, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
This method returns the N endpoints that are responsible for storing the specified key i.e for replication.
getNaturalEndpoints(String, ByteBuffer) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getNewInOrderSSTable() - Method in class org.apache.cassandra.db.compaction.Scrubber
 
getNewSSTable() - Method in class org.apache.cassandra.db.compaction.Scrubber
 
getNext() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
the only difference between background and maximal in LCS is that maximal is still allowed (by explicit user request) even when compaction is disabled.
getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
getNextComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
getNextComparator(int, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
getNextComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
getNextComparator(int, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
getNextComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
getNextComparator(int, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
getNextId() - Static method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getNextVersion() - Static method in class org.apache.cassandra.gms.VersionGenerator
 
getNextWide() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
getNodeId() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
getNodeProbe() - Method in class org.apache.cassandra.cli.CliSessionState
 
getNonSystemTables() - Method in class org.apache.cassandra.config.Schema
 
getNormalAndBootstrappingTokenToEndpointMap() - Method in class org.apache.cassandra.locator.TokenMetadata
 
getNumRecords() - Method in class org.apache.cassandra.cql.SelectStatement
 
getNumWords() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Expert: gets the number of longs in the array that are in use
getOldLocalNodeIds() - Static method in class org.apache.cassandra.db.SystemTable
 
getOldLocalNodeIds() - Static method in class org.apache.cassandra.utils.NodeId
Return the list of old local node id of this node.
getOnDiskFilePointer() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
getOnDiskFilePointer() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
getOnDiskFilePointer() - Method in class org.apache.cassandra.io.util.SequentialWriter
Return the current file pointer of the underlying on-disk file.
getOpCount() - Method in class org.apache.cassandra.utils.LatencyTracker
 
getOperationMode() - Method in class org.apache.cassandra.service.StorageService
 
getOperationMode() - Method in interface org.apache.cassandra.service.StorageServiceMBean
get the operational mode (leaving, joining, normal, decommissioned, client)
getOperationMode() - Method in class org.apache.cassandra.tools.NodeProbe
 
getOperations() - Method in class org.apache.cassandra.db.Memtable
 
getOperations() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
 
getOptions() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getOrCreateLeveledManifest() - Method in class org.apache.cassandra.db.Directories
 
getOriginalRequestedCount() - Method in class org.apache.cassandra.db.RetriedSliceFromReadCommand
 
getOriginalRequestedCount() - Method in class org.apache.cassandra.db.SliceFromReadCommand
The original number of columns requested by the user.
getOutboundBindAny() - Static method in class org.apache.cassandra.config.Config
 
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.BulkOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
The OutputCommitter for this format does not write any data to the DFS.
getOutputCompressionChunkLength(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputCompressionClass(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputCompressionParamaters(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputFormat() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
getOutputInitialAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
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
 
getOutputPartitioner(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputRpcPort(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputTransportFactory(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOverlappingSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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
 
getPage(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
getPageCount() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
getPageSize() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
getPartitioner() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPartitioner() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
 
getPartitioner() - Static method in class org.apache.cassandra.service.StorageService
 
getPartitionKeys(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
getPath() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getPath() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
getPath() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
getPath() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
getPath() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
getPath() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
getPathInfo() - Method in interface org.apache.cassandra.cache.CacheKey
 
getPathInfo() - Method in class org.apache.cassandra.cache.KeyCacheKey
 
getPathInfo() - Method in class org.apache.cassandra.cache.RowCacheKey
 
getPendingAddressRanges(TokenMetadata, Token, InetAddress) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getPendingFiles() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.LoaderFuture
 
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.commitlog.CommitLog
 
getPendingTasks() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
Get the number of tasks waiting to be executed
getPendingTasks() - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
Get the number of tasks waiting to be executed
getPendingTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getPendingTasks() - Method in interface org.apache.cassandra.db.compaction.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
 
getPos() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
getPosition(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
getPosition(RowPosition, SSTableReader.Operator) - Method in class org.apache.cassandra.io.sstable.SSTableReader
Get position updating key cache and stats.
getPosition(RowPosition, SSTableReader.Operator, boolean) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getPosition() - Method in class org.apache.cassandra.io.util.AbstractDataInput
 
getPosition() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
getPosition() - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
getPositionsForRanges(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.SSTableReader
Determine the minimal set of sections that can be extracted from this SSTable to cover the given ranges.
getPrecision(T) - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcType
 
getPrecision(UUID) - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcUUID
 
getPrecision(String) - Method in class org.apache.cassandra.cql.jdbc.JdbcAscii
 
getPrecision(Boolean) - Method in class org.apache.cassandra.cql.jdbc.JdbcBoolean
 
getPrecision(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcBytes
 
getPrecision(Date) - Method in class org.apache.cassandra.cql.jdbc.JdbcDate
 
getPrecision(BigDecimal) - Method in class org.apache.cassandra.cql.jdbc.JdbcDecimal
 
getPrecision(Double) - Method in class org.apache.cassandra.cql.jdbc.JdbcDouble
 
getPrecision(Float) - Method in class org.apache.cassandra.cql.jdbc.JdbcFloat
 
getPrecision(Integer) - Method in class org.apache.cassandra.cql.jdbc.JdbcInt32
 
getPrecision(BigInteger) - Method in class org.apache.cassandra.cql.jdbc.JdbcInteger
 
getPrecision(Long) - Method in class org.apache.cassandra.cql.jdbc.JdbcLong
 
getPrecision(String) - Method in class org.apache.cassandra.cql.jdbc.JdbcUTF8
 
getPredecessor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getPreheatKeyCache() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPrepared() - Method in class org.apache.cassandra.service.ClientState
 
getPrimaryRange() - Method in class org.apache.cassandra.service.StorageService
 
getPrimaryRange() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the local node's primary range.
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
 
getProperty(String) - Method in class org.apache.cassandra.cql.CFPropDefs
 
getPropertyBoolean(String, Boolean) - Method in class org.apache.cassandra.cql.CFPropDefs
 
getPropertyDouble(String, Double) - Method in class org.apache.cassandra.cql.CFPropDefs
 
getPropertyInt(String, Integer) - Method in class org.apache.cassandra.cql.CFPropDefs
 
getPropertyString(String, String) - Method in class org.apache.cassandra.cql.CFPropDefs
 
getProtectedConstructor(Class, Class...) - Static method in class org.apache.cassandra.utils.Hex
Used to get access to protected/private constructor of the specified class
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
 
getQueryMap(String) - Static method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
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 class org.apache.cassandra.locator.GossipingPropertyFileSnitch
Return the rack for which an endpoint resides in
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
 
getRack() - Method in class org.apache.cassandra.tools.NodeProbe
 
getRandomToken() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
getRandomToken() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getRandomToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
getRandomToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getRandomToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getRange(ByteBuffer) - Method in class org.apache.cassandra.client.RingCache
 
getRangeAddresses(TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getRangeBatchSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
The number of rows to request with each get range slices request.
getRangeOperations() - Method in class org.apache.cassandra.service.StorageProxy
 
getRangeOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRangeSlice(ByteBuffer, AbstractBounds<RowPosition>, int, IFilter, List<IndexExpression>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRangeSlice(ByteBuffer, AbstractBounds<RowPosition>, int, IFilter, List<IndexExpression>, boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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 listen addresses.
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.
getRangeToRpcaddressMap(String) - Method in class org.apache.cassandra.service.StorageService
for a keyspace, return the ranges and corresponding RPC addresses for a given keyspace.
getRangeToRpcaddressMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve a map of range to rpc addresses that describe the ring topology of a Cassandra cluster.
getRawCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRawKeyspace() - Method in class org.apache.cassandra.service.ClientState
 
getReadConsistencyLevel(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getReadCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getReadCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getReadOperations() - Method in class org.apache.cassandra.service.StorageProxy
 
getReadOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getReadRepairChance() - Method in class org.apache.cassandra.config.CFMetaData
 
getRecentBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getRecentBloomFilterFalsePositives() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentBloomFilterFalsePositives() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentBloomFilterFalsePositives() - Method in class org.apache.cassandra.db.DataTracker
 
getRecentBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentBloomFilterFalseRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.DataTracker
 
getRecentBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getRecentFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getRecentHitRate() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
getRecentLatencyHistogramMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
 
getRecentLatencyHistogramMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
 
getRecentLatencyMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
 
getRecentLatencyMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
returns microseconds
getRecentlyDroppedMessages() - Method in class org.apache.cassandra.net.MessagingService
 
getRecentlyDroppedMessages() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
dropped message counts since last called
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
 
getRecentTimeoutsPerHost() - Method in class org.apache.cassandra.net.MessagingService
 
getRecentTimeoutsPerHost() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Number of timeouts since last check per host.
getRecentTotalTimouts() - Method in class org.apache.cassandra.net.MessagingService
 
getRecentTotalTimouts() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Number of timeouts since last check.
getRecentTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getRecentWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRecentWriteLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentWriteLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentWriteLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentWriteLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRecognitionErrors() - Method in class org.apache.cassandra.cql.CqlLexer
 
getRecognitionErrors() - Method in class org.apache.cassandra.cql.CqlParser
 
getRecognitionErrors() - Method in class org.apache.cassandra.cql3.CqlLexer
 
getRecognitionErrors() - Method in class org.apache.cassandra.cql3.CqlParser
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
Deprecated. 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
 
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.db.compaction.CompactionIterable.Reducer
 
getReduced() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
 
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
 
getRemainingPart() - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
 
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
 
getReplaceToken() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getReplayPosition(Iterable<? extends SSTableReader>) - Static method in class org.apache.cassandra.db.commitlog.ReplayPosition
Convenience method to compute the replay position for a group of SSTables.
getReplayPosition() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getReplicateOnWrite() - Method in class org.apache.cassandra.config.CFMetaData
 
getReplicationFactor() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
calculate the RF based on strategy_options.
getReplicationFactor() - Method in class org.apache.cassandra.locator.LocalStrategy
 
getReplicationFactor() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
getReplicationFactor(String) - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
getReplicationFactor() - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
 
getReplicationFactor() - Method in class org.apache.cassandra.locator.SimpleStrategy
 
getReplicationOptions() - Method in class org.apache.cassandra.cql3.KSPropDefs
 
getReplicationStrategy() - Method in class org.apache.cassandra.db.Table
 
getReplicationStrategyClass() - Method in class org.apache.cassandra.cql3.KSPropDefs
 
getReply(Message) - Method in class org.apache.cassandra.db.RangeSliceReply
 
getReply(InetAddress, byte[], int) - Method in class org.apache.cassandra.net.Message
 
getRequests() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
getRequestScheduler() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRequestSchedulerId() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRequestSchedulerOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getResetInterval() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getResetInterval() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
getResponse(ReadCommand, Row) - Static method in class org.apache.cassandra.db.ReadVerbHandler
 
getResponseCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getResponseCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Completed tasks for Response(GOSSIP & RESPONSE) TCP Connections
getResponsePendingTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getResponsePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Pending tasks for Response(GOSSIP & RESPONSE) TCP Connections
getReverseComparator() - Method in class org.apache.cassandra.db.marshal.AbstractType
Deprecated. use reverseComparator field instead
getReverseSortedColumns() - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
getReverseSortedColumns() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
getReverseSortedColumns() - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
getReverseSortedColumns() - Method in interface org.apache.cassandra.db.ISortedColumns
Returns the columns of this column map as a collection.
getReverseSortedColumns() - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
getReverseSortedColumns() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
getRightIntervals(List<Interval>) - Method in class org.apache.cassandra.utils.IntervalTree.IntervalNode
 
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
 
getRowCacheCapacityInBytes() - Method in class org.apache.cassandra.service.CacheService
 
getRowCacheCapacityInBytes() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getRowCacheCapacityInMB() - Method in class org.apache.cassandra.service.CacheService
 
getRowCacheCapacityInMB() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getRowCacheHits() - Method in class org.apache.cassandra.service.CacheService
 
getRowCacheHits() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getRowCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRowCacheProvider() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRowCacheRecentHitRate() - Method in class org.apache.cassandra.service.CacheService
 
getRowCacheRecentHitRate() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getRowCacheRequests() - Method in class org.apache.cassandra.service.CacheService
 
getRowCacheRequests() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getRowCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRowCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
 
getRowCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getRowCacheSize() - Method in class org.apache.cassandra.service.CacheService
 
getRowCacheSize() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getRowCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcaddress(InetAddress) - Method in class org.apache.cassandra.service.StorageService
Return the rpc address associated with an endpoint as a string.
getRpcKeepAlive() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcMaxThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcMinThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcPort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcRecvBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcSendBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcServerType() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
 
getRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getSavedCachesLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSavedCachesLocation() - Method in class org.apache.cassandra.service.StorageService
 
getSavedCachesLocation() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Get location of the saved caches dir
getSavedToken() - Static method in class org.apache.cassandra.db.SystemTable
 
getScale(T) - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcType
 
getScale(UUID) - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcUUID
 
getScale(String) - Method in class org.apache.cassandra.cql.jdbc.JdbcAscii
 
getScale(Boolean) - Method in class org.apache.cassandra.cql.jdbc.JdbcBoolean
 
getScale(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcBytes
 
getScale(Date) - Method in class org.apache.cassandra.cql.jdbc.JdbcDate
 
getScale(BigDecimal) - Method in class org.apache.cassandra.cql.jdbc.JdbcDecimal
 
getScale(Double) - Method in class org.apache.cassandra.cql.jdbc.JdbcDouble
 
getScale(Float) - Method in class org.apache.cassandra.cql.jdbc.JdbcFloat
 
getScale(Integer) - Method in class org.apache.cassandra.cql.jdbc.JdbcInt32
 
getScale(BigInteger) - Method in class org.apache.cassandra.cql.jdbc.JdbcInteger
 
getScale(Long) - Method in class org.apache.cassandra.cql.jdbc.JdbcLong
 
getScale(String) - Method in class org.apache.cassandra.cql.jdbc.JdbcUTF8
 
getScanner(QueryFilter) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getScanners(Collection<SSTableReader>, Range<Token>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
Returns a list of KeyScanners given sstables and a range on which to scan.
getScanners(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getScanners(Collection<SSTableReader>, Range<Token>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
getSchedulingValue() - Method in class org.apache.cassandra.service.ClientState
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.AddColumnFamily
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.AddKeyspace
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.CfDef
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.ColumnDef
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.DropColumnFamily
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.DropKeyspace
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.KsDef
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.Migration
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.UpdateColumnFamily
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.UpdateKeyspace
 
getSchema(String) - Static method in class org.apache.cassandra.db.SystemTable
 
getSchema(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
getSchemaKSKey(String) - Static method in class org.apache.cassandra.db.SystemTable
 
getSchemaVersion() - Method in class org.apache.cassandra.service.StorageService
 
getSchemaVersion() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Fetch a string representation of the current Schema version.
getSchemaVersion() - Method in class org.apache.cassandra.tools.NodeProbe
 
getScores() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getScores() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
getScrubInfo() - Method in class org.apache.cassandra.db.compaction.Scrubber
 
getSeeds() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSeeds() - Method in interface org.apache.cassandra.locator.SeedProvider
 
getSeeds() - Method in class org.apache.cassandra.locator.SimpleSeedProvider
 
getSegment(long) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile
 
getSegment(long) - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
 
getSegment(long) - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile
 
getSegment(long) - Method in class org.apache.cassandra.io.util.SegmentedFile
 
getSequentialIterator(ByteBuffer, AbstractBounds<RowPosition>, IFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Iterate over a range of rows and columns from memtables/sstables.
getSerializedBuffer(int) - Method in class org.apache.cassandra.db.RowMutation
 
getSerializedCachePath(String, String, CacheService.CacheType) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSerializedSize() - Method in class org.apache.cassandra.db.Memtable
 
getServerSocket(EncryptionOptions, InetAddress, int) - Static method in class org.apache.cassandra.security.SSLFactory
 
getSessionId() - Method in class org.apache.cassandra.streaming.AbstractStreamSession
 
getShortLength(ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
getShortName(AbstractType<?>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
 
getShortTypeName(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.statements.SelectStatement
 
getSimple(String) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
 
getSimpleStates() - Method in class org.apache.cassandra.gms.FailureDetector
 
getSimpleStates() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
getSliceFilter(DecoratedKey<?>, QueryPath, ByteBuffer, ByteBuffer, boolean, int) - Static method in class org.apache.cassandra.db.filter.QueryFilter
 
getSliceIterator(DecoratedKey, ColumnFamily, SliceQueryFilter) - 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.
getSnapshotDirectory(Descriptor, String) - Static method in class org.apache.cassandra.db.Directories
 
getSnapshotSSTableReader(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getSocket(EncryptionOptions, InetAddress, int, InetAddress, int) - Static method in class org.apache.cassandra.security.SSLFactory
Create a socket and connect
getSocket(EncryptionOptions, InetAddress, int) - Static method in class org.apache.cassandra.security.SSLFactory
Create a socket and connect, using any local address
getSocket(EncryptionOptions) - Static method in class org.apache.cassandra.security.SSLFactory
Just create a socket
getSocket() - Method in class org.apache.cassandra.thrift.TCustomSocket
Returns a reference to the underlying socket.
getSortedColumns() - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
getSortedColumns() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
getSortedColumns() - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
getSortedColumns() - Method in interface org.apache.cassandra.db.IColumnContainer
 
getSortedColumns() - Method in interface org.apache.cassandra.db.ISortedColumns
Returns the columns of this column map as a collection.
getSortedColumns() - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
getSortedColumns() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
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
getSourceFlag() - Method in class org.apache.cassandra.streaming.AbstractStreamSession
 
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(JobConf, int) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
 
getSplits(String, String, Range<Token>, int) - Method in class org.apache.cassandra.service.StorageService
 
getSpProxy() - Method in class org.apache.cassandra.tools.NodeProbe
 
getSSLStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSStable() - Method in interface org.apache.cassandra.db.columniterator.ISSTableColumnIterator
 
getSStable() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
getSStable() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey<?>) - Method in interface org.apache.cassandra.db.filter.IFilter
Get an iterator that returns columns from the given SSTable using the opened file matching the Filter criteria in sorted order.
getSSTableColumnIterator(SSTableReader, DecoratedKey<?>) - Method in interface org.apache.cassandra.db.filter.IFilter
returns an iterator that returns columns from the given SSTable matching the Filter criteria in sorted order.
getSSTableColumnIterator(SSTableReader, DecoratedKey<?>) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey<?>) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getSSTableColumnIterator(SSTableReader) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey<?>) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
getSSTableColumnIterator(SSTableReader, DecoratedKey<?>) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey<?>) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getSSTables() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
getSSTables() - Method in class org.apache.cassandra.db.DataTracker
 
getSSTables(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getSSTablesForKey(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getSSTablesForKey(String) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Returns a list of filenames that contain the given key on this node
getSstablesIterated() - Method in class org.apache.cassandra.db.CollationController
 
getSSTablesPerReadHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getSSTablesPerReadHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getStage(Stage) - Static method in class org.apache.cassandra.concurrent.StageManager
Retrieve a stage from the StageManager
getStart() - Method in class org.apache.cassandra.cql.SelectExpression
 
getStartKey() - Method in class org.apache.cassandra.cql.WhereClause
 
getStartToken() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
getStatement() - Method in class org.apache.cassandra.cli.CliParser
 
getStatements() - Method in class org.apache.cassandra.cql.BatchStatement
 
getStatistics(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
getStatus() - Method in class org.apache.cassandra.streaming.StreamingService
 
getStatus() - Method in interface org.apache.cassandra.streaming.StreamingServiceMBean
What's currently happening wrt streaming.
getStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getStrategyClass() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
 
getStrategyOptions() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
 
getStreamDestinations() - Method in class org.apache.cassandra.streaming.StreamingService
hosts receiving outgoing streams.
getStreamDestinations() - Method in interface org.apache.cassandra.streaming.StreamingServiceMBean
hosts recieving outgoing streams
getStreamDestinations() - Method in class org.apache.cassandra.tools.NodeProbe
 
getStreamingSocketTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
 
getStreamThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
 
getStreamThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getStreamThroughputOutboundMegabitsPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getString(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcAscii
 
getString(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcBoolean
 
getString(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcBytes
 
getString(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcDate
 
getString(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcDecimal
 
getString(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcDouble
 
getString(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcFloat
 
getString(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcInt32
 
getString(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcInteger
 
getString(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcLexicalUUID
 
getString(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcLong
 
getString(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcTimeUUID
 
getString(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcUTF8
 
getString(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcUUID
 
getString(String, String) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
 
getString(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getString(AbstractType<?>) - Method in class org.apache.cassandra.db.Column
 
getString(AbstractType<?>) - Method in class org.apache.cassandra.db.CounterColumn
 
getString(AbstractType<?>) - Method in class org.apache.cassandra.db.ExpiringColumn
 
getString(AbstractType<?>) - Method in interface org.apache.cassandra.db.IColumn
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
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.BooleanType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DateType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
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.ReversedType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
getString(AbstractType<?>) - Method in class org.apache.cassandra.db.SuperColumn
 
getStringMap(Map<CharSequence, CharSequence>) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
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) - Method in class org.apache.cassandra.config.Schema
Get subComparator of the ColumnFamily
getSubComparator() - Method in class org.apache.cassandra.db.ColumnFamily
 
getSubsnitchClassName() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getSubsnitchClassName() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
getSuccessor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getSuccessor(InetAddress) - Method in class org.apache.cassandra.service.StorageService
 
getTable() - Method in class org.apache.cassandra.db.CounterMutation
 
getTable() - Method in interface org.apache.cassandra.db.IMutation
 
getTable() - Method in class org.apache.cassandra.db.RowMutation
 
getTableDefinition(String) - Method in class org.apache.cassandra.config.Schema
Get metadata about table by its name
getTableDefinitions() - Method in class org.apache.cassandra.config.Schema
 
getTableInstance(String) - Method in class org.apache.cassandra.config.Schema
Get table instance by name
getTableMetaData(String) - Method in class org.apache.cassandra.config.Schema
Get metadata about table inner ColumnFamilies
getTableName() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getTables() - Method in class org.apache.cassandra.config.Schema
 
getTaskType() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getTaskType() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
getTempSSTablePath(File, String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTempSSTablePath(File) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getText() - Method in class org.apache.cassandra.cql.Term
Returns the text parsed to create this term.
getText() - Method in class org.apache.cassandra.cql3.Term
Returns the text parsed to create this term.
getThreadPoolMBeanProxies() - Method in class org.apache.cassandra.tools.NodeProbe
 
getThriftFramedTransportSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getThriftMaxMessageLength() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTimeoutsPerHost() - Method in class org.apache.cassandra.net.MessagingService
 
getTimeoutsPerHost() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Number of timeouts per host
getTimestamp(ClientState) - Method in class org.apache.cassandra.cql.AbstractModification
 
getTimestamp() - Method in class org.apache.cassandra.cql.Attributes
 
getTimestamp(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
getTimestamp() - Method in class org.apache.cassandra.service.ClientState
This clock guarantees that updates from a given client will be ordered in the sequence seen, even if multiple updates happen in the same millisecond.
getTimestampedSnapshotName(String) - Static method in class org.apache.cassandra.db.Table
 
getTimeToLive() - Method in class org.apache.cassandra.cql.AbstractModification
 
getTimeToLive() - Method in class org.apache.cassandra.cql.Attributes
 
getTimeToLive() - Method in class org.apache.cassandra.cql.BatchStatement
 
getTimeToLive() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
getTimeToLive() - Method in class org.apache.cassandra.db.ExpiringColumn
 
getTimeUUIDBytes() - Static method in class org.apache.cassandra.utils.UUIDGen
Returns a 16 byte representation of a type 1 UUID (a time-based UUID), based on the current system time.
getTimeUUIDBytes(long) - Static method in class org.apache.cassandra.utils.UUIDGen
Converts a milliseconds-since-epoch timestamp into the 16 byte representation of a type 1 UUID (a time-based UUID).
getToken() - Method in class org.apache.cassandra.db.DecoratedKey
 
getToken() - Method in class org.apache.cassandra.db.RowPosition
 
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() - Method in interface org.apache.cassandra.dht.RingPosition
 
getToken() - Method in class org.apache.cassandra.dht.Token
 
getToken() - Method in class org.apache.cassandra.dht.Token.KeyBound
 
getToken(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getToken() - Method in class org.apache.cassandra.service.StorageService
 
getToken() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Fetch a string representation of the token.
getToken() - Method in class org.apache.cassandra.tools.NodeProbe
 
getTokenFactory() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
getTokenFactory() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getTokenFactory() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
getTokenFactory() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getTokenFactory() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getTokenMetadata() - Method in class org.apache.cassandra.service.StorageService
 
getTokenNames() - Method in class org.apache.cassandra.cli.CliParser
 
getTokenNames() - Method in class org.apache.cassandra.cql.CqlParser
 
getTokenNames() - Method in class org.apache.cassandra.cql3.CqlParser
 
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
 
getTokenToEndpointMapForReading() - Method in class org.apache.cassandra.locator.TokenMetadata
 
getTopLevelColumns() - Method in class org.apache.cassandra.db.CollationController
 
getTotalBlockedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
getTotalBlockedTasks() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
Get the number of tasks that had blocked before being accepted (or rejected).
getTotalBytes() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getTotalBytes() - Method in class org.apache.cassandra.io.sstable.KeyIterator
 
getTotalBytes() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
getTotalBytes(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.SSTable
 
getTotalBytesCompacted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getTotalBytesCompacted() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
 
getTotalCommitlogSize() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getTotalCommitlogSize() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
Get the current size used by all the commitlog segments.
getTotalCommitlogSpaceInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTotalCompactionsCompleted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getTotalCompactionsCompleted() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
 
getTotalDiskSpaceUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTotalDiskSpaceUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getTotalHints() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalHints() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalLatencyHistogramMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
 
getTotalLatencyHistogramMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
 
getTotalLatencyMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
 
getTotalLatencyMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
returns microseconds
getTotalLiveSize() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
getTotalMemtableLiveSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTotalMemtableSpaceInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTotalRangeLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalRangeLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalRangeLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalRangeLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalReadLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalReadLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTotalReadLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getTotalReadLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalReadLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalSize() - Method in class org.apache.cassandra.db.DataTracker
 
getTotalTimeouts() - Method in class org.apache.cassandra.net.MessagingService
 
getTotalTimeouts() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Total number of timeouts happened on this node
getTotalWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalWriteLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTotalWriteLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getTotalWriteLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalWriteLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.addColumnFamily_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.addKeyspace_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.arrayConstruct_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.assumeStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.attr_name_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.attrValue_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.attrValueDouble_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.attrValueInt_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.attrValueString_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.columnFamily_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.columnFamilyExpr_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.columnLimitExpr_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.columnName_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.columnOrSuperColumn_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.command_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.comparator_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.connectStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.consistencyLevelStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.countStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.delColumnFamily_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.delKeyspace_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.delStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.describeCluster_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.describeTable_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.dropIndex_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.entityName_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.exitStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.functionArgument_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.functionCall_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.getCondition_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.getStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.hashConstruct_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.hashElementPair_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.helpStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.host_name_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.host_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.incrementValue_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.incrStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.ip_address_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.keyRangeExpr_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.keyspace_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.keyspaceNewName_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.keyValuePair_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.keyValuePairExpr_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.listStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.newColumnFamily_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.operator_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.password_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.port_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.replica_placement_strategy_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.reversedExpr_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.root_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.rowKey_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.rowLimitExpr_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.rowValue_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.setStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.showClusterName_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.showKeyspaces_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.showSchema_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.showStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.showVersion_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.statement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.truncateStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.typeIdentifier_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.updateColumnFamily_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.updateKeyspace_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.useKeyspace_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.username_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.value_return
 
getTreeAdaptor() - Method in class org.apache.cassandra.cli.CliParser
 
getTrickleFsync() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTrickleFsyncIntervalInKb() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getType() - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcType
 
getType() - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcUUID
 
getType() - Method in class org.apache.cassandra.cql.jdbc.JdbcAscii
 
getType() - Method in class org.apache.cassandra.cql.jdbc.JdbcBoolean
 
getType() - Method in class org.apache.cassandra.cql.jdbc.JdbcBytes
 
getType() - Method in class org.apache.cassandra.cql.jdbc.JdbcDate
 
getType() - Method in class org.apache.cassandra.cql.jdbc.JdbcDecimal
 
getType() - Method in class org.apache.cassandra.cql.jdbc.JdbcDouble
 
getType() - Method in class org.apache.cassandra.cql.jdbc.JdbcFloat
 
getType() - Method in class org.apache.cassandra.cql.jdbc.JdbcInt32
 
getType() - Method in class org.apache.cassandra.cql.jdbc.JdbcInteger
 
getType() - Method in class org.apache.cassandra.cql.jdbc.JdbcLong
 
getType() - Method in class org.apache.cassandra.cql.jdbc.JdbcUTF8
 
getType() - Method in class org.apache.cassandra.cql.Term
Obtain the term's type.
getType() - Method in class org.apache.cassandra.cql3.Term
Obtain the term's type.
getType() - Method in class org.apache.cassandra.db.ColumnFamily
 
getTypeByFunction(String) - Static method in class org.apache.cassandra.cli.CliClient
Get AbstractType by function name
getTypeForComparator(String) - Static method in class org.apache.cassandra.cql.jdbc.TypesMap
 
getTypeParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
 
getUncompactingSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getUncompactingSSTables() - Method in class org.apache.cassandra.db.DataTracker
 
getUnleveledSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getUnleveledSSTables() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
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
 
getUpdateTimestamp() - Method in class org.apache.cassandra.gms.EndpointState
 
getUptime() - Method in class org.apache.cassandra.tools.NodeProbe
 
getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
getUsername() - Method in class org.apache.cassandra.cli.CliClient
 
getUUID(ByteBuffer) - Static method in class org.apache.cassandra.utils.UUIDGen
creates a type 1 uuid from raw bytes.
getValidator() - Method in enum org.apache.cassandra.cli.CliClient.Function
 
getValidator() - Method in class org.apache.cassandra.config.ColumnDefinition
 
getValidator() - Method in class org.apache.cassandra.cql.CFPropDefs
 
getValidColumnFamilies(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
getValue() - Method in class org.apache.cassandra.cql.Relation
 
getValue() - Method in class org.apache.cassandra.cql3.Relation
 
getValue() - Method in class org.apache.cassandra.utils.PureJavaCrc32
getValueAlias() - Method in class org.apache.cassandra.config.CFMetaData
 
getValueValidator(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
 
getValueValidator(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
 
getValueValidator(String, String, ByteBuffer) - Method in class org.apache.cassandra.config.Schema
Get value validator for specific column
getValueValidator(String, ByteBuffer) - Method in class org.apache.cassandra.cql.SelectStatement
 
getValueValidator(String, ByteBuffer) - Method in class org.apache.cassandra.cql.UpdateStatement
 
getVerb() - Method in class org.apache.cassandra.net.Message
 
getVerbHandler(StorageService.Verb) - Method in class org.apache.cassandra.net.MessagingService
This method returns the verb handler associated with the registered verb.
getVersion() - Method in class org.apache.cassandra.config.Schema
 
getVersion(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
getVersion(String) - Method in class org.apache.cassandra.gms.Gossiper
 
getVersion(String) - Method in interface org.apache.cassandra.gms.GossiperMBean
 
getVersion() - Method in class org.apache.cassandra.net.Message
 
GetVersion - Class in org.apache.cassandra.tools
 
GetVersion() - Constructor for class org.apache.cassandra.tools.GetVersion
 
getView() - Method in class org.apache.cassandra.db.DataTracker
 
getWithShortLength(ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
getWorkMap(Multimap<Range<Token>, InetAddress>) - Static method in class org.apache.cassandra.dht.RangeStreamer
 
getWriteConsistencyLevel(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getWriteCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getWriteCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getWriteEndpoints(Token, String, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.TokenMetadata
write endpoints may be different from read endpoints, because read endpoints only need care about the "natural" nodes for a token, but write endpoints also need to account for nodes that are bootstrapping into the ring, and write data there too so that they stay up to date during the bootstrap process.
getWriteOperations() - Method in class org.apache.cassandra.service.StorageProxy
 
getWriteOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getWriter(int) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
getWriter() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
getWriteResponseHandler(Collection<InetAddress>, ConsistencyLevel, Runnable) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
GossipDigest - Class in org.apache.cassandra.gms
Contains information about a specified list of Endpoints and the largest version of the state they have generated as known by the local endpoint.
GossipDigestAck2VerbHandler - Class in org.apache.cassandra.gms
 
GossipDigestAck2VerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestAck2VerbHandler
 
GossipDigestAckVerbHandler - Class in org.apache.cassandra.gms
 
GossipDigestAckVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestAckVerbHandler
 
GossipDigestSynVerbHandler - Class in org.apache.cassandra.gms
 
GossipDigestSynVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestSynVerbHandler
 
Gossiper - Class in org.apache.cassandra.gms
This module is responsible for Gossiping information for the local endpoint.
GossiperMBean - Interface in org.apache.cassandra.gms
 
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.Ec2MultiRegionSnitch
 
gossiperStarting() - Method in class org.apache.cassandra.locator.Ec2Snitch
 
gossiperStarting() - Method in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
 
gossiperStarting() - Method in interface org.apache.cassandra.locator.IEndpointSnitch
called after Gossiper instance exists immediately before it starts gossiping
GossipingPropertyFileSnitch - Class in org.apache.cassandra.locator
 
GossipingPropertyFileSnitch() - Constructor for class org.apache.cassandra.locator.GossipingPropertyFileSnitch
 
GossipShutdownVerbHandler - Class in org.apache.cassandra.gms
 
GossipShutdownVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipShutdownVerbHandler
 
grant(AuthenticatedUser, Permission, String, CFName, boolean) - Method in interface org.apache.cassandra.auth.IAuthority2
GRANT ON TO [WITH GRANT OPTION];
grant(AuthenticatedUser, Permission, String, CFName, boolean) - Method in class org.apache.cassandra.auth.IAuthorityContainer
 
grantPermission(Permission, String, CFName, boolean) - Method in class org.apache.cassandra.service.ClientState
 
grantStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
GrantStatement - Class in org.apache.cassandra.cql3.statements
 
GrantStatement(Permission, CFName, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.GrantStatement
 
GRANULAR_PERMISSIONS - Static variable in enum org.apache.cassandra.auth.Permission
 
groups - Variable in class org.apache.cassandra.auth.AuthenticatedUser
 
GT - Static variable in class org.apache.cassandra.io.sstable.SSTableReader.Operator
 
guid() - Static method in class org.apache.cassandra.utils.GuidGenerator
 
guidAsBytes() - Static method in class org.apache.cassandra.utils.GuidGenerator
 
GuidGenerator - Class in org.apache.cassandra.utils
 
GuidGenerator() - Constructor for class org.apache.cassandra.utils.GuidGenerator
 
guidToString(byte[]) - Static method in class org.apache.cassandra.utils.GuidGenerator
 

H

H - Static variable in class org.apache.cassandra.cql.CqlLexer
 
H - Static variable in class org.apache.cassandra.cql.CqlParser
 
H - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
H - Static variable in class org.apache.cassandra.cql3.CqlParser
 
hadFailures() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.LoaderFuture
 
handleMessage(Message, String, InetAddress) - Method in interface org.apache.cassandra.net.sink.IMessageSink
 
handleNotification(INotification, Object) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
handleNotification(INotification, Object) - Method in interface org.apache.cassandra.notifications.INotificationConsumer
 
handleOrLog(Throwable) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
Send @param t to the default uncaught exception handler, or log it if none such is set up
has(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
hasAncestors - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
hasCapacityFor(RowMutation) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
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.
hasColumnFamilyAccess(String, String, Permission) - Method in class org.apache.cassandra.service.ClientState
 
hasColumnFamilySchemaAccess(String, Permission) - Method in class org.apache.cassandra.service.ClientState
Confirms that the client thread has the given Permission for the ColumnFamily list of the provided keyspace.
hasCompressionRatio - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
hasEncodedKeys - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
hasFirstSet() - Method in class org.apache.cassandra.cql.SelectExpression
 
hasFunction() - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
hasFunction() - Method in interface org.apache.cassandra.cql3.statements.Selector
 
hasFunction() - Method in class org.apache.cassandra.cql3.statements.Selector.WithFunction
 
HASH - Static variable in class org.apache.cassandra.cli.CliLexer
 
HASH - Static variable in class org.apache.cassandra.cli.CliParser
 
hash(ByteBuffer...) - Static method in class org.apache.cassandra.utils.FBUtilities
 
hash(Range<Token>) - 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.cache.KeyCacheKey
 
hashCode() - Method in class org.apache.cassandra.cache.RowCacheKey
 
hashCode() - Method in class org.apache.cassandra.cache.RowCacheSentinel
 
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.cql.Term
 
hashCode() - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
hashCode() - Method in class org.apache.cassandra.cql3.statements.Selector.WithFunction
 
hashCode() - Method in class org.apache.cassandra.cql3.Term
 
hashCode() - Method in class org.apache.cassandra.db.Column
 
hashCode() - Method in class org.apache.cassandra.db.ColumnFamily
 
hashCode() - Method in class org.apache.cassandra.db.commitlog.ReplayPosition
 
hashCode() - Method in class org.apache.cassandra.db.CounterColumn
 
hashCode() - Method in class org.apache.cassandra.db.DecoratedKey
 
hashCode() - Method in class org.apache.cassandra.db.ExpiringColumn
 
hashCode() - Method in class org.apache.cassandra.db.SuperColumn
 
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() - Method in class org.apache.cassandra.dht.Token.KeyBound
 
hashCode() - Method in class org.apache.cassandra.io.compress.CompressionParameters
 
hashCode - Variable in class org.apache.cassandra.io.sstable.Component
 
hashCode() - Method in class org.apache.cassandra.io.sstable.Component
 
hashCode() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
hashCode() - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
hashCode() - Method in class org.apache.cassandra.streaming.PendingFile
 
hashCode() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
hashCode() - Method in class org.apache.cassandra.utils.NodeId
 
hashCode() - Method in class org.apache.cassandra.utils.NodeId.NodeIdRecord
 
hashCode() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
hashCode() - Method in class org.apache.cassandra.utils.Pair
 
hashCode() - Method in class org.apache.cassandra.utils.SemanticVersion
 
hashConstruct() - Method in class org.apache.cassandra.cli.CliParser
 
hashdepth - Variable in class org.apache.cassandra.utils.MerkleTree
 
hashElementPair() - Method in class org.apache.cassandra.cli.CliParser
 
hashToBigInteger(ByteBuffer) - Static method in class org.apache.cassandra.utils.FBUtilities
 
hasIndexFor(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
hasIntRowSize - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
hasIrrelevantData(int) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
hasIrrelevantData(int) - Method in class org.apache.cassandra.db.Column
 
hasIrrelevantData(int) - Method in interface org.apache.cassandra.db.IColumn
 
hasIrrelevantData(int) - Method in interface org.apache.cassandra.db.IColumnContainer
 
hasKeyspace() - Method in class org.apache.cassandra.cql3.CFName
 
hasKeyspaceAccess(String, Permission) - Method in class org.apache.cassandra.service.ClientState
 
hasNext() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
hasNext() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
hasNext() - Method in class org.apache.cassandra.io.sstable.SSTableBoundedScanner.BoundedKeyScanningIterator
 
hasNext() - Method in class org.apache.cassandra.io.sstable.SSTableBoundedScanner
 
hasNext() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
hasNext() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
hasNext() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
 
hasNext() - Method in class org.apache.cassandra.utils.DestructivePQIterator
 
hasNodeId(ByteBuffer, NodeId) - Method in class org.apache.cassandra.db.context.CounterContext
Checks whether the provided context has a count for the provided NodeId.
hasNodeId(NodeId) - Method in class org.apache.cassandra.db.CounterColumn
Check if a given nodeId is found in this CounterColumn context.
hasPartitioner - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
hasProperty(String) - Method in class org.apache.cassandra.cql.CFPropDefs
 
hasProperty(String) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
 
hasRemaining() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
hasStringsInBloomFilter - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
hasUnreclaimedSpace() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
Header - Class in org.apache.cassandra.net
 
header - Variable in class org.apache.cassandra.streaming.FileStreamTask
 
headerLength - Variable in class org.apache.cassandra.db.context.CounterContext.ContextState
 
HeaderTypes - Class in org.apache.cassandra.net
 
HeaderTypes() - Constructor for class org.apache.cassandra.net.HeaderTypes
 
headMap(ByteBuffer) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
HeapAllocator - Class in org.apache.cassandra.utils
 
help - Variable in class org.apache.cassandra.cli.CliCommandHelp
 
HELP - Static variable in class org.apache.cassandra.cli.CliLexer
 
HELP - Static variable in class org.apache.cassandra.cli.CliParser
 
help - Variable in class org.apache.cassandra.cli.CliUserHelp
 
helpStatement() - Method in class org.apache.cassandra.cli.CliParser
 
HEX - Static variable in class org.apache.cassandra.cql.CqlLexer
 
HEX - Static variable in class org.apache.cassandra.cql.CqlParser
 
HEX - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
HEX - Static variable in class org.apache.cassandra.cql3.CqlParser
 
Hex - Class in org.apache.cassandra.utils
 
Hex() - Constructor for class org.apache.cassandra.utils.Hex
 
HexDigit - Static variable in class org.apache.cassandra.cli.CliLexer
 
HexDigit - Static variable in class org.apache.cassandra.cli.CliParser
 
HexEscapeSequence - Static variable in class org.apache.cassandra.cli.CliLexer
 
HexEscapeSequence - Static variable in class org.apache.cassandra.cli.CliParser
 
hexToBytes(String) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
hexToBytes(String) - Static method in class org.apache.cassandra.utils.Hex
 
HIBERNATE - Static variable in class org.apache.cassandra.gms.VersionedValue
 
hibernate(boolean) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
hinted_handoff_enabled - Variable in class org.apache.cassandra.config.Config
 
hinted_handoff_throttle_delay_in_ms - Variable in class org.apache.cassandra.config.Config
 
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
 
hintFor(RowMutation, ByteBuffer) - Static method in class org.apache.cassandra.db.RowMutation
Returns mutation representing a Hints to be sent to address as soon as it becomes available.
HINTS_CF - Static variable in class org.apache.cassandra.db.HintedHandOffManager
 
HintsCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
HISTORYFILE - Static variable in class org.apache.cassandra.cli.CliMain
 
host() - Method in class org.apache.cassandra.cli.CliParser
 
host_name() - Method in class org.apache.cassandra.cli.CliParser
 
hostName - Variable in class org.apache.cassandra.cli.CliSessionState
 
hotKeySet(int) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
hotKeySet(int) - Method in interface org.apache.cassandra.cache.ICache
 
hotKeySet(int) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
hotKeySet(int) - Method in class org.apache.cassandra.cache.SerializingCache
 

I

I - Static variable in class org.apache.cassandra.cql.CqlLexer
 
I - Static variable in class org.apache.cassandra.cql.CqlParser
 
I - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
I - Static variable in class org.apache.cassandra.cql3.CqlParser
 
IAsyncCallback - Interface in org.apache.cassandra.net
implementors of IAsyncCallback need to make sure that any public methods are threadsafe with respect to response() being called from the message service.
IAsyncResult - Interface in org.apache.cassandra.net
 
IAuthenticator - Interface in org.apache.cassandra.auth
 
IAuthority - Interface in org.apache.cassandra.auth
Cassandra's resource hierarchy looks something like: {{/cassandra/keyspaces/$ks_name/...}} In table form: /cassandra/ - no checked permissions - String * Separates Cassandra-internal resources from resources that might be provided by plugins.
IAuthority2 - Interface in org.apache.cassandra.auth
 
IAuthorityContainer - Class in org.apache.cassandra.auth
1.1.x : Temporary measure to unable dynamic operations without changing IAuthority interface.
IAuthorityContainer(IAuthority) - Constructor for class org.apache.cassandra.auth.IAuthorityContainer
 
ICache<K,V> - Interface in org.apache.cassandra.cache
This is similar to the Map interface, but requires maintaining a given capacity and does not require put or remove to return values, which lets SerializingCache be more efficient by avoiding deserialize except on get.
IColumn - Interface in org.apache.cassandra.db
TODO: rename
IColumnContainer - Interface in org.apache.cassandra.db
 
IColumnIterator - Interface in org.apache.cassandra.db.columniterator
 
IColumnSerializer - Interface in org.apache.cassandra.io
 
IColumnSerializer.Flag - Enum in org.apache.cassandra.io
Flag affecting deserialization behavior.
ICommitLogExecutorService - Interface in org.apache.cassandra.db.commitlog
Like ExecutorService, but customized for batch and periodic commitlog execution.
ICompactionScanner - Interface in org.apache.cassandra.db.compaction
An ICompactionScanner is an abstraction allowing multiple SSTableScanners to be chained together under the hood.
ICompressor - Interface in org.apache.cassandra.io.compress
 
ICompressor.WrappedArray - Class in org.apache.cassandra.io.compress
A simple wrapper of a byte array.
ICompressor.WrappedArray(byte[]) - Constructor for class org.apache.cassandra.io.compress.ICompressor.WrappedArray
 
IContext - Interface in org.apache.cassandra.db.context
An opaque commutative context.
IContext.ContextRelationship - Enum in org.apache.cassandra.db.context
 
ICountableColumnIterator - Interface in org.apache.cassandra.db.columniterator
 
id - Variable in class org.apache.cassandra.concurrent.NamedThreadFactory
 
id() - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
id() - Method in interface org.apache.cassandra.cql3.statements.Selector
 
id() - Method in class org.apache.cassandra.cql3.statements.Selector.WithFunction
 
id() - Method in class org.apache.cassandra.db.ColumnFamily
 
id - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
id - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
id - Variable in class org.apache.cassandra.io.sstable.Component
 
id - Variable in class org.apache.cassandra.streaming.StreamingRepairTask
 
id - Variable in class org.apache.cassandra.utils.NodeId.NodeIdRecord
 
IDENT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
IDENT - Static variable in class org.apache.cassandra.cql.CqlParser
 
IDENT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
IDENT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
ident - Variable in class org.apache.cassandra.cql3.Operation
 
Identifier - Static variable in class org.apache.cassandra.cli.CliLexer
 
Identifier - Static variable in class org.apache.cassandra.cli.CliParser
 
IdentityQueryFilter - Class in org.apache.cassandra.db.columniterator
 
IdentityQueryFilter() - Constructor for class org.apache.cassandra.db.columniterator.IdentityQueryFilter
Only for use in testing; will read entire CF into memory.
idFromFilename(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogSegment
Extracts the commit log ID from filename
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.
IIterableColumns - Interface in org.apache.cassandra.io.util
 
ILatencySubscriber - Interface in org.apache.cassandra.locator
 
IMergeIterator<In,Out> - Interface in org.apache.cassandra.utils
 
IMessageCallback - Interface in org.apache.cassandra.net
 
IMessageSink - Interface in org.apache.cassandra.net.sink
 
importJson(String, String, String, String) - Static method in class org.apache.cassandra.tools.SSTableImport
Convert a JSON formatted file to an SSTable.
importSorted(String, ColumnFamily, String, IPartitioner<?>) - Static method in class org.apache.cassandra.tools.SSTableImport
 
IMutation - Interface in org.apache.cassandra.db
 
in - Variable in class org.apache.cassandra.cli.CliSessionState
 
in_memory_compaction_limit_in_mb - Variable in class org.apache.cassandra.config.Config
 
includeBackups(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
includeFinishKey() - Method in class org.apache.cassandra.cql.SelectStatement
 
includeFinishKey() - Method in class org.apache.cassandra.cql.WhereClause
 
includeStartKey() - Method in class org.apache.cassandra.cql.SelectStatement
 
includeStartKey() - Method in class org.apache.cassandra.cql.WhereClause
 
IncludingExcludingBounds<T extends RingPosition> - Class in org.apache.cassandra.dht
AbstractBounds containing only its left endpoint: [left, right).
IncludingExcludingBounds(T, T) - Constructor for class org.apache.cassandra.dht.IncludingExcludingBounds
 
IncomingStreamReader - Class in org.apache.cassandra.streaming
 
IncomingStreamReader(StreamHeader, Socket) - Constructor for class org.apache.cassandra.streaming.IncomingStreamReader
 
IncomingTcpConnection - Class in org.apache.cassandra.net
 
IncomingTcpConnection(Socket) - Constructor for class org.apache.cassandra.net.IncomingTcpConnection
 
INCR - Static variable in class org.apache.cassandra.cli.CliLexer
 
INCR - Static variable in class org.apache.cassandra.cli.CliParser
 
incrementActiveStreamsOutbound() - Method in class org.apache.cassandra.net.MessagingService
 
incremental_backups - Variable in class org.apache.cassandra.config.Config
 
incrementallyBackup(SSTableReader) - Method in class org.apache.cassandra.db.DataTracker
 
incrementAndGetGeneration() - Static method in class org.apache.cassandra.db.SystemTable
 
incrementDroppedMessages(StorageService.Verb) - Method in class org.apache.cassandra.net.MessagingService
 
incrementRowid() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
incrementValue() - Method in class org.apache.cassandra.cli.CliParser
 
incrStatement() - Method in class org.apache.cassandra.cli.CliParser
 
INDEX - Static variable in class org.apache.cassandra.cli.CliLexer
 
INDEX - Static variable in class org.apache.cassandra.cli.CliParser
 
index - Variable in class org.apache.cassandra.cql.DropIndexStatement
 
INDEX_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
index_clause - Variable in class org.apache.cassandra.db.IndexScanCommand
 
index_interval - Variable in class org.apache.cassandra.config.Config
 
index_name - Variable in class org.apache.cassandra.db.migration.avro.ColumnDef
 
index_options - Variable in class org.apache.cassandra.db.migration.avro.ColumnDef
 
index_type - Variable in class org.apache.cassandra.db.migration.avro.ColumnDef
 
IndexCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
indexColumnFamilyName(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
generate a column family name for an index corresponding to the given column.
indexComparator() - Static method in class org.apache.cassandra.db.index.keys.KeysIndex
 
indexComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
indexEntries - Variable in class org.apache.cassandra.db.ColumnIndexer.RowHeader
 
indexFilePath - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
 
indexFor(ByteBuffer, List<IndexHelper.IndexInfo>, AbstractType<?>, boolean) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
The index of the IndexInfo in which a scan starting with @name should begin.
IndexHelper - Class in org.apache.cassandra.io.sstable
Provides helper to serialize, deserialize and use column indexes.
IndexHelper() - Constructor for class org.apache.cassandra.io.sstable.IndexHelper
 
IndexHelper.IndexInfo - Class in org.apache.cassandra.io.sstable
 
IndexHelper.IndexInfo(ByteBuffer, ByteBuffer, long, long) - Constructor for class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
indexManager - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
indexManager - Variable in class org.apache.cassandra.db.index.SecondaryIndexSearcher
 
indexName - Variable in class org.apache.cassandra.cql3.statements.DropIndexStatement
 
indexReverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
indexRow(DecoratedKey<?>, ColumnFamilyStore, SortedSet<ByteBuffer>) - Static method in class org.apache.cassandra.db.Table
 
IndexScanCommand - Class in org.apache.cassandra.db
 
IndexScanCommand(String, String, IndexClause, SlicePredicate, AbstractBounds<RowPosition>) - Constructor for class org.apache.cassandra.db.IndexScanCommand
 
IndexScanVerbHandler - Class in org.apache.cassandra.service
Deprecated. 
IndexScanVerbHandler() - Constructor for class org.apache.cassandra.service.IndexScanVerbHandler
Deprecated.  
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
 
IndexType - Enum in org.apache.cassandra.db.migration.avro
 
inFileMode() - Method in class org.apache.cassandra.cli.CliSessionState
 
init() - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
init() - Method in class org.apache.cassandra.db.index.SecondaryIndex
Perform any initialization work
init(String) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
Initialize the client.
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, boolean) - 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
 
initClient(int) - Method in class org.apache.cassandra.service.StorageService
 
initial_token - Variable in class org.apache.cassandra.config.Config
 
initialCompressedBufferLength(int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
initialCompressedBufferLength(int) - Method in interface org.apache.cassandra.io.compress.ICompressor
 
initialCompressedBufferLength(int) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
 
initialFilter() - Method in class org.apache.cassandra.db.filter.ExtendedFilter
The initial filter we'll do our first slice with (either the original or a superset of it)
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
initializeNodeUnsafe(InetAddress, int) - Method in class org.apache.cassandra.gms.Gossiper
This should *only* be used for testing purposes.
initLog4j() - Static method in class org.apache.cassandra.service.AbstractCassandraDaemon
Initialize logging in such a way that it checks for config changes every 10 seconds.
initRowCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
initServer() - Method in class org.apache.cassandra.service.StorageService
 
initServer(int) - Method in class org.apache.cassandra.service.StorageService
 
injectPreProcessed(ReadResponse) - Method in class org.apache.cassandra.service.AbstractRowResolver
hack so local reads don't force de/serialization of an extra real Message
INotification - Interface in org.apache.cassandra.notifications
Created by IntelliJ IDEA.
INotificationConsumer - Interface in org.apache.cassandra.notifications
 
inputStream(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
insertColumn(DecoratedKey<?>, ByteBuffer, IColumn) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
insertColumn(DecoratedKey<?>, ByteBuffer, IColumn) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
insert a column to the index
insertStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
insertStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
instance - Static variable in class org.apache.cassandra.config.Schema
 
instance - Static variable in class org.apache.cassandra.cql.jdbc.JdbcAscii
 
instance - Static variable in class org.apache.cassandra.cql.jdbc.JdbcBoolean
 
instance - Static variable in class org.apache.cassandra.cql.jdbc.JdbcBytes
 
instance - Static variable in class org.apache.cassandra.cql.jdbc.JdbcCounterColumn
 
instance - Static variable in class org.apache.cassandra.cql.jdbc.JdbcDate
 
instance - Static variable in class org.apache.cassandra.cql.jdbc.JdbcDecimal
 
instance - Static variable in class org.apache.cassandra.cql.jdbc.JdbcDouble
 
instance - Static variable in class org.apache.cassandra.cql.jdbc.JdbcFloat
 
instance - Static variable in class org.apache.cassandra.cql.jdbc.JdbcInt32
 
instance - Static variable in class org.apache.cassandra.cql.jdbc.JdbcInteger
 
instance - Static variable in class org.apache.cassandra.cql.jdbc.JdbcLexicalUUID
 
instance - Static variable in class org.apache.cassandra.cql.jdbc.JdbcLong
 
instance - Static variable in class org.apache.cassandra.cql.jdbc.JdbcTimeUUID
 
instance - Static variable in class org.apache.cassandra.cql.jdbc.JdbcUTF8
 
instance - Static variable in class org.apache.cassandra.cql.jdbc.JdbcUUID
 
instance - Static variable in class org.apache.cassandra.db.commitlog.CommitLog
 
instance - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
 
instance() - Static method in class org.apache.cassandra.db.context.CounterContext
 
instance - Static variable in class org.apache.cassandra.db.HintedHandOffManager
 
instance - Static variable in class org.apache.cassandra.db.marshal.AsciiType
 
instance - Static variable in class org.apache.cassandra.db.marshal.BooleanType
 
instance - Static variable in class org.apache.cassandra.db.marshal.BytesType
 
instance - Static variable in class org.apache.cassandra.db.marshal.CounterColumnType
 
instance - Static variable in class org.apache.cassandra.db.marshal.DateType
 
instance - Static variable in class org.apache.cassandra.db.marshal.DecimalType
 
instance - Static variable in class org.apache.cassandra.db.marshal.DoubleType
 
instance - Static variable in class org.apache.cassandra.db.marshal.FloatType
 
instance - Static variable in class org.apache.cassandra.db.marshal.Int32Type
 
instance - Static variable in class org.apache.cassandra.db.marshal.IntegerType
 
instance - Static variable in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
instance - Static variable in class org.apache.cassandra.db.marshal.LongType
 
instance - Static variable in class org.apache.cassandra.db.marshal.TimeUUIDType
 
instance - Static variable in class org.apache.cassandra.db.marshal.UTF8Type
 
instance - Static variable in class org.apache.cassandra.db.marshal.UUIDType
 
instance - Static variable in class org.apache.cassandra.gms.FailureDetector
 
instance - Static variable in class org.apache.cassandra.gms.Gossiper
 
instance - Static variable in class org.apache.cassandra.io.compress.DeflateCompressor
 
instance - Static variable in class org.apache.cassandra.io.compress.SnappyCompressor
 
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.CacheService
 
instance - Static variable in class org.apache.cassandra.service.GCInspector
 
instance - Static variable in class org.apache.cassandra.service.LoadBroadcaster
 
instance - Static variable in class org.apache.cassandra.service.SocketSessionManagementService
 
instance - Static variable in class org.apache.cassandra.service.StorageProxy
 
instance - Static variable in class org.apache.cassandra.service.StorageService
 
instance - Static variable in class org.apache.cassandra.streaming.StreamingService
 
instance - Static variable in class org.apache.cassandra.thrift.CassandraDaemon
 
instance - Static variable in class org.apache.cassandra.utils.HeapAllocator
 
InstrumentingCache<K,V> - Class in org.apache.cassandra.cache
Wraps an ICache in requests + hits tracking.
InstrumentingCache(ICache<K, V>) - Constructor for class org.apache.cassandra.cache.InstrumentingCache
 
int32(String, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
Int32Type - Class in org.apache.cassandra.db.marshal
 
INTEGER - Static variable in class org.apache.cassandra.cql.CqlLexer
 
INTEGER - Static variable in class org.apache.cassandra.cql.CqlParser
 
INTEGER - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
INTEGER - Static variable in class org.apache.cassandra.cql3.CqlParser
 
IntegerNegativeLiteral - Static variable in class org.apache.cassandra.cli.CliLexer
 
IntegerNegativeLiteral - Static variable in class org.apache.cassandra.cli.CliParser
 
IntegerPositiveLiteral - Static variable in class org.apache.cassandra.cli.CliLexer
 
IntegerPositiveLiteral - Static variable in class org.apache.cassandra.cli.CliParser
 
IntegerType - Class in org.apache.cassandra.db.marshal
 
internalIP(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
internedNames - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
InterNode - Interface in org.apache.cassandra
 
internode_encryption - Variable in class org.apache.cassandra.config.EncryptionOptions
 
internOrCopy(ByteBuffer, Allocator) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
interpret(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
 
interpret(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
This method is invoked by any entity wanting to interrogate the status of an endpoint.
interrupt() - Method in class org.apache.cassandra.thrift.TCustomServerSocket
 
intersect(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
this = this AND other
intersectionWith(Range<T>) - Method in class org.apache.cassandra.dht.Range
 
intersects(Iterable<Range<T>>) - Method in class org.apache.cassandra.dht.AbstractBounds
return true if @param range intersects any of the given @param ranges
intersects(Bounds<T>) - Method in class org.apache.cassandra.dht.Bounds
 
intersects(Range<T>) - Method in class org.apache.cassandra.dht.Range
 
intersects(AbstractBounds<T>) - Method in class org.apache.cassandra.dht.Range
 
intersects(Bounds<T>) - Method in class org.apache.cassandra.dht.Range
 
intersects(Interval) - Method in class org.apache.cassandra.utils.IntervalTree.Interval
 
Interval<T> - Class in org.apache.cassandra.utils.IntervalTree
 
Interval(Comparable, Comparable) - Constructor for class org.apache.cassandra.utils.IntervalTree.Interval
 
Interval(Comparable, Comparable, T) - Constructor for class org.apache.cassandra.utils.IntervalTree.Interval
 
intervalInMillis - Static variable in class org.apache.cassandra.gms.Gossiper
 
IntervalNode - Class in org.apache.cassandra.utils.IntervalTree
 
IntervalNode(List<Interval>) - Constructor for class org.apache.cassandra.utils.IntervalTree.IntervalNode
 
IntervalTree<T> - Class in org.apache.cassandra.utils.IntervalTree
 
IntervalTree() - Constructor for class org.apache.cassandra.utils.IntervalTree.IntervalTree
 
IntervalTree(List<Interval>) - Constructor for class org.apache.cassandra.utils.IntervalTree.IntervalTree
 
intSize - Static variable in class org.apache.cassandra.db.DBConstants
 
intTerm() - Method in class org.apache.cassandra.cql.CqlParser
 
intTerm() - Method in class org.apache.cassandra.cql3.CqlParser
 
invalidate() - Method in class org.apache.cassandra.db.ColumnFamilyStore
call when dropping or renaming a CF.
invalidate() - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
invalidate() - Method in class org.apache.cassandra.db.index.SecondaryIndex
Remove the index and unregisters this index's mbean if one exists
invalidate() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
Remove the index
invalidate(Token) - Method in class org.apache.cassandra.utils.MerkleTree
Invalidates the ranges containing the given token.
invalidateCachedRow(RowCacheKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
invalidateCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
invalidateCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.CompactionController
 
invalidateCachedTokenEndpointValues() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
invalidateCaches() - Method in class org.apache.cassandra.locator.TokenMetadata
 
invalidateKeyCache() - Method in class org.apache.cassandra.service.CacheService
 
invalidateKeyCache() - Method in interface org.apache.cassandra.service.CacheServiceMBean
invalidate the key cache; for use after invalidating row cache
invalidateKeyCache() - Method in class org.apache.cassandra.tools.NodeProbe
 
invalidateRowCache() - Method in class org.apache.cassandra.service.CacheService
 
invalidateRowCache() - Method in interface org.apache.cassandra.service.CacheServiceMBean
invalidate the row cache; for use after bulk loading via BinaryMemtable
invalidateRowCache() - Method in class org.apache.cassandra.tools.NodeProbe
 
invalids() - Method in class org.apache.cassandra.utils.MerkleTree
Returns a lazy iterator of invalid TreeRanges that need to be filled in order to make the given Range valid.
IP_ADDRESS - Static variable in class org.apache.cassandra.cli.CliLexer
 
IP_ADDRESS - Static variable in class org.apache.cassandra.cli.CliParser
 
ip_address() - Method in class org.apache.cassandra.cli.CliParser
 
IPartitioner<T extends Token> - Interface in org.apache.cassandra.dht
 
IReadCommand - Interface in org.apache.cassandra.service
 
IRequestScheduler - Interface in org.apache.cassandra.scheduler
Implementors of IRequestScheduler must provide a constructor taking a RequestSchedulerOptions object.
IResponseResolver<T> - Interface in org.apache.cassandra.service
 
IRowCacheEntry - Interface in org.apache.cassandra.cache
 
IRowCacheProvider - Interface in org.apache.cassandra.cache
Provides cache objects with a requested capacity.
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
 
isAutoSnapshot() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isAvailable() - Static method in class org.apache.cassandra.io.compress.SnappyCompressor
 
isBindMarker() - Method in class org.apache.cassandra.cql.Term
 
isBindMarker() - Method in class org.apache.cassandra.cql3.Term
 
isBootstrapMode() - Method in class org.apache.cassandra.service.StorageService
 
isCancelled() - Method in class org.apache.cassandra.concurrent.CreationTimeAwareFuture
 
isCancelled() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.LoaderFuture
 
isCapacitySetManually() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
isCaseSensitive() - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcType
 
isCaseSensitive() - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcUUID
 
isCaseSensitive() - Method in class org.apache.cassandra.cql.jdbc.JdbcAscii
 
isCaseSensitive() - Method in class org.apache.cassandra.cql.jdbc.JdbcBoolean
 
isCaseSensitive() - Method in class org.apache.cassandra.cql.jdbc.JdbcBytes
 
isCaseSensitive() - Method in class org.apache.cassandra.cql.jdbc.JdbcDate
 
isCaseSensitive() - Method in class org.apache.cassandra.cql.jdbc.JdbcDecimal
 
isCaseSensitive() - Method in class org.apache.cassandra.cql.jdbc.JdbcDouble
 
isCaseSensitive() - Method in class org.apache.cassandra.cql.jdbc.JdbcFloat
 
isCaseSensitive() - Method in class org.apache.cassandra.cql.jdbc.JdbcInt32
 
isCaseSensitive() - Method in class org.apache.cassandra.cql.jdbc.JdbcInteger
 
isCaseSensitive() - Method in class org.apache.cassandra.cql.jdbc.JdbcLong
 
isCaseSensitive() - Method in class org.apache.cassandra.cql.jdbc.JdbcUTF8
 
isClean() - Method in class org.apache.cassandra.db.Memtable
 
isCleanerAvailable() - Static method in class org.apache.cassandra.io.util.FileUtils
 
isClientMode() - Method in class org.apache.cassandra.service.StorageService
 
isColumnList() - Method in class org.apache.cassandra.cql.SelectExpression
 
isColumnRange() - Method in class org.apache.cassandra.cql.SelectExpression
 
isColumnRange() - Method in class org.apache.cassandra.cql.SelectStatement
 
isColumnsReversed() - Method in class org.apache.cassandra.cql.SelectExpression
 
isColumnsReversed() - Method in class org.apache.cassandra.cql.SelectStatement
 
isCommutative() - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
 
isCommutative() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isCompact - Variable in class org.apache.cassandra.cql3.CFDefinition
 
isCompactionDisabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isCompactionInteresting(Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
isCompactionInteresting(Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
 
isCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.AbstractType
Returns true if this comparator is compatible with the provided previous comparator, that is if previous can safely be replaced by this.
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.BytesType
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
isComposite - Variable in class org.apache.cassandra.cql3.CFDefinition
 
isConnected() - Static method in class org.apache.cassandra.cli.CliMain
Checks whether the thrift client is connected.
isCountOperation() - Method in class org.apache.cassandra.cql.SelectStatement
 
isCurrency() - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcType
 
isCurrency() - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcUUID
 
isCurrency() - Method in class org.apache.cassandra.cql.jdbc.JdbcAscii
 
isCurrency() - Method in class org.apache.cassandra.cql.jdbc.JdbcBoolean
 
isCurrency() - Method in class org.apache.cassandra.cql.jdbc.JdbcBytes
 
isCurrency() - Method in class org.apache.cassandra.cql.jdbc.JdbcDate
 
isCurrency() - Method in class org.apache.cassandra.cql.jdbc.JdbcDecimal
 
isCurrency() - Method in class org.apache.cassandra.cql.jdbc.JdbcDouble
 
isCurrency() - Method in class org.apache.cassandra.cql.jdbc.JdbcFloat
 
isCurrency() - Method in class org.apache.cassandra.cql.jdbc.JdbcInt32
 
isCurrency() - Method in class org.apache.cassandra.cql.jdbc.JdbcInteger
 
isCurrency() - Method in class org.apache.cassandra.cql.jdbc.JdbcLong
 
isCurrency() - Method in class org.apache.cassandra.cql.jdbc.JdbcUTF8
 
isDataPresent() - Method in interface org.apache.cassandra.service.IResponseResolver
 
isDataPresent() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
isDataPresent() - Method in class org.apache.cassandra.service.RowDigestResolver
 
isDataPresent() - Method in class org.apache.cassandra.service.RowRepairResolver
 
isDelta() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
isDigestQuery() - Method in class org.apache.cassandra.db.ReadCommand
 
isDigestQuery() - Method in class org.apache.cassandra.db.ReadResponse
 
isDirty - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
isDone() - Method in class org.apache.cassandra.concurrent.CreationTimeAwareFuture
 
isDone() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
 
isDone() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.LoaderFuture
 
isDynamic() - Method in class org.apache.cassandra.auth.IAuthorityContainer
 
isEmpty() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
isEmpty() - Method in class org.apache.cassandra.cache.SerializingCache
 
isEmpty() - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
isEmpty() - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
 
isEmpty() - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
isEmpty() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isEmpty() - Method in class org.apache.cassandra.db.compaction.AbstractCompactedRow
 
isEmpty() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
isEmpty() - Method in class org.apache.cassandra.db.compaction.PrecompactedRow
 
isEmpty() - Method in class org.apache.cassandra.db.EchoedRow
 
isEmpty() - Method in interface org.apache.cassandra.db.ISortedColumns
Returns true if this map is empty, false otherwise.
isEmpty() - Method in class org.apache.cassandra.db.RowMutation
 
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 interface org.apache.cassandra.io.util.FileDataInput
 
isEOF() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
isEOF() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
ISerializer<T> - Interface in org.apache.cassandra.io
 
isFullWildcard() - Method in class org.apache.cassandra.cql.SelectStatement
 
isIncrementalBackupsEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isIncrementalBackupsEnabled() - Method in class org.apache.cassandra.service.StorageService
 
isIncrementalBackupsEnabled() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isIndex() - Method in class org.apache.cassandra.db.ColumnFamilyStore
true if this CFS contains secondary index data
isIndexBuilt(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
Checks if the index for specified column is fully built
isIndexBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemTable
 
isIndexing(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.keys.KeysSearcher
 
isIndexing(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
 
isIndexNameValid(String) - Static method in class org.apache.cassandra.config.CFMetaData
 
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
 
isInRanges(T, Iterable<Range<T>>) - Static method in class org.apache.cassandra.dht.Range
 
isInsertReversed() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
isInsertReversed() - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
isInsertReversed() - Method in interface org.apache.cassandra.db.ISortedColumns
Returns if this map only support inserts in reverse order.
isInsertReversed() - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
isInsertReversed() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
isJoined() - Method in class org.apache.cassandra.service.StorageService
 
isJoined() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isJoined() - Method in class org.apache.cassandra.tools.NodeProbe
 
isKeyExistenceExpensive(Set<? extends SSTable>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
isKeyExistenceExpensive(Set<? extends SSTable>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
isKeyExistenceExpensive(Set<? extends SSTable>) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
isKeyRange() - Method in class org.apache.cassandra.cql.SelectStatement
 
isKeyRange() - Method in class org.apache.cassandra.cql.WhereClause
 
isKnownEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
isLatencyForSnitch() - Method in interface org.apache.cassandra.net.IMessageCallback
 
isLatencyForSnitch() - Method in class org.apache.cassandra.service.AsyncRepairCallback
 
isLatencyForSnitch() - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
isLatencyForSnitch() - Method in class org.apache.cassandra.service.ReadCallback
 
isLatencyForSnitch() - Method in class org.apache.cassandra.service.RepairCallback
 
isLatencyForSnitch() - Method in class org.apache.cassandra.service.TruncateResponseHandler
 
isLatencyForSnitch() - Method in class org.apache.cassandra.service.WriteResponseHandler
 
isLatestVersion - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
isLeaving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
isLive() - Method in class org.apache.cassandra.db.Column
 
isLive() - Method in interface org.apache.cassandra.db.IColumn
For a simple column, live == !isMarkedForDelete.
isLive() - Method in class org.apache.cassandra.db.SuperColumn
 
isLocalId() - Method in class org.apache.cassandra.utils.NodeId
 
isLocalTask() - Method in class org.apache.cassandra.streaming.StreamingRepairTask
Returns true if the task if the task can be executed locally, false if it has to be forwarded.
isMarkedForDelete() - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
isMarkedForDelete() - Method in class org.apache.cassandra.db.Column
 
isMarkedForDelete() - Method in class org.apache.cassandra.db.DeletedColumn
 
isMarkedForDelete() - Method in interface org.apache.cassandra.db.IColumn
 
isMarkedForDelete() - Method in interface org.apache.cassandra.db.IColumnContainer
 
isMarkedSuspect() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
isMember(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
isMinimum(IPartitioner) - Method in class org.apache.cassandra.db.DecoratedKey
 
isMinimum() - Method in class org.apache.cassandra.db.RowPosition
 
isMinimum(IPartitioner) - Method in interface org.apache.cassandra.dht.RingPosition
 
isMinimum(IPartitioner) - Method in class org.apache.cassandra.dht.Token
 
isMinimum() - Method in class org.apache.cassandra.dht.Token
 
isMinimum(IPartitioner) - Method in class org.apache.cassandra.dht.Token.KeyBound
 
isMinimumBound - Variable in class org.apache.cassandra.dht.Token.KeyBound
 
isModified() - Method in class org.apache.cassandra.utils.DefaultDouble
 
isModified() - Method in class org.apache.cassandra.utils.DefaultInteger
 
isMoving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
isMultiKey() - Method in class org.apache.cassandra.cql.SelectStatement
 
isMultiKey() - Method in class org.apache.cassandra.cql.WhereClause
 
isMultithreadedCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isNameValid(String) - Static method in class org.apache.cassandra.config.CFMetaData
 
iso8601Patterns - Static variable in class org.apache.cassandra.cql.jdbc.JdbcDate
 
isOpen() - Method in class org.apache.cassandra.thrift.TCustomSocket
Checks whether the socket is connected.
ISortedColumns - Interface in org.apache.cassandra.db
A sorted map of columns.
ISortedColumns.DeletionInfo - Class in org.apache.cassandra.db
 
ISortedColumns.DeletionInfo() - Constructor for class org.apache.cassandra.db.ISortedColumns.DeletionInfo
 
ISortedColumns.DeletionInfo(long, int) - Constructor for class org.apache.cassandra.db.ISortedColumns.DeletionInfo
 
ISortedColumns.Factory - Interface in org.apache.cassandra.db
 
isOverflowed() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
isPaging - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
isPresent(ByteBuffer) - Method in class org.apache.cassandra.utils.BloomFilter
 
isPresent(ByteBuffer) - Method in class org.apache.cassandra.utils.Filter
 
isPresent(ByteBuffer) - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
isPutCopying() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
isPutCopying() - Method in interface org.apache.cassandra.cache.ICache
 
isPutCopying() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
isPutCopying() - Method in class org.apache.cassandra.cache.SerializingCache
 
isReadyForBootstrap() - Static method in class org.apache.cassandra.service.MigrationManager
 
isRelevant(IColumn, IColumnContainer, int) - Static method in class org.apache.cassandra.db.filter.QueryFilter
 
isReversed() - Method in interface org.apache.cassandra.db.filter.IFilter
 
isReversed() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
isReversed() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
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
 
isSatisfiedBy(ColumnFamily) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
 
isSetConsistencyLevel() - Method in class org.apache.cassandra.cql.AbstractModification
True if an explicit consistency level was parsed from the statement.
isSetConsistencyLevel() - Method in class org.apache.cassandra.cql.UpdateStatement
True if an explicit consistency level was parsed from the statement.
isSetConsistencyLevel() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
True if an explicit consistency level was parsed from the statement.
isSetKeyspace() - Method in class org.apache.cassandra.cql.SelectStatement
 
isSetTimestamp() - Method in class org.apache.cassandra.cql.AbstractModification
 
isSetTimestamp() - Method in class org.apache.cassandra.cql.BatchStatement
 
isSetTimestamp() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
isShutdown() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
isSignaled() - Method in class org.apache.cassandra.utils.SimpleCondition
 
isSigned() - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcType
 
isSigned() - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcUUID
 
isSigned() - Method in class org.apache.cassandra.cql.jdbc.JdbcAscii
 
isSigned() - Method in class org.apache.cassandra.cql.jdbc.JdbcBoolean
 
isSigned() - Method in class org.apache.cassandra.cql.jdbc.JdbcBytes
 
isSigned() - Method in class org.apache.cassandra.cql.jdbc.JdbcDate
 
isSigned() - Method in class org.apache.cassandra.cql.jdbc.JdbcDecimal
 
isSigned() - Method in class org.apache.cassandra.cql.jdbc.JdbcDouble
 
isSigned() - Method in class org.apache.cassandra.cql.jdbc.JdbcFloat
 
isSigned() - Method in class org.apache.cassandra.cql.jdbc.JdbcInt32
 
isSigned() - Method in class org.apache.cassandra.cql.jdbc.JdbcInteger
 
isSigned() - Method in class org.apache.cassandra.cql.jdbc.JdbcLong
 
isSigned() - Method in class org.apache.cassandra.cql.jdbc.JdbcUTF8
 
isSnapshotBeforeCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
ISSTableColumnIterator - Interface in org.apache.cassandra.db.columniterator
 
isStopRequested() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
 
isStreamCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
isSuccess() - Method in class org.apache.cassandra.db.WriteResponse
 
isSuper() - Method in class org.apache.cassandra.db.ColumnFamily
 
isSupportedBy(SemanticVersion) - Method in class org.apache.cassandra.utils.SemanticVersion
 
isTerminated() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
isThriftServerRunning() - Method in class org.apache.cassandra.tools.NodeProbe
 
isToken - Variable in class org.apache.cassandra.cql3.Term
 
IStreamCallback - Interface in org.apache.cassandra.streaming
Callback interface for streaming session success/failure.
isUnary() - Method in class org.apache.cassandra.cql.Operation
 
isUnary() - Method in class org.apache.cassandra.cql3.Operation
 
isUnused() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
isUserDefined - Variable in class org.apache.cassandra.db.compaction.CompactionTask
 
isUserDefined(boolean) - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
isValid() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isWildcard() - Method in class org.apache.cassandra.cql.SelectExpression
 
isWildcard() - Method in class org.apache.cassandra.cql.SelectStatement
 
isWrapAround(T, T) - 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.cql3.CFDefinition
 
iterator() - Method in class org.apache.cassandra.cql3.UntypedResultSet
 
iterator() - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
iterator(ByteBuffer) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
iterator() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
iterator(ByteBuffer) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
iterator() - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
iterator(ByteBuffer) - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
iterator() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
iterator() - Method in class org.apache.cassandra.db.compaction.CompactionIterable
 
iterator() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
iterator() - Method in class org.apache.cassandra.db.compaction.ParallelCompactionIterable
 
iterator(ByteBuffer) - Method in interface org.apache.cassandra.db.ISortedColumns
Returns an iterator over the columns of this map starting from the first column whose name is equal or greater than @param start.
iterator() - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
iterator(ByteBuffer) - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
iterator() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
iterator(ByteBuffer) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
iterator - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
 
iterator(long, int) - Method in class org.apache.cassandra.io.util.SegmentedFile
 
iterator() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
iterator() - Method in class org.apache.cassandra.utils.BoundedStatsDeque
 
iterator() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRangeIterator
 
iterators() - Method in interface org.apache.cassandra.utils.IMergeIterator
 
iterators - Variable in class org.apache.cassandra.utils.MergeIterator
 
iterators() - Method in class org.apache.cassandra.utils.MergeIterator
 
ITransportFactory - Interface in org.apache.cassandra.thrift
 
IVerbHandler - Interface in org.apache.cassandra.net
IVerbHandler provides the method that all verb handlers need to implement.
IVersionedSerializer<T> - Interface in org.apache.cassandra.io
 
IWriteResponseHandler - Interface in org.apache.cassandra.service
 

J

J - Static variable in class org.apache.cassandra.cql.CqlLexer
 
J - Static variable in class org.apache.cassandra.cql.CqlParser
 
J - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
J - Static variable in class org.apache.cassandra.cql3.CqlParser
 
JdbcAscii - Class in org.apache.cassandra.cql.jdbc
 
JdbcBoolean - Class in org.apache.cassandra.cql.jdbc
 
JdbcBytes - Class in org.apache.cassandra.cql.jdbc
 
JdbcCounterColumn - Class in org.apache.cassandra.cql.jdbc
 
JdbcDate - Class in org.apache.cassandra.cql.jdbc
 
JdbcDecimal - Class in org.apache.cassandra.cql.jdbc
 
JdbcDouble - Class in org.apache.cassandra.cql.jdbc
 
JdbcFloat - Class in org.apache.cassandra.cql.jdbc
 
JdbcInt32 - Class in org.apache.cassandra.cql.jdbc
 
JdbcInteger - Class in org.apache.cassandra.cql.jdbc
 
JdbcLexicalUUID - Class in org.apache.cassandra.cql.jdbc
 
JdbcLexicalUUID() - Constructor for class org.apache.cassandra.cql.jdbc.JdbcLexicalUUID
 
JdbcLong - Class in org.apache.cassandra.cql.jdbc
 
JdbcTimeUUID - Class in org.apache.cassandra.cql.jdbc
 
JdbcUTF8 - Class in org.apache.cassandra.cql.jdbc
 
JdbcUTF8() - Constructor for class org.apache.cassandra.cql.jdbc.JdbcUTF8
 
JdbcUUID - Class in org.apache.cassandra.cql.jdbc
 
JMXConfigurableThreadPoolExecutor - Class in org.apache.cassandra.concurrent
 
JMXConfigurableThreadPoolExecutor(int, long, TimeUnit, BlockingQueue<Runnable>, NamedThreadFactory, String) - Constructor for class org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutor
 
JMXConfigurableThreadPoolExecutorMBean - Interface in org.apache.cassandra.concurrent
 
JMXEnabledThreadPoolExecutor - Class in org.apache.cassandra.concurrent
This is a wrapper class for the ScheduledThreadPoolExecutor.
JMXEnabledThreadPoolExecutor(String) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(String, String) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(String, int) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(int, long, TimeUnit, BlockingQueue<Runnable>, NamedThreadFactory, String) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(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
 
jmxPort - Variable in class org.apache.cassandra.cli.CliSessionState
 
job_jar_file_location - Variable in class org.apache.cassandra.config.Config
 
job_tracker_host - Variable in class org.apache.cassandra.config.Config
 
joinRing() - Method in class org.apache.cassandra.service.StorageService
 
joinRing() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
joinRing() - Method in class org.apache.cassandra.tools.NodeProbe
 
joinSelector() - Method in class org.apache.cassandra.thrift.CustomTHsHaServer
 
json(Object) - Static method in class org.apache.cassandra.utils.FBUtilities
 

K

K - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K - Static variable in class org.apache.cassandra.cql.CqlParser
 
K - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_ADD - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_ADD - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_ADD - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_ADD - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_ALL - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_ALL - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_ALTER - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_ALTER - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_ALTER - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_ALTER - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_AND - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_AND - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_AND - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_AND - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_APPLY - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_APPLY - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_APPLY - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_APPLY - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_ASC - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_ASC - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_ASCII - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_ASCII - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_BATCH - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_BATCH - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_BATCH - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_BATCH - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_BEGIN - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_BEGIN - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_BEGIN - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_BEGIN - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_BIGINT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_BIGINT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_BLOB - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_BLOB - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_BOOLEAN - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_BOOLEAN - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_BY - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_BY - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_CLUSTERING - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_CLUSTERING - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_COLUMNFAMILY - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_COLUMNFAMILY - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_COLUMNFAMILY - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_COLUMNFAMILY - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_COMPACT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_COMPACT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_CONSISTENCY - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_CONSISTENCY - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_CONSISTENCY - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_CONSISTENCY - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_COUNT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_COUNT - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_COUNT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_COUNT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_COUNTER - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_COUNTER - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_CREATE - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_CREATE - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_CREATE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_CREATE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_DECIMAL - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_DECIMAL - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_DELETE - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_DELETE - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_DELETE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_DELETE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_DESC - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_DESC - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_DESCRIBE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_DESCRIBE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_DOUBLE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_DOUBLE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_DROP - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_DROP - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_DROP - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_DROP - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_FIRST - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_FIRST - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_FLOAT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_FLOAT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_FOR - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_FOR - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_FROM - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_FROM - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_FROM - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_FROM - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_FULL_ACCESS - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_FULL_ACCESS - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_GRANT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_GRANT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_GRANTS - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_GRANTS - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_IN - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_IN - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_IN - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_IN - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_INDEX - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_INDEX - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_INDEX - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_INDEX - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_INSERT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_INSERT - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_INSERT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_INSERT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_INT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_INT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_INTO - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_INTO - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_INTO - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_INTO - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_KEY - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_KEY - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_KEY - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_KEY - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_KEYSPACE - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_KEYSPACE - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_KEYSPACE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_KEYSPACE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_LEVEL - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_LEVEL - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_LEVEL - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_LEVEL - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_LIMIT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_LIMIT - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_LIMIT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_LIMIT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_LIST - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_LIST - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_NO_ACCESS - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_NO_ACCESS - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_ON - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_ON - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_ON - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_ON - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_OPTION - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_OPTION - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_ORDER - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_ORDER - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_PRIMARY - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_PRIMARY - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_PRIMARY - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_PRIMARY - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_REVERSED - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_REVERSED - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_REVOKE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_REVOKE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_SELECT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_SELECT - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_SELECT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_SELECT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_SET - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_SET - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_SET - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_SET - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_STORAGE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_STORAGE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_TEXT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_TEXT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_TIMESTAMP - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_TIMESTAMP - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_TIMESTAMP - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_TIMESTAMP - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_TIMEUUID - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_TIMEUUID - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_TO - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_TO - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_TOKEN - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_TOKEN - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_TRUNCATE - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_TRUNCATE - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_TRUNCATE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_TRUNCATE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_TTL - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_TTL - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_TTL - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_TTL - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_TYPE - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_TYPE - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_TYPE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_TYPE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_UPDATE - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_UPDATE - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_UPDATE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_UPDATE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_USE - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_USE - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_USE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_USE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_USING - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_USING - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_USING - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_USING - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_UUID - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_UUID - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_VALUES - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_VALUES - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_VALUES - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_VALUES - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_VARCHAR - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_VARCHAR - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_VARINT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_VARINT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_WHERE - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_WHERE - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_WHERE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_WHERE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_WITH - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_WITH - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_WITH - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_WITH - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_WRITETIME - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_WRITETIME - Static variable in class org.apache.cassandra.cql3.CqlParser
 
KEEPALIVE - Static variable in class org.apache.cassandra.concurrent.StageManager
 
key - Variable in class org.apache.cassandra.cache.RowCacheKey
 
key - Variable in class org.apache.cassandra.cql3.CFDefinition
 
key - Variable in class org.apache.cassandra.cql3.ColumnIdentifier
 
key - Variable in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
key - Variable in class org.apache.cassandra.db.compaction.AbstractCompactedRow
 
key() - Method in class org.apache.cassandra.db.CounterMutation
 
key - Variable in class org.apache.cassandra.db.DecoratedKey
 
key - Variable in class org.apache.cassandra.db.filter.QueryFilter
 
key() - Method in interface org.apache.cassandra.db.IMutation
 
key - Variable in class org.apache.cassandra.db.ReadCommand
 
key - Variable in class org.apache.cassandra.db.Row
 
key() - Method in class org.apache.cassandra.db.RowMutation
 
key() - Method in class org.apache.cassandra.db.WriteResponse
 
key - Variable in class org.apache.cassandra.service.AbstractRowResolver
 
key_alias - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
key_cache_keys_to_save - Variable in class org.apache.cassandra.config.Config
 
key_cache_save_period - Variable in class org.apache.cassandra.config.Config
 
key_cache_size - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
key_cache_size_in_mb - Variable in class org.apache.cassandra.config.Config
 
key_validation_class - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
keyAlias(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
 
keyAlias(String) - Method in class org.apache.cassandra.config.CFMetaData
 
keyCache - Variable in class org.apache.cassandra.service.CacheService
 
KeyCacheKey - Class in org.apache.cassandra.cache
 
KeyCacheKey(Descriptor, ByteBuffer) - Constructor for class org.apache.cassandra.cache.KeyCacheKey
 
keyExistenceIsExpensive - Variable in class org.apache.cassandra.db.compaction.CompactionController
 
KeyIterator - Class in org.apache.cassandra.io.sstable
 
KeyIterator(Descriptor) - Constructor for class org.apache.cassandra.io.sstable.KeyIterator
 
keyName - Variable in class org.apache.cassandra.cql.AbstractModification
 
keyRangeExpr() - Method in class org.apache.cassandra.cli.CliParser
 
keySamples(Range<Token>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
keySet() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
keySet() - Method in interface org.apache.cassandra.cache.ICache
 
keySet() - Method in class org.apache.cassandra.cache.SerializingCache
 
keySet() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
keySet() - Method in class org.apache.cassandra.utils.ExpiringMap
 
KeysIndex - Class in org.apache.cassandra.db.index.keys
Implements a secondary index for a column family using a second column family in which the row keys are indexed values, and column names are base row keys.
KeysIndex() - Constructor for class org.apache.cassandra.db.index.keys.KeysIndex
 
KEYSPACE - Static variable in class org.apache.cassandra.cli.CliLexer
 
KEYSPACE - Static variable in class org.apache.cassandra.cli.CliParser
 
keyspace() - Method in class org.apache.cassandra.cli.CliParser
 
keyspace - Variable in class org.apache.cassandra.cli.CliSessionState
 
keyspace - Variable in class org.apache.cassandra.cql.AbstractModification
 
keyspace() - Method in class org.apache.cassandra.cql3.statements.CFStatement
 
keyspace() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
keyspace - Variable in class org.apache.cassandra.db.IndexScanCommand
 
keyspace - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
keyspace - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
keyspace - Variable in class org.apache.cassandra.db.SnapshotCommand
 
keyspace - Variable in class org.apache.cassandra.db.TruncateResponse
 
keyspace - Variable in class org.apache.cassandra.db.Truncation
 
keyspaceName() - Method in class org.apache.cassandra.cql3.CqlParser
 
keyspaceNewName() - Method in class org.apache.cassandra.cli.CliParser
 
KeyspaceNotDefinedException - Exception in org.apache.cassandra.db
 
KeyspaceNotDefinedException(String) - Constructor for exception org.apache.cassandra.db.KeyspaceNotDefinedException
 
KEYSPACES - Static variable in class org.apache.cassandra.auth.Resources
 
KEYSPACES - Static variable in class org.apache.cassandra.cli.CliLexer
 
KEYSPACES - Static variable in class org.apache.cassandra.cli.CliParser
 
KeysSearcher - Class in org.apache.cassandra.db.index.keys
 
KeysSearcher(SecondaryIndexManager, Set<ByteBuffer>) - Constructor for class org.apache.cassandra.db.index.keys.KeysSearcher
 
keystore - Variable in class org.apache.cassandra.config.EncryptionOptions
 
keystore_password - Variable in class org.apache.cassandra.config.EncryptionOptions
 
keyValidator(AbstractType<?>) - Method in class org.apache.cassandra.config.CFMetaData
 
keyValuePair() - Method in class org.apache.cassandra.cli.CliParser
 
keyValuePairExpr() - Method in class org.apache.cassandra.cli.CliParser
 
keywords - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
keywords - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
keywords - Static variable in class org.apache.cassandra.cql3.KSPropDefs
 
kind - Variable in class org.apache.cassandra.cql3.CFDefinition.Name
 
kind() - Method in class org.apache.cassandra.db.DecoratedKey
 
kind() - Method in class org.apache.cassandra.db.RowPosition
 
kind() - Method in class org.apache.cassandra.dht.Token.KeyBound
 
ks - Variable in class org.apache.cassandra.db.migration.avro.AddKeyspace
 
KsDef - Class in org.apache.cassandra.db.migration.avro
 
KsDef() - Constructor for class org.apache.cassandra.db.migration.avro.KsDef
 
ksFromAvro(KsDef) - Static method in class org.apache.cassandra.config.Avro
Deprecated. 
KSMetaData - Class in org.apache.cassandra.config
 
ksName - Variable in class org.apache.cassandra.config.CFMetaData
 
ksname - Variable in class org.apache.cassandra.db.migration.avro.DropColumnFamily
 
ksname - Variable in class org.apache.cassandra.db.migration.avro.DropKeyspace
 
ksname - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
KSPropDefs - Class in org.apache.cassandra.cql3
 
KSPropDefs() - Constructor for class org.apache.cassandra.cql3.KSPropDefs
 
KW_BF_FP_CHANCE - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
KW_BF_FP_CHANCE - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
KW_CACHING - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
KW_CACHING - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
KW_COMMENT - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
KW_COMMENT - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
KW_COMPACTION_STRATEGY_CLASS - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
KW_COMPACTION_STRATEGY_CLASS - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
KW_COMPARATOR - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
KW_DCLOCALREADREPAIRCHANCE - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
KW_DCLOCALREADREPAIRCHANCE - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
KW_DEFAULTVALIDATION - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
KW_DURABLE_WRITES - Static variable in class org.apache.cassandra.cql3.KSPropDefs
 
KW_GCGRACESECONDS - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
KW_GCGRACESECONDS - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
KW_MAXCOMPACTIONTHRESHOLD - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
KW_MAXCOMPACTIONTHRESHOLD - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
KW_MINCOMPACTIONTHRESHOLD - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
KW_MINCOMPACTIONTHRESHOLD - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
KW_READREPAIRCHANCE - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
KW_READREPAIRCHANCE - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
KW_REPLICATEONWRITE - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
KW_REPLICATEONWRITE - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
KW_REPLICATION_STRATEGY - Static variable in class org.apache.cassandra.cql3.KSPropDefs
 

L

L - Static variable in class org.apache.cassandra.cql.CqlLexer
 
L - Static variable in class org.apache.cassandra.cql.CqlParser
 
L - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
L - Static variable in class org.apache.cassandra.cql3.CqlParser
 
LA(int) - Method in class org.apache.cassandra.cli.CliCompiler.ANTLRNoCaseStringStream
 
last - Variable in class org.apache.cassandra.io.sstable.SSTable
 
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
 
LatencyTracker - Class in org.apache.cassandra.utils
 
LatencyTracker() - Constructor for class org.apache.cassandra.utils.LatencyTracker
 
LazilyCompactedRow - Class in org.apache.cassandra.db.compaction
LazilyCompactedRow only computes the row bloom filter and column index in memory (at construction time); it does this by reading one column at a time from each of the rows being compacted, and merging them as it does so.
LazilyCompactedRow(CompactionController, List<? extends ICountableColumnIterator>) - Constructor for class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
leaving(Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
left - Variable in class org.apache.cassandra.dht.AbstractBounds
 
left(Token, long) - 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
 
LegacyBloomFilterSerializer - Class in org.apache.cassandra.utils
 
LegacyBloomFilterSerializer() - Constructor for class org.apache.cassandra.utils.LegacyBloomFilterSerializer
 
length() - Method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
 
length - Variable in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
 
length() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
length - Variable in class org.apache.cassandra.io.util.SegmentedFile
 
length() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
LENGTH - Static variable in class org.apache.cassandra.utils.NodeId
 
length() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
Letter - Static variable in class org.apache.cassandra.cli.CliLexer
 
Letter - Static variable in class org.apache.cassandra.cli.CliParser
 
LETTER - Static variable in class org.apache.cassandra.cql.CqlLexer
 
LETTER - Static variable in class org.apache.cassandra.cql.CqlParser
 
LETTER - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
LETTER - Static variable in class org.apache.cassandra.cql3.CqlParser
 
LeveledCompactionStrategy - Class in org.apache.cassandra.db.compaction
 
LeveledCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
LeveledCompactionTask - Class in org.apache.cassandra.db.compaction
 
LeveledCompactionTask(ColumnFamilyStore, Collection<SSTableReader>, int, int) - Constructor for class org.apache.cassandra.db.compaction.LeveledCompactionTask
 
LeveledManifest - Class in org.apache.cassandra.db.compaction
 
LexicalUUIDType - Class in org.apache.cassandra.db.marshal
 
LIMIT - Static variable in class org.apache.cassandra.cli.CliLexer
 
LIMIT - Static variable in class org.apache.cassandra.cli.CliParser
 
LIST - Static variable in class org.apache.cassandra.cli.CliLexer
 
LIST - Static variable in class org.apache.cassandra.cli.CliParser
 
list() - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
listen(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
Listen on the specified port.
listen() - Method in class org.apache.cassandra.thrift.TCustomServerSocket
 
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
 
listFiles() - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
listGrantsStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
ListGrantsStatement - Class in org.apache.cassandra.cql3.statements
 
ListGrantsStatement(String) - Constructor for class org.apache.cassandra.cql3.statements.ListGrantsStatement
 
listPermissions(String) - Method in interface org.apache.cassandra.auth.IAuthority2
LIST GRANTS FOR ; Not 'SHOW' because it's reserved for CQLsh for commands like 'show cluster'
listPermissions(String) - Method in class org.apache.cassandra.auth.IAuthorityContainer
 
listPermissions(String) - Method in class org.apache.cassandra.service.ClientState
 
listStatement() - Method in class org.apache.cassandra.cli.CliParser
 
load(Collection<KSMetaData>) - Method in class org.apache.cassandra.config.Schema
Load up non-system tables
load(KSMetaData) - Method in class org.apache.cassandra.config.Schema
Load specific keyspace into Schema
load(CFMetaData) - Method in class org.apache.cassandra.config.Schema
Load individual ColumnFamily Definition to the schema (to make ColumnFamily lookup faster)
load(double) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
LoadBroadcaster - Class in org.apache.cassandra.service
 
loadFromStorage(UUID) - Static method in class org.apache.cassandra.db.DefsTable
Loads a version of keyspace definitions from storage (using old SCHEMA_CF as a data source) Note: If definitions where found in SCHEMA_CF this method would load them into new schema handling table KEYSPACE_CF
loadFromTable() - Static method in class org.apache.cassandra.db.DefsTable
Load keyspace definitions for the system keyspace (system.SCHEMA_KEYSPACES_CF)
loadNewSSTables(String, String) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
See #StorageService.loadNewSSTables(String, String) for more info
loadNewSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
#Scan through Keyspace/ColumnFamily's data directory determine which SSTables should be loaded and load them
loadNewSSTables() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Scan through Keyspace/ColumnFamily's data directory determine which SSTables should be loaded and load them
loadNewSSTables(String, String) - Method in class org.apache.cassandra.service.StorageService
#Load new SSTables to the given keyspace/columnFamily
loadNewSSTables(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Load new SSTables to the given keyspace/columnFamily
loadNewSSTables(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
loadSchemas() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
load keyspace (table) definitions, but do not initialize the table instances.
loadTokens() - Static method in class org.apache.cassandra.db.SystemTable
Return a map of stored tokens to IP addresses
LocalByPartionerType<T extends Token> - Class in org.apache.cassandra.db.marshal
for sorting columns representing row keys in the row ordering as determined by a partitioner.
LocalByPartionerType(IPartitioner<T>) - Constructor for class org.apache.cassandra.db.marshal.LocalByPartionerType
 
localCopy(ColumnFamilyStore) - Method in class org.apache.cassandra.db.Column
 
localCopy(ColumnFamilyStore, Allocator) - Method in class org.apache.cassandra.db.Column
 
localCopy(ColumnFamilyStore) - Method in class org.apache.cassandra.db.CounterColumn
 
localCopy(ColumnFamilyStore, Allocator) - Method in class org.apache.cassandra.db.CounterColumn
 
localCopy(ColumnFamilyStore) - Method in class org.apache.cassandra.db.CounterUpdateColumn
 
localCopy(ColumnFamilyStore, Allocator) - Method in class org.apache.cassandra.db.CounterUpdateColumn
 
localCopy(ColumnFamilyStore) - Method in class org.apache.cassandra.db.DeletedColumn
 
localCopy(ColumnFamilyStore, Allocator) - Method in class org.apache.cassandra.db.DeletedColumn
 
localCopy(ColumnFamilyStore) - Method in class org.apache.cassandra.db.ExpiringColumn
 
localCopy(ColumnFamilyStore, Allocator) - Method in class org.apache.cassandra.db.ExpiringColumn
 
localCopy(ColumnFamilyStore) - Method in interface org.apache.cassandra.db.IColumn
clones the column for the row cache, interning column names and making copies of other underlying byte buffers
localCopy(ColumnFamilyStore, Allocator) - Method in interface org.apache.cassandra.db.IColumn
clones the column for the memtable, interning column names and making copies of other underlying byte buffers.
localCopy(ColumnFamilyStore) - Method in class org.apache.cassandra.db.SuperColumn
 
localCopy(ColumnFamilyStore, Allocator) - Method in class org.apache.cassandra.db.SuperColumn
 
localdc - Static variable in class org.apache.cassandra.service.ReadCallback
 
localDeletionTime - Variable in class org.apache.cassandra.db.ISortedColumns.DeletionInfo
 
localFile - Variable in class org.apache.cassandra.streaming.IncomingStreamReader
 
LocalPartitioner - Class in org.apache.cassandra.dht
 
LocalPartitioner(AbstractType<?>) - Constructor for class org.apache.cassandra.dht.LocalPartitioner
 
LocalStrategy - Class in org.apache.cassandra.locator
 
LocalStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.LocalStrategy
 
LocalToken - Class in org.apache.cassandra.dht
 
LocalToken(AbstractType<?>, ByteBuffer) - Constructor for class org.apache.cassandra.dht.LocalToken
 
log() - Static method in class org.apache.cassandra.utils.StatusLogger
 
logExceptionsAfterExecute(Runnable, Throwable) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
Send @param t and any exception wrapped by @param r to the default uncaught exception handler, or log them if none such is set up
logger - Static variable in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
logger - Static variable in class org.apache.cassandra.cql3.PropertyDefinitions
 
logger - Static variable in class org.apache.cassandra.db.compaction.CompactionTask
 
logger - Static variable in class org.apache.cassandra.gms.EndpointState
 
logger - Static variable in class org.apache.cassandra.locator.Ec2Snitch
 
logger - Static variable in class org.apache.cassandra.service.AbstractRowResolver
 
logger - Static variable in class org.apache.cassandra.service.ReadCallback
 
logger - Static variable in class org.apache.cassandra.service.TruncateResponseHandler
 
logger - Static variable in class org.apache.cassandra.service.WriteResponseHandler
 
login(Map<? extends CharSequence, ? extends CharSequence>) - Method in class org.apache.cassandra.service.ClientState
Attempts to login this client with the given credentials map.
login(AuthenticationRequest) - Method in class org.apache.cassandra.thrift.CassandraServer
 
logOpenException(Descriptor, IOException) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
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
 

M

M - Static variable in class org.apache.cassandra.cql.CqlLexer
 
M - Static variable in class org.apache.cassandra.cql.CqlParser
 
M - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
M - Static variable in class org.apache.cassandra.cql3.CqlParser
 
mA() - Method in class org.apache.cassandra.cql.CqlLexer
 
mA() - Method in class org.apache.cassandra.cql3.CqlLexer
 
main(String[]) - Static method in class org.apache.cassandra.cli.CliMain
 
main(String[]) - Static method in class org.apache.cassandra.gms.FailureDetector
 
main(String[]) - Static method in class org.apache.cassandra.thrift.CassandraDaemon
 
main(String[]) - Static method in class org.apache.cassandra.tools.BulkLoader
 
main(String[]) - Static method in class org.apache.cassandra.tools.GetVersion
 
main(String[]) - Static method in class org.apache.cassandra.tools.NodeCmd
 
main(String[]) - Static method in class org.apache.cassandra.tools.SSTableExport
Given arguments specifying an SSTable, and optionally an output file, export the contents of the SSTable to JSON.
main(String[]) - Static method in class org.apache.cassandra.tools.SSTableImport
Converts JSON to an SSTable file.
main(String[]) - Static method in class org.apache.cassandra.tools.SSTableMetadataViewer
 
main(String[]) - Static method in class org.apache.cassandra.tools.StandaloneScrubber
 
major - Variable in class org.apache.cassandra.utils.SemanticVersion
 
makeMutationMessage(int) - Method in class org.apache.cassandra.db.CounterMutation
 
makeReplicationMutation() - Method in class org.apache.cassandra.db.CounterMutation
 
makeRowBounds(Token, Token, IPartitioner) - Static method in class org.apache.cassandra.dht.Bounds
Compute a bounds of keys corresponding to a given bounds of token.
makeRowRange(Token, Token, IPartitioner) - Static method in class org.apache.cassandra.dht.Range
Compute a range of keys corresponding to a given range of token.
makeTruncateResponseMessage(Message, TruncateResponse) - Static method in class org.apache.cassandra.db.TruncateResponse
 
makeType1UUIDFromHost(InetAddress) - Static method in class org.apache.cassandra.utils.UUIDGen
Creates a type 1 UUID (time-based UUID) that substitutes a hash of an IP address in place of the MAC (unavailable to Java).
makeWriteResponseMessage(Message, WriteResponse) - Static method in class org.apache.cassandra.db.WriteResponse
 
mAlnum() - Method in class org.apache.cassandra.cli.CliLexer
 
manages(String) - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
 
mAND() - Method in class org.apache.cassandra.cli.CliLexer
 
mAPI_VERSION() - Method in class org.apache.cassandra.cli.CliLexer
 
MappedFileDataInput - Class in org.apache.cassandra.io.util
 
MappedFileDataInput(FileInputStream, String, int) - Constructor for class org.apache.cassandra.io.util.MappedFileDataInput
 
MappedFileDataInput(MappedByteBuffer, String, int) - Constructor for class org.apache.cassandra.io.util.MappedFileDataInput
 
MAPRED_TASK_ID - Static variable in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
 
mark() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
mark() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
mark - Variable in class org.apache.cassandra.io.util.FastByteArrayInputStream
The current mark position.
mark(int) - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
Sets a mark position in this ByteArrayInputStream.
mark() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
mark() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
mark() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
mark() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
markClean(Integer, ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
Marks the ColumnFamily specified by cfId as clean for this log segment.
markCompacted(Collection<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
markCompacted(Collection<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.DataTracker
 
markCompacted() - Method in class org.apache.cassandra.io.sstable.SSTableReader
Mark the sstable as compacted.
markCompacting(Collection<SSTableReader>, int, int) - Method in class org.apache.cassandra.db.DataTracker
 
markCurrentSSTablesReferenced() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Get the current sstables, acquiring references on all of them.
markDeltaToBeCleared(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Mark context to delete delta afterward.
markDeltaToBeCleared() - Method in class org.apache.cassandra.db.CounterColumn
 
markedForDeleteAt - Variable in class org.apache.cassandra.db.ISortedColumns.DeletionInfo
 
markedPointer - Variable in class org.apache.cassandra.io.util.RandomAccessReader
 
markReferenced(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
markReferenced(RowPosition, RowPosition) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
markSSTablesForCompaction() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
Try to mark the sstable to compact as compacting.
markSSTablesForCompaction(int, int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
markSSTablesForCompaction(int, int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
 
markSupported() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
Indicates whether this stream supports the mark() and reset() methods.
markSupported() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
markSuspect() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
MarshalException - Exception in org.apache.cassandra.cql.jdbc
 
MarshalException(String) - Constructor for exception org.apache.cassandra.cql.jdbc.MarshalException
 
MarshalException(String, Throwable) - Constructor for exception org.apache.cassandra.cql.jdbc.MarshalException
 
MarshalException - Exception in org.apache.cassandra.db.marshal
 
MarshalException(String) - Constructor for exception org.apache.cassandra.db.marshal.MarshalException
 
MarshalException(String, Throwable) - Constructor for exception org.apache.cassandra.db.marshal.MarshalException
 
mASSUME() - Method in class org.apache.cassandra.cli.CliLexer
 
max() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
max - Variable in class org.apache.cassandra.utils.IntervalTree.Interval
 
max() - Method in class org.apache.cassandra.utils.IntervalTree.IntervalTree
 
MAX_COLUMNS_DEFAULT - Static variable in class org.apache.cassandra.cql.SelectExpression
 
max_compaction_threshold - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
MAX_CONNECT_ATTEMPTS - Static variable in class org.apache.cassandra.streaming.FileStreamTask
 
max_hint_window_in_ms - Variable in class org.apache.cassandra.config.Config
 
MAX_NAME_LENGTH - Static variable in interface org.apache.cassandra.db.IColumn
 
MAX_REPLICATE_ON_WRITE_TASKS - Static variable in class org.apache.cassandra.concurrent.StageManager
 
MAX_SEGMENT_SIZE - Static variable in class org.apache.cassandra.io.util.MmappedSegmentedFile
 
max_streaming_retries - Variable in class org.apache.cassandra.config.Config
 
MAX_TTL - Static variable in class org.apache.cassandra.db.ExpiringColumn
 
MAX_UNSIGNED_SHORT - Static variable in class org.apache.cassandra.utils.FBUtilities
 
maxColumns() - Method in class org.apache.cassandra.db.filter.ExtendedFilter
 
maxCompactionThreshold(int) - Method in class org.apache.cassandra.config.CFMetaData
 
maxDataAge - Variable in class org.apache.cassandra.io.sstable.SSTableReader
maxDataAge is a timestamp in local server time (e.g.
MAXIMUM - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 
maxIsColumns - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
maxKeyBound(IPartitioner) - Method in class org.apache.cassandra.dht.Token
 
maxKeyBound() - Method in class org.apache.cassandra.dht.Token
 
maxLiveColumns - Variable in class org.apache.cassandra.service.RowRepairResolver
 
maxOrdering - Static variable in class org.apache.cassandra.utils.IntervalTree.Interval
 
maxResults - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
maxRows() - Method in class org.apache.cassandra.db.filter.ExtendedFilter
 
maxsize() - Method in class org.apache.cassandra.utils.MerkleTree
 
maxsize(long) - Method in class org.apache.cassandra.utils.MerkleTree
 
maxTimestamp() - Method in class org.apache.cassandra.db.Column
 
maxTimestamp() - Method in class org.apache.cassandra.db.ColumnFamily
 
maxTimestamp() - Method in class org.apache.cassandra.db.compaction.AbstractCompactedRow
 
maxTimestamp() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
maxTimestamp() - Method in class org.apache.cassandra.db.compaction.PrecompactedRow
 
maxTimestamp() - Method in class org.apache.cassandra.db.EchoedRow
 
maxTimestamp() - Method in interface org.apache.cassandra.db.IColumn
For a standard column, this is the same as timestamp().
maxTimestamp() - Method in class org.apache.cassandra.db.SuperColumn
 
maxTimestamp - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
maxTimestamp - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
 
maxTimestampComparator - Static variable in class org.apache.cassandra.io.sstable.SSTable
 
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
maybeArchive(String, String) - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
maybeBuildSecondaryIndexes(Collection<SSTableReader>, SortedSet<ByteBuffer>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
Does a full, blocking rebuild of the indexes specified by columns from the sstables.
maybeCreateWriter(ColumnFamilyStore, File, int, SSTableWriter, Collection<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
 
maybeGenerateRetryCommand(RepairCallback, Row) - Method in class org.apache.cassandra.db.ReadCommand
 
maybeGenerateRetryCommand(RepairCallback, Row) - Method in class org.apache.cassandra.db.SliceFromReadCommand
 
maybeInitializeLocalState(int) - Method in class org.apache.cassandra.gms.Gossiper
 
maybeIntern(ByteBuffer) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
maybeLoad() - Static method in class org.apache.cassandra.utils.Mx4jTool
Starts a JMX over http interface if and mx4j-tools.jar is in the classpath.
maybeRenew(CounterColumn) - Method in class org.apache.cassandra.utils.NodeId.OneShotRenewer
 
maybeResetDeletionTimes(int) - Method in class org.apache.cassandra.db.AbstractColumnContainer
Drops expired row-level tombstones.
maybeResetDeletionTimes(int) - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
 
maybeResetDeletionTimes(int) - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
maybeResetDeletionTimes(int) - Method in interface org.apache.cassandra.db.ISortedColumns
 
maybeResolveForRepair() - Method in class org.apache.cassandra.service.ReadCallback
Check digests in the background on the Repair stage if we've received replies too all the requests we sent.
maybeRestoreArchive() - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
maybeSwitchMemtable(Memtable, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
flush the given memtable and swap in a new one for its CFS, if it hasn't been frozen already.
maybeTrim(Row) - Method in class org.apache.cassandra.db.ReadCommand
 
maybeTrim(Row) - Method in class org.apache.cassandra.db.SliceFromReadCommand
 
maybeWaitForArchiving(String) - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
mayThrottle(long) - Method in class org.apache.cassandra.db.compaction.CompactionController
 
mB() - Method in class org.apache.cassandra.cql.CqlLexer
 
mB() - Method in class org.apache.cassandra.cql3.CqlLexer
 
MBEAN_NAME - Static variable in class org.apache.cassandra.gms.FailureDetector
 
MBEAN_NAME - Static variable in class org.apache.cassandra.net.MessagingService
 
MBEAN_NAME - Static variable in class org.apache.cassandra.service.CacheService
 
MBEAN_NAME - Static variable in class org.apache.cassandra.service.StorageProxy
 
MBEAN_OBJECT_NAME - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
 
MBEAN_OBJECT_NAME - Static variable in class org.apache.cassandra.streaming.StreamingService
 
mBY() - Method in class org.apache.cassandra.cli.CliLexer
 
mC() - Method in class org.apache.cassandra.cql.CqlLexer
 
mC() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mCharacterEscapeSequence() - Method in class org.apache.cassandra.cli.CliLexer
 
mCOLUMN() - Method in class org.apache.cassandra.cli.CliLexer
 
mCOMMENT() - Method in class org.apache.cassandra.cli.CliLexer
 
mCOMMENT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mCOMMENT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mCOMPIDENT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mCONFIG() - Method in class org.apache.cassandra.cli.CliLexer
 
mCONNECT() - Method in class org.apache.cassandra.cli.CliLexer
 
mCONSISTENCYLEVEL() - Method in class org.apache.cassandra.cli.CliLexer
 
mCOUNT() - Method in class org.apache.cassandra.cli.CliLexer
 
mCREATE() - Method in class org.apache.cassandra.cli.CliLexer
 
mD() - Method in class org.apache.cassandra.cql.CqlLexer
 
mD() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mDecimalDigit() - Method in class org.apache.cassandra.cli.CliLexer
 
mDECR() - Method in class org.apache.cassandra.cli.CliLexer
 
mDEL() - Method in class org.apache.cassandra.cli.CliLexer
 
mDESCRIBE() - Method in class org.apache.cassandra.cli.CliLexer
 
mDigit() - Method in class org.apache.cassandra.cli.CliLexer
 
mDIGIT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mDIGIT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mDoubleLiteral() - Method in class org.apache.cassandra.cli.CliLexer
 
mDROP() - Method in class org.apache.cassandra.cli.CliLexer
 
mE() - Method in class org.apache.cassandra.cql.CqlLexer
 
mE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mean() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
mean() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
Memory - Class in org.apache.cassandra.io.util
 
Memory(long) - Constructor for class org.apache.cassandra.io.util.Memory
 
MemoryInputStream - Class in org.apache.cassandra.io.util
 
MemoryInputStream(FreeableMemory) - Constructor for class org.apache.cassandra.io.util.MemoryInputStream
 
MemoryOutputStream - Class in org.apache.cassandra.io.util
This class provides a way to stream the writes into the Memory
MemoryOutputStream(Memory) - Constructor for class org.apache.cassandra.io.util.MemoryOutputStream
 
Memtable - Class in org.apache.cassandra.db
 
Memtable(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.Memtable
 
memtable_flush_queue_size - Variable in class org.apache.cassandra.config.Config
 
memtable_flush_writers - Variable in class org.apache.cassandra.config.Config
 
memtable_total_space_in_mb - Variable in class org.apache.cassandra.config.Config
 
memtables - Variable in class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
 
merge(ByteBuffer, ByteBuffer, Allocator) - Method in class org.apache.cassandra.db.context.CounterContext
Return a context w/ an aggregated count for each node id.
merge(ByteBuffer, ByteBuffer, Allocator) - Method in interface org.apache.cassandra.db.context.IContext
Return a context w/ an aggregated count for each node id.
merge_shards_chance - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
mergeAndRemoveOldShards(DecoratedKey, ColumnFamily, int, int) - Static method in class org.apache.cassandra.db.CounterColumn
 
mergeAndRemoveOldShards(DecoratedKey, ColumnFamily, int, int, boolean) - Static method in class org.apache.cassandra.db.CounterColumn
There is two phase to the removal of old shards.
MergeIterator<In,Out> - Class in org.apache.cassandra.utils
Merges sorted input iterators which individually contain unique items.
MergeIterator(List<? extends CloseableIterator<In>>, MergeIterator.Reducer<In, Out>) - Constructor for class org.apache.cassandra.utils.MergeIterator
 
MergeIterator.Candidate<In> - Class in org.apache.cassandra.utils
 
MergeIterator.Candidate(CloseableIterator<In>, Comparator<In>) - Constructor for class org.apache.cassandra.utils.MergeIterator.Candidate
 
MergeIterator.Reducer<In,Out> - Class in org.apache.cassandra.utils
Accumulator that collects values of type A, and outputs a value of type B.
MergeIterator.Reducer() - Constructor for class org.apache.cassandra.utils.MergeIterator.Reducer
 
mergeRemoteSchema(byte[], int) - Static method in class org.apache.cassandra.db.DefsTable
Merge remote schema in form of row mutations with local and mutate ks/cf metadata objects (which also involves fs operations on add/drop ks/cf)
mergeSchema(Collection<RowMutation>) - Static method in class org.apache.cassandra.db.DefsTable
 
mergeShardBefore - Variable in class org.apache.cassandra.db.compaction.CompactionController
 
MerkleTree - Class in org.apache.cassandra.utils
A MerkleTree implemented as a binary tree.
MerkleTree(IPartitioner, Range<Token>, byte, long) - Constructor for class org.apache.cassandra.utils.MerkleTree
 
MerkleTree.MerkleTreeSerializer - Class in org.apache.cassandra.utils
 
MerkleTree.MerkleTreeSerializer() - Constructor for class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
 
MerkleTree.RowHash - Class in org.apache.cassandra.utils
Hash value representing a row, to be used to pass hashes to the MerkleTree.
MerkleTree.RowHash(Token, byte[]) - Constructor for class org.apache.cassandra.utils.MerkleTree.RowHash
 
MerkleTree.TreeRange - Class in org.apache.cassandra.utils
The public interface to a range in the tree.
MerkleTree.TreeRangeIterator - Class in org.apache.cassandra.utils
Returns the leaf (range) of a given tree in increasing order.
mEscapeCharacter() - Method in class org.apache.cassandra.cli.CliLexer
 
mEscapeSequence() - Method in class org.apache.cassandra.cli.CliLexer
 
Message - Class in org.apache.cassandra.net
 
Message(Header, byte[], int) - Constructor for class org.apache.cassandra.net.Message
 
Message(InetAddress, StorageService.Verb, byte[], int) - Constructor for class org.apache.cassandra.net.Message
 
MessageDeliveryTask - Class in org.apache.cassandra.net
 
MessageDeliveryTask(Message, String) - Constructor for class org.apache.cassandra.net.MessageDeliveryTask
 
messageLength(Header, String, byte[]) - Static method in class org.apache.cassandra.net.OutboundTcpConnection
 
MessageProducer - Interface in org.apache.cassandra.net
 
MessagingService - Class in org.apache.cassandra.net
 
MessagingServiceMBean - Interface in org.apache.cassandra.net
MBean exposing MessagingService metrics.
metadata - Variable in class org.apache.cassandra.cql3.CFDefinition
 
metadata() - Method in class org.apache.cassandra.db.ColumnFamily
 
metadata - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
metadata - Variable in class org.apache.cassandra.db.migration.avro.UpdateColumnFamily
 
metadata - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
metadata - Variable in class org.apache.cassandra.io.sstable.SSTable
 
metadata - Variable in class org.apache.cassandra.io.util.CompressedSegmentedFile
 
metadataIncludesModernReplayPosition - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
metadataIncludesReplayPosition - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
mEXIT() - Method in class org.apache.cassandra.cli.CliLexer
 
mF() - Method in class org.apache.cassandra.cql.CqlLexer
 
mF() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mFAMILY() - Method in class org.apache.cassandra.cli.CliLexer
 
mFILE() - Method in class org.apache.cassandra.cli.CliLexer
 
mFLOAT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mFLOAT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mG() - Method in class org.apache.cassandra.cql.CqlLexer
 
mG() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mGET() - Method in class org.apache.cassandra.cli.CliLexer
 
mH() - Method in class org.apache.cassandra.cql.CqlLexer
 
mH() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mHELP() - Method in class org.apache.cassandra.cli.CliLexer
 
mHEX() - Method in class org.apache.cassandra.cql.CqlLexer
 
mHEX() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mHexDigit() - Method in class org.apache.cassandra.cli.CliLexer
 
mHexEscapeSequence() - Method in class org.apache.cassandra.cli.CliLexer
 
mI() - Method in class org.apache.cassandra.cql.CqlLexer
 
mI() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mIDENT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mIDENT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mIdentifier() - Method in class org.apache.cassandra.cli.CliLexer
 
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
midpoint(Token, Token) - Method in interface org.apache.cassandra.dht.IPartitioner
Calculate a Token representing the approximate "middle" of the given range.
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
midpoint(BigInteger, BigInteger, int) - Static method in class org.apache.cassandra.utils.FBUtilities
Given two bit arrays represented as BigIntegers, containing the given number of significant bits, calculate a midpoint.
migrateSSTables() - Static method in class org.apache.cassandra.db.Directories
Move sstables from the pre-#2749 layout to their new location/names.
Migration - Class in org.apache.cassandra.db.migration.avro
 
Migration() - Constructor for class org.apache.cassandra.db.migration.avro.Migration
 
migration - Variable in class org.apache.cassandra.db.migration.avro.Migration
 
MigrationManager - Class in org.apache.cassandra.service
 
MigrationManager() - Constructor for class org.apache.cassandra.service.MigrationManager
 
MigrationRequestVerbHandler - Class in org.apache.cassandra.db
Sends it's current schema state in form of row mutations in reply to the remote node's request.
MigrationRequestVerbHandler() - Constructor for class org.apache.cassandra.db.MigrationRequestVerbHandler
 
MigrationsCf - Static variable in class org.apache.cassandra.config.CFMetaData
Deprecated. 
min() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
min - Variable in class org.apache.cassandra.utils.IntervalTree.Interval
 
min() - Method in class org.apache.cassandra.utils.IntervalTree.IntervalTree
 
min_compaction_threshold - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
MIN_SSTABLE_SIZE_KEY - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
minCompactionThreshold(int) - Method in class org.apache.cassandra.config.CFMetaData
 
mINCR() - Method in class org.apache.cassandra.cli.CliLexer
 
mINDEX() - Method in class org.apache.cassandra.cli.CliLexer
 
MINIMUM - Static variable in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
MINIMUM - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
MINIMUM - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 
minKeyBound(IPartitioner) - Method in class org.apache.cassandra.dht.Token
 
minKeyBound() - Method in class org.apache.cassandra.dht.Token
 
minor - Variable in class org.apache.cassandra.utils.SemanticVersion
 
minOrdering - Static variable in class org.apache.cassandra.utils.IntervalTree.Interval
 
minSSTableSize - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
mINTEGER() - Method in class org.apache.cassandra.cql.CqlLexer
 
mINTEGER() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mIntegerNegativeLiteral() - Method in class org.apache.cassandra.cli.CliLexer
 
mIntegerPositiveLiteral() - Method in class org.apache.cassandra.cli.CliLexer
 
minValue(Class<R>) - Method in class org.apache.cassandra.dht.AbstractPartitioner
 
minValue(Class<T>) - Method in interface org.apache.cassandra.dht.IPartitioner
 
mIP_ADDRESS() - Method in class org.apache.cassandra.cli.CliLexer
 
mJ() - Method in class org.apache.cassandra.cql.CqlLexer
 
mJ() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_ADD() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_ADD() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_ALL() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_ALTER() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_ALTER() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_AND() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_AND() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_APPLY() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_APPLY() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_ASC() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_ASCII() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_BATCH() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_BATCH() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_BEGIN() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_BEGIN() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_BIGINT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_BLOB() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_BOOLEAN() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_BY() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_CLUSTERING() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_COLUMNFAMILY() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_COLUMNFAMILY() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_COMPACT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_CONSISTENCY() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_CONSISTENCY() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_COUNT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_COUNT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_COUNTER() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_CREATE() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_CREATE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_DECIMAL() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_DELETE() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_DELETE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_DESC() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_DESCRIBE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_DOUBLE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_DROP() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_DROP() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_FIRST() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_FLOAT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_FOR() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_FROM() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_FROM() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_FULL_ACCESS() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_GRANT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_GRANTS() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_IN() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_IN() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_INDEX() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_INDEX() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_INSERT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_INSERT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_INT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_INTO() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_INTO() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_KEY() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_KEY() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_KEYSPACE() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_KEYSPACE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_LEVEL() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_LEVEL() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_LIMIT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_LIMIT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_LIST() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_NO_ACCESS() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_ON() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_ON() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_OPTION() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_ORDER() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_PRIMARY() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_PRIMARY() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_REVERSED() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_REVOKE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_SELECT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_SELECT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_SET() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_SET() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_STORAGE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_TEXT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_TIMESTAMP() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_TIMESTAMP() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_TIMEUUID() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_TO() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_TOKEN() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_TRUNCATE() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_TRUNCATE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_TTL() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_TTL() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_TYPE() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_TYPE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_UPDATE() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_UPDATE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_USE() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_USE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_USING() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_USING() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_UUID() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_VALUES() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_VALUES() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_VARCHAR() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_VARINT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_WHERE() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_WHERE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_WITH() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_WITH() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_WRITETIME() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mKEYSPACE() - Method in class org.apache.cassandra.cli.CliLexer
 
mKEYSPACES() - Method in class org.apache.cassandra.cli.CliLexer
 
mL() - Method in class org.apache.cassandra.cql.CqlLexer
 
mL() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mLetter() - Method in class org.apache.cassandra.cli.CliLexer
 
mLETTER() - Method in class org.apache.cassandra.cql.CqlLexer
 
mLETTER() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mLIMIT() - Method in class org.apache.cassandra.cli.CliLexer
 
mLIST() - Method in class org.apache.cassandra.cli.CliLexer
 
mM() - Method in class org.apache.cassandra.cql.CqlLexer
 
mM() - Method in class org.apache.cassandra.cql3.CqlLexer
 
MmappedSegmentedFile - Class in org.apache.cassandra.io.util
 
MmappedSegmentedFile(String, long, SegmentedFile.Segment[]) - Constructor for class org.apache.cassandra.io.util.MmappedSegmentedFile
 
mMULTILINE_COMMENT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mMULTILINE_COMMENT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mN() - Method in class org.apache.cassandra.cql.CqlLexer
 
mN() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mNonEscapeCharacter() - Method in class org.apache.cassandra.cli.CliLexer
 
mO() - Method in class org.apache.cassandra.cql.CqlLexer
 
mO() - Method in class org.apache.cassandra.cql3.CqlLexer
 
modifications_ - Variable in class org.apache.cassandra.db.RowMutation
 
ModificationStatement - Class in org.apache.cassandra.cql3.statements
Abstract class for statements that apply on a given column family.
ModificationStatement(CFName, Attributes) - Constructor for class org.apache.cassandra.cql3.statements.ModificationStatement
 
ModificationStatement(CFName, ConsistencyLevel, Long, int) - Constructor for class org.apache.cassandra.cql3.statements.ModificationStatement
 
mON() - Method in class org.apache.cassandra.cli.CliLexer
 
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
 
mostRecentNonGCableChangeAt(int) - Method in class org.apache.cassandra.db.Column
 
mostRecentNonGCableChangeAt(int) - Method in interface org.apache.cassandra.db.IColumn
 
mostRecentNonGCableChangeAt(int) - Method in class org.apache.cassandra.db.SuperColumn
 
move(String) - Method in class org.apache.cassandra.service.StorageService
 
move(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
move(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
moveToNext() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
moving(Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
mP() - Method in class org.apache.cassandra.cql.CqlLexer
 
mP() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mQ() - Method in class org.apache.cassandra.cql.CqlLexer
 
mQ() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mQMARK() - Method in class org.apache.cassandra.cql.CqlLexer
 
mQMARK() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mQUIT() - Method in class org.apache.cassandra.cli.CliLexer
 
mQUOTED_NAME() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mR() - Method in class org.apache.cassandra.cql.CqlLexer
 
mR() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mRANGEOP() - Method in class org.apache.cassandra.cql.CqlLexer
 
mS() - Method in class org.apache.cassandra.cql.CqlLexer
 
mS() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mSCHEMA() - Method in class org.apache.cassandra.cli.CliLexer
 
mSEMICOLON() - Method in class org.apache.cassandra.cli.CliLexer
 
mSET() - Method in class org.apache.cassandra.cli.CliLexer
 
mSHOW() - Method in class org.apache.cassandra.cli.CliLexer
 
mSingleEscapeCharacter() - Method in class org.apache.cassandra.cli.CliLexer
 
mSingleStringCharacter() - Method in class org.apache.cassandra.cli.CliLexer
 
msProxy - Variable in class org.apache.cassandra.tools.NodeProbe
 
mSTRING_LITERAL() - Method in class org.apache.cassandra.cql.CqlLexer
 
mSTRING_LITERAL() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mStringLiteral() - Method in class org.apache.cassandra.cli.CliLexer
 
mT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__100() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__101() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__102() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__103() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__104() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__105() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__105() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__106() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__106() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__107() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__107() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__108() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__109() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__110() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__111() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__112() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__112() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__113() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__113() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__114() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__114() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__115() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__115() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__116() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__116() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__117() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__117() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__118() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__118() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__119() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__119() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__120() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__120() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__121() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__121() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__122() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__122() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__123() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__123() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__124() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__124() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__125() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__125() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__126() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__81() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__82() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__83() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__84() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__85() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__86() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__87() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__88() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__89() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__90() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__91() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__92() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__93() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__94() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__95() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__96() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__97() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__98() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__99() - Method in class org.apache.cassandra.cql.CqlLexer
 
mTokens() - Method in class org.apache.cassandra.cli.CliLexer
 
mTokens() - Method in class org.apache.cassandra.cql.CqlLexer
 
mTokens() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mTRUNCATE() - Method in class org.apache.cassandra.cli.CliLexer
 
mTTL() - Method in class org.apache.cassandra.cli.CliLexer
 
mU() - Method in class org.apache.cassandra.cql.CqlLexer
 
mU() - Method in class org.apache.cassandra.cql3.CqlLexer
 
multiget_count(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
multiget_slice(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql.CqlParser
 
MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
multithreaded_compaction - Variable in class org.apache.cassandra.config.Config
 
mUnicodeEscapeSequence() - Method in class org.apache.cassandra.cli.CliLexer
 
mUPDATE() - Method in class org.apache.cassandra.cli.CliLexer
 
MurmurHash - Class in org.apache.cassandra.utils
This is a very fast, non-cryptographic hash suitable for general hash-based lookup.
MurmurHash() - Constructor for class org.apache.cassandra.utils.MurmurHash
 
mUSE() - Method in class org.apache.cassandra.cli.CliLexer
 
mutate(List<? extends IMutation>, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
Use this method to have these Mutations applied across all replicas.
mutateCounter(CounterMutation, String) - Static method in class org.apache.cassandra.service.StorageProxy
Handle counter mutation on the coordinator host.
mutationForKey(ByteBuffer, String, Long, ClientState, List<ByteBuffer>, CFMetaData) - Method in class org.apache.cassandra.cql.DeleteStatement
 
mutationForKey(CFDefinition, ClientState, ByteBuffer, ColumnNameBuilder, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
 
mUUID() - Method in class org.apache.cassandra.cql.CqlLexer
 
mUUID() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mV() - Method in class org.apache.cassandra.cql.CqlLexer
 
mV() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mW() - Method in class org.apache.cassandra.cql.CqlLexer
 
mW() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mWITH() - Method in class org.apache.cassandra.cli.CliLexer
 
mWS() - Method in class org.apache.cassandra.cli.CliLexer
 
mWS() - Method in class org.apache.cassandra.cql.CqlLexer
 
mWS() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mX() - Method in class org.apache.cassandra.cql.CqlLexer
 
mX() - Method in class org.apache.cassandra.cql3.CqlLexer
 
Mx4jTool - Class in org.apache.cassandra.utils
If mx4j-tools is in the classpath call maybeLoad to load the HTTP interface of mx4j.
Mx4jTool() - Constructor for class org.apache.cassandra.utils.Mx4jTool
 
mY() - Method in class org.apache.cassandra.cql.CqlLexer
 
mY() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mZ() - Method in class org.apache.cassandra.cql.CqlLexer
 
mZ() - Method in class org.apache.cassandra.cql3.CqlLexer
 

N

n - Variable in class org.apache.cassandra.concurrent.NamedThreadFactory
 
N - Static variable in class org.apache.cassandra.cql.CqlLexer
 
N - Static variable in class org.apache.cassandra.cql.CqlParser
 
N - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
N - Static variable in class org.apache.cassandra.cql3.CqlParser
 
name - Variable in class org.apache.cassandra.cli.CliCommandHelp
 
name - Variable in class org.apache.cassandra.config.ColumnDefinition
 
name - Variable in class org.apache.cassandra.config.KSMetaData
 
name - Variable in class org.apache.cassandra.cql3.CFDefinition.Name
 
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 - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
name - Variable in class org.apache.cassandra.db.migration.avro.ColumnDef
 
name - Variable in class org.apache.cassandra.db.migration.avro.KsDef
 
name() - Method in class org.apache.cassandra.db.SuperColumn
 
name - Variable in class org.apache.cassandra.db.Table
 
name() - Method in class org.apache.cassandra.io.sstable.Component
 
NAME_LENGTH - Static variable in class org.apache.cassandra.config.Schema
longest permissible KS or CF name.
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
 
native_type() - Method in class org.apache.cassandra.cql3.CqlParser
 
needsQuotes() - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcType
 
needsQuotes() - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcUUID
 
needsQuotes() - Method in class org.apache.cassandra.cql.jdbc.JdbcAscii
 
needsQuotes() - Method in class org.apache.cassandra.cql.jdbc.JdbcBoolean
 
needsQuotes() - Method in class org.apache.cassandra.cql.jdbc.JdbcBytes
 
needsQuotes() - Method in class org.apache.cassandra.cql.jdbc.JdbcDate
 
needsQuotes() - Method in class org.apache.cassandra.cql.jdbc.JdbcDecimal
 
needsQuotes() - Method in class org.apache.cassandra.cql.jdbc.JdbcDouble
 
needsQuotes() - Method in class org.apache.cassandra.cql.jdbc.JdbcFloat
 
needsQuotes() - Method in class org.apache.cassandra.cql.jdbc.JdbcInt32
 
needsQuotes() - Method in class org.apache.cassandra.cql.jdbc.JdbcInteger
 
needsQuotes() - Method in class org.apache.cassandra.cql.jdbc.JdbcLong
 
needsQuotes() - Method in class org.apache.cassandra.cql.jdbc.JdbcUTF8
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
NetworkTopologyStrategy - Class in org.apache.cassandra.locator
This Replication Strategy takes a property file that gives the intended replication factor in each datacenter.
NetworkTopologyStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.NetworkTopologyStrategy
 
new_version - Variable in class org.apache.cassandra.db.migration.avro.Migration
 
newCacheProvider(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newColumnFamily() - Method in class org.apache.cassandra.cli.CliParser
 
newIndexMetadata(CFMetaData, ColumnDefinition, AbstractType<?>) - Static method in class org.apache.cassandra.config.CFMetaData
 
newKeyspace(String, String, Map<String, String>, boolean) - Static method in class org.apache.cassandra.config.KSMetaData
 
newKeyspace(String, Class<? extends AbstractReplicationStrategy>, Map<String, String>, boolean, Iterable<CFMetaData>) - Static method in class org.apache.cassandra.config.KSMetaData
 
newKs - Variable in class org.apache.cassandra.db.migration.avro.UpdateKeyspace
 
newMessageDigest(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newPartitioner(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newRow(ByteBuffer) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
Start a new row whose key is key.
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).
newSocket() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
newSSTableSegmentThresholdReached(SSTableWriter) - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
newSSTableSegmentThresholdReached(SSTableWriter) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
 
newSuperColumn(ByteBuffer) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
Start a new super column with name name.
newThread(Runnable) - Method in class org.apache.cassandra.concurrent.NamedThreadFactory
 
next() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
next(ByteBuffer, SortedMap<ByteBuffer, IColumn>) - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
next() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
next() - Method in class org.apache.cassandra.io.sstable.SSTableBoundedScanner
 
next() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
next() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
 
next() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
next() - Method in class org.apache.cassandra.utils.DestructivePQIterator
 
nextCFId() - Method in class org.apache.cassandra.config.Schema
 
nextKeyValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
nextSetBit(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the index of the first set bit starting at the index specified.
nextSetBit(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the index of the first set bit starting at the index specified.
nextToken() - Method in class org.apache.cassandra.cql.CqlLexer
 
nextToken() - Method in class org.apache.cassandra.cql3.CqlLexer
 
NO_GC - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
 
NODE_ADD_COLUMN_FAMILY - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_ADD_COLUMN_FAMILY - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_ADD_KEYSPACE - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_ADD_KEYSPACE - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_ASSUME - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_ASSUME - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_COLUMN_ACCESS - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_COLUMN_ACCESS - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_COLUMNS - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_COLUMNS - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_CONNECT - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_CONNECT - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_CONSISTENCY_LEVEL - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_CONSISTENCY_LEVEL - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_DEL_COLUMN_FAMILY - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_DEL_COLUMN_FAMILY - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_DEL_KEYSPACE - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_DEL_KEYSPACE - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_DESCRIBE - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_DESCRIBE - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_DESCRIBE_CLUSTER - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_DESCRIBE_CLUSTER - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_DROP_INDEX - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_DROP_INDEX - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_EXIT - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_EXIT - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_HELP - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_HELP - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_ID_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
NODE_ID_LIST - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_ID_LIST - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_KEY_RANGE - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_KEY_RANGE - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_LIMIT - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_LIMIT - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_LIST - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_LIST - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_NEW_CF_ACCESS - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_NEW_CF_ACCESS - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_NEW_KEYSPACE_ACCESS - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_NEW_KEYSPACE_ACCESS - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_NO_OP - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_NO_OP - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_REVERSED - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_REVERSED - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_SHOW_CLUSTER_NAME - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_SHOW_CLUSTER_NAME - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_SHOW_KEYSPACES - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_SHOW_KEYSPACES - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_SHOW_SCHEMA - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_SHOW_SCHEMA - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_SHOW_VERSION - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_SHOW_VERSION - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_THRIFT_COUNT - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_THRIFT_COUNT - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_THRIFT_DECR - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_THRIFT_DECR - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_THRIFT_DEL - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_THRIFT_DEL - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_THRIFT_GET - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_THRIFT_GET - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_THRIFT_GET_WITH_CONDITIONS - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_THRIFT_GET_WITH_CONDITIONS - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_THRIFT_INCR - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_THRIFT_INCR - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_THRIFT_SET - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_THRIFT_SET - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_TRUNCATE - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_TRUNCATE - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_UPDATE_COLUMN_FAMILY - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_UPDATE_COLUMN_FAMILY - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_UPDATE_KEYSPACE - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_UPDATE_KEYSPACE - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_USE_TABLE - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_USE_TABLE - Static variable in class org.apache.cassandra.cli.CliParser
 
NodeCmd - Class in org.apache.cassandra.tools
 
NodeCmd(NodeProbe) - Constructor for class org.apache.cassandra.tools.NodeCmd
 
nodeid - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
NodeId - Class in org.apache.cassandra.utils
 
NodeId.NodeIdRecord - Class in org.apache.cassandra.utils
 
NodeId.NodeIdRecord(NodeId, long) - Constructor for class org.apache.cassandra.utils.NodeId.NodeIdRecord
 
NodeId.OneShotRenewer - Class in org.apache.cassandra.utils
 
NodeId.OneShotRenewer() - Constructor for class org.apache.cassandra.utils.NodeId.OneShotRenewer
 
NodeIdCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
NodeProbe - Class in org.apache.cassandra.tools
JMX client operations for Cassandra.
NodeProbe(String, int, String, String) - Constructor for class org.apache.cassandra.tools.NodeProbe
Creates a NodeProbe using the specified JMX host, port, username, and password.
NodeProbe(String, int) - Constructor for class org.apache.cassandra.tools.NodeProbe
Creates a NodeProbe using the specified JMX host and port.
NodeProbe(String) - Constructor for class org.apache.cassandra.tools.NodeProbe
Creates a NodeProbe using the specified JMX host and default port.
NONE - Static variable in enum org.apache.cassandra.auth.Permission
 
NONE - Static variable in class org.apache.cassandra.db.commitlog.ReplayPosition
 
NonEscapeCharacter - Static variable in class org.apache.cassandra.cli.CliLexer
 
NonEscapeCharacter - Static variable in class org.apache.cassandra.cli.CliParser
 
normal(Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
normalize(Collection<Range<T>>) - Static method in class org.apache.cassandra.dht.Range
 
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
 
notifyAdded(SSTableReader) - Method in class org.apache.cassandra.db.DataTracker
 
notifySSTablesChanged(Iterable<SSTableReader>, Iterable<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.DataTracker
 
numColumnSpecifiers(Tree) - Static method in class org.apache.cassandra.cli.CliCompiler
 

O

O - Static variable in class org.apache.cassandra.cql.CqlLexer
 
O - Static variable in class org.apache.cassandra.cql.CqlParser
 
O - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
O - Static variable in class org.apache.cassandra.cql3.CqlParser
 
obsoleteKeywords - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
obsoleteKeywords - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
obsoleteKeywords - Static variable in class org.apache.cassandra.cql3.KSPropDefs
 
offset - Variable in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
 
offset - Variable in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
OLD_MIGRATIONS_CF - Static variable in class org.apache.cassandra.db.DefsTable
 
OLD_SCHEMA_CF - Static variable in class org.apache.cassandra.db.DefsTable
 
old_version - Variable in class org.apache.cassandra.db.migration.avro.Migration
 
oldestUnflushedMemtable() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Returns the creation time of the oldest memtable not fully flushed yet.
oldKs - Variable in class org.apache.cassandra.db.migration.avro.UpdateKeyspace
 
OldNetworkTopologyStrategy - Class in org.apache.cassandra.locator
This Replication Strategy returns the nodes responsible for a given key but respects rack awareness.
OldNetworkTopologyStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.OldNetworkTopologyStrategy
 
oldToNew - Static variable in enum org.apache.cassandra.auth.Permission
Maps old permissions to the new ones as we want to support old client IAuthority implementations and new style of granular permission checking at the same time.
ON - Static variable in class org.apache.cassandra.cli.CliLexer
 
ON - Static variable in class org.apache.cassandra.cli.CliParser
 
onAlive(InetAddress, EndpointState) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.locator.Ec2MultiRegionSnitch
 
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.MigrationManager
 
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.streaming.AbstractStreamSession
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.locator.Ec2MultiRegionSnitch
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.MigrationManager
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.StorageService
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.streaming.AbstractStreamSession
 
onDead(InetAddress, EndpointState) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.locator.Ec2MultiRegionSnitch
 
onDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.MigrationManager
 
onDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.streaming.AbstractStreamSession
 
onDiskLength() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
onDiskLength - Variable in class org.apache.cassandra.io.util.SegmentedFile
 
one() - Method in class org.apache.cassandra.cql3.UntypedResultSet
 
onFailure() - Method in interface org.apache.cassandra.streaming.IStreamCallback
called when streaming somehow got in trouble.
onFinalAccept(Runnable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
onFinalAccept(Runnable) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
onFinalRejection(Runnable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
onFinalRejection(Runnable) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
onInitialRejection(Runnable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
onInitialRejection(Runnable) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
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.locator.Ec2MultiRegionSnitch
 
onJoin(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onJoin(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.MigrationManager
 
onJoin(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onJoin(InetAddress, EndpointState) - Method in class org.apache.cassandra.streaming.AbstractStreamSession
 
onKeyChange() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
Called at the begining of each new key, before any reduce is called.
onlyBackups(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
onRemove(InetAddress) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onRemove(InetAddress) - Method in class org.apache.cassandra.locator.Ec2MultiRegionSnitch
 
onRemove(InetAddress) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onRemove(InetAddress) - Method in class org.apache.cassandra.service.MigrationManager
 
onRemove(InetAddress) - Method in class org.apache.cassandra.service.StorageService
 
onRemove(InetAddress) - Method in class org.apache.cassandra.streaming.AbstractStreamSession
 
onRestart(InetAddress, EndpointState) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
Called whenever a node is restarted.
onRestart(InetAddress, EndpointState) - Method in class org.apache.cassandra.locator.Ec2MultiRegionSnitch
 
onRestart(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onRestart(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.MigrationManager
 
onRestart(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onRestart(InetAddress, EndpointState) - Method in class org.apache.cassandra.streaming.AbstractStreamSession
 
onSuccess() - Method in interface org.apache.cassandra.streaming.IStreamCallback
called when stream session is finished successfully.
onToken - Variable in class org.apache.cassandra.cql3.Relation
 
open(String) - Static method in class org.apache.cassandra.db.Table
 
open(String, CompressionMetadata) - Static method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
 
open(String, CompressionMetadata, boolean) - Static method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
 
open(String, String, boolean, CompressionParameters, SSTableMetadata.Collector) - Static method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
open(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
open(Descriptor, CFMetaData) - 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>, CFMetaData, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
open(File, boolean) - Static method in class org.apache.cassandra.io.util.RandomAccessReader
 
open(File) - Static method in class org.apache.cassandra.io.util.RandomAccessReader
 
open(File, int) - Static method in class org.apache.cassandra.io.util.RandomAccessReader
 
open(File, int, boolean) - Static method in class org.apache.cassandra.io.util.RandomAccessReader
 
open(SequentialWriter) - Static method in class org.apache.cassandra.io.util.RandomAccessReader
 
open(File) - Static method in class org.apache.cassandra.io.util.SequentialWriter
 
open(File, boolean) - Static method in class org.apache.cassandra.io.util.SequentialWriter
 
open(File, int, boolean) - Static method in class org.apache.cassandra.io.util.SequentialWriter
 
open() - Method in class org.apache.cassandra.thrift.TCustomSocket
Connects the socket, creating a new socket object if necessary.
open(String, int) - Static method in class org.apache.cassandra.utils.CLibrary
 
OpenBitSet - Class in org.apache.cassandra.utils.obs
An "open" BitSet implementation that allows direct access to the arrays 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(BitSet) - Constructor for class org.apache.cassandra.utils.obs.OpenBitSet
Contructs an OpenBitset from a BitSet
openDataReader(boolean) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
openNoValidation(Descriptor, Set<Component>, CFMetaData) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
openSSTables() - Method in class org.apache.cassandra.io.sstable.SSTableLoader
 
openTransport(TSocket) - Method in interface org.apache.cassandra.thrift.ITransportFactory
 
openTransport(TSocket) - Method in class org.apache.cassandra.thrift.TFramedTransportFactory
 
openWithoutSSTables(String) - Static method in class org.apache.cassandra.db.Table
 
Operation - Class in org.apache.cassandra.cql
 
Operation(Term) - Constructor for class org.apache.cassandra.cql.Operation
 
Operation(Term, Operation.OperationType, Term) - Constructor for class org.apache.cassandra.cql.Operation
 
Operation - Class in org.apache.cassandra.cql3
 
Operation(Term) - Constructor for class org.apache.cassandra.cql3.Operation
 
Operation(ColumnIdentifier, Operation.Type, Term) - Constructor for class org.apache.cassandra.cql3.Operation
 
Operation.OperationType - Enum in org.apache.cassandra.cql
 
Operation.Type - Enum in org.apache.cassandra.cql3
 
OperationType - Enum in org.apache.cassandra.db.compaction
 
OperationType - Enum in org.apache.cassandra.streaming
Streaming operation type.
operator() - Method in class org.apache.cassandra.cli.CliParser
 
operator() - Method in class org.apache.cassandra.cql.Relation
 
operator() - Method in class org.apache.cassandra.cql3.Relation
 
optionalTasks - Static variable in class org.apache.cassandra.service.StorageService
tasks that do not need to be waited for on shutdown/drain
options - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
optsWithRF(Integer) - Static method in class org.apache.cassandra.config.KSMetaData
 
orderByClause(Map<ColumnIdentifier, Boolean>) - Method in class org.apache.cassandra.cql3.CqlParser
 
OrderPreservingPartitioner - Class in org.apache.cassandra.dht
 
OrderPreservingPartitioner() - Constructor for class org.apache.cassandra.dht.OrderPreservingPartitioner
 
org.apache.cassandra - package org.apache.cassandra
 
org.apache.cassandra.auth - package org.apache.cassandra.auth
 
org.apache.cassandra.cache - package org.apache.cassandra.cache
 
org.apache.cassandra.cli - package org.apache.cassandra.cli
 
org.apache.cassandra.client - package org.apache.cassandra.client
 
org.apache.cassandra.concurrent - package org.apache.cassandra.concurrent
 
org.apache.cassandra.config - package org.apache.cassandra.config
 
org.apache.cassandra.cql - package org.apache.cassandra.cql
 
org.apache.cassandra.cql.jdbc - package org.apache.cassandra.cql.jdbc
 
org.apache.cassandra.cql3 - package org.apache.cassandra.cql3
 
org.apache.cassandra.cql3.statements - package org.apache.cassandra.cql3.statements
 
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.compaction - package org.apache.cassandra.db.compaction
 
org.apache.cassandra.db.context - package org.apache.cassandra.db.context
 
org.apache.cassandra.db.filter - package org.apache.cassandra.db.filter
 
org.apache.cassandra.db.index - package org.apache.cassandra.db.index
 
org.apache.cassandra.db.index.keys - package org.apache.cassandra.db.index.keys
 
org.apache.cassandra.db.marshal - package org.apache.cassandra.db.marshal
 
org.apache.cassandra.db.migration.avro - package org.apache.cassandra.db.migration.avro
 
org.apache.cassandra.dht - package org.apache.cassandra.dht
 
org.apache.cassandra.gms - package org.apache.cassandra.gms
 
org.apache.cassandra.hadoop - package org.apache.cassandra.hadoop
 
org.apache.cassandra.hadoop.pig - package org.apache.cassandra.hadoop.pig
 
org.apache.cassandra.io - package org.apache.cassandra.io
 
org.apache.cassandra.io.compress - package org.apache.cassandra.io.compress
 
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.metrics - package org.apache.cassandra.metrics
 
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.notifications - package org.apache.cassandra.notifications
 
org.apache.cassandra.scheduler - package org.apache.cassandra.scheduler
 
org.apache.cassandra.security - package org.apache.cassandra.security
 
org.apache.cassandra.service - package org.apache.cassandra.service
 
org.apache.cassandra.streaming - package org.apache.cassandra.streaming
 
org.apache.cassandra.thrift - package org.apache.cassandra.thrift
 
org.apache.cassandra.tools - package org.apache.cassandra.tools
 
org.apache.cassandra.utils - package org.apache.cassandra.utils
 
org.apache.cassandra.utils.avro - package org.apache.cassandra.utils.avro
 
org.apache.cassandra.utils.IntervalTree - package org.apache.cassandra.utils.IntervalTree
 
org.apache.cassandra.utils.obs - package org.apache.cassandra.utils.obs
 
originalCount - Variable in class org.apache.cassandra.db.RetriedSliceFromReadCommand
 
originalFilter - Variable in class org.apache.cassandra.db.filter.ExtendedFilter
 
otherOptions - Variable in class org.apache.cassandra.io.compress.CompressionParameters
 
oType - Variable in class org.apache.cassandra.cql.AlterTableStatement
 
oType - Variable in class org.apache.cassandra.cql3.statements.AlterTableStatement
 
out - Variable in class org.apache.cassandra.cli.CliSessionState
 
out - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
OutboundTcpConnection - Class in org.apache.cassandra.net
 
OutboundTcpConnection(OutboundTcpConnectionPool) - Constructor for class org.apache.cassandra.net.OutboundTcpConnection
 
OutboundTcpConnectionPool - Class in org.apache.cassandra.net
 
output(String) - Method in class org.apache.cassandra.utils.OutputHandler.LogOutput
 
output(String) - Method in interface org.apache.cassandra.utils.OutputHandler
 
output(String) - Method in class org.apache.cassandra.utils.OutputHandler.SystemOutput
 
OutputHandler - Interface in org.apache.cassandra.utils
 
OutputHandler.LogOutput - Class in org.apache.cassandra.utils
 
OutputHandler.LogOutput() - Constructor for class org.apache.cassandra.utils.OutputHandler.LogOutput
 
OutputHandler.SystemOutput - Class in org.apache.cassandra.utils
 
OutputHandler.SystemOutput(boolean, boolean) - Constructor for class org.apache.cassandra.utils.OutputHandler.SystemOutput
 

P

P - Static variable in class org.apache.cassandra.cql.CqlLexer
 
P - Static variable in class org.apache.cassandra.cql.CqlParser
 
P - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
P - Static variable in class org.apache.cassandra.cql3.CqlParser
 
PAIR - Static variable in class org.apache.cassandra.cli.CliLexer
 
PAIR - Static variable in class org.apache.cassandra.cli.CliParser
 
Pair<T1,T2> - Class in org.apache.cassandra.utils
 
Pair(T1, T2) - Constructor for class org.apache.cassandra.utils.Pair
 
ParallelCompactionIterable - Class in org.apache.cassandra.db.compaction
A class to run compaction taking advantage of multiple-core processes: One Deserializer thread per input sstable performs read + deserialize (a row at a time).
ParallelCompactionIterable(OperationType, List<ICompactionScanner>, CompactionController) - Constructor for class org.apache.cassandra.db.compaction.ParallelCompactionIterable
 
ParallelCompactionIterable(OperationType, List<ICompactionScanner>, CompactionController, int) - Constructor for class org.apache.cassandra.db.compaction.ParallelCompactionIterable
 
parameters - Variable in class org.apache.cassandra.config.SeedProviderDef
 
parameters - Variable in class org.apache.cassandra.cql3.statements.SelectStatement
 
parameters - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
 
parse(String) - Static method in class org.apache.cassandra.db.marshal.TypeParser
Parse a string containing an type definition.
parse(CharSequence) - Static method in class org.apache.cassandra.db.marshal.TypeParser
 
parseDefaultParameters(AbstractType<?>, TypeParser) - Static method in class org.apache.cassandra.db.marshal.AbstractType
 
ParsedStatement - Class in org.apache.cassandra.cql3.statements
 
ParsedStatement() - Constructor for class org.apache.cassandra.cql3.statements.ParsedStatement
 
ParsedStatement.Prepared - Class in org.apache.cassandra.cql3.statements
 
ParsedStatement.Prepared(CQLStatement, List<CFDefinition.Name>) - Constructor for class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
 
ParsedStatement.Prepared(CQLStatement) - Constructor for class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
 
parseNextComparator(int, String) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
parseNextComparator(int, String) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
parseNextComparator(int, String) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
parseType(String) - Static method in class org.apache.cassandra.cql3.CFPropDefs
 
partialCompactionsAcceptable() - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
partialCompactionsAcceptable() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
 
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 - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
 
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(UUID) - Static method in class org.apache.cassandra.service.MigrationManager
Announce my version passively over gossip.
password() - Method in class org.apache.cassandra.cli.CliParser
 
password - Variable in class org.apache.cassandra.cli.CliSessionState
 
PASSWORD_KEY - Static variable in interface org.apache.cassandra.auth.IAuthenticator
 
patch - Variable in class org.apache.cassandra.utils.SemanticVersion
 
path - Variable in class org.apache.cassandra.db.filter.QueryFilter
 
path - Variable in class org.apache.cassandra.io.util.SegmentedFile
 
peer - Variable in class org.apache.cassandra.io.util.Memory
 
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(SSTableReader, Descriptor, String, List<Pair<Long, Long>>, OperationType) - Constructor for class org.apache.cassandra.streaming.PendingFile
 
PendingFile(SSTableReader, Descriptor, String, List<Pair<Long, Long>>, OperationType, 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
 
PerColumnSecondaryIndex - Class in org.apache.cassandra.db.index
Base class for Secondary indexes that implement a unique index per column
PerColumnSecondaryIndex() - Constructor for class org.apache.cassandra.db.index.PerColumnSecondaryIndex
 
performCleanup(ColumnFamilyStore, NodeId.OneShotRenewer) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
performMaximal(ColumnFamilyStore) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
performScrub(ColumnFamilyStore) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
performSSTableRewrite(ColumnFamilyStore) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
performWrite(IMutation, ConsistencyLevel, String, StorageProxy.WritePerformer, Runnable) - Static method in class org.apache.cassandra.service.StorageProxy
Perform the write of a mutation given a WritePerformer.
Permission - Enum in org.apache.cassandra.auth
An enum encapsulating the set of possible permissions that an authenticated user can have for a resource.
permission() - Method in class org.apache.cassandra.cql3.CqlParser
 
PermissionDenied - Exception in org.apache.cassandra.auth
 
PermissionDenied(String) - Constructor for exception org.apache.cassandra.auth.PermissionDenied
 
PerRowSecondaryIndex - Class in org.apache.cassandra.db.index
Base class for Secondary indexes that implement a unique index per row
PerRowSecondaryIndex() - Constructor for class org.apache.cassandra.db.index.PerRowSecondaryIndex
 
phi_convict_threshold - Variable in class org.apache.cassandra.config.Config
 
PIG_ALLOW_DELETES - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
PIG_INITIAL_ADDRESS - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
PIG_INPUT_FORMAT - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
PIG_INPUT_INITIAL_ADDRESS - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
PIG_INPUT_PARTITIONER - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
PIG_INPUT_RPC_PORT - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
PIG_OUTPUT_FORMAT - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
PIG_OUTPUT_INITIAL_ADDRESS - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
PIG_OUTPUT_PARTITIONER - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
PIG_OUTPUT_RPC_PORT - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
PIG_PARTITIONER - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
PIG_RPC_PORT - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
PIG_USE_SECONDARY - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
PIG_WIDEROW_INPUT - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
pointInTimeExceeded(RowMutation) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
populate_io_cache_on_flush - Variable in class org.apache.cassandra.config.Config
 
populateIOCacheOnFlush() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
port() - Method in class org.apache.cassandra.cli.CliParser
 
pos - Variable in class org.apache.cassandra.io.util.FastByteArrayInputStream
The current position within the byte array.
position - Variable in class org.apache.cassandra.cql3.CFDefinition.Name
 
position() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
position - Variable in class org.apache.cassandra.db.commitlog.ReplayPosition
 
position() - Method in class org.apache.cassandra.io.util.MemoryOutputStream
 
posix_fadvise(int, long, 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.db.compaction
PrecompactedRow merges its rows in its constructor in memory.
PrecompactedRow(DecoratedKey<?>, ColumnFamily) - Constructor for class org.apache.cassandra.db.compaction.PrecompactedRow
it is caller's responsibility to call removeDeleted + removeOldShards from the cf before calling this constructor
PrecompactedRow(CompactionController, List<SSTableIdentityIterator>) - Constructor for class org.apache.cassandra.db.compaction.PrecompactedRow
 
predicate - Variable in class org.apache.cassandra.db.IndexScanCommand
 
predicate - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
prepare(String, ClientState) - Static method in class org.apache.cassandra.cql.QueryProcessor
 
prepare(String, ClientState) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
prepare(CFDefinition.Name[]) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement.RawStatement
Transform this raw statement into a CreateColumnFamilyStatement.
prepare(CFDefinition.Name[]) - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.GrantStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.ListGrantsStatement
 
prepare(CFDefinition.Name[]) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.ParsedStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.RevokeStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
 
prepare(CFDefinition.Name[]) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.UseStatement
 
prepare(ColumnFamilyStore) - Method in class org.apache.cassandra.service.AntiEntropyService.Validator
 
prepare_cql_query(ByteBuffer, Compression) - Method in class org.apache.cassandra.thrift.CassandraServer
 
prepareKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
prepareKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.CFStatement
 
prepareKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
 
prepareRowMutations(String, ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.AbstractModification
Convert statement into a list of mutations to apply on the server
prepareRowMutations(String, ClientState, Long, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.AbstractModification
Convert statement into a list of mutations to apply on the server
prepareRowMutations(String, ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.DeleteStatement
 
prepareRowMutations(String, ClientState, Long, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.DeleteStatement
 
prepareRowMutations(String, ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.UpdateStatement
Convert statement into a list of mutations to apply on the server
prepareRowMutations(String, ClientState, Long, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.UpdateStatement
Convert statement into a list of mutations to apply on the server
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
prepareToWrite(RecordWriter) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
preprocess(Message) - Method in class org.apache.cassandra.service.AbstractRowResolver
 
preprocess(Message) - Method in interface org.apache.cassandra.service.IResponseResolver
 
preprocess(Message) - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
preservesOrder() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
preservesOrder() - Method in interface org.apache.cassandra.dht.IPartitioner
 
preservesOrder() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
preservesOrder() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
preservesOrder() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
PRIMARY_INDEX - Static variable in class org.apache.cassandra.io.sstable.Component
 
printBanner() - Method in class org.apache.cassandra.cli.CliClient
 
printColumnFamilyStats(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
printCompactionStats(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
printInfo(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
Write node information.
printNetworkStats(InetAddress, PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
printPendingRanges() - Method in class org.apache.cassandra.locator.TokenMetadata
 
printReleaseVersion(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
printRemovalStatus(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
printRing(PrintStream, String) - Method in class org.apache.cassandra.tools.NodeCmd
Write a textual representation of the Cassandra ring.
printStack - Variable in class org.apache.cassandra.utils.OutputHandler.SystemOutput
 
printThreadPoolStats(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
process(String, ClientState) - Static method in class org.apache.cassandra.cql.QueryProcessor
 
process(String, ClientState) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
process(List<Row>) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
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
 
processInternal(String, ClientState) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
processPrepared(CQLStatement, ClientState, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql.QueryProcessor
 
processPrepared(CQLStatement, ClientState, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
processServerMessage(Message, String) - Static method in class org.apache.cassandra.net.sink.SinkManager
 
processStatement(String) - Static method in class org.apache.cassandra.cli.CliMain
 
processStatement(CQLStatement, ClientState, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql.QueryProcessor
 
processStatementInteractive(String) - Static method in class org.apache.cassandra.cli.CliMain
 
progress() - Method in class org.apache.cassandra.hadoop.Progressable
 
progress - Variable in class org.apache.cassandra.streaming.PendingFile
 
Progressable - Class in org.apache.cassandra.hadoop
 
promote(Iterable<SSTableReader>, Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
properties - Variable in class org.apache.cassandra.cql.CFPropDefs
 
properties(PropertyDefinitions) - Method in class org.apache.cassandra.cql3.CqlParser
 
properties - Variable in class org.apache.cassandra.cql3.PropertyDefinitions
 
property(PropertyDefinitions) - Method in class org.apache.cassandra.cql3.CqlParser
 
PropertyDefinitions - Class in org.apache.cassandra.cql3
 
PropertyDefinitions() - Constructor for class org.apache.cassandra.cql3.PropertyDefinitions
 
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
 
propertyKey() - Method in class org.apache.cassandra.cql3.CqlParser
 
propertyValue() - Method in class org.apache.cassandra.cql3.CqlParser
 
protocol - Variable in class org.apache.cassandra.config.EncryptionOptions
 
PROTOCOL - Static variable in interface org.apache.cassandra.InterNode
 
prune(ColumnFamily) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
 
PureJavaCrc32 - Class in org.apache.cassandra.utils
A pure-java implementation of the CRC32 checksum that uses the same polynomial as the built-in native CRC32.
PureJavaCrc32() - Constructor for class org.apache.cassandra.utils.PureJavaCrc32
Create a new PureJavaCrc32 object.
purge(CFMetaData) - Method in class org.apache.cassandra.config.Schema
Used for ColumnFamily data eviction out from the schema
put(K, V) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
put(K, V) - Method in interface org.apache.cassandra.cache.ICache
 
put(K, V) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
put(K, V) - Method in class org.apache.cassandra.cache.SerializingCache
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.AddColumnFamily
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.AddKeyspace
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.CfDef
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.ColumnDef
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.DropColumnFamily
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.DropKeyspace
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.KsDef
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.Migration
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.UpdateColumnFamily
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.UpdateKeyspace
 
put(ByteBuffer, IColumn) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
put(SocketAddress, ClientState) - Method in class org.apache.cassandra.service.SocketSessionManagementService
 
put(K, V) - Method in class org.apache.cassandra.utils.ExpiringMap
 
put(K, V, long) - Method in class org.apache.cassandra.utils.ExpiringMap
 
putAll(Map<? extends ByteBuffer, ? extends IColumn>) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
putIfAbsent(K, V) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
putIfAbsent(K, V) - Method in interface org.apache.cassandra.cache.ICache
 
putIfAbsent(K, V) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
putIfAbsent(K, V) - Method in class org.apache.cassandra.cache.SerializingCache
 
putNext(Tuple) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
putShortLength(ByteBuffer, int) - Static method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 

Q

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

R

R - Static variable in class org.apache.cassandra.cql.CqlLexer
 
R - Static variable in class org.apache.cassandra.cql.CqlParser
 
R - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
R - Static variable in class org.apache.cassandra.cql3.CqlParser
 
rack(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
RACK_PROPERTY_FILENAME - Static variable in class org.apache.cassandra.locator.PropertyFileSnitch
 
RACKDC_PROPERTY_FILENAME - Static variable in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
 
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
 
RandomAccessReader - Class in org.apache.cassandra.io.util
 
RandomAccessReader(File, int, boolean) - Constructor for class org.apache.cassandra.io.util.RandomAccessReader
 
RandomAccessReader.BufferedRandomAccessFileMark - Class in org.apache.cassandra.io.util
Class to hold a mark to the position of the file
RandomAccessReader.BufferedRandomAccessFileMark(long) - Constructor for class org.apache.cassandra.io.util.RandomAccessReader.BufferedRandomAccessFileMark
 
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<T extends RingPosition> - Class in org.apache.cassandra.dht
A representation of the range that a node is responsible for on the DHT ring.
Range(T, T) - Constructor for class org.apache.cassandra.dht.Range
 
Range(T, T, IPartitioner) - Constructor for class org.apache.cassandra.dht.Range
 
range - Variable in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
RANGEOP - Static variable in class org.apache.cassandra.cql.CqlLexer
 
RANGEOP - Static variable in class org.apache.cassandra.cql.CqlParser
 
rangeSet(Range<T>...) - Static method in class org.apache.cassandra.dht.Range
 
rangeSet(Range<T>) - Static method in class org.apache.cassandra.dht.Range
 
RangeSliceCommand - Class in org.apache.cassandra.db
 
RangeSliceCommand(String, String, ByteBuffer, SlicePredicate, AbstractBounds<RowPosition>, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
 
RangeSliceCommand(String, String, ByteBuffer, SlicePredicate, AbstractBounds<RowPosition>, int, boolean, boolean) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
 
RangeSliceCommand(String, ColumnParent, SlicePredicate, AbstractBounds<RowPosition>, List<IndexExpression>, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
 
RangeSliceCommand(String, ColumnParent, SlicePredicate, AbstractBounds<RowPosition>, List<IndexExpression>, int, boolean, boolean) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
 
RangeSliceCommand(String, String, ByteBuffer, SlicePredicate, AbstractBounds<RowPosition>, List<IndexExpression>, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
 
RangeSliceCommand(String, String, ByteBuffer, SlicePredicate, AbstractBounds<RowPosition>, List<IndexExpression>, int, boolean, boolean) - 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) - Constructor for class org.apache.cassandra.service.RangeSliceResponseResolver
 
RangeSliceVerbHandler - Class in org.apache.cassandra.service
 
RangeSliceVerbHandler() - Constructor for class org.apache.cassandra.service.RangeSliceVerbHandler
 
RangeStreamer - Class in org.apache.cassandra.dht
Assists in streaming ranges to a node.
RangeStreamer(TokenMetadata, InetAddress, OperationType) - Constructor for class org.apache.cassandra.dht.RangeStreamer
 
RangeStreamer.FailureDetectorSourceFilter - Class in org.apache.cassandra.dht
Source filter which excludes any endpoints that are not alive according to a failure detector.
RangeStreamer.FailureDetectorSourceFilter(IFailureDetector) - Constructor for class org.apache.cassandra.dht.RangeStreamer.FailureDetectorSourceFilter
 
RangeStreamer.ISourceFilter - Interface in org.apache.cassandra.dht
A filter applied to sources to stream from when constructing a fetch map.
RangeStreamer.SingleDatacenterFilter - Class in org.apache.cassandra.dht
Source filter which excludes any endpoints that are not in a specific data center.
RangeStreamer.SingleDatacenterFilter(IEndpointSnitch, String) - Constructor for class org.apache.cassandra.dht.RangeStreamer.SingleDatacenterFilter
 
read(Message) - Static method in class org.apache.cassandra.db.IndexScanCommand
 
read(Message) - Static method in class org.apache.cassandra.db.RangeSliceCommand
 
read(byte[], int) - Static method in class org.apache.cassandra.db.RangeSliceReply
 
read(Message) - Static method in class org.apache.cassandra.db.SnapshotCommand
 
read(DataInput) - Static method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
read() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
Reads a single byte from the source byte array and returns it as an integer in the range from 0 to 255.
read(byte[], int, int) - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
Reads at most len bytes from this stream and stores them in byte array b starting at offset.
read() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
read() - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
read() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
read(byte[]) - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
read(byte[], int, int) - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
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(DataInput, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
read(DataInput) - Static method in class org.apache.cassandra.utils.UUIDGen
reads a uuid from an input stream.
read_repair_chance - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
readBoolean() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a boolean from the current position in this file.
readBoolean() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readByte() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads an 8-bit byte from the current position in this file.
readByte() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
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)
readBytes(int) - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
ReadCallback<T> - Class in org.apache.cassandra.service
 
ReadCallback(IResponseResolver<T>, ConsistencyLevel, IReadCommand, List<InetAddress>) - Constructor for class org.apache.cassandra.service.ReadCallback
Constructor when response count has to be calculated and blocked for.
readChar() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a 16-bit character from the current position in this file.
readChar() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
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.
readDouble() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
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.
readFloat() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
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
 
readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
readFully(byte[], int, int) - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readFully(byte[]) - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readInt() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a 32-bit integer from the current position in this file.
readInt() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readLine() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a line of text form the current position in this file.
readLine() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readLong() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a 64-bit long from the current position in this file.
readLong() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readRepairChance(double) - Method in class org.apache.cassandra.config.CFMetaData
 
ReadRepairVerbHandler - Class in org.apache.cassandra.db
 
ReadRepairVerbHandler() - Constructor for class org.apache.cassandra.db.ReadRepairVerbHandler
 
ReadResponse - Class in org.apache.cassandra.db
 
ReadResponse(ByteBuffer) - Constructor for class org.apache.cassandra.db.ReadResponse
 
ReadResponse(Row) - Constructor for class org.apache.cassandra.db.ReadResponse
 
readRowSize(DataInput, Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
readSaved(String, String, IPartitioner) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
readSchema(String, String) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
readSchemaRow(String) - Static method in class org.apache.cassandra.db.SystemTable
 
readSchemaRow(String, String) - Static method in class org.apache.cassandra.db.SystemTable
 
readShort() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a 16-bit short from the current position in this file.
readShort() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
readTimeouts - Static variable in class org.apache.cassandra.metrics.ClientRequestMetrics
 
readUnavailables - Static variable in class org.apache.cassandra.metrics.ClientRequestMetrics
 
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.
readUnsignedByte() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
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.
readUnsignedShort() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readUTF() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a string that is encoded in modified UTF-8 from this file.
readUTF() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
ReadVerbHandler - Class in org.apache.cassandra.db
 
ReadVerbHandler() - Constructor for class org.apache.cassandra.db.ReadVerbHandler
 
readWithLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
readWithShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
reBuffer() - Method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
 
reBuffer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
Read data from file starting from current currentOffset to populate buffer.
reBuffer() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
rebuild(String) - Method in class org.apache.cassandra.service.StorageService
 
rebuild(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Initiate a process of streaming data for which we are responsible from other nodes.
rebuild(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
rebuildIndex(String, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
rebuildSecondaryIndex(String, String, String...) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
rebuildSecondaryIndex(String, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
rebuildSecondaryIndex(String, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
rebuild the specified indexes
receive(Message, String) - Method in class org.apache.cassandra.net.MessagingService
 
received - Variable in class org.apache.cassandra.service.AsyncRepairCallback
 
received - Variable in class org.apache.cassandra.service.ReadCallback
 
received - Variable in class org.apache.cassandra.service.RepairCallback
 
receiveTiming(InetAddress, Double) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
receiveTiming(InetAddress, Double) - Method in interface org.apache.cassandra.locator.ILatencySubscriber
 
RECOMMENDED_DEPTH - Static variable in class org.apache.cassandra.utils.MerkleTree
 
reconcile(IColumn) - Method in class org.apache.cassandra.db.Column
 
reconcile(IColumn, Allocator) - Method in class org.apache.cassandra.db.Column
 
reconcile(IColumn, Allocator) - Method in class org.apache.cassandra.db.CounterColumn
 
reconcile(IColumn, Allocator) - Method in class org.apache.cassandra.db.CounterUpdateColumn
 
reconcile(IColumn, Allocator) - Method in class org.apache.cassandra.db.DeletedColumn
 
reconcile(IColumn) - Method in interface org.apache.cassandra.db.IColumn
 
reconcile(IColumn, Allocator) - Method in interface org.apache.cassandra.db.IColumn
 
reconcile(IColumn) - Method in class org.apache.cassandra.db.SuperColumn
 
reconcile(IColumn, Allocator) - Method in class org.apache.cassandra.db.SuperColumn
 
recover() - Method in class org.apache.cassandra.db.commitlog.CommitLog
Perform recovery on commit logs located in the directory specified by the config file.
recover(File...) - Method in class org.apache.cassandra.db.commitlog.CommitLog
Perform recovery on a list of commit log files.
recover(String) - Method in class org.apache.cassandra.db.commitlog.CommitLog
Perform recovery on a single commit log.
recover(String) - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
Recover a single file.
recover(File[]) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
recover(File) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
recycle() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
Recycle processes an unneeded segment file for reuse.
recycleSegment(CommitLogSegment) - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
Indicates that a segment is no longer in use and that it should be recycled.
recycleSegment(File) - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
Differs from the above because it can work on any file instead of just existing commit log segments managed by this allocator.
reduce(IColumnIterator) - Method in class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
 
reduce(In) - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
combine this object with the previous ones.
reduce_cache_capacity_to - Variable in class org.apache.cassandra.config.Config
 
reduce_cache_sizes_at - Variable in class org.apache.cassandra.config.Config
 
reduceCacheSize() - Method in class org.apache.cassandra.cache.AutoSavingCache
 
reduceCacheSizes() - Method in class org.apache.cassandra.service.CacheService
 
reduceCacheSizes() - Method in interface org.apache.cassandra.service.CacheServiceMBean
sets each cache's maximum capacity to "reduce_cache_capacity_to" of its current size
reduceKeyCacheSize() - Method in class org.apache.cassandra.service.CacheService
 
reducer - Variable in class org.apache.cassandra.utils.MergeIterator
 
reduceRowCacheSize() - Method in class org.apache.cassandra.service.CacheService
 
ReducingKeyIterator - Class in org.apache.cassandra.io.sstable
Caller must acquire and release references to the sstables used here.
ReducingKeyIterator(Collection<SSTableReader>) - Constructor for class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
reference() - Method in class org.apache.cassandra.cache.FreeableMemory
 
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.
registerVerbHandlers(StorageService.Verb, IVerbHandler) - Method in class org.apache.cassandra.net.MessagingService
Register a verb and the corresponding verb handler with the Messaging Service.
relation() - Method in class org.apache.cassandra.cql.CqlParser
 
Relation - Class in org.apache.cassandra.cql
Relations encapsulate the relationship between an entity of some kind, and a value (term).
Relation(Term, String, Term) - Constructor for class org.apache.cassandra.cql.Relation
Creates a new relation.
relation() - Method in class org.apache.cassandra.cql3.CqlParser
 
Relation - Class in org.apache.cassandra.cql3
Relations encapsulate the relationship between an entity of some kind, and a value (term).
Relation(ColumnIdentifier, String, Term) - Constructor for class org.apache.cassandra.cql3.Relation
Creates a new relation.
Relation(ColumnIdentifier, String, Term, boolean) - Constructor for class org.apache.cassandra.cql3.Relation
 
Relation.Type - Enum in org.apache.cassandra.cql3
 
relativeToAbsolutePath(String, Path) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
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
 
releaseReference() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
releaseReferences(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
releaseVersion() - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
reload() - Method in class org.apache.cassandra.config.CFMetaData
 
reload() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
reload() - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
reload() - Method in class org.apache.cassandra.db.index.SecondaryIndex
Reload an existing index following a change to its configuration, or that of the indexed column(s).
reload() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
Drops and adds new indexes associated with the underlying CF
reloadAttributes() - Method in class org.apache.cassandra.config.KSMetaData
 
reloadConfiguration() - Method in class org.apache.cassandra.locator.PropertyFileSnitch
 
reloadSecondaryIndexMetadata(CFMetaData) - Method in class org.apache.cassandra.config.CFMetaData
 
relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
remainingBodyLength() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
remainingHeaderLength() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
remoteFile - Variable in class org.apache.cassandra.streaming.IncomingStreamReader
 
remoteSocket - Static variable in class org.apache.cassandra.service.SocketSessionManagementService
 
REMOVAL_COORDINATOR - Static variable in class org.apache.cassandra.gms.VersionedValue
 
removalCoordinator(Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
remove(K) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
remove(K) - Method in interface org.apache.cassandra.cache.ICache
 
remove(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
remove(K) - Method in class org.apache.cassandra.cache.SerializingCache
 
remove(ByteBuffer) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
remove() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
remove() - Method in class org.apache.cassandra.db.filter.AbstractColumnIterator
 
remove(ByteBuffer) - Method in interface org.apache.cassandra.db.IColumnContainer
 
remove(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
 
remove(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
remove endpoint from failure detector
remove() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
remove() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
remove() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
 
remove() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
remove(Object) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
remove(SocketAddress) - Method in class org.apache.cassandra.service.SocketSessionManagementService
 
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_counter(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
removeBootstrapToken(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
 
removeColumn(ByteBuffer) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
removeColumn(ByteBuffer) - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
removeColumn(ByteBuffer) - Method in interface org.apache.cassandra.db.ISortedColumns
Remove if present a column by name.
removeColumn(ByteBuffer) - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
removeColumn(ByteBuffer) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
removeColumnDefinition(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
 
removed - Variable in class org.apache.cassandra.notifications.SSTableListChangedNotification
 
REMOVED_TOKEN - Static variable in class org.apache.cassandra.gms.VersionedValue
 
removeDeleted(ColumnFamily, int) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
removeDeletedAndOldShards(DecoratedKey<?>, CompactionController, ColumnFamily) - Static method in class org.apache.cassandra.db.compaction.PrecompactedRow
 
removeDeletedAndOldShards(DecoratedKey, boolean, CompactionController, ColumnFamily) - Static method in class org.apache.cassandra.db.compaction.PrecompactedRow
 
removeDeletedCF(ColumnFamily, int) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
removeDeletedColumnsOnly(ColumnFamily, int) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
removeDeletedInCache(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.CompactionController
 
removedNonlocal(Token, long) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
removeEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
Removes the endpoint from Gossip but retains endpoint state
removeEndpoint(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
removeFromMoving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
Remove pair of token/address from moving endpoints
removeIndex(ByteBuffer) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
removeIndex(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
Delete all files and references to this index
removeIndexedColumn(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
Removes a existing index
removeOldShards(ByteBuffer, int) - Method in class org.apache.cassandra.db.context.CounterContext
Remove shards that have been canceled through computeOldShardMerger since a time older than gcBefore.
removeRegisteredCallback(String) - Method in class org.apache.cassandra.net.MessagingService
 
removeTableInstance(String) - Method in class org.apache.cassandra.config.Schema
Remove table from schema
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) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
rename(CFMetaData, String) - Static method in class org.apache.cassandra.config.CFMetaData
 
rename(Descriptor, Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.SSTableWriter
 
renameWithConfirm(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
renameWithConfirm(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
renewLocalId() - Static method in class org.apache.cassandra.utils.NodeId
Renew the local node id.
renewLocalId(long) - Static method in class org.apache.cassandra.utils.NodeId
 
renewMemtable() - Method in class org.apache.cassandra.db.DataTracker
Renew the current memtable without putting the old one for a flush.
RepairCallback - Class in org.apache.cassandra.service
 
RepairCallback(RowRepairResolver, List<InetAddress>) - Constructor for class org.apache.cassandra.service.RepairCallback
The main difference between this and ReadCallback is, ReadCallback has a ConsistencyLevel it needs to achieve.
repairOverlappingSSTables(int) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
repairResults - Variable in class org.apache.cassandra.service.RangeSliceResponseResolver
 
repairResults - Variable in class org.apache.cassandra.service.RowRepairResolver
 
replace(K, V, V) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
replace(K, V, V) - Method in interface org.apache.cassandra.cache.ICache
 
replace(K, V, V) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
replace(K, V, V) - Method in class org.apache.cassandra.cache.SerializingCache
 
replace(IColumn, IColumn) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
replace(IColumn, IColumn) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
replace(IColumn, IColumn) - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
replace(Iterable<SSTableReader>, Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
replace(IColumn, IColumn) - Method in interface org.apache.cassandra.db.IColumnContainer
Replace oldColumn if represent by newColumn.
replace(IColumn, IColumn) - Method in interface org.apache.cassandra.db.ISortedColumns
Replace oldColumn if present by newColumn.
replace(IColumn, IColumn) - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
replace(IColumn, IColumn) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
replaceCompactedSSTables(Collection<SSTableReader>, Iterable<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
replaceCompactedSSTables(Collection<SSTableReader>, Iterable<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.DataTracker
 
replacedEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
Remove the Endpoint and evict immediately, to avoid gossiping about this node.
replaceFlushed(Memtable, SSTableReader) - Method in class org.apache.cassandra.db.DataTracker
 
ReplayPosition - Class in org.apache.cassandra.db.commitlog
 
ReplayPosition(long, int) - Constructor for class org.apache.cassandra.db.commitlog.ReplayPosition
 
replayPosition - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
replayPosition(ReplayPosition) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
replayPosition - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
 
ReplayPosition.ReplayPositionSerializer - Class in org.apache.cassandra.db.commitlog
 
ReplayPosition.ReplayPositionSerializer() - Constructor for class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
 
replica_placement_strategy() - Method in class org.apache.cassandra.cli.CliParser
 
replicate_on_write - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
replicateOnWrite(boolean) - Method in class org.apache.cassandra.config.CFMetaData
 
replication_factor - Variable in class org.apache.cassandra.db.migration.avro.KsDef
 
ReplicationFinishedVerbHandler - Class in org.apache.cassandra.streaming
 
ReplicationFinishedVerbHandler() - Constructor for class org.apache.cassandra.streaming.ReplicationFinishedVerbHandler
 
replies - Variable in class org.apache.cassandra.service.AbstractRowResolver
 
report(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
 
report(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
This method is invoked by the receiver of the heartbeat.
reportError(RecognitionException) - Method in class org.apache.cassandra.cli.CliLexer
 
reportError(RecognitionException) - Method in class org.apache.cassandra.cli.CliParser
 
representJavaBeanProperty(Object, Property, Object, Tag) - Method in class org.apache.cassandra.utils.SkipNullRepresenter
 
request - Variable in class org.apache.cassandra.service.AntiEntropyService.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
 
requestGC() - Method in class org.apache.cassandra.service.StorageService
 
requestInvoke(TNonblockingServer.FrameBuffer, CustomTHsHaServer.SelectorThread) - Method in class org.apache.cassandra.thrift.CustomTHsHaServer
 
requestInvoke(TNonblockingServer.FrameBuffer) - Method in class org.apache.cassandra.thrift.CustomTNonBlockingServer
 
requestRanges(InetAddress, String, Collection<Range<Token>>, IStreamCallback, OperationType) - Static method in class org.apache.cassandra.streaming.StreamIn
Request ranges for all column families in the given keyspace.
requestRanges(InetAddress, String, Collection<ColumnFamilyStore>, Collection<Range<Token>>, IStreamCallback, OperationType) - Static method in class org.apache.cassandra.streaming.StreamIn
Request ranges to be transferred from specific CFs
RequestSchedulerOptions - Class in org.apache.cassandra.config
 
RequestSchedulerOptions() - Constructor for class org.apache.cassandra.config.RequestSchedulerOptions
 
requestSelectInterestChange(TNonblockingServer.FrameBuffer) - Method in class org.apache.cassandra.thrift.CustomTHsHaServer
 
requestSelectInterestChange(TNonblockingServer.FrameBuffer) - Method in class org.apache.cassandra.thrift.CustomTHsHaServer.SelectorThread
 
RequestType - Enum in org.apache.cassandra.thrift
 
requiresKeyspace - Static variable in enum org.apache.cassandra.cql.StatementType
 
rescheduleFailedDeletions() - Method in class org.apache.cassandra.service.StorageService
 
rescheduleFailedDeletions() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
rescheduleFailedTasks() - Static method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
Retry all deletions that failed the first time around (presumably b/c the sstable was still mmap'd.) Useful because there are times when we know GC has been invoked; also exposed as an mbean.
reset() - Method in interface org.apache.cassandra.db.columniterator.ICountableColumnIterator
 
reset() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
reset() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
reset() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
Resets this stream to the last marked location.
reset() - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
Resets this stream to the beginning of the underlying byte array.
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.io.util.RandomAccessReader
 
reset(FileMark) - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
reset(InetAddress) - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
reconnect to @param remoteEP (after the current message backlog is exhausted).
reset() - Method in class org.apache.cassandra.service.ClientState
 
reset(long) - Method in class org.apache.cassandra.utils.BytesReadTracker
reset counter to @param count
reset() - Method in class org.apache.cassandra.utils.DefaultInteger
 
reset() - Method in class org.apache.cassandra.utils.ExpiringMap
 
reset() - Method in class org.apache.cassandra.utils.PureJavaCrc32
reset() - Method in class org.apache.cassandra.utils.SimpleCondition
 
resetAndTruncate(FileMark) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
resetAndTruncate(int) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
Reset the writer so that the next chunk offset written will be the one of chunkIndex.
resetAndTruncate() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
resetAndTruncate(FileMark) - Method in class org.apache.cassandra.io.util.SequentialWriter
 
resetBuffer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
resetBuffer() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
resetLocalSchema() - Static method in class org.apache.cassandra.service.MigrationManager
Clear all locally stored schema information and reset schema to initial state.
resetLocalSchema() - Method in class org.apache.cassandra.service.StorageService
 
resetLocalSchema() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
resetLocalSchema() - Method in class org.apache.cassandra.tools.NodeProbe
 
resetUnsafe() - Method in class org.apache.cassandra.db.commitlog.CommitLog
FOR TESTING PURPOSES.
resetUnsafe() - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
Resets all the segments, for testing purposes.
resetVersion(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
resolve(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamily
 
resolve(ColumnFamily, Allocator) - Method in class org.apache.cassandra.db.ColumnFamily
 
resolve() - Method in interface org.apache.cassandra.service.IResponseResolver
This Method resolves the responses that are passed in .
resolve() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
resolve() - Method in class org.apache.cassandra.service.RowDigestResolver
 
resolve() - Method in class org.apache.cassandra.service.RowRepairResolver
 
resolver - Variable in class org.apache.cassandra.service.ReadCallback
 
resolver - Variable in class org.apache.cassandra.service.RepairCallback
 
Resources - Class in org.apache.cassandra.auth
Constants related to Cassandra's resource hierarchy.
Resources() - Constructor for class org.apache.cassandra.auth.Resources
 
resourceToFile(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
ResourceWatcher - Class in org.apache.cassandra.utils
 
ResourceWatcher() - Constructor for class org.apache.cassandra.utils.ResourceWatcher
 
ResourceWatcher.WatchedResource - Class in org.apache.cassandra.utils
 
ResourceWatcher.WatchedResource(String, Runnable) - Constructor for class org.apache.cassandra.utils.ResourceWatcher.WatchedResource
 
response(Message) - Method in interface org.apache.cassandra.net.IAsyncCallback
 
response(Message) - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
null message means "response from local write"
response(Message) - Method in class org.apache.cassandra.service.AsyncRepairCallback
 
response(Message) - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
response(Message) - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
response(Message) - Method in class org.apache.cassandra.service.ReadCallback
 
response(ReadResponse) - Method in class org.apache.cassandra.service.ReadCallback
 
response(Message) - Method in class org.apache.cassandra.service.RepairCallback
 
response(Message) - Method in class org.apache.cassandra.service.TruncateResponseHandler
 
response(Message) - Method in class org.apache.cassandra.service.WriteResponseHandler
 
responses - Variable in class org.apache.cassandra.service.RangeSliceResponseResolver
 
responses - Variable in class org.apache.cassandra.service.TruncateResponseHandler
 
responses - Variable in class org.apache.cassandra.service.WriteResponseHandler
 
ResponseVerbHandler - Class in org.apache.cassandra.net
 
ResponseVerbHandler() - Constructor for class org.apache.cassandra.net.ResponseVerbHandler
 
restorePointInTime - Variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
result(Message) - Method in interface org.apache.cassandra.net.IAsyncResult
Store the result obtained for the submitted task.
resultify(String, Row) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
retainAll(AbstractColumnContainer) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
retainAll(ISortedColumns) - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
 
retainAll(ISortedColumns) - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
retainAll(ISortedColumns) - Method in interface org.apache.cassandra.db.ISortedColumns
 
RetriedSliceFromReadCommand - Class in org.apache.cassandra.db
 
RetriedSliceFromReadCommand(String, ByteBuffer, ColumnParent, ByteBuffer, ByteBuffer, boolean, int, int) - Constructor for class org.apache.cassandra.db.RetriedSliceFromReadCommand
 
RetriedSliceFromReadCommand(String, ByteBuffer, QueryPath, ByteBuffer, ByteBuffer, boolean, int, int) - Constructor for class org.apache.cassandra.db.RetriedSliceFromReadCommand
 
retry(PendingFile) - Method in class org.apache.cassandra.streaming.StreamInSession
 
retry() - Method in class org.apache.cassandra.streaming.StreamOutSession
 
reverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
reversed - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
reversed - Variable in class org.apache.cassandra.db.SliceFromReadCommand
 
reversedExpr() - Method in class org.apache.cassandra.cli.CliParser
 
ReversedType<T> - Class in org.apache.cassandra.db.marshal
 
reverseIterator() - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
reverseIterator(ByteBuffer) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
reverseIterator() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
reverseIterator(ByteBuffer) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
reverseIterator() - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
reverseIterator(ByteBuffer) - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
reverseIterator() - Method in interface org.apache.cassandra.db.ISortedColumns
Returns an iterator that iterates over the columns of this map in reverse order.
reverseIterator(ByteBuffer) - Method in interface org.apache.cassandra.db.ISortedColumns
Returns a reversed iterator over the columns of this map starting from the last column whose name is equal or lesser than @param start.
reverseIterator() - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
reverseIterator(ByteBuffer) - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
reverseIterator() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
reverseIterator(ByteBuffer) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
revive(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureNotification
 
revoke(AuthenticatedUser, Permission, String, CFName) - Method in interface org.apache.cassandra.auth.IAuthority2
REVOKE ON FROM ;
revoke(AuthenticatedUser, Permission, String, CFName) - Method in class org.apache.cassandra.auth.IAuthorityContainer
 
revokePermission(Permission, String, CFName) - Method in class org.apache.cassandra.service.ClientState
 
revokeStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
RevokeStatement - Class in org.apache.cassandra.cql3.statements
 
RevokeStatement(Permission, String, CFName) - Constructor for class org.apache.cassandra.cql3.statements.RevokeStatement
 
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(Configuration) - 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)
RingPosition<T> - Interface in org.apache.cassandra.dht
Interface representing a position on the ring.
ROOT - Static variable in class org.apache.cassandra.auth.Resources
 
root() - Method in class org.apache.cassandra.cli.CliParser
 
RoundRobinScheduler - Class in org.apache.cassandra.scheduler
A very basic Round Robin implementation of the RequestScheduler.
RoundRobinScheduler(RequestSchedulerOptions) - Constructor for class org.apache.cassandra.scheduler.RoundRobinScheduler
 
row() - Method in class org.apache.cassandra.db.ReadResponse
 
Row - Class in org.apache.cassandra.db
 
Row(DecoratedKey<?>, ColumnFamily) - Constructor for class org.apache.cassandra.db.Row
 
Row.RowSerializer - Class in org.apache.cassandra.db
 
Row.RowSerializer() - Constructor for class org.apache.cassandra.db.Row.RowSerializer
 
row_cache_keys_to_save - Variable in class org.apache.cassandra.config.Config
 
row_cache_provider - Variable in class org.apache.cassandra.config.Config
 
row_cache_save_period - Variable in class org.apache.cassandra.config.Config
 
row_cache_size - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
row_cache_size_in_mb - Variable in class org.apache.cassandra.config.Config
 
row_filter - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
row_mutation - Variable in class org.apache.cassandra.db.migration.avro.Migration
 
rowCache - Variable in class org.apache.cassandra.service.CacheService
 
RowCacheKey - Class in org.apache.cassandra.cache
 
RowCacheKey(int, DecoratedKey) - Constructor for class org.apache.cassandra.cache.RowCacheKey
 
RowCacheKey(int, ByteBuffer) - Constructor for class org.apache.cassandra.cache.RowCacheKey
 
RowCacheSentinel - Class in org.apache.cassandra.cache
A sentinel object for row caches.
RowCacheSentinel() - Constructor for class org.apache.cassandra.cache.RowCacheSentinel
 
RowDigestResolver - Class in org.apache.cassandra.service
 
RowDigestResolver(String, ByteBuffer) - Constructor for class org.apache.cassandra.service.RowDigestResolver
 
RowIteratorFactory - Class in org.apache.cassandra.db
 
RowIteratorFactory() - Constructor for class org.apache.cassandra.db.RowIteratorFactory
 
rowKey() - Method in class org.apache.cassandra.cli.CliParser
 
rowLimitExpr() - Method in class org.apache.cassandra.cli.CliParser
 
rowMutation() - Method in class org.apache.cassandra.db.CounterMutation
 
RowMutation - Class in org.apache.cassandra.db
 
RowMutation(String, ByteBuffer) - Constructor for class org.apache.cassandra.db.RowMutation
 
RowMutation(String, Row) - Constructor for class org.apache.cassandra.db.RowMutation
 
RowMutation(String, ByteBuffer, Map<Integer, ColumnFamily>) - Constructor for class org.apache.cassandra.db.RowMutation
 
RowMutation.RowMutationSerializer - Class in org.apache.cassandra.db
 
RowMutation.RowMutationSerializer() - Constructor for class org.apache.cassandra.db.RowMutation.RowMutationSerializer
 
RowMutationVerbHandler - Class in org.apache.cassandra.db
 
RowMutationVerbHandler() - Constructor for class org.apache.cassandra.db.RowMutationVerbHandler
 
RowPosition - Class in org.apache.cassandra.db
 
RowPosition() - Constructor for class org.apache.cassandra.db.RowPosition
 
RowPosition.Kind - Enum in org.apache.cassandra.db
 
RowPosition.RowPositionSerializer - Class in org.apache.cassandra.db
 
RowPosition.RowPositionSerializer() - Constructor for class org.apache.cassandra.db.RowPosition.RowPositionSerializer
 
RowRepairResolver - Class in org.apache.cassandra.service
 
RowRepairResolver(String, ByteBuffer) - Constructor for class org.apache.cassandra.service.RowRepairResolver
 
rows - Variable in class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
 
rows - Variable in class org.apache.cassandra.db.RangeSliceReply
 
rowValue() - Method in class org.apache.cassandra.cli.CliParser
 
rpc_address - Variable in class org.apache.cassandra.config.Config
 
rpc_keepalive - Variable in class org.apache.cassandra.config.Config
 
rpc_max_threads - Variable in class org.apache.cassandra.config.Config
 
rpc_min_threads - Variable in class org.apache.cassandra.config.Config
 
rpc_port - Variable in class org.apache.cassandra.config.Config
 
rpc_recv_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
 
rpc_send_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
 
rpc_server_type - Variable in class org.apache.cassandra.config.Config
 
rpc_server_types - Static variable in class org.apache.cassandra.thrift.CassandraDaemon
 
rpc_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
rpcaddress(InetAddress) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
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.Validator
Called after the validation lifecycle to respond with the now valid tree.
run() - Method in class org.apache.cassandra.streaming.StreamingRepairTask
 
run() - Method in class org.apache.cassandra.thrift.CustomTHsHaServer.Invocation
 
run() - Method in class org.apache.cassandra.thrift.CustomTHsHaServer.SelectorThread
 
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.io.sstable.SSTableDeletingTask
 
runMayThrow() - Method in class org.apache.cassandra.streaming.FileStreamTask
 
runMayThrow() - Method in class org.apache.cassandra.utils.WrappedRunnable
 

S

S - Static variable in class org.apache.cassandra.cql.CqlLexer
 
S - Static variable in class org.apache.cassandra.cql.CqlParser
 
S - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
S - Static variable in class org.apache.cassandra.cql3.CqlParser
 
sampleKeyRange() - Method in class org.apache.cassandra.service.StorageService
#Return a List of Tokens representing a sample of keys across all ColumnFamilyStores.
sampleKeyRange() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Return a List of Tokens representing a sample of keys across all ColumnFamilyStores.
sampleKeyRange() - Method in class org.apache.cassandra.tools.NodeProbe
 
satisfies(int, IndexOperator) - Static method in class org.apache.cassandra.db.filter.ExtendedFilter
 
saveCache() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
 
saveCaches() - Method in class org.apache.cassandra.service.CacheService
 
saveCaches() - Method in interface org.apache.cassandra.service.CacheServiceMBean
save row and key caches
saved_caches_directory - Variable in class org.apache.cassandra.config.Config
 
saveTask - Variable in class org.apache.cassandra.cache.AutoSavingCache
 
scanners - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
schedule() - Method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
 
scheduledTasks - Static variable in class org.apache.cassandra.service.StorageService
This pool is used for periodic short (sub-second) tasks.
scheduleHintDelivery(InetAddress) - Method in class org.apache.cassandra.db.HintedHandOffManager
 
scheduleHintDelivery(String) - Method in class org.apache.cassandra.db.HintedHandOffManager
 
scheduleHintDelivery(String) - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
force hint delivery to an endpoint
scheduleLocalHint(RowMutation, InetAddress, IWriteResponseHandler, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
 
scheduleRepairs(ColumnFamily, String, DecoratedKey<?>, List<ColumnFamily>, List<InetAddress>) - Static method in class org.apache.cassandra.service.RowRepairResolver
For each row version, compare with resolved (the superset of all row versions); if it is missing anything, send a mutation to the endpoint it come from.
scheduleSaving(int, int) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
 
SCHEMA - Static variable in class org.apache.cassandra.cli.CliLexer
 
SCHEMA - Static variable in class org.apache.cassandra.cli.CliParser
 
Schema - Class in org.apache.cassandra.config
 
Schema() - Constructor for class org.apache.cassandra.config.Schema
Initialize empty schema object
schema(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.AddColumnFamily
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.AddKeyspace
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.CfDef
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.ColumnDef
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.DropColumnFamily
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.DropKeyspace
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.KsDef
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.Migration
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.UpdateColumnFamily
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.UpdateKeyspace
 
SCHEMA_COLUMNFAMILIES_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
SCHEMA_COLUMNS_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
SCHEMA_KEYSPACES_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
schema_mwt - Variable in class org.apache.cassandra.cli.CliSessionState
 
SchemaAlteringStatement - Class in org.apache.cassandra.cql3.statements
Abstract class for statements that alter the schema.
SchemaAlteringStatement() - Constructor for class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
 
SchemaAlteringStatement(CFName) - Constructor for class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
 
SchemaCf - Static variable in class org.apache.cassandra.config.CFMetaData
Deprecated. 
schemaCFS(String) - Static method in class org.apache.cassandra.db.SystemTable
 
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
 
SchemaColumnFamiliesCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
SchemaColumnsCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
SchemaKeyspacesCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
scrub() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
scrub() - Method in class org.apache.cassandra.db.compaction.Scrubber
 
scrub(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
scrub(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Scrub (deserialize + reserialize at the latest version, skipping bad rows if any) the given keyspace.
scrub(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
Scrubber - Class in org.apache.cassandra.db.compaction
 
Scrubber(ColumnFamilyStore, SSTableReader) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
 
Scrubber(ColumnFamilyStore, SSTableReader, OutputHandler, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
 
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.
search(List<IndexExpression>, AbstractBounds<RowPosition>, int, IFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
search(List<IndexExpression>, AbstractBounds<RowPosition>, int, IFilter, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
search(List<IndexExpression>, AbstractBounds<RowPosition>, int, IFilter, boolean) - Method in class org.apache.cassandra.db.index.keys.KeysSearcher
 
search(List<IndexExpression>, AbstractBounds<RowPosition>, int, IFilter, boolean) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
Performs a search across a number of column indexes TODO: add support for querying across index types
search(List<IndexExpression>, AbstractBounds<RowPosition>, int, IFilter, boolean) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
 
search(Interval<T>) - Method in class org.apache.cassandra.utils.IntervalTree.IntervalTree
 
searchComposite(String, boolean) - Static method in class org.apache.cassandra.db.DefsTable
 
searchInternal(IntervalNode, Interval<T>, List<T>) - Method in class org.apache.cassandra.utils.IntervalTree.IntervalTree
 
SECONDARY_INDEX_NAME_SEPARATOR - Static variable in class org.apache.cassandra.db.Directories
 
SecondaryIndex - Class in org.apache.cassandra.db.index
Abstract base class for different types of secondary indexes.
SecondaryIndex() - Constructor for class org.apache.cassandra.db.index.SecondaryIndex
 
SecondaryIndexBuilder - Class in org.apache.cassandra.db.index
Manages building an entire index from column family data.
SecondaryIndexBuilder(ColumnFamilyStore, SortedSet<ByteBuffer>, ReducingKeyIterator) - Constructor for class org.apache.cassandra.db.index.SecondaryIndexBuilder
 
SecondaryIndexManager - Class in org.apache.cassandra.db.index
Manages all the indexes associated with a given CFS Different types of indexes can be created across the same CF
SecondaryIndexManager(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.index.SecondaryIndexManager
 
SecondaryIndexSearcher - Class in org.apache.cassandra.db.index
 
SecondaryIndexSearcher(SecondaryIndexManager, Set<ByteBuffer>) - Constructor for class org.apache.cassandra.db.index.SecondaryIndexSearcher
 
sections - Variable in class org.apache.cassandra.streaming.PendingFile
 
seed_provider - Variable in class org.apache.cassandra.config.Config
 
SeedProvider - Interface in org.apache.cassandra.locator
 
SeedProviderDef - Class in org.apache.cassandra.config
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
SeedProviderDef(LinkedHashMap) - Constructor for class org.apache.cassandra.config.SeedProviderDef
 
seek(long) - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
seekInternal(int) - Method in class org.apache.cassandra.io.util.AbstractDataInput
 
seekInternal(int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
seekInternal(int) - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
seekTo(RowPosition) - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
segment - Variable in class org.apache.cassandra.db.commitlog.ReplayPosition
 
SegmentedFile - Class in org.apache.cassandra.io.util
Abstracts a read-only file that has been split into segments, each of which can be represented by an independent FileDataInput.
SegmentedFile(String, long, long) - Constructor for class org.apache.cassandra.io.util.SegmentedFile
 
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
 
selectClause() - Method in class org.apache.cassandra.cql3.CqlParser
 
selectCountClause() - Method in class org.apache.cassandra.cql3.CqlParser
 
selectExpression() - Method in class org.apache.cassandra.cql.CqlParser
 
SelectExpression - Class in org.apache.cassandra.cql
Select expressions are analogous to the projection in a SQL query.
SelectExpression(Term, Term, int, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.cql.SelectExpression
Create a new SelectExpression for a range (slice) of columns.
SelectExpression(Term, int, boolean, boolean) - Constructor for class org.apache.cassandra.cql.SelectExpression
Create a new SelectExpression for a list of columns.
selector() - Method in class org.apache.cassandra.cql3.CqlParser
 
Selector - Interface in org.apache.cassandra.cql3.statements
 
Selector.Function - Enum in org.apache.cassandra.cql3.statements
 
Selector.WithFunction - Class in org.apache.cassandra.cql3.statements
 
Selector.WithFunction(ColumnIdentifier, Selector.Function) - Constructor for class org.apache.cassandra.cql3.statements.Selector.WithFunction
 
selectStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
SelectStatement - Class in org.apache.cassandra.cql
Encapsulates a completely parsed SELECT query, including the target column family, expression, result count, and ordering clause.
SelectStatement(SelectExpression, boolean, String, String, ConsistencyLevel, WhereClause, int) - Constructor for class org.apache.cassandra.cql.SelectStatement
 
selectStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
SelectStatement - Class in org.apache.cassandra.cql3.statements
Encapsulates a completely parsed SELECT query, including the target column family, expression, result count, and ordering clause.
SelectStatement(CFDefinition, int, SelectStatement.Parameters) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement
 
SelectStatement.Parameters - Class in org.apache.cassandra.cql3.statements
 
SelectStatement.Parameters(ConsistencyLevel, int, Map<ColumnIdentifier, Boolean>, boolean) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
 
SelectStatement.RawStatement - Class in org.apache.cassandra.cql3.statements
 
SelectStatement.RawStatement(CFName, SelectStatement.Parameters, List<Selector>, List<Relation>) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
 
SemanticVersion - Class in org.apache.cassandra.utils
Implements semantic versioning as defined at http://semver.org/.
SemanticVersion(String) - Constructor for class org.apache.cassandra.utils.SemanticVersion
Parse a semantic version from a string.
SEMICOLON - Static variable in class org.apache.cassandra.cli.CliLexer
 
SEMICOLON - Static variable in class org.apache.cassandra.cli.CliParser
 
send(R) - Method in class org.apache.cassandra.service.AntiEntropyService.RequestCoordinator
 
sendMessage(Message) - Method in class org.apache.cassandra.streaming.StreamInSession
 
sendOneWay(Message, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
sendOneWay(Message, String, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
Send a message to a given endpoint.
sendReply(Message, String, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
sendRR(Message, InetAddress, IMessageCallback) - Method in class org.apache.cassandra.net.MessagingService
 
sendRR(Message, InetAddress, IMessageCallback, long) - Method in class org.apache.cassandra.net.MessagingService
Send a message to a given endpoint.
sendRR(MessageProducer, InetAddress, IAsyncCallback) - Method in class org.apache.cassandra.net.MessagingService
Send a message to a given endpoint.
sendRR(Message, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
sendToHintedEndpoints(RowMutation, Collection<InetAddress>, IWriteResponseHandler, String, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
Send the mutations to the right targets, write it locally if it corresponds or writes a hint when the node is not available.
separator - Static variable in class org.apache.cassandra.io.sstable.Component
 
SequentialWriter - Class in org.apache.cassandra.io.util
 
SequentialWriter(File, int, boolean) - Constructor for class org.apache.cassandra.io.util.SequentialWriter
 
SequentialWriter.BufferedFileWriterMark - Class in org.apache.cassandra.io.util
Class to hold a mark to the position of the file
SequentialWriter.BufferedFileWriterMark(long) - Constructor for class org.apache.cassandra.io.util.SequentialWriter.BufferedFileWriterMark
 
serializationFlags() - Method in class org.apache.cassandra.db.Column
 
serializationFlags() - Method in class org.apache.cassandra.db.CounterColumn
 
serializationFlags() - Method in class org.apache.cassandra.db.CounterUpdateColumn
 
serializationFlags() - Method in class org.apache.cassandra.db.DeletedColumn
 
serializationFlags() - Method in class org.apache.cassandra.db.ExpiringColumn
 
serializationFlags() - Method in interface org.apache.cassandra.db.IColumn
 
serializationFlags() - Method in class org.apache.cassandra.db.SuperColumn
 
serialize(ColumnFamily, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serialize(IIterableColumns, DataOutput) - Static method in class org.apache.cassandra.db.ColumnIndexer
Given a column family this, function creates an in-memory structure that represents the column index for the column family, and subsequently writes it to disk.
serialize(ColumnIndexer.RowHeader, DataOutput) - Static method in class org.apache.cassandra.db.ColumnIndexer
 
serialize(IIterableColumns) - Static method in class org.apache.cassandra.db.ColumnIndexer
Serializes the index into in-memory structure with all required components such as Bloom Filter, index block size, IndexInfo list
serialize(IColumn, DataOutput) - Method in class org.apache.cassandra.db.ColumnSerializer
 
serialize(ReplayPosition, DataOutput) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
 
serialize() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
serialize(DataOutput) - Method in class org.apache.cassandra.db.filter.QueryPath
 
serialize(Row, DataOutput, int) - Method in class org.apache.cassandra.db.Row.RowSerializer
 
serialize(RowMutation, DataOutput, int) - Method in class org.apache.cassandra.db.RowMutation.RowMutationSerializer
 
serialize(RowPosition, DataOutput) - Method in class org.apache.cassandra.db.RowPosition.RowPositionSerializer
 
serialize(TruncateResponse, DataOutput, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
 
serialize(WriteResponse, DataOutput, int) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
 
serialize(AbstractBounds<?>, DataOutput, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
 
serialize(Token, DataOutput) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
 
serialize(T, DataOutput) - Method in interface org.apache.cassandra.io.ISerializer
Serialize the specified type into the specified DataOutput instance.
serialize(T, DataOutput, int) - Method in interface org.apache.cassandra.io.IVersionedSerializer
Serialize the specified type into the specified DataOutputStream instance.
serialize(DataOutput) - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
serialize(SSTableMetadata, DataOutput) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.SSTableMetadataSerializer
 
serialize(InetAddress, DataOutput) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
 
serialize(AntiEntropyService.TreeRequest, DataOutput, int) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequestVerbHandler
 
serialize(AntiEntropyService.Validator, DataOutputStream, int) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeResponseVerbHandler
 
serialize(PendingFile, DataOutput, int) - Method in class org.apache.cassandra.streaming.PendingFile.PendingFileSerializer
 
serialize(BloomFilter, DataOutput) - Method in class org.apache.cassandra.utils.BloomFilterSerializer
 
serialize(EstimatedHistogram, DataOutput) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
serialize(TSerializer, TBase, DataOutput) - Static method in class org.apache.cassandra.utils.FBUtilities
 
serialize(T, IVersionedSerializer<T>, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
serialize(LegacyBloomFilter, DataOutput) - Method in class org.apache.cassandra.utils.LegacyBloomFilterSerializer
 
serialize(MerkleTree, DataOutputStream, int) - Method in class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
 
serializeCFInfo(ColumnFamily, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializeComparator(ByteBuffer) - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
 
serializedSchema() - Static method in class org.apache.cassandra.db.SystemTable
 
serializedSchema(String) - Static method in class org.apache.cassandra.db.SystemTable
 
serializedSize() - Method in interface org.apache.cassandra.cache.CacheKey
 
serializedSize() - Method in class org.apache.cassandra.cache.KeyCacheKey
 
serializedSize() - Method in class org.apache.cassandra.cache.RowCacheKey
 
serializedSize() - Method in class org.apache.cassandra.db.Column
 
serializedSize() - Method in class org.apache.cassandra.db.ColumnFamily
 
serializedSize(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializedSize() - Method in class org.apache.cassandra.db.ColumnIndexer.RowHeader
 
serializedSize(IColumn) - Method in class org.apache.cassandra.db.ColumnSerializer
 
serializedSize(ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
 
serializedSize() - Method in class org.apache.cassandra.db.filter.QueryPath
 
serializedSize() - Method in interface org.apache.cassandra.db.IColumn
 
serializedSize(Row, int) - Method in class org.apache.cassandra.db.Row.RowSerializer
 
serializedSize(RowMutation, int) - Method in class org.apache.cassandra.db.RowMutation.RowMutationSerializer
 
serializedSize(RowPosition) - Method in class org.apache.cassandra.db.RowPosition.RowPositionSerializer
 
serializedSize() - Method in class org.apache.cassandra.db.SuperColumn
This returns the size of the super-column when serialized.
serializedSize(TruncateResponse, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
 
serializedSize(WriteResponse, int) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
 
serializedSize(AbstractBounds<?>, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
 
serializedSize(Token) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
 
serializedSize(T) - Method in interface org.apache.cassandra.io.ISerializer
 
serializedSize(T, int) - Method in interface org.apache.cassandra.io.IVersionedSerializer
 
serializedSize() - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
serializedSize(InetAddress) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
 
serializedSize() - Method in class org.apache.cassandra.net.Header
 
serializedSize(PendingFile, int) - Method in class org.apache.cassandra.streaming.PendingFile.PendingFileSerializer
 
serializedSize() - Method in class org.apache.cassandra.utils.BloomFilter
 
serializedSize(BloomFilter) - Method in class org.apache.cassandra.utils.BloomFilterSerializer
Calculates a serialized size of the given Bloom Filter
serializedSize(EstimatedHistogram) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
serializedSize(LegacyBloomFilter) - Method in class org.apache.cassandra.utils.LegacyBloomFilterSerializer
 
serializedSizeForSSTable() - Method in class org.apache.cassandra.db.ColumnFamily
 
serializeForSSTable(ColumnFamily, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializer() - Static method in class org.apache.cassandra.db.Column
 
serializer - Static variable in class org.apache.cassandra.db.ColumnFamily
 
serializer() - Static method in class org.apache.cassandra.db.ColumnFamily
 
serializer - Static variable in class org.apache.cassandra.db.commitlog.ReplayPosition
 
serializer() - Static method in class org.apache.cassandra.db.CounterMutation
 
serializer - Static variable in class org.apache.cassandra.db.IndexScanCommand
 
serializer() - Static method in class org.apache.cassandra.db.ReadCommand
 
serializer() - Static method in class org.apache.cassandra.db.ReadResponse
 
serializer() - Static method in class org.apache.cassandra.db.Row
 
serializer() - Static method in class org.apache.cassandra.db.RowMutation
 
serializer() - Static method in class org.apache.cassandra.db.RowPosition
 
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 variable in class org.apache.cassandra.io.sstable.SSTableMetadata
 
serializer() - Static method in class org.apache.cassandra.net.Header
 
SERIALIZER - Static variable in class org.apache.cassandra.service.AntiEntropyService.TreeRequestVerbHandler
 
SERIALIZER - Static variable in class org.apache.cassandra.service.AntiEntropyService.TreeResponseVerbHandler
 
serializer() - Static method in class org.apache.cassandra.streaming.PendingFile
 
serializer() - Static method in class org.apache.cassandra.streaming.StreamHeader
 
serializer() - Static method in class org.apache.cassandra.utils.BloomFilter
 
serializer - Static variable in class org.apache.cassandra.utils.EstimatedHistogram
 
serializer() - Static method in class org.apache.cassandra.utils.LegacyBloomFilter
 
serializer - Static variable in class org.apache.cassandra.utils.MerkleTree
 
SerializerType - Enum in org.apache.cassandra.net.io
 
serializeSchema() - Static method in class org.apache.cassandra.db.SystemTable
 
serializeSchema(Collection<RowMutation>, int) - Static method in class org.apache.cassandra.service.MigrationManager
Serialize given row mutations into raw bytes
serializeWithIndexes(ColumnFamily, ColumnIndexer.RowHeader, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
SerializingCache<K,V> - Class in org.apache.cassandra.cache
Serializes cache values off-heap.
SerializingCache(long, boolean, ISerializer<V>) - Constructor for class org.apache.cassandra.cache.SerializingCache
 
SerializingCacheProvider - Class in org.apache.cassandra.cache
 
SerializingCacheProvider() - Constructor for class org.apache.cassandra.cache.SerializingCacheProvider
 
serialVersionUID - Static variable in class org.apache.cassandra.dht.Range
 
serialVersionUID - Static variable in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
serve() - Method in class org.apache.cassandra.thrift.CustomTHsHaServer
 
serve() - Method in class org.apache.cassandra.thrift.CustomTThreadPoolServer
 
session - Variable in class org.apache.cassandra.service.AntiEntropyService.RepairFuture
 
session - Variable in class org.apache.cassandra.streaming.IncomingStreamReader
 
sessionid - Variable in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
sessionId - Variable in class org.apache.cassandra.streaming.StreamHeader
session is tuple of (host, sessionid)
sessionState - Static variable in class org.apache.cassandra.cli.CliMain
 
SET - Static variable in class org.apache.cassandra.cli.CliLexer
 
SET - Static variable in class org.apache.cassandra.cli.CliParser
 
set(int, long) - Method in class org.apache.cassandra.utils.BigLongArray
 
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 the bit at the specified index.
set(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Sets the bit at the specified index.
set_cql_version(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
set_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
setBootstrapState(SystemTable.BootstrapState) - Static method in class org.apache.cassandra.db.SystemTable
 
setBoundTerms(int) - Method in class org.apache.cassandra.cql3.statements.ParsedStatement
 
setBroadcastAddress(InetAddress) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setByte(long, byte) - Method in class org.apache.cassandra.io.util.Memory
 
setBytes(long, byte[], int, int) - Method in class org.apache.cassandra.io.util.Memory
Transfers count bytes from buffer to Memory
setCacheCapacities(int, int) - Method in class org.apache.cassandra.tools.NodeProbe
 
setCapacity(long) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
setCapacity(long) - Method in interface org.apache.cassandra.cache.ICache
 
setCapacity(long) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
setCapacity(long) - Method in class org.apache.cassandra.cache.SerializingCache
 
setColumnFamily(String, boolean) - Method in class org.apache.cassandra.cql3.CFName
 
setColumnsLimit(int) - Method in class org.apache.cassandra.cql.SelectExpression
 
setColumnsReversed(boolean) - Method in class org.apache.cassandra.cql.SelectExpression
 
setCompactionStrategyClass(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setCompactionStrategyClass(String) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Sets the compaction strategy by class name
setCompactionThreshold(String, String, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
Set the compaction threshold
setCompactionThresholds(int, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setCompactionThresholds(int, int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Sets the maximum and maximum number of SSTables in queue before compaction kicks off
setCompactionThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
 
setCompactionThroughputMbPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCompactionThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
 
setCompactionThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setCompactionType(OperationType) - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
setCompactStorage() - Method in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement.RawStatement
 
setCompressionParameters(Map<String, String>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setCompressionParameters(Map<String, String>) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Set the compression parameters
setComputeDigest() - Method in class org.apache.cassandra.io.util.SequentialWriter
Turn on digest computation on this writer.
setConsistencyLevel(ConsistencyLevel) - Method in class org.apache.cassandra.cql.Attributes
 
setCorePoolSize(int) - Method in interface org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutorMBean
 
setCQLVersion(String) - Method in class org.apache.cassandra.service.ClientState
 
setCurrentFile(PendingFile) - Method in class org.apache.cassandra.streaming.StreamInSession
 
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
 
setEndpointSnitch(IEndpointSnitch) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setErr(PrintStream) - Method in class org.apache.cassandra.cli.CliSessionState
 
setHintedHandoffEnabled(boolean) - Method in class org.apache.cassandra.service.StorageProxy
 
setHintedHandoffEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
setIncrementalBackupsEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setIncrementalBackupsEnabled(boolean) - Method in class org.apache.cassandra.service.StorageService
 
setIncrementalBackupsEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setIndexBuilt(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
 
setIndexBuilt(Collection<ByteBuffer>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
setIndexBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemTable
 
setIndexName(String) - Method in class org.apache.cassandra.config.ColumnDefinition
 
setIndexRemoved(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
 
setIndexRemoved(Collection<ByteBuffer>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
setIndexRemoved(String, String) - Static method in class org.apache.cassandra.db.SystemTable
 
setIndexType(IndexType, Map<String, String>) - Method in class org.apache.cassandra.config.ColumnDefinition
 
setInMemoryCompactionLimit(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setInputColumnFamily(Configuration, String, String, boolean) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the keyspace and column family for the input of this job.
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.
setInputInitialAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setInputPartitioner(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setInputRange(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the KeyRange to limit the rows.
setInputRange(Configuration, String, String, List<IndexExpression>) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the KeyRange to limit the rows.
setInputRange(Configuration, List<IndexExpression>) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the KeyRange to limit the rows.
setInputRpcPort(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
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.
setInputTransportFactoryClass(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setKeyAlias(String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
 
setKeyAlias(String) - Method in class org.apache.cassandra.cql.WhereClause
 
setKeyAlias(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement.RawStatement
 
setKeyCacheCapacityInMB(long) - Method in class org.apache.cassandra.service.CacheService
 
setKeyCacheCapacityInMB(long) - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
setKeyCacheSavePeriodInSeconds(int) - Method in class org.apache.cassandra.service.CacheService
 
setKeyCacheSavePeriodInSeconds(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
setKeyCountToImport(Integer) - Static method in class org.apache.cassandra.tools.SSTableImport
Used by test framework to set key count
setKeySpace(String) - Method in class org.apache.cassandra.cli.CliClient
 
setKeyspace(String, boolean) - Method in class org.apache.cassandra.cql3.CFName
 
setKeyspace(String) - Method in class org.apache.cassandra.service.ClientState
 
setKeyType(String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
 
setLoadYaml(boolean) - Static method in class org.apache.cassandra.config.Config
 
setLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
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
setMaxHintsInProgress(int) - Method in class org.apache.cassandra.service.StorageProxy
 
setMaxHintsInProgress(int) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
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
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
setMultiKey(boolean) - Method in class org.apache.cassandra.cql.WhereClause
 
setOrdering(ColumnIdentifier, boolean) - Method in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement.RawStatement
 
setOut(PrintStream) - Method in class org.apache.cassandra.cli.CliSessionState
 
setOutboundBindAny(boolean) - Static method in class org.apache.cassandra.config.Config
 
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.
setOutputCompressionChunkLength(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setOutputCompressionClass(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setOutputInitialAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setOutputKeyspacePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setOutputKeyspaceUserName(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setOutputPartitioner(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setOutputRpcPort(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setOutputTransportFactoryClass(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setPartitioner(IPartitioner) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setPartitioner(String) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
 
setPartitioner(IPartitioner) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
 
setPartitionFilter(Expression) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
setPendingRanges(String, Multimap<Range<Token>, InetAddress>) - Method in class org.apache.cassandra.locator.TokenMetadata
 
setPhiConvictThreshold(int) - Method in class org.apache.cassandra.gms.FailureDetector
 
setPhiConvictThreshold(int) - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
setRangeBatchSize(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
The number of rows to request with each get range slices request.
setRowCacheCapacityInMB(long) - Method in class org.apache.cassandra.service.CacheService
 
setRowCacheCapacityInMB(long) - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
setRowCacheSavePeriodInSeconds(int) - Method in class org.apache.cassandra.service.CacheService
 
setRowCacheSavePeriodInSeconds(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
setRpcTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
 
setRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
setSocket(Socket) - Method in class org.apache.cassandra.streaming.StreamInSession
 
setSources(List<InetAddress>) - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
setStatement() - Method in class org.apache.cassandra.cli.CliParser
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
setStoreLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
setStreamThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
 
setStreamThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
 
setStreamThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setStreamThroughputOutboundMegabitsPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setTable(String) - Method in class org.apache.cassandra.streaming.StreamInSession
 
setTableDefinition(KSMetaData) - Method in class org.apache.cassandra.config.Schema
Update (or insert) new table definition
setTimeout(int) - Method in class org.apache.cassandra.thrift.TCustomSocket
Sets the socket timeout
setTimestamp(Long) - Method in class org.apache.cassandra.cql.Attributes
 
setTimeToLive(int) - Method in class org.apache.cassandra.cql.Attributes
 
setToken(Token) - Method in class org.apache.cassandra.service.StorageService
This method updates the local token on disk
setTrackedBy(DataTracker) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
setTracker(DataTracker) - Method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
 
setTreeAdaptor(TreeAdaptor) - Method in class org.apache.cassandra.cli.CliParser
 
setUDFContextSignature(String) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
setup() - Method in interface org.apache.cassandra.auth.IAuthority2
Setup is called each time upon system startup
setup() - Method in class org.apache.cassandra.auth.IAuthorityContainer
 
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.BulkOutputFormat.NullOutputCommitter
 
setupJob(JobContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
setupTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
 
setupTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
setUsername(String) - Method in class org.apache.cassandra.cli.CliClient
 
setValidator(AbstractType<?>) - Method in class org.apache.cassandra.config.ColumnDefinition
 
setVersion(InetAddress, int) - Method in class org.apache.cassandra.gms.Gossiper
 
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
 
shouldInclude(InetAddress) - Method in class org.apache.cassandra.dht.RangeStreamer.FailureDetectorSourceFilter
 
shouldInclude(InetAddress) - Method in interface org.apache.cassandra.dht.RangeStreamer.ISourceFilter
 
shouldInclude(InetAddress) - Method in class org.apache.cassandra.dht.RangeStreamer.SingleDatacenterFilter
 
shouldPurge(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.CompactionController
 
shouldReplicateOnWrite() - Method in class org.apache.cassandra.db.CounterMutation
 
SHOW - Static variable in class org.apache.cassandra.cli.CliLexer
 
SHOW - Static variable in class org.apache.cassandra.cli.CliParser
 
showClusterName() - Method in class org.apache.cassandra.cli.CliParser
 
showKeyspaces() - Method in class org.apache.cassandra.cli.CliParser
 
showSchema() - Method in class org.apache.cassandra.cli.CliParser
 
showStatement() - Method in class org.apache.cassandra.cli.CliParser
 
showVersion() - Method in class org.apache.cassandra.cli.CliParser
 
shutdown() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
shutdown() - Method in class org.apache.cassandra.db.commitlog.CommitLogAllocator
Initiates the shutdown process for the allocator thread.
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.db.compaction.AbstractCompactionStrategy
Releases any resources if this strategy is shutdown (when the CFS is reloaded after a schema change).
shutdown() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
shutdown() - Method in class org.apache.cassandra.net.MessagingService
Wait for callbacks and don't allow any more to be created (since they could require writing hints)
shutdownBlocking() - Method in class org.apache.cassandra.db.commitlog.CommitLog
Shuts down the threads used by the commit log, blocking until completion.
shutdownBlocking() - Method in class org.apache.cassandra.utils.ExpiringMap
 
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.service.AbstractWriteResponseHandler
 
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
 
SimpleCondition - Class in org.apache.cassandra.utils
 
SimpleCondition() - Constructor for class org.apache.cassandra.utils.SimpleCondition
 
SimpleSeedProvider - Class in org.apache.cassandra.locator
 
SimpleSeedProvider(Map<String, String>) - Constructor for class org.apache.cassandra.locator.SimpleSeedProvider
 
SimpleSnitch - Class in org.apache.cassandra.locator
A simple endpoint snitch implementation that treats Strategy order as proximity, allowing non-read-repaired reads to prefer a single endpoint, which improves cache locality.
SimpleSnitch() - Constructor for class org.apache.cassandra.locator.SimpleSnitch
 
SimpleStrategy - Class in org.apache.cassandra.locator
This class returns the nodes responsible for a given key but does not respect rack awareness.
SimpleStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.SimpleStrategy
 
SingleEscapeCharacter - Static variable in class org.apache.cassandra.cli.CliLexer
 
SingleEscapeCharacter - Static variable in class org.apache.cassandra.cli.CliParser
 
SingleStringCharacter - Static variable in class org.apache.cassandra.cli.CliLexer
 
SingleStringCharacter - Static variable in class org.apache.cassandra.cli.CliParser
 
singleton(T) - Static method in class org.apache.cassandra.utils.FBUtilities
 
SinkManager - Class in org.apache.cassandra.net.sink
 
SinkManager() - Constructor for class org.apache.cassandra.net.sink.SinkManager
 
size() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
size() - Method in interface org.apache.cassandra.cache.ICache
 
size() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
size() - Method in class org.apache.cassandra.cache.SerializingCache
 
size() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
size() - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
size() - Method in class org.apache.cassandra.db.Column
 
size() - Method in class org.apache.cassandra.db.CounterColumn
 
size() - Method in class org.apache.cassandra.db.ExpiringColumn
 
size() - Method in interface org.apache.cassandra.db.IColumn
 
size() - Method in interface org.apache.cassandra.db.ISortedColumns
Returns the number of columns in this map.
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.db.ThreadSafeSortedColumns
 
size() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
size() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
size() - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
Returns the total number of bytes written to this stream so far.
size() - Method in class org.apache.cassandra.io.util.Memory
 
size - Variable in class org.apache.cassandra.streaming.PendingFile
 
size() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
size - Variable in class org.apache.cassandra.utils.BigLongArray
 
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.
SizeTieredCompactionStrategy - Class in org.apache.cassandra.db.compaction
 
SizeTieredCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
skip(long) - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
Skips count number of bytes in this InputStream.
skipBloomFilter(DataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
Skip the bloom filter
skipBytes(int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
skipBytes(int) - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
skipBytes(int) - Method in class org.apache.cassandra.utils.BytesReadTracker
 
skipBytesFully(DataInput, int) - Static method in class org.apache.cassandra.io.util.FileUtils
 
skipBytesFully(DataInput, long) - Static method in class org.apache.cassandra.io.util.FileUtils
 
skipCompacted(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
skipIndex(DataInput) - 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
 
skipTemporary(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
SlabAllocator - Class in org.apache.cassandra.utils
The SlabAllocator is a bump-the-pointer allocator that allocates large (2MB by default) regions and then doles them out to threads that request slices into the array.
SlabAllocator() - Constructor for class org.apache.cassandra.utils.SlabAllocator
 
sleep(int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
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
 
SliceFromReadCommand - Class in org.apache.cassandra.db
 
SliceFromReadCommand(String, ByteBuffer, ColumnParent, ByteBuffer, ByteBuffer, boolean, int) - Constructor for class org.apache.cassandra.db.SliceFromReadCommand
 
SliceFromReadCommand(String, ByteBuffer, QueryPath, ByteBuffer, ByteBuffer, boolean, int) - Constructor for class org.apache.cassandra.db.SliceFromReadCommand
 
SliceQueryFilter - Class in org.apache.cassandra.db.filter
 
SliceQueryFilter(ByteBuffer, ByteBuffer, boolean, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
 
SnappyCompressor - Class in org.apache.cassandra.io.compress
 
SnappyCompressor() - Constructor for class org.apache.cassandra.io.compress.SnappyCompressor
 
snapshot(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Take a snap shot of this columnfamily store.
snapshot(String, String) - Method in class org.apache.cassandra.db.Table
Take a snapshot of the specific column family, or the entire set of column families if columnFamily is null with a given timestamp
snapshot_before_compaction - Variable in class org.apache.cassandra.config.Config
 
snapshot_name - Variable in class org.apache.cassandra.db.SnapshotCommand
 
SNAPSHOT_SUBDIR - Static variable in class org.apache.cassandra.db.Directories
 
SnapshotCommand - Class in org.apache.cassandra.db
 
SnapshotCommand(String, String, String, boolean) - Constructor for class org.apache.cassandra.db.SnapshotCommand
 
snapshotExists(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
snapshotExists(String) - Method in class org.apache.cassandra.db.Directories
 
snapshotExists(String) - Method in class org.apache.cassandra.db.Table
Check whether snapshots already exists for a given name.
snapshotLeveledManifest(String) - Method in class org.apache.cassandra.db.Directories
 
snapshots(String) - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
SnapshotVerbHandler - Class in org.apache.cassandra.service
 
SnapshotVerbHandler() - Constructor for class org.apache.cassandra.service.SnapshotVerbHandler
 
snapshotWithoutFlush(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
snitch - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
snitch - Static variable in class org.apache.cassandra.service.ReadCallback
 
SocketSessionManagementService - Class in org.apache.cassandra.service
 
SocketSessionManagementService() - Constructor for class org.apache.cassandra.service.SocketSessionManagementService
 
sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
Sorts the List of node addresses, in-place, 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
 
sortForConsistencyLevel(List<InetAddress>) - Method in class org.apache.cassandra.service.DatacenterReadCallback
 
sortForConsistencyLevel(List<InetAddress>) - Method in class org.apache.cassandra.service.ReadCallback
Endpoints is already restricted to live replicas, sorted by snitch preference.
sortSampledKeys(List<DecoratedKey>, Range<Token>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
spaceReclaimed(long) - Method in class org.apache.cassandra.db.DataTracker
 
split(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
Split a composite column names into it's components.
split(T) - 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 AbstractBounds is returned as the original.
split(T) - Method in class org.apache.cassandra.dht.Bounds
 
split(T) - Method in class org.apache.cassandra.dht.ExcludingBounds
 
split(T) - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
split(T) - Method in class org.apache.cassandra.dht.Range
 
split(Token) - Method in class org.apache.cassandra.utils.MerkleTree
Splits the range containing the given token, if no tree limits would be violated.
src - Variable in class org.apache.cassandra.streaming.StreamingRepairTask
 
ssl_storage_port - Variable in class org.apache.cassandra.config.Config
 
SSLFactory - Class in org.apache.cassandra.security
A Factory for providing and setting up Client and Server SSL wrapped Socket and ServerSocket
SSLFactory() - Constructor for class org.apache.cassandra.security.SSLFactory
 
sstable - Variable in class org.apache.cassandra.db.compaction.Scrubber
 
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 - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
 
sstable - Variable in class org.apache.cassandra.streaming.PendingFile
 
SSTABLE_COMPRESSION - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
 
SSTableAddedNotification - Class in org.apache.cassandra.notifications
 
SSTableAddedNotification(SSTableReader) - Constructor for class org.apache.cassandra.notifications.SSTableAddedNotification
 
SSTableBoundedScanner - Class in org.apache.cassandra.io.sstable
A SSTableScanner that only reads key in a given range (for validation compaction).
SSTableBoundedScanner.BoundedKeyScanningIterator - Class in org.apache.cassandra.io.sstable
 
SSTableBoundedScanner.BoundedKeyScanningIterator() - Constructor for class org.apache.cassandra.io.sstable.SSTableBoundedScanner.BoundedKeyScanningIterator
 
sstableComparator - Static variable in class org.apache.cassandra.io.sstable.SSTable
 
sstableCompressor - Variable in class org.apache.cassandra.io.compress.CompressionParameters
 
SSTableDeletingTask - Class in org.apache.cassandra.io.sstable
 
SSTableDeletingTask(SSTableReader) - Constructor for class org.apache.cassandra.io.sstable.SSTableDeletingTask
 
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, RandomAccessReader, DecoratedKey<?>, long, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
Used to iterate through the columns of a row.
SSTableIdentityIterator(SSTableReader, RandomAccessReader, DecoratedKey<?>, long, long, boolean) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
Used to iterate through the columns of a row.
SSTableIdentityIterator(CFMetaData, DataInput, DecoratedKey<?>, long, long, IColumnSerializer.Flag) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
SSTableImport - Class in org.apache.cassandra.tools
Create SSTables from JSON input
SSTableImport() - Constructor for class org.apache.cassandra.tools.SSTableImport
 
SSTableListChangedNotification - Class in org.apache.cassandra.notifications
 
SSTableListChangedNotification(Iterable<SSTableReader>, Iterable<SSTableReader>, OperationType) - Constructor for class org.apache.cassandra.notifications.SSTableListChangedNotification
 
sstableLister() - Method in class org.apache.cassandra.db.Directories
 
SSTableLoader - Class in org.apache.cassandra.io.sstable
Cassandra SSTable bulk loader.
SSTableLoader(File, SSTableLoader.Client, OutputHandler) - Constructor for class org.apache.cassandra.io.sstable.SSTableLoader
 
SSTableLoader.Client - Class in org.apache.cassandra.io.sstable
 
SSTableLoader.Client() - Constructor for class org.apache.cassandra.io.sstable.SSTableLoader.Client
 
SSTableLoader.LoaderFuture - Class in org.apache.cassandra.io.sstable
 
SSTableMetadata - Class in org.apache.cassandra.io.sstable
Metadata for a SSTable.
SSTableMetadata.Collector - Class in org.apache.cassandra.io.sstable
 
SSTableMetadata.Collector() - Constructor for class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
SSTableMetadata.SSTableMetadataSerializer - Class in org.apache.cassandra.io.sstable
 
SSTableMetadata.SSTableMetadataSerializer() - Constructor for class org.apache.cassandra.io.sstable.SSTableMetadata.SSTableMetadataSerializer
 
SSTableMetadataViewer - Class in org.apache.cassandra.tools
Shows the contents of sstable metadata
SSTableMetadataViewer() - Constructor for class org.apache.cassandra.tools.SSTableMetadataViewer
 
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
 
sstableOrdering - Static variable in class org.apache.cassandra.io.sstable.SSTable
 
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
 
sstables - Variable in class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
 
sstables - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
SSTableScanner - Class in org.apache.cassandra.io.sstable
 
SSTableScanner.KeyScanningIterator - Class in org.apache.cassandra.io.sstable
 
SSTableScanner.KeyScanningIterator() - Constructor for class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
 
SSTableSimpleUnsortedWriter - Class in org.apache.cassandra.io.sstable
A SSTable writer that doesn't assume rows are in sorted order.
SSTableSimpleUnsortedWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>, int, CompressionParameters) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
Create a new buffering writer.
SSTableSimpleUnsortedWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>, int) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
 
SSTableSimpleWriter - Class in org.apache.cassandra.io.sstable
A SSTable writer that assumes rows are in (partitioner) sorted order.
SSTableSimpleWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleWriter
Create a new writer.
SSTableSimpleWriter(File, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleWriter
 
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
sstablesNeedsMigration() - Static method in class org.apache.cassandra.db.Directories
To check if sstables needs migration, we look at the System directory.
sstablesRewrite() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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<?>, SSTableMetadata.Collector) - Constructor for class org.apache.cassandra.io.sstable.SSTableWriter
 
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
 
StandaloneScrubber - Class in org.apache.cassandra.tools
 
StandaloneScrubber() - Constructor for class org.apache.cassandra.tools.StandaloneScrubber
 
start - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
start() - Method in class org.apache.cassandra.db.HintedHandOffManager
 
start - Variable in class org.apache.cassandra.db.SliceFromReadCommand
 
start(int) - Method in class org.apache.cassandra.gms.Gossiper
Start the gossiper with the generation # retrieved from the System table
start() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Start the Cassandra Daemon, assuming that it has already been initialized via AbstractCassandraDaemon.init(String[]) Hook for JSVC
start() - Method in class org.apache.cassandra.service.AntiEntropyService.RequestCoordinator
 
start() - Method in interface org.apache.cassandra.service.CassandraDaemon
Start the Cassandra Daemon, assuming that it has already been initialized (via CassandraDaemon.init(String[]))
start() - Method in class org.apache.cassandra.service.EmbeddedCassandraService
 
start() - Method in class org.apache.cassandra.service.GCInspector
 
startBroadcasting() - Method in class org.apache.cassandra.service.LoadBroadcaster
 
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.service.AbstractCassandraDaemon
Start the underlying RPC server.
startServer() - Method in class org.apache.cassandra.thrift.CassandraDaemon
 
startThreads() - Method in class org.apache.cassandra.thrift.CustomTHsHaServer
 
startThriftServer() - Method in class org.apache.cassandra.tools.NodeProbe
 
startTime - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
state() - Method in class org.apache.cassandra.thrift.CassandraServer
 
statement() - Method in class org.apache.cassandra.cli.CliParser
 
statement - Variable in class org.apache.cassandra.cql.CQLStatement
 
statement - Variable in class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
 
statements - Variable in class org.apache.cassandra.cql.BatchStatement
 
statements - Variable in class org.apache.cassandra.cql3.statements.BatchStatement
 
StatementType - Enum in org.apache.cassandra.cql
 
STATS - Static variable in class org.apache.cassandra.io.sstable.Component
 
STATUS_BOOTSTRAPPING - Static variable in class org.apache.cassandra.gms.VersionedValue
 
STATUS_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
STATUS_LEAVING - Static variable in class org.apache.cassandra.gms.VersionedValue
 
STATUS_LEFT - Static variable in class org.apache.cassandra.gms.VersionedValue
 
STATUS_MOVING - Static variable in class org.apache.cassandra.gms.VersionedValue
 
STATUS_NORMAL - Static variable in class org.apache.cassandra.gms.VersionedValue
 
StatusCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
StatusLogger - Class in org.apache.cassandra.utils
 
StatusLogger() - Constructor for class org.apache.cassandra.utils.StatusLogger
 
stdev() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
stop() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
 
stop() - Method in class org.apache.cassandra.gms.Gossiper
 
stop() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
Stop the client.
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(String[]) - Static method in class org.apache.cassandra.thrift.CassandraDaemon
 
stop() - Method in class org.apache.cassandra.thrift.CustomTHsHaServer
Stop serving and shut everything down.
stop() - Method in class org.apache.cassandra.thrift.CustomTThreadPoolServer
 
stop(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
stopClient() - Method in class org.apache.cassandra.service.StorageService
 
stopCompaction(String) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
stopCompaction(String) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Stop all running compaction-like tasks having the provided type.
stopCompactionFor(Collection<CFMetaData>) - Method in class org.apache.cassandra.db.compaction.CompactionManager
Try to stop all of the compactions for given ColumnFamilies.
stopGossiping() - Method in class org.apache.cassandra.service.StorageService
 
stopGossiping() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
stopGossiping() - Method in class org.apache.cassandra.tools.NodeProbe
 
stopRPCServer() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Stop the underlying RPC server in idempotent manner.
stopRPCServer() - Method in interface org.apache.cassandra.service.CassandraDaemon
 
stopRPCServer() - Method in class org.apache.cassandra.service.StorageService
 
stopRPCServer() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
stopServer() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Stop the underlying RPC server.
stopServer() - Method in class org.apache.cassandra.thrift.CassandraDaemon
 
stopThriftServer() - Method in class org.apache.cassandra.tools.NodeProbe
 
storage_port - Variable in class org.apache.cassandra.config.Config
 
StorageProxy - Class in org.apache.cassandra.service
 
StorageProxy.WritePerformer - Interface in org.apache.cassandra.service
 
StorageProxyMBean - Interface in org.apache.cassandra.service
 
StorageService - Class in org.apache.cassandra.service
This abstraction contains the token/identifier of this node on the identifier space.
StorageService() - Constructor for class org.apache.cassandra.service.StorageService
 
StorageService.Verb - Enum in org.apache.cassandra.service
 
StorageServiceMBean - Interface in org.apache.cassandra.service
 
store_type - Variable in class org.apache.cassandra.config.EncryptionOptions
 
storeTableInstance(Table) - Method in class org.apache.cassandra.config.Schema
Store given Table instance to the schema
strategy_class - Variable in class org.apache.cassandra.db.migration.avro.KsDef
 
strategy_options - Variable in class org.apache.cassandra.db.migration.avro.KsDef
 
strategyClass - Variable in class org.apache.cassandra.config.KSMetaData
 
strategyOptions - Variable in class org.apache.cassandra.config.KSMetaData
 
stream() - Method in class org.apache.cassandra.io.sstable.SSTableLoader
 
stream(Set<InetAddress>) - Method in class org.apache.cassandra.io.sstable.SSTableLoader
 
stream - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
stream(StreamHeader, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
Stream a file from source to destination.
STREAM_IN_SOURCE_FLAG - Static variable in class org.apache.cassandra.streaming.StreamHeader
 
STREAM_OUT_SOURCE_FLAG - Static variable in class org.apache.cassandra.streaming.StreamHeader
 
stream_throughput_outbound_megabits_per_sec - Variable in class org.apache.cassandra.config.Config
 
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
 
StreamHeader(String, long, PendingFile, Collection<PendingFile>, InetAddress) - 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
 
streaming_socket_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
StreamingRepairTask - Class in org.apache.cassandra.streaming
Task that make two nodes exchange (stream) some ranges (for a given table/cf).
StreamingRepairTask.StreamingRepairRequest - Class in org.apache.cassandra.streaming
 
StreamingRepairTask.StreamingRepairRequest() - Constructor for class org.apache.cassandra.streaming.StreamingRepairTask.StreamingRepairRequest
 
StreamingRepairTask.StreamingRepairResponse - Class in org.apache.cassandra.streaming
 
StreamingRepairTask.StreamingRepairResponse() - Constructor for class org.apache.cassandra.streaming.StreamingRepairTask.StreamingRepairResponse
 
StreamingService - Class in org.apache.cassandra.streaming
 
StreamingServiceMBean - Interface in org.apache.cassandra.streaming
 
StreamInSession - Class in org.apache.cassandra.streaming
each context gets its own StreamInSession.
StreamOut - Class in org.apache.cassandra.streaming
This class handles streaming data from one node to another.
StreamOut() - Constructor for class org.apache.cassandra.streaming.StreamOut
 
StreamOutSession - Class in org.apache.cassandra.streaming
This class manages the streaming of multiple files one after the other.
StreamReplyVerbHandler - Class in org.apache.cassandra.streaming
 
StreamReplyVerbHandler() - Constructor for class org.apache.cassandra.streaming.StreamReplyVerbHandler
 
StreamRequestVerbHandler - Class in org.apache.cassandra.streaming
This verb handler handles the StreamRequestMessage that is sent by the node requesting range transfer.
StreamRequestVerbHandler() - Constructor for class org.apache.cassandra.streaming.StreamRequestVerbHandler
 
string(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Decode a String representation.
string(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Decode a String representation.
string(ByteBuffer, int, int, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Decode a String representation.
string(ByteBuffer, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Decode a String representation.
STRING_LITERAL - Static variable in class org.apache.cassandra.cql.CqlLexer
 
STRING_LITERAL - Static variable in class org.apache.cassandra.cql.CqlParser
 
STRING_LITERAL - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
STRING_LITERAL - Static variable in class org.apache.cassandra.cql3.CqlParser
 
stringifyAliasesParameters(Map<Byte, AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
Helper function to ease the writing of AbstractType.toString() methods.
stringifyFileSize(double) - Static method in class org.apache.cassandra.io.util.FileUtils
 
stringifyTypeParameters(List<AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
Helper function to ease the writing of AbstractType.toString() methods.
StringLiteral - Static variable in class org.apache.cassandra.cli.CliLexer
 
StringLiteral - Static variable in class org.apache.cassandra.cli.CliParser
 
StringToken - Class in org.apache.cassandra.dht
 
StringToken(String) - Constructor for class org.apache.cassandra.dht.StringToken
 
subcolumnComparator - Variable in class org.apache.cassandra.config.CFMetaData
 
subcomparator_type - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
subMap(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
submit(Callable<T>) - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
 
submitBackground(ColumnFamilyStore) - Method in class org.apache.cassandra.db.compaction.CompactionManager
Call this whenever a compaction might be needed on the given columnfamily.
submitCacheWrite(AutoSavingCache.Writer) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
submitIndexBuild(SecondaryIndexBuilder) - Method in class org.apache.cassandra.db.compaction.CompactionManager
Is not scheduled, because it is performing disjoint work from sstable compaction.
submitMaximal(ColumnFamilyStore, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
submitRepairSession(Range<Token>, String, boolean, 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.
submitTruncate(ColumnFamilyStore, long) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
submitUserDefined(ColumnFamilyStore, Collection<Descriptor>, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
submitValidation(ColumnFamilyStore, AntiEntropyService.Validator) - Method in class org.apache.cassandra.db.compaction.CompactionManager
Does not mutate data, so is not scheduled.
submitWrite(int) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
subscribe(INotificationConsumer) - Method in class org.apache.cassandra.db.DataTracker
 
subscribers - Variable in class org.apache.cassandra.db.DataTracker
 
subsnitch - Variable in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
subtract(Range<T>) - Method in class org.apache.cassandra.dht.Range
 
success - Variable in class org.apache.cassandra.db.TruncateResponse
 
sum() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
sumOfDeviations() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
super_column - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
SuperColumn - Class in org.apache.cassandra.db
 
SuperColumn(ByteBuffer, AbstractType<?>) - Constructor for class org.apache.cassandra.db.SuperColumn
 
superColumnName - Variable in class org.apache.cassandra.db.filter.QueryPath
 
supportedOptions() - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
supportedOptions() - Method in interface org.apache.cassandra.io.compress.ICompressor
 
supportedOptions() - Method in class org.apache.cassandra.io.compress.SnappyCompressor
 
switchLock - Static variable in class org.apache.cassandra.db.Table
accesses to CFS.memtable should acquire this for thread safety.
switchMemtable() - Method in class org.apache.cassandra.db.DataTracker
Switch the current memtable.
sync() - Method in class org.apache.cassandra.db.commitlog.CommitLog
Forces a disk flush on the commit log files that need it.
sync() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
Forces a disk flush for this segment file.
sync() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
sync() - Method in class org.apache.cassandra.io.util.SequentialWriter
Synchronize file contents with disk.
syncDataOnlyInternal() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
syncInternal() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
syncNeeded - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
system_add_column_family(CfDef) - Method in class org.apache.cassandra.thrift.CassandraServer
 
system_add_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.CassandraServer
 
system_drop_column_family(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
system_drop_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
SYSTEM_TABLE - Static variable in class org.apache.cassandra.db.Table
 
system_update_column_family(CfDef) - Method in class org.apache.cassandra.thrift.CassandraServer
 
system_update_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.CassandraServer
update an existing keyspace, but do not allow column family modifications.
systemKeyspace() - Static method in class org.apache.cassandra.config.KSMetaData
 
SystemTable - Class in org.apache.cassandra.db
 
SystemTable() - Constructor for class org.apache.cassandra.db.SystemTable
 
SystemTable.BootstrapState - Enum in org.apache.cassandra.db
 

T

T - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T - Static variable in class org.apache.cassandra.cql.CqlParser
 
T - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__100 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__100 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__101 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__101 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__102 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__102 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__103 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__103 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__104 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__104 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__105 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__105 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__105 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__105 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__106 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__106 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__106 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__106 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__107 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__107 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__107 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__107 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__108 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__108 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__109 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__109 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__110 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__110 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__111 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__111 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__112 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__112 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__112 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__112 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__113 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__113 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__113 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__113 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__114 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__114 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__114 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__114 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__115 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__115 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__115 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__115 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__116 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__116 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__116 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__116 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__117 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__117 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__117 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__117 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__118 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__118 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__118 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__118 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__119 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__119 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__119 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__119 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__120 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__120 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__120 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__120 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__121 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__121 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__121 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__121 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__122 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__122 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__122 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__122 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__123 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__123 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__123 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__123 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__124 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__124 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__124 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__124 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__125 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__125 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__125 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__125 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__126 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__126 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__81 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__81 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__82 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__82 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__83 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__83 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__84 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__84 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__85 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__85 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__86 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__86 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__87 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__87 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__88 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__88 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__89 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__89 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__90 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__90 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__91 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__91 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__92 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__92 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__93 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__93 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__94 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__94 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__95 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__95 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__96 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__96 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__97 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__97 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__98 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__98 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__99 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__99 - Static variable in class org.apache.cassandra.cql.CqlParser
 
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
It represents a Keyspace.
table() - Method in class org.apache.cassandra.db.WriteResponse
 
table - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
table - Variable in class org.apache.cassandra.service.AbstractRowResolver
 
table - Variable in class org.apache.cassandra.streaming.AbstractStreamSession
 
table - Variable in class org.apache.cassandra.streaming.StreamHeader
 
tailMap(ByteBuffer) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
takeColumnFamilySnapshot(String, String, String) - Method in class org.apache.cassandra.service.StorageService
Takes the snapshot of a specific column family.
takeColumnFamilySnapshot(String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Takes the snapshot of a specific column family.
takeSnapshot(String, String...) - Method in class org.apache.cassandra.service.StorageService
Takes the snapshot for the given tables.
takeSnapshot(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Takes the snapshot for the given tables.
takeSnapshot(String, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
Take a snapshot of all the tables, optionally specifying only a specific column family.
targetThroughput() - Method in interface org.apache.cassandra.utils.Throttle.ThroughputFunction
 
TASK_ID - Static variable in class org.apache.cassandra.net.HeaderTypes
 
TASK_PROFILE_CHAIN - Static variable in class org.apache.cassandra.net.HeaderTypes
 
tasks - Static variable in class org.apache.cassandra.service.StorageService
This pool is used by tasks that can have longer execution times, and usually are non periodic.
TBinaryProtocol - Class in org.apache.cassandra.thrift
TODO This was added to support writeBinary on direct buffers for CASSANDRA-1714; we can remove it once we upgrade to Thrift 0.7, which incorporates the patch (THRIFT-883).
TBinaryProtocol(TTransport) - Constructor for class org.apache.cassandra.thrift.TBinaryProtocol
 
TBinaryProtocol(TTransport, boolean, boolean) - Constructor for class org.apache.cassandra.thrift.TBinaryProtocol
 
TBinaryProtocol.Factory - Class in org.apache.cassandra.thrift
 
TBinaryProtocol.Factory() - Constructor for class org.apache.cassandra.thrift.TBinaryProtocol.Factory
 
TBinaryProtocol.Factory(boolean, boolean) - Constructor for class org.apache.cassandra.thrift.TBinaryProtocol.Factory
 
TBinaryProtocol.Factory(boolean, boolean, int) - Constructor for class org.apache.cassandra.thrift.TBinaryProtocol.Factory
 
TCustomNonblockingServerSocket - Class in org.apache.cassandra.thrift
 
TCustomNonblockingServerSocket(InetSocketAddress, boolean, Integer, Integer) - Constructor for class org.apache.cassandra.thrift.TCustomNonblockingServerSocket
 
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.
TCustomSocket - Class in org.apache.cassandra.thrift
Socket implementation of the TTransport interface.
TCustomSocket(Socket) - Constructor for class org.apache.cassandra.thrift.TCustomSocket
Constructor that takes an already created socket.
TCustomSocket(String, int) - Constructor for class org.apache.cassandra.thrift.TCustomSocket
Creates a new unconnected socket that will connect to the given host on the given port.
TCustomSocket(String, int, int) - Constructor for class org.apache.cassandra.thrift.TCustomSocket
Creates a new unconnected socket that will connect to the given host on the given port.
TEMPFILE_MARKER - Static variable in class org.apache.cassandra.io.sstable.SSTable
 
temporary - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
term() - Method in class org.apache.cassandra.cql.CqlParser
 
Term - Class in org.apache.cassandra.cql
A term parsed from a CQL statement.
Term(String, TermType) - Constructor for class org.apache.cassandra.cql.Term
 
Term(String, int) - Constructor for class org.apache.cassandra.cql.Term
Create new Term instance from a string, and an integer that corresponds with the token ID from CQLParser.
Term(long, TermType) - Constructor for class org.apache.cassandra.cql.Term
 
Term() - Constructor for class org.apache.cassandra.cql.Term
 
Term(String, int, int) - Constructor for class org.apache.cassandra.cql.Term
 
term() - Method in class org.apache.cassandra.cql3.CqlParser
 
Term - Class in org.apache.cassandra.cql3
A term parsed from a CQL statement.
Term(String, TermType) - Constructor for class org.apache.cassandra.cql3.Term
 
Term(String, int) - Constructor for class org.apache.cassandra.cql3.Term
Create new Term instance from a string, and an integer that corresponds with the token ID from CQLParser.
Term(long, TermType) - Constructor for class org.apache.cassandra.cql3.Term
 
Term(String, int, int) - Constructor for class org.apache.cassandra.cql3.Term
 
terminateSessions() - Method in class org.apache.cassandra.service.AntiEntropyService
 
termList() - Method in class org.apache.cassandra.cql.CqlParser
 
termPair(Map<Term, Term>) - Method in class org.apache.cassandra.cql.CqlParser
 
termPairWithOperation(Map<Term, Operation>) - Method in class org.apache.cassandra.cql.CqlParser
 
termPairWithOperation(Map<ColumnIdentifier, Operation>) - Method in class org.apache.cassandra.cql3.CqlParser
 
testMetadata(String, Class<? extends AbstractReplicationStrategy>, Map<String, String>, CFMetaData...) - Static method in class org.apache.cassandra.config.KSMetaData
 
testMetadataNotDurable(String, Class<? extends AbstractReplicationStrategy>, Map<String, String>, CFMetaData...) - Static method in class org.apache.cassandra.config.KSMetaData
 
TFramedTransportFactory - Class in org.apache.cassandra.thrift
 
TFramedTransportFactory() - Constructor for class org.apache.cassandra.thrift.TFramedTransportFactory
 
threadLocalMD5Digest() - Static method in class org.apache.cassandra.utils.FBUtilities
 
threadLocalRandom() - Static method in class org.apache.cassandra.utils.FBUtilities
 
ThreadSafeSortedColumns - Class in org.apache.cassandra.db
 
thrift_framed_transport_size_in_mb - Variable in class org.apache.cassandra.config.Config
 
thrift_max_message_length_in_mb - Variable in class org.apache.cassandra.config.Config
 
thriftifyColumns(Collection<IColumn>, boolean) - Method in class org.apache.cassandra.thrift.CassandraServer
 
thriftifyCounterSubColumns(Collection<IColumn>) - Method in class org.apache.cassandra.thrift.CassandraServer
 
thriftifySubColumns(Collection<IColumn>) - Method in class org.apache.cassandra.thrift.CassandraServer
 
thriftPort - Variable in class org.apache.cassandra.cli.CliSessionState
 
ThriftValidation - Class in org.apache.cassandra.thrift
This has a lot of building blocks for CassandraServer to call to make sure it has valid input -- ensuring column names conform to the declared comparator, for instance.
ThriftValidation() - Constructor for class org.apache.cassandra.thrift.ThriftValidation
 
Throttle - Class in org.apache.cassandra.utils
Encapsulates the timing/state required to throttle a caller to a target throughput in bytes per millisecond, when periodically passed an absolute count of bytes.
Throttle(String, Throttle.ThroughputFunction) - Constructor for class org.apache.cassandra.utils.Throttle
 
throttle(long) - Method in class org.apache.cassandra.utils.Throttle
 
Throttle.ThroughputFunction - Interface in org.apache.cassandra.utils
 
throttle_limit - Variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
throttleDelta(long) - Method in class org.apache.cassandra.utils.Throttle
 
throwLastRecognitionError() - Method in class org.apache.cassandra.cql.CqlLexer
 
throwLastRecognitionError() - Method in class org.apache.cassandra.cql.CqlParser
 
throwLastRecognitionError() - Method in class org.apache.cassandra.cql3.CqlLexer
 
throwLastRecognitionError() - Method in class org.apache.cassandra.cql3.CqlParser
 
TICK_CYCLE_TIME - Static variable in class org.apache.cassandra.db.commitlog.CommitLogAllocator
The (theoretical) max milliseconds between loop runs to perform janitorial tasks
timestamp - Variable in class org.apache.cassandra.cql.AbstractModification
 
timestamp - Variable in class org.apache.cassandra.cql.BatchStatement
 
timestamp - Variable in class org.apache.cassandra.cql3.Attributes
 
timestamp - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement
 
timestamp - Variable in class org.apache.cassandra.db.Column
 
timestamp() - Method in class org.apache.cassandra.db.Column
 
timestamp() - Method in interface org.apache.cassandra.db.IColumn
 
timestamp() - Method in class org.apache.cassandra.db.SuperColumn
 
timestamp - Variable in class org.apache.cassandra.utils.NodeId.NodeIdRecord
 
timestampMicros() - Static method in class org.apache.cassandra.utils.FBUtilities
 
timestampOfLastDelete() - Method in class org.apache.cassandra.db.CounterColumn
 
timeToLive - Variable in class org.apache.cassandra.cql.AbstractModification
 
timeToLive - Variable in class org.apache.cassandra.cql.BatchStatement
 
timeToLive - Variable in class org.apache.cassandra.cql3.Attributes
 
timeToLive - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement
 
TimeUUIDType - Class in org.apache.cassandra.db.marshal
 
to - Variable in class org.apache.cassandra.streaming.FileStreamTask
 
toByteArray(Token<T>) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
toByteArray() - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
Returns the contents of this ByteArrayOutputStream as a byte array.
toDouble(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
toFloat(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
toIndexScanCommand() - Method in class org.apache.cassandra.db.RangeSliceCommand
 
toInt(String, String, Integer) - Static method in class org.apache.cassandra.cql3.PropertyDefinitions
 
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.KeyBound - Class in org.apache.cassandra.dht
 
Token.TokenFactory<T> - Class in org.apache.cassandra.dht
 
Token.TokenFactory() - Constructor for class org.apache.cassandra.dht.Token.TokenFactory
 
Token.TokenSerializer - Class in org.apache.cassandra.dht
 
Token.TokenSerializer() - Constructor for class org.apache.cassandra.dht.Token.TokenSerializer
 
tokenMetadata - Variable in class org.apache.cassandra.dht.BootStrapper
 
TokenMetadata - Class in org.apache.cassandra.locator
 
TokenMetadata() - Constructor for class org.apache.cassandra.locator.TokenMetadata
 
TokenMetadata(BiMap<Token, InetAddress>) - Constructor for class org.apache.cassandra.locator.TokenMetadata
 
tokenNames - Static variable in class org.apache.cassandra.cli.CliParser
 
tokenNames - Static variable in class org.apache.cassandra.cql.CqlParser
 
tokenNames - Static variable in class org.apache.cassandra.cql3.CqlParser
 
tokenOf(Term) - Static method in class org.apache.cassandra.cql3.Term
 
toLong(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
toResource() - Method in class org.apache.cassandra.cql3.CFName
 
toRowBounds() - Method in class org.apache.cassandra.dht.AbstractBounds
Transform this abstract bounds to equivalent covering bounds of row positions.
toRowBounds() - Method in class org.apache.cassandra.dht.Bounds
 
toRowBounds() - Method in class org.apache.cassandra.dht.ExcludingBounds
 
toRowBounds() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
toRowBounds() - Method in class org.apache.cassandra.dht.Range
 
toSchema(RowMutation, long) - Method in class org.apache.cassandra.config.CFMetaData
 
toSchema(long) - Method in class org.apache.cassandra.config.CFMetaData
Convert current metadata into schema mutation
toSchema(RowMutation, String, AbstractType<?>, long) - Method in class org.apache.cassandra.config.ColumnDefinition
 
toSchema(long) - Method in class org.apache.cassandra.config.KSMetaData
 
toSchemaUpdate(CFMetaData, long) - Method in class org.apache.cassandra.config.CFMetaData
Create schema mutations to update this metadata to provided new state.
toSchemaUpdate(KSMetaData, long) - Method in class org.apache.cassandra.config.KSMetaData
 
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.cache.KeyCacheKey
 
toString() - Method in class org.apache.cassandra.cache.RowCacheKey
 
toString() - Method in class org.apache.cassandra.config.CFMetaData
 
toString() - Method in class org.apache.cassandra.config.ColumnDefinition
 
toString() - Method in class org.apache.cassandra.config.KSMetaData
 
toString() - Method in class org.apache.cassandra.cql.AlterTableStatement
 
toString() - Method in class org.apache.cassandra.cql.Attributes
 
toString() - Method in class org.apache.cassandra.cql.BatchStatement
 
toString() - Method in class org.apache.cassandra.cql.CFPropDefs
 
toString() - Method in class org.apache.cassandra.cql.DeleteStatement
 
toString(T) - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcType
 
toString(UUID) - Method in class org.apache.cassandra.cql.jdbc.AbstractJdbcUUID
 
toString(String) - Method in class org.apache.cassandra.cql.jdbc.JdbcAscii
 
toString(Boolean) - Method in class org.apache.cassandra.cql.jdbc.JdbcBoolean
 
toString(ByteBuffer) - Method in class org.apache.cassandra.cql.jdbc.JdbcBytes
 
toString(Date) - Method in class org.apache.cassandra.cql.jdbc.JdbcDate
 
toString(BigDecimal) - Method in class org.apache.cassandra.cql.jdbc.JdbcDecimal
 
toString(Double) - Method in class org.apache.cassandra.cql.jdbc.JdbcDouble
 
toString(Float) - Method in class org.apache.cassandra.cql.jdbc.JdbcFloat
 
toString(Integer) - Method in class org.apache.cassandra.cql.jdbc.JdbcInt32
 
toString(BigInteger) - Method in class org.apache.cassandra.cql.jdbc.JdbcInteger
 
toString(Long) - Method in class org.apache.cassandra.cql.jdbc.JdbcLong
 
toString(String) - Method in class org.apache.cassandra.cql.jdbc.JdbcUTF8
 
toString() - Method in class org.apache.cassandra.cql.Operation
 
toString() - Method in class org.apache.cassandra.cql.Relation
 
toString() - Method in class org.apache.cassandra.cql.SelectExpression
 
toString() - Method in class org.apache.cassandra.cql.SelectStatement
 
toString() - Method in class org.apache.cassandra.cql.Term
 
toString() - Method in class org.apache.cassandra.cql.UpdateStatement
 
toString() - Method in class org.apache.cassandra.cql.WhereClause
 
toString() - Method in class org.apache.cassandra.cql3.CFDefinition.Name
 
toString() - Method in class org.apache.cassandra.cql3.CFDefinition
 
toString() - Method in class org.apache.cassandra.cql3.CFName
 
toString() - Method in class org.apache.cassandra.cql3.CFPropDefs
 
toString() - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
toString() - Method in class org.apache.cassandra.cql3.Operation
 
toString() - Method in class org.apache.cassandra.cql3.Relation
 
toString() - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
 
toString() - Method in enum org.apache.cassandra.cql3.statements.Selector.Function
 
toString() - Method in class org.apache.cassandra.cql3.statements.Selector.WithFunction
 
toString() - Method in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
 
toString() - Method in class org.apache.cassandra.cql3.Term
 
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.CommitLogSegment
 
toString() - Method in class org.apache.cassandra.db.commitlog.ReplayPosition
 
toString() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
toString() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
toString() - Method in class org.apache.cassandra.db.compaction.CompactionIterable
 
toString() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
toString() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
toString() - Method in enum org.apache.cassandra.db.compaction.OperationType
 
toString() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
toString(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Human-readable String from context.
toString(ByteBuffer) - Method in interface org.apache.cassandra.db.context.IContext
Human-readable String from context.
toString() - Method in class org.apache.cassandra.db.CounterMutation
 
toString(boolean) - Method in class org.apache.cassandra.db.CounterMutation
 
toString() - Method in class org.apache.cassandra.db.DecoratedKey
 
toString() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
toString() - Method in class org.apache.cassandra.db.filter.QueryFilter
 
toString() - Method in class org.apache.cassandra.db.filter.QueryPath
 
toString() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
toString(boolean) - Method in interface org.apache.cassandra.db.IMutation
 
toString() - Method in class org.apache.cassandra.db.marshal.AbstractType
This must be overriden by subclasses if necessary so that for any AbstractType, this == TypeParser.parse(toString()).
toString() - Method in class org.apache.cassandra.db.marshal.CompositeType
 
toString() - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
toString() - Method in class org.apache.cassandra.db.marshal.ReversedType
 
toString() - Method in class org.apache.cassandra.db.Memtable
 
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.RetriedSliceFromReadCommand
 
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.SnapshotCommand
 
toString() - Method in class org.apache.cassandra.db.Table
 
toString() - Method in class org.apache.cassandra.db.Truncation
 
toString() - Method in class org.apache.cassandra.dht.Bounds
 
toString() - Method in class org.apache.cassandra.dht.BytesToken
 
toString() - Method in class org.apache.cassandra.dht.ExcludingBounds
 
toString() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
toString() - Method in class org.apache.cassandra.dht.LocalToken
 
toString() - Method in class org.apache.cassandra.dht.Range
 
toString() - Method in class org.apache.cassandra.dht.Token.KeyBound
 
toString(Token<T>) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
toString() - Method in class org.apache.cassandra.dht.Token
 
toString() - Method in class org.apache.cassandra.gms.FailureDetector
 
toString() - Method in class org.apache.cassandra.gms.GossipDigest
 
toString() - Method in class org.apache.cassandra.gms.VersionedValue
 
toString() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
toString() - Method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
 
toString() - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
 
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.SSTable
 
toString() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
 
toString() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
toString() - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
Returns the contents of this ByteArrayOutputStream as a string.
toString(int) - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
Deprecated. Use FastByteArrayOutputStream.toString().
toString(String) - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
Returns the contents of this ByteArrayOutputStream as a string converted according to the encoding declared in enc.
toString() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
toString() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
toString() - Method in class org.apache.cassandra.io.util.SegmentedFile
 
toString() - Method in class org.apache.cassandra.locator.TokenMetadata
 
toString() - Method in class org.apache.cassandra.net.Message
 
toString() - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
toString() - Method in enum org.apache.cassandra.service.CacheService.CacheType
 
toString() - Method in class org.apache.cassandra.streaming.FileStreamTask
 
toString() - Method in class org.apache.cassandra.streaming.PendingFile
 
toString(Map<?, ?>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
toString() - Method in class org.apache.cassandra.utils.IntervalTree.Interval
 
toString() - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
toString() - Method in class org.apache.cassandra.utils.MerkleTree.RowHash
 
toString() - Method in class org.apache.cassandra.utils.MerkleTree
 
toString() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
toString() - Method in class org.apache.cassandra.utils.NodeId.NodeIdRecord
 
toString() - Method in class org.apache.cassandra.utils.NodeId
 
toString() - Method in class org.apache.cassandra.utils.Pair
 
toString() - Method in class org.apache.cassandra.utils.SemanticVersion
 
toString() - Method in class org.apache.cassandra.utils.Throttle
 
total(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Returns the aggregated count across all node ids.
total() - Method in class org.apache.cassandra.db.CounterColumn
 
totalBytes - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
totalBytesCompacted - Static variable in class org.apache.cassandra.db.compaction.CompactionTask
 
toThrift() - Method in class org.apache.cassandra.config.CFMetaData
 
toThrift() - Method in class org.apache.cassandra.config.ColumnDefinition
 
toThrift() - Method in class org.apache.cassandra.config.KSMetaData
 
toTokenBounds() - Method in class org.apache.cassandra.dht.AbstractBounds
Transform this abstract bounds to a token abstract bounds.
toTokenBounds() - Method in class org.apache.cassandra.dht.Bounds
 
toTokenBounds() - Method in class org.apache.cassandra.dht.ExcludingBounds
 
toTokenBounds() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
toTokenBounds() - Method in class org.apache.cassandra.dht.Range
 
tracksMaxTimestamp - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
transferRanges(InetAddress, Table, Collection<Range<Token>>, IStreamCallback, OperationType) - Static method in class org.apache.cassandra.streaming.StreamOut
Stream the given ranges to the target endpoint from each CF in the given keyspace.
transferRanges(StreamOutSession, Iterable<ColumnFamilyStore>, Collection<Range<Token>>, OperationType) - Static method in class org.apache.cassandra.streaming.StreamOut
Stream the given ranges to the target endpoint from each of the given CFs.
transferSSTables(StreamOutSession, Iterable<SSTableReader>, Collection<Range<Token>>, OperationType) - Static method in class org.apache.cassandra.streaming.StreamOut
Low-level transfer of 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
 
TreeMapBackedSortedColumns - Class in org.apache.cassandra.db
 
trickle_fsync - Variable in class org.apache.cassandra.config.Config
 
trickle_fsync_interval_in_kb - Variable in class org.apache.cassandra.config.Config
 
trimTrailingZeros() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Lowers numWords, the number of words in use, by checking for trailing zero words.
trivialReduceIsTrivial() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
 
TRUNCATE - Static variable in class org.apache.cassandra.cli.CliLexer
 
TRUNCATE - Static variable in class org.apache.cassandra.cli.CliParser
 
truncate() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Truncate practically deletes the entire column family's data
truncate(long) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
truncate(long) - Method in class org.apache.cassandra.db.index.SecondaryIndex
Truncate all the data from the current index
truncate(String, long) - Static method in class org.apache.cassandra.io.util.FileUtils
 
truncate(long) - Method in class org.apache.cassandra.io.util.SequentialWriter
 
truncate(String, String) - Method in class org.apache.cassandra.service.StorageService
 
truncate(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Truncates (deletes) the given columnFamily from the provided keyspace.
truncate(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
truncate(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
truncateBlocking(String, String) - Static method in class org.apache.cassandra.service.StorageProxy
Performs the truncate operatoin, which effectively deletes all data from the column family cfname
TruncateResponse - Class in org.apache.cassandra.db
This message is sent back the truncate operation and basically specifies if the truncate succeeded.
TruncateResponse(String, String, boolean) - Constructor for class org.apache.cassandra.db.TruncateResponse
 
TruncateResponse.TruncateResponseSerializer - Class in org.apache.cassandra.db
 
TruncateResponse.TruncateResponseSerializer() - Constructor for class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
 
TruncateResponseHandler - Class in org.apache.cassandra.service
 
TruncateResponseHandler(int) - Constructor for class org.apache.cassandra.service.TruncateResponseHandler
 
truncateStatement() - Method in class org.apache.cassandra.cli.CliParser
 
truncateStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
truncateStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
TruncateStatement - Class in org.apache.cassandra.cql3.statements
 
TruncateStatement(CFName) - Constructor for class org.apache.cassandra.cql3.statements.TruncateStatement
 
TruncateVerbHandler - Class in org.apache.cassandra.db
 
TruncateVerbHandler() - Constructor for class org.apache.cassandra.db.TruncateVerbHandler
 
Truncation - Class in org.apache.cassandra.db
A truncate operation descriptor
Truncation(String, String) - Constructor for class org.apache.cassandra.db.Truncation
 
truststore - Variable in class org.apache.cassandra.config.EncryptionOptions
 
truststore_password - Variable in class org.apache.cassandra.config.EncryptionOptions
 
tryCloseFD(int) - Static method in class org.apache.cassandra.utils.CLibrary
 
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
 
tryGetLeveledManifest() - Method in class org.apache.cassandra.db.Directories
 
tryGetManifest(ColumnFamilyStore) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
 
tryMlockall() - Static method in class org.apache.cassandra.utils.CLibrary
 
tryOpenDirectory(String) - Static method in class org.apache.cassandra.utils.CLibrary
 
trySkipCache(int, long, int) - Static method in class org.apache.cassandra.utils.CLibrary
 
trySync(int) - Static method in class org.apache.cassandra.utils.CLibrary
 
tsSize - Static variable in class org.apache.cassandra.db.DBConstants
 
TTL - Static variable in class org.apache.cassandra.cli.CliLexer
 
TTL - Static variable in class org.apache.cassandra.cli.CliParser
 
TWO - Static variable in class org.apache.cassandra.utils.FBUtilities
 
type - Variable in class org.apache.cassandra.cql.CQLStatement
 
type - Variable in class org.apache.cassandra.cql.Operation
 
type - Variable in class org.apache.cassandra.cql3.CFDefinition.Name
 
type - Variable in class org.apache.cassandra.cql3.Operation
 
type - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
type - Variable in class org.apache.cassandra.io.sstable.Component
 
type - Variable in class org.apache.cassandra.streaming.PendingFile
 
typeIdentifier() - Method in class org.apache.cassandra.cli.CliParser
 
TypeParser - Class in org.apache.cassandra.db.marshal
Parse a string containing an Type definition.
types - Variable in class org.apache.cassandra.db.marshal.CompositeType
 
TypesMap - Class in org.apache.cassandra.cql.jdbc
 
TypesMap() - Constructor for class org.apache.cassandra.cql.jdbc.TypesMap
 

U

U - Static variable in class org.apache.cassandra.cql.CqlLexer
 
U - Static variable in class org.apache.cassandra.cql.CqlParser
 
U - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
U - Static variable in class org.apache.cassandra.cql3.CqlParser
 
unchecked(Exception) - Static method in class org.apache.cassandra.utils.FBUtilities
 
uncompress(byte[], int, int, byte[], int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
uncompress(byte[], int, int, byte[], int) - Method in interface org.apache.cassandra.io.compress.ICompressor
 
uncompress(byte[], int, int, byte[], int) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
 
uncompressedLength() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
unescapeSQLString(String) - Static method in class org.apache.cassandra.cli.CliUtils
Strips leading and trailing "'" characters, and handles and escaped characters such as \n, \r, etc.
UnicodeEscapeSequence - Static variable in class org.apache.cassandra.cli.CliLexer
 
UnicodeEscapeSequence - Static variable in class org.apache.cassandra.cli.CliParser
 
UnknownColumnFamilyException - Exception in org.apache.cassandra.db
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
UnknownColumnFamilyException(String, int) - Constructor for exception org.apache.cassandra.db.UnknownColumnFamilyException
 
unmarkCompacting(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
Removes files from compacting status: this is different from 'markCompacted' because it should be run regardless of whether a compaction succeeded.
unmarkSSTables() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
UNREACHABLE - Static variable in class org.apache.cassandra.service.StorageProxy
 
unreference() - Method in class org.apache.cassandra.cache.FreeableMemory
decrement reference count.
unreferenceSSTables() - Method in class org.apache.cassandra.db.DataTracker
removes all sstables that are not busy compacting.
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
 
unreserved_keyword() - Method in class org.apache.cassandra.cql3.CqlParser
 
unsafeAssassinateEndpoint(String) - Method in class org.apache.cassandra.gms.Gossiper
Do not call this method unless you know what you are doing.
unsafeAssassinateEndpoint(String) - Method in interface org.apache.cassandra.gms.GossiperMBean
 
unsubscribe(INotificationConsumer) - Method in class org.apache.cassandra.db.DataTracker
 
UntypedResultSet - Class in org.apache.cassandra.cql3
a utility for doing internal cql-based queries
UntypedResultSet(List<CqlRow>) - Constructor for class org.apache.cassandra.cql3.UntypedResultSet
 
UntypedResultSet.Row - Class in org.apache.cassandra.cql3
 
UntypedResultSet.Row(CqlRow) - Constructor for class org.apache.cassandra.cql3.UntypedResultSet.Row
 
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.ExcludingBounds
 
unwrap() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
unwrap() - Method in class org.apache.cassandra.dht.Range
 
UPDATE - Static variable in class org.apache.cassandra.cli.CliLexer
 
UPDATE - Static variable in class org.apache.cassandra.cli.CliParser
 
update(MessageDigest) - Method in class org.apache.cassandra.db.compaction.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.db.compaction.LazilyCompactedRow
 
update(MessageDigest) - Method in class org.apache.cassandra.db.compaction.PrecompactedRow
 
update(MessageDigest) - Method in class org.apache.cassandra.db.EchoedRow
 
update(byte[], int, int) - Method in class org.apache.cassandra.utils.PureJavaCrc32
update(int) - Method in class org.apache.cassandra.utils.PureJavaCrc32
updateCapacity(long) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
updateColumn(DecoratedKey<?>, ByteBuffer, IColumn) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
updateColumn(DecoratedKey<?>, ByteBuffer, IColumn) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
update a column from the index
updateColumnFamily() - Method in class org.apache.cassandra.cli.CliParser
 
UpdateColumnFamily - Class in org.apache.cassandra.db.migration.avro
 
UpdateColumnFamily() - Constructor for class org.apache.cassandra.db.migration.avro.UpdateColumnFamily
 
updateColumnsLimit(int) - Method in interface org.apache.cassandra.db.filter.IFilter
 
updateColumnsLimit(int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
updateColumnsLimit(int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
updateCompletor(Set<String>) - Static method in class org.apache.cassandra.cli.CliMain
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.Column
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.ColumnFamily
 
updateDigest(MessageDigest, ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Update a MessageDigest with the content of a context.
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.CounterColumn
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.ExpiringColumn
 
updateDigest(MessageDigest) - Method in interface org.apache.cassandra.db.IColumn
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.SuperColumn
 
updateFilter(int) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
Update the filter if necessary given the number of column already fetched.
updateKeyspace() - Method in class org.apache.cassandra.cli.CliParser
 
UpdateKeyspace - Class in org.apache.cassandra.db.migration.avro
 
UpdateKeyspace() - Constructor for class org.apache.cassandra.db.migration.avro.UpdateKeyspace
 
updateLiveRatio() - Method in class org.apache.cassandra.db.Memtable
 
updateMaxTimestamp(long) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
updateMaxTimestamp(long) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
updateNormalToken(Token, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
Update token map with a single token/endpoint pair in normal state.
updateNormalTokens(Set<Pair<Token, InetAddress>>) - Method in class org.apache.cassandra.locator.TokenMetadata
Update token map with a set of token/endpoint pairs in normal state.
updateRowCache(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
updateSnitch(String, Boolean, Integer, Integer, Double) - Method in class org.apache.cassandra.service.StorageService
 
updateSnitch(String, Boolean, Integer, Integer, Double) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Change endpointsnitch class and dynamic-ness (and dynamic attributes) at runtime
updateStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
UpdateStatement - Class in org.apache.cassandra.cql
An UPDATE statement parsed from a CQL query statement.
UpdateStatement(String, String, String, Map<Term, Operation>, List<Term>, Attributes) - Constructor for class org.apache.cassandra.cql.UpdateStatement
Creates a new UpdateStatement from a column family name, columns map, consistency level, and key term.
UpdateStatement(String, String, String, List<Term>, List<Term>, List<Term>, Attributes) - Constructor for class org.apache.cassandra.cql.UpdateStatement
Creates a new UpdateStatement from a column family name, a consistency level, key, and lists of column names and values.
updateStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
UpdateStatement - Class in org.apache.cassandra.cql3.statements
An UPDATE statement parsed from a CQL query statement.
UpdateStatement(CFName, Map<ColumnIdentifier, Operation>, List<Relation>, Attributes) - Constructor for class org.apache.cassandra.cql3.statements.UpdateStatement
Creates a new UpdateStatement from a column family name, columns map, consistency level, and key term.
UpdateStatement(CFName, List<ColumnIdentifier>, List<Term>, Attributes) - Constructor for class org.apache.cassandra.cql3.statements.UpdateStatement
Creates a new UpdateStatement from a column family name, a consistency level, key, and lists of column names and values.
updateToken(InetAddress, Token) - Static method in class org.apache.cassandra.db.SystemTable
Record token being used by another node
updateToken(Token) - Static method in class org.apache.cassandra.db.SystemTable
This method is used to update the System Table with the new token for this node
updateVersion() - Method in class org.apache.cassandra.config.Schema
Read schema from system table and calculate MD5 digest of every row, resulting digest will be converted into UUID which would act as content-based version of the schema.
updateVersionAndAnnounce() - Method in class org.apache.cassandra.config.Schema
 
upgradeSSTables(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
upgradeSSTables(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Rewrite all sstables to the latest version.
upgradeSSTables(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
upperBound(Class<T>) - Method in class org.apache.cassandra.dht.Token
 
USE - Static variable in class org.apache.cassandra.cli.CliLexer
 
USE - Static variable in class org.apache.cassandra.cli.CliParser
 
useKeyspace() - Method in class org.apache.cassandra.cli.CliParser
 
username - Variable in class org.apache.cassandra.auth.AuthenticatedUser
 
username() - Method in class org.apache.cassandra.cli.CliParser
 
username - Variable in class org.apache.cassandra.cli.CliSessionState
 
USERNAME_KEY - Static variable in interface org.apache.cassandra.auth.IAuthenticator
 
usesOldBloomFilter - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
useStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
useStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
UseStatement - Class in org.apache.cassandra.cql3.statements
 
UseStatement(String) - Constructor for class org.apache.cassandra.cql3.statements.UseStatement
 
usingClause(Attributes) - Method in class org.apache.cassandra.cql.CqlParser
 
usingClause(Attributes) - Method in class org.apache.cassandra.cql3.CqlParser
 
usingClauseDelete(Attributes) - Method in class org.apache.cassandra.cql.CqlParser
 
usingClauseDelete(Attributes) - Method in class org.apache.cassandra.cql3.CqlParser
 
usingClauseDeleteObjective(Attributes) - Method in class org.apache.cassandra.cql.CqlParser
 
usingClauseDeleteObjective(Attributes) - Method in class org.apache.cassandra.cql3.CqlParser
 
usingClauseObjective(Attributes) - Method in class org.apache.cassandra.cql.CqlParser
 
usingClauseObjective(Attributes) - Method in class org.apache.cassandra.cql3.CqlParser
 
utf8(String, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
UTF8Type - Class in org.apache.cassandra.db.marshal
 
UUID - Static variable in class org.apache.cassandra.cql.CqlLexer
 
UUID - Static variable in class org.apache.cassandra.cql.CqlParser
 
UUID - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
UUID - Static variable in class org.apache.cassandra.cql3.CqlParser
 
UUID - Class in org.apache.cassandra.utils.avro
 
UUID() - Constructor for class org.apache.cassandra.utils.avro.UUID
 
UUIDGen - Class in org.apache.cassandra.utils
The goods are here: www.ietf.org/rfc/rfc4122.txt.
UUIDType - Class in org.apache.cassandra.db.marshal
Compares UUIDs using the following criteria:
- if count of supplied bytes is less than 16, compare counts
- compare UUID version fields
- nil UUID is always lesser
- compare timestamps if both are time-based
- compare lexically, unsigned msb-to-lsb comparison

V

V - Static variable in class org.apache.cassandra.cql.CqlLexer
 
V - Static variable in class org.apache.cassandra.cql.CqlParser
 
V - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
V - Static variable in class org.apache.cassandra.cql3.CqlParser
 
validate() - Method in class org.apache.cassandra.config.CFMetaData
 
validate() - Method in class org.apache.cassandra.config.KSMetaData
 
validate() - Method in class org.apache.cassandra.cql.CFPropDefs
 
validate() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
The CqlParser only goes as far as extracting the keyword arguments from these statements, so this method is responsible for processing and validating, and must be called prior to access.
validate() - Method in class org.apache.cassandra.cql3.CFPropDefs
 
validate(ClientState) - Method in interface org.apache.cassandra.cql3.CQLStatement
Perform additional validation required by the statment.
validate() - Method in class org.apache.cassandra.cql3.KSPropDefs
 
validate(Set<String>, Set<String>) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
The CqlParser only goes as far as extracting the keyword arguments from these statements, so this method is responsible for processing and validating.
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.GrantStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListGrantsStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.RevokeStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.UseStatement
 
validate(Column) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
 
validate(Column) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
 
validate(Column) - Method in class org.apache.cassandra.db.index.SecondaryIndex
 
validate(Column) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
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.BooleanType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DateType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
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.ReversedType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
validate(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
validateColumn(CFMetaData, ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.cql.QueryProcessor
 
validateColumnData(CFMetaData, Column, boolean) - Static method in class org.apache.cassandra.thrift.ThriftValidation
Validates the data part of the column (everything in the Column object but the name, which is assumed to be valid)
validateColumnFamily(String, String) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
Validate that keyspace is an existing keyspace and cfName one of its existing column family.
validateColumnFamily(String, String, boolean) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateColumnFamily(String, String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateColumnFields() - Method in class org.apache.cassandra.db.ColumnFamily
Goes over all columns and check the fields are valid (as far as we can tell).
validateColumnName(ByteBuffer) - Static method in class org.apache.cassandra.cql.QueryProcessor
 
validateColumnName(ByteBuffer) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
validateColumnNames(Iterable<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
validateColumnNames(CFMetaData, ColumnParent, Iterable<ByteBuffer>) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateColumnOrSuperColumn(CFMetaData, ColumnOrSuperColumn) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateColumnParent(CFMetaData, ColumnParent) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateColumnPath(CFMetaData, ColumnPath) - Static method in class org.apache.cassandra.thrift.ThriftValidation
validates all parts of the path to the column, including the column name
validateCommutativeForWrite(CFMetaData, ConsistencyLevel) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllAuthority
 
validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthenticator
 
validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthority
 
validateConsistencyLevel(String, ConsistencyLevel, RequestType) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateContext(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
 
validateCurrentFile(String) - Method in class org.apache.cassandra.streaming.StreamOutSession
 
validateDeletion(CFMetaData, Deletion) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.Column
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.CounterColumn
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.DeletedColumn
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.ExpiringColumn
 
validateFields(CFMetaData) - Method in interface org.apache.cassandra.db.IColumn
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.SuperColumn
 
validateFilterClauses(CFMetaData, List<IndexExpression>) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateIndexClauses(CFMetaData, IndexClause) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateKey(ByteBuffer) - Static method in class org.apache.cassandra.cql.QueryProcessor
 
validateKey(ByteBuffer) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
validateKey(CFMetaData, ByteBuffer) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateKeyAlias(CFMetaData, String) - Static method in class org.apache.cassandra.cql.QueryProcessor
 
validateKeyRange(CFMetaData, ByteBuffer, KeyRange) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateKeyspaceNotSystem(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateKeyspaceNotYetExisting(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateMagic(int) - Static method in class org.apache.cassandra.net.MessagingService
 
validateMemtableOperations(double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
validateMemtableThroughput(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
validateMinusSupplied(Object, Term, IntStream) - Method in class org.apache.cassandra.cql.CqlParser
 
validateMinusSupplied(Object, Term, IntStream) - Method in class org.apache.cassandra.cql3.CqlParser
 
validateMutation(CFMetaData, Mutation) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateName(CFMetaData) - Method in class org.apache.cassandra.db.Column
 
validateNextComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
validateNextComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
validateNextComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
validateOptions() - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
validateOptions() - Method in class org.apache.cassandra.db.index.SecondaryIndex
Validates the index_options passed in the ColumnDef
validateOptions() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
validateOptions() - Method in class org.apache.cassandra.locator.LocalStrategy
 
validateOptions() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
validateOptions() - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
 
validateOptions() - Method in class org.apache.cassandra.locator.SimpleStrategy
 
validatePredicate(CFMetaData, ColumnParent, SlicePredicate) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateRange(CFMetaData, ColumnParent, SliceRange) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateReplicationFactor(String) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
validateSlicePredicate(CFMetaData, SlicePredicate) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
validateSlicePredicate(CFMetaData, ByteBuffer, SlicePredicate) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateSliceRange(CFMetaData, SliceRange) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
validateSliceRange(CFMetaData, ByteBuffer, ByteBuffer, boolean) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
validateTable(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validation_class - Variable in class org.apache.cassandra.db.migration.avro.ColumnDef
 
validator - Variable in class org.apache.cassandra.cql.AlterTableStatement
 
validator - Variable in class org.apache.cassandra.cql3.statements.AlterTableStatement
 
validBufferBytes - Variable in class org.apache.cassandra.io.util.RandomAccessReader
 
validBufferBytes - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
value() - Method in class org.apache.cassandra.cli.CliParser
 
value - Variable in class org.apache.cassandra.cql3.CFDefinition
 
value - Variable in class org.apache.cassandra.cql3.Operation
 
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 - Variable in class org.apache.cassandra.db.marshal.AbstractCompositeType.CompositeComponent
 
value() - Method in class org.apache.cassandra.db.SuperColumn
 
value - Variable in class org.apache.cassandra.gms.VersionedValue
 
value() - Method in class org.apache.cassandra.utils.DefaultDouble
 
value() - Method in class org.apache.cassandra.utils.DefaultInteger
 
value_alias - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
valueAlias(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
 
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.cli.CliClient.ColumnFamilyArgument
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cli.CliClient.Function
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.concurrent.Stage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.CFMetaData.Caching
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.Config.CommitLogSync
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.Config.DiskAccessMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.Config.RequestSchedulerId
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.EncryptionOptions.InternodeEncryption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cql.AlterTableStatement.OperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cql.Operation.OperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cql.StatementType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cql3.CFDefinition.Name.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cql3.Operation.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cql3.Relation.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.AlterTableStatement.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.Selector.Function
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.ColumnFamilyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.compaction.OperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.context.IContext.ContextRelationship
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.migration.avro.IndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.RowPosition.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.SystemTable.BootstrapState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.gms.ApplicationState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.io.IColumnSerializer.Flag
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.CacheService.CacheType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.service.StorageService.Verb
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.streaming.OperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.thrift.RequestType
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.cli.CliClient.ColumnFamilyArgument
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.cli.CliClient.Function
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.concurrent.Stage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.config.CFMetaData.Caching
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.config.Config.CommitLogSync
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.config.Config.DiskAccessMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.config.Config.RequestSchedulerId
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.config.EncryptionOptions.InternodeEncryption
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.cql.AlterTableStatement.OperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.cql.Operation.OperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.cql.StatementType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.cql3.CFDefinition.Name.Kind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.cql3.Operation.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.cql3.Relation.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.cql3.statements.AlterTableStatement.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.cql3.statements.Selector.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.db.ColumnFamilyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.db.compaction.OperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.db.context.IContext.ContextRelationship
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.db.migration.avro.IndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.db.RowPosition.Kind
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.SystemTable.BootstrapState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.gms.ApplicationState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.io.IColumnSerializer.Flag
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.CacheService.CacheType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.service.StorageService.Verb
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.streaming.OperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.thrift.RequestType
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
 
verifyNoHintsInProgress() - Method in class org.apache.cassandra.service.StorageProxy
 
version - Variable in class org.apache.cassandra.gms.VersionedValue
 
version - Variable in class org.apache.cassandra.io.sstable.Descriptor
version has the following format: [a-z]+
version_ - Static variable in class org.apache.cassandra.net.MessagingService
 
VERSION_07 - Static variable in class org.apache.cassandra.net.MessagingService
 
VERSION_080 - Static variable in class org.apache.cassandra.net.MessagingService
 
VERSION_10 - Static variable in class org.apache.cassandra.net.MessagingService
 
VERSION_11 - Static variable in class org.apache.cassandra.net.MessagingService
 
VERSION_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
VersionCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
VersionedValue - Class in org.apache.cassandra.gms
This abstraction represents the state associated with a particular node which an application wants to make available to the rest of the nodes in the cluster.
VersionedValue.VersionedValueFactory - Class in org.apache.cassandra.gms
 
VersionedValue.VersionedValueFactory(IPartitioner) - Constructor for class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
VersionGenerator - Class in org.apache.cassandra.gms
A unique version number generator for any state that is generated by the local node.
VersionGenerator() - Constructor for class org.apache.cassandra.gms.VersionGenerator
 

W

W - Static variable in class org.apache.cassandra.cql.CqlLexer
 
W - Static variable in class org.apache.cassandra.cql.CqlParser
 
W - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
W - Static variable in class org.apache.cassandra.cql3.CqlParser
 
waitForDeletions() - Static method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
for tests
waitForStreaming() - Method in class org.apache.cassandra.net.MessagingService
 
waitingFor(Message) - Method in class org.apache.cassandra.service.DatacenterReadCallback
 
waitingFor(ReadResponse) - Method in class org.apache.cassandra.service.DatacenterReadCallback
 
waitingFor(Message) - Method in class org.apache.cassandra.service.ReadCallback
 
waitingFor(ReadResponse) - Method in class org.apache.cassandra.service.ReadCallback
 
waitOnFuture(Future<?>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
waitOnFutures(Iterable<Future<?>>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
waitOnFutures(List<IAsyncResult>, long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
waitOnFutures(List<CreationTimeAwareFuture<?>>, long, TimeUnit) - Static method in class org.apache.cassandra.utils.FBUtilities
Waits for the futures to complete.
waitUntilListening() - Method in class org.apache.cassandra.net.MessagingService
 
wakeupSelector() - Method in class org.apache.cassandra.thrift.CustomTHsHaServer.SelectorThread
 
warn(String) - Method in class org.apache.cassandra.utils.OutputHandler.LogOutput
 
warn(String, Throwable) - Method in class org.apache.cassandra.utils.OutputHandler.LogOutput
 
warn(String) - Method in class org.apache.cassandra.utils.OutputHandler.SystemOutput
 
warn(String, Throwable) - Method in class org.apache.cassandra.utils.OutputHandler.SystemOutput
 
warn(String) - Method in interface org.apache.cassandra.utils.OutputHandler
 
warn(String, Throwable) - Method in interface org.apache.cassandra.utils.OutputHandler
 
warnOnUnexpectedOptions(Collection<String>) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
watch(String, Runnable, int) - Static method in class org.apache.cassandra.utils.ResourceWatcher
 
WeightedQueueMBean - Interface in org.apache.cassandra.scheduler
Exposes client request scheduling metrics for a particular scheduler queue.
weightedSize() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
weightedSize() - Method in interface org.apache.cassandra.cache.ICache
 
weightedSize() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
weightedSize() - Method in class org.apache.cassandra.cache.SerializingCache
 
weights - Variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
whereClause() - Method in class org.apache.cassandra.cql.CqlParser
 
WhereClause - Class in org.apache.cassandra.cql
WhereClauses encapsulate all of the predicates of a SELECT query.
WhereClause(Relation) - Constructor for class org.apache.cassandra.cql.WhereClause
Create a new WhereClause with the first parsed relation.
WhereClause() - Constructor for class org.apache.cassandra.cql.WhereClause
 
whereClause() - Method in class org.apache.cassandra.cql3.CqlParser
 
width - Variable in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
WITH - Static variable in class org.apache.cassandra.cli.CliLexer
 
WITH - Static variable in class org.apache.cassandra.cli.CliParser
 
withGeneration(int) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
withHeaderAdded(String, byte[]) - Method in class org.apache.cassandra.net.Message
 
withHeaderRemoved(String) - Method in class org.apache.cassandra.net.Message
 
wrap(ByteBuffer) - Static method in class org.apache.cassandra.utils.NodeId
 
wrap(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.NodeId
 
wrapCharArray(char[]) - Static method in class org.apache.cassandra.utils.Hex
Create a String from a char array with zero-copy (if available), using reflection to access a package-protected constructor of String.
WrappedRunnable - Class in org.apache.cassandra.utils
 
WrappedRunnable() - Constructor for class org.apache.cassandra.utils.WrappedRunnable
 
write(DataOutputStream) - Method in interface org.apache.cassandra.cache.CacheKey
 
write(DataOutputStream) - Method in class org.apache.cassandra.cache.KeyCacheKey
 
write(DataOutputStream) - Method in class org.apache.cassandra.cache.RowCacheKey
 
write(RowMutation) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
Appends a row mutation onto the commit log.
write(DataOutput) - Method in class org.apache.cassandra.db.compaction.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.db.compaction.LazilyCompactedRow
 
write(DataOutput) - Method in class org.apache.cassandra.db.compaction.PrecompactedRow
 
write(DataOutput) - Method in class org.apache.cassandra.db.EchoedRow
 
write(DataOutput) - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
write(int) - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
write(byte[], int, int) - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
write(byte[], int, int) - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
Writes count bytes from the byte array buffer starting at offset index to this stream.
write(int) - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
Writes the specified byte oneByte to the OutputStream.
write(int) - Method in class org.apache.cassandra.io.util.MemoryOutputStream
 
write(byte[], int, int) - Method in class org.apache.cassandra.io.util.MemoryOutputStream
 
write(int) - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
write(byte[]) - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
write(byte[], int, int) - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
write(int) - Method in class org.apache.cassandra.io.util.SequentialWriter
 
write(byte[]) - Method in class org.apache.cassandra.io.util.SequentialWriter
 
write(byte[], int, int) - Method in class org.apache.cassandra.io.util.SequentialWriter
 
write(Message, String, DataOutputStream) - Static method in class org.apache.cassandra.net.OutboundTcpConnection
 
write(RandomAccessReader, long, long) - Method in class org.apache.cassandra.streaming.FileStreamTask
Sequentially read bytes from the file and write them to the output stream
write(ByteBuffer, DataOutput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
write(UUID, DataOutput) - Static method in class org.apache.cassandra.utils.UUIDGen
writes a uuid to an output stream.
writeBinary(ByteBuffer) - Method in class org.apache.cassandra.thrift.TBinaryProtocol
 
writeCurrentLocalNodeId(NodeId, NodeId, long) - Static method in class org.apache.cassandra.db.SystemTable
Write a new current local node id to the system table.
writeElement(NodeId, long, long, boolean) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
writeElement(NodeId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
writeEndpoints - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
writeHeader(CompressionParameters) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
WriteResponse - Class in org.apache.cassandra.db
 
WriteResponse(String, ByteBuffer, boolean) - Constructor for class org.apache.cassandra.db.WriteResponse
 
WriteResponse.WriteResponseSerializer - Class in org.apache.cassandra.db
 
WriteResponse.WriteResponseSerializer() - Constructor for class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
 
WriteResponseHandler - Class in org.apache.cassandra.service
Handles blocking writes for ONE, ANY, TWO, THREE, QUORUM, and ALL consistency levels.
WriteResponseHandler(Collection<InetAddress>, ConsistencyLevel, String, Runnable) - Constructor for class org.apache.cassandra.service.WriteResponseHandler
 
WriteResponseHandler(InetAddress) - Constructor for class org.apache.cassandra.service.WriteResponseHandler
 
writeRow(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
writeRow(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
 
writeRow(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.io.sstable.SSTableSimpleWriter
 
writeTimeouts - Static variable in class org.apache.cassandra.metrics.ClientRequestMetrics
 
writeTo(OutputStream) - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
Takes the contents of this stream and writes it to the output stream out.
writeUnavailables - Static variable in class org.apache.cassandra.metrics.ClientRequestMetrics
 
writeWithLength(ByteBuffer, DataOutput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
writeWithLength(byte[], DataOutput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
writeWithShortLength(ByteBuffer, DataOutput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
WS - Static variable in class org.apache.cassandra.cli.CliLexer
 
WS - Static variable in class org.apache.cassandra.cli.CliParser
 
WS - Static variable in class org.apache.cassandra.cql.CqlLexer
 
WS - Static variable in class org.apache.cassandra.cql.CqlParser
 
WS - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
WS - Static variable in class org.apache.cassandra.cql3.CqlParser
 

X

X - Static variable in class org.apache.cassandra.cql.CqlLexer
 
X - Static variable in class org.apache.cassandra.cql.CqlParser
 
X - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
X - Static variable in class org.apache.cassandra.cql3.CqlParser
 
xor(byte[], byte[]) - Static method in class org.apache.cassandra.utils.FBUtilities
 

Y

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

Z

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

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

Copyright © 2012 The Apache Software Foundation