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
 
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
 
AbstractCassandraStorage - Class in org.apache.cassandra.hadoop.pig
A LoadStoreFunc for retrieving data from and storing data to Cassandra
AbstractCassandraStorage() - Constructor for class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
AbstractCassandraStorage.MarshallerType - Enum in org.apache.cassandra.hadoop.pig
 
AbstractColumnContainer - Class in org.apache.cassandra.db
 
AbstractColumnContainer(ISortedColumns) - Constructor for class org.apache.cassandra.db.AbstractColumnContainer
 
AbstractColumnFamilyInputFormat<K,Y> - Class in org.apache.cassandra.hadoop
 
AbstractColumnFamilyInputFormat() - Constructor for class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
 
AbstractColumnFamilyOutputFormat<K,Y> - 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.
AbstractColumnFamilyOutputFormat() - Constructor for class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
 
AbstractColumnFamilyRecordWriter<K,Y> - Class in org.apache.cassandra.hadoop
The ColumnFamilyRecordWriter maps the output <key, value> pairs to a Cassandra column family.
AbstractColumnFamilyRecordWriter(Configuration) - Constructor for class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
 
AbstractColumnFamilyRecordWriter.AbstractRangeClient<K> - Class in org.apache.cassandra.hadoop
A client that runs in a threadpool and connects to the list of endpoints for a particular range.
AbstractColumnFamilyRecordWriter.AbstractRangeClient(List<InetAddress>) - Constructor for class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
Constructs an AbstractColumnFamilyRecordWriter.AbstractRangeClient for the given endpoints.
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
 
AbstractDataOutput - Class in org.apache.cassandra.io.util
 
AbstractDataOutput() - Constructor for class org.apache.cassandra.io.util.AbstractDataOutput
 
AbstractEndpointSnitch - Class in org.apache.cassandra.locator
 
AbstractEndpointSnitch() - Constructor for class org.apache.cassandra.locator.AbstractEndpointSnitch
 
AbstractFunction - Class in org.apache.cassandra.cql3.functions
 
AbstractFunction(String, AbstractType<?>, AbstractType<?>...) - Constructor for class org.apache.cassandra.cql3.functions.AbstractFunction
 
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
 
AbstractJmxClient - Class in org.apache.cassandra.tools
 
AbstractJmxClient(String, Integer, String, String) - Constructor for class org.apache.cassandra.tools.AbstractJmxClient
 
AbstractMarker - Class in org.apache.cassandra.cql3
A single bind marker.
AbstractMarker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.AbstractMarker
 
AbstractMarker.Raw - Class in org.apache.cassandra.cql3
A parsed, but non prepared, bind marker.
AbstractMarker.Raw(int) - Constructor for class org.apache.cassandra.cql3.AbstractMarker.Raw
 
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
 
AbstractSimplePerColumnSecondaryIndex - Class in org.apache.cassandra.db.index
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.
AbstractSimplePerColumnSecondaryIndex() - Constructor for class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
AbstractSSTableSimpleWriter - Class in org.apache.cassandra.io.sstable
 
AbstractSSTableSimpleWriter(File, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
AbstractStreamSession - Class in org.apache.cassandra.streaming
 
AbstractStreamSession(String, InetAddress, UUID, 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(Table, Collection<InetAddress>, Collection<InetAddress>, ConsistencyLevel, Runnable, WriteType) - 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
 
ackCount() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
ackCount() - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
ackCount() - Method in class org.apache.cassandra.service.WriteResponseHandler
 
acquireReference() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
acquireReferences(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
action - Variable in class org.apache.cassandra.streaming.StreamReply
 
activate() - Method in class 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.
activeStreamsOutbound - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
 
activeTasks - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
Number of active tasks.
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(ByteBuffer, Relation.Type) - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
Add a new ByteBuffer as the next component for this name.
add(IColumn) - Method in class org.apache.cassandra.cql3.statements.ColumnGroupMap.Builder
 
add(ByteBuffer) - Method in class org.apache.cassandra.cql3.statements.Selection.ResultSetBuilder
 
add(IColumn) - Method in class org.apache.cassandra.cql3.statements.Selection.ResultSetBuilder
 
add(OnDiskAtom) - Method in class org.apache.cassandra.db.ColumnIndex.Builder
 
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(DeletionTime) - Method in class org.apache.cassandra.db.DeletionInfo
 
add(RangeTombstone, Comparator<ByteBuffer>) - Method in class org.apache.cassandra.db.DeletionInfo
 
add(DeletionInfo) - Method in class org.apache.cassandra.db.DeletionInfo
Adds the provided deletion infos to the current ones.
add(ByteBuffer, Relation.Type) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
add(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
add(RangeTombstone) - Method in class org.apache.cassandra.db.RangeTombstoneList
 
add(ByteBuffer, ByteBuffer, long, int) - Method in class org.apache.cassandra.db.RangeTombstoneList
Adds a new range tombstone.
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(ChannelBuffer) - Method in class org.apache.cassandra.transport.CBUtil.BufferBuilder
 
add(ByteBuffer) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
 
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 interface org.apache.cassandra.utils.IFilter
 
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.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(RangeTombstoneList) - Method in class org.apache.cassandra.db.RangeTombstoneList
Adds all the range tombstones of tombstones to this RangeTombstoneList.
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>, SecondaryIndexManager.Updater) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
addAllWithSizeDelta(ISortedColumns, Allocator, Function<IColumn, IColumn>, SecondaryIndexManager.Updater) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
addAllWithSizeDelta(ISortedColumns, Allocator, Function<IColumn, IColumn>, SecondaryIndexManager.Updater) - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
addAllWithSizeDelta(ISortedColumns, Allocator, Function<IColumn, IColumn>, SecondaryIndexManager.Updater) - 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>, SecondaryIndexManager.Updater) - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
addAllWithSizeDelta(ISortedColumns, Allocator, Function<IColumn, IColumn>, SecondaryIndexManager.Updater) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
addAncestor(int) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
addAtom(OnDiskAtom) - Method in class org.apache.cassandra.db.ColumnFamily
 
addBootstrapToken(Token, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
Deprecated.
addBootstrapTokens(Collection<Token>, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
addCallback(IMessageCallback, MessageOut, InetAddress, long) - Method in class org.apache.cassandra.net.MessagingService
 
addCmdOption(String, String, boolean, String) - Static method in class org.apache.cassandra.tools.AbstractJmxClient
 
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(IColumn, Allocator, SecondaryIndexManager.Updater) - 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).
addColumn(ColumnFamily, ByteBuffer, InetAddress) - Static method in class org.apache.cassandra.tracing.Tracing
 
addColumn(ColumnFamily, ByteBuffer, int) - Static method in class org.apache.cassandra.tracing.Tracing
 
addColumn(ColumnFamily, ByteBuffer, long) - Static method in class org.apache.cassandra.tracing.Tracing
 
addColumn(ColumnFamily, ByteBuffer, String) - Static method in class org.apache.cassandra.tracing.Tracing
 
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
 
addColumnValue(ByteBuffer) - Method in class org.apache.cassandra.cql3.ResultSet
 
addComponents(Collection<Component>) - Method in class org.apache.cassandra.io.sstable.SSTable
Registers new custom components.
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
addConnection(Channel, Connection) - Method in interface org.apache.cassandra.transport.Connection.Tracker
 
addConnection(Channel, Connection) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
 
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, CQL3Type) - 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
 
addEndpoint(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
Stores current DC/rack assignment for ep
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.Raw) - Method in class org.apache.cassandra.cql3.Relation
 
addKeyAliases(List<ColumnIdentifier>) - Method in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement.RawStatement
 
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, long) - 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.metrics.LatencyMetrics
 
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.metrics.LatencyMetrics
takes nanoseconds
addNano(long) - Method in class org.apache.cassandra.utils.LatencyTracker
takes nanoseconds
addOldCfIdMapping(Integer, UUID) - Method in class org.apache.cassandra.config.Schema
 
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
 
addOrGet(CFMetaData) - Method in class org.apache.cassandra.db.RowMutation
 
addParameterColumns(ColumnFamily, Map<String, String>) - Method in class org.apache.cassandra.tracing.Tracing
 
addPotentialBoundary(long) - Method in class org.apache.cassandra.io.util.BufferedPoolingSegmentedFile.Builder
 
addPotentialBoundary(long) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile.Builder
 
addPotentialBoundary(long) - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile.Builder
 
addPotentialBoundary(long) - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile.Builder
 
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.PropertyDefinitions
 
addProperty(String, Map<String, String>) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
 
addr - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
 
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
 
addRawUpdate(List<Pair<ColumnIdentifier, Operation.RawUpdate>>, ColumnIdentifier, Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.CqlParser
 
addRecognitionError(String) - Method in class org.apache.cassandra.cql3.CqlParser
 
addRelocatingTokens(Collection<Token>, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
Add new relocating ranges (tokens moving from their respective endpoints, to another).
address - Variable in class org.apache.cassandra.dht.BootStrapper
 
address - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
 
addRow(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.ResultSet
 
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
 
addString(String) - Method in class org.apache.cassandra.transport.CBUtil.BufferBuilder
 
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
 
addToVersion(int) - Method in enum org.apache.cassandra.transport.Message.Direction
 
addTruePositive() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
addValue(ByteBuffer) - Method in class org.apache.cassandra.transport.CBUtil.BufferBuilder
 
advance() - Method in class org.apache.cassandra.utils.MergeIterator.Candidate
 
advertiseRemoving(InetAddress, UUID, UUID) - 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, UUID) - 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
affectedColumn() - Method in class org.apache.cassandra.cql3.Operation.ColumnDeletion
 
affectedColumn() - Method in class org.apache.cassandra.cql3.Operation.ElementDeletion
 
affectedColumn() - Method in interface org.apache.cassandra.cql3.Operation.RawDeletion
The name of the column affected by this delete operation.
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.transport.RequestThreadPoolExecutor
 
algorithm - Variable in class org.apache.cassandra.config.EncryptionOptions
 
alive - Variable in exception org.apache.cassandra.exceptions.UnavailableException
 
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
 
ALL_COLUMNS - Static variable in class org.apache.cassandra.db.filter.ColumnSlice
 
ALL_COLUMNS_ARRAY - Static variable in class org.apache.cassandra.db.filter.ColumnSlice
 
ALL_DATA - Static variable in enum org.apache.cassandra.auth.Permission
 
allChannels - Variable in class org.apache.cassandra.transport.Server.ConnectionTracker
 
allIndexesNames() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
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
 
AllowAllAuthorizer - Class in org.apache.cassandra.auth
 
AllowAllAuthorizer() - Constructor for class org.apache.cassandra.auth.AllowAllAuthorizer
 
AllowAllInternodeAuthenticator - Class in org.apache.cassandra.auth
 
AllowAllInternodeAuthenticator() - Constructor for class org.apache.cassandra.auth.AllowAllInternodeAuthenticator
 
allowedKeywords - Static variable in class org.apache.cassandra.cql.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
 
AlreadyExistsException - Exception in org.apache.cassandra.exceptions
 
AlreadyExistsException(String, String) - Constructor for exception org.apache.cassandra.exceptions.AlreadyExistsException
 
AlreadyExistsException(String) - Constructor for exception org.apache.cassandra.exceptions.AlreadyExistsException
 
alter(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
alter(String, Map<IAuthenticator.Option, Object>) - Method in interface org.apache.cassandra.auth.IAuthenticator
Called during execution of ALTER USER query.
alter(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.LegacyAuthenticator
 
alter(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
alterableOptions() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
alterableOptions() - Method in interface org.apache.cassandra.auth.IAuthenticator
Subset of supportedOptions that users are allowed to alter when performing ALTER USER [themselves].
alterableOptions() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
 
alterableOptions() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
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, CQL3Type, CFPropDefs, Map<ColumnIdentifier, ColumnIdentifier>) - 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
 
alterUserStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
AlterUserStatement - Class in org.apache.cassandra.cql3.statements
 
AlterUserStatement(String, UserOptions, Boolean) - Constructor for class org.apache.cassandra.cql3.statements.AlterUserStatement
 
alwaysMatchingBloomFilter() - Static method in class org.apache.cassandra.utils.LegacyBloomFilter
 
AlwaysPresentFilter - Class in org.apache.cassandra.utils
 
AlwaysPresentFilter() - Constructor for class org.apache.cassandra.utils.AlwaysPresentFilter
 
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
 
announceNewKeyspace(KSMetaData, long) - Static method in class org.apache.cassandra.service.MigrationManager
 
ANONYMOUS_USER - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
 
ANONYMOUS_USERNAME - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
 
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.Status - Enum in org.apache.cassandra.service
 
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.TreeRequest.TreeRequestSerializer - Class in org.apache.cassandra.service
 
AntiEntropyService.TreeRequest.TreeRequestSerializer() - Constructor for class org.apache.cassandra.service.AntiEntropyService.TreeRequest.TreeRequestSerializer
 
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
 
AntiEntropyService.Validator.ValidatorSerializer - Class in org.apache.cassandra.service
 
AntiEntropyService.Validator.ValidatorSerializer() - Constructor for class org.apache.cassandra.service.AntiEntropyService.Validator.ValidatorSerializer
 
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
 
appendFromStream(DecoratedKey, CFMetaData, long, DataInput) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
appendTOC(Descriptor, Collection<Component>) - Static method in class org.apache.cassandra.io.sstable.SSTable
Appends new component names to the TOC component.
appendToStringBuilder(StringBuilder) - Method in class org.apache.cassandra.db.marshal.CollectionType
 
appendToStringBuilder(StringBuilder) - Method in class org.apache.cassandra.db.marshal.ListType
 
appendToStringBuilder(StringBuilder) - Method in class org.apache.cassandra.db.marshal.MapType
 
appendToStringBuilder(StringBuilder) - Method in class org.apache.cassandra.db.marshal.SetType
 
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, SecondaryIndexManager.Updater) - 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 appends a row to the global CommitLog, then updates memtables and indexes.
apply(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader.Operator
 
apply(IMutation, Iterable<InetAddress>, AbstractWriteResponseHandler, 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.
applyPropertiesTo(CFMetaData) - Method in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement
 
applyPropertiesToCFMetadata(CFMetaData, CFPropDefs) - Static method in class org.apache.cassandra.cql.AlterTableStatement
 
applyStateTransition(Message.Type, Message.Type) - Method in class org.apache.cassandra.transport.ServerConnection
 
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
 
args - Variable in class org.apache.cassandra.cql3.statements.RawSelector.WithFunction
 
argsType - Variable in class org.apache.cassandra.cql3.functions.AbstractFunction
 
argsType() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
argsType() - Method in interface org.apache.cassandra.cql3.functions.Function
 
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.
AsciiType - Class in org.apache.cassandra.db.marshal
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.AsciiType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.BooleanType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.BytesType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.CollectionType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.DateType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.DecimalType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.DoubleType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.FloatType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.InetAddressType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.Int32Type
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.IntegerType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.LongType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.ReversedType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.UUIDType
 
asIFilter(SlicePredicate, AbstractType<?>) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
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
 
AssignementTestable - Interface in org.apache.cassandra.cql3
 
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(Table, Iterable<InetAddress>) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.ReadCallback
 
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(RowDataResolver, int) - Constructor for class org.apache.cassandra.service.AsyncRepairCallback
 
atomic_batch_mutate(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
AtomicSortedColumns - Class in org.apache.cassandra.db
A thread-safe and atomic ISortedColumns implementation.
attach(Connection) - Method in class org.apache.cassandra.transport.Message
 
attempted - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
 
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
 
Auth - Class in org.apache.cassandra.auth
 
Auth() - Constructor for class org.apache.cassandra.auth.Auth
 
Auth.MigrationListener - Class in org.apache.cassandra.auth
IMigrationListener implementation that cleans up permissions on dropped resources.
Auth.MigrationListener() - Constructor for class org.apache.cassandra.auth.Auth.MigrationListener
 
AUTH_KS - Static variable in class org.apache.cassandra.auth.Auth
 
authenticate(Map<String, String>) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
authenticate(InetAddress, int) - Method in class org.apache.cassandra.auth.AllowAllInternodeAuthenticator
 
authenticate(Map<String, String>) - Method in interface org.apache.cassandra.auth.IAuthenticator
Authenticates a user given a Map of credentials.
authenticate(InetAddress, int) - Method in interface org.apache.cassandra.auth.IInternodeAuthenticator
Decides whether or not a peer is allowed to connect to this node.
authenticate(Map<String, String>) - Method in class org.apache.cassandra.auth.LegacyAuthenticator
 
authenticate(Map<String, String>) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
AuthenticatedUser - Class in org.apache.cassandra.auth
Returned from IAuthenticator#authenticate(), represents an authenticated user everywhere internally.
AuthenticatedUser(String) - Constructor for class org.apache.cassandra.auth.AuthenticatedUser
 
AuthenticateMessage - Class in org.apache.cassandra.transport.messages
Message to indicate that the server is ready to receive requests.
AuthenticateMessage(String) - Constructor for class org.apache.cassandra.transport.messages.AuthenticateMessage
 
AuthenticationException - Exception in org.apache.cassandra.exceptions
 
AuthenticationException(String) - Constructor for exception org.apache.cassandra.exceptions.AuthenticationException
 
AuthenticationStatement - Class in org.apache.cassandra.cql3.statements
 
AuthenticationStatement() - Constructor for class org.apache.cassandra.cql3.statements.AuthenticationStatement
 
authenticator - Variable in class org.apache.cassandra.config.Config
 
authenticator - Variable in class org.apache.cassandra.transport.messages.AuthenticateMessage
 
authority - Variable in class org.apache.cassandra.config.Config
 
AuthorizationStatement - Class in org.apache.cassandra.cql3.statements
 
AuthorizationStatement() - Constructor for class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
authorize(AuthenticatedUser, IResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
authorize(AuthenticatedUser, IResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
authorize(AuthenticatedUser, IResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
The primary IAuthorizer method.
authorize(AuthenticatedUser, List<Object>) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
 
authorize(AuthenticatedUser, IResource) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
Translates new-style authorize() method call to the old-style (including permissions and the hierarchy).
authorizer - Variable in class org.apache.cassandra.config.Config
 
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, AutoSavingCache.CacheSerializer<K, V>) - Constructor for class org.apache.cassandra.cache.AutoSavingCache
 
AutoSavingCache.CacheSerializer<K extends CacheKey,V> - Interface in org.apache.cassandra.cache
 
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.
available() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
 
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
 
baseFilename() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
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.AbstractColumnFamilyOutputFormat
 
BATCHLOG_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
BatchlogCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
BatchlogManager - Class in org.apache.cassandra.db
 
BatchlogManager() - Constructor for class org.apache.cassandra.db.BatchlogManager
 
BatchlogManagerMBean - Interface in org.apache.cassandra.db
 
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(ModificationStatement.Type, 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
 
batchThreshold - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
 
beforeExecute(Thread, Runnable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
begin() - Method in class org.apache.cassandra.streaming.StreamOutSession
 
begin(String, Map<String, String>) - Method in class org.apache.cassandra.tracing.Tracing
 
beginCompaction(CompactionInfo.Holder) - Method in interface org.apache.cassandra.db.compaction.CompactionManager.CompactionExecutorStatsCollector
 
beginCompaction(CompactionInfo.Holder) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.StatsCollector
 
beginCompaction(CompactionInfo.Holder) - Method in class org.apache.cassandra.metrics.CompactionMetrics
 
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
 
BiMultiValMap<K,V> - Class in org.apache.cassandra.utils
A variant of BiMap which does not enforce uniqueness of values.
BiMultiValMap() - Constructor for class org.apache.cassandra.utils.BiMultiValMap
 
BiMultiValMap(Map<K, V>, Multimap<V, K>) - Constructor for class org.apache.cassandra.utils.BiMultiValMap
 
BiMultiValMap(BiMultiValMap<K, V>) - Constructor for class org.apache.cassandra.utils.BiMultiValMap
 
binarySearch(RowPosition) - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
bind(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.Constants.Marker
 
bind(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.FunctionCall
 
bind(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.Lists.DelayedValue
 
bind(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.Lists.Marker
 
bind(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.Maps.DelayedValue
 
bind(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.Maps.Marker
 
bind(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.Sets.DelayedValue
 
bind(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.Sets.Marker
 
bind(List<ByteBuffer>) - Method in interface org.apache.cassandra.cql3.Term
Bind the values in this term to the values contained in values.
bind(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.Term.Terminal
 
bindAndGet(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.Constants.Marker
 
bindAndGet(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.Constants.Value
 
bindAndGet(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.FunctionCall
 
bindAndGet(List<ByteBuffer>) - Method in interface org.apache.cassandra.cql3.Term
A shorter for bind(values).get().
bindAndGet(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.Term.NonTerminal
 
bindAndGet(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.Term.Terminal
 
bindIndex - Variable in class org.apache.cassandra.cql3.AbstractMarker
 
bindIndex - Variable in class org.apache.cassandra.cql3.AbstractMarker.Raw
 
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
 
BlacklistedDirectories - Class in org.apache.cassandra.db
 
BlacklistedDirectoriesMBean - Interface in org.apache.cassandra.db
 
BlobAsVarcharFact - Static variable in class org.apache.cassandra.cql3.functions.BytesConversionFcts
 
blockFor(Table) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
blockFor - Variable in exception org.apache.cassandra.exceptions.RequestTimeoutException
 
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 - Class in org.apache.cassandra.utils
 
bloomFilterDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Disk space used by bloom filter
bloomFilterFalsePositives - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Number of false positives in bloom filter
bloomFilterFalseRatio - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
False positive ratio of bloom filter
bloomFilterFpChance(Double) - Method in class org.apache.cassandra.config.CFMetaData
 
BloomFilterTracker - Class in org.apache.cassandra.io.sstable
 
BloomFilterTracker() - Constructor for class org.apache.cassandra.io.sstable.BloomFilterTracker
 
body - Variable in class org.apache.cassandra.transport.Frame
 
bool(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
 
BOOLEAN - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
BOOLEAN - Static variable in class org.apache.cassandra.cql3.CqlParser
 
BooleanType - Class in org.apache.cassandra.db.marshal
 
bootstrap() - Method in class org.apache.cassandra.dht.BootStrapper
 
bootstrap - Variable in class org.apache.cassandra.transport.SimpleClient
 
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, Collection<Token>, TokenMetadata) - Constructor for class org.apache.cassandra.dht.BootStrapper
 
BootStrapper.BootstrapTokenVerbHandler - Class in org.apache.cassandra.dht
Deprecated.
BootStrapper.BootstrapTokenVerbHandler() - Constructor for class org.apache.cassandra.dht.BootStrapper.BootstrapTokenVerbHandler
Deprecated.
 
BootStrapper.StringSerializer - Class in org.apache.cassandra.dht
 
BootStrapper.StringSerializer() - Constructor for class org.apache.cassandra.dht.BootStrapper.StringSerializer
 
bootstrapping(Collection<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
 
BUCKET_HIGH_KEY - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
BUCKET_LOW_KEY - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
bucketHigh - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
bucketLow - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
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
 
BufferedPoolingSegmentedFile - Class in org.apache.cassandra.io.util
 
BufferedPoolingSegmentedFile(String, long) - Constructor for class org.apache.cassandra.io.util.BufferedPoolingSegmentedFile
 
BufferedPoolingSegmentedFile.Builder - Class in org.apache.cassandra.io.util
 
BufferedPoolingSegmentedFile.Builder() - Constructor for class org.apache.cassandra.io.util.BufferedPoolingSegmentedFile.Builder
 
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
 
bufferOffset - Variable in class org.apache.cassandra.streaming.compress.CompressedInputStream
 
build() - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
Build the column name.
build() - Method in class org.apache.cassandra.cql3.statements.Selection.ResultSetBuilder
 
build(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnIndex.Builder
Serializes the index into in-memory structure with all required components such as Bloom Filter, index block size, IndexInfo list
build(Iterable<OnDiskAtom>) - Method in class org.apache.cassandra.db.ColumnIndex.Builder
 
build() - Method in class org.apache.cassandra.db.ColumnIndex.Builder
 
build() - Method in class org.apache.cassandra.db.index.SecondaryIndexBuilder
 
build(ByteBuffer...) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
build() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
build(IPartitioner) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
build() - Method in class org.apache.cassandra.transport.CBUtil.BufferBuilder
 
build(Collection<I>, Comparator<C>) - Static method in class org.apache.cassandra.utils.IntervalTree
 
build(Collection<I>) - Static method in class org.apache.cassandra.utils.IntervalTree
 
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
 
builder() - Method in class org.apache.cassandra.db.marshal.CompositeType
 
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
 
buildName(CFMetaData, ByteBuffer...) - Static method in class org.apache.cassandra.tracing.Tracing
 
buildTServer(TServerFactory.Args) - Method in class org.apache.cassandra.thrift.CustomTHsHaServer.Factory
 
buildTServer(TServerFactory.Args) - Method in class org.apache.cassandra.thrift.CustomTNonBlockingServer.Factory
 
buildTServer(TServerFactory.Args) - Method in class org.apache.cassandra.thrift.CustomTThreadPoolServer.Factory
 
buildTServer(TServerFactory.Args) - Method in class org.apache.cassandra.thrift.TServerCustomFactory
 
buildTServer(TServerFactory.Args) - Method in interface org.apache.cassandra.thrift.TServerFactory
 
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 - Variable in class org.apache.cassandra.cql3.Constants.Value
 
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(InetAddress) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(UUID) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes() - Method in class org.apache.cassandra.utils.CounterId
 
bytes - Variable in class org.apache.cassandra.utils.MD5Digest
 
bytesCompacted - Variable in class org.apache.cassandra.metrics.CompactionMetrics
Total number of bytes compacted since server [re]start
bytesCompare(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.BytesType
 
BytesConversionFcts - Class in org.apache.cassandra.cql3.functions
 
BytesConversionFcts() - Constructor for class org.apache.cassandra.cql3.functions.BytesConversionFcts
 
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
 
bytesToCB(byte[]) - Static method in class org.apache.cassandra.transport.CBUtil
 
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, RowIndexEntry) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
CacheMetrics - Class in org.apache.cassandra.metrics
Metrics for ICache.
CacheMetrics(String, ICache) - Constructor for class org.apache.cassandra.metrics.CacheMetrics
Create metrics for given cache.
CacheService - Class in org.apache.cassandra.service
 
CacheService.CacheType - Enum in org.apache.cassandra.service
 
CacheService.KeyCacheSerializer - Class in org.apache.cassandra.service
 
CacheService.KeyCacheSerializer() - Constructor for class org.apache.cassandra.service.CacheService.KeyCacheSerializer
 
CacheService.RowCacheSerializer - Class in org.apache.cassandra.service
 
CacheService.RowCacheSerializer() - Constructor for class org.apache.cassandra.service.CacheService.RowCacheSerializer
 
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
 
calculateHintTTL() - Method in class org.apache.cassandra.db.RowMutation
 
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
calculate endpoints in one pass through the tokens by tracking our progress in each DC, rack etc.
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
 
calculateRelocations(Multimap<String, String>) - Method in class org.apache.cassandra.tools.Shuffle
Given a Multimap of endpoint to tokens, return a new randomized mapping.
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.net.CallbackInfo
 
callback - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
callback - Variable in class org.apache.cassandra.streaming.AbstractStreamSession
 
callbackDeserializers - Static variable in class org.apache.cassandra.net.MessagingService
A Map of what kind of serializer to wire up to a REQUEST_RESPONSE callback, based on outbound Verb.
CallbackInfo - Class in org.apache.cassandra.net
Encapsulates the callback information.
CallbackInfo(InetAddress, IMessageCallback, IVersionedSerializer<?>) - Constructor for class org.apache.cassandra.net.CallbackInfo
Create CallbackInfo without sent message
CallbackInfo(InetAddress, IMessageCallback, MessageOut<?>, IVersionedSerializer<?>) - Constructor for class org.apache.cassandra.net.CallbackInfo
 
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 - Variable in class org.apache.cassandra.metrics.CacheMetrics
Cache capacity in bytes
capacity() - Method in interface org.apache.cassandra.utils.obs.IBitSet
 
capacity() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
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.AbstractColumnFamilyInputFormat
 
CASSANDRA_HADOOP_MAX_KEY_SIZE_DEFAULT - Static variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
 
CASSANDRA_HADOOP_MAX_KEY_SIZE_DEFAULT - Static variable in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
CassandraAuthorizer - Class in org.apache.cassandra.auth
CassandraAuthorizer is an IAuthorizer implementation that keeps permissions internally in C* - in system_auth.permissions CQL3 table.
CassandraAuthorizer() - Constructor for class org.apache.cassandra.auth.CassandraAuthorizer
 
CassandraDaemon - 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 CassandraDaemon.setup(), CassandraDaemon.start(), CassandraDaemon.stop() and CassandraDaemon.setup()).
CassandraDaemon() - Constructor for class org.apache.cassandra.service.CassandraDaemon
 
CassandraDaemon.Server - Interface in org.apache.cassandra.service
 
CassandraException - Exception in org.apache.cassandra.exceptions
 
CassandraException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.CassandraException
 
CassandraException(ExceptionCode, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.CassandraException
 
CassandraServer - Class in org.apache.cassandra.thrift
 
CassandraServer() - Constructor for class org.apache.cassandra.thrift.CassandraServer
 
cassandraServer - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
 
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
 
CBCodec<T> - Interface in org.apache.cassandra.transport
 
CBUtil - Class in org.apache.cassandra.transport
ChannelBuffer utility methods.
CBUtil.BufferBuilder - Class in org.apache.cassandra.transport
 
CBUtil.BufferBuilder(int, int, int) - Constructor for class org.apache.cassandra.transport.CBUtil.BufferBuilder
 
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
 
cfdefFromString(String) - Static method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
convert string back to 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
 
cfdefToString(CfDef) - Static method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
convert CfDef to string
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
 
cfIdSerializedSize(UUID, TypeSizes, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
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.ColumnSpecification
 
cfName - Variable in class org.apache.cassandra.cql3.statements.CFStatement
 
cfname - Variable in class org.apache.cassandra.db.migration.avro.DropColumnFamily
 
cfName - Variable in exception org.apache.cassandra.exceptions.AlreadyExistsException
 
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
 
cfs - Variable in class org.apache.cassandra.db.SliceQueryPager
 
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
 
chain(IResource) - Static method in class org.apache.cassandra.auth.Resources
Construct a chain of resource parents starting with the resource and ending with the root.
change - Variable in class org.apache.cassandra.transport.Event.SchemaChange
 
change - Variable in class org.apache.cassandra.transport.Event.TopologyChange
 
change - Variable in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
 
changeType() - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
 
changeType() - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
 
changeType() - Method in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement
 
changeType() - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
 
changeType() - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
 
changeType() - Method in class org.apache.cassandra.cql3.statements.DropColumnFamilyStatement
 
changeType() - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
 
changeType() - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
 
changeType() - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
 
channel - Variable in class org.apache.cassandra.io.util.RandomAccessReader
 
channel() - Method in class org.apache.cassandra.transport.Connection
 
channel - Variable in class org.apache.cassandra.transport.SimpleClient
 
channelOpen(ChannelHandlerContext, ChannelStateEvent) - Method in class org.apache.cassandra.transport.Frame.Decoder
 
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.AlterUserStatement
 
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.CreateUserStatement
 
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.DropUserStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListUsersStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.PermissionAlteringStatement
 
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.AbstractColumnFamilyOutputFormat
Check for validity of the output-specification for the job.
checkOutputSpecs(Configuration) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
Deprecated.
checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
Deprecated.
checkSchema(ResourceSchema) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
checkSeedContact(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
CHUNK_LENGTH_KB - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
 
CHUNK_SIZE - Static variable in class org.apache.cassandra.streaming.compress.CompressedFileStreamTask
 
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.
chunks - Variable in class org.apache.cassandra.streaming.compress.CompressionInfo
 
cident() - 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.CompressedPoolingSegmentedFile
 
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.PoolingSegmentedFile
 
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
 
cleanupOnFailure(String, Job) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
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() - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
 
clear() - Static method in class org.apache.cassandra.net.sink.SinkManager
 
clear() - Method in class org.apache.cassandra.tools.Shuffle
Clear pending token relocations on all nodes.
clear() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
 
clear() - Method in class org.apache.cassandra.utils.BiMultiValMap
 
clear() - Method in class org.apache.cassandra.utils.BloomFilter
 
clear() - Method in class org.apache.cassandra.utils.BoundedStatsDeque
 
clear() - Method in interface org.apache.cassandra.utils.IFilter
 
clear() - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
clear(long) - Method in interface org.apache.cassandra.utils.obs.IBitSet
clears the bit.
clear() - Method in interface org.apache.cassandra.utils.obs.IBitSet
 
clear(long) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
clear() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
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() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
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
 
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
 
client - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
 
Client - Class in org.apache.cassandra.transport
 
Client(String, int, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.Client
 
client_encryption_options - Variable in class org.apache.cassandra.config.Config
 
ClientRequestMetrics - Class in org.apache.cassandra.metrics
 
ClientRequestMetrics(String) - Constructor for class org.apache.cassandra.metrics.ClientRequestMetrics
 
ClientState - Class in org.apache.cassandra.service
State related to a client connection.
ClientState() - Constructor for class org.apache.cassandra.service.ClientState
 
ClientState(boolean) - Constructor for class org.apache.cassandra.service.ClientState
Construct a new, empty ClientState
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.setTraceProbability_return - Class in org.apache.cassandra.cli
 
CliParser.setTraceProbability_return() - Constructor for class org.apache.cassandra.cli.CliParser.setTraceProbability_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.traceNextQuery_return - Class in org.apache.cassandra.cli
 
CliParser.traceNextQuery_return() - Constructor for class org.apache.cassandra.cli.CliParser.traceNextQuery_return
 
CliParser.traceSessionId_return - Class in org.apache.cassandra.cli
 
CliParser.traceSessionId_return() - Constructor for class org.apache.cassandra.cli.CliParser.traceSessionId_return
 
CliParser.tracingProbability_return - Class in org.apache.cassandra.cli
 
CliParser.tracingProbability_return() - Constructor for class org.apache.cassandra.cli.CliParser.tracingProbability_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, move, and relocate 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 class org.apache.cassandra.db.columniterator.LazyColumnIterator
 
close() - Method in interface org.apache.cassandra.db.columniterator.OnDiskAtomIterator
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.CompactionController
 
close() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
close() - Method in class org.apache.cassandra.db.compaction.PrecompactedRow
 
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.AbstractColumnFamilyRecordWriter.AbstractRangeClient
 
close(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
Close this RecordWriter to future operations, but not before flushing out the batched mutations.
close(Reporter) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
Deprecated.
close() - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
 
close() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
close() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
 
close() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
close() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
 
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(Closeable...) - Static method in class org.apache.cassandra.io.util.FileUtils
 
close(Iterable<? extends Closeable>) - Static method in class org.apache.cassandra.io.util.FileUtils
 
close() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
 
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() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
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.AbstractJmxClient
 
close() - Method in class org.apache.cassandra.tools.NodeProbe
 
close() - Method in class org.apache.cassandra.transport.SimpleClient
 
close() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
 
close() - Method in class org.apache.cassandra.utils.BloomFilter
 
close(int) - Static method in class org.apache.cassandra.utils.CLibrary
 
close() - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
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
close() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
close() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
CloseableIterator<T> - Interface in org.apache.cassandra.utils
 
closeableIterator(Iterator<T>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
closeAll() - Method in interface org.apache.cassandra.transport.Connection.Tracker
 
closeAll() - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
 
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() - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
 
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
 
code - Variable in enum org.apache.cassandra.db.ConsistencyLevel
 
code() - Method in exception org.apache.cassandra.exceptions.CassandraException
 
code() - Method in interface org.apache.cassandra.exceptions.TransportException
The exception code.
code() - Method in exception org.apache.cassandra.transport.ProtocolException
 
code() - Method in exception org.apache.cassandra.transport.ServerError
 
codec - Static variable in class org.apache.cassandra.cql3.ResultSet
 
codec - Static variable in class org.apache.cassandra.cql3.ResultSet.Metadata
 
codec - Static variable in enum org.apache.cassandra.transport.DataType
 
codec - Variable in enum org.apache.cassandra.transport.Message.Type
 
codec - Static variable in class org.apache.cassandra.transport.messages.AuthenticateMessage
 
codec - Static variable in class org.apache.cassandra.transport.messages.CredentialsMessage
 
codec - Static variable in class org.apache.cassandra.transport.messages.ErrorMessage
 
codec - Static variable in class org.apache.cassandra.transport.messages.EventMessage
 
codec - Static variable in class org.apache.cassandra.transport.messages.ExecuteMessage
 
codec - Static variable in class org.apache.cassandra.transport.messages.OptionsMessage
 
codec - Static variable in class org.apache.cassandra.transport.messages.PrepareMessage
 
codec - Static variable in class org.apache.cassandra.transport.messages.QueryMessage
 
codec - Static variable in class org.apache.cassandra.transport.messages.ReadyMessage
 
codec - Static variable in class org.apache.cassandra.transport.messages.RegisterMessage
 
codec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage
 
codec - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
 
codec - Static variable in class org.apache.cassandra.transport.messages.SupportedMessage
 
collateColumns(ColumnFamily, List<? extends CloseableIterator<IColumn>>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
collateOnDiskAtom(ColumnFamily, List<? extends CloseableIterator<OnDiskAtom>>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
CollationController - Class in org.apache.cassandra.db
 
CollationController(ColumnFamilyStore, boolean, QueryFilter, int) - Constructor for class org.apache.cassandra.db.CollationController
 
collection_literal() - Method in class org.apache.cassandra.cql3.CqlParser
 
collection_type() - Method in class org.apache.cassandra.cql3.CqlParser
 
CollectionType<T> - Class in org.apache.cassandra.db.marshal
The abstract validator that is the base for maps, sets and lists.
CollectionType(CollectionType.Kind) - Constructor for class org.apache.cassandra.db.marshal.CollectionType
 
CollectionType.Kind - Enum in org.apache.cassandra.db.marshal
 
collectMarkerSpecification(ColumnSpecification[]) - Method in class org.apache.cassandra.cql3.AbstractMarker
 
collectMarkerSpecification(ColumnSpecification[]) - Method in class org.apache.cassandra.cql3.functions.FunctionCall
 
collectMarkerSpecification(ColumnSpecification[]) - Method in class org.apache.cassandra.cql3.Lists.DelayedValue
 
collectMarkerSpecification(ColumnSpecification[]) - Method in class org.apache.cassandra.cql3.Lists.SetterByIndex
 
collectMarkerSpecification(ColumnSpecification[]) - Method in class org.apache.cassandra.cql3.Maps.DelayedValue
 
collectMarkerSpecification(ColumnSpecification[]) - Method in class org.apache.cassandra.cql3.Maps.SetterByKey
 
collectMarkerSpecification(ColumnSpecification[]) - Method in class org.apache.cassandra.cql3.Operation
Collects the column specification for the bind variables of this operation.
collectMarkerSpecification(ColumnSpecification[]) - Method in class org.apache.cassandra.cql3.Sets.DelayedValue
 
collectMarkerSpecification(ColumnSpecification[]) - Method in interface org.apache.cassandra.cql3.Term
Collects the column specification for the bind variables in this Term.
collectMarkerSpecification(ColumnSpecification[]) - Method in class org.apache.cassandra.cql3.Term.Terminal
 
collectReducedColumns(IColumnContainer, Iterator<IColumn>, int) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
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_family - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
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 - Variable in class org.apache.cassandra.io.sstable.ColumnStats
how many columns are there in the row
ColumnCounter - Class in org.apache.cassandra.db.filter
 
ColumnCounter() - Constructor for class org.apache.cassandra.db.filter.ColumnCounter
 
ColumnCounter.GroupByPrefix - Class in org.apache.cassandra.db.filter
 
ColumnCounter.GroupByPrefix(CompositeType, int) - Constructor for class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefix
A column counter that count only 1 for all the columns sharing a given prefix of the key.
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
columnFamilies - Variable in class org.apache.cassandra.streaming.StreamRequest
 
columnFamily(String, String) - Static method in class org.apache.cassandra.auth.DataResource
Creates a DataResource instance representing a column family.
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
 
columnFamily - Variable in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
 
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
 
ColumnFamilyMetrics - Class in org.apache.cassandra.metrics
Metrics for ColumnFamilyStore.
ColumnFamilyMetrics(ColumnFamilyStore) - Constructor for class org.apache.cassandra.metrics.ColumnFamilyMetrics
Creates metrics for given ColumnFamilyStore.
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
 
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
Deprecated.
ColumnFamilySplit(String, String, long, 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.
ColumnGroupMap - Class in org.apache.cassandra.cql3.statements
 
ColumnGroupMap.Builder - Class in org.apache.cassandra.cql3.statements
 
ColumnGroupMap.Builder(CompositeType, boolean) - Constructor for class org.apache.cassandra.cql3.statements.ColumnGroupMap.Builder
 
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
 
ColumnIndex - Class in org.apache.cassandra.db
 
ColumnIndex.Builder - Class in org.apache.cassandra.db
Help to create an index for a column family based on size of columns, and write said columns to disk.
ColumnIndex.Builder(ColumnFamily, ByteBuffer, DataOutput, boolean) - Constructor for class org.apache.cassandra.db.ColumnIndex.Builder
 
ColumnIndex.Builder(ColumnFamily, ByteBuffer, DataOutput) - Constructor for class org.apache.cassandra.db.ColumnIndex.Builder
 
columnLimitExpr() - Method in class org.apache.cassandra.cli.CliParser
 
columnMetadata(Map<ByteBuffer, ColumnDefinition>) - Method in class org.apache.cassandra.config.CFMetaData
 
columnName() - Method in class org.apache.cassandra.cli.CliParser
 
columnName - Variable in class org.apache.cassandra.cql.AlterTableStatement
 
columnName - Variable in class org.apache.cassandra.cql3.Operation
 
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.
columnOperation(List<Pair<ColumnIdentifier, Operation.RawUpdate>>) - Method in class org.apache.cassandra.cql3.CqlParser
 
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
 
ColumnSerializer.CorruptColumnException - Exception in org.apache.cassandra.db
 
ColumnSerializer.CorruptColumnException(String) - Constructor for exception org.apache.cassandra.db.ColumnSerializer.CorruptColumnException
 
columnsIndex - Variable in class org.apache.cassandra.db.ColumnIndex
 
columnsIndex() - Method in class org.apache.cassandra.db.RowIndexEntry
 
ColumnSlice - Class in org.apache.cassandra.db.filter
 
ColumnSlice(ByteBuffer, ByteBuffer) - Constructor for class org.apache.cassandra.db.filter.ColumnSlice
 
ColumnSlice.NavigableMapIterator - Class in org.apache.cassandra.db.filter
 
ColumnSlice.NavigableMapIterator(NavigableMap<ByteBuffer, IColumn>, ColumnSlice[]) - Constructor for class org.apache.cassandra.db.filter.ColumnSlice.NavigableMapIterator
 
ColumnSlice.Serializer - Class in org.apache.cassandra.db.filter
 
ColumnSlice.Serializer() - Constructor for class org.apache.cassandra.db.filter.ColumnSlice.Serializer
 
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
 
ColumnSpecification - Class in org.apache.cassandra.cql3
 
ColumnSpecification(String, String, ColumnIdentifier, AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.ColumnSpecification
 
columnStats() - Method in class org.apache.cassandra.db.compaction.AbstractCompactedRow
 
columnStats() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
columnStats() - Method in class org.apache.cassandra.db.compaction.PrecompactedRow
 
ColumnStats - Class in org.apache.cassandra.io.sstable
ColumnStats holds information about the columns for one row inside sstable
ColumnStats(int, long, long, StreamingHistogram) - Constructor for class org.apache.cassandra.io.sstable.ColumnStats
 
ColumnToCollectionType - Class in org.apache.cassandra.db.marshal
 
columnToTuple(IColumn, CfDef, AbstractType) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
convert a column to a tuple
command() - Method in class org.apache.cassandra.cli.CliParser
 
commandCompletedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
Completed tasks for Command(Mutations, Read etc) TCP Connections
commandDroppedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
Dropped tasks for Command(Mutations, Read etc) TCP Connections
commandPendingTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
Pending tasks for Command(Mutations, Read etc) TCP Connections
commands - Variable in class org.apache.cassandra.cli.CliUserHelp
 
commands - Variable in class org.apache.cassandra.tools.NodeToolHelp
 
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
 
CommitLogDescriptor - Class in org.apache.cassandra.db.commitlog
 
CommitLogDescriptor(int, long) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
CommitLogDescriptor(long) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
CommitLogMBean - Interface in org.apache.cassandra.db.commitlog
 
CommitLogMetrics - Class in org.apache.cassandra.metrics
Metrics for commit log
CommitLogMetrics(ICommitLogExecutorService, CommitLogAllocator) - Constructor for class org.apache.cassandra.metrics.CommitLogMetrics
 
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
 
CommitLogSegment.CommitLogSegmentFileComparator - Class in org.apache.cassandra.db.commitlog
 
CommitLogSegment.CommitLogSegmentFileComparator() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogSegmentFileComparator
 
commitTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.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_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_CLASS_KEY - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
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) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
 
CompactionController(ColumnFamilyStore, int) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
Constructor that subclasses may use when overriding shouldPurge to not need overlappingTree
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(OperationType, long, long, String) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
 
CompactionInfo(CFMetaData, OperationType, long, long, String) - 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
 
CompactionMetrics - Class in org.apache.cassandra.metrics
Metrics for compaction.
CompactionMetrics(ThreadPoolExecutor...) - Constructor for class org.apache.cassandra.metrics.CompactionMetrics
 
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
 
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.AbstractCompactionTask
 
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 - Variable in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement
 
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.db.RangeTombstoneList
 
comparator() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
comparator() - Method in class org.apache.cassandra.utils.IntervalTree
 
comparator_type - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
comparators - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
comparatorType() - Method in class org.apache.cassandra.cql.CqlParser
 
comparatorType() - Method in class org.apache.cassandra.cql3.CqlParser
 
compare(File, File) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogSegmentFileComparator
 
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.CollectionType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
 
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.EmptyType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.InetAddressType
 
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(byte[], ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
compare(ByteBuffer, byte[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
compareCollectionMembers(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
An alternative comparison function used by CollectionsType in conjunction with CompositeType.
compareCollectionMembers(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
 
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(PermissionDetails) - Method in class org.apache.cassandra.auth.PermissionDetails
 
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(DeletionTime) - Method in class org.apache.cassandra.db.DeletionTime
 
compareTo(Directories.DataDirectory) - Method in class org.apache.cassandra.db.Directories.DataDirectory
 
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(Token<Long>) - Method in class org.apache.cassandra.dht.LongToken
 
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(CounterId) - Method in class org.apache.cassandra.utils.CounterId
 
compareTo(MergeIterator.Candidate<In>) - Method in class org.apache.cassandra.utils.MergeIterator.Candidate
 
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(String) - Method in class org.apache.cassandra.io.util.BufferedPoolingSegmentedFile.Builder
 
complete(String) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile.Builder
 
complete(String) - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile.Builder
 
complete(String) - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile.Builder
 
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
 
completedTasks - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
Number of completed tasks
completedTasks - Variable in class org.apache.cassandra.metrics.CompactionMetrics
Number of completed compactions since server [re]start
completedTasks - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
Number of completed tasks.
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, String) - Constructor for class org.apache.cassandra.io.sstable.Component
 
component - Variable in class org.apache.cassandra.streaming.PendingFile
 
Component.Type - Enum in org.apache.cassandra.io.sstable
 
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
 
COMPONENT_SUMMARY - 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.JdbcInetAddress
 
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.ColumnToCollectionType
 
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.EmptyType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.InetAddressType
 
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.ListType
 
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.MapType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.SetType
 
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
 
composeComposite(AbstractCompositeType, ByteBuffer) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
Deconstructs a composite type to a Tuple.
CompositesIndex - Class in org.apache.cassandra.db.index.composites
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.
CompositesIndex() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndex
 
CompositesSearcher - Class in org.apache.cassandra.db.index.composites
 
CompositesSearcher(SecondaryIndexManager, Set<ByteBuffer>, int) - Constructor for class org.apache.cassandra.db.index.composites.CompositesSearcher
 
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
 
CompositeType.Builder(CompositeType, List<ByteBuffer>, byte[]) - 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.LZ4Compressor
 
compress(byte[], int, int, ICompressor.WrappedArray, int) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
 
compress(Frame) - Method in interface org.apache.cassandra.transport.FrameCompressor
 
compress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.SnappyCompressor
 
compressedFileLength - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
 
CompressedFileStreamTask - Class in org.apache.cassandra.streaming.compress
FileStreamTask for compressed SSTable.
CompressedFileStreamTask(StreamHeader, InetAddress) - Constructor for class org.apache.cassandra.streaming.compress.CompressedFileStreamTask
 
CompressedInputStream - Class in org.apache.cassandra.streaming.compress
InputStream which reads data from underlining source with given CompressionInfo.
CompressedInputStream(InputStream, CompressionInfo) - Constructor for class org.apache.cassandra.streaming.compress.CompressedInputStream
 
CompressedPoolingSegmentedFile - Class in org.apache.cassandra.io.util
 
CompressedPoolingSegmentedFile(String, CompressionMetadata) - Constructor for class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
 
CompressedPoolingSegmentedFile.Builder - Class in org.apache.cassandra.io.util
 
CompressedPoolingSegmentedFile.Builder() - Constructor for class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile.Builder
 
CompressedRandomAccessReader - Class in org.apache.cassandra.io.compress
CRAR extends RAR to transparently uncompress blocks from the file into RAR.buffer.
CompressedRandomAccessReader(String, CompressionMetadata, boolean, PoolingSegmentedFile) - 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
 
CompressedThrottledReader - Class in org.apache.cassandra.io.compress
 
CompressedThrottledReader(String, CompressionMetadata, RateLimiter) - Constructor for class org.apache.cassandra.io.compress.CompressedThrottledReader
 
compression - Variable in class org.apache.cassandra.io.sstable.SSTable
 
COMPRESSION - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
 
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
 
CompressionInfo - Class in org.apache.cassandra.streaming.compress
Container that carries compression parameters and chunks to decompress data from stream.
CompressionInfo(CompressionMetadata.Chunk[], CompressionParameters) - Constructor for class org.apache.cassandra.streaming.compress.CompressionInfo
 
compressionInfo - Variable in class org.apache.cassandra.streaming.PendingFile
compression information.
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
 
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 - 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
 
compressionRatio - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Current compression ratio for all SSTables
compressor() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
 
compute(byte[]) - Static method in class org.apache.cassandra.utils.MD5Digest
 
compute(String) - Static method in class org.apache.cassandra.utils.MD5Digest
 
computeExpireTime() - Static method in class org.apache.cassandra.gms.Gossiper
 
computeNext() - Method in class org.apache.cassandra.db.columniterator.LazyColumnIterator
 
computeNext() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
computeNext() - Method in class org.apache.cassandra.db.filter.ColumnSlice.NavigableMapIterator
 
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<CounterId.CounterIdRecord>, 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 counter ids nulified and there content merged to the current localCounterId.
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 extends IMeasurableMemory,V extends IMeasurableMemory> - Class in org.apache.cassandra.cache
Wrapper so CLHM can implement ICache interface.
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.TruncateResponseHandler
 
CONDITIONS - Static variable in class org.apache.cassandra.cli.CliLexer
 
CONDITIONS - Static variable in class org.apache.cassandra.cli.CliParser
 
conf - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
 
conf - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
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
A class that contains configuration properties for the cassandra node it runs within.
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.DiskFailurePolicy - Enum in org.apache.cassandra.config
 
Config.InternodeCompression - 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.exceptions
 
ConfigurationException(String) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
 
ConfigurationException(String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
 
ConfigurationException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
 
confirmReplication(InetAddress) - Method in class org.apache.cassandra.service.StorageService
 
CONNECT - Static variable in class org.apache.cassandra.cli.CliLexer
 
connect(String, int) - Static method in class org.apache.cassandra.cli.CliMain
Establish a thrift connection to cassandra instance
CONNECT - Static variable in class org.apache.cassandra.cli.CliParser
 
connect(boolean) - Method in class org.apache.cassandra.transport.SimpleClient
 
Connection - Class in org.apache.cassandra.transport
 
Connection(Connection.Tracker) - Constructor for class org.apache.cassandra.transport.Connection
 
connection - Variable in class org.apache.cassandra.transport.Frame
 
connection - Variable in class org.apache.cassandra.transport.Message
 
connection() - Method in class org.apache.cassandra.transport.Message
 
connection - Variable in class org.apache.cassandra.transport.SimpleClient
 
Connection.Factory - Interface in org.apache.cassandra.transport
 
Connection.Tracker - Interface in org.apache.cassandra.transport
 
connectionComplete(SocketAddress) - Method in class org.apache.cassandra.thrift.ThriftSessionManager
The connection associated with @param socket is permanently finished.
ConnectionMetrics - Class in org.apache.cassandra.metrics
ConnectionMetrics(InetAddress, OutboundTcpConnectionPool) - Constructor for class org.apache.cassandra.metrics.ConnectionMetrics
Create metrics for given connection pool.
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
 
consistency - Variable in exception org.apache.cassandra.exceptions.RequestTimeoutException
 
consistency - Variable in exception org.apache.cassandra.exceptions.UnavailableException
 
consistency - Variable in class org.apache.cassandra.transport.messages.ExecuteMessage
 
consistency - Variable in class org.apache.cassandra.transport.messages.QueryMessage
 
CONSISTENCYLEVEL - Static variable in class org.apache.cassandra.cli.CliLexer
 
CONSISTENCYLEVEL - Static variable in class org.apache.cassandra.cli.CliParser
 
ConsistencyLevel - Enum in org.apache.cassandra.db
 
consistencyLevel - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
 
consistencyLevel - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
consistencyLevelStatement() - Method in class org.apache.cassandra.cli.CliParser
 
consistencyLevelToCB(ConsistencyLevel) - Static method in class org.apache.cassandra.transport.CBUtil
 
CONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
 
constant() - Method in class org.apache.cassandra.cql3.CqlParser
 
Constants - Class in org.apache.cassandra.cql3
Static helper methods and classes for constants.
Constants() - Constructor for class org.apache.cassandra.cql3.Constants
 
Constants.Adder - Class in org.apache.cassandra.cql3
 
Constants.Adder(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Adder
 
Constants.Deleter - Class in org.apache.cassandra.cql3
 
Constants.Deleter(ColumnIdentifier, boolean) - Constructor for class org.apache.cassandra.cql3.Constants.Deleter
 
Constants.Literal - Class in org.apache.cassandra.cql3
 
Constants.Marker - Class in org.apache.cassandra.cql3
 
Constants.Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Constants.Marker
 
Constants.Setter - Class in org.apache.cassandra.cql3
 
Constants.Setter(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Setter
 
Constants.Substracter - Class in org.apache.cassandra.cql3
 
Constants.Substracter(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Substracter
 
Constants.Type - Enum in org.apache.cassandra.cql3
 
Constants.Value - Class in org.apache.cassandra.cql3
A constant value, i.e.
Constants.Value(ByteBuffer) - Constructor for class org.apache.cassandra.cql3.Constants.Value
 
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.
containsBindMarker() - Method in class org.apache.cassandra.cql3.AbstractMarker
 
containsBindMarker() - Method in class org.apache.cassandra.cql3.functions.FunctionCall
 
containsBindMarker() - Method in class org.apache.cassandra.cql3.Lists.DelayedValue
 
containsBindMarker() - Method in class org.apache.cassandra.cql3.Maps.DelayedValue
 
containsBindMarker() - Method in class org.apache.cassandra.cql3.Sets.DelayedValue
 
containsBindMarker() - Method in interface org.apache.cassandra.cql3.Term
Whether or not that term contains at least one bind marker.
containsBindMarker() - Method in class org.apache.cassandra.cql3.Term.Terminal
 
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(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
 
containsKey(K) - Method in class org.apache.cassandra.utils.ExpiringMap
 
containsTimestamp() - Method in class org.apache.cassandra.io.sstable.Descriptor.Version
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
 
containsValue(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
 
contents() - Method in class org.apache.cassandra.db.Memtable
 
contentSerializedSize(ColumnFamily, TypeSizes, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
context - Variable in class org.apache.cassandra.db.context.CounterContext.ContextState
 
contextManager - Static variable in class org.apache.cassandra.db.CounterColumn
 
controller - Variable in class org.apache.cassandra.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.Murmur3Partitioner
 
convertFromDiskFormat(ByteBuffer) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
convertFromDiskFormat(ByteBuffer) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
convertNewCfId(UUID) - Method in class org.apache.cassandra.config.Schema
 
convertOldCfId(Integer) - Method in class org.apache.cassandra.config.Schema
 
convertOldStrategyName(String) - Static method in class org.apache.cassandra.config.KSMetaData
 
convertPropertyMap(Maps.Literal) - Method in class org.apache.cassandra.cql3.CqlParser
 
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
 
coordinator - Variable in class org.apache.cassandra.tracing.TraceState
 
copy() - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
Clone this builder.
copy() - Method in class org.apache.cassandra.db.DeletionInfo
 
copy() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
copy() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
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
 
CorruptBlockException - Exception in org.apache.cassandra.io.compress
 
CorruptBlockException(String, CompressionMetadata.Chunk) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
 
CorruptBlockException(String, long, int) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
 
CorruptSSTableException - Exception in org.apache.cassandra.io.sstable
 
CorruptSSTableException(Exception, File) - Constructor for exception org.apache.cassandra.io.sstable.CorruptSSTableException
 
CorruptSSTableException(Exception, String) - Constructor for exception org.apache.cassandra.io.sstable.CorruptSSTableException
 
COUNT - Static variable in class org.apache.cassandra.cli.CliLexer
 
COUNT - Static variable in class org.apache.cassandra.cli.CliParser
 
count(IColumn, IColumnContainer) - Method in class org.apache.cassandra.db.filter.ColumnCounter
 
count(IColumn, IColumnContainer) - Method in class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefix
 
count - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
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.metrics.HintedHandoffMetrics.DifferencingCounter
 
count() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
countAllBatches() - Method in class org.apache.cassandra.db.BatchlogManager
 
countAllBatches() - Method in interface org.apache.cassandra.db.BatchlogManagerMBean
Counts all batches currently in the batchlog.
countCQL3Rows - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
COUNTER_ID_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
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
 
counterid - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
CounterId - Class in org.apache.cassandra.utils
 
CounterId.CounterIdRecord - Class in org.apache.cassandra.utils
 
CounterId.CounterIdRecord(CounterId, long) - Constructor for class org.apache.cassandra.utils.CounterId.CounterIdRecord
 
CounterId.OneShotRenewer - Class in org.apache.cassandra.utils
 
CounterId.OneShotRenewer() - Constructor for class org.apache.cassandra.utils.CounterId.OneShotRenewer
 
CounterIdCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
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
 
CQL3Type - Interface in org.apache.cassandra.cql3
 
CQL3Type.Collection - Class in org.apache.cassandra.cql3
 
CQL3Type.Collection(CollectionType) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Collection
 
CQL3Type.Custom - Class in org.apache.cassandra.cql3
 
CQL3Type.Custom(AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Custom
 
CQL3Type.Custom(String) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Custom
 
CQL3Type.Native - Enum in org.apache.cassandra.cql3
 
CQL_VERSION - Static variable in class org.apache.cassandra.cql.QueryProcessor
 
CQL_VERSION - Static variable in class org.apache.cassandra.cql3.QueryProcessor
 
CQL_VERSION - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
 
CqlConfigHelper - Class in org.apache.cassandra.hadoop.cql3
 
CqlConfigHelper() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
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
 
CqlOutputFormat - Class in org.apache.cassandra.hadoop.cql3
The ColumnFamilyOutputFormat acts as a Hadoop-specific OutputFormat that allows reduce tasks to store keys (and corresponding binded variable values) as CQL rows (and respective columns) in a given ColumnFamily.
CqlOutputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
 
CqlPagingInputFormat - Class in org.apache.cassandra.hadoop.cql3
Hadoop InputFormat allowing map/reduce against Cassandra rows within one ColumnFamily.
CqlPagingInputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlPagingInputFormat
 
CqlPagingRecordReader - Class in org.apache.cassandra.hadoop.cql3
Hadoop RecordReader read the values return from the CQL query It use CQL key range query to page through the wide rows.
CqlPagingRecordReader() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
 
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
 
CqlParser.username_return - Class in org.apache.cassandra.cql3
 
CqlParser.username_return() - Constructor for class org.apache.cassandra.cql3.CqlParser.username_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
 
CqlStorage - 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: (((key1, value1), (key2, value2)), ((name1, val1), (name2, val2))).
CqlStorage() - Constructor for class org.apache.cassandra.hadoop.pig.CqlStorage
 
CqlStorage(int) - Constructor for class org.apache.cassandra.hadoop.pig.CqlStorage
 
CRC_CHECK_CHANCE - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
 
create(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
create(String, Map<IAuthenticator.Option, Object>) - Method in interface org.apache.cassandra.auth.IAuthenticator
Called during execution of CREATE USER query (also may be called on startup, see seedSuperuserOptions method).
create(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.LegacyAuthenticator
 
create(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
create(long, EntryWeigher<K, V>) - Static method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
Initialize a cache with initial capacity with weightedCapacity
create(long) - Static method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
create(long) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCacheProvider
 
create(long) - Method in interface org.apache.cassandra.cache.IRowCacheProvider
 
create(long, Weigher<RefCountedMemory>, ISerializer<V>) - Static method in class org.apache.cassandra.cache.SerializingCache
 
create(long, ISerializer<V>) - Static method in class org.apache.cassandra.cache.SerializingCache
 
create(long) - 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, String) - Method in interface org.apache.cassandra.cql3.functions.Function.Factory
 
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(InetAddress, long, String...) - Static method in class org.apache.cassandra.db.Column
 
create(UUID) - Static method in class org.apache.cassandra.db.ColumnFamily
 
create(UUID, 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() - Method in interface org.apache.cassandra.db.columniterator.IColumnIteratorFactory
 
create(DataInput, ByteBuffer) - Static method in exception org.apache.cassandra.db.ColumnSerializer.CorruptColumnException
 
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(CounterId, 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, IDiskAtomFilter, 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(long, DeletionTime, ColumnIndex) - Static method in class org.apache.cassandra.db.RowIndexEntry
 
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.LZ4Compressor
 
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(InetAddress, T, Map<String, byte[]>, MessagingService.Verb, int) - Static method in class org.apache.cassandra.net.MessageIn
 
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, UUID) - Static method in class org.apache.cassandra.streaming.StreamOutSession
 
create(String, InetAddress, UUID, IStreamCallback) - Static method in class org.apache.cassandra.streaming.StreamOutSession
 
create(ChannelBuffer, Connection) - Static method in class org.apache.cassandra.transport.Frame
 
create(Message.Type, int, EnumSet<Frame.Header.Flag>, ChannelBuffer, Connection) - Static method in class org.apache.cassandra.transport.Frame
 
create(C, C) - Static method in class org.apache.cassandra.utils.Interval
 
create(C, C, D) - Static method in class org.apache.cassandra.utils.Interval
 
create(X, Y) - Static method in class org.apache.cassandra.utils.Pair
 
create() - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
 
create(Comparator<K>, Comparator<V>) - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
 
create(BiMultiValMap<K, V>) - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
 
create(BiMultiValMap<K, V>, Comparator<K>, Comparator<V>) - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
 
createAllDirectories() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
Creates all storage-related directories.
createAuthenticatedClient(String, int, Configuration) - Static method in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
 
createAuthenticatedClient(String, int, Configuration) - Static method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
Connects to the given server:port and returns 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
 
createDirectory(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createDirectory(File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createFilter(int, IBitSet) - Method in class org.apache.cassandra.utils.Murmur2BloomFilter.Murmur2BloomFilterSerializer
 
createFilter(int, IBitSet) - Method in class org.apache.cassandra.utils.Murmur3BloomFilter.Murmur3BloomFilterSerializer
 
createHardLink(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
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, boolean, String) - 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
 
createKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
 
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
 
createMessage() - Method in class org.apache.cassandra.db.IndexScanCommand
 
createMessage() - Method in class org.apache.cassandra.db.RangeSliceCommand
 
createMessage() - Method in class org.apache.cassandra.db.RangeSliceReply
 
createMessage() - Method in class org.apache.cassandra.db.ReadCommand
 
createMessage() - Method in class org.apache.cassandra.db.RowMutation
 
createMessage(MessagingService.Verb) - Method in class org.apache.cassandra.db.RowMutation
 
createMessage() - Method in class org.apache.cassandra.db.SnapshotCommand
 
createMessage() - Method in class org.apache.cassandra.db.TruncateResponse
 
createMessage() - Method in class org.apache.cassandra.db.Truncation
 
createMessage() - Method in class org.apache.cassandra.db.WriteResponse
 
createMessage() - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
createMessage() - Method in class org.apache.cassandra.service.AntiEntropyService.Validator
 
createMessage() - Method in class org.apache.cassandra.streaming.StreamReply
 
createMessage() - Method in class org.apache.cassandra.streaming.StreamRequest
 
createMetricName(String) - Method in interface org.apache.cassandra.metrics.MetricNameFactory
Create MetricName from given metric name.
createReader(String) - Method in class org.apache.cassandra.io.util.BufferedPoolingSegmentedFile
 
createReader(String) - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
 
createReader(String) - Method in class org.apache.cassandra.io.util.PoolingSegmentedFile
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingInputFormat
 
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
 
createSecondaryIndexSearcher(Set<ByteBuffer>) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
 
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
createShuffleBatchInsert(Collection<String>, IPartitioner<?>) - Static method in class org.apache.cassandra.tools.Shuffle
Create and return a CQL batch insert statement for a set of token relocations.
createSSLContext(EncryptionOptions, boolean) - Static method in class org.apache.cassandra.security.SSLFactory
 
createTempFile(String, String, File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createTempFile(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createTracingSession() - Method in class org.apache.cassandra.service.QueryState
 
createUserStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
CreateUserStatement - Class in org.apache.cassandra.cql3.statements
 
CreateUserStatement(String, UserOptions, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateUserStatement
 
createValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
createValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
 
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
 
credentials - Variable in class org.apache.cassandra.transport.messages.CredentialsMessage
 
CredentialsMessage - Class in org.apache.cassandra.transport.messages
Message to indicate that the server is ready to receive requests.
CredentialsMessage() - Constructor for class org.apache.cassandra.transport.messages.CredentialsMessage
 
cross_node_timeout - Variable in class org.apache.cassandra.config.Config
 
CURRENT - Static variable in class org.apache.cassandra.io.sstable.Descriptor.Version
 
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.db.commitlog.CommitLogDescriptor
Increment this number if there is a changes in the commit log disc layout or MessagingVersion changes.
current_version - Static variable in class org.apache.cassandra.io.sstable.Descriptor.Version
 
current_version - Static variable in class org.apache.cassandra.net.MessagingService
 
CURRENT_VERSION - Static variable in class org.apache.cassandra.transport.Frame.Header
 
currentBlocked - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
Number of tasks currently blocked, waiting to be accepted by the executor (because all threads are busy and the backing queue is full).
currentKey - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
currentSession() - Method in class org.apache.cassandra.thrift.ThriftSessionManager
 
currentSuperColumn - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
currentTasks - Variable in class org.apache.cassandra.db.Directories.DataDirectory
 
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.Factory - Class in org.apache.cassandra.thrift
 
CustomTHsHaServer.Factory() - Constructor for class org.apache.cassandra.thrift.CustomTHsHaServer.Factory
 
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
 
CustomTNonBlockingServer.Factory - Class in org.apache.cassandra.thrift
 
CustomTNonBlockingServer.Factory() - Constructor for class org.apache.cassandra.thrift.CustomTNonBlockingServer.Factory
 
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
 
CustomTThreadPoolServer.Factory - Class in org.apache.cassandra.thrift
 
CustomTThreadPoolServer.Factory() - Constructor for class org.apache.cassandra.thrift.CustomTThreadPoolServer.Factory
 

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.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
 
DatacenterSyncWriteResponseHandler - Class in org.apache.cassandra.service
This class blocks for a quorum of responses _in all datacenters_ (CL.EACH_QUORUM).
DatacenterSyncWriteResponseHandler(Collection<InetAddress>, Collection<InetAddress>, ConsistencyLevel, Table, Runnable, WriteType) - 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>, Collection<InetAddress>, ConsistencyLevel, Table, Runnable, WriteType) - 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
 
dataPresent - Variable in exception org.apache.cassandra.exceptions.ReadTimeoutException
 
DataResource - Class in org.apache.cassandra.auth
The primary type of resource in Cassandra.
dataResource() - Method in class org.apache.cassandra.cql3.CqlParser
 
dataSize() - Method in class org.apache.cassandra.db.Column
 
dataSize() - Method in class org.apache.cassandra.db.CounterColumn
 
dataSize() - Method in class org.apache.cassandra.db.DeletionInfo
 
dataSize() - Method in class org.apache.cassandra.db.ExpiringColumn
 
dataSize() - Method in interface org.apache.cassandra.db.IColumn
the size of user-provided data, not including internal overhead
dataSize() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
dataSize() - Method in class org.apache.cassandra.db.SuperColumn
This calculates the exact size of the sub columns on the fly
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
 
DataTracker.SSTableIntervalTree - Class in org.apache.cassandra.db
 
DataType - Enum in org.apache.cassandra.transport
 
dateOfFct - Static variable in class org.apache.cassandra.cql3.functions.TimeuuidFcts
 
dateStringToTimestamp(String) - Static method in class org.apache.cassandra.db.marshal.DateType
 
DateType - Class in org.apache.cassandra.db.marshal
 
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.CassandraDaemon
A convenience method to stop and destroy the daemon in one shot.
deallocate() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
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
 
decode(ChannelBuffer) - Method in class org.apache.cassandra.cql3.ResultSet.Codec
 
decode(ChannelBuffer) - Method in interface org.apache.cassandra.transport.CBCodec
 
decode(ChannelHandlerContext, Channel, ChannelBuffer) - Method in class org.apache.cassandra.transport.Frame.Decoder
 
decode(ChannelHandlerContext, Channel, Object) - Method in class org.apache.cassandra.transport.Frame.Decompressor
 
decode(ChannelHandlerContext, Channel, Object) - Method in class org.apache.cassandra.transport.Message.ProtocolDecoder
 
decode(ChannelBuffer) - Method in class org.apache.cassandra.transport.OptionCodec
 
decodeKey(IPartitioner, Descriptor, ByteBuffer) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
Conditionally use the deprecated 'IPartitioner.convertFromDiskFormat' method.
decodeKey(ByteBuffer) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
decodeOne(ChannelBuffer) - Method in class org.apache.cassandra.transport.OptionCodec
 
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(InetAddress) - Method in class org.apache.cassandra.cql.jdbc.JdbcInetAddress
 
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(Object...) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
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(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
 
decompose(Object...) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
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(Object...) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
decompose(Void) - Method in class org.apache.cassandra.db.marshal.EmptyType
 
decompose(Float) - Method in class org.apache.cassandra.db.marshal.FloatType
 
decompose(InetAddress) - Method in class org.apache.cassandra.db.marshal.InetAddressType
 
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(List<T>) - Method in class org.apache.cassandra.db.marshal.ListType
Layout is: <n><s_1><b_1>...<s_n><b_n> where: n is the number of elements s_i is the number of bytes composing the ith element b_i is the s_i bytes composing the ith element
decompose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
decompose(Long) - Method in class org.apache.cassandra.db.marshal.LongType
 
decompose(Map<K, V>) - Method in class org.apache.cassandra.db.marshal.MapType
Layout is: <n><sk_1><k_1><sv_1><v_1>...<sk_n><k_n><sv_n><v_n> where: n is the number of elements sk_i is the number of bytes composing the ith key k_i k_i is the sk_i bytes composing the ith key sv_i is the number of bytes composing the ith value v_i v_i is the sv_i bytes composing the ith value
decompose(T) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
decompose(Set<T>) - Method in class org.apache.cassandra.db.marshal.SetType
Layout is: <n><s_1><b_1>...<s_n><b_n> where: n is the number of elements s_i is the number of bytes composing the ith element b_i is the s_i bytes composing the ith element
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.
decompress(Frame) - Method in interface org.apache.cassandra.transport.FrameCompressor
 
decompress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.SnappyCompressor
 
deconstruct(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
DecoratedKey - Class in org.apache.cassandra.db
Represents a decorated key, handy for certain operations where just working with strings gets slow.
DecoratedKey(Token, 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.Murmur3Partitioner
 
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
 
DEFAULT_BUCKET_HIGH - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
DEFAULT_BUCKET_LOW - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
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_PAGE_LIMIT - Static variable in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
 
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_HOST - Static variable in class org.apache.cassandra.tools.AbstractJmxClient
 
DEFAULT_INPUT_FORMAT - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
DEFAULT_JMX_PORT - Static variable in class org.apache.cassandra.tools.AbstractJmxClient
 
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_MAX_FRAME_SIZE - Static variable in class org.apache.cassandra.cli.transport.FramedTransportFactory
 
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_OUTPUT_FORMAT - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
DEFAULT_PAGE_SIZE - Static variable in class org.apache.cassandra.db.SliceQueryPager
 
DEFAULT_POPULATE_IO_CACHE_ON_FLUSH - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_READ_REPAIR_CHANCE - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_REPLICATE_ON_WRITE - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_SSTABLE_SIZE - Static variable in class org.apache.cassandra.tools.StandaloneSplitter
 
DEFAULT_SUPERUSER_NAME - Static variable in class org.apache.cassandra.auth.Auth
 
DEFAULT_THROTTLE_LIMIT - Static variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
DEFAULT_TOMBSTONE_COMPACTION_INTERVAL - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
DEFAULT_TOMBSTONE_THRESHOLD - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
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
 
DefaultDouble - Class in org.apache.cassandra.utils
 
DefaultDouble(double) - Constructor for class org.apache.cassandra.utils.DefaultDouble
 
DefaultInteger - Class in org.apache.cassandra.utils
 
DefaultInteger(int) - Constructor for class org.apache.cassandra.utils.DefaultInteger
 
defaultUser() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
 
defaultValidator(AbstractType<?>) - Method in class org.apache.cassandra.config.CFMetaData
 
defined - Variable in class org.apache.cassandra.db.marshal.ColumnToCollectionType
 
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
 
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(AbstractColumnContainer) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
delete(DeletionInfo) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
delete(DeletionTime) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
delete(RangeTombstone) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
delete(DeletionInfo) - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
 
delete(RangeTombstone) - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
 
delete(RangeTombstone) - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
delete(DeletionInfo) - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
delete(ByteBuffer, IColumn) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
delete(ByteBuffer, IColumn) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
Delete a column from the index
delete(DecoratedKey) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
cleans up deleted columns from cassandra cleanup compaction
delete(DeletionInfo) - Method in interface org.apache.cassandra.db.ISortedColumns
 
delete(RangeTombstone) - 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
 
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
 
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`.
deleteOp() - Method in class org.apache.cassandra.cql3.CqlParser
 
deleteRecursive(File) - Static method in class org.apache.cassandra.io.util.FileUtils
Deletes all files and subdirectories under "dir".
deleteSelection() - Method in class org.apache.cassandra.cql3.CqlParser
 
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<Operation.RawDeletion>, List<Relation>, Attributes) - Constructor for class org.apache.cassandra.cql3.statements.DeleteStatement
 
deleteUser(String) - Static method in class org.apache.cassandra.auth.Auth
Deletes the user from AUTH_KS.USERS_CF.
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
 
deletionInfo() - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
deletionInfo() - Method in class org.apache.cassandra.db.compaction.AbstractCompactedRow
 
deletionInfo() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
deletionInfo() - Method in class org.apache.cassandra.db.compaction.PrecompactedRow
 
DeletionInfo - Class in org.apache.cassandra.db
 
DeletionInfo(long, int) - Constructor for class org.apache.cassandra.db.DeletionInfo
 
DeletionInfo(DeletionTime) - Constructor for class org.apache.cassandra.db.DeletionInfo
 
DeletionInfo(ByteBuffer, ByteBuffer, Comparator<ByteBuffer>, long, int) - Constructor for class org.apache.cassandra.db.DeletionInfo
 
DeletionInfo(RangeTombstone, Comparator<ByteBuffer>) - Constructor for class org.apache.cassandra.db.DeletionInfo
 
deletionInfo() - Method in interface org.apache.cassandra.db.IColumnContainer
 
DeletionInfo.Serializer - Class in org.apache.cassandra.db
 
DeletionInfo.Serializer() - Constructor for class org.apache.cassandra.db.DeletionInfo.Serializer
 
DeletionTime - Class in org.apache.cassandra.db
 
DeletionTime(long, int) - Constructor for class org.apache.cassandra.db.DeletionTime
 
deletionTime() - Method in class org.apache.cassandra.db.RowIndexEntry
 
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.cache.KeyCacheKey
 
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
Deprecated.
describe_splits_ex(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 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.Murmur3Partitioner
 
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 - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
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(Descriptor.Version, File, String, String, int, boolean) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
 
descriptor - Variable in class org.apache.cassandra.io.sstable.SSTable
 
Descriptor.Version - Class in org.apache.cassandra.io.sstable
 
Descriptor.Version(String) - Constructor for class org.apache.cassandra.io.sstable.Descriptor.Version
 
deserialize(DataInputStream, ColumnFamilyStore) - Method in interface org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
 
deserialize(int) - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserialize(DataInput, IColumnSerializer.Flag, ISortedColumns.Factory, int) - 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, int) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
 
deserialize(DataInput, int, Comparator<ByteBuffer>) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.db.filter.ColumnSlice.Serializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
 
deserialize(DataInput, int, AbstractType<?>) - Method in class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter.Serializer
 
deserialize(DataInput, int, AbstractType) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter.Serializer
 
deserialize(DataInput) - Static method in class org.apache.cassandra.db.filter.QueryPath
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
 
deserialize(DataInput, int, Comparator<ByteBuffer>) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
 
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, Descriptor.Version) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
 
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, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
 
deserialize(DataInput) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
 
deserialize(IPartitioner, DataInput) - Static method in class org.apache.cassandra.gms.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(DataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
deserialize(DataInput, IPartitioner) - Method in class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
 
deserialize(Descriptor) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.SSTableMetadataSerializer
deserializes the metadata returns a pair containing the part of the metadata meant to be kept-in memory and the part that should not.
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.TreeRequest.TreeRequestSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.service.AntiEntropyService.Validator.ValidatorSerializer
 
deserialize(DataInputStream, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.KeyCacheSerializer
 
deserialize(DataInputStream, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.RowCacheSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.streaming.PendingFile.PendingFileSerializer
 
deserialize(ChannelBuffer) - Static method in class org.apache.cassandra.transport.Event
 
deserialize(int) - Static method in enum org.apache.cassandra.transport.Frame.Header.Flag
 
deserialize(DataInput) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
deserialize(TDeserializer, TBase, DataInput) - Static method in class org.apache.cassandra.utils.FBUtilities
Deprecated.
deserialize(DataInput, FilterFactory.Type, boolean) - Static method in class org.apache.cassandra.utils.FilterFactory
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
Deserialize an IntervalTree whose keys use the natural ordering.
deserialize(DataInput, int, Comparator<C>) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
 
deserialize(DataInput) - Method in class org.apache.cassandra.utils.LegacyBloomFilterSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
 
deserialize(DataInput) - Static method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
deserialize(DataInput) - Static method in class org.apache.cassandra.utils.obs.OpenBitSet
 
deserialize(DataInput) - Method in class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
 
deserializeAvro(Schema, ByteBuffer, T) - Static method in class org.apache.cassandra.db.DefsTable
Deserialize a single object based on the given Schema.
deserializeBody(DataInput, ByteBuffer, Descriptor.Version) - Method in class org.apache.cassandra.db.RangeTombstone.Serializer
 
deserializeBounds(DataInput) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
 
deserializeCfId(DataInput, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
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
deserializeColumnsFromSSTable(DataInput, ColumnFamily, int, IColumnSerializer.Flag, int, Descriptor.Version) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserializeFromSSTable(DataInput, Descriptor.Version) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserializeFromSSTable(DataInput, ColumnFamily, IColumnSerializer.Flag, Descriptor.Version) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserializeFromSSTable(DataInput, Descriptor.Version) - Method in class org.apache.cassandra.db.OnDiskAtom.Serializer
 
deserializeFromSSTable(DataInput, IColumnSerializer.Flag, int, Descriptor.Version) - Method in class org.apache.cassandra.db.OnDiskAtom.Serializer
 
deserializeFromSSTable(DataInput, Descriptor.Version) - Method in class org.apache.cassandra.db.RangeTombstone.Serializer
 
deserializeFromSSTable(DataInput, Descriptor.Version) - Method in interface org.apache.cassandra.io.ISSTableSerializer
Deserialize into the specified DataInputStream instance in the format suited for SSTables.
deserializeIndex(FileDataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
Deserialize the index into a structure and return it
destination - Variable in class org.apache.cassandra.db.compaction.Scrubber
 
destroy() - Method in class org.apache.cassandra.service.CassandraDaemon
Clean up all resources obtained during the lifetime of the daemon.
destroyConnectionPool(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
dfa1 - Variable in class org.apache.cassandra.cql.CqlLexer
 
dfa1 - Variable in class org.apache.cassandra.cql.CqlParser
 
dfa10 - Variable in class org.apache.cassandra.cql.CqlParser
 
dfa11 - Variable in class org.apache.cassandra.cql3.CqlLexer
 
dfa13 - Variable in class org.apache.cassandra.cql.CqlParser
 
dfa13 - Variable in class org.apache.cassandra.cql3.CqlParser
 
dfa15 - Variable in class org.apache.cassandra.cql.CqlLexer
 
dfa18 - Variable in class org.apache.cassandra.cli.CliLexer
 
dfa19 - Variable in class org.apache.cassandra.cql3.CqlLexer
 
dfa2 - Variable in class org.apache.cassandra.cli.CliParser
 
dfa2 - Variable in class org.apache.cassandra.cql3.CqlParser
 
dfa27 - 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
 
dfa63 - Variable in class org.apache.cassandra.cql3.CqlParser
 
dfa7 - Variable in class org.apache.cassandra.cql.CqlLexer
 
dfa80 - Variable in class org.apache.cassandra.cql3.CqlParser
 
dfa88 - Variable in class org.apache.cassandra.cql3.CqlParser
 
dfile - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
 
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
diffrence() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
 
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
 
direction - Variable in enum org.apache.cassandra.transport.Message.Type
 
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.DataDirectory - Class in org.apache.cassandra.db
 
Directories.DataDirectory(File) - Constructor for class org.apache.cassandra.db.Directories.DataDirectory
 
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
 
disable() - Method in class org.apache.cassandra.tools.Shuffle
Disable shuffling on all nodes in the cluster.
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
 
disableConsistencyPredictionLogging() - Method in class org.apache.cassandra.service.PBSPredictor
 
disableConsistencyPredictionLogging() - Method in interface org.apache.cassandra.service.PBSPredictorMBean
 
disableHintedHandoff() - Method in class org.apache.cassandra.tools.NodeProbe
 
disableRelocations(String...) - Method in class org.apache.cassandra.tools.Shuffle
Disable relocations.
disableRelocations(Collection<String>) - Method in class org.apache.cassandra.tools.Shuffle
Disable relocations.
disableScheduledRangeXfers() - Method in class org.apache.cassandra.service.StorageService
 
disableScheduledRangeXfers() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Disable processing of queued range transfers.
discard(boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
Completely discards a segment file by deleting it.
discardCompletedSegments(UUID, 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
 
disk_failure_policy - Variable in class org.apache.cassandra.config.Config
 
DiskAwareRunnable - Class in org.apache.cassandra.io.util
 
DiskAwareRunnable() - Constructor for class org.apache.cassandra.io.util.DiskAwareRunnable
 
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
 
doPrediction(int, int, int, float, int, float) - Method in class org.apache.cassandra.service.PBSPredictor
 
doPrediction(int, int, int, float, int, float) - Method in interface org.apache.cassandra.service.PBSPredictorMBean
 
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(MessageIn<CounterMutation>, String) - Method in class org.apache.cassandra.db.CounterMutationVerbHandler
 
doVerb(MessageIn<Collection<RowMutation>>, String) - Method in class org.apache.cassandra.db.DefinitionsUpdateVerbHandler
 
doVerb(MessageIn, String) - Method in class org.apache.cassandra.db.MigrationRequestVerbHandler
 
doVerb(MessageIn<RowMutation>, String) - Method in class org.apache.cassandra.db.ReadRepairVerbHandler
 
doVerb(MessageIn<ReadCommand>, String) - Method in class org.apache.cassandra.db.ReadVerbHandler
 
doVerb(MessageIn<RowMutation>, String) - Method in class org.apache.cassandra.db.RowMutationVerbHandler
 
doVerb(MessageIn, String) - Method in class org.apache.cassandra.db.SchemaCheckVerbHandler
 
doVerb(MessageIn<Truncation>, String) - Method in class org.apache.cassandra.db.TruncateVerbHandler
 
doVerb(MessageIn, String) - Method in class org.apache.cassandra.dht.BootStrapper.BootstrapTokenVerbHandler
Deprecated.
 
doVerb(MessageIn<GossipDigestAck2>, String) - Method in class org.apache.cassandra.gms.GossipDigestAck2VerbHandler
 
doVerb(MessageIn<GossipDigestAck>, String) - Method in class org.apache.cassandra.gms.GossipDigestAckVerbHandler
 
doVerb(MessageIn<GossipDigestSyn>, String) - Method in class org.apache.cassandra.gms.GossipDigestSynVerbHandler
 
doVerb(MessageIn, String) - Method in class org.apache.cassandra.gms.GossipShutdownVerbHandler
 
doVerb(MessageIn<T>, 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(MessageIn, String) - Method in class org.apache.cassandra.net.ResponseVerbHandler
 
doVerb(MessageIn<AntiEntropyService.TreeRequest>, String) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequestVerbHandler
Trigger a validation compaction which will return the tree upon completion.
doVerb(MessageIn<AntiEntropyService.Validator>, String) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeResponseVerbHandler
 
doVerb(MessageIn<IndexScanCommand>, String) - Method in class org.apache.cassandra.service.IndexScanVerbHandler
Deprecated.
 
doVerb(MessageIn<RangeSliceCommand>, String) - Method in class org.apache.cassandra.service.RangeSliceVerbHandler
 
doVerb(MessageIn<SnapshotCommand>, String) - Method in class org.apache.cassandra.service.SnapshotVerbHandler
 
doVerb(MessageIn, String) - Method in class org.apache.cassandra.streaming.ReplicationFinishedVerbHandler
 
doVerb(MessageIn<StreamingRepairTask>, String) - Method in class org.apache.cassandra.streaming.StreamingRepairTask.StreamingRepairRequest
 
doVerb(MessageIn<UUID>, String) - Method in class org.apache.cassandra.streaming.StreamingRepairTask.StreamingRepairResponse
 
doVerb(MessageIn<StreamReply>, String) - Method in class org.apache.cassandra.streaming.StreamReplyVerbHandler
 
doVerb(MessageIn<StreamRequest>, 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(String) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
drop(String) - Method in interface org.apache.cassandra.auth.IAuthenticator
Called during execution of DROP USER query.
drop(String) - Method in class org.apache.cassandra.auth.LegacyAuthenticator
 
drop(String) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
DROP - Static variable in class org.apache.cassandra.cli.CliLexer
 
DROP - Static variable in class org.apache.cassandra.cli.CliParser
 
dropCf(UUID) - 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 the request timeout.
dropped - Variable in class org.apache.cassandra.metrics.DroppedMessageMetrics
Number of dropped messages
DroppedMessageMetrics - Class in org.apache.cassandra.metrics
Metrics for dropped messages by verb.
DroppedMessageMetrics(MessagingService.Verb) - Constructor for class org.apache.cassandra.metrics.DroppedMessageMetrics
 
dropUserStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
DropUserStatement - Class in org.apache.cassandra.cql3.statements
 
DropUserStatement(String) - Constructor for class org.apache.cassandra.cql3.statements.DropUserStatement
 
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
 
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
 
DynamicEndpointSnitch(IEndpointSnitch, String) - 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
 
effectiveOwnership(String) - Method in class org.apache.cassandra.service.StorageService
Calculates ownership.
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
 
elapsed() - Method in class org.apache.cassandra.tracing.ExpiredTraceState
 
elapsed() - Method in class org.apache.cassandra.tracing.TraceState
 
elementIdx() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
elements - Variable in class org.apache.cassandra.cql3.Lists.Value
 
elements - Variable in class org.apache.cassandra.cql3.Sets.Value
 
elements - Variable in class org.apache.cassandra.db.marshal.ListType
 
elements - Variable in class org.apache.cassandra.db.marshal.SetType
 
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() - Static method in class org.apache.cassandra.db.DataTracker.SSTableIntervalTree
 
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
 
emptyTree() - Static method in class org.apache.cassandra.utils.IntervalTree
 
EmptyType - Class in org.apache.cassandra.db.marshal
A type that only accept empty data.
emptyVersion - Static variable in class org.apache.cassandra.config.Schema
 
enable() - Method in class org.apache.cassandra.tools.Shuffle
Enable shuffling on all nodes in the cluster.
enableAutoCompaction() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
enableConsistencyPredictionLogging() - Method in class org.apache.cassandra.service.PBSPredictor
 
enableConsistencyPredictionLogging() - Method in interface org.apache.cassandra.service.PBSPredictorMBean
 
enabled - Variable in class org.apache.cassandra.config.EncryptionOptions.ClientEncryptionOptions
 
enableHintedHandoff() - Method in class org.apache.cassandra.tools.NodeProbe
 
enableRelocations(String...) - Method in class org.apache.cassandra.tools.Shuffle
Enable relocations.
enableRelocations(Collection<String>) - Method in class org.apache.cassandra.tools.Shuffle
Enable relocations.
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.
enableScheduledRangeXfers() - Method in class org.apache.cassandra.service.StorageService
 
enableScheduledRangeXfers() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Begin processing of queued range transfers.
encode(ResultSet) - Method in class org.apache.cassandra.cql3.ResultSet.Codec
 
encode(T) - Method in interface org.apache.cassandra.transport.CBCodec
 
encode(ChannelHandlerContext, Channel, Object) - Method in class org.apache.cassandra.transport.Frame.Compressor
 
encode(ChannelHandlerContext, Channel, Object) - Method in class org.apache.cassandra.transport.Frame.Encoder
 
encode() - Method in class org.apache.cassandra.transport.Message
 
encode(ChannelHandlerContext, Channel, Object) - Method in class org.apache.cassandra.transport.Message.ProtocolEncoder
 
encode() - Method in class org.apache.cassandra.transport.messages.AuthenticateMessage
 
encode() - Method in class org.apache.cassandra.transport.messages.CredentialsMessage
 
encode() - Method in class org.apache.cassandra.transport.messages.ErrorMessage
 
encode() - Method in class org.apache.cassandra.transport.messages.EventMessage
 
encode() - Method in class org.apache.cassandra.transport.messages.ExecuteMessage
 
encode() - Method in class org.apache.cassandra.transport.messages.OptionsMessage
 
encode() - Method in class org.apache.cassandra.transport.messages.PrepareMessage
 
encode() - Method in class org.apache.cassandra.transport.messages.QueryMessage
 
encode() - Method in class org.apache.cassandra.transport.messages.ReadyMessage
 
encode() - Method in class org.apache.cassandra.transport.messages.RegisterMessage
 
encode() - Method in class org.apache.cassandra.transport.messages.ResultMessage
 
encode() - Method in class org.apache.cassandra.transport.messages.StartupMessage
 
encode() - Method in class org.apache.cassandra.transport.messages.SupportedMessage
 
encode(Map<T, Object>) - Method in class org.apache.cassandra.transport.OptionCodec
 
encodeBody() - Method in class org.apache.cassandra.transport.messages.ResultMessage
 
encodeBody() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
 
encodeBody() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Rows
 
encodeBody() - Method in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
 
encodeBody() - Method in class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
 
encodeBody() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Void
 
EncodedDataInputStream - Class in org.apache.cassandra.utils.vint
Borrows idea from https://developers.google.com/protocol-buffers/docs/encoding#varints Should be used with EncodedDataOutputStream
EncodedDataInputStream(DataInput) - Constructor for class org.apache.cassandra.utils.vint.EncodedDataInputStream
 
EncodedDataOutputStream - Class in org.apache.cassandra.utils.vint
Borrows idea from https://developers.google.com/protocol-buffers/docs/encoding#varints
EncodedDataOutputStream(OutputStream) - Constructor for class org.apache.cassandra.utils.vint.EncodedDataOutputStream
 
encodedUTF8Length(String) - Static method in class org.apache.cassandra.db.TypeSizes
 
encodeOne(Pair<T, Object>) - Method in class org.apache.cassandra.transport.OptionCodec
 
encOptions - Variable in class org.apache.cassandra.cli.CliSessionState
 
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.ClientEncryptionOptions - Class in org.apache.cassandra.config
 
EncryptionOptions.ClientEncryptionOptions() - Constructor for class org.apache.cassandra.config.EncryptionOptions.ClientEncryptionOptions
 
EncryptionOptions.ServerEncryptionOptions - Class in org.apache.cassandra.config
 
EncryptionOptions.ServerEncryptionOptions() - Constructor for class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
EncryptionOptions.ServerEncryptionOptions.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() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
endpoint - Variable in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
endpoint_snitch - Variable in class org.apache.cassandra.config.Config
 
endpoints - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
 
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(MessageOut<?>, String) - Method in class org.apache.cassandra.net.OutboundTcpConnection
 
ensureHasPermission(Permission, IResource) - Method in class org.apache.cassandra.service.ClientState
 
ensureNotAnonymous() - Method in class org.apache.cassandra.service.ClientState
 
entityName() - Method in class org.apache.cassandra.cli.CliParser
 
entries - Variable in class org.apache.cassandra.cql3.Maps.Literal
 
entries - Variable in class org.apache.cassandra.metrics.CacheMetrics
Total number of cache entries
entrySet() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
entrySet() - Method in class org.apache.cassandra.utils.BiMultiValMap
 
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.
enumValueToCB(T) - Static method in class org.apache.cassandra.transport.CBUtil
 
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.auth.AuthenticatedUser
 
equals(Object) - Method in class org.apache.cassandra.auth.DataResource
 
equals(Object) - Method in class org.apache.cassandra.auth.PermissionDetails
 
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.CFDefinition.Name
 
equals(Object) - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
equals(Object) - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
 
equals(Object) - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
 
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.DeletionInfo
 
equals(Object) - Method in class org.apache.cassandra.db.DeletionTime
 
equals(Object) - Method in class org.apache.cassandra.db.ExpiringColumn
 
equals(Object) - Method in class org.apache.cassandra.db.filter.ColumnSlice
 
equals(Object) - Method in class org.apache.cassandra.db.RangeTombstoneList
 
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.CompressionMetadata.Chunk
 
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.io.sstable.Descriptor.Version
 
equals(Object) - Method in class org.apache.cassandra.io.util.Memory
 
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.CounterId.CounterIdRecord
 
equals(Object) - Method in class org.apache.cassandra.utils.CounterId
 
equals(Object) - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
equals(Object) - Method in class org.apache.cassandra.utils.Interval
 
equals(Object) - Method in class org.apache.cassandra.utils.IntervalTree
 
equals(Object) - Method in class org.apache.cassandra.utils.MD5Digest
 
equals(Object) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
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
 
error - Variable in class org.apache.cassandra.transport.messages.ErrorMessage
 
ErrorMessage - Class in org.apache.cassandra.transport.messages
Message to indicate an error to the client.
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
 
establishConnection() - Method in class org.apache.cassandra.transport.SimpleClient
 
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
 
estimatedColumnCountHistogram - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Histogram of estimated number of columns.
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
estimated number of keys to transfer
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
 
estimatedRowSizeHistogram - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Histogram of estimated row size (in bytes).
estimatedTombstoneDropTime - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
estimatedTombstoneDropTime - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
 
estimatedWorkingSize - Variable in class org.apache.cassandra.db.Directories.DataDirectory
 
estimateKeys() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
estimateKeys() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
Event - Class in org.apache.cassandra.transport
 
event - Variable in class org.apache.cassandra.transport.messages.EventMessage
 
Event.SchemaChange - Class in org.apache.cassandra.transport
 
Event.SchemaChange(Event.SchemaChange.Change, String, String) - Constructor for class org.apache.cassandra.transport.Event.SchemaChange
 
Event.SchemaChange(Event.SchemaChange.Change, String) - Constructor for class org.apache.cassandra.transport.Event.SchemaChange
 
Event.SchemaChange.Change - Enum in org.apache.cassandra.transport
 
Event.StatusChange - Class in org.apache.cassandra.transport
 
Event.StatusChange.Status - Enum in org.apache.cassandra.transport
 
Event.TopologyChange - Class in org.apache.cassandra.transport
 
Event.TopologyChange.Change - Enum in org.apache.cassandra.transport
 
Event.Type - Enum in org.apache.cassandra.transport
 
EventMessage - Class in org.apache.cassandra.transport.messages
 
EventMessage(Event) - Constructor for class org.apache.cassandra.transport.messages.EventMessage
 
EVENTS_CF - Static variable in class org.apache.cassandra.tracing.Tracing
 
eventTypes - Variable in class org.apache.cassandra.transport.messages.RegisterMessage
 
exceptionCaught(ChannelHandlerContext, ExceptionEvent) - Method in class org.apache.cassandra.transport.Message.Dispatcher
 
ExceptionCode - Enum in org.apache.cassandra.exceptions
Exceptions code, as defined by the binary protocol.
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(Runnable, TraceState) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
execute(Runnable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
execute(Runnable, TraceState) - Method in interface org.apache.cassandra.concurrent.TracingAwareExecutorService
 
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Constants.Adder
 
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Constants.Deleter
 
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Constants.Setter
 
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Constants.Substracter
 
execute(ConsistencyLevel, QueryState, 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(List<ByteBuffer>) - Method in interface org.apache.cassandra.cql3.functions.Function
 
execute(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.TokenFct
 
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.Appender
 
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.Discarder
 
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.DiscarderByIndex
 
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.Prepender
 
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.Setter
 
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.SetterByIndex
 
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Maps.DiscarderByKey
 
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Maps.Putter
 
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Maps.Setter
 
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Maps.SetterByKey
 
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Operation
Execute the operation.
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Sets.Adder
 
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Sets.Discarder
 
execute(ByteBuffer, ColumnFamily, ColumnNameBuilder, UpdateParameters) - Method in class org.apache.cassandra.cql3.Sets.Setter
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterUserStatement
 
execute(ConsistencyLevel, QueryState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
 
execute(ConsistencyLevel, QueryState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
execute(ClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement.RawStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateUserStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropUserStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.GrantStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListUsersStatement
 
execute(ConsistencyLevel, QueryState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.RevokeStatement
 
execute(ConsistencyLevel, QueryState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
 
execute(ConsistencyLevel, QueryState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
execute(ConsistencyLevel, QueryState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
 
execute(ConsistencyLevel, QueryState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.statements.UseStatement
 
execute(CompactionManager.CompactionExecutorStatsCollector) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
executes the task and unmarks sstables compacting
execute(QueryState) - Method in class org.apache.cassandra.transport.Message.Request
 
execute(QueryState) - Method in class org.apache.cassandra.transport.messages.CredentialsMessage
 
execute(QueryState) - Method in class org.apache.cassandra.transport.messages.ExecuteMessage
 
execute(QueryState) - Method in class org.apache.cassandra.transport.messages.OptionsMessage
 
execute(QueryState) - Method in class org.apache.cassandra.transport.messages.PrepareMessage
 
execute(QueryState) - Method in class org.apache.cassandra.transport.messages.QueryMessage
 
execute(QueryState) - Method in class org.apache.cassandra.transport.messages.RegisterMessage
 
execute(QueryState) - Method in class org.apache.cassandra.transport.messages.StartupMessage
 
execute(String, ConsistencyLevel) - Method in class org.apache.cassandra.transport.SimpleClient
 
execute(Message.Request) - Method in class org.apache.cassandra.transport.SimpleClient
 
execute_cql3_query(ByteBuffer, Compression, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
execute_cql_query(ByteBuffer, Compression) - Method in class org.apache.cassandra.thrift.CassandraServer
 
execute_prepared_cql3_query(int, List<ByteBuffer>, ConsistencyLevel) - 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
 
executeCqlQuery(String, int, boolean, String) - Static method in class org.apache.cassandra.tools.Shuffle
Execute a CQL v3 query.
executeInternal(QueryState) - Method in interface org.apache.cassandra.cql3.CQLStatement
Variante of execute used for internal query against the system tables, and thus only query the local node.
executeInternal(QueryState) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
 
executeInternal(QueryState) - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
executeInternal(QueryState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
executeInternal(QueryState) - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
 
executeInternal(QueryState) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
executeInternal(QueryState) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
 
executeInternal(QueryState) - Method in class org.apache.cassandra.cql3.statements.UseStatement
 
executeInternal(CompactionManager.CompactionExecutorStatsCollector) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
executeInternal(CompactionManager.CompactionExecutorStatsCollector) - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
executeLocally(RangeSliceCommand) - Static method in class org.apache.cassandra.service.RangeSliceVerbHandler
 
ExecuteMessage - Class in org.apache.cassandra.transport.messages
 
ExecuteMessage(byte[], List<ByteBuffer>, ConsistencyLevel) - Constructor for class org.apache.cassandra.transport.messages.ExecuteMessage
 
ExecuteMessage(MD5Digest, List<ByteBuffer>, ConsistencyLevel) - Constructor for class org.apache.cassandra.transport.messages.ExecuteMessage
 
executePrepared(byte[], List<ByteBuffer>, ConsistencyLevel) - Method in class org.apache.cassandra.transport.SimpleClient
 
executor - Variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
exhausted - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
 
exists() - Method in class org.apache.cassandra.auth.DataResource
 
exists() - Method in interface org.apache.cassandra.auth.IResource
 
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
 
ExpiredTraceState - Class in org.apache.cassandra.tracing
 
ExpiredTraceState(UUID) - Constructor for class org.apache.cassandra.tracing.ExpiredTraceState
 
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, ExpiringMap.CacheableObject<V>>, ?>) - Constructor for class org.apache.cassandra.utils.ExpiringMap
 
ExpiringMap.CacheableObject<T> - Class in org.apache.cassandra.utils
 
EXPONENT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
EXPONENT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
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.
expressionString(IndexExpression) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
ExtendedFilter - Class in org.apache.cassandra.db.filter
Extends a column filter (IFilter) to include a number of IndexExpression.
ExtendedFilter(ColumnFamilyStore, IDiskAtomFilter, int, boolean, boolean) - Constructor for class org.apache.cassandra.db.filter.ExtendedFilter
 
EXTENSION - Static variable in class org.apache.cassandra.db.compaction.LeveledManifest
 
extractComponent(ByteBuffer, int) - Static method in class org.apache.cassandra.db.marshal.CompositeType
 
extractExpireTime(String[], int) - Method in class org.apache.cassandra.service.StorageService
 
extractFromVersion(int) - Static method in enum org.apache.cassandra.transport.Message.Direction
 
extractKeyAliasFromColumns(CFMetaData) - Method in class org.apache.cassandra.cql.SelectStatement
 
extractKeysFromColumns(CFMetaData) - Method in class org.apache.cassandra.cql.WhereClause
 
extractLastComponent(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
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(Function) - Static method in class org.apache.cassandra.cql3.functions.AbstractFunction
Creates a trivial factory that always return the provided function.
factory - Static variable in class org.apache.cassandra.cql3.functions.TokenFct
 
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
 
factory - Variable in class org.apache.cassandra.metrics.LatencyMetrics
 
FACTORY - Static variable in class org.apache.cassandra.transport.ServerConnection
 
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.streaming.StreamHeader
file being sent on initial stream
file - Variable in class org.apache.cassandra.streaming.StreamReply
 
file - Variable in class org.apache.cassandra.streaming.StreamRequest
 
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
 
fileName() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
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
 
filter(ColumnFamilyStore.AbstractScanIterator, ExtendedFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
filter - Variable in class org.apache.cassandra.db.filter.QueryFilter
 
filter() - Method in class org.apache.cassandra.db.ReadCommand
 
filter - Variable in class org.apache.cassandra.db.SliceByNamesReadCommand
 
filter() - Method in class org.apache.cassandra.db.SliceByNamesReadCommand
 
filter - Variable in class org.apache.cassandra.db.SliceFromReadCommand
 
filter() - Method in class org.apache.cassandra.db.SliceFromReadCommand
 
FILTER - Static variable in class org.apache.cassandra.io.sstable.Component
 
FilterFactory - Class in org.apache.cassandra.utils
 
FilterFactory() - Constructor for class org.apache.cassandra.utils.FilterFactory
 
FilterFactory.Type - Enum in org.apache.cassandra.utils
 
filterForQuery(Table, List<InetAddress>) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
filterForQuery(Table, List<InetAddress>, ReadRepairDecision) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
filterSuperColumn(SuperColumn, int) - Method in class org.apache.cassandra.db.columniterator.IdentityQueryFilter
 
filterSuperColumn(SuperColumn, int) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
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
filterType - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
 
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
 
findNested(Throwable) - Static method in error org.apache.cassandra.io.FSError
Unwraps the Throwable cause chain looking for an FSError instance
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.ColumnSlice
 
finish() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
finishBootstrapping() - Method in class org.apache.cassandra.service.StorageService
 
finishCompaction(CompactionInfo.Holder) - Method in interface org.apache.cassandra.db.compaction.CompactionManager.CompactionExecutorStatsCollector
 
finishCompaction(CompactionInfo.Holder) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.StatsCollector
 
finishCompaction(CompactionInfo.Holder) - Method in class org.apache.cassandra.metrics.CompactionMetrics
 
finished() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
remove the event complete
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
 
fixSchemaNanoTimestamps() - Static method in class org.apache.cassandra.db.DefsTable
 
flag - Variable in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
flags - Variable in class org.apache.cassandra.cql3.ResultSet.Metadata
 
flags - Variable in class org.apache.cassandra.transport.Frame.Header
 
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
 
floatingPoint(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
 
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, 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
fmix(long) - Static method in class org.apache.cassandra.utils.MurmurHash
 
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_111_in_connectStatement695 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_111_in_connectStatement741 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_112_in_describeCluster2872 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_112_in_helpStatement963 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_113_in_helpStatement1045 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_113_in_showClusterName2407 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_114_in_helpStatement1652 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_115_in_assumeStatement2325 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_115_in_consistencyLevelStatement2367 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_115_in_getStatement1729 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_116_in_getStatement1789 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_117_in_keyValuePair3116 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_117_in_setStatement1960 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_117_in_setStatement1971 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_122_in_dropIndex2678 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_122_in_host_name4132 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_123_in_arrayConstruct3201 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_123_in_columnFamilyExpr3337 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_123_in_columnFamilyExpr3354 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_123_in_columnFamilyExpr3376 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_123_in_keyRangeExpr3445 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_124_in_arrayConstruct3206 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_124_in_hashConstruct3254 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_125_in_arrayConstruct3211 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_125_in_columnFamilyExpr3341 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_125_in_columnFamilyExpr3360 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_125_in_columnFamilyExpr3382 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_125_in_keyRangeExpr3464 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_126_in_hashConstruct3249 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_127_in_batchStatement1762 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_127_in_hashConstruct3260 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_127_in_query75 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_128_in_cfamColumns2035 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_128_in_cfamDefinition1947 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_128_in_cfamProperty2152 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_128_in_createIndexStatement2262 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_128_in_functionArgs4318 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_128_in_functionArgs4330 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_128_in_hashElementPair3298 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_128_in_insertStatement1195 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_128_in_insertStatement1239 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_128_in_keyRangeExpr3454 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_128_in_pkDef2082 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_128_in_relation4861 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_128_in_relation4930 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_128_in_selectionFunctionArgs820 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_128_in_selectionFunctionArgs832 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_128_in_selector940 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_128_in_selector977 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_128_in_selectStatement640 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_128_in_term4444 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_129_in_cfamColumns2052 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_129_in_cfamDefinition1963 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_129_in_cfamProperty2165 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_129_in_columnLimitExpr3539 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_129_in_createIndexStatement2268 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_129_in_functionArgs4320 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_129_in_functionArgs4368 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_129_in_insertStatement1217 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_129_in_insertStatement1260 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_129_in_pkDef2105 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_129_in_relation4881 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_129_in_relation4955 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_129_in_selectionFunctionArgs822 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_129_in_selectionFunctionArgs870 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_129_in_selector946 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_129_in_selector983 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_129_in_selectStatement646 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_129_in_term4450 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_cfamColumns2041 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_cfamDefinition1954 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_cfamProperty2158 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_collection_literal4045 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_collection_type5271 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_deleteSelection1581 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_functionArgs4350 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_insertStatement1206 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_insertStatement1249 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_map_literal3868 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_pkDef2094 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_relation4871 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_relation4941 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_reversedExpr3583 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_130_in_selectClause781 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_selectionFunctionArgs852 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_selectStatement699 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_set_or_map3938 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_set_or_map3983 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_130_in_updateStatement1417 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_131_in_functionCall3985 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_131_in_selectClause797 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_131_in_selectCountClause1035 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_132_in_collection_literal4021 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_132_in_columnOperation4579 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_132_in_deleteOp1641 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_132_in_functionCall3990 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_133_in_collection_literal4065 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_133_in_columnOperation4585 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_133_in_deleteOp1647 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_134_in_columnFamilyName3623 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_135_in_collection_literal4075 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_135_in_collection_literal4106 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_135_in_map_literal3838 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_136_in_map_literal3858 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_136_in_map_literal3874 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_136_in_set_or_map3918 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_136_in_set_or_map3944 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_137_in_collection_literal4088 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_137_in_collection_literal4108 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_137_in_map_literal3894 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_138_in_columnOperation4479 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_138_in_columnOperation4513 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_138_in_columnOperation4551 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_138_in_columnOperation4587 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_138_in_property4648 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_138_in_relationType4755 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_139_in_columnOperation4486 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_141_in_collection_type5265 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_141_in_collection_type5297 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_141_in_collection_type5324 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_141_in_relationType4766 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_142_in_relationType4777 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_143_in_collection_type5277 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_143_in_collection_type5303 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_143_in_collection_type5330 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_143_in_relationType4787 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_144_in_relationType4798 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
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_statement518 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_addKeyspace_in_statement510 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_alterKeyspaceStatement_in_cqlStatement411 - 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_alterUserStatement_in_cqlStatement512 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_AND_in_getStatement1794 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_AND_in_keyValuePairExpr3050 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_API_VERSION_in_helpStatement1134 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_API_VERSION_in_showVersion2717 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_arrayConstruct_in_attrValue3150 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_ASSUME_in_assumeStatement2317 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_ASSUME_in_helpStatement1579 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_assumeStatement_in_statement646 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_attr_name_in_keyValuePair3114 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_attrValue_in_keyValuePair3118 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_attrValueDouble_in_attrValue3182 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_attrValueInt_in_attrValue3174 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_attrValueString_in_attrValue3166 - 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_batchStatement1760 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_BOOLEAN_in_constant3769 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_BY_in_incrStatement2026 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_BY_in_incrStatement2069 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_cfamColumns_in_cfamDefinition1949 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamColumns_in_cfamDefinition1956 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamDefinition_in_createColumnFamilyStatement1928 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamOrdering_in_cfamProperty2154 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamOrdering_in_cfamProperty2160 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamProperty_in_cfamDefinition1975 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamProperty_in_cfamDefinition1982 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfOrKsName_in_columnFamilyName3620 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfOrKsName_in_columnFamilyName3627 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfOrKsName_in_keyspaceName3586 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_alterTableStatement2405 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_alterTableStatement2433 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_alterTableStatement2561 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_alterTableStatement2567 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_alterTableStatement2592 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_alterTableStatement2598 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_cfamColumns2008 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_cfamColumns2045 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_cfamOrdering2193 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_columnOperation4477 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_columnOperation4490 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_columnOperation4511 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_columnOperation4517 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_columnOperation4549 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_columnOperation4555 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_columnOperation4577 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_createIndexStatement2266 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_deleteOp1612 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_deleteOp1639 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_insertStatement1199 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_insertStatement1210 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_orderByClause1130 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_pkDef2072 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_pkDef2088 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_pkDef2098 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_property4646 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_relation4820 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_relation4865 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_relation4875 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_relation4917 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_selector895 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_selector944 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_selector981 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_collection_literal_in_value4155 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_collection_type_in_comparatorType4996 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_COLUMN_in_addColumnFamily2478 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COLUMN_in_delColumnFamily2632 - 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_helpStatement1250 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COLUMN_in_helpStatement1309 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COLUMN_in_updateColumnFamily2555 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_assumeStatement2319 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_columnFamilyExpr3335 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_delColumnFamily2636 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_dropIndex2676 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_getStatement1787 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_listStatement2231 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_truncateStatement2284 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_countStatement2118 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_delStatement2154 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_getStatement1726 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_incrStatement2023 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_incrStatement2066 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_setStatement1958 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyName_in_alterTableStatement2387 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_createColumnFamilyStatement1918 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_createIndexStatement2260 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_dataResource3211 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_deleteStatement1497 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_dropColumnFamilyStatement2681 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_insertStatement1183 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_selectStatement663 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_truncateStatement2753 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_updateStatement1389 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnLimitExpr_in_listStatement2239 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnName_in_dropIndex2680 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnOperation_in_updateStatement1413 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnOperation_in_updateStatement1419 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnOrSuperColumn_in_columnFamilyExpr3358 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnOrSuperColumn_in_columnFamilyExpr3380 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnOrSuperColumn_in_getCondition1856 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_comparatorType_in_alterTableStatement2411 - 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_alterTableStatement2437 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_alterTableStatement2490 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_comparatorType_in_cfamColumns2012 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_collection_type5269 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_collection_type5275 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_collection_type5301 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_collection_type5328 - 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_comparatorType_in_term4448 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_CONNECT_in_connectStatement691 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CONNECT_in_connectStatement737 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CONNECT_in_helpStatement821 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_connectStatement_in_statement470 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CONSISTENCYLEVEL_in_consistencyLevelStatement2365 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CONSISTENCYLEVEL_in_helpStatement1605 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_consistencyLevelStatement_in_statement654 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_constant_in_propertyValue4710 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_constant_in_value4133 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_COUNT_in_countStatement2116 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COUNT_in_helpStatement1499 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_countStatement_in_statement486 - 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_addColumnFamily2476 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CREATE_in_addKeyspace2438 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CREATE_in_helpStatement1160 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CREATE_in_helpStatement1217 - 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_createUserStatement_in_cqlStatement492 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_dataResource_in_resource3149 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_DECR_in_helpStatement1446 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DECR_in_incrStatement2064 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DEL_in_delStatement2152 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DEL_in_helpStatement1472 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_delColumnFamily_in_statement542 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_deleteOp_in_deleteSelection1566 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_deleteOp_in_deleteSelection1585 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_deleteSelection_in_deleteStatement1480 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_deleteStatement_in_batchStatementObjective1209 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_deleteStatement_in_batchStatementObjective1835 - 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_statement550 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_delStatement_in_statement582 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DESCRIBE_in_describeCluster2870 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DESCRIBE_in_describeTable2825 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DESCRIBE_in_helpStatement935 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DESCRIBE_in_helpStatement961 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_describeCluster_in_statement502 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_describeTable_in_statement494 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DoubleLiteral_in_attrValueDouble3694 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DoubleLiteral_in_tracingProbability4254 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DROP_in_delColumnFamily2630 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DROP_in_delKeyspace2592 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DROP_in_dropIndex2670 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DROP_in_helpStatement1278 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DROP_in_helpStatement1307 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DROP_in_helpStatement1338 - 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_statement662 - 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_dropUserStatement_in_cqlStatement533 - Static variable in class org.apache.cassandra.cql3.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_assumeStatement2327 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_entityName_in_columnFamily3821 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_entityName_in_columnName3611 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_entityName_in_keyRangeExpr3451 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_entityName_in_keyRangeExpr3458 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_entityName_in_keyspace3710 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_entityName_in_keyspaceNewName3738 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_entityName_in_keyValuePairExpr3045 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_entityName_in_newColumnFamily3785 - 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_root454 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_EXIT_in_exitStatement1701 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_EXIT_in_helpStatement989 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_exitStatement_in_statement478 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_FAMILY_in_addColumnFamily2480 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_FAMILY_in_delColumnFamily2634 - 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_helpStatement1252 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_FAMILY_in_helpStatement1311 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_FAMILY_in_updateColumnFamily2557 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_FLOAT_in_constant3748 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_FLOAT_in_term2818 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_functionArgs_in_term4434 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_functionArgument_in_functionCall3987 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_functionCall_in_columnOrSuperColumn4074 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_functionCall_in_rowKey3882 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_functionCall_in_rowValue3920 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_functionCall_in_value3962 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_functionName_in_selector1008 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_functionName_in_term4430 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_GET_in_getStatement1724 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_GET_in_getStatement1785 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_GET_in_helpStatement1366 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_getCondition_in_getStatement1791 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_getCondition_in_getStatement1796 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_getStatement_in_statement590 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_grantStatement_in_cqlStatement428 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_hashConstruct_in_arrayConstruct3204 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_hashConstruct_in_attrValue3158 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_hashConstruct_in_rowValue3924 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_hashElementPair_in_hashConstruct3251 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_hashElementPair_in_hashConstruct3256 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1014 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1041 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1069 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1098 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1130 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1158 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1187 - 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_helpStatement1276 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1305 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1336 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1364 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1391 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1418 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1444 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1470 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1497 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1524 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1551 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1577 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1603 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1629 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement792 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement794 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement819 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement846 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement873 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement903 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement933 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement959 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement987 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_helpStatement_in_statement598 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HEXNUMBER_in_constant3810 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_host_in_connectStatement693 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_host_name_in_host4096 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IDENT_in_cfOrKsName3648 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IDENT_in_cident3509 - 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_createIndexStatement2252 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IDENT_in_dropIndexStatement2718 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IDENT_in_functionName4229 - 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_assumeStatement2323 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_attr_name3625 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_columnOrSuperColumn4058 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_command3771 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_consistencyLevelStatement2371 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_functionCall3983 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_host_name4129 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_host_name4134 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_rowKey3866 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_rowValue3904 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_traceSessionId4237 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_username3794 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_value3946 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_INCR_in_helpStatement1420 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_INCR_in_incrStatement2021 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_incrementValue_in_incrStatement2030 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_incrementValue_in_incrStatement2073 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_incrStatement_in_statement614 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_INDEX_in_dropIndex2672 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_INDEX_in_helpStatement1340 - 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_batchStatementObjective1809 - 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_columnOperation4559 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_INTEGER_in_constant3729 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_INTEGER_in_intTerm2943 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_INTEGER_in_selectCountClause1057 - 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_selectStatement722 - 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_usingClauseDelete1673 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_INTEGER_in_usingClauseDeleteObjective1024 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_INTEGER_in_usingClauseObjective1057 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_INTEGER_in_usingClauseObjective1337 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_INTEGER_in_usingClauseObjective1351 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IntegerNegativeLiteral_in_columnOrSuperColumn4066 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerNegativeLiteral_in_rowKey3878 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerNegativeLiteral_in_rowValue3916 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerNegativeLiteral_in_value3954 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_columnLimitExpr3543 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_columnOrSuperColumn4062 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_getStatement1740 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_getStatement1805 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_port4195 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_rowKey3874 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_rowLimitExpr3505 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_rowValue3912 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_setStatement1975 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_value3950 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_intTerm_in_termPairWithOperation3047 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_ip_address_in_connectStatement739 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IP_ADDRESS_in_ip_address4157 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_K_ADD_in_alterTableStatement2427 - 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_ALL_in_dataResource3172 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALL_in_permissionOrAll3092 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALLOW_in_selectStatement737 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALTER_in_alterKeyspaceStatement2327 - 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_ALTER_in_alterTableStatement2381 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALTER_in_alterTableStatement2401 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALTER_in_alterUserStatement3332 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AND_in_alterTableStatement2588 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AND_in_alterTableStatement2611 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_AND_in_cfamDefinition1980 - 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_properties4621 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AND_in_usingClause1309 - 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_usingClauseDelete982 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_AND_in_whereClause1097 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AND_in_whereClause676 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_APPLY_in_batchStatement1148 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_APPLY_in_batchStatement1776 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ASC_in_cfamOrdering2196 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ASC_in_orderByClause1135 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ASCII_in_native_type5037 - 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_batchStatement1736 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BATCH_in_batchStatement1778 - 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_batchStatement1707 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BIGINT_in_native_type5051 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BLOB_in_native_type5064 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BOOLEAN_in_native_type5079 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BY_in_cfamProperty2150 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BY_in_selectStatement692 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CLUSTERING_in_cfamProperty2146 - 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_alterTableStatement2383 - 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_createColumnFamilyStatement1914 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COLUMNFAMILY_in_dataResource3202 - 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_COLUMNFAMILY_in_dropColumnFamilyStatement2677 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COMPACT_in_cfamProperty2134 - 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_usingClauseDeleteObjective1007 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_COUNT_in_selectStatement337 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_COUNT_in_selectStatement638 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COUNTER_in_batchStatement1723 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COUNTER_in_native_type5091 - 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_createColumnFamilyStatement1912 - 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_createIndexStatement2238 - 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_CREATE_in_createKeyspaceStatement1870 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CREATE_in_createUserStatement3251 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CUSTOM_in_createIndexStatement2241 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DECIMAL_in_native_type5103 - 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_DELETE_in_deleteStatement1474 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DESC_in_cfamOrdering2200 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DESC_in_orderByClause1139 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DOUBLE_in_native_type5115 - 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_dropColumnFamilyStatement2671 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_DROP_in_dropColumnFamilyStatement2675 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DROP_in_dropIndexStatement2221 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_DROP_in_dropIndexStatement2712 - 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_DROP_in_dropKeyspaceStatement2644 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DROP_in_dropUserStatement3404 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FILTERING_in_selectStatement739 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FIRST_in_selectExpression524 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_FLOAT_in_native_type5128 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FROM_in_deleteStatement1493 - 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_revokeStatement2901 - 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_selectStatement659 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_GRANT_in_grantStatement2778 - 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_relation4919 - 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_createIndexStatement2150 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_INDEX_in_createIndexStatement2247 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_INDEX_in_dropIndexStatement2223 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_INDEX_in_dropIndexStatement2714 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_INET_in_native_type5142 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_INSERT_in_insertStatement1177 - 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_INT_in_native_type5157 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_INTO_in_insertStatement1179 - 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_KEY_in_cfamColumns2019 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEY_in_cfamColumns2033 - 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_alterKeyspaceStatement2329 - 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_createKeyspaceStatement1872 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEYSPACE_in_dataResource3184 - 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_KEYSPACE_in_dropKeyspaceStatement2646 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEYSPACES_in_dataResource3174 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_LEVEL_in_selectStatement424 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_LEVEL_in_usingClauseDeleteObjective1009 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_LIMIT_in_selectStatement462 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_LIMIT_in_selectStatement718 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_LIST_in_collection_type5295 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_LIST_in_listPermissionsStatement2951 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_LIST_in_listUsersStatement3433 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_MAP_in_collection_type5262 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NORECURSIVE_in_listPermissionsStatement3007 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NOSUPERUSER_in_alterUserStatement3368 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NOSUPERUSER_in_createUserStatement3287 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NULL_in_value4165 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_OF_in_listPermissionsStatement2990 - 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_createIndexStatement2256 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ON_in_grantStatement2798 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ON_in_listPermissionsStatement2973 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ON_in_revokeStatement2881 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ORDER_in_cfamProperty2148 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ORDER_in_selectStatement690 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_PASSWORD_in_userOption3476 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_PERMISSION_in_permissionOrAll3121 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_PERMISSIONS_in_permissionOrAll3096 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_PRIMARY_in_cfamColumns2017 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_PRIMARY_in_cfamColumns2031 - 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_RENAME_in_alterTableStatement2507 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_REVERSED_in_selectExpression545 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_REVOKE_in_revokeStatement2861 - 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_selectStatement627 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_SET_in_collection_type5321 - 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_SET_in_updateStatement1411 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_STORAGE_in_cfamProperty2136 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_SUPERUSER_in_alterUserStatement3362 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_SUPERUSER_in_createUserStatement3281 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TEXT_in_native_type5173 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TIMESTAMP_in_native_type5188 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TIMESTAMP_in_usingClauseDelete1669 - 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_usingClauseObjective1333 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TIMEUUID_in_native_type5238 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TO_in_alterTableStatement2563 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TO_in_alterTableStatement2594 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TO_in_grantStatement2818 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TOKEN_in_functionName4273 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TOKEN_in_relation4838 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TRUNCATE_in_truncateStatement2749 - 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_selector969 - 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_usingClauseObjective1347 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TYPE_in_alterTableStatement2407 - 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_UNLOGGED_in_batchStatement1717 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_UPDATE_in_updateStatement1243 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_UPDATE_in_updateStatement1385 - 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_useStatement589 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USER_in_alterUserStatement3334 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USER_in_createUserStatement3253 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USER_in_dropUserStatement3406 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USERS_in_listUsersStatement3435 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USING_in_createIndexStatement2280 - 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_usingClause1302 - 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_usingClauseDelete1667 - 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_UUID_in_native_type5198 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_VALUES_in_insertStatement1227 - 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_VARCHAR_in_native_type5213 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_VARINT_in_native_type5225 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WHERE_in_deleteStatement1519 - 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_selectStatement673 - 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_WHERE_in_updateStatement1430 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WITH_in_alterKeyspaceStatement2343 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WITH_in_alterTableStatement2471 - 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_alterUserStatement3346 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WITH_in_cfamDefinition1973 - 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_createKeyspaceStatement1738 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_WITH_in_createKeyspaceStatement1884 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WITH_in_createUserStatement3265 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WRITETIME_in_selector938 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_keyRangeExpr_in_listStatement2233 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_addKeyspace2440 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_delKeyspace2594 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyspace_in_delKeyspace2596 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyspace_in_describeTable2828 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_helpStatement1162 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_helpStatement1191 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_helpStatement1280 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyspace_in_showSchema2787 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_updateKeyspace2518 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyspace_in_useKeyspace2905 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyspaceName_in_alterKeyspaceStatement2333 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_keyspaceName_in_createKeyspaceStatement1876 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_keyspaceName_in_dataResource3190 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_keyspaceName_in_dropKeyspaceStatement2650 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_keyspaceName_in_useStatement593 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_KEYSPACES_in_helpStatement1073 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACES_in_showKeyspaces2750 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyValuePair_in_keyValuePairExpr3057 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyValuePairExpr_in_addColumnFamily2482 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyValuePairExpr_in_addKeyspace2442 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyValuePairExpr_in_updateColumnFamily2559 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyValuePairExpr_in_updateKeyspace2520 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_LIMIT_in_getStatement1736 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_LIMIT_in_getStatement1801 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_LIMIT_in_rowLimitExpr3501 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_LIST_in_helpStatement1526 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_LIST_in_listStatement2229 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_listPermissionsStatement_in_cqlStatement477 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_listStatement_in_statement630 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_listUsersStatement_in_cqlStatement555 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_map_literal_in_property4682 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_native_type_in_comparatorType4980 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_native_type_in_unreserved_function_keyword5679 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_NEXT_in_helpStatement877 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_NEXT_in_traceNextQuery2973 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_ON_in_dropIndex2674 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_operator_in_getCondition1858 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_orderByClause_in_selectStatement694 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_orderByClause_in_selectStatement701 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_password_in_connectStatement702 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_password_in_connectStatement748 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_password_in_useKeyspace2916 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_permission_in_permissionOrAll3117 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_permissionOrAll_in_grantStatement2790 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_permissionOrAll_in_listPermissionsStatement2963 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_permissionOrAll_in_revokeStatement2873 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_pkDef_in_cfamColumns2037 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_port_in_connectStatement697 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_port_in_connectStatement743 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_PROBABILITY_in_helpStatement909 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_PROBABILITY_in_setTraceProbability3010 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_properties_in_alterKeyspaceStatement2345 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_properties_in_alterTableStatement2474 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_properties_in_createKeyspaceStatement1886 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_property_in_cfamProperty2125 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_property_in_properties4617 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_property_in_properties4623 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_propertyValue_in_property4653 - 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_value4189 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QUERY_in_helpStatement879 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_QUERY_in_traceNextQuery2975 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_QUIT_in_exitStatement1687 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_QUIT_in_helpStatement1016 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_QUOTED_NAME_in_cfOrKsName3673 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QUOTED_NAME_in_cident3534 - 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_whereClause1093 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_relation_in_whereClause1099 - Static variable in class org.apache.cassandra.cql3.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_relationType_in_relation4824 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_relationType_in_relation4893 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_resource_in_grantStatement2810 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_resource_in_listPermissionsStatement2975 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_resource_in_revokeStatement2893 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_reversedExpr_in_columnLimitExpr3545 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_revokeStatement_in_cqlStatement453 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_rowKey_in_columnFamilyExpr3339 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_rowKey_in_hashElementPair3296 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_rowLimitExpr_in_listStatement2236 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_rowValue_in_hashElementPair3300 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SCHEMA_in_helpStatement1102 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SCHEMA_in_showSchema2784 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_selectClause_in_selectStatement633 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_selectCountClause_in_selectStatement644 - 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_selectionFunctionArgs_in_selector1012 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_selector_in_selectClause776 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_selector_in_selectClause785 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_selector_in_selectionFunctionArgs836 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_selector_in_selectionFunctionArgs856 - 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_root451 - 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_attrValueString3642 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_columnOperation4521 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
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_entityName3834 - 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_helpStatement1393 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SET_in_helpStatement905 - 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_operator0 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_permission3043 - 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_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_setStatement1956 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SET_in_setTraceProbability3006 - Static variable in class org.apache.cassandra.cli.CliParser
 
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_function_keyword5439 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_set_in_unreserved_keyword5404 - 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_username0 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_set_in_useStatement242 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_or_map_in_collection_literal4083 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_setStatement_in_statement606 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_setTraceProbability_in_statement574 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_helpStatement1043 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_helpStatement1071 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_helpStatement1100 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_helpStatement1132 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_showClusterName2405 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_showKeyspaces2748 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_showSchema2782 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_showVersion2715 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_showClusterName_in_showStatement2188 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_showKeyspaces_in_showStatement2204 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_showSchema_in_showStatement2212 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_showStatement_in_statement622 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_showVersion_in_showStatement2196 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_statement_in_root449 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_STRING_LITERAL_in_comparatorType5008 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_STRING_LITERAL_in_constant3717 - 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_createIndexStatement2284 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_STRING_LITERAL_in_term2794 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_STRING_LITERAL_in_userOption3480 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_StringLiteral_in_columnOrSuperColumn4070 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_StringLiteral_in_comparator3752 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_StringLiteral_in_password3806 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_StringLiteral_in_replica_placement_strategy3724 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_StringLiteral_in_rowKey3870 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_StringLiteral_in_rowValue3908 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_StringLiteral_in_value3958 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_term_in_collection_literal4039 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_collection_literal4049 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_collection_literal4079 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_columnOperation4483 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_columnOperation4531 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_columnOperation4583 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_columnOperation4591 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
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_deleteOp1645 - Static variable in class org.apache.cassandra.cql3.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_functionArgs4334 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_functionArgs4354 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_insertStatement1243 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_insertStatement1253 - 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_map_literal3856 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_map_literal3862 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_map_literal3872 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_map_literal3878 - Static variable in class org.apache.cassandra.cql3.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_relation4828 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_relation4897 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_relation4936 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_relation4945 - 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_set_or_map3922 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_set_or_map3942 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_set_or_map3948 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_set_or_map3987 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_term4454 - Static variable in class org.apache.cassandra.cql3.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_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_updateStatement1310 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_termPairWithOperation_in_updateStatement1316 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_TRACE_in_helpStatement875 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_TRACE_in_helpStatement907 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_TRACE_in_setTraceProbability3008 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_TRACE_in_traceNextQuery2971 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_traceNextQuery_in_statement566 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_tracingProbability_in_setTraceProbability3012 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_TRUNCATE_in_helpStatement1553 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_TRUNCATE_in_truncateStatement2282 - 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_statement638 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_TTL_in_setStatement1969 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_typeIdentifier_in_getStatement1731 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_unreserved_function_keyword_in_functionName4263 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unreserved_function_keyword_in_unreserved_keyword5388 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unreserved_keyword_in_cfOrKsName3692 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unreserved_keyword_in_cident3553 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unreserved_keyword_in_propertyValue4732 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_UPDATE_in_helpStatement1189 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_UPDATE_in_helpStatement1248 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_UPDATE_in_updateColumnFamily2553 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_UPDATE_in_updateKeyspace2516 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_updateColumnFamily_in_statement534 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_updateKeyspace_in_statement526 - 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_batchStatementObjective1822 - 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_helpStatement848 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_USE_in_useKeyspace2903 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_useKeyspace_in_statement558 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_username_in_alterUserStatement3336 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_username_in_connectStatement700 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_username_in_connectStatement746 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_username_in_createUserStatement3255 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_username_in_dropUserStatement3408 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_username_in_grantStatement2830 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_username_in_listPermissionsStatement2992 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_username_in_revokeStatement2913 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_username_in_useKeyspace2909 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_userOption_in_userOptions3455 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userOptions_in_alterUserStatement3348 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userOptions_in_createUserStatement3267 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
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_batchStatement1740 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClause_in_insertStatement1272 - 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_updateStatement1292 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_usingClause_in_updateStatement1399 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClauseDelete_in_deleteStatement1507 - 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_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_usingClauseObjective_in_usingClause1304 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClauseObjective_in_usingClause1311 - 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_constant3788 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_UUID_in_term2806 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_value_in_getCondition1860 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_value_in_setStatement1964 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_value_in_term4393 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_whereClause_in_deleteStatement1523 - 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_selectStatement677 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_whereClause_in_updateStatement1434 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_WITH_in_keyValuePairExpr3054 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_WITH_in_setStatement1967 - Static variable in class org.apache.cassandra.cli.CliParser
 
forceBatchlogReplay() - Method in class org.apache.cassandra.db.BatchlogManager
 
forceBatchlogReplay() - Method in interface org.apache.cassandra.db.BatchlogManagerMBean
Forces batchlog replay.
forceBlockingFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceBlockingFlush() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
forceBlockingFlush() - Method in class org.apache.cassandra.db.index.SecondaryIndex
Forces this indexes in memory data to disk
forceBlockingFlush(String) - Static method in class org.apache.cassandra.db.SystemTable
 
forceCleanup(CounterId.OneShotRenewer) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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
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
 
forceRepairAsync(String, boolean, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceRepairAsync(String, boolean, boolean, Collection<Range<Token>>, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceRepairAsync(String, boolean, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Invoke repair asynchronously.
forceRepairAsync(PrintStream, String, boolean, boolean, boolean, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceRepairRangeAsync(String, String, String, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceRepairRangeAsync(String, String, String, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Same as forceRepairAsync, but handles a specified range
forceRepairRangeAsync(PrintStream, String, boolean, boolean, String, String, String...) - 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, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
Trigger proactive repair for a table and column families.
forceTableRepair(Range<Token>, String, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceTableRepair(String, boolean, 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, boolean, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceTableRepairPrimaryRange(String, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceTableRepairPrimaryRange(String, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Triggers proactive repair but only for the node primary range.
forceTableRepairPrimaryRange(String, boolean, boolean, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceTableRepairRange(String, String, String, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceTableRepairRange(String, Collection<Range<Token>>, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceTableRepairRange(String, String, String, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Perform repair of a specific range.
forceTableRepairRange(String, String, String, boolean, 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
 
forThrift(int, List<ColumnSpecification>) - Static method in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
 
FORWARD_FROM - Static variable in class org.apache.cassandra.db.RowMutation
 
FORWARD_TO - Static variable in class org.apache.cassandra.db.RowMutation
 
forwardMap - Variable in class org.apache.cassandra.utils.BiMultiValMap
 
Frame - Class in org.apache.cassandra.transport
 
Frame.Compressor - Class in org.apache.cassandra.transport
 
Frame.Compressor() - Constructor for class org.apache.cassandra.transport.Frame.Compressor
 
Frame.Decoder - Class in org.apache.cassandra.transport
 
Frame.Decoder(Connection.Tracker, Connection.Factory) - Constructor for class org.apache.cassandra.transport.Frame.Decoder
 
Frame.Decompressor - Class in org.apache.cassandra.transport
 
Frame.Decompressor() - Constructor for class org.apache.cassandra.transport.Frame.Decompressor
 
Frame.Encoder - Class in org.apache.cassandra.transport
 
Frame.Encoder() - Constructor for class org.apache.cassandra.transport.Frame.Encoder
 
Frame.Header - Class in org.apache.cassandra.transport
 
Frame.Header.Flag - Enum in org.apache.cassandra.transport
 
FrameCompressor - Interface in org.apache.cassandra.transport
 
FrameCompressor.SnappyCompressor - Class in org.apache.cassandra.transport
 
FramedTransportFactory - Class in org.apache.cassandra.cli.transport
 
FramedTransportFactory() - Constructor for class org.apache.cassandra.cli.transport.FramedTransportFactory
 
free() - Method in class org.apache.cassandra.io.util.Memory
 
freshSegment() - Static method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
from - Variable in class org.apache.cassandra.net.IncomingTcpConnection
 
from - Variable in class org.apache.cassandra.net.MessageIn
 
from - Variable in class org.apache.cassandra.net.MessageOut
 
fromByteArray(ByteBuffer) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
fromCode(int) - Static method in enum org.apache.cassandra.db.ConsistencyLevel
 
fromException(Throwable) - Static method in class org.apache.cassandra.transport.messages.ErrorMessage
 
fromFileName(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
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-][-]-"
fromId(int) - Static method in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
 
fromInt(int) - Static method in class org.apache.cassandra.utils.CounterId
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
 
fromName(String) - Static method in class org.apache.cassandra.auth.DataResource
Parses a data resource name into a DataResource instance.
fromOpcode(int, Message.Direction) - Static method in enum org.apache.cassandra.transport.Message.Type
 
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
fromSelectors(CFDefinition, List<RawSelector>) - Static method in class org.apache.cassandra.cql3.statements.Selection
 
fromSerialized(ByteBuffer, ListType) - Static method in class org.apache.cassandra.cql3.Lists.Value
 
fromSerialized(ByteBuffer, MapType) - Static method in class org.apache.cassandra.cql3.Maps.Value
 
fromSerialized(ByteBuffer, SetType) - Static method in class org.apache.cassandra.cql3.Sets.Value
 
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.CollectionType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
 
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.EmptyType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.FloatType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.InetAddressType
 
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
 
fromStringCQL2(String) - Method in class org.apache.cassandra.db.marshal.AbstractType
for compatibility with TimeUUID in CQL2.
fromStringCQL2(String) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
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
 
fromThrift(ConsistencyLevel) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
fromType(AbstractType) - Static method in enum org.apache.cassandra.transport.DataType
 
fromValue(int) - Static method in enum org.apache.cassandra.exceptions.ExceptionCode
 
FSError - Error in org.apache.cassandra.io
 
FSError(Throwable, File) - Constructor for error org.apache.cassandra.io.FSError
 
FSReadError - Error in org.apache.cassandra.io
 
FSReadError(Throwable, File) - Constructor for error org.apache.cassandra.io.FSReadError
 
FSReadError(Throwable, String) - Constructor for error org.apache.cassandra.io.FSReadError
 
FSWriteError - Error in org.apache.cassandra.io
 
FSWriteError(Throwable, File) - Constructor for error org.apache.cassandra.io.FSWriteError
 
FSWriteError(Throwable, String) - Constructor for error org.apache.cassandra.io.FSWriteError
 
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 - Interface in org.apache.cassandra.cql3.functions
 
Function.Factory - Interface in org.apache.cassandra.cql3.functions
 
FUNCTION_CALL - Static variable in class org.apache.cassandra.cli.CliLexer
 
FUNCTION_CALL - Static variable in class org.apache.cassandra.cli.CliParser
 
functionArgs() - Method in class org.apache.cassandra.cql3.CqlParser
 
functionArgument() - Method in class org.apache.cassandra.cli.CliParser
 
functionCall() - Method in class org.apache.cassandra.cli.CliParser
 
FunctionCall - Class in org.apache.cassandra.cql3.functions
 
FunctionCall.Raw - Class in org.apache.cassandra.cql3.functions
 
FunctionCall.Raw(String, List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.functions.FunctionCall.Raw
 
functionName() - Method in class org.apache.cassandra.cql3.CqlParser
 
functionName - Variable in class org.apache.cassandra.cql3.statements.RawSelector.WithFunction
 
Functions - Class in org.apache.cassandra.cql3.functions
 

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
 
gatherTombstones(ColumnFamily, CloseableIterator<OnDiskAtom>) - Static method in class org.apache.cassandra.db.filter.QueryFilter
Given an iterator of on disk atom, returns an iterator that filters the tombstone range markers adding them to returnCF and returns the normal column.
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.CounterId
 
generateCFMetadataUpdate() - 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(K) - 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(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.CFDefinition
 
get() - Method in class org.apache.cassandra.cql3.Constants.Value
 
get(String, List<? extends AssignementTestable>, ColumnSpecification) - Static method in class org.apache.cassandra.cql3.functions.Functions
 
get() - Method in class org.apache.cassandra.cql3.Lists.Value
 
get() - Method in class org.apache.cassandra.cql3.Maps.Value
 
get() - Method in class org.apache.cassandra.cql3.Sets.Value
 
get() - Method in class org.apache.cassandra.cql3.Term.Terminal
 
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(String, String) - Static method in class org.apache.cassandra.locator.SnitchProperties
Get a snitch property value or return null if not defined.
get(InetAddress) - Static method in class org.apache.cassandra.metrics.StreamingMetrics
 
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 class org.apache.cassandra.service.ReadCallback
 
get() - Method in class org.apache.cassandra.service.TruncateResponseHandler
 
get(InetAddress, UUID) - Static method in class org.apache.cassandra.streaming.StreamInSession
 
get(UUID) - Static method in class org.apache.cassandra.streaming.StreamOutSession
 
get(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
get() - Method in class org.apache.cassandra.tracing.Tracing
 
get(UUID) - Method in class org.apache.cassandra.tracing.Tracing
 
get(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
 
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(long) - Method in interface org.apache.cassandra.utils.obs.IBitSet
Returns true or false for the specified bit index.
get(long) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
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
Deprecated.
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
 
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
getAllEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
 
getAllEndpointStates() - Method in class org.apache.cassandra.gms.FailureDetector
 
getAllEndpointStates() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
getAllLevelSize() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
getAllLevelSize() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
getAllLocalAddresses() - Static method in class org.apache.cassandra.utils.FBUtilities
 
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
 
getAndAppendComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
Adds type information from @param bb to @param sb.
getAndAppendComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
getAndAppendComparator(int, ByteBuffer, StringBuilder) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
getAndReferenceOverlappingSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
like getOverlappingSSTables, but acquires references before returning
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.
getArrayHeaderSize() - Method in interface org.apache.cassandra.utils.ObjectSizes.MemoryLayoutSpecification
 
getArraySize(int, long) - Static method in class org.apache.cassandra.utils.ObjectSizes
Memory an array will consume
getArraySize(byte[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
Memory a byte array consumes
getAsMap() - Method in class org.apache.cassandra.utils.StreamingHistogram
 
getAuthenticator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getAuthorizer() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getAvailableProcessors() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getAverageReadLatency() - Method in class org.apache.cassandra.service.PBSPredictionResult
 
getAverageWriteLatency() - Method in class org.apache.cassandra.service.PBSPredictionResult
 
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
Deprecated.
getBaseCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndex
 
getBatchlogMutationFor(Collection<RowMutation>, UUID) - Static method in class org.apache.cassandra.db.BatchlogManager
 
getBits(int, int, int) - Static method in class org.apache.cassandra.net.MessagingService
 
getBitSet() - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
getblock(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.MurmurHash
 
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
Deprecated.
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
Deprecated.
getBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getBloomFilterFalseRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Deprecated.
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() - 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(TokenMetadata, Map<InetAddress, Double>) - Static method in class org.apache.cassandra.dht.BootStrapper
if initialtoken was specified, use that (split on comma).
getBootstrapTokens() - Method in class org.apache.cassandra.locator.TokenMetadata
 
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.AuthenticationStatement
 
getBoundsTerms() - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
getBoundsTerms() - Method in class org.apache.cassandra.cql3.statements.ParsedStatement
 
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.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.
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
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, 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
 
getCanonicalPath(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
getCanonicalPath(File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
getCapacity() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
getCF(UUID) - Method in class org.apache.cassandra.config.Schema
 
getCfDef() - Method in class org.apache.cassandra.config.CFMetaData
 
getCfDef(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
get the columnfamily definition for the signature
getCfDef(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
return the CfDef for the column family
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(UUID) - 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
 
getChunksForSections(Collection<Pair<Long, Long>>) - Method in class org.apache.cassandra.io.compress.CompressionMetadata
 
getClass(String) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getClause() - Method in class org.apache.cassandra.db.filter.ExtendedFilter
 
getClientEncryptionOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getClientFromInputAddressList(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getClientFromOutputAddressList(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getClientState() - Method in class org.apache.cassandra.service.QueryState
 
getClientTransportFactory(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getClock() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
getClosingString() - Method in class org.apache.cassandra.dht.AbstractBounds
 
getClosingString() - Method in class org.apache.cassandra.dht.Bounds
 
getClosingString() - Method in class org.apache.cassandra.dht.ExcludingBounds
 
getClosingString() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
getClosingString() - Method in class org.apache.cassandra.dht.Range
 
getClusterName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCollection(ByteBuffer) - Method in class org.apache.cassandra.cql3.statements.ColumnGroupMap
 
getCollectionsParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
 
getCollectionType() - Method in class org.apache.cassandra.cql3.CFDefinition
 
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.IDiskAtomFilter
 
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
Returns the ColumnDefinition for name.
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
 
getColumnDefinitionFromColumnName(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
Returns a ColumnDefinition given a full (internal) column name.
getColumnDefs() - Method in class org.apache.cassandra.db.index.SecondaryIndex
 
getColumnFamilies() - Method in class org.apache.cassandra.db.RowMutation
 
getColumnFamily() - Method in class org.apache.cassandra.auth.DataResource
 
getColumnFamily(Tree, Iterable<CfDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getColumnFamily(String, Iterable<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.DropIndexStatement
 
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() - Method in class org.apache.cassandra.db.columniterator.LazyColumnIterator
 
getColumnFamily() - Method in interface org.apache.cassandra.db.columniterator.OnDiskAtomIterator
 
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(UUID) - 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(String) - Method in class org.apache.cassandra.db.Table
 
getColumnFamilyStore(UUID) - 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(ISortedColumns.Factory) - 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
 
getColumnMeta(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
get column meta data
getColumnMetadata(Cassandra.Client, boolean) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
get a list of columns
getColumnMetadata(Cassandra.Client, boolean) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
get a list of column for the column family
getColumnMetadata(Cassandra.Client, boolean) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
include key columns
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
 
getColumnsList() - Method in class org.apache.cassandra.cql3.statements.Selection
 
getColumnsString(Collection<IColumn>) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
getColumnStart() - Method in class org.apache.cassandra.cql.SelectStatement
 
getColumnStats() - Method in class org.apache.cassandra.db.ColumnFamily
 
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(InetAddress) - 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
getCompacting() - Method in class org.apache.cassandra.db.DataTracker
 
getCompactionCandidates() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
getCompactionController(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
getCompactionController(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
 
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
 
getCompactionOptions() - Method in class org.apache.cassandra.cql3.CFPropDefs
 
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.
getCompactions() - Static method in class org.apache.cassandra.metrics.CompactionMetrics
 
getCompactionStrategy() - Method in class org.apache.cassandra.cql3.CFPropDefs
 
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.
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(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
getComparator(int, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
Adds DynamicCompositeType type information from @param bb1 to @param bb2.
getComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
getComparator(int, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
getComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
getComparator(int, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
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
 
getCompleted() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getCompletedMesssages() - Method in class org.apache.cassandra.net.OutboundTcpConnection
 
getCompletedTasks() - Method in interface org.apache.cassandra.concurrent.IExecutorMBean
Deprecated.
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
Deprecated.
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
Deprecated.
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.
getCompressionOptions() - Method in class org.apache.cassandra.cql3.CFPropDefs
 
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
Deprecated.
getCompressionRatio() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getCompressor() - Method in class org.apache.cassandra.transport.Connection
 
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, MessageOut) - 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.
getConsistencyProbability() - Method in class org.apache.cassandra.service.PBSPredictionResult
 
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.
getCoreCompactorThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getCoreCompactorThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Returns core size of compaction thread pool
getCorePoolSize() - Method in interface org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutorMBean
 
getCoreThreads() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
getCoreThreads() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
Deprecated.
Returns core pool size of thread pool.
getCoreValidationThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getCoreValidationThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Returns core size of validation thread pool
getCount() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
getCounterId() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
getCQLSupportedVersion() - Static method in class org.apache.cassandra.service.ClientState
 
getCQLVersion() - Method in class org.apache.cassandra.service.ClientState
 
getCrcCheckChance() - Method in class org.apache.cassandra.io.compress.CompressionParameters
 
getCreationTimeFor(Component) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
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
 
getCurrentKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
 
getCurrentLocalCounterId() - 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
Deprecated.
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
 
getCurrentValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
 
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.RowDataResolver
 
getData() - Method in class org.apache.cassandra.service.RowDigestResolver
Special case of resolve() so that CL.ONE reads never throw DigestMismatchException in the foreground
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
 
getDatacenterEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
 
getDatacenterRacks() - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
 
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
 
getDefaultIndexName(String, AbstractType<?>, ByteBuffer) - Static method in class org.apache.cassandra.config.CFMetaData
 
getDefaultMarshallers(CfDef) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
construct a map to store the mashaller type to cassandra data type mapping
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
 
getDirectories() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
getDirectories() - Method in class org.apache.cassandra.io.util.DiskAwareRunnable
Get sstable directories for the CF.
getDirectoryForNewSSTables(long) - Method in class org.apache.cassandra.db.Directories
 
getDirectScanner(RateLimiter) - Method in class org.apache.cassandra.io.sstable.SSTableReader
Direct I/O SSTableScanner
getDirectScanner(Range<Token>, RateLimiter) - 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
 
getDiskFailurePolicy() - 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
getDroppableTombstoneRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getDroppableTombstoneRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Get the ratio of droppable tombstones to real columns (and non-droppable tombstones)
getDroppableTombstoneRatio() - Method in class org.apache.cassandra.db.DataTracker
 
getDroppableTombstonesBefore(int) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata
Get the amount of droppable tombstones
getDroppableTombstonesBefore(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
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
 
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
 
getEndpointForHostId(UUID) - Method in class org.apache.cassandra.locator.TokenMetadata
Return the end-point for a unique host ID
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
 
getEndpointToHostIdMapForReading() - Method in class org.apache.cassandra.locator.TokenMetadata
 
getEndpointToRangesMap() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
 
getEndpointToTokenMapForReading() - Method in class org.apache.cassandra.locator.TokenMetadata
 
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
 
getEpSnitchProxy(MBeanServerConnection) - Method in class org.apache.cassandra.tools.Shuffle
 
getEstimatedAvailableSpace() - Method in class org.apache.cassandra.db.Directories.DataDirectory
 
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
Deprecated.
getEstimatedDroppableTombstoneRatio(int) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata
 
getEstimatedDroppableTombstoneRatio(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
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
Deprecated.
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.
getExpectedWriteSize() - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
getExpectedWriteSize() - Method in class org.apache.cassandra.io.util.DiskAwareRunnable
Get expected write size to determine which disk to use for this task.
getExpireTimeForEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
getExpressionComparator() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
getExpressionComparator() - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
 
getExpressionComparator() - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
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.
getFieldSize(long) - Static method in class org.apache.cassandra.utils.ObjectSizes
Memory a class consumes, including the object header and the size of the fields.
getFileDataInput(long) - 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 interface org.apache.cassandra.io.util.FileDataInput
 
getFilePointer() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
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(long, int, boolean) - Static method in class org.apache.cassandra.utils.FilterFactory
 
getFilter(long, double, boolean) - Static method in class org.apache.cassandra.utils.FilterFactory
 
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
 
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
 
getFullColumnFamily() - Method in class org.apache.cassandra.db.compaction.PrecompactedRow
 
getFullyQualifiedClassName(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
get the full class name
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
 
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
 
getHintedHandoffThrottleInKB() - 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
 
getHost() - Method in class org.apache.cassandra.streaming.AbstractStreamSession
 
getHostId(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
getHostId(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
Return the unique host ID for an end-point.
getHostIdMap() - Method in class org.apache.cassandra.service.StorageService
 
getHostIdMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve the mapping of endpoint to host ID
getHostIdMap() - Method in class org.apache.cassandra.tools.NodeProbe
 
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
 
getId() - Method in enum org.apache.cassandra.transport.DataType
 
getId() - Method in interface org.apache.cassandra.transport.OptionCodec.Codecable
 
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.AbstractSimplePerColumnSecondaryIndex
 
getIndexCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndex
Allow access to the underlying column family store if there is one
getIndexComparator(CFMetaData, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.SecondaryIndex
Returns the index comparator for index backed by CFS, or null.
getIndexedIterator(AbstractBounds<RowPosition>, ExtendedFilter) - Method in class org.apache.cassandra.db.index.composites.CompositesSearcher
 
getIndexedIterator(AbstractBounds<RowPosition>, ExtendedFilter) - Method in class org.apache.cassandra.db.index.keys.KeysSearcher
 
getIndexes() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
getIndexes() - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
get a list of columns with defined index
getIndexesBackedByCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
getIndexesByNames(Set<String>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
getIndexesNotBackedByCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
getIndexFilename() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getIndexForColumn(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
getIndexInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getIndexKeyFor(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
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.AbstractSimplePerColumnSecondaryIndex
 
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
 
getIndexScanPosition(RowPosition) - Method in class org.apache.cassandra.io.sstable.SSTableReader
get the position in the index file to start scanning to find the given key (at most indexInterval keys away)
getIndexType() - Method in class org.apache.cassandra.config.ColumnDefinition
 
getIndexType(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
get index type from string
getInetAddress(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getInitialTokens() - 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
 
getInputcolumns(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputFormat() - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
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
 
getInputPageRowSize(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
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
 
getInputWhereClauses(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
 
getInstance(Map<ByteBuffer, CollectionType>) - Static method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
 
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.ListType
 
getInstance(AbstractType<T>) - Static method in class org.apache.cassandra.db.marshal.ListType
 
getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.MapType
 
getInstance(AbstractType<K>, AbstractType<V>) - Static method in class org.apache.cassandra.db.marshal.MapType
 
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
 
getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.SetType
 
getInstance(AbstractType<T>) - Static method in class org.apache.cassandra.db.marshal.SetType
 
getInt(String, Integer) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
 
getInt(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getInterDCTcpNoDelay() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternal(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
getInternodeAuthenticator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternodeRecvBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternodeSendBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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.JdbcInetAddress
 
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
 
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 class org.apache.cassandra.db.columniterator.LazyColumnIterator
 
getKey() - Method in interface org.apache.cassandra.db.columniterator.OnDiskAtomIterator
 
getKey() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
getKey() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
getKey(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
getKey() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
getKeyAlias() - Method in class org.apache.cassandra.cql.SelectStatement
 
getKeyAlias() - Method in class org.apache.cassandra.cql.WhereClause
 
getKeyAliases() - Method in class org.apache.cassandra.config.CFMetaData
 
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
Deprecated.
getKeyCacheCapacityInMB() - Method in class org.apache.cassandra.service.CacheService
 
getKeyCacheCapacityInMB() - Method in interface org.apache.cassandra.service.CacheServiceMBean
Deprecated.
getKeyCacheEntries() - Method in class org.apache.cassandra.service.CacheService
 
getKeyCacheEntries() - Method in interface org.apache.cassandra.service.CacheServiceMBean
Deprecated.
getKeyCacheHit() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getKeyCacheHits() - Method in class org.apache.cassandra.service.CacheService
 
getKeyCacheHits() - Method in interface org.apache.cassandra.service.CacheServiceMBean
Deprecated.
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
Deprecated.
getKeyCacheRequest() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getKeyCacheRequests() - Method in class org.apache.cassandra.service.CacheService
 
getKeyCacheRequests() - Method in interface org.apache.cassandra.service.CacheServiceMBean
Deprecated.
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
Deprecated.
getKeyCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getKeyComponent(int) - Method in class org.apache.cassandra.cql3.statements.ColumnGroupMap
 
getKeyFinish() - Method in class org.apache.cassandra.cql.SelectStatement
 
getKeyName() - Method in class org.apache.cassandra.config.CFMetaData
 
getKeyNameBuilder() - Method in class org.apache.cassandra.cql3.CFDefinition
 
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
 
getKeysMeta(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
get keys meta data
getKeyspace() - Method in class org.apache.cassandra.auth.DataResource
 
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
 
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
 
getLevelSorted(int, Comparator<SSTableReader>) - 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
Deprecated.
getLifetimeWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getLifetimeWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Deprecated.
getLimit() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
 
getListenAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getLiveCount(ColumnFamily) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
 
getLiveCount(ColumnFamily) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getLiveCount(ColumnFamily) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getLiveCount(IDiskAtomFilter) - 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
Deprecated.
getLiveMembers() - Method in class org.apache.cassandra.gms.Gossiper
 
getLiveNaturalEndpoints(Table, 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(Table, 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
 
getLiveNodes() - Method in class org.apache.cassandra.tools.Shuffle
Return a list of the live nodes (using JMX).
getLiveSize() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
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
Deprecated.
getLoad() - Method in class org.apache.cassandra.service.StorageService
raw load value
getLoad() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
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.
getLocalComparator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getLocalDataCenter() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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.OnDiskAtom
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.RangeTombstone
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.SuperColumn
 
getLocalHostId() - Static method in class org.apache.cassandra.db.SystemTable
Read the host ID from the system table, creating (and storing) one if none exists.
getLocalHostId() - Method in class org.apache.cassandra.service.StorageService
 
getLocalHostId() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve this hosts unique ID
getLocalHostId() - Method in class org.apache.cassandra.tools.NodeProbe
 
getLocalId() - Static method in class org.apache.cassandra.utils.CounterId
 
getLocalPrimaryRange() - Method in class org.apache.cassandra.service.StorageService
Deprecated.
getLocalPrimaryRanges(String) - Method in class org.apache.cassandra.service.StorageService
 
getLocalRanges(String) - Method in class org.apache.cassandra.service.StorageService
 
getLocalTokens() - Method in class org.apache.cassandra.service.StorageService
 
getLocationCapableOfSize(long) - Method in class org.apache.cassandra.db.Directories
Finds location which is capable of holding given estimatedSize.
getLocationForDisk(Directories.DataDirectory) - Method in class org.apache.cassandra.db.Directories
Returns SSTable location which is inside given data directory.
getLocations() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
getLocationWithMaximumAvailableSpace(long) - Method in class org.apache.cassandra.db.Directories
 
getLong(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getLong(long) - Method in class org.apache.cassandra.io.util.Memory
 
getMap(String) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
 
getMap(String, AbstractType<K>, AbstractType<V>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
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 class org.apache.cassandra.db.SuperColumn
 
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
 
getMaxHintsThread() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
getMaximumCompactorThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getMaximumCompactorThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Returns maximum size of compaction thread pool
getMaximumSize() - Method in class org.apache.cassandra.utils.SlabAllocator
 
getMaximumThreads() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
getMaximumThreads() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
Deprecated.
Returns maximum pool size of thread pool.
getMaximumValidatorThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getMaximumValidatorThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Returns size of validator thread pool
getMaxLiveCount() - Method in class org.apache.cassandra.service.RowDataResolver
 
getMaxRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMaxRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Deprecated.
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
Deprecated.
getMemtable() - Method in class org.apache.cassandra.db.DataTracker
 
getMemtableColumnIterator(ColumnFamily, DecoratedKey) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
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
Deprecated.
getMemtableDataSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMemtableDataSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Deprecated. 
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
Deprecated.
getMergedRowCounts() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
getMessage() - Method in interface org.apache.cassandra.exceptions.TransportException
The exception 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.MessageIn
 
getMessagingVersion() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
getMetadata() - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
 
getMetadata() - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
 
getMetadata() - Method in interface org.apache.cassandra.io.util.ICompressedFile
 
getMetrics() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
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
getMinimumSize() - Method in class org.apache.cassandra.utils.SlabAllocator
 
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.Murmur3Partitioner
 
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
Deprecated.
getMinRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getMinTimestamp() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
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, ThriftClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.BatchStatement
 
getMutations(List<ByteBuffer>, boolean, ConsistencyLevel, long) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
getMutations(List<ByteBuffer>, boolean, ConsistencyLevel, long) - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
 
getMutations(List<ByteBuffer>, boolean, ConsistencyLevel, long) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
Convert statement into a list of mutations to apply on the server
getMutations(List<ByteBuffer>, boolean, ConsistencyLevel, long) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
Convert statement into a list of mutations to apply on the server
getN() - Method in class org.apache.cassandra.service.PBSPredictionResult
 
getName() - Method in class org.apache.cassandra.auth.AuthenticatedUser
 
getName() - Method in class org.apache.cassandra.auth.DataResource
 
getName() - Method in interface org.apache.cassandra.auth.IResource
 
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
 
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
 
getNativeTransportAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNativeTransportMaxThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNativeTransportMinThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNativeTransportPort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNaturalEndpoints(RingPosition) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
get the (possibly cached) endpoints that should store the given Token.
getNaturalEndpoints(RingPosition) - Method in class org.apache.cassandra.locator.LocalStrategy
We need to override this even if we override calculateNaturalEndpoints, because the default implementation depends on token calculations but LocalStrategy may be used before tokens are set up.
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
 
getNext() - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
get next row
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
 
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
read wide row
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
 
getNumberVersionsStale() - Method in class org.apache.cassandra.service.PBSPredictionResult
 
getNumRecords() - Method in class org.apache.cassandra.cql.SelectStatement
 
getNumTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNumWords() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Expert: gets the number of longs in the array that are in use
getObjectHeaderSize() - Method in interface org.apache.cassandra.utils.ObjectSizes.MemoryLayoutSpecification
 
getObjectPadding() - Method in interface org.apache.cassandra.utils.ObjectSizes.MemoryLayoutSpecification
 
getOldLocalCounterIds() - Static method in class org.apache.cassandra.db.SystemTable
 
getOldLocalCounterIds() - Static method in class org.apache.cassandra.utils.CounterId
Return the list of old local counter 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.
getOnDiskSerializer() - Method in class org.apache.cassandra.config.CFMetaData
 
getOnDiskSerializer() - Method in class org.apache.cassandra.db.ColumnFamily
 
getOpCount() - Method in class org.apache.cassandra.utils.LatencyTracker
 
getOpeningString() - Method in class org.apache.cassandra.dht.AbstractBounds
 
getOpeningString() - Method in class org.apache.cassandra.dht.Bounds
 
getOpeningString() - Method in class org.apache.cassandra.dht.ExcludingBounds
 
getOpeningString() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
getOpeningString() - Method in class org.apache.cassandra.dht.Range
 
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
Deprecated.
 
getOptions() - Method in class org.apache.cassandra.cql3.UserOptions
 
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.AbstractColumnFamilyOutputFormat
The OutputCommitter for this format does not write any data to the DFS.
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
 
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
 
getOutputCql(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getOutputFormat() - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
output format
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
 
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
 
getParent() - Method in class org.apache.cassandra.auth.DataResource
 
getParent() - Method in interface org.apache.cassandra.auth.IResource
Gets next resource in the hierarchy.
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
 
getPartitioner(String, int, boolean) - Static method in class org.apache.cassandra.tools.Shuffle
Return a partitioner instance for remote host.
getPartitionerName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPartitionKeys(String, Job) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
return partition keys
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
 
getPBSPredictorMBean() - Method in class org.apache.cassandra.tools.NodeProbe
 
getPendingAddressRanges(TokenMetadata, Token, InetAddress) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getPendingAddressRanges(TokenMetadata, Collection<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
Deprecated.
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
Deprecated.
getPendingTasks() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getPendingTasks() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
Deprecated.
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
Deprecated.
getPercentileReadLatencyPercentile() - Method in class org.apache.cassandra.service.PBSPredictionResult
 
getPercentileReadLatencyValue() - Method in class org.apache.cassandra.service.PBSPredictionResult
 
getPercentileWriteLatencyPercentile() - Method in class org.apache.cassandra.service.PBSPredictionResult
 
getPercentileWriteLatencyValue() - Method in class org.apache.cassandra.service.PBSPredictionResult
 
getPermissionsValidity() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
 
getPigType(AbstractType) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
get pig type for the cassandra data type
getPos() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
getPos() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
 
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
 
getPosition() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
 
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(InetAddress) - Method in class org.apache.cassandra.cql.jdbc.JdbcInetAddress
 
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
 
getPrefetchedList(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
getPreheatKeyCache() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPrepared(MD5Digest) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
getPrepared(Integer) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
getPrepared() - Method in class org.apache.cassandra.thrift.ThriftClientState
 
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
Deprecated.
getPrimaryRangeForEndpoint(InetAddress) - Method in class org.apache.cassandra.service.StorageService
Deprecated. 
getPrimaryRangesFor(Collection<Token>) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getPrimaryRangesForEndpoint(String, InetAddress) - Method in class org.apache.cassandra.service.StorageService
Get the "primary ranges" for the specified keyspace and endpoint.
getProgress() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
getProgress() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
 
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.AbstractCassandraStorage
decompose the query to store the parameters in a map
getQueryState() - Method in class org.apache.cassandra.thrift.ThriftClientState
 
getQueryState(int) - Method in class org.apache.cassandra.transport.ServerConnection
 
getR() - Method in class org.apache.cassandra.service.PBSPredictionResult
 
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.Murmur3Partitioner
 
getRandomToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getRandomToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getRandomTokens(TokenMetadata, int) - Static method in class org.apache.cassandra.dht.BootStrapper
 
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
Deprecated.
getRangeRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRangeRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
 
getRangeRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRangeSlice(ByteBuffer, AbstractBounds<RowPosition>, int, IDiskAtomFilter, List<IndexExpression>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRangeSlice(ByteBuffer, AbstractBounds<RowPosition>, int, IDiskAtomFilter, 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.
getRateLimiter() - Method in class org.apache.cassandra.db.compaction.CompactionManager
Gets compaction rate limiter.
getRawCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRawKeyspace() - Method in class org.apache.cassandra.service.ClientState
 
getRawText() - Method in class org.apache.cassandra.cql3.Constants.Literal
 
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
Deprecated.
getReadOperations() - Method in class org.apache.cassandra.service.StorageProxy
 
getReadOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
Deprecated.
getReadRepairAttempted() - Method in class org.apache.cassandra.service.StorageProxy
 
getReadRepairAttempted() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getReadRepairAttempted() - Method in class org.apache.cassandra.tools.NodeProbe
 
getReadRepairChance() - Method in class org.apache.cassandra.config.CFMetaData
 
getReadRepairRepairedBackground() - Method in class org.apache.cassandra.service.StorageProxy
 
getReadRepairRepairedBackground() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getReadRepairRepairedBackground() - Method in class org.apache.cassandra.tools.NodeProbe
 
getReadRepairRepairedBlocking() - Method in class org.apache.cassandra.service.StorageProxy
 
getReadRepairRepairedBlocking() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getReadRepairRepairedBlocking() - Method in class org.apache.cassandra.tools.NodeProbe
 
getReadRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getReadRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
 
getReadRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getReceivedCount() - Method in class org.apache.cassandra.service.ReadCallback
 
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
Deprecated.
getRecentBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentBloomFilterFalseRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Deprecated.
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.metrics.CacheMetrics
Deprecated.
getRecentLatency() - Method in class org.apache.cassandra.metrics.LatencyMetrics
Deprecated.
getRecentLatencyHistogramMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
Deprecated.
 
getRecentLatencyHistogramMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
 
getRecentLatencyMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
Deprecated.
 
getRecentLatencyMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
returns microseconds
getRecentlyDropped() - Method in class org.apache.cassandra.metrics.DroppedMessageMetrics
Deprecated.
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
Deprecated.
getRecentRangeLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentRangeLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
Deprecated.
getRecentReadLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Deprecated.
getRecentReadLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
Deprecated.
getRecentReadLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentReadLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Deprecated.
getRecentReadLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentReadLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
Deprecated.
getRecentSSTablesPerReadHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentSSTablesPerReadHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Deprecated.
getRecentTimeout() - Method in class org.apache.cassandra.metrics.ConnectionMetrics
Deprecated.
getRecentTimeouts() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
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.
getRecentTotalTimeout() - Static method in class org.apache.cassandra.metrics.ConnectionMetrics
Deprecated.
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
Deprecated.
getRecentWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
Deprecated.
getRecentWriteLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentWriteLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Deprecated.
getRecentWriteLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentWriteLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
Deprecated.
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
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingInputFormat
 
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.
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
Deprecated.
getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
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
 
getReferenceSize() - Static method in class org.apache.cassandra.utils.ObjectSizes
 
getReferenceSize() - Method in interface org.apache.cassandra.utils.ObjectSizes.MemoryLayoutSpecification
 
getRegisteredCallback(String) - Method in class org.apache.cassandra.net.MessagingService
 
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
 
getRelocatingRanges() - Method in class org.apache.cassandra.locator.TokenMetadata
Ranges which are migrating to new endpoints.
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
 
getReplaceNode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getReplaceTokens() - 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
 
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
getReturnType(String, String, String) - Static method in class org.apache.cassandra.cql3.functions.Functions
 
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
 
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
Deprecated.
getRowCacheCapacityInMB() - Method in class org.apache.cassandra.service.CacheService
 
getRowCacheCapacityInMB() - Method in interface org.apache.cassandra.service.CacheServiceMBean
Deprecated.
getRowCacheEntries() - Method in class org.apache.cassandra.service.CacheService
 
getRowCacheEntries() - Method in interface org.apache.cassandra.service.CacheServiceMBean
Deprecated.
getRowCacheHits() - Method in class org.apache.cassandra.service.CacheService
 
getRowCacheHits() - Method in interface org.apache.cassandra.service.CacheServiceMBean
Deprecated.
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
Deprecated.
getRowCacheRequests() - Method in class org.apache.cassandra.service.CacheService
 
getRowCacheRequests() - Method in interface org.apache.cassandra.service.CacheServiceMBean
Deprecated.
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
Deprecated.
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
getSavedTokens() - 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(InetAddress) - Method in class org.apache.cassandra.cql.jdbc.JdbcInetAddress
 
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.thrift.ThriftClientState
 
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
define the schema
getSchema(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
schema: (value, value, value) where keys are in the front.
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.PoolingSegmentedFile
 
getSegment(long) - Method in class org.apache.cassandra.io.util.SegmentedFile
 
getSequentialIterator(ByteBuffer, AbstractBounds<RowPosition>, IDiskAtomFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Iterate over a range of rows and columns from memtables/sstables.
getSerializedCachePath(String, String, CacheService.CacheType, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSerializedSize() - Method in class org.apache.cassandra.db.Memtable
 
getServerEncryptionOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getServerSocket(EncryptionOptions, InetAddress, int) - Static method in class org.apache.cassandra.security.SSLFactory
 
getSessionId() - Method in class org.apache.cassandra.streaming.AbstractStreamSession
 
getSessionId() - Method in class org.apache.cassandra.tracing.Tracing
 
getSet(String, AbstractType<T>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getSeverity() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getSeverity() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
getSeverity(InetAddress) - Method in class org.apache.cassandra.service.StorageService
 
getShortLength(ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
getShortName(AbstractType<?>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
 
getSimple(String) - Method in class org.apache.cassandra.cql3.PropertyDefinitions
 
getSimple(ByteBuffer) - Method in class org.apache.cassandra.cql3.statements.ColumnGroupMap
 
getSimpleStates() - Method in class org.apache.cassandra.gms.FailureDetector
 
getSimpleStates() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
getSize(ByteBuffer) - Static method in class org.apache.cassandra.utils.ObjectSizes
Memory a byte buffer consumes
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.
getSnapshotCreationTime(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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
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.AbstractColumnFamilyInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
 
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
 
getSSProxy(MBeanServerConnection) - Method in class org.apache.cassandra.tools.Shuffle
 
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, RowIndexEntry) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
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.IDiskAtomFilter
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, RowIndexEntry) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getSSTableColumnIterator(SSTableReader) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry) - 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, RowIndexEntry) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getSSTableCountPerLevel() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getSSTableCountPerLevel() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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
Deprecated.
getStage(Stage) - Static method in class org.apache.cassandra.concurrent.StageManager
Retrieve a stage from the StageManager
getStage() - Method in class org.apache.cassandra.net.MessageOut
 
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.AbstractCassandraStorage
 
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
 
getStreamId() - Method in class org.apache.cassandra.transport.Message
 
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
 
getStreamThroughput() - 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.JdbcInetAddress
 
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.CollectionType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
 
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.EmptyType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.InetAddressType
 
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
 
getString(AbstractType<?>) - Method in class org.apache.cassandra.dht.AbstractBounds
 
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(Token) - Method in class org.apache.cassandra.service.StorageService
 
getSuperclassFieldPadding() - Method in interface org.apache.cassandra.utils.ObjectSizes.MemoryLayoutSpecification
 
getSuperClassFieldSize(long) - Static method in class org.apache.cassandra.utils.ObjectSizes
Memory a super class consumes, given the primitive field sizes
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
 
getTargetVersion() - Method in class org.apache.cassandra.net.OutboundTcpConnection
 
getTaskType() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getTaskType() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
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.
getThreadPoolMBeanProxies() - Method in class org.apache.cassandra.tools.NodeProbe
 
getThriftClient(String, int, boolean) - Static method in class org.apache.cassandra.tools.Shuffle
Setup and return a new Thrift RPC connection.
getThriftFramedTransportSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getThriftFramedTransportSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getTimeout(MessagingService.Verb) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTimeout() - Method in class org.apache.cassandra.db.RangeSliceCommand
 
getTimeout() - Method in class org.apache.cassandra.db.ReadCommand
 
getTimeout() - Method in class org.apache.cassandra.net.MessageIn
 
getTimeout() - Method in class org.apache.cassandra.net.MessageOut
 
getTimeout() - Method in interface org.apache.cassandra.service.IReadCommand
 
getTimeouts() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
getTimeoutsPerHost() - Method in class org.apache.cassandra.net.MessagingService
 
getTimeoutsPerHost() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Number of timeouts per host
getTimeSinceWrite() - Method in class org.apache.cassandra.service.PBSPredictionResult
 
getTimestamp(ThriftClientState) - Method in class org.apache.cassandra.cql.AbstractModification
 
getTimestamp() - Method in class org.apache.cassandra.cql.Attributes
 
getTimestamp(long) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
getTimestamp(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getTimestamp() - Method in class org.apache.cassandra.service.QueryState
This clock guarantees that updates for the same QueryState 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
 
getTimeUUID() - Static method in class org.apache.cassandra.utils.UUIDGen
Creates a type 1 UUID (time-based UUID).
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).
getTimeUUIDBytes(long, int) - Static method in class org.apache.cassandra.utils.UUIDGen
Converts a 100-nanoseconds precision 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 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.Murmur3Partitioner
Generate the token of a key.
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
Deprecated.
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.Murmur3Partitioner
 
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
 
getTokens(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getTokens() - Method in class org.apache.cassandra.service.StorageService
 
getTokens(String) - Method in class org.apache.cassandra.service.StorageService
 
getTokens() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Fetch string representations of the tokens for this node.
getTokens(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Fetch string representations of the tokens for a specified node.
getTokens() - Method in class org.apache.cassandra.tools.NodeProbe
 
getTokens(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
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
 
getTokenValidator() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
getTokenValidator() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getTokenValidator() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
getTokenValidator() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
 
getTokenValidator() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getTokenValidator() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getToolsOutputDirectory() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getTopLevelColumns() - Method in class org.apache.cassandra.db.CollationController
 
getTopLevelColumns(QueryFilter, int, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTopLevelDeletion() - Method in class org.apache.cassandra.db.DeletionInfo
 
getTopology() - Method in class org.apache.cassandra.locator.TokenMetadata
 
getTotal() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getTotalBatchesReplayed() - Method in class org.apache.cassandra.db.BatchlogManager
 
getTotalBatchesReplayed() - Method in interface org.apache.cassandra.db.BatchlogManagerMBean
 
getTotalBlockedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
getTotalBlockedTasks() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
Deprecated.
Get the number of tasks that had blocked before being accepted (or rejected).
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
Deprecated.
getTotalCommitlogSize() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getTotalCommitlogSize() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
Deprecated.
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
Deprecated.
getTotalCompressedBytesRead() - Method in class org.apache.cassandra.streaming.compress.CompressedInputStream
 
getTotalDiskSpaceUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTotalDiskSpaceUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Deprecated.
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
Deprecated.
 
getTotalLatencyHistogramMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
 
getTotalLatencyMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
Deprecated.
 
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
Deprecated.
getTotalRangeLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalRangeLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
Deprecated.
getTotalReadLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
Deprecated.
getTotalReadLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTotalReadLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Deprecated.
getTotalReadLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalReadLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
Deprecated.
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
Deprecated.
getTotalWriteLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTotalWriteLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Deprecated.
getTotalWriteLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalWriteLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
Deprecated.
getTracingId() - Method in class org.apache.cassandra.transport.Message.Response
 
getTracingProbability() - Method in class org.apache.cassandra.service.StorageService
 
getTracingProbability() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the configured tracing probability.
getTracker() - Method in class org.apache.cassandra.transport.Connection
 
getTransport(TTransport) - Method in class org.apache.cassandra.cli.transport.FramedTransportFactory
 
getTransport(TTransport) - Method in class org.apache.cassandra.cli.transport.SimpleTransportFactory
 
getTransport(TTransport) - Method in class org.apache.cassandra.cli.transport.SSLTransportFactory
 
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.setTraceProbability_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.traceNextQuery_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.traceSessionId_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.tracingProbability_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
 
getTruncateRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTruncateRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
 
getTruncateRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTruncationRecords() - Static method in class org.apache.cassandra.db.SystemTable
 
getTruncationTime() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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.JdbcInetAddress
 
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.CQL3Type.Collection
 
getType() - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
 
getType() - Method in interface org.apache.cassandra.cql3.CQL3Type
 
getType() - Method in enum org.apache.cassandra.cql3.CQL3Type.Native
 
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
 
getUnreadableDirectories() - Method in class org.apache.cassandra.db.BlacklistedDirectories
 
getUnreadableDirectories() - Method in interface org.apache.cassandra.db.BlacklistedDirectoriesMBean
 
getUnsignedShort(ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.CollectionType
 
getUnwritableDirectories() - Method in class org.apache.cassandra.db.BlacklistedDirectories
 
getUnwritableDirectories() - Method in interface org.apache.cassandra.db.BlacklistedDirectoriesMBean
 
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
 
getUser() - Method in class org.apache.cassandra.service.ClientState
 
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(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
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
 
getValidatorMap(CfDef) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
get the validators
getValidColumnFamilies(boolean, boolean, 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
 
getVerbHandler(MessagingService.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.net.MessagingService
 
getVersion(String) - Method in class org.apache.cassandra.net.MessagingService
 
getVersion(String) - Method in interface org.apache.cassandra.net.MessagingServiceMBean
 
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
 
getW() - Method in class org.apache.cassandra.service.PBSPredictionResult
 
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
Deprecated.
getWriteEndpoints(Token, String, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.TokenMetadata
Deprecated.
retained for benefit of old tests
getWriteOperations() - Method in class org.apache.cassandra.service.StorageProxy
 
getWriteOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
Deprecated.
getWriter(int) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
getWriter() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
getWriteResponseHandler(Collection<InetAddress>, Collection<InetAddress>, ConsistencyLevel, Runnable, WriteType) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getWriteRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getWriteRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
 
getWriteRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
GLOBAL_OPTIONS - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
 
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.
GossipDigestAck - Class in org.apache.cassandra.gms
This ack gets sent out as a result of the receipt of a GossipDigestSynMessage by an endpoint.
GossipDigestAck2 - Class in org.apache.cassandra.gms
This ack gets sent out as a result of the receipt of a GossipDigestAckMessage.
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
 
GossipDigestSyn - Class in org.apache.cassandra.gms
This is the first message that gets sent out as a start of the Gossip protocol in a round.
GossipDigestSyn(String, String, List<GossipDigest>) - Constructor for class org.apache.cassandra.gms.GossipDigestSyn
 
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.GossipingPropertyFileSnitch
 
gossiperStarting() - Method in interface org.apache.cassandra.locator.IEndpointSnitch
called after Gossiper instance exists immediately before it starts gossiping
gossiperStarting() - Method in class org.apache.cassandra.locator.PropertyFileSnitch
 
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
 
gossipSnitchInfo() - Method in class org.apache.cassandra.service.StorageService
 
grant(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
grant(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
grant(AuthenticatedUser, Set<Permission>, IResource, String) - Method in interface org.apache.cassandra.auth.IAuthorizer
Grants a set of permissions on a resource to a user.
grant(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
 
grantStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
GrantStatement - Class in org.apache.cassandra.cql3.statements
 
GrantStatement(Set<Permission>, IResource, String) - Constructor for class org.apache.cassandra.cql3.statements.GrantStatement
 
GROUP_NAME - Static variable in class org.apache.cassandra.metrics.CacheMetrics
 
GROUP_NAME - Static variable in class org.apache.cassandra.metrics.CommitLogMetrics
 
GROUP_NAME - Static variable in class org.apache.cassandra.metrics.CompactionMetrics
 
GROUP_NAME - Static variable in class org.apache.cassandra.metrics.ConnectionMetrics
 
GROUP_NAME - Static variable in class org.apache.cassandra.metrics.DroppedMessageMetrics
 
GROUP_NAME - Static variable in class org.apache.cassandra.metrics.HintedHandoffMetrics
 
GROUP_NAME - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
 
GROUP_NAME - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
 
groups() - Method in class org.apache.cassandra.cql3.statements.ColumnGroupMap.Builder
 
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
 
handleFSError(FSError) - Static method in class org.apache.cassandra.io.util.FileUtils
 
handleMessage(MessageOut, String, InetAddress) - Method in interface org.apache.cassandra.net.sink.IMessageSink
 
handleMessage(MessageIn, 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
handleRow(Selection.ResultSetBuilder) - Method in class org.apache.cassandra.cql3.statements.Selection
 
has(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
hasAllKeyspacesAccess(Permission) - Method in class org.apache.cassandra.service.ClientState
 
hasAncestors - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
 
hasCapacityFor(long) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
hasCollections - Variable in class org.apache.cassandra.cql3.CFDefinition
 
hasColumnFamilyAccess(String, String, Permission) - Method in class org.apache.cassandra.service.ClientState
 
hasCompositeKey - Variable in class org.apache.cassandra.cql3.CFDefinition
 
hasCompressionRatio - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
 
hasCounterId(ByteBuffer, CounterId) - Method in class org.apache.cassandra.db.context.CounterContext
Checks whether the provided context has a count for the provided CounterId.
hasCounterId(CounterId) - Method in class org.apache.cassandra.db.CounterColumn
Check if a given counterId is found in this CounterColumn context.
hasCrossNodeTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
hasEncodedKeys - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
 
hasFirstSet() - Method in class org.apache.cassandra.cql.SelectExpression
 
HASH - Static variable in class org.apache.cassandra.cli.CliLexer
 
HASH - Static variable in class org.apache.cassandra.cli.CliParser
 
hash(ByteBuffer, int, int, long) - Method in class org.apache.cassandra.utils.BloomFilter
 
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
 
hash(ByteBuffer, int, int, long) - Method in class org.apache.cassandra.utils.Murmur2BloomFilter
 
hash(ByteBuffer, int, int, long) - Method in class org.apache.cassandra.utils.Murmur3BloomFilter
 
hash2_64(ByteBuffer, int, int, long) - Static method in class org.apache.cassandra.utils.MurmurHash
 
hash32(ByteBuffer, int, int, int) - Static method in class org.apache.cassandra.utils.MurmurHash
 
hash3_x64_128(ByteBuffer, int, int, long) - Static method in class org.apache.cassandra.utils.MurmurHash
 
hashCode() - Method in class org.apache.cassandra.auth.AuthenticatedUser
 
hashCode() - Method in class org.apache.cassandra.auth.DataResource
 
hashCode() - Method in class org.apache.cassandra.auth.PermissionDetails
 
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.CFDefinition.Name
 
hashCode() - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
hashCode() - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
 
hashCode() - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
 
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.DeletionInfo
 
hashCode() - Method in class org.apache.cassandra.db.DeletionTime
 
hashCode() - Method in class org.apache.cassandra.db.ExpiringColumn
 
hashCode() - Method in class org.apache.cassandra.db.filter.ColumnSlice
 
hashCode() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
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.CompressionMetadata.Chunk
 
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.io.sstable.Descriptor.Version
 
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.CounterId.CounterIdRecord
 
hashCode() - Method in class org.apache.cassandra.utils.CounterId
 
hashCode() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
hashCode() - Method in class org.apache.cassandra.utils.Interval
 
hashCode() - Method in class org.apache.cassandra.utils.IntervalTree
 
hashCode() - Method in class org.apache.cassandra.utils.MD5Digest
 
hashCode() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
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
 
hashCount - Variable in class org.apache.cassandra.utils.BloomFilter
 
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.Version
 
hasIrrelevantData(int) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
hasIrrelevantData(int) - Method in class org.apache.cassandra.db.Column
 
hasIrrelevantData(int) - Method in class org.apache.cassandra.db.DeletionInfo
 
hasIrrelevantData(int) - Method in interface org.apache.cassandra.db.IColumn
 
hasIrrelevantData(int) - Method in interface org.apache.cassandra.db.IColumnContainer
 
hasIrrelevantData(int) - Method in class org.apache.cassandra.db.RangeTombstoneList
Returns whether purge(gcBefore) would remove something or not.
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.db.SliceQueryPager
 
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.FilteredKeyScanningIterator
 
hasNext() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
hasNext() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
 
hasOnlyTombstones() - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
hasParent() - Method in class org.apache.cassandra.auth.DataResource
 
hasParent() - Method in interface org.apache.cassandra.auth.IResource
Indicates whether or not this resource has a parent in the hierarchy.
hasPartitioner - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
 
hasPromotedIndexes - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
 
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
 
hasRowLevelBF - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
 
hasSession(UUID) - Static method in class org.apache.cassandra.streaming.StreamInSession
 
hasStringsInBloomFilter - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
 
hasUnreclaimedSpace() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
header - Variable in class org.apache.cassandra.streaming.FileStreamTask
 
header - Variable in class org.apache.cassandra.transport.Frame
 
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
 
help - Variable in class org.apache.cassandra.tools.NodeToolHelp.NodeToolCommand
 
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(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
 
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
 
HEXNUMBER - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
HEXNUMBER - Static variable in class org.apache.cassandra.cql3.CqlParser
 
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_in_kb - 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
The hint schema looks like this: CREATE TABLE hints ( target_id uuid, hint_id timeuuid, message_version int, mutation blob, PRIMARY KEY (target_id, hint_id, message_version) ) WITH COMPACT STORAGE; Thus, for each node in the cluster we treat its uuid as the partition key; each hint is a logical row (physical composite column) containing the mutation to replay and associated metadata.
HintedHandOffManager() - Constructor for class org.apache.cassandra.db.HintedHandOffManager
 
HintedHandOffManagerMBean - Interface in org.apache.cassandra.db
 
HintedHandoffMetrics - Class in org.apache.cassandra.metrics
HintedHandoffMetrics() - Constructor for class org.apache.cassandra.metrics.HintedHandoffMetrics
 
HintedHandoffMetrics.DifferencingCounter - Class in org.apache.cassandra.metrics
 
HintedHandoffMetrics.DifferencingCounter(InetAddress) - Constructor for class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
 
HINTS_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
HintsCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
HISTORYFILE - Static variable in class org.apache.cassandra.cli.CliMain
 
hitRate - Variable in class org.apache.cassandra.metrics.CacheMetrics
cache hit rate
hits - Variable in class org.apache.cassandra.metrics.CacheMetrics
Total number of cache hits
host() - Method in class org.apache.cassandra.cli.CliParser
 
host - Variable in class org.apache.cassandra.streaming.AbstractStreamSession
 
host - Variable in class org.apache.cassandra.tools.AbstractJmxClient
 
host - Variable in class org.apache.cassandra.transport.SimpleClient
 
host_name() - Method in class org.apache.cassandra.cli.CliParser
 
hostId(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
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<T> - 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<T> - Interface in org.apache.cassandra.net
 
IAuthenticator - Interface in org.apache.cassandra.auth
 
IAuthenticator.Option - Enum in org.apache.cassandra.auth
Supported CREATE USER/ALTER USER options.
IAuthorizer - Interface in org.apache.cassandra.auth
Primary Cassandra authorization interface.
IBitSet - Interface in org.apache.cassandra.utils.obs
 
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
 
IColumnIteratorFactory - 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.
ICompressedFile - Interface in org.apache.cassandra.io.util
 
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 - Variable in class org.apache.cassandra.cql3.statements.RawSelector.WritetimeOrTTL
 
id() - Method in class org.apache.cassandra.db.ColumnFamily
 
id - Variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
id - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
id - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
id - Variable in exception org.apache.cassandra.exceptions.PreparedQueryNotFoundException
 
id - Variable in class org.apache.cassandra.streaming.StreamingRepairTask
 
id - Variable in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
 
id - Variable in class org.apache.cassandra.utils.CounterId.CounterIdRecord
 
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
 
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
Will read entire CF into memory.
IDiskAtomFilter - 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.
IDiskAtomFilter.Serializer - Class in org.apache.cassandra.db.filter
 
IDiskAtomFilter.Serializer() - Constructor for class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
 
IEndpointLifecycleSubscriber - Interface in org.apache.cassandra.service
Interface on which interested parties can be notified of high level endpoint state changes.
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
Deprecated.
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
 
ifile - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
 
IFilter - Interface in org.apache.cassandra.utils
 
ignored - Variable in class org.apache.cassandra.db.filter.ColumnCounter
 
ignored() - Method in class org.apache.cassandra.db.filter.ColumnCounter
 
ignoredSchemaRow(Row) - Static method in class org.apache.cassandra.config.Schema
 
IInternodeAuthenticator - Interface in org.apache.cassandra.auth
 
IIterableColumns - Interface in org.apache.cassandra.io.util
 
ILatencySubscriber - Interface in org.apache.cassandra.locator
 
IMeasurableMemory - Interface in org.apache.cassandra.cache
 
IMergeIterator<In,Out> - Interface in org.apache.cassandra.utils
 
IMessageCallback - Interface in org.apache.cassandra.net
 
IMessageSink - Interface in org.apache.cassandra.net.sink
 
IMigrationListener - Interface in org.apache.cassandra.service
 
importJson(String, String, String, String) - Method in class org.apache.cassandra.tools.SSTableImport
Convert a JSON formatted file to an SSTable.
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
 
includes(Comparator<ByteBuffer>, ByteBuffer) - Method in class org.apache.cassandra.db.filter.ColumnSlice
 
includes(Comparator<ByteBuffer>, ByteBuffer) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
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
 
incomingBytes - Variable in class org.apache.cassandra.metrics.StreamingMetrics
 
IncomingStreamReader - Class in org.apache.cassandra.streaming
 
IncomingStreamReader(StreamHeader, Socket) - Constructor for class org.apache.cassandra.streaming.IncomingStreamReader
 
IncomingTcpConnection - Class in org.apache.cassandra.net
 
IncomingTcpConnection(Socket) - Constructor for class org.apache.cassandra.net.IncomingTcpConnection
 
INCR - Static variable in class org.apache.cassandra.cli.CliLexer
 
INCR - Static variable in class org.apache.cassandra.cli.CliParser
 
incremental_backups - Variable in class org.apache.cassandra.config.Config
 
incrementAndGetGeneration() - Static method in class org.apache.cassandra.db.SystemTable
 
incrementDroppedMessages(MessagingService.Verb) - Method in class org.apache.cassandra.net.MessagingService
 
incrementTimeout() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
incrementValue() - Method in class org.apache.cassandra.cli.CliParser
 
incrPastWindow(InetAddress) - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
 
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() - Method in class org.apache.cassandra.db.compaction.AbstractCompactedRow
 
index() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
index() - Method in class org.apache.cassandra.db.compaction.PrecompactedRow
 
index(ByteBuffer, ColumnFamily) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
Index the given row for new index creation.
index(ByteBuffer) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
Index the given row
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 - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
indexes(ByteBuffer) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
 
indexes(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
Returns true if the provided column name is indexed by this secondary index.
indexes(ByteBuffer, Collection<SecondaryIndex>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
indexes(IColumn) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
indexes(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
indexFilePath - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
 
indexFor(ByteBuffer, Collection<SecondaryIndex>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
indexFor(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
indexFor(ByteBuffer, List<IndexHelper.IndexInfo>, AbstractType<?>, boolean, int) - 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.cql.DropIndexStatement
 
indexName - Variable in class org.apache.cassandra.cql3.statements.DropIndexStatement
 
indexReverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
indexRow(ByteBuffer, ColumnFamily) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
When building an index against existing data, add the given row to the index
indexRow(DecoratedKey, ColumnFamilyStore, Set<String>) - 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.
 
indexSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Lists
 
IndexSummary - Class in org.apache.cassandra.io.sstable
 
IndexSummary(IPartitioner, byte[][], long[]) - Constructor for class org.apache.cassandra.io.sstable.IndexSummary
 
IndexSummary.IndexSummarySerializer - Class in org.apache.cassandra.io.sstable
 
IndexSummary.IndexSummarySerializer() - Constructor for class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
 
IndexSummaryBuilder - Class in org.apache.cassandra.io.sstable
 
IndexSummaryBuilder(long) - Constructor for class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
IndexType - Enum in org.apache.cassandra.db.migration.avro
 
InetAddressType - Class in org.apache.cassandra.db.marshal
 
inetToCB(InetSocketAddress) - Static method in class org.apache.cassandra.transport.CBUtil
 
inFileMode() - Method in class org.apache.cassandra.cli.CliSessionState
 
init() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
init(ColumnDefinition) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
init(ColumnDefinition) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
 
init(ColumnDefinition) - 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.CassandraDaemon
Initialize the Cassandra Daemon based on the given Commons Daemon-specific arguments.
init() - Method in class org.apache.cassandra.service.PBSPredictor
 
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(UUID, 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
 
initialComparator - Variable in class org.apache.cassandra.db.Memtable
 
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.LZ4Compressor
 
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
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
 
initializeFromMessage(MessageIn<?>) - Method in class org.apache.cassandra.tracing.Tracing
Determines the tracing context from a message.
initializeNodeUnsafe(InetAddress, UUID, int) - Method in class org.apache.cassandra.gms.Gossiper
 
initLog4j() - Static method in class org.apache.cassandra.service.CassandraDaemon
Initialize logging in such a way that it checks for config changes every 10 seconds.
initRowCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
initSchema(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
Methods to get the column family schema from Cassandra
initServer() - Method in class org.apache.cassandra.service.StorageService
 
initServer(int) - Method in class org.apache.cassandra.service.StorageService
 
injectApplicationState(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.Gossiper
 
INotification - Interface in org.apache.cassandra.notifications
Created by IntelliJ IDEA.
INotificationConsumer - Interface in org.apache.cassandra.notifications
 
inputFormatClass - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
inputStream(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
insert(ByteBuffer, IColumn) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
insert(ByteBuffer, IColumn) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
insert a column to the index
insert(IColumn) - Method in interface org.apache.cassandra.db.index.SecondaryIndexManager.Updater
called when constructing the index against pre-existing data
insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
insertStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
insertStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
insertUser(String, boolean) - Static method in class org.apache.cassandra.auth.Auth
Inserts the user into AUTH_KS.USERS_CF (or overwrites their superuser status as a result of an ALTER USER query).
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.JdbcInetAddress
 
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.BatchlogManager
 
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.filter.IDiskAtomFilter.Serializer
 
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.EmptyType
 
instance - Static variable in class org.apache.cassandra.db.marshal.FloatType
 
instance - Static variable in class org.apache.cassandra.db.marshal.InetAddressType
 
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.dht.BootStrapper.StringSerializer
 
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.MigrationManager
 
instance - Static variable in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
 
instance() - Static method in class org.apache.cassandra.service.PBSPredictor
 
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.ThriftSessionManager
 
instance() - Static method in class org.apache.cassandra.tracing.Tracing
Fetches and lazy initializes the trace context.
instance - Static variable in class org.apache.cassandra.transport.FrameCompressor.SnappyCompressor
 
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(String, ICache<K, V>) - Constructor for class org.apache.cassandra.cache.InstrumentingCache
 
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(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
 
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
 
inter_dc_tcp_nodelay - Variable in class org.apache.cassandra.config.Config
 
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_authenticator - Variable in class org.apache.cassandra.config.Config
 
internode_compression - Variable in class org.apache.cassandra.config.Config
 
internode_encryption - Variable in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
internode_recv_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
 
internode_send_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
 
internodeCompression() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
 
Interval<C,D> - Class in org.apache.cassandra.utils
 
Interval(C, C, D) - Constructor for class org.apache.cassandra.utils.Interval
 
intervalCount() - Method in class org.apache.cassandra.utils.IntervalTree
 
intervalInMillis - Static variable in class org.apache.cassandra.gms.Gossiper
 
IntervalTree<C,D,I extends Interval<C,D>> - Class in org.apache.cassandra.utils
 
IntervalTree(Collection<I>, Comparator<C>) - Constructor for class org.apache.cassandra.utils.IntervalTree
 
IntervalTree.Serializer<C,D,I extends Interval<C,D>> - Class in org.apache.cassandra.utils
 
inTransportFactory - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
 
intTerm() - Method in class org.apache.cassandra.cql.CqlParser
 
intToCB(int) - Static method in class org.apache.cassandra.transport.CBUtil
 
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.AbstractSimplePerColumnSecondaryIndex
 
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
 
InvalidRequestException - Exception in org.apache.cassandra.exceptions
 
InvalidRequestException(String) - Constructor for exception org.apache.cassandra.exceptions.InvalidRequestException
 
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.
invalidSchemaRow(Row) - Static method in class org.apache.cassandra.config.Schema
 
inverse() - Method in class org.apache.cassandra.utils.BiMultiValMap
 
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.
IResource - Interface in org.apache.cassandra.auth
The interface at the core of Cassandra authorization.
IResponseResolver<TMessage,TResolved> - 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.
isAlwaysEmpty(AbstractType<?>, boolean) - Method in class org.apache.cassandra.db.filter.ColumnSlice
 
isAnonymous() - Method in class org.apache.cassandra.auth.AuthenticatedUser
If IAuthenticator doesn't require authentication, this method may return true.
isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
 
isAssignableTo(ColumnSpecification) - Method in interface org.apache.cassandra.cql3.AssignementTestable
 
isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Constants.Literal
 
isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
 
isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Lists.Literal
 
isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Maps.Literal
 
isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Sets.Literal
 
isAssignableTo(ColumnSpecification) - Method in class org.apache.cassandra.cql3.TypeCast
 
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
 
isAvailable() - Method in interface org.apache.cassandra.service.NativeAccessMBean
 
isBindMarker() - Method in class org.apache.cassandra.cql.Term
 
isBootstrapMode() - Method in class org.apache.cassandra.service.StorageService
 
IsBootstrappingException - Exception in org.apache.cassandra.exceptions
 
IsBootstrappingException() - Constructor for exception org.apache.cassandra.exceptions.IsBootstrappingException
 
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.JdbcInetAddress
 
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
 
isCollection() - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
 
isCollection() - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
 
isCollection() - Method in interface org.apache.cassandra.cql3.CQL3Type
 
isCollection() - Method in enum org.apache.cassandra.cql3.CQL3Type.Native
 
isCollection() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isCollection() - Method in class org.apache.cassandra.db.marshal.CollectionType
 
isColumnFamilyLevel() - Method in class org.apache.cassandra.auth.DataResource
 
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
 
isCompactionManager - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
 
isCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
isCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor.Version
 
isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.Addition
 
isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.Prepend
 
isCompatibleWith(Operation.RawUpdate) - Method in interface org.apache.cassandra.cql3.Operation.RawUpdate
 
isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.SetElement
 
isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.SetValue
 
isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.Substraction
 
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.ColumnToCollectionType
 
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.
isCounter() - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
 
isCounter() - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
 
isCounter() - Method in interface org.apache.cassandra.cql3.CQL3Type
 
isCounter() - Method in enum org.apache.cassandra.cql3.CQL3Type.Native
 
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.JdbcInetAddress
 
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.RowDataResolver
 
isDataPresent() - Method in class org.apache.cassandra.service.RowDigestResolver
 
isDeleted(IColumn) - Method in class org.apache.cassandra.db.DeletionInfo
Return whether a given column is deleted by the container having this deletion info.
isDeleted(ByteBuffer, long) - Method in class org.apache.cassandra.db.DeletionInfo
 
isDeleted(IColumn) - Method in class org.apache.cassandra.db.DeletionTime
 
isDeleted(IColumn) - Method in class org.apache.cassandra.db.RangeTombstone.Tracker
 
isDeleted(ByteBuffer, long) - Method in class org.apache.cassandra.db.RangeTombstoneList
Returns whether the given name/timestamp pair is deleted by one of the tombstone of this RangeTombstoneList.
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.io.sstable.SSTableLoader.LoaderFuture
 
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.cql3.UntypedResultSet
 
isEmpty() - Method in class org.apache.cassandra.cql3.UserOptions
 
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 interface org.apache.cassandra.db.ISortedColumns
Returns true if this map is empty, false otherwise.
isEmpty() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
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.BiMultiValMap
 
isEmpty() - Method in class org.apache.cassandra.utils.ExpiringMap
 
isEmpty() - Method in class org.apache.cassandra.utils.IntervalTree
 
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
 
isExistingUser(String) - Static method in class org.apache.cassandra.auth.Auth
Checks if the username is stored in AUTH_KS.USERS_CF.
isFailed() - Method in class org.apache.cassandra.tools.NodeProbe
 
isFatClient(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
isFullWildcard() - Method in class org.apache.cassandra.cql.SelectStatement
 
isGcAble(int) - Method in class org.apache.cassandra.db.DeletionTime
 
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
 
isIndexed() - Method in class org.apache.cassandra.db.RowIndexEntry
 
isIndexing(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.composites.CompositesSearcher
 
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
 
isIndexValueStale(ColumnFamily, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
 
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
 
isKeyRange() - Method in class org.apache.cassandra.cql.SelectStatement
 
isKeyRange() - Method in class org.apache.cassandra.cql.WhereClause
 
isKeyspaceLevel() - Method in class org.apache.cassandra.auth.DataResource
 
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.TruncateResponseHandler
 
isLatencyForSnitch() - Method in class org.apache.cassandra.service.WriteResponseHandler
 
isLatestVersion - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
 
isLeaving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
isLive() - Method in class org.apache.cassandra.db.Column
 
isLive() - Method in class org.apache.cassandra.db.DeletionInfo
Returns whether this DeletionInfo is live, that is deletes no columns.
isLive(IColumn, IColumnContainer) - Static method in class org.apache.cassandra.db.filter.ColumnCounter
 
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.CounterId
 
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.
isLoggingEnabled() - Method in class org.apache.cassandra.service.PBSPredictor
 
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
 
isMemoryLockable() - Method in interface org.apache.cassandra.service.NativeAccessMBean
 
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
 
isNativeTransportRunning() - Method in class org.apache.cassandra.service.StorageService
 
isNativeTransportRunning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isNativeTransportRunning() - Method in class org.apache.cassandra.tools.NodeProbe
 
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.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.AlwaysPresentFilter
 
isPresent(ByteBuffer) - Method in class org.apache.cassandra.utils.BloomFilter
 
isPresent(ByteBuffer) - Method in interface org.apache.cassandra.utils.IFilter
 
isPresent(ByteBuffer) - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
isPure() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
isPure() - Method in interface org.apache.cassandra.cql3.functions.Function
 
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
 
isRelocating(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
 
isReplacing() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isReversed() - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
 
isReversed() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
isReversed() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
isRootLevel() - Method in class org.apache.cassandra.auth.DataResource
 
isRPCServerRunning() - Method in class org.apache.cassandra.service.StorageService
 
isRPCServerRunning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isRunning() - Method in interface org.apache.cassandra.service.CassandraDaemon.Server
Returns whether the server is currently running.
isRunning() - Method in class org.apache.cassandra.thrift.ThriftServer
 
isRunning() - Method in class org.apache.cassandra.transport.Server
 
isSatisfiedBy(ColumnFamily, ColumnNameBuilder) - 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.
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.JdbcInetAddress
 
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
 
ISSTableSerializer<T> - Interface in org.apache.cassandra.io
 
isStopRequested() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
 
isStreamCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
isStreamCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor.Version
 
isSufficientLiveNodes(Table, Iterable<InetAddress>) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
isSuper() - Method in class org.apache.cassandra.auth.AuthenticatedUser
Checks the user's superuser status.
isSuper() - Method in class org.apache.cassandra.db.ColumnFamily
 
isSuperuser(String) - Static method in class org.apache.cassandra.auth.Auth
Checks if the user is a known superuser.
isSupportedBy(SemanticVersion) - Method in class org.apache.cassandra.utils.SemanticVersion
 
isTerminated() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
isThriftIncompatible() - Method in class org.apache.cassandra.config.CFMetaData
Returns whether this CFMetaData has information non exposed on thrift so that it cannot be correctly handled automatically by thrift clients.
isThriftServerRunning() - Method in class org.apache.cassandra.tools.NodeProbe
 
isTracing() - Static method in class org.apache.cassandra.tracing.Tracing
Indicates if the current thread's execution is being traced.
isTracingRequested() - Method in class org.apache.cassandra.transport.Message.Request
 
IStreamCallback - Interface in org.apache.cassandra.streaming
Callback interface for streaming session success/failure.
isUnary() - Method in class org.apache.cassandra.cql.Operation
 
isUnreadable(File) - Static method in class org.apache.cassandra.db.BlacklistedDirectories
Tells whether or not the directory is blacklisted for reads.
isUnused() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
isUnwritable(File) - Static method in class org.apache.cassandra.db.BlacklistedDirectories
Tells whether or not the directory is blacklisted for writes.
isUserDefined - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
isValid() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isValid(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
isWildcard() - Method in class org.apache.cassandra.cql.SelectExpression
 
isWildcard() - Method in class org.apache.cassandra.cql.SelectStatement
 
isWorthMergingForRangeQuery(List<InetAddress>, List<InetAddress>, List<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
 
isWorthMergingForRangeQuery(List<InetAddress>, List<InetAddress>, List<InetAddress>) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
isWorthMergingForRangeQuery(List<InetAddress>, List<InetAddress>, List<InetAddress>) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
Returns whether for a range query doing a query against merged is likely to be faster than 2 sequential queries, one against l1 followed by one against l2.
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
 
isWritetime - Variable in class org.apache.cassandra.cql3.statements.RawSelector.WritetimeOrTTL
 
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(ColumnSlice[]) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
iterator() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
iterator() - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
iterator(ColumnSlice[]) - 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(ColumnSlice[]) - Method in interface org.apache.cassandra.db.ISortedColumns
Returns an iterator over the columns of this map that returns only the matching @param slices.
iterator() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
iterator() - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
iterator() - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
iterator(ColumnSlice[]) - 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.BoundedStatsDeque
 
iterator() - Method in class org.apache.cassandra.utils.IntervalTree
 
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
Transport factory for establishing thrift connections from clients to a remote server.
IVerbHandler<T> - 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
 

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
 
JdbcInetAddress - 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
 
jmxConn - Variable in class org.apache.cassandra.tools.AbstractJmxClient
 
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
Deprecated.
jmxPassword - Variable in class org.apache.cassandra.cli.CliSessionState
 
jmxPort - Variable in class org.apache.cassandra.cli.CliSessionState
 
jmxUsername - Variable in class org.apache.cassandra.cli.CliSessionState
 
jnaAvailable() - Static method in class org.apache.cassandra.utils.CLibrary
 
jnaMemoryLockable() - Static method in class org.apache.cassandra.utils.CLibrary
 
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_ALLOW - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_ALLOW - 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_AUTHORIZE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_AUTHORIZE - 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_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_CUSTOM - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_CUSTOM - 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_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_FILTERING - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_FILTERING - 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_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_GRANT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_GRANT - 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_INET - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_INET - 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_KEYSPACES - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_KEYSPACES - 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_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_MAP - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_MAP - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_MODIFY - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_MODIFY - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_NORECURSIVE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_NORECURSIVE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_NOSUPERUSER - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_NOSUPERUSER - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_NULL - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_NULL - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_OF - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_OF - 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_ORDER - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_ORDER - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_PASSWORD - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_PASSWORD - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_PERMISSION - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_PERMISSION - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_PERMISSIONS - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_PERMISSIONS - 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_RENAME - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_RENAME - 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_SUPERUSER - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_SUPERUSER - 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_UNLOGGED - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_UNLOGGED - 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_USER - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_USER - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_USERS - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_USERS - 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
 
keepAlive - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
 
key - Variable in class org.apache.cassandra.cache.KeyCacheKey
 
key - Variable in class org.apache.cassandra.cache.RowCacheKey
 
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 - Variable in class org.apache.cassandra.db.SliceQueryPager
 
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
 
keyAliases(List<ByteBuffer>) - Method in class org.apache.cassandra.config.CFMetaData
 
keyCache - Variable in class org.apache.cassandra.service.CacheService
 
keyCacheHitRate - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Key cache hit rate for this CF
KeyCacheKey - Class in org.apache.cassandra.cache
 
KeyCacheKey(Descriptor, ByteBuffer) - Constructor for class org.apache.cassandra.cache.KeyCacheKey
 
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
 
keys - Variable in class org.apache.cassandra.cql3.CFDefinition
 
keys - Variable in class org.apache.cassandra.db.marshal.MapType
 
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.BiMultiValMap
 
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(String) - Static method in class org.apache.cassandra.auth.DataResource
Creates a DataResource representing a keyspace.
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.AlterKeyspaceStatement
 
keyspace() - Method in class org.apache.cassandra.cql3.statements.CFStatement
 
keyspace() - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
 
keyspace() - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
 
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
 
keyspace - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
keyspace - Variable in class org.apache.cassandra.transport.Event.SchemaChange
 
keyspace - Variable in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
 
keyspace - Variable in class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
 
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
Deprecated.
KEYSPACES - Static variable in class org.apache.cassandra.cli.CliLexer
 
KEYSPACES - Static variable in class org.apache.cassandra.cli.CliParser
 
keySpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Maps
 
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 - Variable in class org.apache.cassandra.db.marshal.CollectionType
 
kind() - Method in class org.apache.cassandra.db.RowPosition
 
kind() - Method in class org.apache.cassandra.dht.Token.KeyBound
 
kind - Variable in class org.apache.cassandra.transport.messages.ResultMessage
 
knowsVersion(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
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.cql3.ColumnSpecification
 
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 exception org.apache.cassandra.exceptions.AlreadyExistsException
 
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 - Static variable in class org.apache.cassandra.cql3.CFPropDefs
 
KW_COMPACTION_STRATEGY_CLASS - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
KW_COMPARATOR - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
KW_COMPRESSION - Static variable in class org.apache.cassandra.cql3.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_POPULATE_IO_CACHE_ON_FLUSH - Static variable in class org.apache.cassandra.cql.CFPropDefs
 
KW_POPULATE_IO_CACHE_ON_FLUSH - 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 - 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
 
lastCounted(ColumnFamily) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
 
lastCounted() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
lastException - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
 
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
 
lastLatency - Variable in class org.apache.cassandra.metrics.LatencyMetrics
 
lastName - Variable in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
lastOpCount - Variable in class org.apache.cassandra.metrics.LatencyMetrics
 
lastWriteFuture - Variable in class org.apache.cassandra.transport.SimpleClient
 
latch - Variable in class org.apache.cassandra.dht.RangeStreamer
 
latency - Variable in class org.apache.cassandra.metrics.LatencyMetrics
Latency
LatencyMetrics - Class in org.apache.cassandra.metrics
Metrics about latencies
LatencyMetrics(String, String, String) - Constructor for class org.apache.cassandra.metrics.LatencyMetrics
Create LatencyMetrics with given group, type, and scope.
LatencyMetrics(String, String, String, String) - Constructor for class org.apache.cassandra.metrics.LatencyMetrics
Create LatencyMetrics with given group, type, prefix to append to each metric name, and scope.
LatencyMetrics(MetricNameFactory, String) - Constructor for class org.apache.cassandra.metrics.LatencyMetrics
Create LatencyMetrics with given group, type, prefix to append to each metric name, and scope.
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
 
LazyColumnIterator - Class in org.apache.cassandra.db.columniterator
 
LazyColumnIterator(DecoratedKey, IColumnIteratorFactory) - Constructor for class org.apache.cassandra.db.columniterator.LazyColumnIterator
 
leaving(Collection<Token>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
left - Variable in class org.apache.cassandra.dht.AbstractBounds
 
left(Collection<Token>, long) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
left - Variable in class org.apache.cassandra.utils.Pair
 
LEGACY - Static variable in class org.apache.cassandra.io.sstable.Descriptor.Version
 
LEGACY_VERSION - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
LegacyAuthenticator - Class in org.apache.cassandra.auth
Provides a transitional IAuthenticator implementation for old-style (pre-1.2) authenticators.
LegacyAuthenticator() - Constructor for class org.apache.cassandra.auth.LegacyAuthenticator
 
LegacyAuthorizer - Class in org.apache.cassandra.auth
Provides a transitional IAuthorizer implementation for old-style (pre-1.2) authorizers.
LegacyAuthorizer() - Constructor for class org.apache.cassandra.auth.LegacyAuthorizer
 
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.transport.Frame.Header
 
LENGTH - Static variable in class org.apache.cassandra.utils.CounterId
 
length() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
LengthAvailableInputStream - Class in org.apache.cassandra.io.util
a FilterInputStream that returns the remaining bytes to read from available() regardless of whether the device is ready to provide them.
LengthAvailableInputStream(InputStream, long) - Constructor for class org.apache.cassandra.io.util.LengthAvailableInputStream
 
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(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
list(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
list(AuthenticatedUser, Set<Permission>, IResource, String) - Method in interface org.apache.cassandra.auth.IAuthorizer
Returns a list of permissions on a resource of a user.
list(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
 
LIST - Static variable in class org.apache.cassandra.cli.CliLexer
 
LIST - Static variable in class org.apache.cassandra.cli.CliParser
 
list(CQL3Type) - Static method in class org.apache.cassandra.cql3.CQL3Type.Collection
 
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
 
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.
listFiles() - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
listPermissionsStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
ListPermissionsStatement - Class in org.apache.cassandra.cql3.statements
 
ListPermissionsStatement(Set<Permission>, IResource, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
Lists - Class in org.apache.cassandra.cql3
Static helper methods and classes for lists.
Lists.Appender - Class in org.apache.cassandra.cql3
 
Lists.Appender(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Lists.Appender
 
Lists.DelayedValue - Class in org.apache.cassandra.cql3
 
Lists.DelayedValue(List<Term>) - Constructor for class org.apache.cassandra.cql3.Lists.DelayedValue
 
Lists.Discarder - Class in org.apache.cassandra.cql3
 
Lists.Discarder(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Lists.Discarder
 
Lists.DiscarderByIndex - Class in org.apache.cassandra.cql3
 
Lists.DiscarderByIndex(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Lists.DiscarderByIndex
 
Lists.Literal - Class in org.apache.cassandra.cql3
 
Lists.Literal(List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.Lists.Literal
 
Lists.Marker - Class in org.apache.cassandra.cql3
 
Lists.Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Lists.Marker
 
Lists.Prepender - Class in org.apache.cassandra.cql3
 
Lists.Prepender(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Lists.Prepender
 
Lists.Setter - Class in org.apache.cassandra.cql3
 
Lists.Setter(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Lists.Setter
 
Lists.SetterByIndex - Class in org.apache.cassandra.cql3
 
Lists.SetterByIndex(ColumnIdentifier, Term, Term) - Constructor for class org.apache.cassandra.cql3.Lists.SetterByIndex
 
Lists.Value - Class in org.apache.cassandra.cql3
 
Lists.Value(List<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Lists.Value
 
listStatement() - Method in class org.apache.cassandra.cli.CliParser
 
ListType<T> - Class in org.apache.cassandra.db.marshal
 
listUsersStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
ListUsersStatement - Class in org.apache.cassandra.cql3.statements
 
ListUsersStatement() - Constructor for class org.apache.cassandra.cql3.statements.ListUsersStatement
 
live() - Static method in class org.apache.cassandra.db.DeletionInfo
 
LIVE - Static variable in class org.apache.cassandra.db.DeletionTime
 
live - Variable in class org.apache.cassandra.db.filter.ColumnCounter
 
live() - Method in class org.apache.cassandra.db.filter.ColumnCounter
 
liveDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Disk space used by SSTables belonging to this CF
liveSSTableCount - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Number of SSTables on disk for this CF
load(Set<ByteBuffer>, ColumnFamilyStore) - Method in interface org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
Deprecated.
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
 
load - Static variable in class org.apache.cassandra.metrics.StorageMetrics
 
load(Set<ByteBuffer>, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.KeyCacheSerializer
 
load(Set<ByteBuffer>, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.RowCacheSerializer
 
LoadBroadcaster - Class in org.apache.cassandra.service
 
loadCql3Defs(Cassandra.Client, KsDef) - Static method in class org.apache.cassandra.cli.CliClient
 
loadCql3DefsUnchecked(Cassandra.Client, KsDef) - Static method in class org.apache.cassandra.cli.CliClient
 
loadDcRackInfo() - Static method in class org.apache.cassandra.db.SystemTable
Return a map of IP addresses containing a map of dc and rack info
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)
loadHostIds() - Static method in class org.apache.cassandra.db.SystemTable
Return a map of store host_ids to IP addresses
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
 
loadSaved(ColumnFamilyStore) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
loadSchemas() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
load keyspace (table) definitions, but do not initialize the table instances.
loadSignature - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
loadSummary(SSTableReader, SegmentedFile.Builder, SegmentedFile.Builder) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
loadTokens() - Static method in class org.apache.cassandra.db.SystemTable
Return a map of stored tokens to IP addresses
LOCAL_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
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
 
LocalCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
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
 
localDeletionTime - Variable in class org.apache.cassandra.cql3.UpdateParameters
 
localDeletionTime - Variable in class org.apache.cassandra.db.DeletionTime
 
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
 
location - Variable in class org.apache.cassandra.db.Directories.DataDirectory
 
log() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
 
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.db.index.SecondaryIndex
 
logger - Static variable in class org.apache.cassandra.gms.EndpointState
 
logger - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
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
 
logger - Static variable in class org.apache.cassandra.tracing.Tracing
 
logger - Static variable in class org.apache.cassandra.transport.Message
 
login(Map<String, String>) - 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
 
login(Map<String, String>) - Method in class org.apache.cassandra.transport.SimpleClient
 
logOpenException(Descriptor, IOException) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
logReadResponse(String, long) - Method in class org.apache.cassandra.service.PBSPredictor
 
logReadResponse(String, long, long) - Method in class org.apache.cassandra.service.PBSPredictor
 
logWriteResponse(String, long) - Method in class org.apache.cassandra.service.PBSPredictor
 
logWriteResponse(String, long, long) - Method in class org.apache.cassandra.service.PBSPredictor
 
LONG_OPTION - Static variable in interface org.apache.cassandra.thrift.ITransportFactory
 
longStringToCB(String) - Static method in class org.apache.cassandra.transport.CBUtil
 
LongToken - Class in org.apache.cassandra.dht
 
LongToken(Long) - Constructor for class org.apache.cassandra.dht.LongToken
 
LongType - Class in org.apache.cassandra.db.marshal
 
ls() - Method in class org.apache.cassandra.tools.Shuffle
Print a list of pending token relocations for all nodes.
LZ4Compressor - Class in org.apache.cassandra.io.compress
 

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.service.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.Shuffle
Execute.
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
 
main(String[]) - Static method in class org.apache.cassandra.tools.StandaloneSplitter
 
main(String[]) - Static method in class org.apache.cassandra.tools.StandaloneUpgrader
 
main(String[]) - Static method in class org.apache.cassandra.transport.Client
 
major - Variable in class org.apache.cassandra.utils.SemanticVersion
 
makeArgSpec(ColumnSpecification, Function, int) - Static method in class org.apache.cassandra.cql3.functions.Functions
 
makeColumn(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
makeCountResult() - Method in class org.apache.cassandra.cql3.ResultSet
 
makeFilename(File, String, String) - Static method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
makeFromBlobFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.BytesConversionFcts
 
makeIndexColumnName(ByteBuffer, IColumn) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
makeIndexColumnName(ByteBuffer, IColumn) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
 
makeIndexColumnName(ByteBuffer, IColumn) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
makeMutationMessage() - Method in class org.apache.cassandra.db.CounterMutation
 
makeRangeTombstone(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
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.
makeToBlobFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.BytesConversionFcts
 
makeTombstone(ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
makeTombstoneForOverwrite(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
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
 
map(CQL3Type, CQL3Type) - Static method in class org.apache.cassandra.cql3.CQL3Type.Collection
 
map - Variable in class org.apache.cassandra.cql3.Maps.Value
 
map_literal() - Method in class org.apache.cassandra.cql3.CqlParser
 
mAPI_VERSION() - Method in class org.apache.cassandra.cli.CliLexer
 
MappedFileDataInput - Class in org.apache.cassandra.io.util
 
MappedFileDataInput(FileInputStream, String, long, int) - Constructor for class org.apache.cassandra.io.util.MappedFileDataInput
 
MappedFileDataInput(MappedByteBuffer, String, long, int) - Constructor for class org.apache.cassandra.io.util.MappedFileDataInput
 
MAPRED_TASK_ID - Static variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
 
Maps - Class in org.apache.cassandra.cql3
Static helper methods and classes for maps.
Maps.DelayedValue - Class in org.apache.cassandra.cql3
 
Maps.DelayedValue(Comparator<ByteBuffer>, Map<Term, Term>) - Constructor for class org.apache.cassandra.cql3.Maps.DelayedValue
 
Maps.DiscarderByKey - Class in org.apache.cassandra.cql3
 
Maps.DiscarderByKey(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Maps.DiscarderByKey
 
Maps.Literal - Class in org.apache.cassandra.cql3
 
Maps.Literal(List<Pair<Term.Raw, Term.Raw>>) - Constructor for class org.apache.cassandra.cql3.Maps.Literal
 
Maps.Marker - Class in org.apache.cassandra.cql3
 
Maps.Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Maps.Marker
 
Maps.Putter - Class in org.apache.cassandra.cql3
 
Maps.Putter(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Maps.Putter
 
Maps.Setter - Class in org.apache.cassandra.cql3
 
Maps.Setter(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Maps.Setter
 
Maps.SetterByKey - Class in org.apache.cassandra.cql3
 
Maps.SetterByKey(ColumnIdentifier, Term, Term) - Constructor for class org.apache.cassandra.cql3.Maps.SetterByKey
 
Maps.Value - Class in org.apache.cassandra.cql3
 
Maps.Value(Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Maps.Value
 
MapType<K,V> - Class in org.apache.cassandra.db.marshal
 
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(int) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
 
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
 
mark() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
 
markClean(UUID, 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>) - 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.DeletionTime
 
markedPointer - Variable in class org.apache.cassandra.io.util.RandomAccessReader
 
markReferenced(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
markReferenced(AbstractBounds<RowPosition>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
markReferenced(Collection<AbstractBounds<RowPosition>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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.LengthAvailableInputStream
 
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.Interval
 
max() - Method in class org.apache.cassandra.utils.IntervalTree
 
MAX_CACHE_PREPARED - Static variable in class org.apache.cassandra.cql3.QueryProcessor
 
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_hints_delivery_threads - 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.Murmur3Partitioner
 
MAXIMUM - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 
maxKeyBound(IPartitioner) - Method in class org.apache.cassandra.dht.Token
 
maxKeyBound() - Method in class org.apache.cassandra.dht.Token
 
maxMarkedAt() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
maxResults - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
maxRows() - Method in class org.apache.cassandra.db.filter.ExtendedFilter
 
maxRowSize - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Size of the largest compacted row
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.DeletionInfo
The maximum timestamp mentioned by this DeletionInfo.
maxTimestamp() - Method in interface org.apache.cassandra.db.IColumn
For a standard column, this is the same as timestamp().
maxTimestamp() - Method in interface org.apache.cassandra.db.OnDiskAtom
 
maxTimestamp() - Method in class org.apache.cassandra.db.RangeTombstone
 
maxTimestamp() - Method in class org.apache.cassandra.db.SuperColumn
 
maxTimestamp - Variable in class org.apache.cassandra.io.sstable.ColumnStats
 
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
 
maxTimeUUID(long) - Static method in class org.apache.cassandra.utils.UUIDGen
Returns the biggest possible type 1 UUID having the provided timestamp.
maxTimeuuidFct - Static variable in class org.apache.cassandra.cql3.functions.TimeuuidFcts
 
maybeAddEntry(DecoratedKey, long) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
maybeAddLatency(IMessageCallback, InetAddress, long) - 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>, Set<String>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
Does a full, blocking rebuild of the indexes specified by columns from the sstables.
maybeCorrectResource(DataResource, ClientState) - Static method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
maybeCreateWriter(ColumnFamilyStore, File, int, SSTableWriter, Collection<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
 
maybeEscapeName(String) - Static method in class org.apache.cassandra.cli.CliUtils
 
maybeGenerateRetryCommand(RowDataResolver, Row) - Method in class org.apache.cassandra.db.ReadCommand
 
maybeGenerateRetryCommand(RowDataResolver, Row) - Method in class org.apache.cassandra.db.SliceFromReadCommand
 
maybeIncrementallyBackup(SSTableReader) - Method in class org.apache.cassandra.db.DataTracker
 
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.
maybeMarkUnreadable(File) - Static method in class org.apache.cassandra.db.BlacklistedDirectories
Adds parent directory of the file (or the file itself, if it is a directory) to the set of unreadable directories.
maybeMarkUnwritable(File) - Static method in class org.apache.cassandra.db.BlacklistedDirectories
Adds parent directory of the file (or the file itself, if it is a directory) to the set of unwritable directories.
maybeRenew(CounterColumn) - Method in class org.apache.cassandra.utils.CounterId.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
 
maybeTrim(Row) - Method in class org.apache.cassandra.db.ReadCommand
 
maybeTrim(Row) - Method in class org.apache.cassandra.db.SliceFromReadCommand
 
maybeUpdateRowCache(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
maybeWaitForArchiving(String) - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
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.db.BlacklistedDirectories
 
MBEAN_NAME - Static variable in class org.apache.cassandra.db.HintedHandOffManager
 
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.CassandraDaemon
 
MBEAN_NAME - Static variable in class org.apache.cassandra.service.PBSPredictor
 
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
 
mBOOLEAN() - Method in class org.apache.cassandra.cql3.CqlLexer
 
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
 
MD5Digest - Class in org.apache.cassandra.utils
The result of the computation of an MD5 digest.
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.BoundedStatsDeque
 
mean() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
meanRowSize - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Size of the smallest compacted row
measureDeep(Object) - Static method in class org.apache.cassandra.utils.ObjectSizes
 
Memory - Class in org.apache.cassandra.io.util
An off-heap region of memory that must be manually free'd when no longer needed.
Memory(long) - Constructor for class org.apache.cassandra.io.util.Memory
 
MemoryInputStream - Class in org.apache.cassandra.io.util
 
MemoryInputStream(RefCountedMemory) - 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
 
memorySize() - Method in interface org.apache.cassandra.cache.IMeasurableMemory
 
memorySize() - Method in class org.apache.cassandra.cache.KeyCacheKey
 
memorySize() - Method in class org.apache.cassandra.cache.RowCacheKey
 
memorySize() - Method in class org.apache.cassandra.cache.RowCacheSentinel
 
memorySize() - Method in class org.apache.cassandra.db.ColumnFamily
 
memorySize() - Method in class org.apache.cassandra.db.DeletionTime
 
memorySize() - Method in class org.apache.cassandra.db.RowIndexEntry
 
memorySize() - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
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
 
memtableColumnsCount - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Total number of columns present in the memtable.
memtableDataSize - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Total amount of data stored in the memtable, including column related overhead.
memtables - Variable in class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
 
memtableSwitchCount - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Number of times flush has resulted in the memtable being switched out.
merge(ColumnFamily, List<CloseableIterator<IColumn>>, SecondaryIndexManager.Updater) - Static method in class org.apache.cassandra.db.compaction.PrecompactedRow
 
merge(ByteBuffer, ByteBuffer, Allocator) - Method in class org.apache.cassandra.db.context.CounterContext
Return a context w/ an aggregated count for each counter 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(StreamingHistogram) - Method in class org.apache.cassandra.utils.StreamingHistogram
Merges given histogram with this histogram.
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.
mergeCounters - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
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
 
mergeSchema(Collection<RowMutation>) - 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)
mergeShardBefore - Variable in class org.apache.cassandra.db.compaction.CompactionController
 
mergeTombstoneHistogram(StreamingHistogram) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
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.transport
A message from the CQL binary protocol.
Message(Message.Type) - Constructor for class org.apache.cassandra.transport.Message
 
Message.Codec<M extends Message> - Interface in org.apache.cassandra.transport
 
Message.Direction - Enum in org.apache.cassandra.transport
 
Message.Dispatcher - Class in org.apache.cassandra.transport
 
Message.Dispatcher() - Constructor for class org.apache.cassandra.transport.Message.Dispatcher
 
Message.ProtocolDecoder - Class in org.apache.cassandra.transport
 
Message.ProtocolDecoder() - Constructor for class org.apache.cassandra.transport.Message.ProtocolDecoder
 
Message.ProtocolEncoder - Class in org.apache.cassandra.transport
 
Message.ProtocolEncoder() - Constructor for class org.apache.cassandra.transport.Message.ProtocolEncoder
 
Message.Request - Class in org.apache.cassandra.transport
 
Message.Request(Message.Type) - Constructor for class org.apache.cassandra.transport.Message.Request
 
Message.Response - Class in org.apache.cassandra.transport
 
Message.Response(Message.Type) - Constructor for class org.apache.cassandra.transport.Message.Response
 
Message.Type - Enum in org.apache.cassandra.transport
 
MessageDeliveryTask - Class in org.apache.cassandra.net
 
MessageDeliveryTask(MessageIn, String, long) - Constructor for class org.apache.cassandra.net.MessageDeliveryTask
 
MessageIn<T> - Class in org.apache.cassandra.net
 
MessageOut<T> - Class in org.apache.cassandra.net
 
MessageOut(MessagingService.Verb) - Constructor for class org.apache.cassandra.net.MessageOut
 
MessageOut(MessagingService.Verb, T, IVersionedSerializer<T>) - Constructor for class org.apache.cassandra.net.MessageOut
 
MessageOut(InetAddress, MessagingService.Verb, T, IVersionedSerializer<T>, Map<String, byte[]>) - Constructor for class org.apache.cassandra.net.MessageOut
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.apache.cassandra.transport.Message.Dispatcher
 
MessagingService - Class in org.apache.cassandra.net
 
MessagingService.Verb - Enum 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 - Variable in class org.apache.cassandra.cql3.ResultSet
 
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.CompressedPoolingSegmentedFile
 
metadata - Variable in class org.apache.cassandra.io.util.CompressedSegmentedFile
 
metadata - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
 
metadataIncludesModernReplayPosition - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
 
metadataIncludesReplayPosition - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
 
MeteredFlusher - Class in org.apache.cassandra.db
 
MeteredFlusher() - Constructor for class org.apache.cassandra.db.MeteredFlusher
 
metric - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
MetricNameFactory - Interface in org.apache.cassandra.metrics
 
metrics - Variable in class org.apache.cassandra.db.HintedHandOffManager
 
metrics - Variable in class org.apache.cassandra.streaming.FileStreamTask
 
mEXIT() - Method in class org.apache.cassandra.cli.CliLexer
 
mEXPONENT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
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
 
mHEXNUMBER() - Method in class org.apache.cassandra.cql3.CqlLexer
 
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.Murmur3Partitioner
 
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.
migrateKeyAlias() - Static method in class org.apache.cassandra.db.SystemTable
1.1 used a key_alias column; 1.2 changed that to key_aliases as part of CQL3
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
 
MIGRATION_DELAY_IN_MS - Static variable in class org.apache.cassandra.service.MigrationManager
 
MigrationManager - Class in org.apache.cassandra.service
 
MigrationManager.MigrationsSerializer - Class in org.apache.cassandra.service
 
MigrationManager.MigrationsSerializer() - Constructor for class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
 
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
 
min() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
min - Variable in class org.apache.cassandra.utils.Interval
 
min() - Method in class org.apache.cassandra.utils.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.Murmur3Partitioner
 
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
 
minMarkedAt() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
minor - Variable in class org.apache.cassandra.utils.SemanticVersion
 
minRowSize - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Size of the smallest compacted row
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
 
minTimestamp() - Method in class org.apache.cassandra.db.Column
 
minTimestamp() - Method in class org.apache.cassandra.db.DeletionInfo
 
minTimestamp() - Method in interface org.apache.cassandra.db.OnDiskAtom
For a standard column, this is the same as timestamp().
minTimestamp() - Method in class org.apache.cassandra.db.RangeTombstone
 
minTimestamp() - Method in class org.apache.cassandra.db.SuperColumn
 
minTimestamp - Variable in class org.apache.cassandra.io.sstable.ColumnStats
the largest (client-supplied) timestamp in the row
minTimestamp - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
minTimestamp - Variable in class org.apache.cassandra.io.sstable.SSTableMetadata
 
minTimeUUID(long) - Static method in class org.apache.cassandra.utils.UUIDGen
Returns the smaller possible type 1 UUID having the provided timestamp.
minTimeuuidFct - Static variable in class org.apache.cassandra.cql3.functions.TimeuuidFcts
 
minValue(Class<R>) - Method in class org.apache.cassandra.dht.AbstractPartitioner
 
minValue(Class<R>) - 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_ALLOW() - 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_AUTHORIZE() - 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_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_CUSTOM() - 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_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_FILTERING() - 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_FROM() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_FROM() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_GRANT() - 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_INET() - 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_KEYSPACES() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_LEVEL() - Method in class org.apache.cassandra.cql.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_MAP() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_MODIFY() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_NORECURSIVE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_NOSUPERUSER() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_NULL() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_OF() - 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_ORDER() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_PASSWORD() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_PERMISSION() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_PERMISSIONS() - 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_RENAME() - 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_SUPERUSER() - 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_UNLOGGED() - 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_USER() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_USERS() - 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
 
mNEXT() - Method in class org.apache.cassandra.cli.CliLexer
 
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
 
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, Long, int) - Constructor for class org.apache.cassandra.cql3.statements.ModificationStatement
 
ModificationStatement.Type - Enum in org.apache.cassandra.cql3.statements
 
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
 
movedNode(InetAddress, int) - Static method in class org.apache.cassandra.transport.Event.TopologyChange
 
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
 
mPROBABILITY() - Method in class org.apache.cassandra.cli.CliLexer
 
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
 
mQUERY() - Method in class org.apache.cassandra.cli.CliLexer
 
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.cql.CqlLexer
 
mT__106() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__107() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__111() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__112() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__113() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__114() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__115() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__116() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__117() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__118() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__119() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__120() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__121() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__122() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__123() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__124() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__125() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__126() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__127() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__127() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__128() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__128() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__129() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__129() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__130() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__130() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__131() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__131() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__132() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__132() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__133() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__134() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__135() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__136() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__137() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__138() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__139() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__140() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__141() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__142() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__143() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__144() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__81() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__82() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__83() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__84() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__85() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__86() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__87() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__88() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__89() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__90() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__91() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__92() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__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
 
mTRACE() - Method in class org.apache.cassandra.cli.CliLexer
 
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
 
Murmur2BloomFilter - Class in org.apache.cassandra.utils
 
Murmur2BloomFilter(int, IBitSet) - Constructor for class org.apache.cassandra.utils.Murmur2BloomFilter
 
Murmur2BloomFilter.Murmur2BloomFilterSerializer - Class in org.apache.cassandra.utils
 
Murmur2BloomFilter.Murmur2BloomFilterSerializer() - Constructor for class org.apache.cassandra.utils.Murmur2BloomFilter.Murmur2BloomFilterSerializer
 
Murmur3BloomFilter - Class in org.apache.cassandra.utils
 
Murmur3BloomFilter(int, IBitSet) - Constructor for class org.apache.cassandra.utils.Murmur3BloomFilter
 
Murmur3BloomFilter.Murmur3BloomFilterSerializer - Class in org.apache.cassandra.utils
 
Murmur3BloomFilter.Murmur3BloomFilterSerializer() - Constructor for class org.apache.cassandra.utils.Murmur3BloomFilter.Murmur3BloomFilterSerializer
 
Murmur3Partitioner - Class in org.apache.cassandra.dht
This class generates a BigIntegerToken using a Murmur3 hash.
Murmur3Partitioner() - Constructor for class org.apache.cassandra.dht.Murmur3Partitioner
 
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(Collection<? extends IMutation>, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
Use this method to have these Mutations applied across all replicas.
mutateAtomically(Collection<RowMutation>, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
See mutate.
mutateCounter(CounterMutation, String) - Static method in class org.apache.cassandra.service.StorageProxy
Handle counter mutation on the coordinator host.
mutationForKey(ByteBuffer, String, Long, ThriftClientState, List<ByteBuffer>, CFMetaData) - Method in class org.apache.cassandra.cql.DeleteStatement
 
mutationForKey(CFDefinition, ByteBuffer, ColumnNameBuilder, boolean, UpdateParameters) - 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.ColumnSpecification
 
name - Variable in class org.apache.cassandra.cql3.functions.AbstractFunction
 
name() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
name() - Method in interface org.apache.cassandra.cql3.functions.Function
 
name - Variable in class org.apache.cassandra.db.Column
 
name() - Method in class org.apache.cassandra.db.Column
 
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 interface org.apache.cassandra.db.OnDiskAtom
 
name() - Method in class org.apache.cassandra.db.RangeTombstone
 
name() - Method in class org.apache.cassandra.db.SuperColumn
 
name - Variable in class org.apache.cassandra.db.Table
 
name - Variable in class org.apache.cassandra.io.sstable.Component
 
name() - Method in class org.apache.cassandra.io.sstable.Component
 
name - Variable in class org.apache.cassandra.tools.NodeToolHelp.NodeToolCommand
 
NAME_LENGTH - Static variable in class org.apache.cassandra.config.Schema
longest permissible KS or CF name.
nameComparator() - Method in class org.apache.cassandra.db.marshal.CollectionType
 
nameComparator() - Method in class org.apache.cassandra.db.marshal.ListType
 
nameComparator() - Method in class org.apache.cassandra.db.marshal.MapType
 
nameComparator() - Method in class org.apache.cassandra.db.marshal.SetType
 
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
 
namePrefix - Variable in class org.apache.cassandra.metrics.LatencyMetrics
 
names - Variable in class org.apache.cassandra.cql3.ResultSet.Metadata
 
NamesQueryFilter - Class in org.apache.cassandra.db.filter
 
NamesQueryFilter(SortedSet<ByteBuffer>) - Constructor for class org.apache.cassandra.db.filter.NamesQueryFilter
 
NamesQueryFilter(SortedSet<ByteBuffer>, boolean) - Constructor for class org.apache.cassandra.db.filter.NamesQueryFilter
 
NamesQueryFilter(ByteBuffer) - Constructor for class org.apache.cassandra.db.filter.NamesQueryFilter
 
NamesQueryFilter.Serializer - Class in org.apache.cassandra.db.filter
 
NamesQueryFilter.Serializer() - Constructor for class org.apache.cassandra.db.filter.NamesQueryFilter.Serializer
 
NATIVE - Static variable in class org.apache.cassandra.db.TypeSizes
 
native_transport_max_threads - Variable in class org.apache.cassandra.config.Config
 
native_transport_min_threads - Variable in class org.apache.cassandra.config.Config
 
native_transport_port - Variable in class org.apache.cassandra.config.Config
 
native_type() - Method in class org.apache.cassandra.cql3.CqlParser
 
NativeAccessMBean - Interface in org.apache.cassandra.service
 
nativeServer - Variable in class org.apache.cassandra.service.CassandraDaemon
 
naturalEndpoints - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
needsFiltering() - Method in class org.apache.cassandra.db.ColumnFamilyStore.AbstractScanIterator
 
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.JdbcInetAddress
 
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
 
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
 
networkVersion() - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
new_version - Variable in class org.apache.cassandra.db.migration.avro.Migration
 
newAuthenticator(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newAuthorizer(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newCacheProvider(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newColumnFamily() - Method in class org.apache.cassandra.cli.CliParser
 
newConnection(Connection.Tracker) - Method in interface org.apache.cassandra.transport.Connection.Factory
 
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
 
newNode(InetAddress, int) - Static method in class org.apache.cassandra.transport.Event.TopologyChange
 
newPartitioner(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newReadRepairDecision() - Method in class org.apache.cassandra.config.CFMetaData
 
newRow() - Method in class org.apache.cassandra.cql3.statements.Selection.ResultSetBuilder
 
newRow(ByteBuffer) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
Start a new row whose key is key.
newSession() - Method in class org.apache.cassandra.tracing.Tracing
 
newSession(UUID) - Method in class org.apache.cassandra.tracing.Tracing
 
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
 
newSSTableSegmentThresholdReached(SSTableWriter) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
 
newSuperColumn(ByteBuffer) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
Start a new super column with name name.
newTaskFor(Runnable, T) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
newTaskFor(Callable<T>) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
newThread(Runnable) - Method in class org.apache.cassandra.concurrent.NamedThreadFactory
 
NEXT - Static variable in class org.apache.cassandra.cli.CliLexer
 
NEXT - Static variable in class org.apache.cassandra.cli.CliParser
 
next() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
next() - Method in class org.apache.cassandra.db.SliceQueryPager
 
next(ByteBuffer, SortedMap<ByteBuffer, IColumn>) - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
next(Map<String, ByteBuffer>, Map<String, ByteBuffer>) - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
 
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.FilteredKeyScanningIterator
 
next() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
 
next() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
nextEntry - Variable in class org.apache.cassandra.io.sstable.SSTableScanner.FilteredKeyScanningIterator
 
nextKey - Variable in class org.apache.cassandra.io.sstable.SSTableScanner.FilteredKeyScanningIterator
 
nextKeyValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
nextKeyValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlPagingRecordReader
 
nextToken() - Method in class org.apache.cassandra.cql.CqlLexer
 
nextToken() - Method in class org.apache.cassandra.cql3.CqlLexer
 
NO_COMPRESSION_RATIO - Static variable in class org.apache.cassandra.io.sstable.SSTableMetadata
 
NO_GC - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
 
node - Variable in class org.apache.cassandra.transport.Event.StatusChange
 
node - Variable in class org.apache.cassandra.transport.Event.TopologyChange
 
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_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_SET_TRACE_PROBABILITY - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_SET_TRACE_PROBABILITY - 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_TRACE_NEXT_QUERY - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_TRACE_NEXT_QUERY - 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
 
nodeDown(InetAddress, int) - Static method in class org.apache.cassandra.transport.Event.StatusChange
 
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.
NodeToolHelp - Class in org.apache.cassandra.tools
 
NodeToolHelp() - Constructor for class org.apache.cassandra.tools.NodeToolHelp
 
NodeToolHelp.NodeToolCommand - Class in org.apache.cassandra.tools
 
NodeToolHelp.NodeToolCommand() - Constructor for class org.apache.cassandra.tools.NodeToolHelp.NodeToolCommand
 
nodeUp(InetAddress, int) - Static method in class org.apache.cassandra.transport.Event.StatusChange
 
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
 
nonSystem() - Static method in class org.apache.cassandra.db.Table
 
normal(Collection<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
 
nothing() - Static method in class org.apache.cassandra.db.ColumnIndex
 
notifyAdded(SSTableReader) - Method in class org.apache.cassandra.db.DataTracker
 
notifyCreateColumnFamily(CFMetaData) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyCreateKeyspace(KSMetaData) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyDropColumnFamily(CFMetaData) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyDropKeyspace(KSMetaData) - Method in class org.apache.cassandra.service.MigrationManager
 
notifySSTablesChanged(Iterable<SSTableReader>, Iterable<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.DataTracker
 
notifyUpdateColumnFamily(CFMetaData) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyUpdateKeyspace(KSMetaData) - Method in class org.apache.cassandra.service.MigrationManager
 
nowFct - Static variable in class org.apache.cassandra.cql3.functions.TimeuuidFcts
 
NULL_LITERAL - Static variable in class org.apache.cassandra.cql3.Constants
 
nullUpdater - Static variable in class org.apache.cassandra.db.index.SecondaryIndexManager
 
num_tokens - Variable in class org.apache.cassandra.config.Config
 
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
 
ObjectSizes - Class in org.apache.cassandra.utils
Modified version of the code from.
ObjectSizes() - Constructor for class org.apache.cassandra.utils.ObjectSizes
 
ObjectSizes.MemoryLayoutSpecification - Interface in org.apache.cassandra.utils
Describes constant memory overheads for various constructs in a JVM implementation.
objToBB(Object) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
convert object to ByteBuffer
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
 
OffHeapBitSet - Class in org.apache.cassandra.utils.obs
Off-heap bitset, file compatible with OpeBitSet
OffHeapBitSet(long) - Constructor for class org.apache.cassandra.utils.obs.OffHeapBitSet
 
offset - Variable in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
 
offset - Variable in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
OLD_HINTS_CF - Static variable in class org.apache.cassandra.db.SystemTable
Deprecated.
OLD_HISTORYFILE - Static variable in class org.apache.cassandra.cli.CliMain
 
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_STATUS_CF - Static variable in class org.apache.cassandra.db.SystemTable
Deprecated.
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.
OldHintsCf - Static variable in class org.apache.cassandra.config.CFMetaData
Deprecated.
oldKs - Variable in class org.apache.cassandra.db.migration.avro.UpdateKeyspace
 
OldMigrationsCf - Static variable in class org.apache.cassandra.config.CFMetaData
Deprecated.
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
 
OldSchemaCf - Static variable in class org.apache.cassandra.config.CFMetaData
Deprecated.
OldStatusCf - Static variable in class org.apache.cassandra.config.CFMetaData
Deprecated.
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.ReconnectableSnitchHelper
 
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.ReconnectableSnitchHelper
 
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
 
onCreateColumnFamily(String, String) - Method in class org.apache.cassandra.auth.Auth.MigrationListener
 
onCreateColumnFamily(String, String) - Method in interface org.apache.cassandra.service.IMigrationListener
 
onCreateKeyspace(String) - Method in class org.apache.cassandra.auth.Auth.MigrationListener
 
onCreateKeyspace(String) - Method in interface org.apache.cassandra.service.IMigrationListener
 
onDead(InetAddress, EndpointState) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.locator.ReconnectableSnitchHelper
 
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
 
OnDiskAtom - Interface in org.apache.cassandra.db
 
OnDiskAtom.Serializer - Class in org.apache.cassandra.db
 
OnDiskAtom.Serializer(IColumnSerializer) - Constructor for class org.apache.cassandra.db.OnDiskAtom.Serializer
 
onDiskAtomComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
OnDiskAtomIterator - Interface in org.apache.cassandra.db.columniterator
 
onDiskLength() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
onDiskLength - Variable in class org.apache.cassandra.io.util.SegmentedFile
 
onDiskSerializer() - Static method in class org.apache.cassandra.db.Column
 
onDiskSerializer(AbstractType<?>) - Static method in class org.apache.cassandra.db.SuperColumn
 
onDown(InetAddress) - Method in interface org.apache.cassandra.service.IEndpointLifecycleSubscriber
Called when a node is marked DOWN.
onDropColumnFamily(String, String) - Method in class org.apache.cassandra.auth.Auth.MigrationListener
 
onDropColumnFamily(String, String) - Method in interface org.apache.cassandra.service.IMigrationListener
 
onDropKeyspace(String) - Method in class org.apache.cassandra.auth.Auth.MigrationListener
 
onDropKeyspace(String) - Method in interface org.apache.cassandra.service.IMigrationListener
 
one() - Method in class org.apache.cassandra.cql3.UntypedResultSet
 
oneSerializedSize(Pair<T, Object>) - Method in class org.apache.cassandra.transport.OptionCodec
 
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.ReconnectableSnitchHelper
 
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
 
onJoinCluster(InetAddress) - Method in interface org.apache.cassandra.service.IEndpointLifecycleSubscriber
Called when a new node joins the cluster, i.e.
onKeyChange() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
Called at the begining of each new key, before any reduce is called.
onLeaveCluster(InetAddress) - Method in interface org.apache.cassandra.service.IEndpointLifecycleSubscriber
Called when a new node leave the cluster (decommission or removeToken).
onlyBackups(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
onMove(InetAddress) - Method in interface org.apache.cassandra.service.IEndpointLifecycleSubscriber
Called when a node has moved (to a new token).
onRemove(InetAddress) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onRemove(InetAddress) - Method in class org.apache.cassandra.locator.ReconnectableSnitchHelper
 
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.ReconnectableSnitchHelper
 
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
 
onUp(InetAddress) - Method in interface org.apache.cassandra.service.IEndpointLifecycleSubscriber
Called when a node is marked UP.
onUpdateColumnFamily(String, String) - Method in class org.apache.cassandra.auth.Auth.MigrationListener
 
onUpdateColumnFamily(String, String) - Method in interface org.apache.cassandra.service.IMigrationListener
 
onUpdateKeyspace(String) - Method in class org.apache.cassandra.auth.Auth.MigrationListener
 
onUpdateKeyspace(String) - Method in interface org.apache.cassandra.service.IMigrationListener
 
opcode - Variable in enum org.apache.cassandra.transport.Message.Type
 
open(String) - Static method in class org.apache.cassandra.db.Table
 
open(String, CompressionMetadata, CompressedPoolingSegmentedFile) - 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(String, CompressionMetadata, RateLimiter) - Static method in class org.apache.cassandra.io.compress.CompressedThrottledReader
 
open(String) - Static method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
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(File) - Static method in class org.apache.cassandra.io.util.RandomAccessReader
 
open(File, PoolingSegmentedFile) - Static method in class org.apache.cassandra.io.util.RandomAccessReader
 
open(File, boolean) - 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(File, RateLimiter) - Static method in class org.apache.cassandra.io.util.ThrottledReader
 
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
 
openAll(Set<Map.Entry<Descriptor, Set<Component>>>, CFMetaData, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
OpenBitSet - Class in org.apache.cassandra.utils.obs
An "open" BitSet implementation that allows direct access to the 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
 
openDataReader(RateLimiter) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
openDataReader(boolean) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
openForBatch(Descriptor, Set<Component>, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
openIndexReader(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(String, int, Configuration) - Method in interface org.apache.cassandra.thrift.ITransportFactory
Opens a client transport to a thrift server.
openTransport(String, int, Configuration) - 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
An UPDATE or DELETE operation.
Operation(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Operation
 
Operation.Addition - Class in org.apache.cassandra.cql3
 
Operation.Addition(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.Addition
 
Operation.ColumnDeletion - Class in org.apache.cassandra.cql3
 
Operation.ColumnDeletion(ColumnIdentifier) - Constructor for class org.apache.cassandra.cql3.Operation.ColumnDeletion
 
Operation.ElementDeletion - Class in org.apache.cassandra.cql3
 
Operation.ElementDeletion(ColumnIdentifier, Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.ElementDeletion
 
Operation.OperationType - Enum in org.apache.cassandra.cql
 
Operation.Prepend - Class in org.apache.cassandra.cql3
 
Operation.Prepend(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.Prepend
 
Operation.RawDeletion - Interface in org.apache.cassandra.cql3
A parsed raw DELETE operation.
Operation.RawUpdate - Interface in org.apache.cassandra.cql3
A parsed raw UPDATE operation.
Operation.SetElement - Class in org.apache.cassandra.cql3
 
Operation.SetElement(Term.Raw, Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.SetElement
 
Operation.SetValue - Class in org.apache.cassandra.cql3
 
Operation.SetValue(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.SetValue
 
Operation.Substraction - Class in org.apache.cassandra.cql3
 
Operation.Substraction(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.Substraction
 
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
OptionCodec<T extends java.lang.Enum<T> & OptionCodec.Codecable<T>> - Class in org.apache.cassandra.transport
 
OptionCodec(Class<T>) - Constructor for class org.apache.cassandra.transport.OptionCodec
 
OptionCodec.Codecable<T extends java.lang.Enum<T>> - Interface in org.apache.cassandra.transport
 
options - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
options - Variable in class org.apache.cassandra.transport.messages.StartupMessage
 
OptionsMessage - Class in org.apache.cassandra.transport.messages
Message to indicate that the server is ready to receive requests.
OptionsMessage() - Constructor for class org.apache.cassandra.transport.messages.OptionsMessage
 
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.cli.transport - package org.apache.cassandra.cli.transport
 
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.functions - package org.apache.cassandra.cql3.functions
 
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.composites - package org.apache.cassandra.db.index.composites
 
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.exceptions - package org.apache.cassandra.exceptions
 
org.apache.cassandra.gms - package org.apache.cassandra.gms
 
org.apache.cassandra.hadoop - package org.apache.cassandra.hadoop
 
org.apache.cassandra.hadoop.cql3 - package org.apache.cassandra.hadoop.cql3
 
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.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.streaming.compress - package org.apache.cassandra.streaming.compress
 
org.apache.cassandra.thrift - package org.apache.cassandra.thrift
 
org.apache.cassandra.tools - package org.apache.cassandra.tools
 
org.apache.cassandra.tracing - package org.apache.cassandra.tracing
 
org.apache.cassandra.transport - package org.apache.cassandra.transport
 
org.apache.cassandra.transport.messages - package org.apache.cassandra.transport.messages
 
org.apache.cassandra.utils - package org.apache.cassandra.utils
 
org.apache.cassandra.utils.avro - package org.apache.cassandra.utils.avro
 
org.apache.cassandra.utils.obs - package org.apache.cassandra.utils.obs
 
org.apache.cassandra.utils.vint - package org.apache.cassandra.utils.vint
 
originalCount - Variable in class org.apache.cassandra.db.RetriedSliceFromReadCommand
 
originalFilter - Variable in class org.apache.cassandra.db.filter.ExtendedFilter
 
originalFilter() - Method 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
 
out - Variable in class org.apache.cassandra.tools.AbstractJmxClient
 
OutboundTcpConnection - Class in org.apache.cassandra.net
 
OutboundTcpConnection(OutboundTcpConnectionPool) - Constructor for class org.apache.cassandra.net.OutboundTcpConnection
 
OutboundTcpConnectionPool - Class in org.apache.cassandra.net
 
outgoingBytes - Variable in class org.apache.cassandra.metrics.StreamingMetrics
 
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
 
outputFormatClass - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
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
 
outTransportFactory - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
 
OverloadedException - Exception in org.apache.cassandra.exceptions
 
OverloadedException(String) - Constructor for exception org.apache.cassandra.exceptions.OverloadedException
 
owner - Variable in class org.apache.cassandra.io.util.RandomAccessReader
 

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
 
pack(List<ByteBuffer>, int, int) - Static method in class org.apache.cassandra.db.marshal.CollectionType
 
pack(List<ByteBuffer>, int) - Static method in class org.apache.cassandra.db.marshal.CollectionType
 
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
 
parameters - Variable in class org.apache.cassandra.net.MessageIn
 
parameters - Variable in class org.apache.cassandra.net.MessageOut
 
parameters - Variable in class org.apache.cassandra.streaming.compress.CompressionInfo
 
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
 
parse() - Method in class org.apache.cassandra.db.marshal.TypeParser
Parse an AbstractType from current position of this parser.
parseComparator(int, String) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
Used by fromString
parseComparator(int, String) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
parseComparator(int, String) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
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<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
 
ParsedStatement.Prepared(CQLStatement) - Constructor for class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
 
parseStatement(String) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
parseType(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
parse the string to a cassandra data type
partialCompactionsAcceptable() - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
partialCompactionsAcceptable() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
 
partialCompactionsAcceptable() - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
 
PARTIALLY_INCONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
 
PARTITION_FILTER_SIGNATURE - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
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.
partitionerClass - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
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 - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
password - Variable in class org.apache.cassandra.tools.AbstractJmxClient
 
PASSWORD_KEY - Static variable in interface org.apache.cassandra.auth.IAuthenticator
 
PasswordAuthenticator - Class in org.apache.cassandra.auth
PasswordAuthenticator is an IAuthenticator implementation that keeps credentials (usernames and bcrypt-hashed passwords) internally in C* - in system_auth.credentials CQL3 table.
PasswordAuthenticator() - Constructor for class org.apache.cassandra.auth.PasswordAuthenticator
 
patch - Variable in class org.apache.cassandra.utils.SemanticVersion
 
path - Variable in class org.apache.cassandra.db.filter.QueryFilter
 
path - Variable in error org.apache.cassandra.io.FSError
 
path - Variable in exception org.apache.cassandra.io.sstable.CorruptSSTableException
 
path - Variable in class org.apache.cassandra.io.util.SegmentedFile
 
pauseHintsDelivery(boolean) - Method in class org.apache.cassandra.db.HintedHandOffManager
 
pauseHintsDelivery(boolean) - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
pause hints delivery process
pauseHintsDelivery() - Method in class org.apache.cassandra.tools.NodeProbe
 
payload - Variable in class org.apache.cassandra.net.MessageIn
 
payload - Variable in class org.apache.cassandra.net.MessageOut
 
PBSPredictionResult - Class in org.apache.cassandra.service
 
PBSPredictionResult(int, int, int, float, int, float, float, float, long, float, long, float) - Constructor for class org.apache.cassandra.service.PBSPredictionResult
 
PBSPredictor - Class in org.apache.cassandra.service
Performs latency and consistency predictions as described in "Probabilistically Bounded Staleness for Practical Partial Quorums" by Bailis et al.
PBSPredictorMBean - Interface in org.apache.cassandra.service
 
peer - Variable in class org.apache.cassandra.io.util.Memory
 
PEER_EVENTS_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
PeerEventsCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
PEERS_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
PeersCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
pendingEndpoints - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
pendingEndpointsFor(Token, String) - Method in class org.apache.cassandra.locator.TokenMetadata
 
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, CompressionInfo) - 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
 
pendingTasks - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Estimated number of tasks pending for this column family
pendingTasks - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
Number of pending tasks
pendingTasks - Variable in class org.apache.cassandra.metrics.CompactionMetrics
Estimated number of compactions remaining to perform
pendingTasks - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
Number of tasks waiting to be executed.
percentile(double) - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
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, CounterId.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, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
performWrite(IMutation, ConsistencyLevel, String, StorageProxy.WritePerformer, Runnable, WriteType) - 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 on a resource.
permission - Variable in class org.apache.cassandra.auth.PermissionDetails
 
permission() - Method in class org.apache.cassandra.cql3.CqlParser
 
PermissionAlteringStatement - Class in org.apache.cassandra.cql3.statements
 
PermissionAlteringStatement(Set<Permission>, IResource, String) - Constructor for class org.apache.cassandra.cql3.statements.PermissionAlteringStatement
 
PermissionDetails - Class in org.apache.cassandra.auth
Sets of instances of this class are returned by IAuthorizer.listPermissions() method for LIST PERMISSIONS query.
PermissionDetails(String, IResource, Permission) - Constructor for class org.apache.cassandra.auth.PermissionDetails
 
permissionOrAll() - Method in class org.apache.cassandra.cql3.CqlParser
 
permissions - Variable in class org.apache.cassandra.cql3.statements.PermissionAlteringStatement
 
permissions_validity_in_ms - Variable in class org.apache.cassandra.config.Config
 
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.AbstractCassandraStorage
 
PIG_INPUT_FORMAT - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
PIG_INPUT_INITIAL_ADDRESS - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
PIG_INPUT_PARTITIONER - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
PIG_INPUT_RPC_PORT - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
PIG_INPUT_SPLIT_SIZE - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
PIG_OUTPUT_FORMAT - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
PIG_OUTPUT_INITIAL_ADDRESS - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
PIG_OUTPUT_PARTITIONER - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
PIG_OUTPUT_RPC_PORT - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
PIG_PARTITIONER - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
PIG_RPC_PORT - Static variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
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
 
pkDef(CreateColumnFamilyStatement.RawStatement) - Method in class org.apache.cassandra.cql3.CqlParser
 
pointInTimeExceeded(RowMutation) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
pool - Variable in class org.apache.cassandra.io.util.PoolingSegmentedFile
 
PoolingSegmentedFile - Class in org.apache.cassandra.io.util
 
PoolingSegmentedFile(String, long) - Constructor for class org.apache.cassandra.io.util.PoolingSegmentedFile
 
PoolingSegmentedFile(String, long, long) - Constructor for class org.apache.cassandra.io.util.PoolingSegmentedFile
 
populate_io_cache_on_flush - Variable in class org.apache.cassandra.config.Config
 
populateIoCacheOnFlush(boolean) - Method in class org.apache.cassandra.config.CFMetaData
 
populateIoCacheOnFlush() - Method in class org.apache.cassandra.config.CFMetaData
 
port() - Method in class org.apache.cassandra.cli.CliParser
 
port - Variable in class org.apache.cassandra.tools.AbstractJmxClient
 
port - Variable in class org.apache.cassandra.transport.SimpleClient
 
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 - Variable in class org.apache.cassandra.db.RowIndexEntry
 
position() - Method in class org.apache.cassandra.io.util.MemoryOutputStream
 
position(long) - Method in class org.apache.cassandra.streaming.compress.CompressedInputStream
 
posix_fadvise(int, long, int, int) - Static method in class org.apache.cassandra.utils.CLibrary
 
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
 
predictConsistency(Integer, Integer, Integer, Float, PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
PREFIX_SIZE_OPTION - Static variable in class org.apache.cassandra.db.index.composites.CompositesIndex
 
prepare(String, ThriftClientState) - Static method in class org.apache.cassandra.cql.QueryProcessor
 
prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
 
prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Constants.Literal
 
prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
 
prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Lists.Literal
 
prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Maps.Literal
 
prepare(CFDefinition.Name) - Method in class org.apache.cassandra.cql3.Operation.Addition
 
prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.ColumnDeletion
 
prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.ElementDeletion
 
prepare(CFDefinition.Name) - Method in class org.apache.cassandra.cql3.Operation.Prepend
 
prepare(ColumnSpecification) - Method in interface org.apache.cassandra.cql3.Operation.RawDeletion
This method validates the operation (i.e.
prepare(CFDefinition.Name) - Method in interface org.apache.cassandra.cql3.Operation.RawUpdate
This method validates the operation (i.e.
prepare(CFDefinition.Name) - Method in class org.apache.cassandra.cql3.Operation.SetElement
 
prepare(CFDefinition.Name) - Method in class org.apache.cassandra.cql3.Operation.SetValue
 
prepare(CFDefinition.Name) - Method in class org.apache.cassandra.cql3.Operation.Substraction
 
prepare(String, ClientState, boolean) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Sets.Literal
 
prepare() - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
prepare(ColumnSpecification[]) - 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(ColumnSpecification[]) - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
 
prepare(ColumnSpecification[]) - 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.SchemaAlteringStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
 
prepare(ColumnSpecification[]) - 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(ColumnSpecification) - Method in interface org.apache.cassandra.cql3.Term.Raw
This method validates this RawTerm is valid for provided column specification and "prepare" this RawTerm, returning the resulting prepared Term.
prepare(ColumnSpecification) - Method in class org.apache.cassandra.cql3.TypeCast
 
prepare(ColumnFamilyStore) - Method in class org.apache.cassandra.service.AntiEntropyService.Validator
 
prepare(String) - Method in class org.apache.cassandra.transport.SimpleClient
 
prepare_cql3_query(ByteBuffer, Compression) - Method in class org.apache.cassandra.thrift.CassandraServer
 
prepare_cql_query(ByteBuffer, Compression) - Method in class org.apache.cassandra.thrift.CassandraServer
 
PreparedQueryNotFoundException - Exception in org.apache.cassandra.exceptions
 
PreparedQueryNotFoundException(MD5Digest) - Constructor for exception org.apache.cassandra.exceptions.PreparedQueryNotFoundException
 
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
 
PrepareMessage - Class in org.apache.cassandra.transport.messages
 
PrepareMessage(String) - Constructor for class org.apache.cassandra.transport.messages.PrepareMessage
 
prepareRowMutations(String, ThriftClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.AbstractModification
Convert statement into a list of mutations to apply on the server
prepareRowMutations(String, ThriftClientState, 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, ThriftClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.DeleteStatement
 
prepareRowMutations(String, ThriftClientState, Long, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.DeleteStatement
 
prepareRowMutations(String, ThriftClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.UpdateStatement
Convert statement into a list of mutations to apply on the server
prepareRowMutations(String, ThriftClientState, 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
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
 
prepareToWrite(RecordWriter) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
prepare writer
prepareToWrite(RecordWriter) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
 
prepareTracingSession(UUID) - Method in class org.apache.cassandra.service.QueryState
 
preprocess(MessageIn<ReadResponse>) - Method in class org.apache.cassandra.service.AbstractRowResolver
 
preprocess(MessageIn<TMessage>) - Method in interface org.apache.cassandra.service.IResponseResolver
 
preprocess(MessageIn) - 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.Murmur3Partitioner
 
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
 
printClusterStatus(PrintStream, String) - Method in class org.apache.cassandra.tools.NodeCmd
Writes a table of cluster-wide node information to a PrintStream
printColumnFamilyStats(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
printCompactionStats(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
printCompactionThreshold(PrintStream, String, String) - Method in class org.apache.cassandra.tools.NodeCmd
Print the compaction threshold
printCompactionThroughput(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
Print the compaction throughput
printHelp(String, String) - Static method in class org.apache.cassandra.tools.AbstractJmxClient
 
printInfo(PrintStream, NodeCmd.ToolCommandLine) - 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
 
printRelocatingRanges() - Method in class org.apache.cassandra.locator.TokenMetadata
 
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
 
printStreamThroughput(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
Print the stream throughput
printThreadPoolStats(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
PROBABILITY - Static variable in class org.apache.cassandra.cli.CliLexer
 
PROBABILITY - Static variable in class org.apache.cassandra.cli.CliParser
 
process(String, ThriftClientState) - Static method in class org.apache.cassandra.cql.QueryProcessor
 
process(String, ConsistencyLevel, QueryState) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
process(String, ConsistencyLevel) - 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
 
processArguments(String[]) - Static method in class org.apache.cassandra.tools.AbstractJmxClient
 
processInboundMessage(MessageIn, String) - Static method in class org.apache.cassandra.net.sink.SinkManager
 
processInternal(String) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
processor - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
 
processOutboundMessage(MessageOut, String, InetAddress) - Static method in class org.apache.cassandra.net.sink.SinkManager
 
processPrepared(CQLStatement, ThriftClientState, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql.QueryProcessor
 
processPrepared(CQLStatement, ConsistencyLevel, QueryState, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
processStatement(String) - Static method in class org.apache.cassandra.cli.CliMain
 
processStatement(CQLStatement, ThriftClientState, 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 - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
 
Progressable - Class in org.apache.cassandra.hadoop
 
Progressable(TaskAttemptContext) - Constructor for class org.apache.cassandra.hadoop.Progressable
 
Progressable(Progressable) - Constructor for class org.apache.cassandra.hadoop.Progressable
 
promote(Iterable<SSTableReader>, Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
promotedSize() - Method in class org.apache.cassandra.db.RowIndexEntry
 
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
 
properties - Variable in class org.apache.cassandra.cql3.statements.CreateColumnFamilyStatement.RawStatement
 
property(PropertyDefinitions) - Method in class org.apache.cassandra.cql3.CqlParser
 
PROPERTY_KEY - Static variable in interface org.apache.cassandra.thrift.ITransportFactory
 
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
 
propertyValue() - Method in class org.apache.cassandra.cql3.CqlParser
 
protectedResources() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
protectedResources() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
protectedResources() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
protectedResources() - Method in interface org.apache.cassandra.auth.IAuthenticator
Set of resources that should be made inaccessible to users and only accessible internally.
protectedResources() - Method in interface org.apache.cassandra.auth.IAuthorizer
Set of resources that should be made inaccessible to users and only accessible internally.
protectedResources() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
 
protectedResources() - Method in class org.apache.cassandra.auth.LegacyAuthorizer
 
protectedResources() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
protocol - Variable in class org.apache.cassandra.config.EncryptionOptions
 
PROTOCOL - Static variable in interface org.apache.cassandra.InterNode
 
ProtocolException - Exception in org.apache.cassandra.transport
Exceptions thrown when a client didn't respect the protocol.
ProtocolException(String) - Constructor for exception org.apache.cassandra.transport.ProtocolException
 
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
purge(int) - Method in class org.apache.cassandra.db.DeletionInfo
Purge every tombstones that are older than gcbefore.
purge(int) - Method in class org.apache.cassandra.db.RangeTombstoneList
Removes all range tombstones whose local deletion time is older than gcBefore.
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(String, Object) - Method in class org.apache.cassandra.cql3.UserOptions
 
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(K) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
enqueues the given value to Cassandra
put(ByteBuffer, IColumn) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
put(K, V) - Method in class org.apache.cassandra.utils.BiMultiValMap
 
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
 
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.cassandra.utils.BiMultiValMap
 
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
write next row
putNext(Tuple) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
output: (((name, value), (name, value)), (value ...
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 - Static variable in class org.apache.cassandra.cli.CliLexer
 
QUERY - Static variable in class org.apache.cassandra.cli.CliParser
 
query() - Method in class org.apache.cassandra.cql.CqlParser
 
query() - Method in class org.apache.cassandra.cql3.CqlParser
 
query - Variable in class org.apache.cassandra.transport.messages.QueryMessage
 
QueryFilter - Class in org.apache.cassandra.db.filter
 
QueryFilter(DecoratedKey, QueryPath, IDiskAtomFilter) - Constructor for class org.apache.cassandra.db.filter.QueryFilter
 
QueryMessage - Class in org.apache.cassandra.transport.messages
A CQL query
QueryMessage(String, ConsistencyLevel) - Constructor for class org.apache.cassandra.transport.messages.QueryMessage
 
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
 
QueryState - Class in org.apache.cassandra.service
Represents the state related to a given query.
QueryState(ClientState) - Constructor for class org.apache.cassandra.service.QueryState
 
queue - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
 
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.AbstractColumnFamilyOutputFormat
 
queueSize - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
 
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
 
RACKDC_PROPERTY_FILENAME - Static variable in class org.apache.cassandra.locator.SnitchProperties
 
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, PoolingSegmentedFile) - 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
 
range_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
RANGE_TOMBSTONE_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
 
RANGE_XFERS_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
rangeIterator() - Method in class org.apache.cassandra.db.DeletionInfo
 
RANGEOP - Static variable in class org.apache.cassandra.cql.CqlLexer
 
RANGEOP - Static variable in class org.apache.cassandra.cql.CqlParser
 
ranges - Variable in class org.apache.cassandra.streaming.StreamRequest
 
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, IDiskAtomFilter, AbstractBounds<RowPosition>, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
 
RangeSliceCommand(String, ColumnParent, IDiskAtomFilter, AbstractBounds<RowPosition>, List<IndexExpression>, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
 
RangeSliceCommand(String, String, ByteBuffer, IDiskAtomFilter, AbstractBounds<RowPosition>, List<IndexExpression>, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
 
RangeSliceCommand(String, String, ByteBuffer, IDiskAtomFilter, 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
 
RangeTombstone - Class in org.apache.cassandra.db
 
RangeTombstone(ByteBuffer, ByteBuffer, long, int) - Constructor for class org.apache.cassandra.db.RangeTombstone
 
RangeTombstone(ByteBuffer, ByteBuffer, DeletionTime) - Constructor for class org.apache.cassandra.db.RangeTombstone
 
RangeTombstone.Serializer - Class in org.apache.cassandra.db
 
RangeTombstone.Serializer() - Constructor for class org.apache.cassandra.db.RangeTombstone.Serializer
 
RangeTombstone.Tracker - Class in org.apache.cassandra.db
 
RangeTombstone.Tracker(Comparator<ByteBuffer>) - Constructor for class org.apache.cassandra.db.RangeTombstone.Tracker
 
RangeTombstoneList - Class in org.apache.cassandra.db
Data structure holding the range tombstones of a ColumnFamily.
RangeTombstoneList(Comparator<ByteBuffer>, int) - Constructor for class org.apache.cassandra.db.RangeTombstoneList
 
RangeTombstoneList.Serializer - Class in org.apache.cassandra.db
 
RangeXfersCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
RawSelector - Interface in org.apache.cassandra.cql3.statements
 
RawSelector.WithFunction - Class in org.apache.cassandra.cql3.statements
 
RawSelector.WithFunction(String, List<RawSelector>) - Constructor for class org.apache.cassandra.cql3.statements.RawSelector.WithFunction
 
RawSelector.WritetimeOrTTL - Class in org.apache.cassandra.cql3.statements
 
RawSelector.WritetimeOrTTL(ColumnIdentifier, boolean) - Constructor for class org.apache.cassandra.cql3.statements.RawSelector.WritetimeOrTTL
 
read(byte[], int) - Static method in class org.apache.cassandra.db.RangeSliceReply
 
read(DataInput) - Static method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
read() - Method in class org.apache.cassandra.io.util.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.LengthAvailableInputStream
 
read(byte[]) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
 
read(byte[], int, int) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
 
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(DataInput, int, String) - Static method in class org.apache.cassandra.net.MessageIn
 
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.compress.CompressedInputStream
 
read() - Method in class org.apache.cassandra.streaming.IncomingStreamReader
 
read(DataInput, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
read() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
 
read_repair_chance - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
read_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
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
 
readBytes(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
 
readBytes(DataInput, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
ReadCallback<TMessage,TResolved> - Class in org.apache.cassandra.service
 
ReadCallback(IResponseResolver<TMessage, TResolved>, 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
 
readConsistencyLevel(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
 
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
 
readEnumValue(Class<T>, ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
 
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
 
readInet(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
 
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
 
readInt() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
 
readLatency - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Read metrics
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
 
readLong() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
 
readLongString(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
 
readNextChar() - Method in class org.apache.cassandra.db.marshal.TypeParser
 
readNextIdentifier() - Method in class org.apache.cassandra.db.marshal.TypeParser
 
readRepairChance(double) - Method in class org.apache.cassandra.config.CFMetaData
 
ReadRepairDecision - Enum in org.apache.cassandra.config
 
ReadRepairMetrics - Class in org.apache.cassandra.metrics
Metrics related to Read Repair.
ReadRepairMetrics() - Constructor for class org.apache.cassandra.metrics.ReadRepairMetrics
 
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
 
readRows(List<ByteBuffer>, ColumnNameBuilder, Set<ByteBuffer>, CompositeType, boolean, ConsistencyLevel) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
readRowSize(DataInput, Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
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
 
readShort() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
 
readShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
readString(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
 
readStringList(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
 
readStringMap(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
 
readStringToStringListMap(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
 
ReadTimeoutException - Exception in org.apache.cassandra.exceptions
 
ReadTimeoutException(ConsistencyLevel, int, int, boolean) - Constructor for exception org.apache.cassandra.exceptions.ReadTimeoutException
 
readTimeouts - Static variable in class org.apache.cassandra.metrics.ClientRequestMetrics
Deprecated.
readTOC(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTable
Reads the list of components from the TOC component.
readUnavailables - Static variable in class org.apache.cassandra.metrics.ClientRequestMetrics
Deprecated.
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
 
readUnsignedShort() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
 
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
 
readUuid(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
 
readValue(ChannelBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
 
readValue(ChannelBuffer) - Method in enum org.apache.cassandra.transport.DataType
 
readValue(ChannelBuffer) - Method in interface org.apache.cassandra.transport.OptionCodec.Codecable
 
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
 
ReadyMessage - Class in org.apache.cassandra.transport.messages
Message to indicate that the server is ready to receive requests.
ReadyMessage() - Constructor for class org.apache.cassandra.transport.messages.ReadyMessage
 
reBuffer() - Method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
 
reBuffer() - Method in class org.apache.cassandra.io.compress.CompressedThrottledReader
 
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
 
reBuffer() - Method in class org.apache.cassandra.io.util.ThrottledReader
 
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(MessageIn, String, long) - Method in class org.apache.cassandra.net.MessagingService
 
received - Variable in exception org.apache.cassandra.exceptions.RequestTimeoutException
 
received - Variable in class org.apache.cassandra.service.AsyncRepairCallback
 
receiver - Variable in class org.apache.cassandra.cql3.AbstractMarker
 
receiveReply() - Method in class org.apache.cassandra.streaming.FileStreamTask
 
receiveTiming(InetAddress, long) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
receiveTiming(InetAddress, long) - Method in interface org.apache.cassandra.locator.ILatencySubscriber
 
recentBloomFilterFalsePositives - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Number of false positives in bloom filter from last read
recentBloomFilterFalseRatio - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
False positive ratio of bloom filter from last read
recentLatencyHistogram - Variable in class org.apache.cassandra.metrics.LatencyMetrics
Deprecated.
recentSSTablesPerRead - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Deprecated.
recognizedOptions() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
recognizedOptions() - Method in class org.apache.cassandra.locator.LocalStrategy
 
recognizedOptions() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
recognizedOptions() - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
 
recognizedOptions() - Method in class org.apache.cassandra.locator.SimpleStrategy
 
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
 
ReconnectableSnitchHelper - Class in org.apache.cassandra.locator
Sidekick helper for snitches that want to reconnect from one IP addr for a node to another.
ReconnectableSnitchHelper(IEndpointSnitch, String, boolean) - Constructor for class org.apache.cassandra.locator.ReconnectableSnitchHelper
 
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
 
recvBufferSize - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
 
recycle() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
Recycle processes an unneeded segment file for reuse.
recycle(RandomAccessReader) - Method in class org.apache.cassandra.io.util.PoolingSegmentedFile
 
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(OnDiskAtomIterator) - 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
 
reduceScopeForLimitedSpace() - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
reduceScopeForLimitedSpace() - Method in class org.apache.cassandra.io.util.DiskAwareRunnable
Called if no disk is available with free space for the full write size.
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
 
RefCountedMemory - Class in org.apache.cassandra.cache
 
RefCountedMemory(long) - Constructor for class org.apache.cassandra.cache.RefCountedMemory
 
reference() - Method in class org.apache.cassandra.cache.RefCountedMemory
 
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
 
register(IMigrationListener) - Method in class org.apache.cassandra.service.MigrationManager
 
register(IEndpointLifecycleSubscriber) - Method in class org.apache.cassandra.service.StorageService
 
register(Event.Type, Channel) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
 
registerChannel(Channel) - Method in class org.apache.cassandra.transport.Connection
 
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.
RegisterMessage - Class in org.apache.cassandra.transport.messages
 
RegisterMessage(List<Event.Type>) - Constructor for class org.apache.cassandra.transport.messages.RegisterMessage
 
registerVerbHandlers(MessagingService.Verb, IVerbHandler) - Method in class org.apache.cassandra.net.MessagingService
Register a verb and the corresponding verb handler with the Messaging Service.
regularColumnsToFetch() - Method in class org.apache.cassandra.cql3.statements.Selection
 
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(List<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, Relation.Type, Term.Raw) - Constructor for class org.apache.cassandra.cql3.Relation
Creates a new relation.
Relation(ColumnIdentifier, Relation.Type, Term.Raw, boolean) - Constructor for class org.apache.cassandra.cql3.Relation
 
Relation.Type - Enum in org.apache.cassandra.cql3
 
relationType() - Method in class org.apache.cassandra.cql3.CqlParser
 
relativeToAbsolutePath(String, Path) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
release() - Method in class org.apache.cassandra.metrics.ClientRequestMetrics
 
release() - Method in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Release all associated metrics.
release() - Method in class org.apache.cassandra.metrics.ConnectionMetrics
 
release() - Method in class org.apache.cassandra.metrics.LatencyMetrics
 
release() - Method in class org.apache.cassandra.metrics.ThreadPoolMetrics
 
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.AbstractSimplePerColumnSecondaryIndex
 
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
 
relocate(Collection<String>) - Method in class org.apache.cassandra.service.StorageService
 
relocate(Collection<String>) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
relocating(Collection<Token>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
remainingBodyLength() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
remainingCount() - Method in interface org.apache.cassandra.cql3.ColumnNameBuilder
 
remainingCount() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
remainingHeaderLength() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
remoteFile - Variable in class org.apache.cassandra.streaming.IncomingStreamReader
 
REMOVAL_COORDINATOR - Static variable in class org.apache.cassandra.gms.VersionedValue
 
removalCoordinator(UUID) - 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(IColumn) - Method in interface org.apache.cassandra.db.index.SecondaryIndexManager.Updater
called when lazy-updating the index during compaction (CASSANDRA-2897)
remove() - Method in class org.apache.cassandra.db.SliceQueryPager
 
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.FilteredKeyScanningIterator
 
remove() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
 
remove() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
remove(Object) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
remove(ByteBuffer, ColumnPath, long, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
remove(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
 
remove(K) - Method in class org.apache.cassandra.utils.ExpiringMap
 
remove_counter(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
removeBootstrapTokens(Collection<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
 
removeDeleted(ColumnFamily, int, SecondaryIndexManager.Updater) - 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
 
removedNode(InetAddress, int) - Static method in class org.apache.cassandra.transport.Event.TopologyChange
 
removedNonlocal(UUID, long) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
removeEndpoint(InetAddress) - Static method in class org.apache.cassandra.db.SystemTable
Remove stored tokens being used by another node
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
 
removeEndpoint(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
Removes current DC/rack assignment for ep
removeFromMoving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
Remove pair of token/address from moving endpoints
removeFromRelocating(Token, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
Remove pair of token/address from relocating ranges.
removeIndex(ByteBuffer) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
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
removeNode(String) - Method in class org.apache.cassandra.service.StorageService
Remove a node that has died, attempting to restore the replica count.
removeNode(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
removeToken removes token (and all data associated with enpoint that had it) from the ring
removeNode(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
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
removeTruncationRecord(UUID) - Static method in class org.apache.cassandra.db.SystemTable
This method is used to remove information about truncation time for specified column family
removeUnreadableSSTables(File) - Static method in class org.apache.cassandra.db.Table
Removes every SSTable in the directory from the appropriate DataTracker's view.
removeValue(V) - Method in class org.apache.cassandra.utils.BiMultiValMap
 
REMOVING_TOKEN - Static variable in class org.apache.cassandra.gms.VersionedValue
 
removingNonlocal(UUID) - 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(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
renameWithConfirm(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
renameWithOutConfirm(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
renewLocalId() - Static method in class org.apache.cassandra.utils.CounterId
Renew the local counter id.
renewLocalId(long) - Static method in class org.apache.cassandra.utils.CounterId
 
renewMemtable() - Method in class org.apache.cassandra.db.DataTracker
Renew the current memtable without putting the old one for a flush.
repairedBackground - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
 
repairedBlocking - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
 
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.RowDataResolver
 
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>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
replaceCompactedSSTables(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
 
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
 
REPLICATION_STRATEGY_CLASS_KEY - Static variable in class org.apache.cassandra.cql3.KSPropDefs
 
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
 
reportSeverity(double) - Method in class org.apache.cassandra.service.StorageService
Gossip about the known severity of the events in this node
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
 
request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
RequestExecutionException - Exception in org.apache.cassandra.exceptions
 
RequestExecutionException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.RequestExecutionException
 
RequestExecutionException(ExceptionCode, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.RequestExecutionException
 
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
requests - Variable in class org.apache.cassandra.metrics.CacheMetrics
Total number of cache requests
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
 
RequestThreadPoolExecutor - Class in org.apache.cassandra.transport
 
RequestThreadPoolExecutor() - Constructor for class org.apache.cassandra.transport.RequestThreadPoolExecutor
 
RequestTimeoutException - Exception in org.apache.cassandra.exceptions
 
RequestTimeoutException(ExceptionCode, ConsistencyLevel, int, int) - Constructor for exception org.apache.cassandra.exceptions.RequestTimeoutException
 
RequestType - Enum in org.apache.cassandra.thrift
 
RequestValidationException - Exception in org.apache.cassandra.exceptions
 
RequestValidationException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.RequestValidationException
 
RequestValidationException(ExceptionCode, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.RequestValidationException
 
require_client_auth - Variable in class org.apache.cassandra.config.EncryptionOptions
 
requireAuthentication() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
requireAuthentication() - Method in interface org.apache.cassandra.auth.IAuthenticator
Whether or not the authenticator requires explicit login.
requireAuthentication() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
 
requireAuthentication() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
required - Variable in exception org.apache.cassandra.exceptions.UnavailableException
 
requiresKeyspace - Static variable in enum org.apache.cassandra.cql.StatementType
 
requiresRead() - Method in class org.apache.cassandra.cql3.Lists.Discarder
 
requiresRead() - Method in class org.apache.cassandra.cql3.Lists.DiscarderByIndex
 
requiresRead() - Method in class org.apache.cassandra.cql3.Lists.SetterByIndex
 
requiresRead() - Method in class org.apache.cassandra.cql3.Operation
 
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() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
 
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(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
 
resetToNewerVersion(int) - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
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.net.MessagingService
 
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.RowDataResolver
 
resolve() - Method in class org.apache.cassandra.service.RowDigestResolver
 
resolver - Variable in class org.apache.cassandra.service.ReadCallback
 
resource - Variable in class org.apache.cassandra.auth.PermissionDetails
 
resource() - Method in class org.apache.cassandra.cql3.CqlParser
 
resource - Variable in class org.apache.cassandra.cql3.statements.PermissionAlteringStatement
 
Resources - Class in org.apache.cassandra.auth
 
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(MessageIn<T>) - Method in interface org.apache.cassandra.net.IAsyncCallback
 
response(MessageIn) - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
null message means "response from local write"
response(MessageIn) - Method in class org.apache.cassandra.service.AsyncRepairCallback
 
response(MessageIn) - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
response(MessageIn) - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
response(MessageIn<TMessage>) - Method in class org.apache.cassandra.service.ReadCallback
 
response(TMessage) - Method in class org.apache.cassandra.service.ReadCallback
 
response(MessageIn) - Method in class org.apache.cassandra.service.TruncateResponseHandler
 
response(MessageIn) - Method in class org.apache.cassandra.service.WriteResponseHandler
 
responseCompletedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
Completed tasks for Response(GOSSIP & RESPONSE) TCP Connections
responseHandler - Variable in class org.apache.cassandra.transport.SimpleClient
 
responsePendingTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
Pending tasks for Response(GOSSIP & RESPONSE) TCP Connections
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(MessageIn<T>) - Method in interface org.apache.cassandra.net.IAsyncResult
Store the result obtained for the submitted task.
result - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Rows
 
resultify(String, Row) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
ResultMessage - Class in org.apache.cassandra.transport.messages
 
ResultMessage(ResultMessage.Kind) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage
 
ResultMessage.Kind - Enum in org.apache.cassandra.transport.messages
 
ResultMessage.Prepared - Class in org.apache.cassandra.transport.messages
 
ResultMessage.Prepared(MD5Digest, List<ColumnSpecification>) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Prepared
 
ResultMessage.Rows - Class in org.apache.cassandra.transport.messages
 
ResultMessage.Rows(ResultSet) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Rows
 
ResultMessage.SchemaChange - Class in org.apache.cassandra.transport.messages
 
ResultMessage.SchemaChange(ResultMessage.SchemaChange.Change, String) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
 
ResultMessage.SchemaChange(ResultMessage.SchemaChange.Change, String, String) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
 
ResultMessage.SchemaChange.Change - Enum in org.apache.cassandra.transport.messages
 
ResultMessage.SetKeyspace - Class in org.apache.cassandra.transport.messages
 
ResultMessage.SetKeyspace(String) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
 
ResultMessage.Void - Class in org.apache.cassandra.transport.messages
 
ResultMessage.Void() - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Void
 
ResultSet - Class in org.apache.cassandra.cql3
 
ResultSet(List<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.ResultSet
 
ResultSet.Codec - Class in org.apache.cassandra.cql3
 
ResultSet.Codec() - Constructor for class org.apache.cassandra.cql3.ResultSet.Codec
 
ResultSet.Flag - Enum in org.apache.cassandra.cql3
 
ResultSet.Metadata - Class in org.apache.cassandra.cql3
 
ResultSet.Metadata(List<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.ResultSet.Metadata
 
resultSetBuilder() - Method in class org.apache.cassandra.cql3.statements.Selection
 
resumeHintsDelivery() - Method in class org.apache.cassandra.tools.NodeProbe
 
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
 
rethrow(RequestExecutionException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
RetriedSliceFromReadCommand - Class in org.apache.cassandra.db
 
RetriedSliceFromReadCommand(String, ByteBuffer, QueryPath, SliceQueryFilter, 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
 
returnType - Variable in class org.apache.cassandra.cql3.functions.AbstractFunction
 
returnType() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
returnType() - Method in interface org.apache.cassandra.cql3.functions.Function
 
reverse() - Method in class org.apache.cassandra.cql3.ResultSet
 
reverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
reversed - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
reversedExpr() - Method in class org.apache.cassandra.cli.CliParser
 
ReversedType<T> - Class in org.apache.cassandra.db.marshal
 
reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
reverseIterator(ColumnSlice[]) - Method in interface org.apache.cassandra.db.ISortedColumns
Returns a reversed iterator over the columns of this map that returns only the matching @param slices.
reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ThreadSafeSortedColumns
 
reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.TreeMapBackedSortedColumns
 
reverseMap - Variable in class org.apache.cassandra.utils.BiMultiValMap
 
revive(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureNotification
 
revoke(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
revoke(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
revoke(AuthenticatedUser, Set<Permission>, IResource, String) - Method in interface org.apache.cassandra.auth.IAuthorizer
Revokes a set of permissions on a resource from a user.
revoke(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
 
revokeAll(String) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
revokeAll(IResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
revokeAll(String) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
revokeAll(IResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
revokeAll(String) - Method in interface org.apache.cassandra.auth.IAuthorizer
This method is called before deleting a user with DROP USER query so that a new user with the same name wouldn't inherit permissions of the deleted user in the future.
revokeAll(IResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
This method is called after a resource is removed (i.e.
revokeAll(String) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
 
revokeAll(IResource) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
 
revokeStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
RevokeStatement - Class in org.apache.cassandra.cql3.statements
 
RevokeStatement(Set<Permission>, IResource, String) - 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
 
ringCache - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
 
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 method in class org.apache.cassandra.auth.DataResource
 
ROOT - Static variable in class org.apache.cassandra.auth.Resources
Deprecated.
root() - Method in class org.apache.cassandra.cli.CliParser
 
rotl64(long, int) - Static method in class org.apache.cassandra.utils.MurmurHash
 
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
 
roundTo(long, int) - Static method in class org.apache.cassandra.utils.ObjectSizes
 
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(UUID, DecoratedKey) - Constructor for class org.apache.cassandra.cache.RowCacheKey
 
RowCacheKey(UUID, 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
 
RowDataResolver - Class in org.apache.cassandra.service
 
RowDataResolver(String, ByteBuffer, IDiskAtomFilter) - Constructor for class org.apache.cassandra.service.RowDataResolver
 
RowDigestResolver - Class in org.apache.cassandra.service
 
RowDigestResolver(String, ByteBuffer) - Constructor for class org.apache.cassandra.service.RowDigestResolver
 
RowIndexEntry - Class in org.apache.cassandra.db
 
RowIndexEntry(long) - Constructor for class org.apache.cassandra.db.RowIndexEntry
 
RowIndexEntry.Serializer - Class in org.apache.cassandra.db
 
RowIndexEntry.Serializer() - Constructor for class org.apache.cassandra.db.RowIndexEntry.Serializer
 
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<UUID, 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
 
rows - Variable in class org.apache.cassandra.cql3.ResultSet
 
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
 
rpcaddress(InetAddress) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
run() - Method in class org.apache.cassandra.db.MeteredFlusher
 
run - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
 
run() - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
Loops collecting mutations from the queue and sending to Cassandra
run() - Method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
 
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.transport.Client
 
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.util.DiskAwareRunnable
Run this task after selecting the optimal disk for it
runMayThrow() - Method in class org.apache.cassandra.streaming.FileStreamTask
 
runMayThrow() - Method in class org.apache.cassandra.utils.WrappedRunnable
 
runWith(File) - Method in class org.apache.cassandra.db.compaction.CompactionTask
For internal use and testing only.
runWith(File) - Method in class org.apache.cassandra.io.util.DiskAwareRunnable
Executes this task on given sstableDirectory.

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
 
save(Collection<KSMetaData>) - Static method in class org.apache.cassandra.db.DefsTable
 
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
 
saveSummary(SSTableReader, SegmentedFile.Builder, SegmentedFile.Builder) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
saveTask - Variable in class org.apache.cassandra.cache.AutoSavingCache
 
saveTruncationRecord(ColumnFamilyStore, long, ReplayPosition) - Static method in class org.apache.cassandra.db.SystemTable
 
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
 
ScheduledRangeTransferExecutorService - Class in org.apache.cassandra.service
 
ScheduledRangeTransferExecutorService() - Constructor for class org.apache.cassandra.service.ScheduledRangeTransferExecutorService
 
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
scheduleRepairs(ColumnFamily, String, DecoratedKey, List<ColumnFamily>, List<InetAddress>) - Static method in class org.apache.cassandra.service.RowDataResolver
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
 
schemaCFS(String) - Static method in class org.apache.cassandra.db.SystemTable
 
SchemaCheckVerbHandler - Class in org.apache.cassandra.db
 
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(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
scrub() - Method in class org.apache.cassandra.db.compaction.Scrubber
 
scrub(boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
scrub(boolean, 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(boolean, 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, IDiskAtomFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
search(List<IndexExpression>, AbstractBounds<RowPosition>, int, IDiskAtomFilter, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
search(List<IndexExpression>, AbstractBounds<RowPosition>, int, IDiskAtomFilter, boolean) - Method in class org.apache.cassandra.db.index.composites.CompositesSearcher
 
search(List<IndexExpression>, AbstractBounds<RowPosition>, int, IDiskAtomFilter, boolean) - Method in class org.apache.cassandra.db.index.keys.KeysSearcher
 
search(List<IndexExpression>, AbstractBounds<RowPosition>, int, IDiskAtomFilter, 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, IDiskAtomFilter, boolean) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
 
search(ByteBuffer) - Method in class org.apache.cassandra.db.RangeTombstoneList
Returns the DeletionTime for the tombstone overlapping name (there can't be more than one), or null if name is not covered by any tombstone.
search(Interval<C, D>) - Method in class org.apache.cassandra.utils.IntervalTree
 
search(C) - Method in class org.apache.cassandra.utils.IntervalTree
 
searchComposite(String, boolean) - Static method in class org.apache.cassandra.db.DefsTable
 
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, Set<String>, 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
 
SecondaryIndexManager.Updater - Interface in org.apache.cassandra.db.index
 
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
 
SeedProviderDef(LinkedHashMap<String, ?>) - Constructor for class org.apache.cassandra.config.SeedProviderDef
 
seek(long) - Method in interface org.apache.cassandra.io.util.FileDataInput
 
seek(long) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
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
 
seekInternal(int) - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
 
seekTo(RowPosition) - Method in class org.apache.cassandra.io.sstable.SSTableBoundedScanner
 
seekTo(RowPosition) - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
seenAnySeed() - Method in class org.apache.cassandra.gms.Gossiper
 
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.
Selection - Class in org.apache.cassandra.cql3.statements
 
Selection(List<CFDefinition.Name>, List<ColumnSpecification>, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.Selection
 
Selection.ResultSetBuilder - Class in org.apache.cassandra.cql3.statements
 
selectionFunctionArgs() - Method in class org.apache.cassandra.cql3.CqlParser
 
selector() - Method in class org.apache.cassandra.cql3.CqlParser
 
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, Selection) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement
 
SelectStatement.Parameters - Class in org.apache.cassandra.cql3.statements
 
SelectStatement.Parameters(int, Map<ColumnIdentifier, Boolean>, 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<RawSelector>, 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
 
send(Event) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
 
sendBufferSize - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
 
sendMessage(MessageOut<StreamReply>) - Method in class org.apache.cassandra.streaming.StreamInSession
 
sendNotification(String, String, Object) - Method in class org.apache.cassandra.service.StorageService
Sends JMX notification to subscribers.
sendOneWay(MessageOut, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
sendOneWay(MessageOut, String, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
Send a message to a given endpoint.
sendReply(MessageOut, String, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
sendRR(MessageOut, InetAddress, IMessageCallback) - Method in class org.apache.cassandra.net.MessagingService
 
sendRR(MessageOut, InetAddress, IMessageCallback, long) - Method in class org.apache.cassandra.net.MessagingService
Send a message to a given endpoint.
sendRR(MessageOut, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
sendToHintedEndpoints(RowMutation, Iterable<InetAddress>, AbstractWriteResponseHandler, 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.
sentMessage - Variable in class org.apache.cassandra.net.CallbackInfo
 
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(K, DataOutput) - Method in interface org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
 
serialize(EnumSet<ResultSet.Flag>) - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
 
serialize(ColumnFamily, DataOutput, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
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(DeletionInfo, DataOutput, int) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
 
serialize(ColumnSlice, DataOutput, int) - Method in class org.apache.cassandra.db.filter.ColumnSlice.Serializer
 
serialize(IDiskAtomFilter, DataOutput, int) - Method in class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
 
serialize(NamesQueryFilter, DataOutput, int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter.Serializer
 
serialize(DataOutput) - Method in class org.apache.cassandra.db.filter.QueryPath
 
serialize(SliceQueryFilter, DataOutput, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
 
serialize(List<Pair<ByteBuffer, IColumn>>) - Method in class org.apache.cassandra.db.marshal.CollectionType
 
serialize(List<Pair<ByteBuffer, IColumn>>) - Method in class org.apache.cassandra.db.marshal.ListType
 
serialize(List<Pair<ByteBuffer, IColumn>>) - Method in class org.apache.cassandra.db.marshal.MapType
Creates the same output than decompose, but from the internal representation.
serialize(List<Pair<ByteBuffer, IColumn>>) - Method in class org.apache.cassandra.db.marshal.SetType
 
serialize(RangeTombstoneList, DataOutput, int) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
 
serialize(Row, DataOutput, int) - Method in class org.apache.cassandra.db.Row.RowSerializer
 
serialize(RowIndexEntry, DataOutput) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
 
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(String, DataOutput, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
 
serialize(Token, DataOutput) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
 
serialize(IPartitioner, Collection<Token>, DataOutput) - Static method in class org.apache.cassandra.gms.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(IndexSummary, DataOutput) - Method in class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
 
serialize(SSTableMetadata, Set<Integer>, DataOutput) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.SSTableMetadataSerializer
 
serialize(InetAddress, DataOutput) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
 
serialize(DataOutputStream, int) - Method in class org.apache.cassandra.net.MessageOut
 
serialize(AntiEntropyService.TreeRequest, DataOutput, int) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequest.TreeRequestSerializer
 
serialize(AntiEntropyService.Validator, DataOutput, int) - Method in class org.apache.cassandra.service.AntiEntropyService.Validator.ValidatorSerializer
 
serialize(KeyCacheKey, DataOutput) - Method in class org.apache.cassandra.service.CacheService.KeyCacheSerializer
 
serialize(RowCacheKey, DataOutput) - Method in class org.apache.cassandra.service.CacheService.RowCacheSerializer
 
serialize(Collection<RowMutation>, DataOutput, int) - Method in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
 
serialize(PendingFile, DataOutput, int) - Method in class org.apache.cassandra.streaming.PendingFile.PendingFileSerializer
 
serialize() - Method in class org.apache.cassandra.transport.Event
 
serialize(EnumSet<Frame.Header.Flag>) - Static method in enum org.apache.cassandra.transport.Frame.Header.Flag
 
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
Deprecated.
serialize(T, IVersionedSerializer<T>, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
serialize(IFilter, DataOutput) - Static method in class org.apache.cassandra.utils.FilterFactory
 
serialize(IFilter, DataOutput, FilterFactory.Type) - Static method in class org.apache.cassandra.utils.FilterFactory
 
serialize(IntervalTree<C, D, I>, DataOutput, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
 
serialize(LegacyBloomFilter, DataOutput) - Method in class org.apache.cassandra.utils.LegacyBloomFilterSerializer
 
serialize(MerkleTree, DataOutput, int) - Method in class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
 
serialize(DataOutput) - Method in interface org.apache.cassandra.utils.obs.IBitSet
 
serialize(DataOutput) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
serialize(DataOutput) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
serialize(StreamingHistogram, DataOutput) - Method in class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
 
serialize(UUID, DataOutput, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
 
serializeBounds(DataOutput) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
 
serializeCfId(UUID, DataOutput, int) - 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(TypeSizes) - Method in class org.apache.cassandra.db.Column
 
serializedSize(ColumnFamily, TypeSizes, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializedSize(ColumnFamily, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializedSize(IColumn, TypeSizes) - Method in class org.apache.cassandra.db.ColumnSerializer
 
serializedSize(ReplayPosition, TypeSizes) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
 
serializedSize(TypeSizes) - Method in class org.apache.cassandra.db.CounterColumn
 
serializedSize(DeletionInfo, TypeSizes, int) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
 
serializedSize(DeletionInfo, int) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
 
serializedSize(TypeSizes) - Method in class org.apache.cassandra.db.ExpiringColumn
 
serializedSize(ColumnSlice, int) - Method in class org.apache.cassandra.db.filter.ColumnSlice.Serializer
 
serializedSize(IDiskAtomFilter, int) - Method in class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
 
serializedSize(NamesQueryFilter, int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter.Serializer
 
serializedSize(TypeSizes) - Method in class org.apache.cassandra.db.filter.QueryPath
 
serializedSize(SliceQueryFilter, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
 
serializedSize(TypeSizes) - Method in interface org.apache.cassandra.db.OnDiskAtom
 
serializedSize(TypeSizes) - Method in class org.apache.cassandra.db.RangeTombstone
 
serializedSize(RangeTombstoneList, TypeSizes, int) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
 
serializedSize(RangeTombstoneList, int) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
 
serializedSize(Row, int) - Method in class org.apache.cassandra.db.Row.RowSerializer
 
serializedSize() - Method in class org.apache.cassandra.db.RowIndexEntry
 
serializedSize(RowMutation, int) - Method in class org.apache.cassandra.db.RowMutation.RowMutationSerializer
 
serializedSize(RowPosition, TypeSizes) - Method in class org.apache.cassandra.db.RowPosition.RowPositionSerializer
 
serializedSize(TypeSizes) - 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(String, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
 
serializedSize(Token, TypeSizes) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
 
serializedSize(Collection<Token>, TypeSizes) - Static method in class org.apache.cassandra.gms.TokenSerializer
 
serializedSize(T, TypeSizes) - Method in interface org.apache.cassandra.io.ISerializer
 
serializedSize(T, int) - Method in interface org.apache.cassandra.io.IVersionedSerializer
Calculate serialized size of object without actually serializing.
serializedSize(TypeSizes) - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
serializedSize(InetAddress) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
 
serializedSize(int) - Method in class org.apache.cassandra.net.MessageOut
 
serializedSize(AntiEntropyService.TreeRequest, int) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequest.TreeRequestSerializer
 
serializedSize(AntiEntropyService.Validator, int) - Method in class org.apache.cassandra.service.AntiEntropyService.Validator.ValidatorSerializer
 
serializedSize(Collection<RowMutation>, int) - Method in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
 
serializedSize(PendingFile, int) - Method in class org.apache.cassandra.streaming.PendingFile.PendingFileSerializer
 
serializedSize(EstimatedHistogram, TypeSizes) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
serializedSize(IFilter) - Static method in class org.apache.cassandra.utils.FilterFactory
 
serializedSize(IFilter, FilterFactory.Type) - Static method in class org.apache.cassandra.utils.FilterFactory
 
serializedSize(IntervalTree<C, D, I>, TypeSizes, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
 
serializedSize(IntervalTree<C, D, I>, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
 
serializedSize(LegacyBloomFilter) - Method in class org.apache.cassandra.utils.LegacyBloomFilterSerializer
 
serializedSize(MerkleTree, int) - Method in class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
 
serializedSize(TypeSizes) - Method in interface org.apache.cassandra.utils.obs.IBitSet
 
serializedSize(TypeSizes) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
serializedSize(TypeSizes) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
serializedSize(StreamingHistogram, TypeSizes) - Method in class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
 
serializedSize(UUID, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
 
serializedSizeForSSTable() - Method in class org.apache.cassandra.db.Column
 
serializedSizeForSSTable() - Method in interface org.apache.cassandra.db.OnDiskAtom
 
serializedSizeForSSTable() - Method in class org.apache.cassandra.db.RangeTombstone
 
serializedSizeForSSTable() - Method in class org.apache.cassandra.db.SuperColumn
 
serializedValueSize(Object) - Method in enum org.apache.cassandra.transport.DataType
 
serializedValueSize(Object) - Method in interface org.apache.cassandra.transport.OptionCodec.Codecable
 
serializeEvent() - Method in class org.apache.cassandra.transport.Event.SchemaChange
 
serializeEvent() - Method in class org.apache.cassandra.transport.Event
 
serializeEvent() - Method in class org.apache.cassandra.transport.Event.StatusChange
 
serializeEvent() - Method in class org.apache.cassandra.transport.Event.TopologyChange
 
serializeForSSTable(ColumnFamily, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializeForSSTable(OnDiskAtom, DataOutput) - Method in class org.apache.cassandra.db.OnDiskAtom.Serializer
 
serializeForSSTable(RangeTombstone, DataOutput) - Method in class org.apache.cassandra.db.RangeTombstone.Serializer
 
serializeForSSTable(T, DataOutput) - Method in interface org.apache.cassandra.io.ISSTableSerializer
Serialize the specified type into the specified DataOutputStream instance in the format suited for SSTables.
serializer() - Static method in class org.apache.cassandra.db.Column
 
serializer - Static variable in class org.apache.cassandra.db.ColumnFamily
 
serializer - Static variable in class org.apache.cassandra.db.commitlog.ReplayPosition
 
serializer - Static variable in class org.apache.cassandra.db.CounterMutation
 
serializer() - Static method in class org.apache.cassandra.db.DeletionInfo
 
serializer - Static variable in class org.apache.cassandra.db.DeletionTime
 
serializer - Static variable in class org.apache.cassandra.db.filter.ColumnSlice
 
serializer - Static variable in class org.apache.cassandra.db.filter.NamesQueryFilter
 
serializer - Static variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
serializer - Static variable in class org.apache.cassandra.db.IndexScanCommand
 
serializer - Static variable in class org.apache.cassandra.db.RangeSliceCommand
 
serializer - Static variable in class org.apache.cassandra.db.RangeSliceReply
 
serializer - Static variable in class org.apache.cassandra.db.RangeTombstone
 
serializer - Static variable in class org.apache.cassandra.db.RangeTombstoneList
 
serializer - Static variable in class org.apache.cassandra.db.ReadCommand
 
serializer - Static variable in class org.apache.cassandra.db.ReadResponse
 
serializer - Static variable in class org.apache.cassandra.db.Row
 
serializer - Static variable in class org.apache.cassandra.db.RowIndexEntry
 
serializer - Static variable in class org.apache.cassandra.db.RowMutation
 
serializer - Static variable in class org.apache.cassandra.db.RowPosition
 
serializer - Static variable in class org.apache.cassandra.db.SnapshotCommand
 
serializer(AbstractType<?>) - Static method in class org.apache.cassandra.db.SuperColumn
 
serializer - Static variable in class org.apache.cassandra.db.TruncateResponse
 
serializer - Static variable in class org.apache.cassandra.db.Truncation
 
serializer - Static variable in class org.apache.cassandra.db.WriteResponse
 
serializer - Static variable in class org.apache.cassandra.dht.AbstractBounds
 
serializer - Static variable in class org.apache.cassandra.dht.Token
 
serializer - Static variable in class org.apache.cassandra.gms.EndpointState
 
serializer - Static variable in class org.apache.cassandra.gms.GossipDigest
 
serializer - Static variable in class org.apache.cassandra.gms.GossipDigestAck
 
serializer - Static variable in class org.apache.cassandra.gms.GossipDigestAck2
 
serializer - Static variable in class org.apache.cassandra.gms.GossipDigestSyn
 
serializer - Static variable in class org.apache.cassandra.gms.VersionedValue
 
serializer - Static variable in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
 
serializer - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
 
serializer - Static variable in class org.apache.cassandra.io.sstable.IndexSummary
 
serializer - Static variable in class org.apache.cassandra.io.sstable.SSTableMetadata
 
serializer - Variable in class org.apache.cassandra.net.CallbackInfo
 
serializer - Variable in class org.apache.cassandra.net.MessageOut
 
serializer - Static variable in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
serializer - Static variable in class org.apache.cassandra.service.AntiEntropyService.Validator
 
serializer - Static variable in class org.apache.cassandra.streaming.compress.CompressionInfo
 
serializer - Static variable in class org.apache.cassandra.streaming.PendingFile
 
serializer - Static variable in class org.apache.cassandra.streaming.StreamHeader
 
serializer - Static variable in class org.apache.cassandra.streaming.StreamingRepairTask
 
serializer - Static variable in class org.apache.cassandra.streaming.StreamReply
 
serializer - Static variable in class org.apache.cassandra.streaming.StreamRequest
 
serializer - Static variable in class org.apache.cassandra.utils.EstimatedHistogram
 
serializer(ISerializer<C>, ISerializer<D>, Constructor<I>) - Static method in class org.apache.cassandra.utils.IntervalTree
 
serializer - Static variable in class org.apache.cassandra.utils.LegacyBloomFilter
 
serializer - Static variable in class org.apache.cassandra.utils.MerkleTree
 
serializer - Static variable in class org.apache.cassandra.utils.Murmur2BloomFilter
 
serializer - Static variable in class org.apache.cassandra.utils.Murmur3BloomFilter
 
serializer - Static variable in class org.apache.cassandra.utils.StreamingHistogram
 
serializer - Static variable in class org.apache.cassandra.utils.UUIDSerializer
 
serializeSchema() - Static method in class org.apache.cassandra.db.SystemTable
 
SerializingCache<K,V> - Class in org.apache.cassandra.cache
Serializes cache values off-heap.
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
 
Server - Class in org.apache.cassandra.transport
 
Server(InetSocketAddress) - Constructor for class org.apache.cassandra.transport.Server
 
Server(String, int) - Constructor for class org.apache.cassandra.transport.Server
 
Server(InetAddress, int) - Constructor for class org.apache.cassandra.transport.Server
 
Server(int) - Constructor for class org.apache.cassandra.transport.Server
 
Server.ConnectionTracker - Class in org.apache.cassandra.transport
 
Server.ConnectionTracker() - Constructor for class org.apache.cassandra.transport.Server.ConnectionTracker
 
server_encryption_options - Variable in class org.apache.cassandra.config.Config
 
ServerConnection - Class in org.apache.cassandra.transport
 
ServerConnection(Connection.Tracker) - Constructor for class org.apache.cassandra.transport.ServerConnection
 
ServerError - Exception in org.apache.cassandra.transport
Exceptions thrown when a client didn't respect the protocol.
ServerError(Throwable) - Constructor for exception org.apache.cassandra.transport.ServerError
 
ServerError(String) - Constructor for exception org.apache.cassandra.transport.ServerError
 
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.AbstractStreamSession
 
sessionId - Variable in class org.apache.cassandra.streaming.StreamHeader
session ID
sessionId - Variable in class org.apache.cassandra.streaming.StreamReply
 
sessionId - Variable in class org.apache.cassandra.streaming.StreamRequest
 
sessionId - Variable in class org.apache.cassandra.tracing.TraceState
 
sessionIdBytes - Variable in class org.apache.cassandra.tracing.TraceState
 
SESSIONS_CF - Static variable in class org.apache.cassandra.tracing.Tracing
 
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(CQL3Type) - Static method in class org.apache.cassandra.cql3.CQL3Type.Collection
 
set(TraceState) - Method in class org.apache.cassandra.tracing.Tracing
 
set(double) - Method in class org.apache.cassandra.utils.DefaultDouble
 
set(int) - Method in class org.apache.cassandra.utils.DefaultInteger
 
set(long) - Method in interface org.apache.cassandra.utils.obs.IBitSet
Sets the bit at the specified index.
set(long) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
set(long, byte) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
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
 
set_or_map(Term.Raw) - Method in class org.apache.cassandra.cql3.CqlParser
 
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
 
setCallbackForTests(String, CallbackInfo) - Method in class org.apache.cassandra.net.MessagingService
 
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.AbstractCompactionTask
 
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
setCompressor(FrameCompressor) - Method in class org.apache.cassandra.transport.Connection
 
setComputeDigest() - Method in class org.apache.cassandra.io.util.SequentialWriter
Turn on digest computation on this writer.
setConnectionInformation() - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
set hadoop cassandra connection settings
setConnectionInformation() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
set hadoop cassandra connection settings
setConsistencyLevel(ConsistencyLevel) - Method in class org.apache.cassandra.cql.Attributes
 
setCoreCompactorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
setCoreCompactorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Allows user to resize maximum size of the compaction thread pool.
setCorePoolSize(int) - Method in interface org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutorMBean
 
setCoreThreads(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
setCoreThreads(int) - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
Deprecated.
Allows user to resize core pool size of the thread pool.
setCoreValidationThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
setCoreValidationThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Allows user to resize maximum size of the compaction thread pool.
setCQLVersion(String) - Method in class org.apache.cassandra.service.ClientState
 
setCrcCheckChance(double) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setCrcCheckChance(double) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Set new crc check chance
setCrcCheckChance(double) - Method in class org.apache.cassandra.io.compress.CompressionParameters
 
setCurrentFile(PendingFile) - Method in class org.apache.cassandra.streaming.StreamInSession
 
setCurrentSocket(SocketAddress) - Method in class org.apache.cassandra.thrift.ThriftSessionManager
 
setDeletionInfo(DeletionInfo) - Method in class org.apache.cassandra.db.AbstractColumnContainer
 
setDeletionInfo(DeletionInfo) - Method in class org.apache.cassandra.db.AbstractThreadUnsafeSortedColumns
 
setDeletionInfo(DeletionInfo) - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
setDeletionInfo(DeletionInfo) - Method in interface org.apache.cassandra.db.ISortedColumns
 
setDigestQuery(boolean) - Method in class org.apache.cassandra.db.ReadCommand
 
setDiskFailurePolicy(Config.DiskFailurePolicy) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
 
setIncrementalBackupsEnabled(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
 
setIndexBuilt() - Method in class org.apache.cassandra.db.index.SecondaryIndex
 
setIndexBuilt(Set<String>) - 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() - Method in class org.apache.cassandra.db.index.SecondaryIndex
 
setIndexRemoved(Set<String>) - 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.
setInputColumns(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
Set the CQL columns for the input of this job.
setInputCQLPageRowSize(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
Set the CQL query Limit for the input of this job.
setInputInitialAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setInputKeyspacePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setInputKeyspaceUserName(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setInputKeyspaceUserNameAndPassword(Configuration, String, 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.
setInputWhereClauses(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
Set the CQL user defined where clauses for the input of this job.
setKeyAlias(String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
 
setKeyAlias(String) - Method in class org.apache.cassandra.cql.WhereClause
 
setKeyCacheCapacityInMB(long) - Method in class org.apache.cassandra.service.CacheService
 
setKeyCacheCapacityInMB(long) - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
setKeyCacheSavePeriod(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setKeyCacheSavePeriodInSeconds(int) - Method in class org.apache.cassandra.service.CacheService
 
setKeyCacheSavePeriodInSeconds(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
setKeySpace(String) - Method in class org.apache.cassandra.cli.CliClient
 
setKeyspace(String) - Method in class org.apache.cassandra.cql.DropIndexStatement
 
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
set read configuration settings
setLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
set read configuration settings
setLog4jLevel(String, String) - Method in class org.apache.cassandra.service.StorageService
 
setLog4jLevel(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
set the logging level at runtime
setLong(long, long) - Method in class org.apache.cassandra.io.util.Memory
 
setMaxHintsInProgress(int) - Method in class org.apache.cassandra.service.StorageProxy
 
setMaxHintsInProgress(int) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
setMaxHintWindow(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
setMaximumCompactorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
setMaximumCompactorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Allows user to resize maximum size of the compaction thread pool.
setMaximumThreads(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
setMaximumThreads(int) - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
Deprecated.
Allows user to resize maximum size of the thread pool.
setMaximumValidatorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
setMaximumValidatorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Allows user to resize maximum size of the validator thread pool.
setMaxLoggedLatenciesForConsistencyPrediction(int) - Method in class org.apache.cassandra.service.PBSPredictor
 
setMaxLoggedLatenciesForConsistencyPrediction(int) - Method in interface org.apache.cassandra.service.PBSPredictorMBean
 
setMemory(long, long, byte) - Method in class org.apache.cassandra.io.util.Memory
 
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
 
setNumberTrialsForConsistencyPrediction(int) - Method in class org.apache.cassandra.service.PBSPredictor
 
setNumberTrialsForConsistencyPrediction(int) - Method in interface org.apache.cassandra.service.PBSPredictorMBean
 
setOptions(Map<String, String>) - Method in interface org.apache.cassandra.thrift.ITransportFactory
Sets an implementation defined set of options.
setOptions(Map<String, String>) - Method in class org.apache.cassandra.thrift.TFramedTransportFactory
 
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
 
setOutput(PrintStream) - Method in class org.apache.cassandra.tools.AbstractJmxClient
 
setOutputColumnFamily(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the column family for the output of this job.
setOutputColumnFamily(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the 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
 
setOutputCql(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
Set the CQL prepared statement for the output of this job.
setOutputInitialAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setOutputKeyspace(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the keyspace for the output of this job.
setOutputKeyspacePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setOutputKeyspaceUserName(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setOutputKeyspaceUserNameAndPassword(Configuration, String, 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
 
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
set partition filter
setPartitionFilter(Expression) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
 
setPendingRanges(String, Multimap<Range<Token>, InetAddress>) - Method in class org.apache.cassandra.locator.TokenMetadata
 
setPhiConvictThreshold(double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setPhiConvictThreshold(double) - Method in class org.apache.cassandra.gms.FailureDetector
 
setPhiConvictThreshold(double) - 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.
setRangeRpcTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRangeRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
 
setRangeRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
setReadConsistencyLevel(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setReadRpcTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setReadRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
 
setReadRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
setRowCacheCapacityInMB(long) - Method in class org.apache.cassandra.service.CacheService
 
setRowCacheCapacityInMB(long) - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
setRowCacheSavePeriod(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
 
Sets - Class in org.apache.cassandra.cql3
Static helper methods and classes for sets.
Sets.Adder - Class in org.apache.cassandra.cql3
 
Sets.Adder(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Adder
 
Sets.DelayedValue - Class in org.apache.cassandra.cql3
 
Sets.DelayedValue(Comparator<ByteBuffer>, Set<Term>) - Constructor for class org.apache.cassandra.cql3.Sets.DelayedValue
 
Sets.Discarder - Class in org.apache.cassandra.cql3
 
Sets.Discarder(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Discarder
 
Sets.Literal - Class in org.apache.cassandra.cql3
 
Sets.Literal(List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.Sets.Literal
 
Sets.Marker - Class in org.apache.cassandra.cql3
 
Sets.Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Sets.Marker
 
Sets.Setter - Class in org.apache.cassandra.cql3
 
Sets.Setter(ColumnIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Setter
 
Sets.Value - Class in org.apache.cassandra.cql3
 
Sets.Value(Set<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Sets.Value
 
setSeverity(double) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
setSeverity(double) - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
Use this if you want to specify a severity; it can be negative Example: Page cache is cold and you want data to be sent though it is not preferred one.
setSocket(Socket) - Method in class org.apache.cassandra.streaming.StreamInSession
 
setSources(List<InetAddress>) - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
setStart(ByteBuffer) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
setStatement() - Method in class org.apache.cassandra.cli.CliParser
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
StoreFunc methods
setStoreLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
set store configuration settings
setStoreLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlStorage
set store configuration settings
setStreamId(int) - Method in class org.apache.cassandra.transport.Message
 
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
setThriftFramedTransportSizeInMb(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setTimeout(int) - Method in class org.apache.cassandra.thrift.TCustomSocket
Sets the socket timeout
setTimestamp(Long) - Method in class org.apache.cassandra.cql.Attributes
 
setTimestamp(long) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
setTimeToLive(int) - Method in class org.apache.cassandra.cql.Attributes
 
setTokens(Collection<Token>) - Method in class org.apache.cassandra.service.StorageService
This method updates the local token on disk
setTraceProbability() - Method in class org.apache.cassandra.cli.CliParser
 
setTraceProbability(double) - Method in class org.apache.cassandra.service.StorageService
 
setTraceProbability(double) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Enables/Disables tracing for the whole system.
setTraceProbability(double) - Method in class org.apache.cassandra.tools.NodeProbe
 
setTracingId(UUID) - Method in class org.apache.cassandra.transport.Message.Response
 
setTracingRequested() - Method in class org.apache.cassandra.transport.Message.Request
 
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
 
setTruncateRpcTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setTruncateRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
 
setTruncateRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
setTupleValue(Tuple, int, Object) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
set the value to the position of the tuple
SetType<T> - Class in org.apache.cassandra.db.marshal
 
SetType(AbstractType<T>) - Constructor for class org.apache.cassandra.db.marshal.SetType
 
setUDFContextSignature(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
setup() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
setup() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
setup() - Static method in class org.apache.cassandra.auth.Auth
Sets up Authenticator and Authorizer.
setup() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
setup() - Method in interface org.apache.cassandra.auth.IAuthenticator
Setup is called once upon system startup to initialize the IAuthenticator.
setup() - Method in interface org.apache.cassandra.auth.IAuthorizer
Setup is called once upon system startup to initialize the IAuthorizer.
setup() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
 
setup() - Method in class org.apache.cassandra.auth.LegacyAuthorizer
 
setup() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
setup() - Method in class org.apache.cassandra.service.CassandraDaemon
This is a hook for concrete daemons to initialize themselves suitably.
setup() - Method in class org.apache.cassandra.service.ScheduledRangeTransferExecutorService
 
setupJob(JobContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
 
setupTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
 
setUserDefined(boolean) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
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.net.MessagingService
 
setWriteConsistencyLevel(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setWriteRpcTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setWriteRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
 
setWriteRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
severity(double) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
SHORT_OPTION - Static variable in interface org.apache.cassandra.thrift.ITransportFactory
 
shortToCB(int) - Static method in class org.apache.cassandra.transport.CBUtil
 
shouldHint() - Method in class org.apache.cassandra.net.CallbackInfo
 
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, long) - Method in class org.apache.cassandra.db.compaction.CompactionController
 
shouldPurge(DecoratedKey, long) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplitController
 
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
 
Shuffle - Class in org.apache.cassandra.tools
 
Shuffle(String, int) - Constructor for class org.apache.cassandra.tools.Shuffle
 
Shuffle(String, int, String, int, boolean, String, String) - Constructor for class org.apache.cassandra.tools.Shuffle
 
shuffle(boolean, String) - Method in class org.apache.cassandra.tools.Shuffle
Create and distribute a new, randomized token to endpoint mapping.
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
 
SimpleClient - Class in org.apache.cassandra.transport
 
SimpleClient(String, int, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.SimpleClient
 
SimpleClient(String, int) - Constructor for class org.apache.cassandra.transport.SimpleClient
 
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
 
SimpleTransportFactory - Class in org.apache.cassandra.cli.transport
Almost a noop factory, getTransport() method returns back the argument
SimpleTransportFactory() - Constructor for class org.apache.cassandra.cli.transport.SimpleTransportFactory
 
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.cql3.ResultSet
 
size() - Method in class org.apache.cassandra.cql3.UntypedResultSet
 
size() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
size() - Method in class org.apache.cassandra.db.AtomicSortedColumns
 
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.RangeTombstoneList
 
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.sstable.IndexSummary
 
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.metrics.CacheMetrics
Total size of cache, in bytes
size - Variable in class org.apache.cassandra.streaming.PendingFile
total length of data to transfer
size() - Method in class org.apache.cassandra.utils.BiMultiValMap
 
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.
sizeof(boolean) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
 
sizeof(short) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
 
sizeof(int) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
 
sizeof(long) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
 
sizeof(UUID) - Method in class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
 
sizeof(boolean) - Method in class org.apache.cassandra.db.TypeSizes
 
sizeof(short) - Method in class org.apache.cassandra.db.TypeSizes
 
sizeof(int) - Method in class org.apache.cassandra.db.TypeSizes
 
sizeof(long) - Method in class org.apache.cassandra.db.TypeSizes
 
sizeof(UUID) - Method in class org.apache.cassandra.db.TypeSizes
 
sizeof(String) - Method in class org.apache.cassandra.db.TypeSizes
assumes UTF8
sizeof(long) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
 
sizeof(boolean) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
 
sizeof(short) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
 
sizeof(int) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
 
sizeof(UUID) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
 
sizeofVInt(long) - Method in class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
 
sizeofWithLength(ByteBuffer) - Method in class org.apache.cassandra.db.TypeSizes
 
sizeofWithShortLength(ByteBuffer) - Method in class org.apache.cassandra.db.TypeSizes
 
SizeTieredCompactionStrategy - Class in org.apache.cassandra.db.compaction
 
SizeTieredCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
skip(DataInput, Descriptor.Version) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
 
skip(long) - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
Skips count number of bytes in this InputStream.
skip(long) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
 
skipBloomFilter(DataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
 
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
 
skipBytes(int) - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
 
skipBytesFully(DataInput, int) - Static method in class org.apache.cassandra.io.util.FileUtils
 
skipBytesFully(DataInput, long) - Static method in class org.apache.cassandra.io.util.FileUtils
 
skipIndex(DataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
Skip the index
SkipNullRepresenter - Class in org.apache.cassandra.utils
 
SkipNullRepresenter() - Constructor for class org.apache.cassandra.utils.SkipNullRepresenter
 
skipPromotedIndex(DataInput) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
 
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
 
SliceByNamesReadCommand(String, ByteBuffer, QueryPath, NamesQueryFilter) - 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
 
SliceFromReadCommand(String, ByteBuffer, QueryPath, SliceQueryFilter) - 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
 
SliceQueryFilter(ByteBuffer, ByteBuffer, boolean, int, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
 
SliceQueryFilter(ColumnSlice[], boolean, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
Constructor that accepts multiple slices.
SliceQueryFilter(ColumnSlice[], boolean, int, int, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
 
SliceQueryFilter.Serializer - Class in org.apache.cassandra.db.filter
 
SliceQueryFilter.Serializer() - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
 
SliceQueryPager - Class in org.apache.cassandra.db
 
SliceQueryPager(ColumnFamilyStore, DecoratedKey, ColumnSlice[]) - Constructor for class org.apache.cassandra.db.SliceQueryPager
 
slices - Variable in 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
 
snapshotCreationTime(String) - Method in class org.apache.cassandra.db.Directories
 
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_PROPERTIES_FILENAME - Static variable in class org.apache.cassandra.locator.PropertyFileSnitch
 
SnitchProperties - Class in org.apache.cassandra.locator
 
SnitchProperties() - Constructor for class org.apache.cassandra.locator.SnitchProperties
 
socket - Variable in class org.apache.cassandra.streaming.FileStreamTask
 
socket - Variable in class org.apache.cassandra.transport.Server
 
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
 
SortedBiMultiValMap<K,V> - Class in org.apache.cassandra.utils
 
SortedBiMultiValMap(SortedMap<K, V>, SortedSetMultimap<V, K>) - Constructor for class org.apache.cassandra.utils.SortedBiMultiValMap
 
sortedTokens() - Method in class org.apache.cassandra.locator.TokenMetadata
 
sortSampledKeys(List<DecoratedKey>, Range<Token>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
spaceReclaimed(long) - Method in class org.apache.cassandra.db.DataTracker
 
SPEC - Static variable in class org.apache.cassandra.utils.ObjectSizes
 
split() - Method in class org.apache.cassandra.db.compaction.SSTableSplitter
 
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.
splitSize - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
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
 
SSLTransportFactory - Class in org.apache.cassandra.cli.transport
 
SSLTransportFactory() - Constructor for class org.apache.cassandra.cli.transport.SSLTransportFactory
 
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, String, 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
 
SSTableImport(boolean) - Constructor for class org.apache.cassandra.tools.SSTableImport
 
SSTableImport(Integer, boolean) - 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>, RowIndexEntry) - 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.FilteredKeyScanningIterator - Class in org.apache.cassandra.io.sstable
 
SSTableScanner.FilteredKeyScanningIterator() - Constructor for class org.apache.cassandra.io.sstable.SSTableScanner.FilteredKeyScanningIterator
 
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
 
SSTableSimpleUnsortedWriter(File, CFMetaData, IPartitioner, long) - 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, ColumnSlice[], boolean) - Constructor for class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
SSTableSliceIterator(SSTableReader, FileDataInput, DecoratedKey, ColumnSlice[], boolean, RowIndexEntry) - 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.
sstablesPerRead - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Deprecated.
sstablesPerReadHistogram - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Histogram of the number of sstable data files accessed per read
SSTableSplitter - Class in org.apache.cassandra.db.compaction
 
SSTableSplitter(ColumnFamilyStore, SSTableReader, int) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter
 
SSTableSplitter.SplitController - Class in org.apache.cassandra.db.compaction
 
SSTableSplitter.SplitController(ColumnFamilyStore, Collection<SSTableReader>) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.SplitController
 
SSTableSplitter.SplittingCompactionTask - Class in org.apache.cassandra.db.compaction
 
SSTableSplitter.SplittingCompactionTask(ColumnFamilyStore, SSTableReader, int) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
 
SSTableSplitter.StatsCollector - Class in org.apache.cassandra.db.compaction
 
SSTableSplitter.StatsCollector() - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.StatsCollector
 
sstablesRewrite(boolean) - 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
 
StandaloneSplitter - Class in org.apache.cassandra.tools
 
StandaloneSplitter() - Constructor for class org.apache.cassandra.tools.StandaloneSplitter
 
StandaloneUpgrader - Class in org.apache.cassandra.tools
 
StandaloneUpgrader() - Constructor for class org.apache.cassandra.tools.StandaloneUpgrader
 
start() - Method in class org.apache.cassandra.db.BatchlogManager
 
start - Variable in class org.apache.cassandra.db.filter.ColumnSlice
 
start() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
start() - Method in class org.apache.cassandra.db.HintedHandOffManager
 
start(int) - Method in class org.apache.cassandra.gms.Gossiper
 
start(int, Map<ApplicationState, VersionedValue>) - Method in class org.apache.cassandra.gms.Gossiper
Start the gossiper with the generation number, preloading the map of application states before starting
start() - Method in class org.apache.cassandra.service.AntiEntropyService.RequestCoordinator
 
start() - Method in interface org.apache.cassandra.service.CassandraDaemon.Server
Start the server.
start() - Method in class org.apache.cassandra.service.CassandraDaemon
Start the Cassandra Daemon, assuming that it has already been initialized via CassandraDaemon.init(String[]) Hook for JSVC
start() - Method in class org.apache.cassandra.service.EmbeddedCassandraService
 
start() - Method in class org.apache.cassandra.service.GCInspector
 
start() - Method in class org.apache.cassandra.thrift.ThriftServer
 
start() - Method in class org.apache.cassandra.transport.Server
 
start_native_transport - Variable in class org.apache.cassandra.config.Config
 
start_rpc - Variable in class org.apache.cassandra.config.Config
 
startBroadcasting() - Method in class org.apache.cassandra.service.LoadBroadcaster
 
started() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
report event on the size of the compaction.
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
 
startNativeTransport() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
startNativeTransport() - Method in class org.apache.cassandra.service.StorageService
 
startNativeTransport() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
startNativeTransport() - Method in class org.apache.cassandra.tools.NodeProbe
 
startNext() - Method in class org.apache.cassandra.streaming.StreamOutSession
 
startReadOperation(String) - Method in class org.apache.cassandra.service.PBSPredictor
 
startReadOperation(String, long) - Method in class org.apache.cassandra.service.PBSPredictor
 
startRpc() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
startRPCServer() - Method in class org.apache.cassandra.service.StorageService
 
startRPCServer() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
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
 
StartupMessage - Class in org.apache.cassandra.transport.messages
The initial message of the protocol.
StartupMessage(Map<String, String>) - Constructor for class org.apache.cassandra.transport.messages.StartupMessage
 
startWriteOperation(String) - Method in class org.apache.cassandra.service.PBSPredictor
 
startWriteOperation(String, long) - Method in class org.apache.cassandra.service.PBSPredictor
 
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
 
statementId - Variable in class org.apache.cassandra.transport.messages.ExecuteMessage
 
statementId - Variable in class org.apache.cassandra.transport.messages.ResultMessage.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 - Variable in class org.apache.cassandra.transport.Event.StatusChange
 
STATUS_BOOTSTRAPPING - Static variable in class org.apache.cassandra.gms.VersionedValue
 
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
 
STATUS_RELOCATING - Static variable in class org.apache.cassandra.gms.VersionedValue
 
StatusLogger - Class in org.apache.cassandra.utils
 
StatusLogger() - Constructor for class org.apache.cassandra.utils.StatusLogger
 
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 interface org.apache.cassandra.service.CassandraDaemon.Server
Stop the server.
stop() - Method in class org.apache.cassandra.service.CassandraDaemon
Stop the daemon, ideally in an idempotent manner.
stop(String[]) - Static method in class org.apache.cassandra.service.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() - Method in class org.apache.cassandra.thrift.ThriftServer
 
stop(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
stop() - Method in class org.apache.cassandra.transport.Server
 
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
 
stopNativeTransport() - Method in class org.apache.cassandra.service.StorageService
 
stopNativeTransport() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
stopNativeTransport() - Method in class org.apache.cassandra.tools.NodeProbe
 
stopNonLocal(TraceState) - Method in class org.apache.cassandra.tracing.Tracing
 
stopRPCServer() - Method in class org.apache.cassandra.service.StorageService
 
stopRPCServer() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
stopSession() - Method in class org.apache.cassandra.tracing.Tracing
Stop the session and record its complete.
stopThriftServer() - Method in class org.apache.cassandra.tools.NodeProbe
 
storage_port - Variable in class org.apache.cassandra.config.Config
 
StorageMetrics - Class in org.apache.cassandra.metrics
Metrics related to Storage.
StorageMetrics() - Constructor for class org.apache.cassandra.metrics.StorageMetrics
 
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
 
StorageServiceMBean - Interface in org.apache.cassandra.service
 
store_type - Variable in class org.apache.cassandra.config.EncryptionOptions
 
storeSignature - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
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() - Method in class org.apache.cassandra.streaming.compress.CompressedFileStreamTask
 
stream() - Method in class org.apache.cassandra.streaming.FileStreamTask
Stream file by it's sections specified by this.header
stream_throughput_outbound_megabits_per_sec - Variable in class org.apache.cassandra.config.Config
 
StreamHeader - Class in org.apache.cassandra.streaming
 
StreamHeader(String, UUID, PendingFile) - Constructor for class org.apache.cassandra.streaming.StreamHeader
 
StreamHeader(String, UUID, PendingFile, Collection<PendingFile>) - Constructor for class org.apache.cassandra.streaming.StreamHeader
 
streamId - Variable in class org.apache.cassandra.transport.Frame.Header
 
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
 
StreamingHistogram - Class in org.apache.cassandra.utils
Histogram that can be constructed from streaming of data.
StreamingHistogram(int) - Constructor for class org.apache.cassandra.utils.StreamingHistogram
Creates a new histogram with max bin size of maxBinSize
StreamingHistogram.StreamingHistogramSerializer - Class in org.apache.cassandra.utils
 
StreamingHistogram.StreamingHistogramSerializer() - Constructor for class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
 
StreamingMetrics - Class in org.apache.cassandra.metrics
Metrics for streaming.
StreamingMetrics(InetAddress) - Constructor for class org.apache.cassandra.metrics.StreamingMetrics
 
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.
StreamReply - Class in org.apache.cassandra.streaming
 
StreamReply(String, UUID, StreamReply.Status) - Constructor for class org.apache.cassandra.streaming.StreamReply
 
StreamReplyVerbHandler - Class in org.apache.cassandra.streaming
 
StreamReplyVerbHandler() - Constructor for class org.apache.cassandra.streaming.StreamReplyVerbHandler
 
StreamRequest - Class in org.apache.cassandra.streaming
This class encapsulates the message that needs to be sent to nodes that handoff data.
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(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
 
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.
stringifyCollectionsParameters(Map<ByteBuffer, CollectionType>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
 
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
 
stringToCB(String) - Static method in class org.apache.cassandra.transport.CBUtil
 
StringToken - Class in org.apache.cassandra.dht
 
StringToken(String) - Constructor for class org.apache.cassandra.dht.StringToken
 
subcodec - Variable in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
 
subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
 
subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.Rows
 
subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
 
subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
 
subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.Void
 
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
 
submitHint(RowMutation, InetAddress, AbstractWriteResponseHandler, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
 
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, 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.BoundedStatsDeque
 
sum(double) - Method in class org.apache.cassandra.utils.StreamingHistogram
Calculates estimated number of points in interval [-inf,b].
SUMMARY - Static variable in class org.apache.cassandra.io.sstable.Component
 
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
 
supersedes(RangeTombstone, Comparator<ByteBuffer>) - Method in class org.apache.cassandra.db.RangeTombstone
This tombstone supersedes another one if it is more recent and cover a bigger range than rt.
SUPERUSER_SETUP_DELAY - Static variable in class org.apache.cassandra.auth.Auth
 
supported - Variable in class org.apache.cassandra.transport.messages.SupportedMessage
 
SupportedMessage - Class in org.apache.cassandra.transport.messages
Message to indicate that the server is ready to receive requests.
SupportedMessage(Map<String, List<String>>) - Constructor for class org.apache.cassandra.transport.messages.SupportedMessage
 
supportedOptions() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
supportedOptions() - Method in interface org.apache.cassandra.auth.IAuthenticator
Set of options supported by CREATE USER and ALTER USER queries.
supportedOptions() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
 
supportedOptions() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
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.LZ4Compressor
 
supportedOptions() - Method in class org.apache.cassandra.io.compress.SnappyCompressor
 
supportedOptions() - Method in interface org.apache.cassandra.thrift.ITransportFactory
 
supportedOptions() - Method in class org.apache.cassandra.thrift.TFramedTransportFactory
 
switchLock - Static variable in class org.apache.cassandra.db.Table
accesses to CFS.memtable should acquire this for thread safety.
switchMemtable(boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Switch and flush the current memtable, if it was dirty.
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
 
SyntaxException - Exception in org.apache.cassandra.exceptions
 
SyntaxException(String) - Constructor for exception org.apache.cassandra.exceptions.SyntaxException
 
system() - Static method in class org.apache.cassandra.db.Table
 
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_KS - 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
 
systemKeyspaceNames - Static variable in class org.apache.cassandra.config.Schema
 
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 - Variable in class org.apache.cassandra.cql3.Operation
 
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.cql.CqlLexer
 
T__105 - Static variable in class org.apache.cassandra.cql.CqlParser
 
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.cql.CqlLexer
 
T__107 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__111 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__111 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__112 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__112 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__113 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__113 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__114 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__114 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__115 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__115 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__116 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__116 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__117 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__117 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__118 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__118 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__119 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__119 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__120 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__120 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__121 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__121 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__122 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__122 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__123 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__123 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__124 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__124 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__125 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__125 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__126 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__126 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__127 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__127 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__127 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__127 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__128 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__128 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__128 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__128 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__129 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__129 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__129 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__129 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__130 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__130 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__130 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__130 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__131 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__131 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__131 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__131 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__132 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__132 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__132 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__132 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__133 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__133 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__134 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__134 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__135 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__135 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__136 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__136 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__137 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__137 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__138 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__138 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__139 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__139 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__140 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__140 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__141 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__141 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__142 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__142 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__143 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__143 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__144 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__144 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__81 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__81 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__82 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__82 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__83 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__83 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__84 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__84 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__85 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__85 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__86 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__86 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__87 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__87 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__88 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__88 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__89 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__89 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__90 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__90 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__91 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__91 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__92 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__92 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__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 - Variable in class org.apache.cassandra.service.AbstractRowResolver
 
table - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
table - Variable in class org.apache.cassandra.streaming.AbstractStreamSession
 
table - Variable in class org.apache.cassandra.streaming.StreamHeader
 
table - Variable in class org.apache.cassandra.streaming.StreamRequest
 
table - Variable in class org.apache.cassandra.transport.Event.SchemaChange
 
tableTransformer - Static variable in class org.apache.cassandra.db.Table
 
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.
target - Variable in class org.apache.cassandra.net.CallbackInfo
 
target - Variable in class org.apache.cassandra.streaming.StreamRequest
 
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, 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
 
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.
TCustomServerSocket(ServerSocket, boolean, Integer, Integer) - Constructor for class org.apache.cassandra.thrift.TCustomServerSocket
 
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.
tearDown() - Method in class org.apache.cassandra.service.ScheduledRangeTransferExecutorService
 
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 - Interface in org.apache.cassandra.cql3
A CQL3 term, i.e.
Term.NonTerminal - Class in org.apache.cassandra.cql3
A non terminal term, i.e.
Term.NonTerminal() - Constructor for class org.apache.cassandra.cql3.Term.NonTerminal
 
Term.Raw - Interface in org.apache.cassandra.cql3
A parsed, non prepared (thus untyped) term.
Term.Terminal - Class in org.apache.cassandra.cql3
A terminal term, one that can be reduced to a byte buffer directly.
Term.Terminal() - Constructor for class org.apache.cassandra.cql3.Term.Terminal
 
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
 
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
 
ThreadPoolMetrics - Class in org.apache.cassandra.metrics
Metrics for ThreadPoolExecutor.
ThreadPoolMetrics(ThreadPoolExecutor, String, String) - Constructor for class org.apache.cassandra.metrics.ThreadPoolMetrics
Create metrics for given ThreadPoolExecutor.
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
Deprecated.
ThriftClientState - Class in org.apache.cassandra.thrift
ClientState used by thrift that also provide a QueryState.
ThriftClientState() - Constructor for class org.apache.cassandra.thrift.ThriftClientState
 
ThriftConversion - Class in org.apache.cassandra.thrift
Static utility methods to convert internal structure to and from thrift ones.
ThriftConversion() - Constructor for class org.apache.cassandra.thrift.ThriftConversion
 
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
 
thriftServer - Variable in class org.apache.cassandra.service.CassandraDaemon
 
ThriftServer - Class in org.apache.cassandra.thrift
 
ThriftServer(InetAddress, int) - Constructor for class org.apache.cassandra.thrift.ThriftServer
 
ThriftSessionManager - Class in org.apache.cassandra.thrift
Encapsulates the current client state (session).
ThriftSessionManager() - Constructor for class org.apache.cassandra.thrift.ThriftSessionManager
 
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 - Variable in class org.apache.cassandra.streaming.FileStreamTask
 
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
 
ThrottledReader - Class in org.apache.cassandra.io.util
 
ThrottledReader(File, RateLimiter) - Constructor for class org.apache.cassandra.io.util.ThrottledReader
 
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
timeout - Variable in class org.apache.cassandra.utils.ExpiringMap.CacheableObject
 
timeouts - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
 
timeouts - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
Number of timeouts for specific IP
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.UpdateParameters
 
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.CounterId.CounterIdRecord
 
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
 
TimeuuidFcts - Class in org.apache.cassandra.cql3.functions
 
TimeuuidFcts() - Constructor for class org.apache.cassandra.cql3.functions.TimeuuidFcts
 
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.
TOC - Static variable in class org.apache.cassandra.io.sstable.Component
 
toDouble(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
toFloat(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
toHint(int, UUID) - Method in class org.apache.cassandra.db.RowMutation
Returns mutation representing a Hint to be sent to targetId as soon as it becomes available.
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<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
 
TokenFct - Class in org.apache.cassandra.cql3.functions
 
TokenFct(CFMetaData) - Constructor for class org.apache.cassandra.cql3.functions.TokenFct
 
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.Topology - Class in org.apache.cassandra.locator
Tracks the assignment of racks and endpoints in each datacenter for all the "normal" endpoints in this TokenMetadata.
TokenMetadata.Topology() - Constructor for class org.apache.cassandra.locator.TokenMetadata.Topology
 
TokenMetadata.Topology(TokenMetadata.Topology) - Constructor for class org.apache.cassandra.locator.TokenMetadata.Topology
construct deep-copy of other
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
 
tokens - Variable in class org.apache.cassandra.dht.BootStrapper
 
tokens(Collection<Token>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
TokenSerializer - Class in org.apache.cassandra.gms
 
TokenSerializer() - Constructor for class org.apache.cassandra.gms.TokenSerializer
 
tokensFromString(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
toLong(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
TOMBSTONE_COMPACTION_INTERVAL_OPTION - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
TOMBSTONE_HISTOGRAM_BIN_SIZE - Static variable in class org.apache.cassandra.io.sstable.SSTable
 
TOMBSTONE_THRESHOLD_OPTION - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
tombstoneCompactionInterval - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
tombstoneHistogram - Variable in class org.apache.cassandra.io.sstable.ColumnStats
histogram of tombstone drop time
tombstoneThreshold - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
tombstoneTracker() - Method in class org.apache.cassandra.db.ColumnIndex.Builder
 
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() - Method in class org.apache.cassandra.auth.DataResource
 
toString() - Method in class org.apache.cassandra.auth.PermissionDetails
 
toString(List<Object>) - Static method in class org.apache.cassandra.auth.Resources
Deprecated.
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(InetAddress) - Method in class org.apache.cassandra.cql.jdbc.JdbcInetAddress
 
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.AbstractMarker.Raw
 
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.ColumnSpecification
 
toString() - Method in class org.apache.cassandra.cql3.Constants.Literal
 
toString() - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
 
toString() - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
 
toString() - Method in enum org.apache.cassandra.cql3.CQL3Type.Native
 
toString() - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
 
toString() - Method in class org.apache.cassandra.cql3.Lists.Literal
 
toString() - Method in class org.apache.cassandra.cql3.Maps.Literal
 
toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.Addition
 
toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.Prepend
 
toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.SetElement
 
toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.SetValue
 
toString(ColumnSpecification) - Method in class org.apache.cassandra.cql3.Operation.Substraction
 
toString() - Method in class org.apache.cassandra.cql3.Relation
 
toString() - Method in class org.apache.cassandra.cql3.ResultSet.Metadata
 
toString() - Method in class org.apache.cassandra.cql3.ResultSet
 
toString() - Method in class org.apache.cassandra.cql3.Sets.Literal
 
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 class org.apache.cassandra.cql3.statements.RawSelector.WithFunction
 
toString() - Method in class org.apache.cassandra.cql3.statements.RawSelector.WritetimeOrTTL
 
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.TypeCast
 
toString() - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
toString() - Method in class org.apache.cassandra.cql3.UserOptions
 
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.DeletionInfo
 
toString() - Method in class org.apache.cassandra.db.DeletionTime
 
toString() - Method in class org.apache.cassandra.db.filter.ColumnSlice
 
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.CollectionType
 
toString() - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
 
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.EndpointState
 
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.AbstractColumnFamilyRecordWriter.AbstractRangeClient
 
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 error org.apache.cassandra.io.FSReadError
 
toString() - Method in error org.apache.cassandra.io.FSWriteError
 
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.Descriptor.Version
 
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
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.MessageIn
 
toString() - Method in class org.apache.cassandra.net.MessageOut
 
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() - Method in class org.apache.cassandra.streaming.StreamReply
 
toString() - Method in class org.apache.cassandra.streaming.StreamRequest
 
toString() - Method in class org.apache.cassandra.tools.NodeToolHelp.NodeToolCommand
 
toString() - Method in class org.apache.cassandra.transport.Event.SchemaChange
 
toString() - Method in class org.apache.cassandra.transport.Event.StatusChange
 
toString() - Method in class org.apache.cassandra.transport.Event.TopologyChange
 
toString() - Method in class org.apache.cassandra.transport.messages.AuthenticateMessage
 
toString() - Method in class org.apache.cassandra.transport.messages.CredentialsMessage
 
toString() - Method in class org.apache.cassandra.transport.messages.ErrorMessage
 
toString() - Method in class org.apache.cassandra.transport.messages.EventMessage
 
toString() - Method in class org.apache.cassandra.transport.messages.ExecuteMessage
 
toString() - Method in class org.apache.cassandra.transport.messages.OptionsMessage
 
toString() - Method in class org.apache.cassandra.transport.messages.PrepareMessage
 
toString() - Method in class org.apache.cassandra.transport.messages.QueryMessage
 
toString() - Method in class org.apache.cassandra.transport.messages.ReadyMessage
 
toString() - Method in class org.apache.cassandra.transport.messages.RegisterMessage
 
toString() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
 
toString() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Rows
 
toString() - Method in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
 
toString() - Method in class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
 
toString() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Void
 
toString() - Method in class org.apache.cassandra.transport.messages.StartupMessage
 
toString() - Method in class org.apache.cassandra.transport.messages.SupportedMessage
 
toString() - Method in class org.apache.cassandra.utils.CounterId.CounterIdRecord
 
toString() - Method in class org.apache.cassandra.utils.CounterId
 
toString(Map<?, ?>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
toString() - Method in class org.apache.cassandra.utils.Interval
 
toString() - Method in class org.apache.cassandra.utils.IntervalTree
 
toString() - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
toString() - Method in class org.apache.cassandra.utils.MD5Digest
 
toString() - Method in class org.apache.cassandra.utils.MerkleTree.RowHash
 
toString() - Method in class org.apache.cassandra.utils.MerkleTree
 
toString() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
toString() - Method in class org.apache.cassandra.utils.Pair
 
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 counter ids.
total() - Method in class org.apache.cassandra.db.CounterColumn
 
totalBlocked - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
Number of tasks that had blocked before being accepted (or rejected).
totalBlockFor() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
totalBytes - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
totalBytesCompacted - Static variable in class org.apache.cassandra.db.compaction.CompactionTask
 
totalCommitLogSize - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
Current size used by all the commit log segments
totalCompactionsCompleted - Variable in class org.apache.cassandra.metrics.CompactionMetrics
Total number of compactions since server [re]start
totalDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Total disk space used by SSTables belonging to this CF, including obsolete ones waiting to be GC'd
totalIncomingBytes - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
 
totalLatency - Variable in class org.apache.cassandra.metrics.LatencyMetrics
Total latency in micro sec
totalLatencyHistogram - Variable in class org.apache.cassandra.metrics.LatencyMetrics
Deprecated.
totalOutgoingBytes - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
 
totalTimeouts - Static variable in class org.apache.cassandra.metrics.ConnectionMetrics
Total number of timeouts happened on this node
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
 
toThrift(ConsistencyLevel) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
toThrift(RequestValidationException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
toThrift(InvalidRequestException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
toThrift(UnavailableException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
toThrift(AuthenticationException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
toThrift(RequestTimeoutException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
toThriftPreparedResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
 
toThriftResult() - Method in class org.apache.cassandra.cql3.ResultSet
 
toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
 
toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Rows
 
toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
 
toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
 
toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage
 
toThriftResult() - Method in class org.apache.cassandra.transport.messages.ResultMessage.Void
 
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
 
toType(Pair<DataType, Object>) - Static method in enum org.apache.cassandra.transport.DataType
 
tProtocolFactory - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
 
TRACE - Static variable in class org.apache.cassandra.cli.CliLexer
 
TRACE - Static variable in class org.apache.cassandra.cli.CliParser
 
trace(String, Object) - Method in class org.apache.cassandra.tracing.TraceState
 
trace(String, Object, Object) - Method in class org.apache.cassandra.tracing.TraceState
 
trace(String, Object[]) - Method in class org.apache.cassandra.tracing.TraceState
 
trace(String) - Method in class org.apache.cassandra.tracing.TraceState
 
trace(ByteBuffer, String, int) - Static method in class org.apache.cassandra.tracing.TraceState
 
trace(String) - Static method in class org.apache.cassandra.tracing.Tracing
 
trace(String, Object) - Static method in class org.apache.cassandra.tracing.Tracing
 
trace(String, Object, Object) - Static method in class org.apache.cassandra.tracing.Tracing
 
trace(String, Object[]) - Static method in class org.apache.cassandra.tracing.Tracing
 
TRACE_HEADER - Static variable in class org.apache.cassandra.tracing.Tracing
 
TRACE_KS - Static variable in class org.apache.cassandra.tracing.Tracing
 
trace_next_query() - Method in class org.apache.cassandra.thrift.CassandraServer
 
TraceEventsCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
traceKeyspace() - Static method in class org.apache.cassandra.config.KSMetaData
 
traceNextQuery() - Method in class org.apache.cassandra.cli.CliParser
 
traceNextQuery() - Method in class org.apache.cassandra.service.QueryState
 
traceSessionId() - Method in class org.apache.cassandra.cli.CliParser
 
TraceSessionsCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
TraceState - Class in org.apache.cassandra.tracing
ThreadLocal state for a tracing session.
TraceState(InetAddress, UUID) - Constructor for class org.apache.cassandra.tracing.TraceState
 
Tracing - Class in org.apache.cassandra.tracing
A trace session context.
Tracing() - Constructor for class org.apache.cassandra.tracing.Tracing
 
TracingAwareExecutorService - Interface in org.apache.cassandra.concurrent
 
tracingId - Variable in class org.apache.cassandra.transport.Message.Response
 
tracingProbability() - Method in class org.apache.cassandra.cli.CliParser
 
tracingRequested - Variable in class org.apache.cassandra.transport.Message.Request
 
tracker - Variable in class org.apache.cassandra.transport.SimpleClient
 
tracksMaxTimestamp - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
 
tracksMinTimestamp - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
 
tracksTombstones - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
 
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(InetAddress, Table, Iterable<ColumnFamilyStore>, Collection<Range<Token>>, IStreamCallback, OperationType) - Static method in class org.apache.cassandra.streaming.StreamOut
Stream the given ranges to the target endpoint for provided CFs 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.
transferRanges(StreamOutSession, Iterable<ColumnFamilyStore>, Collection<Range<Token>>, OperationType, boolean) - 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.
TransportException - Interface in org.apache.cassandra.exceptions
 
transportFactory - Variable in class org.apache.cassandra.cli.CliSessionState
 
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
 
trim(int) - Method in class org.apache.cassandra.cql3.ResultSet
 
trim(ColumnFamily, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
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 deletes the entire column family's data with no expensive tombstone creation
truncate(long) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
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
 
truncate_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
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
TruncateException - Exception in org.apache.cassandra.exceptions
 
TruncateException(Throwable) - Constructor for exception org.apache.cassandra.exceptions.TruncateException
 
TruncateException(String) - Constructor for exception org.apache.cassandra.exceptions.TruncateException
 
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
 
TServerCustomFactory - Class in org.apache.cassandra.thrift
Helper implementation to create a thrift TServer based on one of the common types we support (sync, async, hsha), or a custom type by setting the fully qualified java class name in the rpc_server_type setting.
TServerCustomFactory(String) - Constructor for class org.apache.cassandra.thrift.TServerCustomFactory
 
TServerFactory - Interface in org.apache.cassandra.thrift
 
TServerFactory.Args - Class in org.apache.cassandra.thrift
 
TServerFactory.Args() - Constructor for class org.apache.cassandra.thrift.TServerFactory.Args
 
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.ColumnSpecification
 
type - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement
 
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
 
type - Variable in class org.apache.cassandra.streaming.StreamRequest
 
type - Variable in class org.apache.cassandra.transport.Event
 
type - Variable in class org.apache.cassandra.transport.Frame.Header
 
type - Variable in class org.apache.cassandra.transport.Message
 
TYPE_NAME - Static variable in class org.apache.cassandra.metrics.CacheMetrics
 
TYPE_NAME - Static variable in class org.apache.cassandra.metrics.CommitLogMetrics
 
TYPE_NAME - Static variable in class org.apache.cassandra.metrics.CompactionMetrics
 
TYPE_NAME - Static variable in class org.apache.cassandra.metrics.ConnectionMetrics
 
TYPE_NAME - Static variable in class org.apache.cassandra.metrics.DroppedMessageMetrics
 
TYPE_NAME - Static variable in class org.apache.cassandra.metrics.HintedHandoffMetrics
 
TYPE_NAME - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
 
TYPE_NAME - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
 
TypeCast - Class in org.apache.cassandra.cql3
 
TypeCast(CQL3Type, Term.Raw) - Constructor for class org.apache.cassandra.cql3.TypeCast
 
typeIdentifier() - Method in class org.apache.cassandra.cli.CliParser
 
TypeParser - Class in org.apache.cassandra.db.marshal
Parse a string containing an Type definition.
TypeParser(String) - Constructor for class org.apache.cassandra.db.marshal.TypeParser
 
types - Variable in class org.apache.cassandra.db.marshal.CompositeType
 
TypeSizes - Class in org.apache.cassandra.db
 
TypeSizes() - Constructor for class org.apache.cassandra.db.TypeSizes
 
TypeSizes.NativeDBTypeSizes - Class in org.apache.cassandra.db
 
TypeSizes.NativeDBTypeSizes() - Constructor for class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
 
TypeSizes.VIntEncodedTypeSizes - Class in org.apache.cassandra.db
 
TypeSizes.VIntEncodedTypeSizes() - Constructor for class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
 
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
 
UnauthorizedException - Exception in org.apache.cassandra.exceptions
 
UnauthorizedException(String) - Constructor for exception org.apache.cassandra.exceptions.UnauthorizedException
 
UnavailableException - Exception in org.apache.cassandra.exceptions
 
UnavailableException(ConsistencyLevel, int, int) - Constructor for exception org.apache.cassandra.exceptions.UnavailableException
 
unavailables - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
 
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.LZ4Compressor
 
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
 
unixTimestamp(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
 
unixTimestampOfFct - Static variable in class org.apache.cassandra.cql3.functions.TimeuuidFcts
 
UnknownColumnFamilyException - Exception in org.apache.cassandra.db
 
UnknownColumnFamilyException(String, UUID) - 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.
UNREACHABLE - Static variable in class org.apache.cassandra.service.StorageProxy
 
unreference() - Method in class org.apache.cassandra.cache.RefCountedMemory
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
 
unregister(IMigrationListener) - Method in class org.apache.cassandra.service.MigrationManager
 
unregister(IEndpointLifecycleSubscriber) - Method in class org.apache.cassandra.service.StorageService
 
unregister(Channel) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
 
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_function_keyword() - Method in class org.apache.cassandra.cql3.CqlParser
 
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(ResultSet) - Constructor for class org.apache.cassandra.cql3.UntypedResultSet
 
UntypedResultSet.Row - Class in org.apache.cassandra.cql3
 
UntypedResultSet.Row(List<ColumnSpecification>, List<ByteBuffer>) - 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(ByteBuffer, IColumn) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
update(ByteBuffer, IColumn) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
update a column from the index
update(IColumn, IColumn) - Method in interface org.apache.cassandra.db.index.SecondaryIndexManager.Updater
called when updating the index from a memtable
update(OnDiskAtom) - Method in class org.apache.cassandra.db.RangeTombstone.Tracker
Update this tracker given an atom.
update(byte[], int, int) - Method in class org.apache.cassandra.utils.PureJavaCrc32
 
update(int) - Method in class org.apache.cassandra.utils.PureJavaCrc32
 
update(double) - Method in class org.apache.cassandra.utils.StreamingHistogram
Adds new point p to this histogram.
update(double, long) - Method in class org.apache.cassandra.utils.StreamingHistogram
Adds new point p with value m to this histogram.
updateCapacity(long) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
updateColumnFamily() - Method in class org.apache.cassandra.cli.CliParser
 
UpdateColumnFamily - Class in org.apache.cassandra.db.migration.avro
 
UpdateColumnFamily() - Constructor for class org.apache.cassandra.db.migration.avro.UpdateColumnFamily
 
updateColumnsLimit(int) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
 
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
 
updateCounterFor(int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
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.DeletedColumn
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.ExpiringColumn
 
updateDigest(MessageDigest) - Method in interface org.apache.cassandra.db.OnDiskAtom
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.RangeTombstone
 
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.
updateHintsDropped(InetAddress, UUID, int) - Static method in class org.apache.cassandra.db.SystemTable
 
updateHostId(UUID, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
Store an end-point to host ID mapping.
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
 
updateLocalTokens(Collection<Token>, Collection<Token>) - Static method in class org.apache.cassandra.db.SystemTable
Convenience method to update the list of tokens in the local system table.
updateMaxTimestamp(long) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
updateMinTimestamp(long) - Method in class org.apache.cassandra.io.sstable.SSTableMetadata.Collector
 
updateNormalToken(Token, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
Update token map with a single token/endpoint pair in normal state.
updateNormalTokens(Collection<Token>, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
updateNormalTokens(Multimap<InetAddress, Token>) - Method in class org.apache.cassandra.locator.TokenMetadata
Update token map with a set of token/endpoint pairs in normal state.
UpdateParameters - Class in org.apache.cassandra.cql3
A simple container that simplify passing parameters for collections methods.
UpdateParameters(List<ByteBuffer>, long, int, Map<ByteBuffer, ColumnGroupMap>) - Constructor for class org.apache.cassandra.cql3.UpdateParameters
 
updatePeerInfo(InetAddress, String, String) - Static method in class org.apache.cassandra.db.SystemTable
 
updaterFor(DecoratedKey) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
This helper acts as a closure around the indexManager and row key to ensure that down in Memtable's ColumnFamily implementation, the index can get updated.
updateRowLevelIndexes() - Method in interface org.apache.cassandra.db.index.SecondaryIndexManager.Updater
called after memtable updates are complete (CASSANDRA-5397)
updateSchemaVersion(UUID) - Static method in class org.apache.cassandra.db.SystemTable
 
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
updateSSTableIterated(int) - Method in class org.apache.cassandra.metrics.ColumnFamilyMetrics
 
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, List<Pair<ColumnIdentifier, Operation.RawUpdate>>, 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, Attributes, List<ColumnIdentifier>, List<Term.Raw>) - 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.
updateTokens(InetAddress, Collection<Token>) - Static method in class org.apache.cassandra.db.SystemTable
Record tokens being used by another node
updateTokens(Collection<Token>) - Static method in class org.apache.cassandra.db.SystemTable
This method is used to update the System Table with the new tokens 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
 
upgrade() - Method in class org.apache.cassandra.db.compaction.Upgrader
 
Upgrader - Class in org.apache.cassandra.db.compaction
 
Upgrader(ColumnFamilyStore, SSTableReader, OutputHandler) - Constructor for class org.apache.cassandra.db.compaction.Upgrader
 
upgradeSSTables(String, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
 
upgradeSSTables(String, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Rewrite all sstables to the latest version.
upgradeSSTables(String, boolean, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
upperBound(Class<R>) - 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
 
usePartitionFilter - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
username - Variable in class org.apache.cassandra.auth.PermissionDetails
 
username() - Method in class org.apache.cassandra.cli.CliParser
 
username - Variable in class org.apache.cassandra.cli.CliSessionState
 
username() - Method in class org.apache.cassandra.cql3.CqlParser
 
username - Variable in class org.apache.cassandra.cql3.statements.PermissionAlteringStatement
 
username - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
 
username - Variable in class org.apache.cassandra.tools.AbstractJmxClient
 
USERNAME_KEY - Static variable in interface org.apache.cassandra.auth.IAuthenticator
 
userOption(UserOptions) - Method in class org.apache.cassandra.cql3.CqlParser
 
userOptions(UserOptions) - Method in class org.apache.cassandra.cql3.CqlParser
 
UserOptions - Class in org.apache.cassandra.cql3
 
UserOptions() - Constructor for class org.apache.cassandra.cql3.UserOptions
 
USERS_CF - Static variable in class org.apache.cassandra.auth.Auth
 
usesHostId(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
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
 
usesVnodes(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
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
 
usingClauseObjective(Attributes) - Method in class org.apache.cassandra.cql.CqlParser
 
usingClauseObjective(Attributes) - Method in class org.apache.cassandra.cql3.CqlParser
 
UTF8Type - Class in org.apache.cassandra.db.marshal
 
UUID - Static variable in class org.apache.cassandra.cql.CqlLexer
 
UUID - Static variable in class org.apache.cassandra.cql.CqlParser
 
uuid(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
 
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.
UUIDSerializer - Class in org.apache.cassandra.utils
 
uuidToCB(UUID) - Static method in class org.apache.cassandra.transport.CBUtil
 
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.AlterUserStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
 
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.CreateUserStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropUserStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListUsersStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.PermissionAlteringStatement
 
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() - Method in class org.apache.cassandra.cql3.UserOptions
 
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.CollectionType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
 
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.EmptyType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.InetAddressType
 
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
 
validateCollectionMember(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
An alternative validation function used by CollectionsType in conjunction with CompositeType.
validateCollectionMember(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
 
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
 
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
validateCompactionOptions(Class<? extends AbstractCompactionStrategy>, Map<String, String>, boolean) - Static method in class org.apache.cassandra.config.CFMetaData
 
validateComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
Like getComparator, but validates that @param i does not exceed the defined range
validateComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
validateComparator(int, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
validateCompatility(CFMetaData) - Method in class org.apache.cassandra.config.CFMetaData
 
validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllInternodeAuthenticator
 
validateConfiguration() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthenticator
Validates configuration of IAuthenticator implementation (if configurable).
validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthorizer
Validates configuration of IAuthorizer implementation (if configurable).
validateConfiguration() - Method in interface org.apache.cassandra.auth.IInternodeAuthenticator
Validates configuration of IInternodeAuthenticator implementation (if configurable).
validateConfiguration() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
 
validateConfiguration() - Method in class org.apache.cassandra.auth.LegacyAuthorizer
 
validateConfiguration() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
validateConfiguration(Configuration) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
 
validateConfiguration(Configuration) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
 
validateConsistency(ConsistencyLevel) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
validateConsistency(ConsistencyLevel) - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
 
validateConsistency(ConsistencyLevel) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
validateConsistency(ConsistencyLevel) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
 
validateContext(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
 
validateCounterForWrite(CFMetaData) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
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 interface org.apache.cassandra.db.OnDiskAtom
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.RangeTombstone
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.SuperColumn
 
validateFilterClauses(CFMetaData, List<IndexExpression>) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateForRead(String) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
validateForWrite(String) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
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
 
validateLogin() - Method in class org.apache.cassandra.service.ClientState
 
validateMagic(int) - Static method in class org.apache.cassandra.net.MessagingService
 
validateMinusSupplied(Object, Term, IntStream) - Method in class org.apache.cassandra.cql.CqlParser
 
validateMutation(CFMetaData, Mutation) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateName(CFMetaData) - Method in class org.apache.cassandra.db.Column
 
validateNewMessage(Message.Type) - Method in class org.apache.cassandra.transport.ServerConnection
 
validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
validateOptions() - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
 
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
 
validateReplicationStrategy(String, String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
validateReplicationStrategyIgnoreUnexpected(String, Class<? extends AbstractReplicationStrategy>, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
validateSlicePredicate(CFMetaData, ByteBuffer, SlicePredicate) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateTable(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validation_class - Variable in class org.apache.cassandra.db.migration.avro.ColumnDef
 
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
 
validBufferBytes - Variable in class org.apache.cassandra.streaming.compress.CompressedInputStream
 
value() - Method in class org.apache.cassandra.cli.CliParser
 
value - Variable in class org.apache.cassandra.cql3.CFDefinition
 
value() - Method in class org.apache.cassandra.cql3.CqlParser
 
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 enum org.apache.cassandra.exceptions.ExceptionCode
 
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 - Variable in class org.apache.cassandra.utils.ExpiringMap.CacheableObject
 
value_alias - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
valueAlias(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
 
valueComparator() - Method in class org.apache.cassandra.db.marshal.CollectionType
 
valueComparator() - Method in class org.apache.cassandra.db.marshal.ListType
 
valueComparator() - Method in class org.apache.cassandra.db.marshal.MapType
 
valueComparator() - Method in class org.apache.cassandra.db.marshal.SetType
 
valueFactory - Variable in class org.apache.cassandra.service.StorageService
 
valueOf(String) - Static method in enum org.apache.cassandra.auth.IAuthenticator.Option
Returns the enum constant of this type with the specified name.
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.DiskFailurePolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.Config.InternodeCompression
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.ServerEncryptionOptions.InternodeEncryption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.ReadRepairDecision
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.Constants.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cql3.CQL3Type.Native
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.ResultSet.Flag
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.ModificationStatement.Type
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.ConsistencyLevel
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.marshal.CollectionType.Kind
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.db.WriteType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.exceptions.ExceptionCode
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.hadoop.pig.AbstractCassandraStorage.MarshallerType
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.io.sstable.Component.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.net.MessagingService.Verb
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.service.AntiEntropyService.Status
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.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.
valueOf(String) - Static method in enum org.apache.cassandra.transport.DataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.SchemaChange.Change
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.StatusChange.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.TopologyChange.Change
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.transport.Event.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.transport.Frame.Header.Flag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.transport.Message.Direction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.transport.Message.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.transport.messages.ResultMessage.SchemaChange.Change
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.utils.FilterFactory.Type
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.cassandra.auth.IAuthenticator.Option
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.auth.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.DiskFailurePolicy
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.InternodeCompression
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.ServerEncryptionOptions.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.config.ReadRepairDecision
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.Constants.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.CQL3Type.Native
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.ResultSet.Flag
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.ModificationStatement.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.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.ConsistencyLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.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.marshal.CollectionType.Kind
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.apache.cassandra.db.marshal.MapType
 
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.db.WriteType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.exceptions.ExceptionCode
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.hadoop.pig.AbstractCassandraStorage.MarshallerType
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() - Static method in enum org.apache.cassandra.io.sstable.Component.Type
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.MessagingService.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.service.AntiEntropyService.Status
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.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.
values() - Static method in enum org.apache.cassandra.transport.DataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.transport.Event.SchemaChange.Change
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.transport.Event.StatusChange.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.transport.Event.TopologyChange.Change
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.transport.Event.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.transport.Frame.Header.Flag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.transport.Message.Direction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.transport.Message.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.apache.cassandra.transport.messages.ExecuteMessage
 
values() - Static method in enum org.apache.cassandra.transport.messages.ResultMessage.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.transport.messages.ResultMessage.SchemaChange.Change
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.cassandra.utils.BiMultiValMap
 
values() - Static method in enum org.apache.cassandra.utils.FilterFactory.Type
Returns an array containing the constants of this enum type, in the order they are declared.
valueSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Lists
 
valueSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Maps
 
valueSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Sets
 
VarcharAsBlobFct - Static variable in class org.apache.cassandra.cql3.functions.BytesConversionFcts
 
variables - Variable in class org.apache.cassandra.cql3.UpdateParameters
 
verb - Variable in class org.apache.cassandra.net.MessageIn
 
verb - Variable in class org.apache.cassandra.net.MessageOut
 
verbose - Variable in class org.apache.cassandra.cli.CliSessionState
 
VERBS - Static variable in class org.apache.cassandra.net.MessagingService
 
verbSerializers - Static variable in class org.apache.cassandra.net.MessagingService
Messages we receive in IncomingTcpConnection have a Verb that tells us what kind of message it is.
verbStages - Static variable in class org.apache.cassandra.net.MessagingService
 
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 - Variable in class org.apache.cassandra.net.MessageIn
 
version - Variable in class org.apache.cassandra.transport.Frame.Header
 
VERSION_10 - Static variable in class org.apache.cassandra.net.MessagingService
 
VERSION_11 - Static variable in class org.apache.cassandra.net.MessagingService
 
VERSION_117 - Static variable in class org.apache.cassandra.net.MessagingService
 
VERSION_12 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
VERSION_12 - Static variable in class org.apache.cassandra.net.MessagingService
 
VersionedValue - Class in org.apache.cassandra.gms
This abstraction represents the state associated with a particular node which an application wants to make available to the rest of the nodes in the cluster.
VersionedValue.VersionedValueFactory - Class in org.apache.cassandra.gms
 
VersionedValue.VersionedValueFactory(IPartitioner) - Constructor for class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
VersionGenerator - Class in org.apache.cassandra.gms
A unique version number generator for any state that is generated by the local node.
VersionGenerator() - Constructor for class org.apache.cassandra.gms.VersionGenerator
 
VINT - Static variable in class org.apache.cassandra.db.TypeSizes
 

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
 
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
 
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
 
watch - Variable in class org.apache.cassandra.tracing.TraceState
 
watch(String, Runnable, int) - Static method in class org.apache.cassandra.utils.ResourceWatcher
 
WeightedQueueMBean - Interface in org.apache.cassandra.scheduler
Deprecated.
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
 
wildcard(CFDefinition) - Static method in class org.apache.cassandra.cql3.statements.Selection
 
WITH - Static variable in class org.apache.cassandra.cli.CliLexer
 
WITH - Static variable in class org.apache.cassandra.cli.CliParser
 
with(ChannelBuffer) - Method in class org.apache.cassandra.transport.Frame
 
withGeneration(int) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
withNewResolver(IResponseResolver<TMessage, TResolved>) - Method in class org.apache.cassandra.service.ReadCallback
 
withNewRight(T) - Method in class org.apache.cassandra.dht.AbstractBounds
 
withNewRight(T) - Method in class org.apache.cassandra.dht.Bounds
 
withNewRight(T) - Method in class org.apache.cassandra.dht.ExcludingBounds
 
withNewRight(T) - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
withNewRight(T) - Method in class org.apache.cassandra.dht.Range
 
without(UUID) - Method in class org.apache.cassandra.db.RowMutation
 
withParameter(String, byte[]) - Method in class org.apache.cassandra.net.MessageOut
 
withUpdatedColumns(SortedSet<ByteBuffer>) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
withUpdatedCount(int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
withUpdatedSlices(ColumnSlice[]) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
worthDroppingTombstones(SSTableReader, int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
Check if given sstable is worth dropping tombstones at gcBefore.
wrap(Throwable, int) - Static method in class org.apache.cassandra.transport.messages.ErrorMessage
 
wrap(ByteBuffer) - Static method in class org.apache.cassandra.utils.CounterId
 
wrap(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.CounterId
 
wrap(byte[]) - Static method in class org.apache.cassandra.utils.MD5Digest
 
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(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.hadoop.ColumnFamilySplit
 
write(byte[]) - Method in class org.apache.cassandra.io.util.AbstractDataOutput
Writes the entire contents of the byte array buffer to this RandomAccessFile starting at the current file pointer.
write(byte[], int, int) - Method in class org.apache.cassandra.io.util.AbstractDataOutput
Writes count bytes from the byte array buffer starting at offset to this RandomAccessFile starting at the current file pointer..
write(int) - Method in class org.apache.cassandra.io.util.AbstractDataOutput
Writes the specified byte oneByte to this RandomAccessFile starting at the current file pointer.
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(MessageOut, String, long, DataOutputStream, int) - 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(String) - Method in class org.apache.cassandra.tools.AbstractJmxClient
 
write(String, Object...) - Method in class org.apache.cassandra.tools.AbstractJmxClient
 
write(ByteBuffer, DataOutput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
write(int) - Method in class org.apache.cassandra.utils.vint.EncodedDataOutputStream
 
write(byte[]) - Method in class org.apache.cassandra.utils.vint.EncodedDataOutputStream
 
write(byte[], int, int) - Method in class org.apache.cassandra.utils.vint.EncodedDataOutputStream
 
write_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
writeBinary(ByteBuffer) - Method in class org.apache.cassandra.thrift.TBinaryProtocol
 
writeBoolean(boolean) - Method in class org.apache.cassandra.io.util.AbstractDataOutput
Writes a boolean to this output stream.
writeByte(int) - Method in class org.apache.cassandra.io.util.AbstractDataOutput
Writes a 8-bit byte to this output stream.
writeBytes(String) - Method in class org.apache.cassandra.io.util.AbstractDataOutput
Writes the low order 8-bit bytes from a String to this output stream.
writeChar(int) - Method in class org.apache.cassandra.io.util.AbstractDataOutput
Writes the specified 16-bit character to the OutputStream.
writeChars(String) - Method in class org.apache.cassandra.io.util.AbstractDataOutput
Writes the specified 16-bit characters contained in str to the OutputStream.
writeCurrentLocalCounterId(CounterId, CounterId, long) - Static method in class org.apache.cassandra.db.SystemTable
Write a new current local node id to the system table.
writeDouble(double) - Method in class org.apache.cassandra.io.util.AbstractDataOutput
Writes a 64-bit double to this output stream.
writeElement(CounterId, long, long, boolean) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
writeElement(CounterId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
writeFloat(float) - Method in class org.apache.cassandra.io.util.AbstractDataOutput
Writes a 32-bit float to this output stream.
writeHeader(CompressionParameters) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
writeHintForMutation(RowMutation, int, InetAddress) - Static method in class org.apache.cassandra.service.StorageProxy
 
writeInt(int) - Method in class org.apache.cassandra.io.util.AbstractDataOutput
Writes a 32-bit int to this output stream.
writeInt(int) - Method in class org.apache.cassandra.utils.vint.EncodedDataOutputStream
 
writeLatency - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Write metrics
writeln(Throwable) - Method in class org.apache.cassandra.tools.AbstractJmxClient
 
writeln(String) - Method in class org.apache.cassandra.tools.AbstractJmxClient
 
writeln(String, Object...) - Method in class org.apache.cassandra.tools.AbstractJmxClient
 
writeLong(long) - Method in class org.apache.cassandra.io.util.AbstractDataOutput
Writes a 64-bit long to this output stream.
writeLong(long) - Method in class org.apache.cassandra.utils.vint.EncodedDataOutputStream
 
writeOpenedMarker(OnDiskAtom, DataOutput, OnDiskAtom.Serializer) - Method in class org.apache.cassandra.db.RangeTombstone.Tracker
Compute RangeTombstone that are needed at the beginning of an index block starting with firstColumn.
WriteResponse - Class in org.apache.cassandra.db
 
WriteResponse() - 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>, Collection<InetAddress>, ConsistencyLevel, Table, Runnable, WriteType) - Constructor for class org.apache.cassandra.service.WriteResponseHandler
 
WriteResponseHandler(InetAddress, WriteType, Runnable) - Constructor for class org.apache.cassandra.service.WriteResponseHandler
 
WriteResponseHandler(InetAddress, WriteType) - 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
 
writeShort(int) - Method in class org.apache.cassandra.io.util.AbstractDataOutput
Writes the specified 16-bit short to the OutputStream.
writeShort(int) - Method in class org.apache.cassandra.utils.vint.EncodedDataOutputStream
 
writeStringList(ChannelBuffer, List<String>) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeStringMap(ChannelBuffer, Map<String, String>) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeStringToStringListMap(ChannelBuffer, Map<String, List<String>>) - Static method in class org.apache.cassandra.transport.CBUtil
 
WriteTimeoutException - Exception in org.apache.cassandra.exceptions
 
WriteTimeoutException(WriteType, ConsistencyLevel, int, int) - Constructor for exception org.apache.cassandra.exceptions.WriteTimeoutException
 
writeTimeouts - Static variable in class org.apache.cassandra.metrics.ClientRequestMetrics
Deprecated.
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.
WriteType - Enum in org.apache.cassandra.db
 
writeType - Variable in exception org.apache.cassandra.exceptions.WriteTimeoutException
 
writeUnavailables - Static variable in class org.apache.cassandra.metrics.ClientRequestMetrics
Deprecated.
writeUTF(String) - Method in class org.apache.cassandra.io.util.AbstractDataOutput
Writes the specified String out in UTF format.
writeValue(Object, ChannelBuffer) - Method in enum org.apache.cassandra.transport.DataType
 
writeValue(Object, ChannelBuffer) - Method in interface org.apache.cassandra.transport.OptionCodec.Codecable
 
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
 
writtenAtom() - Method in class org.apache.cassandra.db.RangeTombstone.Tracker
 
writtenAtomCount() - Method in class org.apache.cassandra.db.ColumnIndex.Builder
 
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 © 2013 The Apache Software Foundation