Skip navigation links
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.cql3.CqlLexer
 
A - Static variable in class org.apache.cassandra.cql3.CqlParser
 
abort(Throwable) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
abort() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
abort(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter
 
abort() - Method in class org.apache.cassandra.streaming.StreamReceiveTask
Abort this task.
abort() - Method in class org.apache.cassandra.streaming.StreamTask
Abort the task.
abort() - Method in class org.apache.cassandra.streaming.StreamTransferTask
 
abort(Throwable) - Method in interface org.apache.cassandra.utils.concurrent.Transactional
 
abort(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
rollback any effects of this transaction object graph; delegates first to doCleanup, then to doAbort
abort() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
 
abortEarly() - Method in interface org.apache.cassandra.utils.btree.UpdateFunction
 
abortEarly() - Method in class org.apache.cassandra.utils.btree.UpdateFunction.NoOp
 
abortTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
Deprecated.
 
abortTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
 
abs(long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
AbstractAllocator - Class in org.apache.cassandra.utils.memory
 
AbstractAllocator() - Constructor for class org.apache.cassandra.utils.memory.AbstractAllocator
 
AbstractBounds<T extends RingPosition<T>> - Class in org.apache.cassandra.dht
 
AbstractBounds(T, T) - Constructor for class org.apache.cassandra.dht.AbstractBounds
 
AbstractBounds.AbstractBoundsSerializer<T extends RingPosition<T>> - Class in org.apache.cassandra.dht
 
AbstractBounds.Boundary<T extends RingPosition<T>> - Class in org.apache.cassandra.dht
 
AbstractBoundsSerializer(IPartitionerDependentSerializer<T>) - Constructor for class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
 
AbstractCell - Class in org.apache.cassandra.db
 
AbstractCell() - Constructor for class org.apache.cassandra.db.AbstractCell
 
AbstractCellNameType - Class in org.apache.cassandra.db.composites
 
AbstractCellNameType(boolean) - Constructor for class org.apache.cassandra.db.composites.AbstractCellNameType
 
AbstractColumnFamilyInputFormat<K,Y> - Class in org.apache.cassandra.hadoop
 
AbstractColumnFamilyInputFormat() - Constructor for class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
 
AbstractCommitLogService - Class in org.apache.cassandra.db.commitlog
 
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<ISSTableScanner>, UUID) - 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
 
AbstractCompactionStrategy.ScannerList - Class in org.apache.cassandra.db.compaction
 
AbstractCompactionTask - Class in org.apache.cassandra.db.compaction
 
AbstractCompactionTask(ColumnFamilyStore, LifecycleTransaction) - Constructor for class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
AbstractComposite - Class in org.apache.cassandra.db.composites
 
AbstractComposite() - Constructor for class org.apache.cassandra.db.composites.AbstractComposite
 
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.ParsedComparator - Interface in org.apache.cassandra.db.marshal
 
AbstractCompoundCellNameType - Class in org.apache.cassandra.db.composites
 
AbstractCompoundCellNameType(CompoundCType, CompoundCType) - Constructor for class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
 
AbstractCType - Class in org.apache.cassandra.db.composites
 
AbstractCType(boolean) - Constructor for class org.apache.cassandra.db.composites.AbstractCType
 
AbstractDataInput - Class in org.apache.cassandra.io.util
 
AbstractDataInput() - Constructor for class org.apache.cassandra.io.util.AbstractDataInput
 
AbstractEndpointSnitch - Class in org.apache.cassandra.locator
 
AbstractEndpointSnitch() - Constructor for class org.apache.cassandra.locator.AbstractEndpointSnitch
 
AbstractFunction - Class in org.apache.cassandra.cql3.functions
Base class for our native/hardcoded functions.
AbstractFunction(FunctionName, List<AbstractType<?>>, AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.functions.AbstractFunction
 
AbstractJmxClient - Class in org.apache.cassandra.tools
 
AbstractJmxClient(String, Integer, String, String) - Constructor for class org.apache.cassandra.tools.AbstractJmxClient
 
AbstractLocalAwareExecutorService - Class in org.apache.cassandra.concurrent
 
AbstractLocalAwareExecutorService() - Constructor for class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
AbstractMarker - Class in org.apache.cassandra.cql3
A single bind marker.
AbstractMarker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.AbstractMarker
 
AbstractMarker.INRaw - Class in org.apache.cassandra.cql3
A raw placeholder for multiple values of the same type for a single column.
AbstractMarker.Raw - Class in org.apache.cassandra.cql3
A parsed, but non prepared, bind marker.
AbstractNativeCell - Class in org.apache.cassandra.db
{@code Packs a CellName AND a Cell into one off-heap representation.
AbstractNativeCell(NativeAllocator, OpOrder.Group, Cell) - Constructor for class org.apache.cassandra.db.AbstractNativeCell
 
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
 
AbstractPaxosCallback<T> - Class in org.apache.cassandra.service.paxos
 
AbstractPaxosCallback(int, ConsistencyLevel) - Constructor for class org.apache.cassandra.service.paxos.AbstractPaxosCallback
 
AbstractRangeCommand - Class in org.apache.cassandra.db
 
AbstractRangeCommand(String, String, long, AbstractBounds<RowPosition>, IDiskAtomFilter, List<IndexExpression>) - Constructor for class org.apache.cassandra.db.AbstractRangeCommand
 
AbstractReadExecutor - Class in org.apache.cassandra.service
Sends a read request to the replicas needed to satisfy a given ConsistencyLevel.
AbstractReplicationStrategy - Class in org.apache.cassandra.locator
A abstract parent for all replication strategies.
AbstractRowResolver - Class in org.apache.cassandra.service
 
AbstractRowResolver(ByteBuffer, String, int) - Constructor for class org.apache.cassandra.service.AbstractRowResolver
 
AbstractScanIterator() - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.AbstractScanIterator
 
AbstractSecureIntializer(Server, EncryptionOptions) - Constructor for class org.apache.cassandra.transport.Server.AbstractSecureIntializer
 
AbstractSignal() - Constructor for class org.apache.cassandra.utils.concurrent.WaitQueue.AbstractSignal
 
AbstractSimpleCellNameType - Class in org.apache.cassandra.db.composites
 
AbstractSimpleCellNameType(AbstractType<?>) - Constructor for class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
 
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
 
AbstractTextSerializer - Class in org.apache.cassandra.serializers
 
AbstractTextSerializer(Charset) - Constructor for class org.apache.cassandra.serializers.AbstractTextSerializer
 
AbstractTransactional() - Constructor for class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
 
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<T> - Class in org.apache.cassandra.service
 
AbstractWriteResponseHandler(Keyspace, Collection<InetAddress>, Collection<InetAddress>, ConsistencyLevel, Runnable, WriteType) - Constructor for class org.apache.cassandra.service.AbstractWriteResponseHandler
 
ACCEPTED_PROTOCOLS - Static variable in class org.apache.cassandra.security.SSLFactory
 
acceptImpl() - Method in class org.apache.cassandra.thrift.TCustomNonblockingServerSocket
 
acceptImpl() - Method in class org.apache.cassandra.thrift.TCustomServerSocket
 
accepts(OpOrder.Group, ReplayPosition) - Method in class org.apache.cassandra.db.Memtable
 
Accumulator<E> - Class in org.apache.cassandra.utils.concurrent
A simple append-only collection supporting an unbounded number of concurrent readers/writers, but a bounded number of items.
Accumulator(int) - Constructor for class org.apache.cassandra.utils.concurrent.Accumulator
 
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
 
acquire(int) - Method in class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
 
acquireReference() - Method in class org.apache.cassandra.tracing.TraceState
 
activate() - Method in class org.apache.cassandra.service.CassandraDaemon
A convenience method to initialize and start the daemon in one shot.
ActiveRepairService - Class in org.apache.cassandra.service
ActiveRepairService is the starting point for manual "active" repairs.
ActiveRepairService(IFailureDetector, Gossiper) - Constructor for class org.apache.cassandra.service.ActiveRepairService
 
ActiveRepairService.ParentRepairSession - Class in org.apache.cassandra.service
We keep a ParentRepairSession around for the duration of the entire repair, for example, on a 256 token vnode rf=3 cluster we would have 768 RepairSession but only one ParentRepairSession.
ActiveRepairService.Status - Enum in org.apache.cassandra.service
Deprecated.
this statuses are from the previous JMX notification service, which will be deprecated on 4.0. For statuses of the new notification service, see StreamEvent.ProgressEvent
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.SEPMetrics
Number of active tasks.
activeTasks - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
Number of active tasks.
add(ByteBuffer) - Method in class org.apache.cassandra.cql3.selection.Selection.ResultSetBuilder
 
add(Cell) - Method in class org.apache.cassandra.cql3.selection.Selection.ResultSetBuilder
 
add(int, ColumnSpecification) - Method in class org.apache.cassandra.cql3.VariableSpecifications
 
add(String, Object) - Method in class org.apache.cassandra.db.CFRowAdder
 
add(OnDiskAtom) - Method in class org.apache.cassandra.db.ColumnIndex.Builder
 
add(Mutation) - Method in class org.apache.cassandra.db.commitlog.CommitLog
Add a Mutation to the commit log.
add(SSTableReader) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
add(ByteBuffer) - Method in interface org.apache.cassandra.db.composites.CBuilder
 
add(Object) - Method in interface org.apache.cassandra.db.composites.CBuilder
 
add(ByteBuffer) - Method in class org.apache.cassandra.db.composites.CompoundCType.CompoundCBuilder
 
add(Object) - Method in class org.apache.cassandra.db.composites.CompoundCType.CompoundCBuilder
 
add(ByteBuffer) - Method in class org.apache.cassandra.db.composites.SimpleCType.SimpleCBuilder
 
add(Object) - Method in class org.apache.cassandra.db.composites.SimpleCType.SimpleCBuilder
 
add(DeletionTime) - Method in class org.apache.cassandra.db.DeletionInfo
Potentially replaces the top-level tombstone with another, keeping whichever has the higher markedForDeleteAt timestamp.
add(RangeTombstone, Comparator<Composite>) - Method in class org.apache.cassandra.db.DeletionInfo
 
add(DeletionInfo) - Method in class org.apache.cassandra.db.DeletionInfo
Combines another DeletionInfo with this one and returns the result.
add(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
add(ColumnIdentifier) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
add(ColumnFamily) - Method in class org.apache.cassandra.db.Mutation
 
add(String, CellName, ByteBuffer, long, int) - Method in class org.apache.cassandra.db.Mutation
 
add(String, CellName, ByteBuffer, long) - Method in class org.apache.cassandra.db.Mutation
 
add(RangeTombstone) - Method in class org.apache.cassandra.db.RangeTombstoneList
 
add(Composite, Composite, long, int) - Method in class org.apache.cassandra.db.RangeTombstoneList
Adds a new range tombstone.
add(AbstractCompactedRow) - Method in class org.apache.cassandra.repair.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(String, String, Map<InetAddress, Float>) - Method in class org.apache.cassandra.tools.nodetool.SetHostStat
 
add(IFilter.FilterKey) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
 
add(IFilter.FilterKey) - Method in class org.apache.cassandra.utils.BloomFilter
 
add(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
add(E) - Method in class org.apache.cassandra.utils.concurrent.Accumulator
Adds an item to the collection.
add(long) - Method in class org.apache.cassandra.utils.EstimatedHistogram
Increments the count of the bucket closest to n, rounding UP.
add(long) - Method in class org.apache.cassandra.utils.HistogramBuilder
 
add(IFilter.FilterKey) - Method in interface org.apache.cassandra.utils.IFilter
 
addAggregate(UDAggregate) - Method in class org.apache.cassandra.config.Schema
 
addAll(ColumnFamily) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
addAll(ColumnFamily) - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
addAll(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamily
Adds all the columns of a given column map to this column map.
addAll(IMutation) - Method in class org.apache.cassandra.db.CounterMutation
 
addAll(IMutation) - Method in interface org.apache.cassandra.db.IMutation
 
addAll(IMutation) - Method in class org.apache.cassandra.db.Mutation
 
addAll(RangeTombstoneList) - Method in class org.apache.cassandra.db.RangeTombstoneList
Adds all the range tombstones of tombstones to this RangeTombstoneList.
addAll(Collection<? extends V>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
addAll(Refs<T>) - Method in class org.apache.cassandra.utils.concurrent.Refs
Merge two sets of references, ensuring only one reference is retained between the two sets
addAll(Iterator<MerkleTree.RowHash>) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
addAllColumnDefinitions(Collection<ColumnDefinition>) - Method in class org.apache.cassandra.config.CFMetaData
 
addAllElementsToAll(List<List<ByteBuffer>>) - Method in class org.apache.cassandra.db.composites.CompositesBuilder
Adds individually each of the specified list of elements to the end of all of the existing composites.
addAllWithSizeDelta(ColumnFamily, MemtableAllocator, OpOrder.Group, SecondaryIndexManager.Updater) - Method in class org.apache.cassandra.db.AtomicBTreeColumns
This is only called by Memtable.resolve, so only AtomicBTreeColumns needs to implement it.
addAncestor(int) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
addAndGetIndex(ColumnDefinition, List<ColumnDefinition>) - Static method in class org.apache.cassandra.cql3.selection.Selectable
 
addApplicationState(ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.EndpointState
 
addApplicationStates(Map<ApplicationState, VersionedValue>) - Method in class org.apache.cassandra.gms.EndpointState
 
addApplicationStates(Set<Map.Entry<ApplicationState, VersionedValue>>) - Method in class org.apache.cassandra.gms.EndpointState
 
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(IAsyncCallback, MessageOut, InetAddress, long, boolean) - Method in class org.apache.cassandra.net.MessagingService
 
addCallback(IAsyncCallback, MessageOut<?>, InetAddress, long, ConsistencyLevel, boolean) - Method in class org.apache.cassandra.net.MessagingService
 
addCandidate(long) - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile.Builder.Boundaries
 
addClassPath(File) - Method in class org.apache.cassandra.triggers.CustomClassLoader
 
addCmdOption(String, String, boolean, String) - Static method in class org.apache.cassandra.tools.AbstractJmxClient
 
addColumn(Cell) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
addColumn(Cell) - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
addColumn(CellName, ByteBuffer, long) - Method in class org.apache.cassandra.db.ColumnFamily
 
addColumn(CellName, ByteBuffer, long, int) - Method in class org.apache.cassandra.db.ColumnFamily
 
addColumn(Cell) - Method in class org.apache.cassandra.db.ColumnFamily
Adds a cell to this cell map.
addColumn(Cell) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
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(Cell) - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
Deprecated.
 
addColumnAlias(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
 
addColumnCount(long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
addColumnDefinition(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
 
addColumnForOrdering(ColumnDefinition) - Method in class org.apache.cassandra.cql3.selection.Selection
 
addColumnMapping(SelectionColumnMapping, ColumnSpecification) - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Record a mapping between the ColumnDefinitions that are used by the selector instances created by this factory and a column in the ResultSet.Metadata returned with a query.
addColumnSpecifications(QueryOptions, List<ColumnSpecification>) - Static method in class org.apache.cassandra.cql3.QueryOptions
 
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.metadata.MetadataCollector
Ratio is compressed/uncompressed and it is if you have 1.x then compression isn't helping
addCondition(ColumnCondition) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
addConditions(Composite, Collection<ColumnCondition>, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
 
addConditions(Composite, CQL3CasRequest, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
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(CellName, long) - Method in class org.apache.cassandra.db.ColumnFamily
 
addCounter(String, CellName, long) - Method in class org.apache.cassandra.db.Mutation
 
addCounter(String, Callable<Integer>) - Method in class org.apache.cassandra.metrics.ClientMetrics
 
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).
addCQL3Column(ColumnIdentifier) - Method in interface org.apache.cassandra.db.composites.CellNameType
 
addCQL3Column(ColumnIdentifier) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellNameType
 
addCQL3Column(ColumnIdentifier) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
addCQL3Column(ColumnIdentifier) - Method in class org.apache.cassandra.db.composites.SimpleDenseCellNameType
 
addCQL3Column(ColumnIdentifier) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellNameType
 
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.Raw, boolean) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
 
addDefinition(ColumnIdentifier, CQL3Type.Raw) - Method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
 
addEachElementToAll(List<ByteBuffer>) - Method in class org.apache.cassandra.db.composites.CompositesBuilder
Adds individually each of the specified elements to the end of all of the existing composites.
added - Variable in class org.apache.cassandra.notifications.SSTableAddedNotification
 
added - Variable in class org.apache.cassandra.notifications.SSTableListChangedNotification
 
addElementToAll(ByteBuffer) - Method in class org.apache.cassandra.db.composites.CompositesBuilder
Adds the specified element to all the composites.
Adder(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Adder
 
Adder(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Adder
 
addErrorListener(ErrorListener) - Method in class org.apache.cassandra.cql3.CqlLexer
 
addErrorListener(ErrorListener) - Method in class org.apache.cassandra.cql3.CqlParser
 
addEventListener(StreamEventHandler) - Method in class org.apache.cassandra.streaming.StreamResultFuture
 
addExist(Composite) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
 
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).
addFailedSnapshot(File) - Static method in class org.apache.cassandra.io.sstable.SnapshotDeletingTask
 
addFalsePositive() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
addFunction(UDFunction) - Method in class org.apache.cassandra.config.Schema
 
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
addIndexExpressionTo(List<IndexExpression>, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQ
 
addIndexExpressionTo(List<IndexExpression>, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.IN
 
addIndexExpressionTo(List<IndexExpression>, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
 
addIndexExpressionTo(List<IndexExpression>, SecondaryIndexManager, QueryOptions) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Adds to the specified list the IndexExpressions corresponding to this Restriction.
addIndexExpressionTo(List<IndexExpression>, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
 
addIndexExpressionTo(List<IndexExpression>, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQ
 
addIndexExpressionTo(List<IndexExpression>, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IN
 
addIndexExpressionTo(List<IndexExpression>, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
 
addIndexExpressionTo(List<IndexExpression>, SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
addInitialSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
addInput(int, List<ByteBuffer>) - Method in interface org.apache.cassandra.cql3.functions.AggregateFunction.Aggregate
Adds the specified input to this aggregate.
addInput(int, Selection.ResultSetBuilder) - Method in class org.apache.cassandra.cql3.selection.Selector
Add the current value from the specified ResultSetBuilder.
addInput(int, Selection.ResultSetBuilder) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
 
Addition(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.Addition
 
addition(UTName, ColumnIdentifier, CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
 
addKey(ByteBuffer) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
addKeyAliases(List<ColumnIdentifier>) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
 
addKeyspace(KSMetaData) - Method in class org.apache.cassandra.config.Schema
 
addKeyValue(ColumnDefinition, Term) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
addLatency(InetAddress, long) - Method in class org.apache.cassandra.net.MessagingService
 
addLeavingEndpoint(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
addListEntry(String, Object) - Method in class org.apache.cassandra.db.CFRowAdder
 
addLocalApplicationState(ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.Gossiper
 
addLocalApplicationStates(List<Pair<ApplicationState, VersionedValue>>) - Method in class org.apache.cassandra.gms.Gossiper
 
addMapEntry(String, Object, Object) - Method in class org.apache.cassandra.db.CFRowAdder
 
addMapping(ColumnSpecification, ColumnDefinition) - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
addMapping(ColumnSpecification, Iterable<ColumnDefinition>) - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
addMessageSink(IMessageSink) - Method in class org.apache.cassandra.net.MessagingService
 
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
addNonSerializedColumn(ColumnSpecification) - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
Adds the specified column which will not be serialized.
addNotExist(Composite) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
 
addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class org.apache.cassandra.streaming.StreamManager
 
addOffset(long) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
addOperation(Operation) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
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
addOrderingColumn(ColumnDefinition) - Method in class org.apache.cassandra.cql3.selection.Selection
 
addOrGet(String) - Method in class org.apache.cassandra.db.Mutation
 
addOrGet(CFMetaData) - Method in class org.apache.cassandra.db.Mutation
 
addOrReplaceColumnDefinition(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
 
addOrReplaceFunction(AbstractFunction) - Static method in class org.apache.cassandra.cql3.functions.Functions
 
addOrUpdateCollection(ColumnIdentifier, CollectionType) - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
addOrUpdateCollection(ColumnIdentifier, CollectionType) - Method in interface org.apache.cassandra.db.composites.CellNameType
Return the new type obtained by adding/updating to the new collection type for the provided column name to this type.
addOrUpdateCollection(ColumnIdentifier, CollectionType) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
addOrUpdateCollection(ColumnIdentifier, CollectionType) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType.WithCollection
 
addPendingRange(Range<Token>, InetAddress) - Method in class org.apache.cassandra.locator.PendingRangeMaps
 
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.MmappedSegmentedFile.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.
addProgressListener(ProgressListener) - Method in class org.apache.cassandra.repair.RepairRunnable
 
addProgressListener(ProgressListener) - Method in class org.apache.cassandra.tracing.TraceState
 
addProgressListener(ProgressListener) - Method in interface org.apache.cassandra.utils.progress.ProgressEventNotifier
Register progress listener to this publisher.
addProgressListener(ProgressListener) - Method in class org.apache.cassandra.utils.progress.ProgressEventNotifierSupport
 
addProperty(String, String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
addProperty(String, Map<String, String>) - Method in class org.apache.cassandra.cql3.statements.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
Add ranges to be streamed for given keyspace.
addRawUpdate(List<Pair<ColumnIdentifier.Raw, Operation.RawUpdate>>, ColumnIdentifier.Raw, Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.CqlParser
 
addReplaceTokens(Collection<Token>, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
address - Variable in class org.apache.cassandra.dht.BootStrapper
 
address - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
 
address - Variable in class org.apache.cassandra.thrift.ThriftServer
 
addRow(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.ResultSet
 
addRow(Object...) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
Adds a new row to the writer.
addRow(List<Object>) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
Adds a new row to the writer.
addRow(Map<String, Object>) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
Adds a new row to the writer.
addRowSize(long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
addRowUpdate(Composite, ModificationStatement, QueryOptions, long) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
 
addSample(T) - Method in class org.apache.cassandra.utils.TopKSampler
 
addSample(T, long, int) - Method in class org.apache.cassandra.utils.TopKSampler
Adds a sample to statistics collection.
addSavedEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
Add an endpoint we knew about previously, but whose state is unknown
addSessionInfo(SessionInfo) - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
addSourceFilter(RangeStreamer.ISourceFilter) - Method in class org.apache.cassandra.dht.RangeStreamer
 
addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
 
addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
addSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
addSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
addStreamRequest(String, Collection<Range<Token>>, Collection<String>, long) - Method in class org.apache.cassandra.streaming.StreamSession
Request data fetch task to this session.
addTable(CFMetaData) - Method in class org.apache.cassandra.config.Schema
 
addTask(AbstractLocalAwareExecutorService.FutureTask<?>) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
addTask(AbstractLocalAwareExecutorService.FutureTask<?>) - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
addTombstone(CellName, ByteBuffer, long) - Method in class org.apache.cassandra.db.ColumnFamily
 
addTombstone(CellName, 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
 
addTransferFile(Ref<SSTableReader>, long, List<Pair<Long, Long>>, long) - Method in class org.apache.cassandra.streaming.StreamTransferTask
 
addTransferFiles(Collection<StreamSession.SSTableStreamingSections>) - Method in class org.apache.cassandra.streaming.StreamSession
 
addTransferRanges(String, Collection<Range<Token>>, Collection<String>, boolean, long) - Method in class org.apache.cassandra.streaming.StreamSession
Set up transfer for specific keyspace/ranges/CFs Used in repair - a streamed sstable in repair will be marked with the given repairedAt time
addTriggerDefinition(TriggerDefinition) - Method in class org.apache.cassandra.config.CFMetaData
 
addTruePositive() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
addType(UserType) - Method in class org.apache.cassandra.config.Schema
 
addType(UserType) - Method in class org.apache.cassandra.config.UTMetaData
 
addUpdateForKey(ColumnFamily, ByteBuffer, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
 
addUpdateForKey(ColumnFamily, ByteBuffer, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
addUpdateForKey(ColumnFamily, ByteBuffer, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
 
addUpdateForKey(ColumnFamily, ByteBuffer, Composite, UpdateParameters, boolean) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
 
adjust(long, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator.SubAllocator
 
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 'removenode' 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
 
AggregateFcts - Class in org.apache.cassandra.cql3.functions
Factory methods for aggregate functions.
AggregateFcts() - Constructor for class org.apache.cassandra.cql3.functions.AggregateFcts
 
AggregateFunction - Interface in org.apache.cassandra.cql3.functions
Performs a calculation on a set of values and return a single value.
AggregateFunction.Aggregate - Interface in org.apache.cassandra.cql3.functions
An aggregation operation.
AGGREGATES - Static variable in class org.apache.cassandra.schema.LegacySchemaTables
 
algorithm - Variable in class org.apache.cassandra.config.EncryptionOptions
 
alias - Variable in class org.apache.cassandra.cql3.selection.RawSelector
 
alive - Variable in exception org.apache.cassandra.exceptions.UnavailableException
 
ALL - Static variable in enum org.apache.cassandra.auth.Permission
 
ALL - Static variable in class org.apache.cassandra.cache.CachingOptions
 
all - Static variable in interface org.apache.cassandra.concurrent.ExecutorLocal
 
all() - Static method in class org.apache.cassandra.cql3.functions.Functions
 
all() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
all() - Static method in class org.apache.cassandra.db.Keyspace
 
all - Static variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Stores all metric names created that can be used when unregistering
all - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics.ColumnFamilyHistogram
 
ALL - Static variable in class org.apache.cassandra.schema.LegacySchemaTables
 
All - Static variable in class org.apache.cassandra.schema.LegacySchemaTables
 
all(WaitQueue.Signal...) - Static method in class org.apache.cassandra.utils.concurrent.WaitQueue
 
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
 
allChannels - Variable in class org.apache.cassandra.transport.Server.ConnectionTracker
 
allColumnFamilyMetrics - Static variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
stores metrics that will be rolled into a single global metric
allColumns() - Method in class org.apache.cassandra.config.CFMetaData
 
allColumnsInSelectOrder() - Method in class org.apache.cassandra.config.CFMetaData
 
allData(IPartitioner) - Static method in class org.apache.cassandra.db.DataRange
 
allIndexesNames() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
allInSameTable(Collection<ColumnSpecification>) - Static method in class org.apache.cassandra.cql3.ColumnSpecification
Returns true if all ColumnSpecifications are in the same table, false otherwise.
allMemtablesLiveDataSize - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Total amount of live data stored in the memtables (2i and pending flush memtables included) that resides off-heap, excluding any data structure overhead
allMemtablesLiveDataSize - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Total amount of live data stored in the memtables (2i and pending flush memtables included) that resides off-heap, excluding any data structure overhead
allMemtablesOffHeapDataSize - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Total amount of data stored in the memtables (2i and pending flush memtables included) that resides off-heap.
allMemtablesOffHeapSize - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Total amount of data stored in the memtables (2i and pending flush memtables included) that resides off-heap.
allMemtablesOnHeapDataSize - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Total amount of data stored in the memtables (2i and pending flush memtables included) that resides on-heap.
allMemtablesOnHeapSize - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Total amount of data stored in the memtables (2i and pending flush memtables included) that resides on-heap.
allocate(Mutation, int) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManager
Reserve space in the current segment for the provided mutation or, if there isn't space available, create a new segment.
allocate(int, int, int) - Static method in class org.apache.cassandra.db.context.CounterContext.ContextState
Allocate a new context big enough for globalCount + localCount + remoteCount elements and return the initial corresponding ContextState.
allocate(int) - Method in enum org.apache.cassandra.io.compress.BufferType
 
allocate(long) - Static method in class org.apache.cassandra.io.util.Memory
 
allocate(int) - Method in class org.apache.cassandra.utils.memory.AbstractAllocator
 
allocate(int) - Method in class org.apache.cassandra.utils.memory.ContextAllocator
 
allocate(int) - Method in class org.apache.cassandra.utils.memory.HeapAllocator
 
allocate(int, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.HeapPool.Allocator
 
allocate(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
allocate(long, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator.SubAllocator
 
allocate(int, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
 
allocate(int, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
 
allocate(int) - Method in class org.apache.cassandra.utils.memory.SlabAllocator
 
allocate(int, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.SlabAllocator
 
allocateBuffer(int, BufferType) - Method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
 
allocateBuffer(int, BufferType) - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
allocated(long) - Method in interface org.apache.cassandra.utils.btree.UpdateFunction
 
allocated(long) - Method in class org.apache.cassandra.utils.btree.UpdateFunction.NoOp
 
allocator - Variable in class org.apache.cassandra.db.commitlog.CommitLog
 
allocator - Static variable in class org.apache.cassandra.transport.CBUtil
 
allocator(OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
 
allocator(OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.SlabAllocator
 
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
 
allowedFunctionName() - Method in class org.apache.cassandra.cql3.CqlParser
 
allowFiltering - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
 
allowIncomingMessage(MessageIn, int) - Method in interface org.apache.cassandra.net.IMessageSink
Allow or drop an incoming message
allowOutgoingMessage(MessageOut, int, InetAddress) - Method in interface org.apache.cassandra.net.IMessageSink
Allow or drop an outgoing message
allPriorOpsAreFinished() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
 
allTypes() - Method in class org.apache.cassandra.db.marshal.TupleType
 
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(UTName, ColumnIdentifier, CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
 
alterableOptions() - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
alterableOptions() - Method in interface org.apache.cassandra.auth.IRoleManager
Subset of supportedOptions that users are allowed to alter when performing ALTER ROLE [themselves].
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
 
alterRole(AuthenticatedUser, RoleResource, RoleOptions) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
alterRole(AuthenticatedUser, RoleResource, RoleOptions) - Method in interface org.apache.cassandra.auth.IRoleManager
Called during execution of ALTER ROLE statement.
alterRoleStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
AlterRoleStatement - Class in org.apache.cassandra.cql3.statements
 
AlterRoleStatement(RoleName, RoleOptions) - Constructor for class org.apache.cassandra.cql3.statements.AlterRoleStatement
 
alterTableStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
AlterTableStatement - Class in org.apache.cassandra.cql3.statements
 
AlterTableStatement(CFName, AlterTableStatement.Type, ColumnIdentifier.Raw, CQL3Type.Raw, CFPropDefs, Map<ColumnIdentifier.Raw, ColumnIdentifier.Raw>, boolean) - Constructor for class org.apache.cassandra.cql3.statements.AlterTableStatement
 
AlterTableStatement.Type - Enum in org.apache.cassandra.cql3.statements
 
alterTypeStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
AlterTypeStatement - Class in org.apache.cassandra.cql3.statements
 
AlterTypeStatement(UTName) - Constructor for class org.apache.cassandra.cql3.statements.AlterTypeStatement
 
alterUserStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
AlwaysPresent - Static variable in class org.apache.cassandra.utils.FilterFactory
 
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.metadata.CompactionMetadata
 
ancestors - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
and(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
announceAggregateDrop(UDAggregate, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceColumnFamilyDrop(String, String) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceColumnFamilyDrop(String, String, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceColumnFamilyUpdate(CFMetaData) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceColumnFamilyUpdate(CFMetaData, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceFunctionDrop(UDFunction, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceKeyspaceDrop(String) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceKeyspaceDrop(String, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceKeyspaceUpdate(KSMetaData) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceKeyspaceUpdate(KSMetaData, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.CreateAggregateStatement
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.CreateFunctionStatement
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.CreateTriggerStatement
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.DropAggregateStatement
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.DropFunctionStatement
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.DropTableStatement
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.DropTypeStatement
 
announceMigration(boolean) - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
Announces the migration to other nodes in the cluster.
announceNewAggregate(UDAggregate, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceNewColumnFamily(CFMetaData) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceNewColumnFamily(CFMetaData, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceNewFunction(UDFunction, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceNewKeyspace(KSMetaData) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceNewKeyspace(KSMetaData, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceNewKeyspace(KSMetaData, long, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceNewType(UserType, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceTypeDrop(UserType) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceTypeDrop(UserType, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
 
announceTypeUpdate(UserType, boolean) - 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
 
AnticompactionCallback(AnticompactionTask) - Constructor for class org.apache.cassandra.repair.AnticompactionTask.AnticompactionCallback
 
AnticompactionRequest - Class in org.apache.cassandra.repair.messages
 
AnticompactionRequest(UUID, Collection<Range<Token>>) - Constructor for class org.apache.cassandra.repair.messages.AnticompactionRequest
 
AnticompactionRequest.AnticompactionRequestSerializer - Class in org.apache.cassandra.repair.messages
 
AnticompactionRequestSerializer() - Constructor for class org.apache.cassandra.repair.messages.AnticompactionRequest.AnticompactionRequestSerializer
 
AnticompactionTask - Class in org.apache.cassandra.repair
 
AnticompactionTask(UUID, InetAddress, Collection<Range<Token>>) - Constructor for class org.apache.cassandra.repair.AnticompactionTask
 
AnticompactionTask.AnticompactionCallback - Class in org.apache.cassandra.repair
Callback for antitcompaction request.
any(WaitQueue.Signal...) - Static method in class org.apache.cassandra.utils.concurrent.WaitQueue
 
append(AbstractCompactedRow) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
Writes a row in an implementation specific way
append(AbstractCompactedRow) - Method in class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
 
append(AbstractCompactedRow) - Method in class org.apache.cassandra.db.compaction.writers.MajorLeveledCompactionWriter
 
append(AbstractCompactedRow) - Method in class org.apache.cassandra.db.compaction.writers.MaxSSTableSizeWriter
 
append(AbstractCompactedRow) - Method in class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
 
append(AbstractCompactedRow) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
append(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
append(AbstractCompactedRow) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
append(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
append(AbstractCompactedRow) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
appendBoundTo(CFMetaData, CompositesBuilder, Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
 
appendBoundTo(CFMetaData, CompositesBuilder, Bound, QueryOptions) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Appends the values of the Restriction for the specified bound to the specified builder.
appendBoundTo(CFMetaData, CompositesBuilder, Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
 
appendBoundTo(CFMetaData, CompositesBuilder, Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
 
appendColumn(Cell) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
Adds a cell, assuming that it sorts *strictly after* the current-last cell in the array.
appendColumn(Cell) - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
appendColumn(Cell) - Method in class org.apache.cassandra.db.ColumnFamily
Appends a cell.
appendDirect(ByteBuffer, boolean) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumWriter
 
Appender(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Lists.Appender
 
appendFromStream(DecoratedKey, CFMetaData, DataInput, Version) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
appendFromStream(DecoratedKey, CFMetaData, DataInput, Version) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
appendTo(CFMetaData, CompositesBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQ
 
appendTo(CFMetaData, CompositesBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.IN
Appends the values of this Restriction to the specified builder.
appendTo(CFMetaData, CompositesBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
 
appendTo(CFMetaData, CompositesBuilder, QueryOptions) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Appends the values of this Restriction to the specified builder.
appendTo(CFMetaData, CompositesBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
 
appendTo(CFMetaData, CompositesBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQ
 
appendTo(CFMetaData, CompositesBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IN
 
appendTo(CFMetaData, CompositesBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
 
appendTo(CFMetaData, CompositesBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
appendTOC(Descriptor, Collection<Component>) - Static method in class org.apache.cassandra.io.sstable.SSTable
Appends new component names to the TOC component.
applicablePermissions() - Method in class org.apache.cassandra.auth.DataResource
 
applicablePermissions() - Method in class org.apache.cassandra.auth.FunctionResource
 
applicablePermissions() - Method in interface org.apache.cassandra.auth.IResource
Returns the set of Permissions that may be applied to this resource Certain permissions are not applicable to particular types of resources.
applicablePermissions() - Method in class org.apache.cassandra.auth.RoleResource
 
ApplicationState - Enum in org.apache.cassandra.gms
 
appliesOnlyToStaticColumns() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
Checks that the modification only apply to static columns.
appliesTo(Composite, ColumnFamily, long) - Method in class org.apache.cassandra.cql3.ColumnCondition.Bound
Validates whether this condition applies to current.
appliesTo(Composite, ColumnFamily, long) - Method in class org.apache.cassandra.cql3.ColumnCondition.CollectionInBound
 
appliesTo(ColumnFamily) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
 
appliesTo(ColumnFamily) - Method in interface org.apache.cassandra.service.CASRequest
Returns whether the provided CF, that represents the values fetched using the readFilter(), match the CAS conditions this object stands for.
appliesToRegularColumns() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
Checks that the modification apply to regular columns.
apply(CFMetaData) - Method in class org.apache.cassandra.config.CFMetaData
Updates CFMetaData in-place to match cfm
apply(ColumnDefinition) - Method in class org.apache.cassandra.config.ColumnDefinition
 
apply(DecoratedKey, ColumnFamily, SecondaryIndexManager.Updater, OpOrder.Group, ReplayPosition) - 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
Applies the counter mutation, returns the result Mutation (for replication to other nodes).
apply(Mutation, boolean) - Method in class org.apache.cassandra.db.Keyspace
 
apply(Mutation, boolean, boolean) - Method in class org.apache.cassandra.db.Keyspace
This method appends a row to the global CommitLog, then updates memtables and indexes.
apply() - Method in class org.apache.cassandra.db.Mutation
 
apply(int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Operator
 
apply(IMutation, Iterable<InetAddress>, AbstractWriteResponseHandler<IMutation>, String, ConsistencyLevel) - Method in interface org.apache.cassandra.service.StorageProxy.WritePerformer
 
apply(V, V) - Method in interface org.apache.cassandra.utils.btree.UpdateFunction
 
apply(V, V) - Method in class org.apache.cassandra.utils.btree.UpdateFunction.NoOp
 
apply(V) - Method in class org.apache.cassandra.utils.btree.UpdateFunction.NoOp
 
applyAddressConfig(Config) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
applyConfig(Config) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
 
applyPropertiesTo(CFMetaData) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
 
applyStateTransition(Message.Type, Message.Type) - Method in class org.apache.cassandra.transport.ServerConnection
 
applyToCFMetadata(CFMetaData) - Method in class org.apache.cassandra.cql3.statements.CFPropDefs
 
applyToChannel(Function<WritableByteChannel, R>) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
applyToChannel(Function<WritableByteChannel, R>) - Method in interface org.apache.cassandra.io.util.DataOutputPlus
Safe way to operate against the underlying channel.
applyToChannel(Function<WritableByteChannel, R>) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
 
applyUnsafe() - Method in class org.apache.cassandra.db.Mutation
 
archivePending - Variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
archiver - Variable in class org.apache.cassandra.db.commitlog.CommitLog
 
areAllNodesAtLeast22() - Method in class org.apache.cassandra.net.MessagingService
 
areRequestedBoundsInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the bounds (start or end) of the clustering columns are inclusive.
argDataTypes - Variable in class org.apache.cassandra.cql3.functions.UDFunction
 
argNames - Variable in class org.apache.cassandra.cql3.functions.UDFunction
 
argNames() - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
args - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithFunction
 
Args() - Constructor for class org.apache.cassandra.thrift.TServerFactory.Args
 
argTypes - Variable in class org.apache.cassandra.cql3.functions.AbstractFunction
 
argTypes() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
argTypes() - Method in interface org.apache.cassandra.cql3.functions.Function
 
argTypes - Variable in exception org.apache.cassandra.exceptions.FunctionExecutionException
 
argTypes - Variable in class org.apache.cassandra.transport.Event.SchemaChange
 
ArrayBackedSortedColumns - Class in org.apache.cassandra.db
A ColumnFamily backed by an array.
ArrayBackedSortedColumns(CFMetaData, boolean) - Constructor for class org.apache.cassandra.db.ArrayBackedSortedColumns
 
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.
asAbstractType() - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
 
asAbstractType() - Method in class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
 
asAbstractType() - Method in class org.apache.cassandra.db.composites.CompoundCType
 
asAbstractType() - Method in interface org.apache.cassandra.db.composites.CType
Returns a AbstractType corresponding to this CType for thrift sake.
asAbstractType() - Method in class org.apache.cassandra.db.composites.SimpleCType
 
asByteBuffer(long, int) - Method in class org.apache.cassandra.io.util.Memory
 
asByteBuffers(long, long) - Method in class org.apache.cassandra.io.util.Memory
 
AsciiSerializer - Class in org.apache.cassandra.serializers
 
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.ByteType
 
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
Deprecated.
 
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.ShortType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.TimestampType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.TimeType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.TupleType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.UserType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.UUIDType
 
asCQLTypeStringList(List<AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.AbstractType
 
asIFilter(SlicePredicate, CFMetaData, ByteBuffer) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
ask() - Method in class org.apache.cassandra.utils.concurrent.Blocker
 
asKSMetadata(String) - Method in class org.apache.cassandra.cql3.statements.KSPropDefs
 
asKSMetadataUpdate(KSMetaData) - Method in class org.apache.cassandra.cql3.statements.KSPropDefs
 
asList() - Method in class org.apache.cassandra.dht.Range
 
asMap() - Method in class org.apache.cassandra.db.ColumnFamily
 
asMap() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
asNativeFunction() - Method in class org.apache.cassandra.cql3.functions.FunctionName
 
Assassinate - Class in org.apache.cassandra.tools.nodetool
 
Assassinate() - Constructor for class org.apache.cassandra.tools.nodetool.Assassinate
 
assassinateEndpoint(String) - Method in class org.apache.cassandra.gms.Gossiper
Do not call this method unless you know what you are doing.
assassinateEndpoint(String) - Method in interface org.apache.cassandra.gms.GossiperMBean
 
assassinateEndpoint(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
AssignmentTestable - Interface in org.apache.cassandra.cql3
 
AssignmentTestable.TestResult - Enum in org.apache.cassandra.cql3
 
assureSufficientLiveNodes(Keyspace, 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
 
asThriftOptions() - Method in class org.apache.cassandra.io.compress.CompressionParameters
 
asType(Descriptor.Type) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
asymmetricColumnComparator(boolean) - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
asymmetricColumnComparator(boolean) - Method in interface org.apache.cassandra.db.composites.CellNameType
 
AsymmetricOrdering<T1,T2> - Class in org.apache.cassandra.utils
 
AsymmetricOrdering() - Constructor for class org.apache.cassandra.utils.AsymmetricOrdering
 
AsymmetricOrdering.Op - Enum in org.apache.cassandra.utils
 
ASYNC - Static variable in class org.apache.cassandra.thrift.ThriftServer
 
AsyncOneResponse<T> - Class in org.apache.cassandra.net
A callback specialized for returning a value from a single target; that is, this is for messages that we only send to one recipient.
AsyncOneResponse() - Constructor for class org.apache.cassandra.net.AsyncOneResponse
 
AsyncRepairCallback - Class in org.apache.cassandra.service
 
AsyncRepairCallback(RowDataResolver, int) - Constructor for class org.apache.cassandra.service.AsyncRepairCallback
 
AtomDeserializer - Class in org.apache.cassandra.db
Helper class to deserialize OnDiskAtom efficiently.
AtomDeserializer(CellNameType, DataInput, ColumnSerializer.Flag, int, Version) - Constructor for class org.apache.cassandra.db.AtomDeserializer
 
atomic_batch_mutate(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
AtomicBTreeColumns - Class in org.apache.cassandra.db
A thread-safe and atomic ISortedColumns implementation.
attach(AbstractCommitLogService, CommitLogSegmentManager) - Method in class org.apache.cassandra.metrics.CommitLogMetrics
 
attach(Connection) - Method in class org.apache.cassandra.transport.Message
 
attempted - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
 
Attributes - Class in org.apache.cassandra.cql3
Utility class for the Parser to gather attributes for modification statements.
Attributes.ExpirationDateOverflowPolicy - Enum in org.apache.cassandra.cql3
 
Attributes.Raw - Class in org.apache.cassandra.cql3
 
attrs - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement
 
attrs - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
 
augment(ByteBuffer, ColumnFamily) - Method in interface org.apache.cassandra.triggers.ITrigger
Called exactly once per CF update, returned mutations are atomically updated.
AuthChallenge - Class in org.apache.cassandra.transport.messages
SASL challenge sent from client to server
AuthChallenge(byte[]) - Constructor for class org.apache.cassandra.transport.messages.AuthChallenge
 
authenticate(InetAddress, int) - Method in class org.apache.cassandra.auth.AllowAllInternodeAuthenticator
 
authenticate(InetAddress, int) - Method in interface org.apache.cassandra.auth.IInternodeAuthenticator
Decides whether or not a peer is allowed to connect to this node.
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
 
AuthKeyspace - Class in org.apache.cassandra.auth
 
AuthKeyspace() - Constructor for class org.apache.cassandra.auth.AuthKeyspace
 
AuthMigrationListener - Class in org.apache.cassandra.auth
MigrationListener implementation that cleans up permissions on dropped resources.
AuthMigrationListener() - Constructor for class org.apache.cassandra.auth.AuthMigrationListener
 
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
Returns a set of permissions of a user on a resource.
authorizer - Variable in class org.apache.cassandra.config.Config
 
AuthResponse - Class in org.apache.cassandra.transport.messages
A SASL token message sent from client to server.
AuthResponse(byte[]) - Constructor for class org.apache.cassandra.transport.messages.AuthResponse
 
AuthSuccess - Class in org.apache.cassandra.transport.messages
Indicates to the client that authentication has succeeded.
AuthSuccess(byte[]) - Constructor for class org.apache.cassandra.transport.messages.AuthSuccess
 
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.IStreamFactory - Interface in org.apache.cassandra.cache
 
AutoSavingCache.Writer - Class in org.apache.cassandra.cache
 
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
 
available() - Method in class org.apache.cassandra.io.util.NIODataInputStream
 
AVAILABLE_RANGES - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
aVeryLongTime - Static variable in class org.apache.cassandra.gms.Gossiper
 
avgFunctionForByte - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
AVG function for byte values (tinyint).
avgFunctionForCounter - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
AVG function for counter column values.
avgFunctionForDecimal - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The AVG function for decimal values.
avgFunctionForDouble - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
AVG function for double values.
avgFunctionForFloat - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
AVG function for float values.
avgFunctionForInt32 - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
AVG function for int32 values.
avgFunctionForLong - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
AVG function for long values.
avgFunctionForShort - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
AVG function for for short values (smallint).
avgFunctionForVarint - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The AVG function for varint values.
await() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
 
await(long, TimeUnit) - Method in class org.apache.cassandra.service.ReadCallback
 
await() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
wait for all operations started prior to issuing the barrier to complete
await() - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
 
await(long, TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
 
await() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue.AbstractSignal
 
await() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
Wait until signalled, or throw an InterruptedException if interrupted before this happens.
awaitCompletion() - Method in class org.apache.cassandra.tools.BootstrapMonitor
 
awaitNanos(long) - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
 
awaitNewBarrier() - Method in class org.apache.cassandra.utils.concurrent.OpOrder
 
awaitTermination(long, TimeUnit) - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
awaitTermination() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
 
awaitTermination() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManager
Returns when the management thread terminates.
awaitTermination(long, TimeUnit) - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
 
awaitUninterruptibly() - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
 
awaitUninterruptibly() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue.AbstractSignal
 
awaitUninterruptibly() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
Wait, without throwing InterruptedException, until signalled.
awaitUntil(Date) - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
 
awaitUntil(long) - Method in class org.apache.cassandra.utils.concurrent.WaitQueue.AbstractSignal
 
awaitUntil(long) - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
Wait until signalled, or the provided time is reached, or the thread is interrupted.

B

B - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
B - Static variable in class org.apache.cassandra.cql3.CqlParser
 
BackgroundActivityMonitor - Class in org.apache.cassandra.utils
 
BackgroundActivityMonitor() - Constructor for class org.apache.cassandra.utils.BackgroundActivityMonitor
 
BackgroundActivityMonitor.BackgroundActivityReporter - Class in org.apache.cassandra.utils
 
BackgroundActivityReporter() - Constructor for class org.apache.cassandra.utils.BackgroundActivityMonitor.BackgroundActivityReporter
 
backlog - Variable in class org.apache.cassandra.thrift.ThriftServer
 
BACKUPS_SUBDIR - Static variable in class org.apache.cassandra.db.Directories
 
badRows - Variable in class org.apache.cassandra.db.compaction.Scrubber.ScrubResult
 
ballot - Variable in class org.apache.cassandra.service.paxos.Commit
 
Barrier() - Constructor for class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
 
BASE_SAMPLING_LEVEL - Static variable in class org.apache.cassandra.io.sstable.Downsampling
The base (down)sampling level determines the granularity at which we can down/upsample.
BASE_TIME_KEY - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
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
 
baseTime - Variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
baseType - Variable in class org.apache.cassandra.db.marshal.ReversedType
 
basic_unreserved_keyword() - Method in class org.apache.cassandra.cql3.CqlParser
 
batch_mutate(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
batch_size_fail_threshold_in_kb - Variable in class org.apache.cassandra.config.Config
 
batch_size_warn_threshold_in_kb - Variable in class org.apache.cassandra.config.Config
 
BATCH_THRESHOLD - Static variable in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Deprecated.
 
BATCHLOG - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
Batchlog - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
batchlog_replay_throttle_in_kb - Variable in class org.apache.cassandra.config.Config
 
BatchlogManager - Class in org.apache.cassandra.db
 
BatchlogManager() - Constructor for class org.apache.cassandra.db.BatchlogManager
 
BatchlogManager.EndpointFilter - Class in org.apache.cassandra.db
 
BatchlogManagerMBean - Interface in org.apache.cassandra.db
 
BatchMessage - Class in org.apache.cassandra.transport.messages
 
BatchMessage(BatchStatement.Type, List<Object>, List<List<ByteBuffer>>, QueryOptions) - Constructor for class org.apache.cassandra.transport.messages.BatchMessage
 
BatchQueryOptions - Class in org.apache.cassandra.cql3
 
BatchQueryOptions(QueryOptions, List<Object>) - Constructor for class org.apache.cassandra.cql3.BatchQueryOptions
 
batchRemoveIterator() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
batchRemoveIterator() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
batchRemoveIterator() - Method in class org.apache.cassandra.db.ColumnFamily
 
BatchRemoveIterator<T> - Interface in org.apache.cassandra.utils
Iterator that allows us to more efficiently remove many items
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(int, BatchStatement.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.
BatchStatement.BatchVariables - Interface in org.apache.cassandra.cql3.statements
 
BatchStatement.Parsed - Class in org.apache.cassandra.cql3.statements
 
BatchStatement.Type - Enum in org.apache.cassandra.cql3.statements
 
batchStatementObjective() - Method in class org.apache.cassandra.cql3.CqlParser
 
batchType - Variable in class org.apache.cassandra.transport.messages.BatchMessage
 
beforeChange(InetAddress, EndpointState, ApplicationState, VersionedValue) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
beforeChange(InetAddress, EndpointState, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.locator.ReconnectableSnitchHelper
 
beforeChange(InetAddress, EndpointState, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.repair.AnticompactionTask
 
beforeChange(InetAddress, EndpointState, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.repair.RepairSession
 
beforeChange(InetAddress, EndpointState, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.ActiveRepairService
 
beforeChange(InetAddress, EndpointState, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
beforeChange(InetAddress, EndpointState, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.StorageService
 
beforeChange(InetAddress, EndpointState, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.streaming.StreamSession
 
beforeClose(Message) - Method in class org.apache.cassandra.thrift.THsHaDisruptorServer
 
beforeExecute(Thread, Runnable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
beforeInvoke(Message) - Method in class org.apache.cassandra.thrift.THsHaDisruptorServer
 
begin(String, Map<String, String>) - Method in class org.apache.cassandra.tracing.Tracing
 
begin(String, InetAddress, 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
 
beginLocalSampling(String, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
beginLocalSampling(String, int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
begin sampling for a specific sampler with a given capacity.
beginSampling(int) - Method in class org.apache.cassandra.utils.TopKSampler
Start to record samples
bf - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
BigFormat - Class in org.apache.cassandra.io.sstable.format.big
Legacy bigtable format
BigIntegerToken(BigInteger) - Constructor for class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
 
BigIntegerToken(String) - Constructor for class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
 
BigTableReader - Class in org.apache.cassandra.io.sstable.format.big
SSTableReaders are open()ed by Keyspace.onStart; after that they are created by SSTableWriter.renameAndOpen.
BigTableScanner - Class in org.apache.cassandra.io.sstable.format.big
 
BigTableScanner.EmptySSTableScanner - Class in org.apache.cassandra.io.sstable.format.big
 
BigTableScanner.KeyScanningIterator - Class in org.apache.cassandra.io.sstable.format.big
 
BigTableWriter - Class in org.apache.cassandra.io.sstable.format.big
 
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
 
binarySearchAsymmetric(List<? extends T1>, T2, AsymmetricOrdering.Op) - Method in class org.apache.cassandra.utils.AsymmetricOrdering
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.ColumnCondition
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Constants.Marker
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.functions.FunctionCall
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Lists.DelayedValue
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Lists.Marker
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Maps.DelayedValue
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Maps.Marker
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Sets.DelayedValue
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Sets.Marker
 
bind(QueryOptions) - Method in interface org.apache.cassandra.cql3.Term
Bind the values in this term to the values contained in values.
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Term.Terminal
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Tuples.DelayedValue
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Tuples.InMarker
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Tuples.Marker
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.UserTypes.DelayedValue
 
bindAndGet(QueryOptions) - Method in class org.apache.cassandra.cql3.Constants.Marker
 
bindAndGet(QueryOptions) - Method in class org.apache.cassandra.cql3.Constants.Value
 
bindAndGet(QueryOptions) - Method in class org.apache.cassandra.cql3.functions.FunctionCall
 
bindAndGet(QueryOptions) - Method in interface org.apache.cassandra.cql3.Term
A shorter for bind(values).get().
bindAndGet(QueryOptions) - Method in class org.apache.cassandra.cql3.Term.NonTerminal
 
bindAndGet(QueryOptions) - Method in class org.apache.cassandra.cql3.Term.Terminal
 
bindAndGet(QueryOptions) - Method in class org.apache.cassandra.cql3.Tuples.DelayedValue
 
bindAndGet(QueryOptions) - Method in class org.apache.cassandra.cql3.UserTypes.DelayedValue
 
bindIndex - Variable in class org.apache.cassandra.cql3.AbstractMarker
 
bindIndex - Variable in class org.apache.cassandra.cql3.AbstractMarker.Raw
 
bindIndex - Variable in class org.apache.cassandra.cql3.Json.Marker
 
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
 
BLANK - Static variable in class org.apache.cassandra.db.ClockAndCount
 
BlobAsVarcharFact - Static variable in class org.apache.cassandra.cql3.functions.BytesConversionFcts
 
block(boolean) - Method in class org.apache.cassandra.utils.concurrent.Blocker
 
Blocker - Class in org.apache.cassandra.utils.concurrent
 
Blocker() - Constructor for class org.apache.cassandra.utils.concurrent.Blocker
 
blockFor(Keyspace) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
blockFor - Variable in exception org.apache.cassandra.exceptions.RequestFailureException
 
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
 
blockUntilFinished() - Method in class org.apache.cassandra.service.PendingRangeCalculatorService
 
BloomCalculations - Class in org.apache.cassandra.utils
The following calculations are taken from: http://www.cs.wisc.edu/~cao/papers/summary-cache/node8.html "Bloom Filters - the math" This class's static methods are meant to facilitate the use of the Bloom Filter class by helping to choose correct values of 'bits per element' and 'number of hash functions, k'.
BloomCalculations() - Constructor for class org.apache.cassandra.utils.BloomCalculations
 
BloomCalculations.BloomSpecification - Class in org.apache.cassandra.utils
A wrapper class that holds two key parameters for a Bloom Filter: the number of hash functions used, and the number of buckets per element used.
BloomFilter - Class in org.apache.cassandra.utils
 
bloomFilterDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Disk space used by bloom filter
bloomFilterDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
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
 
bloomFilterFPChance - Variable in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
 
bloomFilterOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Off heap memory used by bloom filter
bloomFilterOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Off heap memory used by bloom filter
BloomFilterTracker - Class in org.apache.cassandra.io.sstable
 
BloomFilterTracker() - Constructor for class org.apache.cassandra.io.sstable.BloomFilterTracker
 
bloomFilterTracker - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
BloomSpecification(int, int) - Constructor for class org.apache.cassandra.utils.BloomCalculations.BloomSpecification
 
body - Variable in class org.apache.cassandra.cql3.functions.UDFunction
 
body() - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
body - Variable in class org.apache.cassandra.transport.Frame
 
BODY_LENGTH_SIZE - Static variable in class org.apache.cassandra.transport.Frame.Header
 
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
 
BooleanSerializer - Class in org.apache.cassandra.serializers
 
BooleanSerializer() - Constructor for class org.apache.cassandra.serializers.BooleanSerializer
 
BooleanSerializer - Class in org.apache.cassandra.utils
 
BooleanSerializer() - Constructor for class org.apache.cassandra.utils.BooleanSerializer
 
BooleanType - Class in org.apache.cassandra.db.marshal
 
bootReplacing(InetAddress) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
bootstrap(StreamStateStore, boolean) - 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.SystemKeyspace
 
bootstrapInProgress() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
BootstrapMonitor - Class in org.apache.cassandra.tools
 
BootstrapMonitor(PrintStream) - Constructor for class org.apache.cassandra.tools.BootstrapMonitor
 
BootStrapper - Class in org.apache.cassandra.dht
 
BootStrapper(InetAddress, Collection<Token>, TokenMetadata) - Constructor for class org.apache.cassandra.dht.BootStrapper
 
BootStrapper.StringSerializer - Class in org.apache.cassandra.dht
 
bootstrapping(Collection<Token>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
BootstrapResume - Class in org.apache.cassandra.tools.nodetool
 
BootstrapResume() - Constructor for class org.apache.cassandra.tools.nodetool.BootstrapResume
 
Bound(ColumnDefinition, Operator) - Constructor for class org.apache.cassandra.cql3.ColumnCondition.Bound
 
Bound - Enum in org.apache.cassandra.cql3.statements
 
boundaries() - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile.Builder
 
Boundaries() - Constructor for class org.apache.cassandra.io.util.MmappedSegmentedFile.Builder.Boundaries
 
Boundaries(long[], int) - Constructor for class org.apache.cassandra.io.util.MmappedSegmentedFile.Builder.Boundaries
 
Boundary(T, boolean) - Constructor for class org.apache.cassandra.dht.AbstractBounds.Boundary
 
boundary - Variable in class org.apache.cassandra.dht.AbstractBounds.Boundary
 
BoundedComposite - Class in org.apache.cassandra.db.composites
Wraps another Composite and adds an EOC byte to track whether this is a slice start or end.
boundNames - Variable in class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
 
bounds(CFMetaData, Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.Slice
 
bounds(AbstractBounds.Boundary<T>, AbstractBounds.Boundary<T>) - Static method in class org.apache.cassandra.dht.AbstractBounds
 
bounds(T, boolean, T, boolean) - Static method in class org.apache.cassandra.dht.AbstractBounds
 
Bounds<T extends RingPosition<T>> - Class in org.apache.cassandra.dht
AbstractBounds containing both its endpoints: [left, right].
Bounds(T, T) - Constructor for class org.apache.cassandra.dht.Bounds
 
boundsAsComposites(CFMetaData, Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
broadcast_address - Variable in class org.apache.cassandra.config.Config
 
broadcast_rpc_address - Variable in class org.apache.cassandra.config.Config
 
BTree - Class in org.apache.cassandra.utils.btree
 
BTree() - Constructor for class org.apache.cassandra.utils.btree.BTree
 
BTreeSearchIterator<CK,K extends CK,V> - Class in org.apache.cassandra.utils.btree
 
BTreeSearchIterator(Object[], Comparator<CK>) - Constructor for class org.apache.cassandra.utils.btree.BTreeSearchIterator
 
BTreeSet<V> - Class in org.apache.cassandra.utils.btree
 
BTreeSet(Object[], Comparator<V>) - Constructor for class org.apache.cassandra.utils.btree.BTreeSet
 
BTreeSet.BTreeDescRange<V> - Class in org.apache.cassandra.utils.btree
 
BTreeSet.BTreeRange<V> - Class in org.apache.cassandra.utils.btree
 
BUCKET_HIGH_KEY - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
BUCKET_LOW_KEY - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
bucketHigh - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
bucketLow - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
buf - Variable in class org.apache.cassandra.io.util.FastByteArrayInputStream
The byte array containing the bytes to stream over.
buffer() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
buffer - Variable in class org.apache.cassandra.io.util.RandomAccessReader
 
buffer - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
BUFFER_SIZE - Static variable in class org.apache.cassandra.io.util.RandomAccessReader
 
BUFFER_SIZE_IN_MB - Static variable in class org.apache.cassandra.hadoop.BulkRecordWriter
Deprecated.
 
BUFFER_SIZE_IN_MB - Static variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
BufferCell - Class in org.apache.cassandra.db
 
BufferCell(CellName, ByteBuffer) - Constructor for class org.apache.cassandra.db.BufferCell
 
BufferCell(CellName, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.BufferCell
 
BufferCounterCell - Class in org.apache.cassandra.db
 
BufferCounterCell(CellName, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.BufferCounterCell
 
BufferCounterCell(CellName, ByteBuffer, long, long) - Constructor for class org.apache.cassandra.db.BufferCounterCell
 
BufferCounterUpdateCell - Class in org.apache.cassandra.db
 
BufferCounterUpdateCell(CellName, long, long) - Constructor for class org.apache.cassandra.db.BufferCounterUpdateCell
 
BufferCounterUpdateCell(CellName, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.BufferCounterUpdateCell
 
BufferDecoratedKey - Class in org.apache.cassandra.db
 
BufferDecoratedKey(Token, ByteBuffer) - Constructor for class org.apache.cassandra.db.BufferDecoratedKey
 
BufferDeletedCell - Class in org.apache.cassandra.db
 
BufferDeletedCell(CellName, int, long) - Constructor for class org.apache.cassandra.db.BufferDeletedCell
 
BufferDeletedCell(CellName, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.BufferDeletedCell
 
BufferedDataOutputStreamPlus - Class in org.apache.cassandra.io.util
An implementation of the DataOutputStreamPlus interface using a ByteBuffer to stage writes before flushing them to an underlying channel.
BufferedDataOutputStreamPlus(RandomAccessFile) - Constructor for class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
BufferedDataOutputStreamPlus(RandomAccessFile, int) - Constructor for class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
BufferedDataOutputStreamPlus(FileOutputStream) - Constructor for class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
BufferedDataOutputStreamPlus(FileOutputStream, int) - Constructor for class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
BufferedDataOutputStreamPlus(WritableByteChannel) - Constructor for class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
BufferedDataOutputStreamPlus(WritableByteChannel, int) - Constructor for class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
BufferedDataOutputStreamPlus(WritableByteChannel, ByteBuffer) - Constructor for class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
BufferedDataOutputStreamPlus(ByteBuffer) - Constructor for class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
BufferedFileWriterMark(long) - Constructor for class org.apache.cassandra.io.util.SequentialWriter.BufferedFileWriterMark
 
BufferedPoolingSegmentedFile - Class in org.apache.cassandra.io.util
 
BufferedPoolingSegmentedFile(ChannelProxy, long) - Constructor for class org.apache.cassandra.io.util.BufferedPoolingSegmentedFile
 
BufferedPoolingSegmentedFile.Builder - Class in org.apache.cassandra.io.util
 
BufferedRandomAccessFileMark(long) - Constructor for class org.apache.cassandra.io.util.RandomAccessReader.BufferedRandomAccessFileMark
 
BufferedSegmentedFile - Class in org.apache.cassandra.io.util
 
BufferedSegmentedFile(ChannelProxy, long) - Constructor for class org.apache.cassandra.io.util.BufferedSegmentedFile
 
BufferedSegmentedFile.Builder - Class in org.apache.cassandra.io.util
 
BufferExpiringCell - Class in org.apache.cassandra.db
 
BufferExpiringCell(CellName, ByteBuffer, long, int) - Constructor for class org.apache.cassandra.db.BufferExpiringCell
 
BufferExpiringCell(CellName, ByteBuffer, long, int, int) - Constructor for class org.apache.cassandra.db.BufferExpiringCell
 
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
 
bufferSize - Variable in class org.apache.cassandra.hadoop.BulkRecordWriter
Deprecated.
 
bufferSize - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
BufferType - Enum in org.apache.cassandra.io.compress
 
build(int) - Method in class org.apache.cassandra.cql3.selection.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() - Method in class org.apache.cassandra.db.ColumnIndex.Builder
 
build() - Method in interface org.apache.cassandra.db.composites.CBuilder
 
build() - Method in class org.apache.cassandra.db.composites.CompositesBuilder
Builds the Composites.
build() - Method in class org.apache.cassandra.db.composites.CompoundCType.CompoundCBuilder
 
build() - Method in class org.apache.cassandra.db.composites.SimpleCType.SimpleCBuilder
 
build() - Method in class org.apache.cassandra.db.index.SecondaryIndexBuilder
 
build(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.lifecycle.SSTableIntervalTree
 
build(ByteBuffer...) - Static method in class org.apache.cassandra.db.marshal.CompositeType
 
build() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
build() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
 
build(IPartitioner) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
build(IPartitioner, IndexSummaryBuilder.ReadableBoundary) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
build(Collection<V>, Comparator<V>, boolean, UpdateFunction<V>) - Static method in class org.apache.cassandra.utils.btree.BTree
 
build(Iterable<V>, int, Comparator<V>, boolean, UpdateFunction<V>) - Static method in class org.apache.cassandra.utils.btree.BTree
Creates a BTree containing all of the objects in the provided collection
build(Collection<I>) - Static method in class org.apache.cassandra.utils.IntervalTree
 
buildAsEndOfRange() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
buildCasResultSet(String, ByteBuffer, String, ColumnFamily, Iterable<ColumnDefinition>, boolean, QueryOptions) - Static method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
Builder(ColumnFamily, ByteBuffer, DataOutputPlus) - Constructor for class org.apache.cassandra.db.ColumnIndex.Builder
 
Builder(ColumnFamily, ByteBuffer, DataOutputPlus, OnDiskAtom.SerializerForWriting) - Constructor for class org.apache.cassandra.db.ColumnIndex.Builder
 
builder() - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
 
builder() - Method in class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
 
builder() - Method in class org.apache.cassandra.db.composites.CompoundCType
 
builder() - Method in interface org.apache.cassandra.db.composites.CType
A builder of Composite.
builder() - Method in class org.apache.cassandra.db.composites.SimpleCType
 
builder() - Method in class org.apache.cassandra.db.marshal.CompositeType
 
Builder(CompositeType) - Constructor for class org.apache.cassandra.db.marshal.CompositeType.Builder
 
builder() - Static method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
Returns a new builder for a CQLSSTableWriter.
Builder() - Constructor for class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
 
Builder() - Constructor for class org.apache.cassandra.io.util.BufferedPoolingSegmentedFile.Builder
 
Builder() - Constructor for class org.apache.cassandra.io.util.BufferedSegmentedFile.Builder
 
Builder(CompressedSequentialWriter) - Constructor for class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile.Builder
 
Builder(CompressedSequentialWriter) - Constructor for class org.apache.cassandra.io.util.CompressedSegmentedFile.Builder
 
Builder() - Constructor for class org.apache.cassandra.io.util.MmappedSegmentedFile.Builder
 
Builder() - Constructor for class org.apache.cassandra.io.util.SegmentedFile.Builder
 
buildForCompaction(Iterator<OnDiskAtom>) - Method in class org.apache.cassandra.db.ColumnIndex.Builder
The important distinction wrt build() is that we may be building for a row that ends up being compacted away entirely, i.e., the input consists only of expired tombstones (or columns shadowed by expired tombstone).
buildForRelation(Operator) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
buildIndexAsync() - Method in class org.apache.cassandra.db.index.SecondaryIndex
Builds the index using the data in the underlying CF, non blocking
buildIndexBlocking() - Method in class org.apache.cassandra.db.index.SecondaryIndex
Builds the index using the data in the underlying CFS Blocks till it's complete
buildIndexComparator(CFMetaData, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.composites.CompositesIndexIncludingCollectionKey
 
buildIndexComparator(CFMetaData, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
 
buildIndexComparator(CFMetaData, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionValue
 
buildIndexComparator(CFMetaData, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
 
buildIndexComparator(CFMetaData, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
 
buildIntervals(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.lifecycle.SSTableIntervalTree
 
buildPartitionKeyNames(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
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.THsHaDisruptorServer.Factory
 
buildTServer(TServerFactory.Args) - Method in class org.apache.cassandra.thrift.TServerCustomFactory
 
buildTServer(TServerFactory.Args) - Method in interface org.apache.cassandra.thrift.TServerFactory
 
buildValue(ByteBuffer[]) - Static method in class org.apache.cassandra.db.marshal.TupleType
 
buildWith(ByteBuffer) - Method in interface org.apache.cassandra.db.composites.CBuilder
 
buildWith(List<ByteBuffer>) - Method in interface org.apache.cassandra.db.composites.CBuilder
 
buildWith(ByteBuffer) - Method in class org.apache.cassandra.db.composites.CompoundCType.CompoundCBuilder
 
buildWith(List<ByteBuffer>) - Method in class org.apache.cassandra.db.composites.CompoundCType.CompoundCBuilder
 
buildWith(ByteBuffer) - Method in class org.apache.cassandra.db.composites.SimpleCType.SimpleCBuilder
 
buildWith(List<ByteBuffer>) - Method in class org.apache.cassandra.db.composites.SimpleCType.SimpleCBuilder
 
buildWithEOC(Composite.EOC) - Method in class org.apache.cassandra.db.composites.CompositesBuilder
Builds the Composites with the specified EOC.
buildWithStdevRangesAroundMean() - Method in class org.apache.cassandra.utils.HistogramBuilder
buildWithStdevRangesAroundMean(int) - Method in class org.apache.cassandra.utils.HistogramBuilder
Calculate the min, mean, max and standard deviation of the items in the builder, and generate an EstimatedHistogram with upto maxdev stdev size ranges either side of the mean, until min/max are hit; if either min/max are not reached a further range is inserted at the relevant ends.
BUILT_INDEXES - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
BuiltIndexes - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
bulkLoad(String) - Method in class org.apache.cassandra.service.StorageService
 
bulkLoad(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Starts a bulk load and blocks until it completes.
bulkLoadAsync(String) - Method in class org.apache.cassandra.service.StorageService
 
bulkLoadAsync(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Starts a bulk load asynchronously and returns the String representation of the planID for the new streaming session.
BulkLoadConnectionFactory - Class in org.apache.cassandra.tools
 
BulkLoadConnectionFactory(int, int, EncryptionOptions.ServerEncryptionOptions, boolean) - Constructor for class org.apache.cassandra.tools.BulkLoadConnectionFactory
 
BulkLoader - Class in org.apache.cassandra.tools
 
BulkLoader() - Constructor for class org.apache.cassandra.tools.BulkLoader
 
BulkLoader.CmdLineOptions - Class in org.apache.cassandra.tools
 
BulkOutputFormat - Class in org.apache.cassandra.hadoop
Deprecated.
BulkOutputFormat() - Constructor for class org.apache.cassandra.hadoop.BulkOutputFormat
Deprecated.
 
BulkOutputFormat.NullOutputCommitter - Class in org.apache.cassandra.hadoop
Deprecated.
 
BulkRecordWriter - Class in org.apache.cassandra.hadoop
Deprecated.
BulkRecordWriter.ExternalClient - Class in org.apache.cassandra.hadoop
Deprecated.
 
BulkRecordWriter.NullOutputHandler - Class in org.apache.cassandra.hadoop
Deprecated.
 
BYTE_MASK - Static variable in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
ByteBufferDataInput - Class in org.apache.cassandra.io.util
 
ByteBufferDataInput(ByteBuffer, String, long, int) - Constructor for class org.apache.cassandra.io.util.ByteBufferDataInput
 
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
 
ByteOrderedPartitioner.BytesToken - Class in org.apache.cassandra.dht
 
bytes - Variable in class org.apache.cassandra.cql3.ColumnIdentifier
 
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(short) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(long) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
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
BytesConversionFcts - Class in org.apache.cassandra.cql3.functions
 
BytesConversionFcts() - Constructor for class org.apache.cassandra.cql3.functions.BytesConversionFcts
 
ByteSerializer - Class in org.apache.cassandra.serializers
 
ByteSerializer() - Constructor for class org.apache.cassandra.serializers.ByteSerializer
 
bytesOnDisk() - Method in class org.apache.cassandra.io.sstable.SSTable
 
bytesPastMark(FileMark) - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
 
bytesPastMark(FileMark) - Method in interface org.apache.cassandra.io.util.FileDataInput
 
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 class org.apache.cassandra.io.util.ByteBufferDataInput
 
bytesRemaining() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
bytesRemaining() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
BytesSerializer - Class in org.apache.cassandra.serializers
 
BytesSerializer() - Constructor for class org.apache.cassandra.serializers.BytesSerializer
 
bytesToHex(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytesToHex(byte...) - Static method in class org.apache.cassandra.utils.Hex
 
BytesToken(ByteBuffer) - Constructor for class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
BytesToken(byte[]) - Constructor for class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
BytesType - Class in org.apache.cassandra.db.marshal
 
ByteType - Class in org.apache.cassandra.db.marshal
 

C

C - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
C - Static variable in class org.apache.cassandra.cql3.CqlParser
 
CachedHashDecoratedKey - Class in org.apache.cassandra.db
 
CachedHashDecoratedKey(Token, ByteBuffer) - Constructor for class org.apache.cassandra.db.CachedHashDecoratedKey
 
cachedOnlyTokenMap() - Method in class org.apache.cassandra.locator.TokenMetadata
Return a cached TokenMetadata with only tokenToEndpointMap, i.e., the same as cloneOnlyTokenMap but uses a cached copy that is invalided when the ring changes, so in the common case no extra locking is required.
cacheFullPartitions() - Method in class org.apache.cassandra.cache.CachingOptions.RowCache
 
CacheKey - Class in org.apache.cassandra.cache
 
CacheKey(Pair<String, String>) - Constructor for class org.apache.cassandra.cache.CacheKey
 
cacheKey(DecoratedKey, RowIndexEntry) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
CacheKey() - Constructor for class org.apache.cassandra.service.FileCacheService.CacheKey
 
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.
CacheProvider<K,V> - Interface in org.apache.cassandra.cache
 
CacheService - Class in org.apache.cassandra.service
 
CacheService.CacheType - Enum in org.apache.cassandra.service
 
CacheService.CounterCacheSerializer - Class in org.apache.cassandra.service
 
CacheService.KeyCacheSerializer - Class in org.apache.cassandra.service
 
CacheService.RowCacheSerializer - Class in org.apache.cassandra.service
 
CacheServiceMBean - Interface in org.apache.cassandra.service
 
cacheType - Variable in class org.apache.cassandra.cache.AutoSavingCache
 
cacheType() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
 
caching(CachingOptions) - Method in class org.apache.cassandra.config.CFMetaData
 
CachingOptions - Class in org.apache.cassandra.cache
 
CachingOptions(CachingOptions.KeyCache, CachingOptions.RowCache) - Constructor for class org.apache.cassandra.cache.CachingOptions
 
CachingOptions.KeyCache - Class in org.apache.cassandra.cache
 
CachingOptions.KeyCache.Type - Enum in org.apache.cassandra.cache
 
CachingOptions.RowCache - Class in org.apache.cassandra.cache
 
CachingOptions.RowCache.Type - Enum in org.apache.cassandra.cache
 
calculateHintTTL(Mutation) - Static method in class org.apache.cassandra.db.HintedHandOffManager
 
calculateIsDense(AbstractType<?>, Collection<ColumnDefinition>) - Static method in class org.apache.cassandra.config.CFMetaData
 
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) - Method in class org.apache.cassandra.locator.TokenMetadata
Calculate pending ranges according to bootsrapping and leaving nodes.
calculatePendingRanges(AbstractReplicationStrategy, String) - Static method in class org.apache.cassandra.service.PendingRangeCalculatorService
 
calculateSamplingLevel(int, int, long, int, int) - Static method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
calculateSchemaDigest() - Static method in class org.apache.cassandra.schema.LegacySchemaTables
Read schema from system keyspace and calculate MD5 digest of every row, resulting digest will be converted into UUID which would act as content-based version of the schema.
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 keyspace 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
 
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, IAsyncCallback, IVersionedSerializer<?>, boolean) - Constructor for class org.apache.cassandra.net.CallbackInfo
Create CallbackInfo without sent message
calledOnNullInput - Variable in class org.apache.cassandra.cql3.functions.UDFunction
 
canBeNonFrozen() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
cancel(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
remove the reader from the set we're modifying
cancel(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
remove the readers from the set we're modifying
cancel() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
Should only be called by the owning thread.
cancel() - Method in interface org.apache.cassandra.utils.memory.MemtableAllocator.DataReclaimer
 
Candidate(Iterator<In>, Comparator<In>) - Constructor for class org.apache.cassandra.utils.MergeIterator.Candidate
 
canHandleIndexClause(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
 
canLogin(RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
canLogin(RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
Return true if there exists a Role with the given name which has login privileges.
CANONICAL_SSTABLES - Static variable in class org.apache.cassandra.db.ColumnFamilyStore
 
capacity() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
capacity() - Method in interface org.apache.cassandra.cache.ICache
 
capacity() - Method in class org.apache.cassandra.cache.SerializingCache
 
capacity() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
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)
captureWarnings() - Method in class org.apache.cassandra.service.ClientWarn
 
cardinality - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
Default cardinality estimation method is to use HyperLogLog++.
cardinality() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
cardinality - Variable in class org.apache.cassandra.utils.TopKSampler.SamplerResult
 
cardinalityEstimator - Variable in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
 
cas(String, String, ByteBuffer, CASRequest, ConsistencyLevel, ConsistencyLevel, ClientState) - Static method in class org.apache.cassandra.service.StorageProxy
Apply @param updates if and only if the current values in the row for @param key match the provided @param conditions.
cas(ByteBuffer, String, List<Column>, List<Column>, ConsistencyLevel, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
cas_contention_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
CASClientRequestMetrics - Class in org.apache.cassandra.metrics
 
CASClientRequestMetrics(String) - Constructor for class org.apache.cassandra.metrics.CASClientRequestMetrics
 
casCommit - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
CAS Commit metrics
casCommit - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
CAS Commit metrics
casPrepare - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
CAS Prepare metrics
casPrepare - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
CAS Prepare metric
casPropose - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
CAS Propose metrics
casPropose - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
CAS Propose metrics
CASRequest - Interface in org.apache.cassandra.service
Abstract the conditions and updates for a CAS operation.
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
Deprecated.
 
CassandraAuthorizer - Class in org.apache.cassandra.auth
CassandraAuthorizer is an IAuthorizer implementation that keeps user permissions internally in C* using the system_auth.role_permissions 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(boolean) - 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
 
CassandraMetricsRegistry - Class in org.apache.cassandra.metrics
Makes integrating 3.0 metrics API with 2.0.
CassandraMetricsRegistry.JmxCounterMBean - Interface in org.apache.cassandra.metrics
 
CassandraMetricsRegistry.JmxGaugeMBean - Interface in org.apache.cassandra.metrics
 
CassandraMetricsRegistry.JmxHistogramMBean - Interface in org.apache.cassandra.metrics
 
CassandraMetricsRegistry.JmxMeterMBean - Interface in org.apache.cassandra.metrics
 
CassandraMetricsRegistry.JmxTimerMBean - Interface in org.apache.cassandra.metrics
 
CassandraMetricsRegistry.MetricMBean - Interface in org.apache.cassandra.metrics
 
CassandraMetricsRegistry.MetricName - Class in org.apache.cassandra.metrics
A value class encapsulating a metric's owning class and name.
CassandraRoleManager - Class in org.apache.cassandra.auth
Responsible for the creation, maintenance and deletion of roles for the purposes of authentication and authorization.
CassandraRoleManager() - Constructor for class org.apache.cassandra.auth.CassandraRoleManager
 
CassandraServer - Class in org.apache.cassandra.thrift
 
CassandraServer() - Constructor for class org.apache.cassandra.thrift.CassandraServer
 
CassandraStorage - Class in org.apache.cassandra.hadoop.pig
Deprecated.
CassandraStorage() - Constructor for class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
CassandraStorage(int) - Constructor for class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
CassandraStorage.MarshallerType - Enum in org.apache.cassandra.hadoop.pig
Deprecated.
 
cassandraToObj(AbstractType, ByteBuffer, int) - Static method in class org.apache.cassandra.hadoop.pig.StorageHelper
Deprecated.
 
cassandraTriggerDir() - Static method in class org.apache.cassandra.utils.FBUtilities
 
CassandraVersion - Class in org.apache.cassandra.utils
Implements versioning used in Cassandra and CQL.
CassandraVersion(String) - Constructor for class org.apache.cassandra.utils.CassandraVersion
Parse a version from a string.
CBCodec<T> - Interface in org.apache.cassandra.transport
 
CBuilder - Interface in org.apache.cassandra.db.composites
A builder of Composite.
CBUtil - Class in org.apache.cassandra.transport
ByteBuf utility methods.
ceiling(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
Cell - Interface in org.apache.cassandra.db
Cell is immutable, which prevents all kinds of confusion in a multithreaded environment.
cellDataSize() - Method in class org.apache.cassandra.db.AbstractCell
 
cellDataSize() - Method in class org.apache.cassandra.db.BufferCounterCell
 
cellDataSize() - Method in class org.apache.cassandra.db.BufferExpiringCell
 
cellDataSize() - Method in interface org.apache.cassandra.db.Cell
 
cellDataSize() - Method in class org.apache.cassandra.db.NativeCounterCell
 
cellDataSize() - Method in class org.apache.cassandra.db.NativeExpiringCell
 
cellFromByteBuffer(ByteBuffer) - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
cellFromByteBuffer(ByteBuffer) - Method in interface org.apache.cassandra.db.composites.CellNameType
Deserialize a Composite from a ByteBuffer.
cellName - Variable in class org.apache.cassandra.cache.CounterCacheKey
 
CellName - Interface in org.apache.cassandra.db.composites
A CellName is a Composite, but for which, for the sake of CQL3, we distinguish different parts: a CellName has first a number of clustering components, followed by the CQL3 column name, and then possibly followed by a collection element part.
cellName - Variable in class org.apache.cassandra.service.pager.PagingState
 
CellNames - Class in org.apache.cassandra.db.composites
 
CellNameType - Interface in org.apache.cassandra.db.composites
The type of CellNames.
CellNameType.Deserializer - Interface in org.apache.cassandra.db.composites
 
cellSerializer() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
cellSerializer() - Method in interface org.apache.cassandra.db.composites.CellNameType
 
cf - Variable in class org.apache.cassandra.db.CFRowAdder
 
cf - Variable in class org.apache.cassandra.db.Row
 
cf - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics.ColumnFamilyHistogram
 
cfamColumns(CreateTableStatement.RawStatement) - Method in class org.apache.cassandra.cql3.CqlParser
 
cfamDefinition(CreateTableStatement.RawStatement) - Method in class org.apache.cassandra.cql3.CqlParser
 
cfamOrdering(CreateTableStatement.RawStatement) - Method in class org.apache.cassandra.cql3.CqlParser
 
cfamProperty(CreateTableStatement.RawStatement) - Method in class org.apache.cassandra.cql3.CqlParser
 
cfdefFromString(String) - Static method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
convert string back to CfDef
cfdefFromString(String) - Static method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
convert string back to CfDef
cfdefToString(CfDef) - Static method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
convert CfDef to string
cfdefToString(TableMetadata) - Static method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
convert CfDef to string
CfHistograms - Class in org.apache.cassandra.tools.nodetool
Deprecated.
use TableHistograms
CfHistograms() - Constructor for class org.apache.cassandra.tools.nodetool.CfHistograms
Deprecated.
 
cfId - Variable in class org.apache.cassandra.config.CFMetaData
 
cfId - Variable in exception org.apache.cassandra.db.UnknownColumnFamilyException
 
cfId - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
 
cfId - Variable in class org.apache.cassandra.streaming.messages.ReceivedMessage
 
cfId - Variable in class org.apache.cassandra.streaming.messages.RetryMessage
Deprecated.
 
cfId - Variable in class org.apache.cassandra.streaming.StreamReader
 
cfId - Variable in class org.apache.cassandra.streaming.StreamSummary
 
cfId - Variable in class org.apache.cassandra.streaming.StreamTask
 
cfIds - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
 
cfIdSerializedSize(UUID, TypeSizes, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
cfm - Variable in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
The Column Family meta data
cfm - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement
 
cfm - Variable in class org.apache.cassandra.cql3.statements.SelectStatement
 
CFMetaData - Class in org.apache.cassandra.config
This class can be tricky to modify.
CFMetaData(String, String, ColumnFamilyType, CellNameType) - Constructor for class org.apache.cassandra.config.CFMetaData
Create new ColumnFamily metadata with generated random ID.
CFMetaData(String, String, ColumnFamilyType, CellNameType, UUID) - Constructor for class org.apache.cassandra.config.CFMetaData
 
cfMetaData() - Method in class org.apache.cassandra.config.KSMetaData
 
CFMetaData.SpeculativeRetry - Class in org.apache.cassandra.config
 
CFMetaData.SpeculativeRetry.RetryType - 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(CFName) - Method in class org.apache.cassandra.cql3.CqlParser
 
cfName - Variable in class org.apache.cassandra.cql3.statements.CFStatement
 
cfName - Variable in class org.apache.cassandra.db.filter.QueryFilter
 
cfName - Variable in class org.apache.cassandra.db.ReadCommand
 
cfName - Variable in exception org.apache.cassandra.exceptions.AlreadyExistsException
 
cfname - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
CFPropDefs - Class in org.apache.cassandra.cql3.statements
 
CFPropDefs() - Constructor for class org.apache.cassandra.cql3.statements.CFPropDefs
 
CFRowAdder - Class in org.apache.cassandra.db
Convenience object to populate a given CQL3 row in a ColumnFamily object.
CFRowAdder(ColumnFamily, Composite, long) - Constructor for class org.apache.cassandra.db.CFRowAdder
 
CFRowAdder(ColumnFamily, Composite, long, int) - Constructor for class org.apache.cassandra.db.CFRowAdder
 
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.writers.CompactionAwareWriter
 
cfs - Variable in class org.apache.cassandra.db.filter.ExtendedFilter
 
cfs - Variable in class org.apache.cassandra.db.Memtable
 
CFStatement - Class in org.apache.cassandra.cql3.statements
Abstract class for statements that apply on a given column family.
CFStatement(CFName) - Constructor for class org.apache.cassandra.cql3.statements.CFStatement
 
CfStats - Class in org.apache.cassandra.tools.nodetool
Deprecated.
use TableStats
CfStats() - Constructor for class org.apache.cassandra.tools.nodetool.CfStats
Deprecated.
 
cfstore - Variable in class org.apache.cassandra.db.lifecycle.Tracker
 
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
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.CreateAggregateStatement
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.CreateFunctionStatement
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.CreateTriggerStatement
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.DropAggregateStatement
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.DropFunctionStatement
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.DropTableStatement
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.DropTypeStatement
 
changeEvent() - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
 
channel() - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
 
channel() - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
 
channel - Variable in class org.apache.cassandra.io.util.DataOutputStreamPlus
 
channel() - Method in interface org.apache.cassandra.io.util.ICompressedFile
 
channel - Variable in class org.apache.cassandra.io.util.RandomAccessReader
 
channel - Variable in class org.apache.cassandra.io.util.SegmentedFile
 
channel - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
channel() - Method in class org.apache.cassandra.transport.Connection
 
channel - Variable in class org.apache.cassandra.transport.SimpleClient
 
ChannelProxy - Class in org.apache.cassandra.io.util
A proxy of a FileChannel that: - implements reference counting - exports only thread safe FileChannel operations - wraps IO exceptions into runtime exceptions Tested by RandomAccessReaderTest.
ChannelProxy(String) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
 
ChannelProxy(File) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
 
ChannelProxy(String, FileChannel) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
 
ChannelProxy(ChannelProxy) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
 
channelRead0(ChannelHandlerContext, Message.Request) - Method in class org.apache.cassandra.transport.Message.Dispatcher
 
CHAR_MASK - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
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.AlterRoleStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateAggregateStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateFunctionStatement
 
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.CreateRoleStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTriggerStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropAggregateStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropFunctionStatement
 
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.DropRoleStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTableStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTypeStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListRolesStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
 
checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.RoleManagementStatement
 
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
 
checkAndClear() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
atomically: cancels the Signal if !isSet(), or returns true if isSignalled()
checkAvailableDiskSpace() - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
checkBindValueSet(ByteBuffer, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified bind marker value is set to a meaningful value.
checkBounds(long, long) - Method in class org.apache.cassandra.io.util.Memory
 
checkBounds(long, long) - Method in class org.apache.cassandra.io.util.SafeMemory
 
checkContainsNoDuplicates(List<?>, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified list does not contains duplicates.
checkContainsOnly(List<E>, List<E>, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified list contains only the specified elements.
checkDatacenter - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkDataDirs - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkFalse(boolean, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified expression is false.
checkFalse(boolean, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified expression is false.
checkForDuplicateNames(UserType) - Static method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
 
checkForEndpointCollision() - Method in class org.apache.cassandra.service.StorageService
 
checkForExpiredSSTableBlockers(Iterable<SSTableReader>, int) - Static method in class org.apache.cassandra.tools.SSTableExpiredBlockers
 
checkHealth() - Static method in class org.apache.cassandra.db.SystemKeyspace
One of three things will happen if you try to read the system keyspace: 1.
checkJemalloc - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkJMXPorts - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkJnaInitialization - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkNotNull(T, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified object is NOT null.
checkNull(T, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified object is null.
checkNull(T, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified object is null.
checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
Deprecated.
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
Deprecated.
checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Deprecated.
Check for validity of the output-specification for the job.
checkOutputSpecs(Configuration) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Deprecated.
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Deprecated.
checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
Deprecated.
checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
Check for validity of the output-specification for the job.
checkOutputSpecs(Configuration) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
Deprecated.
checkPermission(ClientState, Permission, RoleResource) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
 
checkpoint() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
call when a consistent batch of changes is ready to be made atomically visible these will be exposed in the Tracker atomically, or an exception will be thrown; in this case the transaction should be rolled back
checkRack - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkRemaining(ByteBuffer, int, int) - Static method in class org.apache.cassandra.db.composites.AbstractCType
 
checkSchema(ResourceSchema) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
checkSchema(ResourceSchema) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
checkSSTablesFormat - Static variable in class org.apache.cassandra.service.StartupChecks
 
ChecksummedRandomAccessReader - Class in org.apache.cassandra.io.util
 
ChecksummedRandomAccessReader(File, ChannelProxy, DataIntegrityMetadata.ChecksumValidator) - Constructor for class org.apache.cassandra.io.util.ChecksummedRandomAccessReader
 
ChecksummedRandomAccessReader.CorruptFileException - Exception in org.apache.cassandra.io.util
 
ChecksummedSequentialWriter - Class in org.apache.cassandra.io.util
 
ChecksummedSequentialWriter(File, int, File) - Constructor for class org.apache.cassandra.io.util.ChecksummedSequentialWriter
 
ChecksummedSequentialWriter.TransactionalProxy - Class in org.apache.cassandra.io.util
 
checksumValidator(Descriptor) - Static method in class org.apache.cassandra.io.util.DataIntegrityMetadata
 
ChecksumValidator(Descriptor) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
 
ChecksumValidator(Checksum, RandomAccessReader, String) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
 
ChecksumWriter(DataOutput) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumWriter
 
checkSystemKeyspaceState - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkTrue(boolean, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified expression is true.
checkTrue(boolean, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified expression is true.
checkValidLaunchDate - Static variable in class org.apache.cassandra.service.StartupChecks
 
chooseGroup(String, Class<?>) - Static method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
If the group is empty, use the package name of the given class.
chooseName(String, Method) - Static method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
If name is empty, use the name of the given method.
chooseType(String, Class<?>) - Static method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
If the type is empty, use the simple name of the given class.
Chunk(long, int) - Constructor for class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
 
CHUNK_LENGTH_KB - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
 
CHUNK_SIZE - Static variable in class org.apache.cassandra.streaming.compress.CompressedStreamWriter
 
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
 
chunkSegments() - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
 
chunkSegments() - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
 
chunkSegments() - Method in interface org.apache.cassandra.io.util.ICompressedFile
 
chunkSize - Variable in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
 
chunkStart(long) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
 
cident() - Method in class org.apache.cassandra.cql3.CqlParser
 
cipher_suites - Variable in class org.apache.cassandra.config.EncryptionOptions
 
CIPHER_SUITES - Static variable in class org.apache.cassandra.thrift.SSLTransportFactory
 
CLASS - Static variable in class org.apache.cassandra.config.TriggerDefinition
 
class_name - Variable in class org.apache.cassandra.config.ParameterizedClass
 
classForName(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
classOption - Variable in class org.apache.cassandra.config.TriggerDefinition
 
clean(ByteBuffer) - Static method in class org.apache.cassandra.io.util.FileUtils
 
cleanThreshold - Variable in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
 
Cleanup(ChannelProxy, CompressionMetadata, TreeMap<Long, MappedByteBuffer>) - Constructor for class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile.Cleanup
 
Cleanup(ChannelProxy) - Constructor for class org.apache.cassandra.io.util.PoolingSegmentedFile.Cleanup
 
Cleanup(ChannelProxy) - Constructor for class org.apache.cassandra.io.util.SegmentedFile.Cleanup
 
cleanup() - Method in class org.apache.cassandra.streaming.StreamLockfile
 
Cleanup - Class in org.apache.cassandra.tools.nodetool
 
Cleanup() - Constructor for class org.apache.cassandra.tools.nodetool.Cleanup
 
cleanupCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
cleanupJob(JobContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
Deprecated.
 
cleanupJob(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
 
CleanupMessage - Class in org.apache.cassandra.repair.messages
Message to cleanup repair resources on replica nodes.
CleanupMessage(UUID) - Constructor for class org.apache.cassandra.repair.messages.CleanupMessage
 
CleanupMessage.CleanupMessageSerializer - Class in org.apache.cassandra.repair.messages
 
CleanupMessageSerializer() - Constructor for class org.apache.cassandra.repair.messages.CleanupMessage.CleanupMessageSerializer
 
cleanupOnFailure(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
cleanupOnFailure(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
cleanupOnSuccess(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
cleanupOnSuccess(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
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.AtomicBTreeColumns
 
clear() - Method in class org.apache.cassandra.db.ColumnFamily
Clear this column family, removing all columns and deletion info.
clear(String) - Static method in class org.apache.cassandra.db.Keyspace
 
clear(String, Schema) - Static method in class org.apache.cassandra.db.Keyspace
 
clear() - Method in class org.apache.cassandra.metrics.ClearableHistogram
 
clear() - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
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.btree.BTreeSet
 
clear() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
clear() - Method in interface org.apache.cassandra.utils.IFilter
 
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
 
ClearableHistogram - Class in org.apache.cassandra.metrics
Adds ability to reset a histogram
ClearableHistogram(DecayingEstimatedHistogramReservoir) - Constructor for class org.apache.cassandra.metrics.ClearableHistogram
Creates a new Histogram with the given reservoir.
clearAllLocal(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Remove all the local of a context (but keep global).
clearCallbacksUnsafe() - Method in class org.apache.cassandra.net.MessagingService
 
clearEphemeralSnapshots(Directories) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
clearInternalStatementsCache() - Static method in class org.apache.cassandra.cql3.QueryProcessor
Clear our internal statmeent cache for test purposes.
clearKeyspaceDefinition(KSMetaData) - Method in class org.apache.cassandra.config.Schema
Remove keyspace definition from system
clearMessageSinks() - Method in class org.apache.cassandra.net.MessagingService
 
clearSizeEstimates(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
Clears size estimates for a table (on table drop)
clearSnapshot(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Clear all the snapshots for a given column family.
clearSnapshot(String, List<File>) - Static method in class org.apache.cassandra.db.Directories
 
clearSnapshot(String, String) - Static method in class org.apache.cassandra.db.Keyspace
Clear all the snapshots for a given keyspace.
clearSnapshot(String, String...) - Method in class org.apache.cassandra.service.StorageService
Remove the snapshot with the given name from the given keyspaces.
clearSnapshot(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Remove the snapshot with the given name from the given keyspaces.
clearSnapshot(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
Remove all the existing snapshots.
ClearSnapshot - Class in org.apache.cassandra.tools.nodetool
 
ClearSnapshot() - Constructor for class org.apache.cassandra.tools.nodetool.ClearSnapshot
 
clearSSTableReadMeter(String, String, int) - Static method in class org.apache.cassandra.db.SystemKeyspace
Clears persisted read rates from system.sstable_activity for SSTables that have been deleted.
clearUnsafe() - Method in class org.apache.cassandra.db.ColumnFamilyStore
For testing.
clearUnsafe() - Method in class org.apache.cassandra.locator.TokenMetadata
used by tests
CLibrary - Class in org.apache.cassandra.utils
 
Client() - Constructor for class org.apache.cassandra.io.sstable.SSTableLoader.Client
 
Client - Class in org.apache.cassandra.transport
 
Client(String, int, int, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.Client
 
client_encryption_options - Variable in class org.apache.cassandra.config.Config
 
ClientEncryptionOptions() - Constructor for class org.apache.cassandra.config.EncryptionOptions.ClientEncryptionOptions
 
ClientMetrics - Class in org.apache.cassandra.metrics
 
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(InetSocketAddress) - Constructor for class org.apache.cassandra.service.ClientState
 
ClientWarn - Class in org.apache.cassandra.service
 
ClientWarn.State - Class in org.apache.cassandra.service
 
clientWarnState - Variable in class org.apache.cassandra.concurrent.ExecutorLocals
 
clock - Variable in class org.apache.cassandra.db.ClockAndCount
 
ClockAndCount - Class in org.apache.cassandra.db
 
clone(AbstractAllocator) - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
clone() - Method in class org.apache.cassandra.db.commitlog.ReplayPosition
 
clone(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
clone(ByteBuffer) - Method in class org.apache.cassandra.utils.memory.AbstractAllocator
Allocate a slice of the given length.
clone(ByteBuffer) - Method in class org.apache.cassandra.utils.memory.ContextAllocator
 
clone(Cell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
 
clone(CounterCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
 
clone(DeletedCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
 
clone(ExpiringCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
 
clone(DecoratedKey, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
 
clone(Cell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
 
clone(CounterCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
 
clone(DeletedCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
 
clone(ExpiringCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
 
clone(DecoratedKey, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
 
clone(Cell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
 
clone(CounterCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
 
clone(DeletedCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
 
clone(ExpiringCell, CFMetaData, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
 
clone(DecoratedKey, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
 
cloneAfterAllLeft() - Method in class org.apache.cassandra.locator.TokenMetadata
Create a copy of TokenMetadata with tokenToEndpointMap reflecting situation after all current leave operations have finished.
cloneAfterAllSettled() - Method in class org.apache.cassandra.locator.TokenMetadata
Create a copy of TokenMetadata with tokenToEndpointMap reflecting situation after all current leave, and move operations have finished.
cloneMe() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
cloneMe() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
cloneMe() - Method in class org.apache.cassandra.db.ColumnFamily
Clones the column map.
cloneMeShallow(ColumnFamily.Factory<T>, boolean) - Method in class org.apache.cassandra.db.ColumnFamily
 
cloneMeShallow() - Method in class org.apache.cassandra.db.ColumnFamily
 
cloneMeShallow(boolean) - Method in class org.apache.cassandra.db.ColumnFamily
 
cloneOnlyTokenMap() - Method in class org.apache.cassandra.locator.TokenMetadata
Create a copy of TokenMetadata with only tokenToEndpointMap.
cloneShallow() - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
 
cloneShallow() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
cloneShallow() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
cloneWith(Iterable<CFMetaData>, UTMetaData) - Method in class org.apache.cassandra.config.KSMetaData
 
cloneWithHigherVersion(VersionedValue) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
cloneWithNewStart(DecoratedKey, Runnable) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
cloneWithNewSummarySamplingLevel(ColumnFamilyStore, int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Returns a new SSTableReader with the same properties as this SSTableReader except that a new IndexSummary will be built at the target samplingLevel.
cloneWithTableAdded(CFMetaData) - Method in class org.apache.cassandra.config.KSMetaData
 
cloneWithTableRemoved(CFMetaData) - Method in class org.apache.cassandra.config.KSMetaData
 
close() - Method in class org.apache.cassandra.cache.RefCountedMemory
 
close() - Method in class org.apache.cassandra.db.ColumnFamilyStore.RefViewFragment
 
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.compaction.AbstractCompactionStrategy.ScannerList
 
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.Scrubber
 
close() - Method in class org.apache.cassandra.db.compaction.Verifier
 
close(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkRecordWriter
Deprecated.
 
close(Reporter) - Method in class org.apache.cassandra.hadoop.BulkRecordWriter
Deprecated.
close() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
Deprecated.
 
close(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
close(Reporter) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
Deprecated.
close() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
close() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
 
close() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
Close this writer.
close() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
close() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
 
close() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
close() - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
close(Throwable) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
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.SSTableSimpleUnsortedWriter
Deprecated.
 
close() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleWriter
Deprecated.
 
close() - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
close() - Method in class org.apache.cassandra.io.util.ChecksummedRandomAccessReader
 
close() - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
 
close() - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.FileDigestValidator
 
close() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
close() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
Closes this stream and frees resources associated with 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.Memory
 
close() - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
close() - Method in class org.apache.cassandra.io.util.NIODataInputStream
 
close() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
close() - Method in class org.apache.cassandra.io.util.SafeMemory
 
close(Throwable) - Method in class org.apache.cassandra.io.util.SafeMemory
 
close() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
close(Throwable) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
close(Throwable) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
 
close() - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
 
close() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
close() - Method in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
 
close() - Method in class org.apache.cassandra.net.IncomingStreamingConnection
 
close() - Method in class org.apache.cassandra.net.IncomingTcpConnection
 
close() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
close() - Method in class org.apache.cassandra.streaming.ConnectionHandler
 
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(Throwable) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
 
close() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
To be called exactly once for each register() call this object is returned for, indicating the operation is complete
close() - Method in class org.apache.cassandra.utils.concurrent.Ref
 
close() - Method in class org.apache.cassandra.utils.concurrent.Refs
close(Throwable) - Method in interface org.apache.cassandra.utils.concurrent.SharedCloseable
 
close() - Method in class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
 
close(Throwable) - Method in class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
 
close() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
 
close() - Method in interface org.apache.cassandra.utils.IFilter
 
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 interface org.apache.cassandra.utils.obs.IBitSet
 
close() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
close() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
close(Throwable, Iterable<? extends AutoCloseable>) - Static method in class org.apache.cassandra.utils.Throwables
 
CloseableIterator<T> - Interface in org.apache.cassandra.utils
 
closeableIterator(Iterator<T>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
closeAll() - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
 
closed - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
closeIncoming() - Method in class org.apache.cassandra.streaming.ConnectionHandler
 
closeOutgoing() - Method in class org.apache.cassandra.streaming.ConnectionHandler
 
closeQuietly(Closeable) - Static method in class org.apache.cassandra.io.util.FileUtils
 
CloudstackSnitch - Class in org.apache.cassandra.locator
A snitch that assumes a Cloudstack Zone follows the typical convention <country>-<location>-<availability zone> and uses the country/location tuple as a datacenter and the availability zone as a rack
CloudstackSnitch() - Constructor for class org.apache.cassandra.locator.CloudstackSnitch
 
cluster_name - Variable in class org.apache.cassandra.config.Config
 
clusteringColumns() - Method in class org.apache.cassandra.config.CFMetaData
 
clusteringKeyDef(CFMetaData, ByteBuffer, AbstractType<?>, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
clusteringPrefixSize() - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
 
clusteringPrefixSize() - Method in interface org.apache.cassandra.db.composites.CellNameType
The number of clustering columns for the table this is the type of.
clusteringPrefixSize() - Method in class org.apache.cassandra.db.composites.SimpleDenseCellNameType
 
clusteringPrefixSize() - Method in class org.apache.cassandra.db.composites.SimpleSparseCellNameType
 
clusteringRestrictionsNeedFiltering() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
clusteringSize() - Method in class org.apache.cassandra.db.AbstractNativeCell
 
clusteringSize - Variable in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
 
clusteringSize() - Method in interface org.apache.cassandra.db.composites.CellName
The number of clustering components.
clusteringSize() - Method in class org.apache.cassandra.db.composites.CompoundDenseCellName
 
clusteringSize() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
 
clusteringSize() - Method in class org.apache.cassandra.db.composites.SimpleDenseCellName
 
clusteringSize() - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
 
clusteringType - Variable in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
 
CmdLineOptions() - Constructor for class org.apache.cassandra.tools.BulkLoader.CmdLineOptions
 
coalesce(BlockingQueue<C>, List<C>, int) - Method in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
Drain from the input blocking queue to the output list up to maxItems elements.
coalesceInternal(BlockingQueue<C>, List<C>, int) - Method in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
 
CoalescingStrategies - Class in org.apache.cassandra.utils
 
CoalescingStrategies() - Constructor for class org.apache.cassandra.utils.CoalescingStrategies
 
CoalescingStrategies.Coalescable - Interface in org.apache.cassandra.utils
 
CoalescingStrategies.CoalescingStrategy - Class in org.apache.cassandra.utils
 
CoalescingStrategy(CoalescingStrategies.Parker, Logger, String) - Constructor for class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
 
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 - Variable in enum org.apache.cassandra.streaming.ProgressInfo.Direction
 
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.QueryOptions
 
codec - Static variable in class org.apache.cassandra.cql3.ResultSet
 
Codec() - Constructor for class org.apache.cassandra.cql3.ResultSet.Codec
 
codec - Static variable in class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
 
codec - Static variable in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
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.AuthChallenge
 
codec - Static variable in class org.apache.cassandra.transport.messages.AuthenticateMessage
 
codec - Static variable in class org.apache.cassandra.transport.messages.AuthResponse
 
codec - Static variable in class org.apache.cassandra.transport.messages.AuthSuccess
 
codec - Static variable in class org.apache.cassandra.transport.messages.BatchMessage
 
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 Iterator<Cell>>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
collateColumns(ColumnFamily, List<? extends Iterator<Cell>>, IDiskAtomFilter, DecoratedKey, int, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
 
collateOnDiskAtom(ColumnFamily, List<? extends Iterator<? extends OnDiskAtom>>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
collateOnDiskAtom(ColumnFamily, List<? extends Iterator<? extends OnDiskAtom>>, IDiskAtomFilter, DecoratedKey, int, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
 
collateOnDiskAtom(ColumnFamily, Iterator<? extends OnDiskAtom>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
CollationController - Class in org.apache.cassandra.db
 
CollationController(ColumnFamilyStore, QueryFilter, int) - Constructor for class org.apache.cassandra.db.CollationController
 
Collection(CollectionType) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Collection
 
collection_type() - Method in class org.apache.cassandra.cql3.CqlParser
 
collectionColumns(CellName, ColumnFamily, long) - Method in class org.apache.cassandra.cql3.ColumnCondition.Bound
 
collectionCondition(Term.Raw, Term.Raw, Operator) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
A condition on a collection element.
collectionElement() - Method in class org.apache.cassandra.db.AbstractNativeCell
 
collectionElement() - Method in interface org.apache.cassandra.db.composites.CellName
The value of the collection element, or null if the cell is not part of a collection (i.e.
collectionElement() - Method in class org.apache.cassandra.db.composites.CompoundDenseCellName
 
collectionElement() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
 
collectionElement() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName.WithCollection
 
collectionElement() - Method in class org.apache.cassandra.db.composites.SimpleDenseCellName
 
collectionElement() - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
 
collectionInCondition(Term.Raw, List<Term.Raw>) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
An IN condition on a collection element.
collectionInCondition(Term.Raw, AbstractMarker.INRaw) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
An IN condition on a collection element with a single marker.
collectionLiteral() - Method in class org.apache.cassandra.cql3.CqlParser
 
CollectionSerializer<T> - Class in org.apache.cassandra.serializers
 
CollectionSerializer() - Constructor for class org.apache.cassandra.serializers.CollectionSerializer
 
collectionType() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
collectionType() - Method in interface org.apache.cassandra.db.composites.CellNameType
The type of the collections (or null if the type does not have any non-frozen collections).
collectionType() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType.WithCollection
 
CollectionType<T> - Class in org.apache.cassandra.db.marshal
The abstract validator that is the base for maps, sets and lists (both frozen and non-frozen).
CollectionType(CollectionType.Kind) - Constructor for class org.apache.cassandra.db.marshal.CollectionType
 
CollectionType.Kind - Enum in org.apache.cassandra.db.marshal
 
collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.AbstractMarker
 
collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Attributes
 
collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.ColumnCondition
Collects the column specification for the bind variables of this operation.
collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.functions.FunctionCall
 
collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Lists.DelayedValue
 
collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Lists.SetterByIndex
 
collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Maps.DelayedValue
 
collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Maps.SetterByKey
 
collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Operation
Collects the column specification for the bind variables of this operation.
collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Sets.DelayedValue
 
collectMarkerSpecification(VariableSpecifications) - Method in interface org.apache.cassandra.cql3.Term
Collects the column specification for the bind variables in this Term.
collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Term.Terminal
 
collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Tuples.DelayedValue
 
collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.UserTypes.DelayedValue
 
collectReducedColumns(ColumnFamily, Iterator<Cell>, DecoratedKey, int, long) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
collects columns from reducedColumns into returnCF.
collectReducedColumns(ColumnFamily, Iterator<Cell>, DecoratedKey, int, long) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
collectReducedColumns(ColumnFamily, Iterator<Cell>, DecoratedKey, int, long) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
column - Variable in class org.apache.cassandra.cql3.ColumnCondition.Bound
 
column - Variable in class org.apache.cassandra.cql3.ColumnCondition
 
column - Variable in class org.apache.cassandra.cql3.Operation
 
column - Variable in class org.apache.cassandra.cql3.statements.IndexTarget
 
column - Variable in class org.apache.cassandra.db.IndexExpression
 
column_family - Variable in class org.apache.cassandra.db.SnapshotCommand
 
column_family - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
column_family - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
column_index_size_in_kb - Variable in class org.apache.cassandra.config.Config
 
columnComparator(boolean) - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
columnComparator(boolean) - Method in interface org.apache.cassandra.db.composites.CellNameType
 
ColumnCondition - Class in org.apache.cassandra.cql3
A CQL3 condition on the value of a column or collection element.
columnCondition(List<Pair<ColumnIdentifier.Raw, ColumnCondition.Raw>>) - Method in class org.apache.cassandra.cql3.CqlParser
 
ColumnCondition.Bound - Class in org.apache.cassandra.cql3
 
ColumnCondition.CollectionInBound - Class in org.apache.cassandra.cql3
 
ColumnCondition.Raw - Class in org.apache.cassandra.cql3
 
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(long) - Constructor for class org.apache.cassandra.db.filter.ColumnCounter
 
columnCounter(CellNameType, long) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
 
columnCounter(CellNameType, long) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
columnCounter(CellNameType, long) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
columnCounter() - Method in class org.apache.cassandra.service.pager.NamesQueryPager
 
columnCounter() - Method in interface org.apache.cassandra.service.pager.SinglePartitionPager
 
ColumnCounter.GroupByPrefix - Class in org.apache.cassandra.db.filter
 
ColumnCounter.GroupByPrefixReversed - Class in org.apache.cassandra.db.filter
Similar to GroupByPrefix, but designed to handle counting cells in reverse order.
columnDef - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
The definition of the column to which apply the restriction.
columnDef - Variable in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
ColumnDefinition - Class in org.apache.cassandra.config
 
ColumnDefinition(CFMetaData, ByteBuffer, AbstractType<?>, Integer, ColumnDefinition.Kind) - Constructor for class org.apache.cassandra.config.ColumnDefinition
 
ColumnDefinition(String, String, ColumnIdentifier, AbstractType<?>, IndexType, Map<String, String>, String, Integer, ColumnDefinition.Kind) - Constructor for class org.apache.cassandra.config.ColumnDefinition
 
ColumnDefinition.Kind - Enum in org.apache.cassandra.config
 
columnDefs - Variable in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
The columns to which the restriction apply.
columnDefs - Variable in class org.apache.cassandra.cql3.restrictions.TokenRestriction
The definition of the columns to which apply the token restriction.
columnDefs - Variable in class org.apache.cassandra.db.index.SecondaryIndex
The column definitions which this index is responsible for
ColumnDeletion(ColumnIdentifier.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.ColumnDeletion
 
COLUMNFAMILIES - Static variable in class org.apache.cassandra.schema.LegacySchemaTables
 
columnFamilies - Variable in class org.apache.cassandra.streaming.StreamRequest
 
COLUMNFAMILIES_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
columnFamily() - Method in class org.apache.cassandra.cql3.statements.CFStatement
 
columnFamily() - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
 
columnFamily() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
columnFamily() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
columnFamily - Variable in class org.apache.cassandra.db.AbstractRangeCommand
 
ColumnFamily - Class in org.apache.cassandra.db
A sorted map of columns.
ColumnFamily(CFMetaData) - Constructor for class org.apache.cassandra.db.ColumnFamily
 
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.repair.RepairJobDesc
 
ColumnFamily.Factory<T extends ColumnFamily> - Class in org.apache.cassandra.db
 
ColumnFamilyInputFormat - Class in org.apache.cassandra.hadoop
Deprecated.
ColumnFamilyInputFormat() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
Deprecated.
 
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.
ColumnFamilyMetrics.ColumnFamilyHistogram - Class in org.apache.cassandra.metrics
 
ColumnFamilyMetrics.Sampler - Enum in org.apache.cassandra.metrics
 
columnFamilyName() - Method in class org.apache.cassandra.cql3.CqlParser
 
ColumnFamilyOutputFormat - Class in org.apache.cassandra.hadoop
Deprecated.
ColumnFamilyOutputFormat() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Deprecated.
 
ColumnFamilyRecordReader - Class in org.apache.cassandra.hadoop
Deprecated.
ColumnFamilyRecordReader() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
Deprecated.
 
ColumnFamilyRecordReader(int) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
Deprecated.
 
ColumnFamilyRecordReader.Column - Class in org.apache.cassandra.hadoop
Deprecated.
 
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(Keyspace, String, IPartitioner, int, CFMetaData, Directories, boolean) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore
 
ColumnFamilyStore(Keyspace, String, IPartitioner, int, CFMetaData, Directories, boolean, boolean) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore
 
ColumnFamilyStore.AbstractScanIterator - Class in org.apache.cassandra.db
 
ColumnFamilyStore.FlushLargestColumnFamily - Class in org.apache.cassandra.db
Finds the largest memtable, as a percentage of *either* on- or off-heap memory limits, and immediately queues it for flushing.
ColumnFamilyStore.RefViewFragment - Class in org.apache.cassandra.db
 
ColumnFamilyStore.ViewFragment - Class in org.apache.cassandra.db
 
ColumnFamilyStoreMBean - Interface in org.apache.cassandra.db
The MBean interface for ColumnFamilyStore
ColumnFamilyType - Enum in org.apache.cassandra.db
column family type enum
columnFilter - Variable in class org.apache.cassandra.db.DataRange
 
columnFilter(ByteBuffer) - Method in class org.apache.cassandra.db.DataRange
Returns a column filter that should be used for a particular row key.
columnFilter(ByteBuffer) - Method in class org.apache.cassandra.db.DataRange.Paging
 
columnFilter(ByteBuffer) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
 
columnFilter(ByteBuffer) - Method in class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
 
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
 
ColumnIdentifier(ByteBuffer, String) - Constructor for class org.apache.cassandra.cql3.ColumnIdentifier
 
ColumnIdentifier.Raw - Class in org.apache.cassandra.cql3
Because Thrift-created tables may have a non-text comparator, we cannot determine the proper 'key' until we know the comparator.
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.
columnName - Variable in class org.apache.cassandra.db.composites.CompoundSparseCellName
 
ColumnNameHelper - Class in org.apache.cassandra.io.sstable
 
ColumnNameHelper() - Constructor for class org.apache.cassandra.io.sstable.ColumnNameHelper
 
columnOperation(List<Pair<ColumnIdentifier.Raw, Operation.RawUpdate>>) - Method in class org.apache.cassandra.cql3.CqlParser
 
columnOperationDifferentiator(List<Pair<ColumnIdentifier.Raw, Operation.RawUpdate>>, ColumnIdentifier.Raw) - Method in class org.apache.cassandra.cql3.CqlParser
 
columnReverseComparator() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
columnReverseComparator() - Method in interface org.apache.cassandra.db.composites.CellNameType
 
columns - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow.Reducer
 
columns - Variable in class org.apache.cassandra.db.filter.NamesQueryFilter
 
columns - Variable in class org.apache.cassandra.db.index.SecondaryIndexSearcher
 
COLUMNS - Static variable in class org.apache.cassandra.schema.LegacySchemaTables
 
ColumnSerializer - Class in org.apache.cassandra.db
 
ColumnSerializer(CellNameType) - Constructor for class org.apache.cassandra.db.ColumnSerializer
 
columnSerializer() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
columnSerializer() - Method in interface org.apache.cassandra.db.composites.CellNameType
 
ColumnSerializer.CorruptColumnException - Exception in org.apache.cassandra.db
 
ColumnSerializer.Flag - Enum in org.apache.cassandra.db
Flag affecting deserialization behavior.
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(Composite, Composite) - Constructor for class org.apache.cassandra.db.filter.ColumnSlice
 
ColumnSlice.Serializer - Class in org.apache.cassandra.db.filter
 
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 - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
columnStats() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
ColumnStats - Class in org.apache.cassandra.io.sstable
ColumnStats holds information about the columns for one row inside sstable
ColumnStats(int, long, long, int, StreamingHistogram, List<ByteBuffer>, List<ByteBuffer>, boolean) - Constructor for class org.apache.cassandra.io.sstable.ColumnStats
 
ColumnStats.MaxIntTracker - Class in org.apache.cassandra.io.sstable
 
ColumnStats.MaxLongTracker - Class in org.apache.cassandra.io.sstable
 
ColumnStats.MinLongTracker - Class in org.apache.cassandra.io.sstable
 
ColumnToCollectionType - Class in org.apache.cassandra.db.marshal
 
columnToTuple(ColumnFamilyRecordReader.Column, CfDef, AbstractType) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
convert a column to a tuple
colUpdateTimeDeltaHistogram - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Column update time delta on this CF
colUpdateTimeDeltaHistogram - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Column update time delta on this Keyspace
command - Variable in class org.apache.cassandra.service.AbstractReadExecutor
 
commands - Variable in class org.apache.cassandra.service.pager.Pageable.ReadCommands
 
commandType - Variable in class org.apache.cassandra.db.ReadCommand
 
comment(String) - Method in class org.apache.cassandra.config.CFMetaData
 
COMMENT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
COMMENT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
commit(Throwable) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
commit(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter
 
Commit - Class in org.apache.cassandra.service.paxos
 
Commit(ByteBuffer, UUID, ColumnFamily) - Constructor for class org.apache.cassandra.service.paxos.Commit
 
commit(Commit) - Static method in class org.apache.cassandra.service.paxos.PaxosState
 
commit() - Method in interface org.apache.cassandra.utils.BatchRemoveIterator
Commits the remove operations in this batch iterator.
commit(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
commit any effects of this transaction object graph, then cleanup; delegates first to doCommit, then to doCleanup
commit() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
 
commit(Throwable) - Method in interface org.apache.cassandra.utils.concurrent.Transactional
 
commit() - Method in interface org.apache.cassandra.utils.memory.MemtableAllocator.DataReclaimer
 
Commit.CommitSerializer - Class in org.apache.cassandra.service.paxos
 
commit_failure_policy - Variable in class org.apache.cassandra.config.Config
 
CommitLog - Class in org.apache.cassandra.db.commitlog
 
CommitLog.Configuration - Class in org.apache.cassandra.db.commitlog
 
commitlog_compression - Variable in class org.apache.cassandra.config.Config
 
commitlog_directory - Variable in class org.apache.cassandra.config.Config
 
commitlog_max_compression_buffers_in_pool - Variable in class org.apache.cassandra.config.Config
 
commitlog_periodic_queue_size - Variable in class org.apache.cassandra.config.Config
Deprecated.
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
 
CommitLogArchiver - Class in org.apache.cassandra.db.commitlog
 
CommitLogArchiver(String, String, String, long, TimeUnit) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
CommitLogDescriptor - Class in org.apache.cassandra.db.commitlog
 
CommitLogDescriptor(int, long, ParameterizedClass) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
CommitLogDescriptor(long, ParameterizedClass) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
commitLogLowerBound - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
commitLogLowerBound(ReplayPosition) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
commitLogLowerBound - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
CommitLogMBean - Interface in org.apache.cassandra.db.commitlog
 
CommitLogMetrics - Class in org.apache.cassandra.metrics
Metrics for commit log
CommitLogMetrics() - Constructor for class org.apache.cassandra.metrics.CommitLogMetrics
 
CommitLogReplayer - Class in org.apache.cassandra.db.commitlog
 
CommitLogReplayer.CommitLogReplayException - Exception in org.apache.cassandra.db.commitlog
 
CommitLogReplayException(String, Throwable) - Constructor for exception org.apache.cassandra.db.commitlog.CommitLogReplayer.CommitLogReplayException
 
CommitLogReplayException(String) - Constructor for exception org.apache.cassandra.db.commitlog.CommitLogReplayer.CommitLogReplayException
 
CommitLogSegment - Class in org.apache.cassandra.db.commitlog
 
CommitLogSegment.CommitLogSegmentFileComparator - Class in org.apache.cassandra.db.commitlog
 
CommitLogSegmentFileComparator() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogSegmentFileComparator
 
CommitLogSegmentManager - Class in org.apache.cassandra.db.commitlog
Performs eager-creation of commit log segments in a background thread.
commitLogUpperBound - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
commitLogUpperBound(ReplayPosition) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
commitLogUpperBound - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
CommitSerializer() - Constructor for class org.apache.cassandra.service.paxos.Commit.CommitSerializer
 
commitTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
Deprecated.
 
commitTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
 
CommitVerbHandler - Class in org.apache.cassandra.service.paxos
 
CommitVerbHandler() - Constructor for class org.apache.cassandra.service.paxos.CommitVerbHandler
 
compact() - Method in class org.apache.cassandra.db.HintedHandOffManager
 
Compact - Class in org.apache.cassandra.tools.nodetool
 
Compact() - Constructor for class org.apache.cassandra.tools.nodetool.Compact
 
CompactEndpointSerializationHelper - Class in org.apache.cassandra.net
 
CompactEndpointSerializationHelper() - Constructor for class org.apache.cassandra.net.CompactEndpointSerializationHelper
 
compacting - Variable in class org.apache.cassandra.db.lifecycle.View
 
COMPACTION_ENABLED - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
COMPACTION_HISTORY - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
compaction_large_partition_warning_threshold_mb - Variable in class org.apache.cassandra.config.Config
 
COMPACTION_STRATEGY_CLASS_KEY - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
compaction_throughput_mb_per_sec - Variable in class org.apache.cassandra.config.Config
 
CompactionAwareWriter - Class in org.apache.cassandra.db.compaction.writers
Class that abstracts away the actual writing of files to make it possible to use CompactionTask for more use cases.
CompactionAwareWriter(ColumnFamilyStore, LifecycleTransaction, Set<SSTableReader>, boolean) - Constructor for class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
CompactionCandidate(Collection<SSTableReader>, int, long) - Constructor for class org.apache.cassandra.db.compaction.LeveledManifest.CompactionCandidate
 
CompactionController - Class in org.apache.cassandra.db.compaction
Manage compaction options.
CompactionController(ColumnFamilyStore, int) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
 
CompactionController(ColumnFamilyStore, Set<SSTableReader>, int) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
 
CompactionHistory - Class in org.apache.cassandra.tools.nodetool
 
CompactionHistory() - Constructor for class org.apache.cassandra.tools.nodetool.CompactionHistory
 
CompactionHistoryTabularData - Class in org.apache.cassandra.db.compaction
 
CompactionHistoryTabularData() - Constructor for class org.apache.cassandra.db.compaction.CompactionHistoryTabularData
 
compactionId - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
compactionId() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
CompactionInfo - Class in org.apache.cassandra.db.compaction
Implements serializable to allow structured info to be returned via JMX.
CompactionInfo(CFMetaData, OperationType, long, long, UUID) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
 
CompactionInfo(OperationType, long, long, String, UUID) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
 
CompactionInfo(CFMetaData, OperationType, long, long, String, UUID) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
 
CompactionInfo.Holder - Class in org.apache.cassandra.db.compaction
 
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<ISSTableScanner>, CompactionController, SSTableFormat.Type, UUID) - Constructor for class org.apache.cassandra.db.compaction.CompactionIterable
 
CompactionIterable.Reducer - Class in org.apache.cassandra.db.compaction
 
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.AllSSTableOpStatus - Enum in org.apache.cassandra.db.compaction
 
CompactionManager.CompactionExecutorStatsCollector - Interface in org.apache.cassandra.db.compaction
 
CompactionManagerMBean - Interface in org.apache.cassandra.db.compaction
 
CompactionMetadata - Class in org.apache.cassandra.io.sstable.metadata
Compaction related SSTable metadata.
CompactionMetadata(Set<Integer>, ICardinality) - Constructor for class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
 
CompactionMetadata.CompactionMetadataSerializer - Class in org.apache.cassandra.io.sstable.metadata
 
CompactionMetadataSerializer() - Constructor for class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
 
CompactionMetrics - Class in org.apache.cassandra.metrics
Metrics for compaction.
CompactionMetrics(ThreadPoolExecutor...) - Constructor for class org.apache.cassandra.metrics.CompactionMetrics
 
COMPACTIONS_IN_PROGRESS - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
CompactionStats - Class in org.apache.cassandra.tools.nodetool
 
CompactionStats() - Constructor for class org.apache.cassandra.tools.nodetool.CompactionStats
 
compactionStrategyClass - Variable in class org.apache.cassandra.config.CFMetaData
 
compactionStrategyClass(Class<? extends AbstractCompactionStrategy>) - Method in class org.apache.cassandra.config.CFMetaData
 
compactionStrategyOptions - Variable in class org.apache.cassandra.config.CFMetaData
 
compactionStrategyOptions(Map<String, String>) - Method in class org.apache.cassandra.config.CFMetaData
 
CompactionTask - Class in org.apache.cassandra.db.compaction
 
CompactionTask(ColumnFamilyStore, LifecycleTransaction, int, boolean) - 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
 
compactValueColumn() - Method in class org.apache.cassandra.config.CFMetaData
 
compactValueDef(CFMetaData, ByteBuffer, AbstractType<?>) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
comparator - Variable in class org.apache.cassandra.config.CFMetaData
 
comparator - Variable in class org.apache.cassandra.cql3.statements.CreateTableStatement
 
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 - Variable in class org.apache.cassandra.utils.btree.BTreeSet
 
comparator() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
comparatorType() - Method in class org.apache.cassandra.cql3.CqlParser
 
compare(File, File) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogSegmentFileComparator
 
compare(Composite, Composite) - Method in class org.apache.cassandra.db.composites.AbstractCType
 
compare(Composite, Composite) - Method in class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
 
compare(Composite, Composite) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType.WithCollection
 
compare(Composite, Composite) - Method in interface org.apache.cassandra.db.composites.CType
 
compare(Composite, Composite) - Method in class org.apache.cassandra.db.composites.SimpleCType
 
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.ByteType
 
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
Deprecated.
 
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.FrozenType
 
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.ListType
 
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.MapType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.SetType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ShortType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimestampType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TupleType
 
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(SSTableReader, SSTableReader) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.SizeComparator
 
compare(byte[], ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
compare(ByteBuffer, byte[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
compare(byte[], int, int, byte[], int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
 
compare(ByteBuffer, byte[], int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
 
compare(ByteBuffer, ByteBuffer) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
 
compare(ByteBuffer, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
compare(ByteBuffer, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
compareAsymmetric(T1, T2) - Method in class org.apache.cassandra.utils.AsymmetricOrdering
 
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
 
compareIntegers(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.IntegerType
 
compareLongs(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.LongType
 
compareMaps(AbstractType<?>, AbstractType<?>, ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.MapType
 
compareNextTo(Composite) - Method in class org.apache.cassandra.db.AtomDeserializer
Compare the provided composite to the next atom to read on disk.
compareNextTo(Composite) - Method in interface org.apache.cassandra.db.composites.CellNameType.Deserializer
Compare the next name to read to the provided Composite.
compareSubArrays(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Compare two ByteBuffer at specified offsets for length.
compareTo(FunctionResource) - Method in class org.apache.cassandra.auth.FunctionResource
 
compareTo(PermissionDetails) - Method in class org.apache.cassandra.auth.PermissionDetails
 
compareTo(RoleResource) - Method in class org.apache.cassandra.auth.RoleResource
 
compareTo(Composite) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
compareTo(ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition
 
compareTo(RowPosition) - Method in class org.apache.cassandra.db.DecoratedKey
 
compareTo(IPartitioner, ByteBuffer, RowPosition) - Static method in class org.apache.cassandra.db.DecoratedKey
 
compareTo(DeletionTime) - Method in class org.apache.cassandra.db.DeletionTime
 
compareTo(Memtable) - Method in class org.apache.cassandra.db.Memtable
 
compareTo(Token) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
compareTo(Token) - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
 
compareTo(Token) - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
compareTo(Range<T>) - Method in class org.apache.cassandra.dht.Range
Note: this class has a natural ordering that is inconsistent with equals
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(MetadataComponent) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataComponent
 
compareTo(SSTableIdentityIterator) - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
compareTo(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
 
compareTo(CassandraVersion) - Method in class org.apache.cassandra.utils.CassandraVersion
 
compareTo(OpOrder.Group) - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
 
compareTo(CounterId) - Method in class org.apache.cassandra.utils.CounterId
 
compareTo(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
compareTo(Object, long, int, ByteBuffer) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
compareTo(Object, long, int, Object, long, int) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
Lexicographically compare two arrays.
compareTo(MergeIterator.Candidate<In>) - Method in class org.apache.cassandra.utils.MergeIterator.Candidate
 
compareToSimple(Composite) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
compareUnsigned(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
compareUnsigned(byte[], int, int, byte[], int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
Lexicographically compare two byte arrays.
compareUnsigned(ByteBuffer, byte[], int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
 
compareUnsigned(byte[], int, int, ByteBuffer) - Static method in class org.apache.cassandra.utils.FastByteOperations
 
compareUnsigned(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.FastByteOperations
 
compareUnsigned(byte[], byte[], int, int, int, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
compareUnsigned(byte[], byte[]) - Static method in class org.apache.cassandra.utils.FBUtilities
 
compareWithOperator(Operator, AbstractType<?>, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.cql3.ColumnCondition.Bound
Returns true if the operator is satisfied (i.e.
compile(String, String) - Static method in class org.apache.cassandra.config.CFMetaData
 
complete(ChannelProxy, long) - Method in class org.apache.cassandra.io.util.BufferedPoolingSegmentedFile.Builder
 
complete(ChannelProxy, long) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile.Builder
 
complete(ChannelProxy, long) - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile.Builder
 
complete(ChannelProxy, long) - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile.Builder
 
complete(ChannelProxy, long) - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile.Builder
 
complete(ChannelProxy, long) - 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(String) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
 
complete(String, long) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
 
complete() - Method in class org.apache.cassandra.repair.Validator
Registers the newly created tree for rendezvous in Stage.ANTIENTROPY.
complete() - Method in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
 
complete() - Method in class org.apache.cassandra.streaming.StreamSession
Check if session is completed on receiving StreamMessage.Type.COMPLETE message.
complete(int) - Method in class org.apache.cassandra.streaming.StreamTransferTask
Received ACK for file at sequenceNumber.
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.SEPMetrics
Number of completed tasks.
completedTasks - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
Number of completed tasks.
CompleteMessage - Class in org.apache.cassandra.streaming.messages
 
CompleteMessage() - Constructor for class org.apache.cassandra.streaming.messages.CompleteMessage
 
completeSetup() - Method in class org.apache.cassandra.service.CassandraDaemon
 
completeTree() - Method in class org.apache.cassandra.repair.Validator
 
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.Type - Enum in org.apache.cassandra.io.sstable
 
componentCount() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
components - Variable in class org.apache.cassandra.io.sstable.SSTable
 
componentsCount() - Method in class org.apache.cassandra.db.marshal.AbstractType
The number of subcomponents this type has.
componentsCount() - Method in class org.apache.cassandra.db.marshal.CompositeType
 
componentsFor(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTable
Discovers existing components for the descriptor.
componentSpecOf(ColumnSpecification, int) - Static method in class org.apache.cassandra.cql3.Tuples
 
compose(int, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
Used by UDF implementations (both Java code generated by JavaSourceUDFFactory and script executor ScriptBasedUDF) to convert the C* serialized representation to the Java object representation.
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
compose_boolean(int, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
compose_byte(int, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
compose_double(int, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
compose_float(int, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
compose_int(int, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
compose_long(int, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
compose_short(int, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
composeComposite(AbstractCompositeType, ByteBuffer) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
Deconstructs a composite type to a Tuple.
Composite - Interface in org.apache.cassandra.db.composites
A composite value.
Composite.EOC - Enum in org.apache.cassandra.db.composites
 
COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.ProgressInfoCompositeData
 
COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.SessionCompleteEventCompositeData
 
COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.SessionInfoCompositeData
 
COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.StreamStateCompositeData
 
COMPOSITE_TYPE - Static variable in class org.apache.cassandra.streaming.management.StreamSummaryCompositeData
 
CompositeComponent(AbstractType<?>, ByteBuffer) - Constructor for class org.apache.cassandra.db.marshal.AbstractCompositeType.CompositeComponent
 
compositeDense(ByteBuffer...) - Static method in class org.apache.cassandra.db.composites.CellNames
 
Composites - Class in org.apache.cassandra.db.composites
 
CompositesBuilder - Class in org.apache.cassandra.db.composites
Builder that allow to build multiple composites at the same time.
CompositesBuilder(CType) - Constructor for class org.apache.cassandra.db.composites.CompositesBuilder
 
CompositesIndex - Class in org.apache.cassandra.db.index.composites
Base class for secondary indexes where composites are involved.
CompositesIndex() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndex
 
CompositesIndex.IndexedEntry - Class in org.apache.cassandra.db.index.composites
 
CompositesIndexIncludingCollectionKey - Class in org.apache.cassandra.db.index.composites
Common superclass for indexes that capture collection keys, including indexes on such keys themselves.
CompositesIndexIncludingCollectionKey() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexIncludingCollectionKey
 
CompositesIndexOnClusteringKey - Class in org.apache.cassandra.db.index.composites
Index on a CLUSTERING_COLUMN column definition.
CompositesIndexOnClusteringKey() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
 
CompositesIndexOnCollectionKey - Class in org.apache.cassandra.db.index.composites
Index on the collection element of the cell name of a collection.
CompositesIndexOnCollectionKey() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKey
 
CompositesIndexOnCollectionKeyAndValue - Class in org.apache.cassandra.db.index.composites
Index on the element and value of cells participating in a collection.
CompositesIndexOnCollectionKeyAndValue() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKeyAndValue
 
CompositesIndexOnCollectionValue - Class in org.apache.cassandra.db.index.composites
Index the value of a collection cell.
CompositesIndexOnCollectionValue() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionValue
 
CompositesIndexOnPartitionKey - Class in org.apache.cassandra.db.index.composites
Index on a PARTITION_KEY column definition.
CompositesIndexOnPartitionKey() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
 
CompositesIndexOnRegular - Class in org.apache.cassandra.db.index.composites
Index on a REGULAR column definition on a composite type.
CompositesIndexOnRegular() - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
 
compositeSparse(ByteBuffer[], ColumnIdentifier, boolean) - Static method in class org.apache.cassandra.db.composites.CellNames
 
compositeSparseWithCollection(ByteBuffer[], ByteBuffer, ColumnIdentifier, boolean) - Static method in class org.apache.cassandra.db.composites.CellNames
 
CompositesSearcher - Class in org.apache.cassandra.db.index.composites
 
CompositesSearcher(SecondaryIndexManager, Set<ByteBuffer>) - Constructor for class org.apache.cassandra.db.index.composites.CompositesSearcher
 
compositesToGroup - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
CompositeType - Class in org.apache.cassandra.db.marshal
 
CompositeType(List<AbstractType<?>>) - Constructor for class org.apache.cassandra.db.marshal.CompositeType
 
CompositeType.Builder - Class in org.apache.cassandra.db.marshal
 
CompoundCBuilder(CType) - Constructor for class org.apache.cassandra.db.composites.CompoundCType.CompoundCBuilder
 
CompoundComposite - Class in org.apache.cassandra.db.composites
A "truly-composite" Composite.
CompoundCType - Class in org.apache.cassandra.db.composites
A truly-composite CType.
CompoundCType(List<AbstractType<?>>) - Constructor for class org.apache.cassandra.db.composites.CompoundCType
 
CompoundCType.CompoundCBuilder - Class in org.apache.cassandra.db.composites
 
CompoundDenseCellName - Class in org.apache.cassandra.db.composites
 
CompoundDenseCellNameType - Class in org.apache.cassandra.db.composites
 
CompoundDenseCellNameType(List<AbstractType<?>>) - Constructor for class org.apache.cassandra.db.composites.CompoundDenseCellNameType
 
CompoundSparseCellName - Class in org.apache.cassandra.db.composites
 
CompoundSparseCellName.WithCollection - Class in org.apache.cassandra.db.composites
 
CompoundSparseCellNameType - Class in org.apache.cassandra.db.composites
 
CompoundSparseCellNameType(List<AbstractType<?>>) - Constructor for class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
CompoundSparseCellNameType(List<AbstractType<?>>, AbstractType<?>) - Constructor for class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
CompoundSparseCellNameType.WithCollection - Class in org.apache.cassandra.db.composites
 
compress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
compress(ByteBuffer, ByteBuffer) - Method in interface org.apache.cassandra.io.compress.ICompressor
Compression for ByteBuffers.
compress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
 
compress(ByteBuffer, ByteBuffer) - 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.LZ4Compressor
 
compress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.SnappyCompressor
 
compressArray(byte[], int, int, byte[], int, int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
compressBuffer(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
compressedFileLength - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
 
CompressedFileWriterMark(long, long, int, int) - Constructor for class org.apache.cassandra.io.compress.CompressedSequentialWriter.CompressedFileWriterMark
 
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(ChannelProxy, CompressionMetadata) - Constructor for class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
 
CompressedPoolingSegmentedFile.Builder - Class in org.apache.cassandra.io.util
 
CompressedPoolingSegmentedFile.Cleanup - Class in org.apache.cassandra.io.util
 
CompressedRandomAccessReader - Class in org.apache.cassandra.io.compress
CRAR extends RAR to transparently uncompress blocks from the file into RAR.buffer.
CompressedRandomAccessReader(ChannelProxy, CompressionMetadata, ICompressedFile, PoolingSegmentedFile) - Constructor for class org.apache.cassandra.io.compress.CompressedRandomAccessReader
 
CompressedSegment - Class in org.apache.cassandra.db.commitlog
 
CompressedSegmentedFile - Class in org.apache.cassandra.io.util
 
CompressedSegmentedFile(ChannelProxy, CompressionMetadata) - Constructor for class org.apache.cassandra.io.util.CompressedSegmentedFile
 
CompressedSegmentedFile(ChannelProxy, CompressionMetadata, TreeMap<Long, MappedByteBuffer>) - Constructor for class org.apache.cassandra.io.util.CompressedSegmentedFile
 
CompressedSegmentedFile.Builder - Class in org.apache.cassandra.io.util
 
CompressedSequentialWriter - Class in org.apache.cassandra.io.compress
 
CompressedSequentialWriter(File, String, CompressionParameters, MetadataCollector) - 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.TransactionalProxy - Class in org.apache.cassandra.io.compress
 
CompressedStreamReader - Class in org.apache.cassandra.streaming.compress
StreamReader that reads from streamed compressed SSTable
CompressedStreamReader(FileMessageHeader, StreamSession) - Constructor for class org.apache.cassandra.streaming.compress.CompressedStreamReader
 
CompressedStreamWriter - Class in org.apache.cassandra.streaming.compress
StreamWriter for compressed SSTable.
CompressedStreamWriter(SSTableReader, Collection<Pair<Long, Long>>, CompressionInfo, StreamSession) - Constructor for class org.apache.cassandra.streaming.compress.CompressedStreamWriter
 
CompressedThrottledReader - Class in org.apache.cassandra.io.compress
 
CompressedThrottledReader(ChannelProxy, CompressionMetadata, ICompressedFile, RateLimiter) - Constructor for class org.apache.cassandra.io.compress.CompressedThrottledReader
 
compression - Variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
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
 
compressionInfo - Variable in class org.apache.cassandra.streaming.compress.CompressedStreamReader
 
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.messages.FileMessageHeader
Compression info for SSTable to send.
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.Writer - Class in org.apache.cassandra.io.compress
 
compressionMetadataOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Off heap memory used by compression meta data
compressionMetadataOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Off heap memory used by compression meta data
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 - 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.metadata.MetadataCollector
 
compressionRatio - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
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
 
Compressor() - Constructor for class org.apache.cassandra.transport.Frame.Compressor
 
compute(int) - Method in interface org.apache.cassandra.cql3.functions.AggregateFunction.Aggregate
Computes and returns the aggregate current value.
compute(byte[]) - Static method in class org.apache.cassandra.utils.MD5Digest
 
compute(String) - Static method in class org.apache.cassandra.utils.MD5Digest
 
computeBloomSpec(int) - Static method in class org.apache.cassandra.utils.BloomCalculations
Given the number of buckets that can be used per element, return a specification that minimizes the false positive rate.
computeBloomSpec(int, double) - Static method in class org.apache.cassandra.utils.BloomCalculations
Given a maximum tolerable false positive probability, compute a Bloom specification which will give less than the specified false positive rate, but minimize the number of buckets per element and the number of hash functions used.
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.io.sstable.format.big.BigTableScanner.KeyScanningIterator
 
computeNext() - Method in class org.apache.cassandra.io.sstable.KeyIterator
 
computeNext() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRangeIterator
Find the next TreeRange.
concatWithIndexes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
concurrent_compactors - Variable in class org.apache.cassandra.config.Config
 
concurrent_counter_writes - 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
Deprecated.
concurrent_writes - Variable in class org.apache.cassandra.config.Config
 
ConcurrentBiMap<K,V> - Class in org.apache.cassandra.utils
A variant of BiMap that permits concurrent access, and expects uniqueness of values in both domain and range.
ConcurrentBiMap() - Constructor for class org.apache.cassandra.utils.ConcurrentBiMap
 
ConcurrentBiMap(Map<K, V>, Map<V, K>) - Constructor for class org.apache.cassandra.utils.ConcurrentBiMap
 
ConcurrentLinkedHashCache<K extends IMeasurableMemory,V extends IMeasurableMemory> - Class in org.apache.cassandra.cache
Wrapper so CLHM can implement ICache interface.
condition(ColumnDefinition, Term, Operator) - Static method in class org.apache.cassandra.cql3.ColumnCondition
 
condition(ColumnDefinition, Term, Term, Operator) - Static method in class org.apache.cassandra.cql3.ColumnCondition
 
condition - Variable in class org.apache.cassandra.service.TruncateResponseHandler
 
conditionNotMet - Variable in class org.apache.cassandra.metrics.CASClientRequestMetrics
 
conditions - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
 
conf - Variable in class org.apache.cassandra.hadoop.BulkRecordWriter
Deprecated.
 
conf - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
conf - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
conf - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
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.CommitFailurePolicy - Enum in org.apache.cassandra.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.MemtableAllocationType - 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
 
configHintedHandoff() - Method in class org.apache.cassandra.config.Config
 
configOptions - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
Configuration(ParameterizedClass) - Constructor for class org.apache.cassandra.db.commitlog.CommitLog.Configuration
 
ConfigurationException - Exception in org.apache.cassandra.exceptions
 
ConfigurationException(String) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
 
ConfigurationException(String, boolean) - 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
 
ConfigurationLoader - Interface in org.apache.cassandra.config
 
confirmReplication(InetAddress) - Method in class org.apache.cassandra.service.StorageService
 
connect(boolean) - Method in class org.apache.cassandra.transport.SimpleClient
 
connectAllStreamSessions() - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
connecting - Variable in class org.apache.cassandra.streaming.SessionInfo
 
connecting - Variable in class org.apache.cassandra.streaming.StreamSession
Actual connecting address.
Connection - Class in org.apache.cassandra.transport
 
Connection(Channel, int, Connection.Tracker) - Constructor for class org.apache.cassandra.transport.Connection
 
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.
connectionFactory(StreamConnectionFactory) - Method in class org.apache.cassandra.streaming.StreamPlan
Set custom StreamConnectionFactory to be used for establishing connection
ConnectionHandler - Class in org.apache.cassandra.streaming
ConnectionHandler manages incoming/outgoing message exchange for the StreamSession.
ConnectionMetrics - Class in org.apache.cassandra.metrics
ConnectionMetrics(InetAddress, OutboundTcpConnectionPool) - Constructor for class org.apache.cassandra.metrics.ConnectionMetrics
Create metrics for given connection pool.
connections - Variable in class org.apache.cassandra.net.MessagingService.SocketThread
 
ConnectionTracker() - Constructor for class org.apache.cassandra.transport.Server.ConnectionTracker
 
consistency() - Method in class org.apache.cassandra.db.CounterMutation
 
consistency - Variable in exception org.apache.cassandra.exceptions.RequestFailureException
 
consistency - Variable in exception org.apache.cassandra.exceptions.RequestTimeoutException
 
consistency - Variable in exception org.apache.cassandra.exceptions.UnavailableException
 
consistencyForRole(String) - Static method in class org.apache.cassandra.auth.CassandraRoleManager
 
ConsistencyLevel - Enum in org.apache.cassandra.db
 
consistencyLevel - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
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.Deleter - Class in org.apache.cassandra.cql3
 
Constants.Literal - Class in org.apache.cassandra.cql3
 
Constants.Marker - Class in org.apache.cassandra.cql3
 
Constants.Setter - Class in org.apache.cassandra.cql3
 
Constants.Substracter - Class in org.apache.cassandra.cql3
 
Constants.Type - Enum in org.apache.cassandra.cql3
 
Constants.Value - Class in org.apache.cassandra.cql3
A constant value, i.e.
construct(Cell) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
construct() - Static method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
construct(CommitLog) - Static method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
construct(Cell) - Method in class org.apache.cassandra.db.NativeCounterCell
 
construct(Cell) - Method in class org.apache.cassandra.db.NativeExpiringCell
 
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 or default constructor.
Contains(ColumnDefinition, Term, boolean) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
 
Contains(ColumnDefinition, Term, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
 
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(RowPosition) - Method in class org.apache.cassandra.db.DataRange
 
contains(T) - Method in class org.apache.cassandra.dht.AbstractBounds
 
contains(T) - Method in class org.apache.cassandra.dht.Bounds
 
contains(T) - Method in class org.apache.cassandra.dht.ExcludingBounds
 
contains(T) - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
contains(T, T, T) - Static method in class org.apache.cassandra.dht.Range
 
contains(Range<T>) - Method in class org.apache.cassandra.dht.Range
 
contains(T) - Method in class org.apache.cassandra.dht.Range
Helps determine if a given point on the DHT ring is contained in the range in question.
contains(Token) - Method in class org.apache.cassandra.dht.Range.OrderedRangeContainmentChecker
Returns true if the ranges given in the constructor contains the token, false otherwise.
contains(String) - Method in class org.apache.cassandra.locator.SnitchProperties
 
contains(Object) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
containsACollection() - Method in class org.apache.cassandra.cql3.selection.Selection
Checks if this selection contains a collection.
containsAll(Collection<?>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
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
 
containsBindMarker() - Method in class org.apache.cassandra.cql3.Tuples.DelayedValue
 
containsBindMarker() - Method in class org.apache.cassandra.cql3.UserTypes.DelayedValue
 
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.utils.BiMultiValMap
 
containsKey(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
containsKey(K) - Method in class org.apache.cassandra.utils.ExpiringMap
 
containsNull() - Method in class org.apache.cassandra.db.composites.CompositesBuilder
Checks if the composites contains null elements.
containsOnlyStaticColumns() - Method in class org.apache.cassandra.cql3.selection.Selection
Checks if this selection contains only static columns.
containsPreviousLast(Row) - Method in class org.apache.cassandra.service.pager.RangeNamesQueryPager
 
containsPreviousLast(Row) - Method in class org.apache.cassandra.service.pager.RangeSliceQueryPager
 
containsPreviousLast(Row) - Method in class org.apache.cassandra.service.pager.SliceQueryPager
 
containsStaticColumns() - Method in class org.apache.cassandra.cql3.selection.Selection
Checks if this selection contains static columns.
containsTriggerDefinition(TriggerDefinition) - Method in class org.apache.cassandra.config.CFMetaData
 
containsUnset() - Method in class org.apache.cassandra.db.composites.CompositesBuilder
Checks if the composites contains unset elements.
containsValue(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
 
containsValue(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
contention - Variable in class org.apache.cassandra.metrics.CASClientRequestMetrics
 
contents() - Method in class org.apache.cassandra.db.Memtable
 
contentSerializedSize(ColumnFamily, TypeSizes, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
contentSize() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
context - Variable in class org.apache.cassandra.db.context.CounterContext.ContextState
 
context - Variable in class org.apache.cassandra.hadoop.BulkRecordWriter
Deprecated.
 
context - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
ContextAllocator - Class in org.apache.cassandra.utils.memory
Wraps calls to a PoolAllocator with the provided writeOp.
ContextAllocator(OpOrder.Group, MemtableBufferAllocator) - Constructor for class org.apache.cassandra.utils.memory.ContextAllocator
 
contextManager - Static variable in interface org.apache.cassandra.db.CounterCell
 
controller - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
controller - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
convert(long) - Static method in class org.apache.cassandra.utils.NanoTimeToCurrentTimeMillis
 
convertPropertyMap(Maps.Literal) - Method in class org.apache.cassandra.cql3.CqlParser
 
convertSchemaToMutations() - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
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 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.repair.AnticompactionTask
 
convict(InetAddress, double) - Method in class org.apache.cassandra.repair.RepairSession
 
convict(InetAddress, double) - Method in class org.apache.cassandra.service.ActiveRepairService
Something has happened to a remote node - if that node is a coordinator, we mark the parent repair session id as failed.
coordinator - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
coordinator - Variable in class org.apache.cassandra.tracing.TraceState
 
coordinatorReadLatency - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
 
coordinatorScanLatency - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
 
copy(long) - Method in class org.apache.cassandra.cache.RefCountedMemory
 
copy() - Method in class org.apache.cassandra.config.CFMetaData
 
copy(UUID) - Method in class org.apache.cassandra.config.CFMetaData
Clones the CFMetaData, but sets a different cfId
copy() - Method in class org.apache.cassandra.config.ColumnDefinition
 
copy() - Method in class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
 
copy() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.BoundedComposite
 
copy(CFMetaData, AbstractAllocator) - Method in interface org.apache.cassandra.db.composites.CellName
 
copy(CFMetaData, AbstractAllocator) - Method in interface org.apache.cassandra.db.composites.Composite
 
copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.CompoundComposite
 
copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellName
 
copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
 
copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName.WithCollection
 
copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.SimpleComposite
 
copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.SimpleDenseCellName
 
copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
 
copy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.composites.SimpleSparseInternedCellName
 
copy() - Method in class org.apache.cassandra.db.DeletionInfo
 
copy(AbstractAllocator) - 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.Mutation
 
copy() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
copy(AbstractAllocator) - 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
 
copy() - Method in class org.apache.cassandra.io.compress.CompressionParameters
 
copy(long) - Method in class org.apache.cassandra.io.util.Memory
 
copy(long) - Method in class org.apache.cassandra.io.util.SafeMemory
 
copy(ByteBuffer, int, byte[], int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
 
copy(ByteBuffer, int, ByteBuffer, int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
 
copy(ByteBuffer, int, byte[], int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
 
copy(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
 
copy(ByteBuffer, int, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
 
copy(ByteBuffer, int, ByteBuffer, int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
 
copy(ByteBuffer, int, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
copy(ByteBuffer, int, ByteBuffer, int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
copy(Object, long, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
copy(Object, long, byte[], int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
copy(Object, long, Object, long, long) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
copy(InputStream, OutputStream, long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
copyAndMakeWith(ByteBuffer[], int, Composite.EOC, boolean) - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
 
copyAndMakeWith(ByteBuffer[], int, Composite.EOC, boolean) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellNameType
 
copyAndMakeWith(ByteBuffer[], int, Composite.EOC, boolean) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
copyAndMakeWith(ByteBuffer[], int, Composite.EOC, boolean) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType.WithCollection
 
copyOpts(CFMetaData, CFMetaData) - Static method in class org.apache.cassandra.config.CFMetaData
 
copyReadableBounds() - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile
 
copyReadableBounds() - Method in class org.apache.cassandra.io.util.SegmentedFile
Retrieve the readable bounds if any so they can be cloned into other files such as when downsampling an index summary.
copyTo(CounterContext.ContextState) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
copyTo(DataInput, OutputStream, int) - Static method in class org.apache.cassandra.io.util.FileUtils
 
CorruptBlockException - Exception in org.apache.cassandra.io.compress
 
CorruptBlockException(String, CompressionMetadata.Chunk) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
 
CorruptBlockException(String, CompressionMetadata.Chunk, Throwable) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
 
CorruptBlockException(String, long, int) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
 
CorruptBlockException(String, long, int, Throwable) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
 
CorruptColumnException(String) - Constructor for exception org.apache.cassandra.db.ColumnSerializer.CorruptColumnException
 
CorruptFileException(Exception, File) - Constructor for exception org.apache.cassandra.io.util.ChecksummedRandomAccessReader.CorruptFileException
 
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 - Variable in class org.apache.cassandra.db.ClockAndCount
 
count(Cell, DeletionInfo.InOrderTester) - Method in class org.apache.cassandra.db.filter.ColumnCounter
 
count(Cell, DeletionInfo.InOrderTester) - Method in class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefix
 
count(Cell, DeletionInfo.InOrderTester) - Method in class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefixReversed
 
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() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
 
count() - Method in class org.apache.cassandra.metrics.RestorableMeter
The total number of events that have occurred since this object was created.
count() - Method in class org.apache.cassandra.utils.btree.Cursor
 
count() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
countAll(ColumnFamily) - Method in class org.apache.cassandra.db.filter.ColumnCounter
 
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.
countArgument() - Method in class org.apache.cassandra.cql3.CqlParser
 
countColumn(Cell) - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
Deprecated.
 
countCQL3Rows() - Method in class org.apache.cassandra.db.AbstractRangeCommand
 
countCQL3Rows(CellNameType) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
 
countCQL3Rows(CellNameType) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
countCQL3Rows() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
countCQL3Rows(CellNameType) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
countCQL3Rows() - Method in class org.apache.cassandra.db.PagedRangeCommand
 
countCQL3Rows - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
countCQL3Rows() - Method in class org.apache.cassandra.db.RangeSliceCommand
 
counter(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
counter_cache_keys_to_save - Variable in class org.apache.cassandra.config.Config
 
counter_cache_save_period - Variable in class org.apache.cassandra.config.Config
 
counter_cache_size_in_mb - Variable in class org.apache.cassandra.config.Config
 
COUNTER_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
 
COUNTER_UPDATE_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
 
counter_write_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
counterCache - Variable in class org.apache.cassandra.service.CacheService
 
CounterCacheKey - Class in org.apache.cassandra.cache
 
CounterCacheSerializer() - Constructor for class org.apache.cassandra.service.CacheService.CounterCacheSerializer
 
CounterCell - Interface in org.apache.cassandra.db
A column that represents a partitioned counter.
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.Relationship - Enum in org.apache.cassandra.db.context
 
counterid - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
CounterId - Class in org.apache.cassandra.utils
 
CounterMutation - Class in org.apache.cassandra.db
 
CounterMutation(Mutation, ConsistencyLevel) - Constructor for class org.apache.cassandra.db.CounterMutation
 
CounterMutation.CounterMutationSerializer - Class in org.apache.cassandra.db
 
CounterMutationSerializer() - Constructor for class org.apache.cassandra.db.CounterMutation.CounterMutationSerializer
 
CounterMutationVerbHandler - Class in org.apache.cassandra.db
 
CounterMutationVerbHandler() - Constructor for class org.apache.cassandra.db.CounterMutationVerbHandler
 
CounterSerializer - Class in org.apache.cassandra.serializers
 
CounterSerializer() - Constructor for class org.apache.cassandra.serializers.CounterSerializer
 
CounterUpdateCell - Interface in org.apache.cassandra.db
A counter update while it hasn't been applied yet by the leader replica.
countLocalEndpoints(Iterable<InetAddress>) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
countPaged(String, String, ByteBuffer, SliceQueryFilter, ConsistencyLevel, ClientState, int, long) - Static method in class org.apache.cassandra.service.pager.QueryPagers
Convenience method that count (live) cells/rows for a given slice of a row, but page underneath.
countPartitionsWithOnlyStaticData - Variable in class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefix
 
countRowsFunction - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The function used to count the number of rows of a result set.
CQL3CasRequest - Class in org.apache.cassandra.cql3.statements
Processed CAS conditions and update on potentially multiple rows of the same partition.
CQL3CasRequest(CFMetaData, ByteBuffer, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CQL3CasRequest
 
cql3ColumnName(CFMetaData) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
cql3ColumnName(CFMetaData) - Method in interface org.apache.cassandra.db.composites.CellName
The name of the CQL3 column this cell represents.
cql3ColumnName(CFMetaData) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellName
 
cql3ColumnName(CFMetaData) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
 
cql3ColumnName(CFMetaData) - Method in class org.apache.cassandra.db.composites.SimpleDenseCellName
 
cql3ColumnName(CFMetaData) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
 
CQL3Row - Interface in org.apache.cassandra.cql3
 
CQL3Row.Builder - Interface in org.apache.cassandra.cql3
 
CQL3Row.RowIterator - Interface in org.apache.cassandra.cql3
 
CQL3RowBuilder(CFMetaData, long) - Method in interface org.apache.cassandra.db.composites.CellNameType
Creates a new CQL3Row builder for this type.
CQL3RowBuilder(CFMetaData, long) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellNameType
 
CQL3RowBuilder(CFMetaData, long) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
CQL3RowBuilder(CFMetaData, long) - Method in class org.apache.cassandra.db.composites.SimpleDenseCellNameType
 
CQL3RowBuilder(CFMetaData, long) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellNameType
 
CQL3Type - Interface in org.apache.cassandra.cql3
 
CQL3Type.Collection - Class in org.apache.cassandra.cql3
 
CQL3Type.Custom - Class in org.apache.cassandra.cql3
 
CQL3Type.Native - Enum in org.apache.cassandra.cql3
 
CQL3Type.Raw - Class in org.apache.cassandra.cql3
 
CQL3Type.Tuple - Class in org.apache.cassandra.cql3
 
CQL3Type.UserDefined - Class in org.apache.cassandra.cql3
 
CQL_VERSION - Static variable in class org.apache.cassandra.cql3.QueryProcessor
 
CQL_VERSION - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
 
CqlBulkOutputFormat - Class in org.apache.cassandra.hadoop.cql3
The CqlBulkOutputFormat acts as a Hadoop-specific OutputFormat that allows reduce tasks to store keys (and corresponding bound variable values) as CQL rows (and respective columns) in a given table.
CqlBulkOutputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
CqlBulkOutputFormat.NullOutputCommitter - Class in org.apache.cassandra.hadoop.cql3
 
CqlBulkRecordWriter - Class in org.apache.cassandra.hadoop.cql3
The CqlBulkRecordWriter maps the output <key, value> pairs to a Cassandra column family.
CqlBulkRecordWriter.ExternalClient - Class in org.apache.cassandra.hadoop.cql3
 
CqlConfigHelper - Class in org.apache.cassandra.hadoop.cql3
 
CqlConfigHelper() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
CqlInputFormat - Class in org.apache.cassandra.hadoop.cql3
Hadoop InputFormat allowing map/reduce against Cassandra rows within one ColumnFamily.
CqlInputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlInputFormat
 
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
 
CqlLexer.DFA13 - Class in org.apache.cassandra.cql3
 
CqlLexer.DFA21 - Class in org.apache.cassandra.cql3
 
CQLMetrics - Class in org.apache.cassandra.metrics
 
CQLMetrics() - Constructor for class org.apache.cassandra.metrics.CQLMetrics
 
CqlNativeStorage - Class in org.apache.cassandra.hadoop.pig
Deprecated.
CqlNativeStorage() - Constructor for class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
CqlNativeStorage(int) - Constructor for class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
CqlOutputFormat - Class in org.apache.cassandra.hadoop.cql3
The CqlOutputFormat acts as a Hadoop-specific OutputFormat that allows reduce tasks to store keys (and corresponding bound variable values) as CQL rows (and respective columns) in a given table.
CqlOutputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
 
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.DFA13 - Class in org.apache.cassandra.cql3
 
CqlParser.DFA130 - Class in org.apache.cassandra.cql3
 
CqlParser.DFA131 - Class in org.apache.cassandra.cql3
 
CqlParser.DFA149 - Class in org.apache.cassandra.cql3
 
CqlParser.DFA151 - Class in org.apache.cassandra.cql3
 
CqlParser.DFA153 - Class in org.apache.cassandra.cql3
 
CqlParser.DFA155 - Class in org.apache.cassandra.cql3
 
CqlParser.DFA158 - Class in org.apache.cassandra.cql3
 
CqlParser.DFA164 - Class in org.apache.cassandra.cql3
 
CqlParser.DFA169 - Class in org.apache.cassandra.cql3
 
CqlParser.DFA170 - Class in org.apache.cassandra.cql3
 
CqlParser.DFA179 - Class in org.apache.cassandra.cql3
 
CqlParser.DFA2 - Class in org.apache.cassandra.cql3
 
CqlParser.DFA40 - Class in org.apache.cassandra.cql3
 
CqlParser.username_return - Class in org.apache.cassandra.cql3
 
CqlRecordReader - Class in org.apache.cassandra.hadoop.cql3
CqlRecordReader reads the rows return from the CQL query It uses CQL auto-paging.
CqlRecordReader() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
CQLSSTableWriter - Class in org.apache.cassandra.io.sstable
Utility to write SSTables.
CQLSSTableWriter.Builder - Class in org.apache.cassandra.io.sstable
A Builder for a CQLSSTableWriter object.
cqlStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
CQLStatement - Interface in org.apache.cassandra.cql3
 
CRC - Static variable in class org.apache.cassandra.io.sstable.Component
 
CRC32Factory - Class in org.apache.cassandra.utils
CRC Factory that uses our pure java crc for default
CRC32Factory() - Constructor for class org.apache.cassandra.utils.CRC32Factory
 
CRC_CHECK_CHANCE - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
 
create() - Method in interface org.apache.cassandra.cache.CacheProvider
 
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(Pair<String, String>, ByteBuffer, CellName) - Static method in class org.apache.cassandra.cache.CounterCacheKey
 
create() - Method in class org.apache.cassandra.cache.NopCacheProvider
 
create() - Method in class org.apache.cassandra.cache.OHCProvider
 
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() - Method in class org.apache.cassandra.cache.SerializingCacheProvider
 
create() - Static method in class org.apache.cassandra.concurrent.ExecutorLocals
This creates a new ExecutorLocals object based on what is already set.
create(TraceState) - Static method in class org.apache.cassandra.concurrent.ExecutorLocals
 
create(String, String) - Static method in class org.apache.cassandra.config.TriggerDefinition
 
create(TupleType) - Static method in class org.apache.cassandra.cql3.CQL3Type.Tuple
 
create(UserType) - Static method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
 
create(FunctionName, List<AbstractType<?>>, AbstractType<?>, FunctionName, FunctionName, AbstractType<?>, ByteBuffer) - Static method in class org.apache.cassandra.cql3.functions.UDAggregate
 
create(FunctionName, List<ColumnIdentifier>, List<AbstractType<?>>, AbstractType<?>, boolean, String, String) - Static method in class org.apache.cassandra.cql3.functions.UDFunction
 
create(ConsistencyLevel, List<ByteBuffer>, boolean, int, PagingState, ConsistencyLevel) - Static method in class org.apache.cassandra.cql3.QueryOptions
 
create(ResultSet) - Static method in class org.apache.cassandra.cql3.UntypedResultSet
 
create(List<Map<String, ByteBuffer>>) - Static method in class org.apache.cassandra.cql3.UntypedResultSet
 
create(SelectStatement, QueryPager, int) - Static method in class org.apache.cassandra.cql3.UntypedResultSet
 
create(CellName, ByteBuffer, long, int, CFMetaData) - Static method in class org.apache.cassandra.db.AbstractCell
 
create(CellName, ByteBuffer, long, long, ColumnSerializer.Flag) - Static method in class org.apache.cassandra.db.BufferCounterCell
 
create(CellName, ByteBuffer, long, int, int, int, ColumnSerializer.Flag) - Static method in class org.apache.cassandra.db.BufferExpiringCell
 
create(long, long) - Static method in class org.apache.cassandra.db.ClockAndCount
 
create(CFMetaData, boolean, int) - Method in class org.apache.cassandra.db.ColumnFamily.Factory
Returns a (initially empty) column map whose columns are sorted according to the provided comparator.
create(CFMetaData, boolean) - Method in class org.apache.cassandra.db.ColumnFamily.Factory
 
create(CFMetaData) - Method in class org.apache.cassandra.db.ColumnFamily.Factory
 
create(String, String) - Method in class org.apache.cassandra.db.ColumnFamily.Factory
 
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, List<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
 
create(ColumnFamilyStore, int, Iterable<SSTableReader>, SizeTieredCompactionStrategyOptions) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
 
create(Composite, ColumnDefinition, ByteBuffer) - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
create(Composite, ColumnDefinition) - Method in interface org.apache.cassandra.db.composites.CellNameType
Creates a new CellName given a clustering prefix and a CQL3 column.
create(Composite, ColumnDefinition, ByteBuffer) - Method in interface org.apache.cassandra.db.composites.CellNameType
Creates a new collection CellName given a clustering prefix, a CQL3 column and the collection element.
create(Composite, ColumnDefinition) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellNameType
 
create(Composite, ColumnDefinition) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
create(Composite, ColumnDefinition, ByteBuffer) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType.WithCollection
 
create(Composite, ColumnDefinition) - Method in class org.apache.cassandra.db.composites.SimpleDenseCellNameType
 
create(Composite, ColumnDefinition) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellNameType
 
create(ColumnFamilyStore, DataRange, List<IndexExpression>, int, boolean, long) - Static method in class org.apache.cassandra.db.filter.ExtendedFilter
 
create(ColumnDefinition) - Static method in class org.apache.cassandra.db.index.composites.CompositesIndex
 
create(String, ByteBuffer, String, long, IDiskAtomFilter) - Static method in class org.apache.cassandra.db.ReadCommand
 
create(long, DeletionTime, ColumnIndex) - Static method in class org.apache.cassandra.db.RowIndexEntry
 
create(Function, Throwable) - Static method in exception org.apache.cassandra.exceptions.FunctionExecutionException
 
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(Descriptor, Long, Long, CFMetaData, IPartitioner, MetadataCollector) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
create(Descriptor, long, long) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
create(Descriptor, long, long, int) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
create(CFMetaData, Descriptor, long, long, int, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
create(String, long, long, int) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
create(String, long, long) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
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(Collection<SSTableWriter>) - Method in class org.apache.cassandra.streaming.StreamLockfile
 
create(Message.Type, int, int, EnumSet<Frame.Header.Flag>, ByteBuf) - 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
 
createAggregateStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
CreateAggregateStatement - Class in org.apache.cassandra.cql3.statements
A CREATE AGGREGATE statement parsed from a CQL query.
CreateAggregateStatement(FunctionName, List<CQL3Type.Raw>, String, CQL3Type.Raw, String, Term.Raw, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateAggregateStatement
 
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.ColumnFamilyInputFormat
Deprecated.
 
createAuthenticatedClient(String, int, Configuration) - Static method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Deprecated.
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.
createBroken(FunctionName, List<AbstractType<?>>, AbstractType<?>, ByteBuffer, InvalidRequestException) - Static method in class org.apache.cassandra.cql3.functions.UDAggregate
 
createBrokenFunction(FunctionName, List<ColumnIdentifier>, List<AbstractType<?>>, AbstractType<?>, boolean, String, String, InvalidRequestException) - Static method in class org.apache.cassandra.cql3.functions.UDFunction
It can happen that a function has been declared (is listed in the scheam) but cannot be loaded (maybe only on some nodes).
createCachedThreadpoolWithMaxSize(String) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
Creates a thread pool that creates new threads as needed, but will reuse previously constructed threads when they are available.
createClusteringPrefix(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
createColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
Deprecated.
 
createColumnFamilyCounter(String) - Method in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Creates a counter that will also have a global counter thats the sum of all counters across different column families
createColumnFamilyGauge(String, Gauge<T>) - Method in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Create a gauge that will be part of a merged version of all column families.
createColumnFamilyGauge(String, Gauge<T>, Gauge<G>) - Method in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Create a gauge that will be part of a merged version of all column families.
createColumnFamilyHistogram(String, Histogram, boolean) - Method in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Create a histogram-like interface that will register both a CF, keyspace and global level histogram and forward any updates to both
createColumnFamilyStore(Keyspace, CFMetaData, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
createColumnFamilyStore(Keyspace, String, IPartitioner, CFMetaData, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
createCompactionStrategy(String) - Static method in class org.apache.cassandra.config.CFMetaData
 
createCompactionStrategyInstance(Class<? extends AbstractCompactionStrategy>, ColumnFamilyStore, Map<String, String>) - Static method in class org.apache.cassandra.config.CFMetaData
 
createCompactionStrategyInstance(ColumnFamilyStore) - Method in class org.apache.cassandra.config.CFMetaData
Deprecated.
createCompressor(ParameterizedClass) - Static method in class org.apache.cassandra.io.compress.CompressionParameters
 
createConnection(Configuration, String, Integer) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
createConnection(InetAddress) - Method in class org.apache.cassandra.streaming.DefaultConnectionFactory
Connect to peer and start exchanging message.
createConnection(InetAddress) - Method in interface org.apache.cassandra.streaming.StreamConnectionFactory
 
createConnection() - Method in class org.apache.cassandra.streaming.StreamSession
 
createConnection(InetAddress) - Method in class org.apache.cassandra.tools.BulkLoadConnectionFactory
 
createDefaultMBeanName(String, String, String) - Static method in class org.apache.cassandra.metrics.DefaultNameFactory
 
createDescriptor(File, String, String, SSTableFormat.Type) - Static method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
createDirectory(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createDirectory(File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createFragmentIterator(SSTableReader, RandomAccessReader, DecoratedKey, long, boolean) - Static method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
Used only by scrubber to solve problems with data written after the END_OF_ROW marker.
createFunctionStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
CreateFunctionStatement - Class in org.apache.cassandra.cql3.statements
A CREATE FUNCTION statement parsed from a CQL query.
CreateFunctionStatement(FunctionName, String, String, List<ColumnIdentifier>, List<CQL3Type.Raw>, CQL3Type.Raw, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateFunctionStatement
 
createGlobal(CounterId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext
Creates a counter context with a single global, 2.1+ shard (a result of increment).
createHardLink(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createHardLink(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
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, IndexName, IndexTarget.Raw, IndexPropDefs, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateIndexStatement
 
createInRelation(List<ColumnIdentifier.Raw>, List<? extends Term.MultiColumnRaw>) - Static method in class org.apache.cassandra.cql3.MultiColumnRelation
Creates a multi-column IN relation with a list of IN values or markers.
createInRelation(ColumnIdentifier.Raw, List<Term.Raw>) - Static method in class org.apache.cassandra.cql3.SingleColumnRelation
 
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
Deprecated.
 
createKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
createKeyspaceFromName(String) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
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, boolean) - 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.format.SSTableReader
 
createLocal(CellName, long, long, long) - Static method in class org.apache.cassandra.db.BufferCounterCell
 
createLocal(long) - Method in class org.apache.cassandra.db.context.CounterContext
Creates a counter context with a single local shard.
createMessage() - Method in class org.apache.cassandra.db.AbstractRangeCommand
 
createMessage() - Method in class org.apache.cassandra.db.Mutation
 
createMessage(MessagingService.Verb) - Method in class org.apache.cassandra.db.Mutation
 
createMessage() - Method in class org.apache.cassandra.db.PagedRangeCommand
 
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.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.repair.messages.RepairMessage
 
createMessage(boolean, int) - Method in class org.apache.cassandra.streaming.messages.StreamInitMessage
Create serialized message.
createMessageForRetry(int) - Method in class org.apache.cassandra.streaming.StreamTransferTask
 
createMetricName(String) - Method in class org.apache.cassandra.metrics.DefaultNameFactory
 
createMetricName(String, String, String) - Static method in class org.apache.cassandra.metrics.DefaultNameFactory
 
createMetricName(String) - Method in interface org.apache.cassandra.metrics.MetricNameFactory
Create a qualified name from given metric name.
createNonInRelation(List<ColumnIdentifier.Raw>, Operator, Term.MultiColumnRaw) - Static method in class org.apache.cassandra.cql3.MultiColumnRelation
Creates a multi-column EQ, LT, LTE, GT, or GTE relation.
createNotification(String) - Static method in class org.apache.cassandra.utils.progress.ProgressEvent
 
createPooledReader() - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
 
createPooledReader() - Method in class org.apache.cassandra.io.util.PoolingSegmentedFile
 
createReader() - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
 
createReader() - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
 
createReader() - Method in class org.apache.cassandra.io.util.SegmentedFile
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
Deprecated.
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlInputFormat
 
createRemote(CounterId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext
Creates a counter context with a single remote shard.
createReplicationStrategy(String, Class<? extends AbstractReplicationStrategy>, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
createRole(AuthenticatedUser, RoleResource, RoleOptions) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
createRole(AuthenticatedUser, RoleResource, RoleOptions) - Method in interface org.apache.cassandra.auth.IRoleManager
Called during execution of a CREATE ROLE statement.
createRoleStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
CreateRoleStatement - Class in org.apache.cassandra.cql3.statements
 
CreateRoleStatement(RoleName, RoleOptions, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateRoleStatement
 
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
createServerSocket(int) - Method in class org.apache.cassandra.utils.RMIServerSocketFactoryImpl
 
createSingleMarkerInRelation(List<ColumnIdentifier.Raw>, Tuples.INRaw) - Static method in class org.apache.cassandra.cql3.MultiColumnRelation
Creates a multi-column IN relation with a marker for the IN values.
createSSLContext(EncryptionOptions, boolean) - Static method in class org.apache.cassandra.security.SSLFactory
 
createSslHandler() - Method in class org.apache.cassandra.transport.Server.AbstractSecureIntializer
 
createSSTableAndLengthPairs(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
createSSTableAndMinTimestampPairs(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
 
createTableFromName(String, String) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
createTableFromTablePartitionAndColumnsPartition(Row, Row) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
createTableFromTableRowAndColumnRows(UntypedResultSet.Row, UntypedResultSet) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
createTableStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
CreateTableStatement - Class in org.apache.cassandra.cql3.statements
A CREATE TABLE parsed from a CQL query statement.
CreateTableStatement(CFName, CFPropDefs, boolean, Set<ColumnIdentifier>, UUID) - Constructor for class org.apache.cassandra.cql3.statements.CreateTableStatement
 
CreateTableStatement.RawStatement - Class in org.apache.cassandra.cql3.statements
 
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
 
createThrottledReader(RateLimiter) - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
 
createThrottledReader(RateLimiter) - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
 
createThrottledReader(RateLimiter) - Method in class org.apache.cassandra.io.util.SegmentedFile
 
createTracingSession() - Method in class org.apache.cassandra.service.QueryState
 
createTriggerStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
CreateTriggerStatement - Class in org.apache.cassandra.cql3.statements
 
CreateTriggerStatement(CFName, String, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateTriggerStatement
 
createTypeStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
CreateTypeStatement - Class in org.apache.cassandra.cql3.statements
 
CreateTypeStatement(UTName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateTypeStatement
 
createUserStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
createValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
Deprecated.
 
createValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
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.
createWriter(ColumnFamilyStore, File, long, long, SSTableReader) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
 
createWriter(ColumnFamilyStore, long, long, SSTableFormat.Type) - Method in class org.apache.cassandra.streaming.StreamReader
 
createWriterForAntiCompaction(ColumnFamilyStore, File, int, long, Collection<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
 
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
 
csZoneDc - Variable in class org.apache.cassandra.locator.CloudstackSnitch
 
csZoneRack - Variable in class org.apache.cassandra.locator.CloudstackSnitch
 
CType - Interface in org.apache.cassandra.db.composites
A type for a Composite.
CType.Serializer - Interface in org.apache.cassandra.db.composites
 
current() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
returns the currently visible readers managed by this transaction
current(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
return the current version of the provided reader, whether or not it is visible or staged; i.e.
current() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
current() - Method 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.net.MessagingService
 
CURRENT_VERSION - Static variable in class org.apache.cassandra.streaming.messages.StreamMessage
 
CURRENT_VERSION - Static variable in class org.apache.cassandra.transport.Server
 
currentBlocked - Variable in class org.apache.cassandra.metrics.SEPMetrics
Number of tasks currently blocked, waiting to be accepted by the executor (because all threads are busy and the backing queue is full).
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).
currentBuffer() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
currentBytes - Variable in class org.apache.cassandra.streaming.ProgressInfo
 
currentKey - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
currentLimit() - Method in class org.apache.cassandra.db.filter.ExtendedFilter
 
currentlyRepairing(UUID, UUID) - Method in class org.apache.cassandra.service.ActiveRepairService
 
currentSession() - Method in class org.apache.cassandra.thrift.ThriftSessionManager
 
currentSuperColumn - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
currentWriter() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
Cursor<K,V extends K> - Class in org.apache.cassandra.utils.btree
An extension of Path which provides a public interface for iterating over or counting a subrange of the tree
Cursor() - Constructor for class org.apache.cassandra.utils.btree.Cursor
 
Custom(AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Custom
 
Custom(String) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Custom
 
CUSTOM_INDEX_OPTION_NAME - Static variable in class org.apache.cassandra.db.index.SecondaryIndex
 
customClass - Variable in class org.apache.cassandra.cql3.statements.IndexPropDefs
 
CustomClassLoader - Class in org.apache.cassandra.triggers
Custom class loader will load the classes from the class path, CCL will load the classes from the the URL first, if it cannot find the required class it will let the parent class loader do the its job.
CustomClassLoader(ClassLoader) - Constructor for class org.apache.cassandra.triggers.CustomClassLoader
 
CustomClassLoader(ClassLoader, File) - Constructor for class org.apache.cassandra.triggers.CustomClassLoader
 
CustomFrameBuffer(TNonblockingTransport, SelectionKey, AbstractNonblockingServer.AbstractSelectThread) - Constructor for class org.apache.cassandra.thrift.CustomTNonBlockingServer.CustomFrameBuffer
 
CustomPayloadMirroringQueryHandler - Class in org.apache.cassandra.cql3
Custom QueryHandler that sends custom request payloads back with the result.
CustomPayloadMirroringQueryHandler() - Constructor for class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
 
CustomTNonBlockingServer - Class in org.apache.cassandra.thrift
 
CustomTNonBlockingServer(TNonblockingServer.Args) - Constructor for class org.apache.cassandra.thrift.CustomTNonBlockingServer
 
CustomTNonBlockingServer.CustomFrameBuffer - Class in org.apache.cassandra.thrift
 
CustomTNonBlockingServer.Factory - Class in org.apache.cassandra.thrift
 
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
 

D

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
 
DATACENTERS_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
DatacenterSyncWriteResponseHandler<T> - 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, Keyspace, Runnable, WriteType) - Constructor for class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
DatacenterWriteResponseHandler<T> - 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, Keyspace, Runnable, WriteType) - Constructor for class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
dataDirectories - Static variable in class org.apache.cassandra.db.Directories
 
DataDirectory(File) - Constructor for class org.apache.cassandra.db.Directories.DataDirectory
 
DataIntegrityMetadata - Class in org.apache.cassandra.io.util
 
DataIntegrityMetadata() - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata
 
DataIntegrityMetadata.ChecksumValidator - Class in org.apache.cassandra.io.util
 
DataIntegrityMetadata.ChecksumWriter - Class in org.apache.cassandra.io.util
 
DataIntegrityMetadata.FileDigestValidator - Class in org.apache.cassandra.io.util
 
dataLength - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
 
dataLength - Variable in class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
 
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
 
DataOutputBuffer(ByteBuffer) - Constructor for class org.apache.cassandra.io.util.DataOutputBuffer
 
DataOutputBufferFixed - 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.
DataOutputBufferFixed() - Constructor for class org.apache.cassandra.io.util.DataOutputBufferFixed
 
DataOutputBufferFixed(int) - Constructor for class org.apache.cassandra.io.util.DataOutputBufferFixed
 
DataOutputBufferFixed(ByteBuffer) - Constructor for class org.apache.cassandra.io.util.DataOutputBufferFixed
 
DataOutputPlus - Interface in org.apache.cassandra.io.util
Extension to DataOutput that provides for writing ByteBuffer and Memory, potentially with an efficient implementation that is zero copy or at least has reduced bounds checking overhead.
DataOutputStreamPlus - Class in org.apache.cassandra.io.util
Abstract base class for DataOutputStreams that accept writes from ByteBuffer or Memory and also provide access to the underlying WritableByteChannel associated with their output stream.
DataOutputStreamPlus() - Constructor for class org.apache.cassandra.io.util.DataOutputStreamPlus
 
DataOutputStreamPlus(WritableByteChannel) - Constructor for class org.apache.cassandra.io.util.DataOutputStreamPlus
 
dataPresent - Variable in exception org.apache.cassandra.exceptions.ReadFailureException
 
dataPresent - Variable in exception org.apache.cassandra.exceptions.ReadTimeoutException
 
DataRange - Class in org.apache.cassandra.db
Groups key range and column filter for range queries.
DataRange(AbstractBounds<RowPosition>, IDiskAtomFilter) - Constructor for class org.apache.cassandra.db.DataRange
 
dataRange - Variable in class org.apache.cassandra.db.filter.ExtendedFilter
 
DataRange.Paging - Class in org.apache.cassandra.db
 
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.AbstractNativeCell
 
dataSize() - Method in class org.apache.cassandra.db.ColumnFamily
 
dataSize() - Method in class org.apache.cassandra.db.composites.AbstractComposite
 
dataSize() - Method in interface org.apache.cassandra.db.composites.Composite
 
dataSize() - Method in class org.apache.cassandra.db.DeletionInfo
 
dataSize() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
DataType - Enum in org.apache.cassandra.transport
 
dateOfFct - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
Deprecated.
Replaced by the TimeFcts.timeUuidToTimestamp function
dateStringToDays(String) - Static method in class org.apache.cassandra.serializers.SimpleDateSerializer
 
dateStringToTimestamp(String) - Static method in class org.apache.cassandra.serializers.TimestampSerializer
 
DateTieredCompactionStrategy - Class in org.apache.cassandra.db.compaction
 
DateTieredCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
 
DateTieredCompactionStrategyOptions - Class in org.apache.cassandra.db.compaction
 
DateTieredCompactionStrategyOptions(Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
DateTieredCompactionStrategyOptions() - Constructor for class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
dateToTimestamp - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
Function that convert a value of type TIMESTAMP into a DATE.
dateToUnixTimestamp - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
Function that convert a value of type DATE into an UNIX timestamp.
DateType - Class in org.apache.cassandra.db.marshal
Deprecated.
dayToTimeInMillis(int) - Static method in class org.apache.cassandra.serializers.SimpleDateSerializer
 
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.compress.CompressedRandomAccessReader
 
deallocate() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
debug(String) - Method in class org.apache.cassandra.hadoop.BulkRecordWriter.NullOutputHandler
Deprecated.
 
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
 
DEBUG_ENABLED - Static variable in class org.apache.cassandra.utils.concurrent.Ref
 
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(int, ThreadFactory) - 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
 
debugGap(long) - Method in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
 
debugTimestamp(long) - Method in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
 
debugTimestamps(Collection<C>) - Method in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
 
DecayingEstimatedHistogramReservoir - Class in org.apache.cassandra.metrics
A decaying histogram reservoir where values collected during each minute will be twice as significant as the values collected in the previous minute.
DecayingEstimatedHistogramReservoir() - Constructor for class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
Construct a decaying histogram with default number of buckets and without considering zeroes.
DecayingEstimatedHistogramReservoir(boolean) - Constructor for class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
Construct a decaying histogram with default number of buckets.
DecayingEstimatedHistogramReservoir(boolean, int) - Constructor for class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
Construct a decaying histogram.
DecimalSerializer - Class in org.apache.cassandra.serializers
 
DecimalSerializer() - Constructor for class org.apache.cassandra.serializers.DecimalSerializer
 
DecimalType - Class in org.apache.cassandra.db.marshal
 
decode(ByteBuf, int) - Method in class org.apache.cassandra.cql3.ResultSet.Codec
 
decode(ByteBuf, int) - Method in interface org.apache.cassandra.transport.CBCodec
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.cassandra.transport.Frame.Decoder
 
decode(ChannelHandlerContext, Frame, List<Object>) - Method in class org.apache.cassandra.transport.Frame.Decompressor
 
decode(ChannelHandlerContext, Frame, List) - Method in class org.apache.cassandra.transport.Message.ProtocolDecoder
 
decode(ByteBuf, int) - Method in class org.apache.cassandra.transport.OptionCodec
 
decodeEntry(DecoratedKey, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
 
decodeEntry(DecoratedKey, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexIncludingCollectionKey
 
decodeEntry(DecoratedKey, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
 
decodeEntry(DecoratedKey, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionValue
 
decodeEntry(DecoratedKey, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
 
decodeEntry(DecoratedKey, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
 
decodeJson(String) - Static method in class org.apache.cassandra.cql3.Json
 
decodeOne(ByteBuf, int) - Method in class org.apache.cassandra.transport.OptionCodec
 
Decoder(Connection.Factory) - Constructor for class org.apache.cassandra.transport.Frame.Decoder
 
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
 
Decommission - Class in org.apache.cassandra.tools.nodetool
 
Decommission() - Constructor for class org.apache.cassandra.tools.nodetool.Decommission
 
decompose(int, Object) - Method in class org.apache.cassandra.cql3.functions.UDFunction
Used by UDF implementations (both Java code generated by JavaSourceUDFFactory and script executor ScriptBasedUDF) to convert the Java object representation for the return value to the C* serialized representation.
decompose(Object...) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
decompose(T) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
decompose(Object...) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
decompose(Long) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
decompose(Object...) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
decompose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
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.LZ4Compressor
 
decompress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.SnappyCompressor
 
Decompressor() - Constructor for class org.apache.cassandra.transport.Frame.Decompressor
 
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) - Constructor for class org.apache.cassandra.db.DecoratedKey
 
decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
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
 
DEFAULT - Static variable in class org.apache.cassandra.cql3.BatchQueryOptions
 
DEFAULT - Static variable in class org.apache.cassandra.cql3.QueryOptions
 
DEFAULT_BASE_TIME_SECONDS - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
DEFAULT_BUCKET_COUNT - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
The default number of decayingBuckets.
DEFAULT_BUCKET_HIGH - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
DEFAULT_BUCKET_LOW - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
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_COLUMN_ALIAS - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_COMPACTION_STRATEGY_CLASS - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_COMPRESSOR - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_CONCURENCY_LEVEL - Static variable in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
DEFAULT_CQL_VERSION - Static variable in class org.apache.cassandra.service.ClientState
 
DEFAULT_CRC_CHECK_CHANCE - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
 
DEFAULT_DCLOCAL_READ_REPAIR_CHANCE - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_DEFAULT_TIME_TO_LIVE - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_EXPIRED_SSTABLE_CHECK_FREQUENCY_SECONDS - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
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.CassandraStorage
Deprecated.
 
DEFAULT_INPUT_FORMAT - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
DEFAULT_JMX_PORT - Static variable in class org.apache.cassandra.tools.AbstractJmxClient
 
DEFAULT_KEY_ALIAS - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MAX_COMPACTION_THRESHOLD - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MAX_FRAME_SIZE - Static variable in class org.apache.cassandra.thrift.SSLTransportFactory
 
DEFAULT_MAX_INDEX_INTERVAL - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MAX_SSTABLE_AGE_DAYS - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
Deprecated.
DEFAULT_MAX_WINDOW_SIZE_SECONDS - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
DEFAULT_MIN_COMPACTION_THRESHOLD - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MIN_INDEX_INTERVAL - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MIN_SSTABLE_SIZE - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
DEFAULT_OUTPUT_FORMAT - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
DEFAULT_OUTPUT_FORMAT - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
DEFAULT_READ_REPAIR_CHANCE - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_SMALLEST_SSTABLE_BYTES - Static variable in class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
 
DEFAULT_SPECULATIVE_RETRY - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_SSTABLE_SIZE - Static variable in class org.apache.cassandra.tools.StandaloneSplitter
 
DEFAULT_THROTTLE_LIMIT - Static variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
DEFAULT_TIMESTAMP_RESOLUTION - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
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_UNCHECKED_TOMBSTONE_COMPACTION_OPTION - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
DEFAULT_VALUE_ALIAS - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_WEIGHT - Static variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
default_weight - Variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
DEFAULT_WITH_ZERO_BUCKET_OFFSETS - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
DEFAULT_WITHOUT_ZERO_BUCKET_OFFSETS - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
DEFAULT_ZERO_CONSIDERATION - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
DefaultCompactionWriter - Class in org.apache.cassandra.db.compaction.writers
The default compaction writer - creates one output file in L0
DefaultCompactionWriter(ColumnFamilyStore, LifecycleTransaction, Set<SSTableReader>, boolean, OperationType) - Constructor for class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
 
DefaultConnectionFactory - Class in org.apache.cassandra.streaming
 
DefaultConnectionFactory() - Constructor for class org.apache.cassandra.streaming.DefaultConnectionFactory
 
DefaultFSErrorHandler - Class in org.apache.cassandra.service
 
DefaultFSErrorHandler() - Constructor for class org.apache.cassandra.service.DefaultFSErrorHandler
 
DefaultInteger - Class in org.apache.cassandra.utils
 
DefaultInteger(int) - Constructor for class org.apache.cassandra.utils.DefaultInteger
 
DefaultNameFactory - Class in org.apache.cassandra.metrics
MetricNameFactory that generates default MetricName of metrics.
DefaultNameFactory(String) - Constructor for class org.apache.cassandra.metrics.DefaultNameFactory
 
DefaultNameFactory(String, String) - Constructor for class org.apache.cassandra.metrics.DefaultNameFactory
 
defaultStatsMetadata() - Static method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
defaultTimeToLive(int) - Method in class org.apache.cassandra.config.CFMetaData
 
defaultValidator(AbstractType<?>) - Method in class org.apache.cassandra.config.CFMetaData
 
defined - Variable in class org.apache.cassandra.db.marshal.ColumnToCollectionType
 
definition() - Static method in class org.apache.cassandra.auth.AuthKeyspace
 
definition() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
definition() - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
definition() - Static method in class org.apache.cassandra.tracing.TraceKeyspace
 
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
 
DeflateCompressor - Class in org.apache.cassandra.io.compress
 
DelayedValue(List<Term>) - Constructor for class org.apache.cassandra.cql3.Lists.DelayedValue
 
DelayedValue(Comparator<ByteBuffer>, Map<Term, Term>) - Constructor for class org.apache.cassandra.cql3.Maps.DelayedValue
 
DelayedValue(Comparator<ByteBuffer>, Set<Term>) - Constructor for class org.apache.cassandra.cql3.Sets.DelayedValue
 
DelayedValue(TupleType, List<Term>) - Constructor for class org.apache.cassandra.cql3.Tuples.DelayedValue
 
DelayedValue(UserType, List<Term>) - Constructor for class org.apache.cassandra.cql3.UserTypes.DelayedValue
 
delete(DeletionTime) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
delete(DeletionInfo) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
delete(RangeTombstone) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
delete(DeletionTime) - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
delete(RangeTombstone) - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
delete(DeletionInfo) - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
delete(DeletionInfo) - Method in class org.apache.cassandra.db.ColumnFamily
 
delete(DeletionTime) - Method in class org.apache.cassandra.db.ColumnFamily
 
delete(RangeTombstone) - Method in class org.apache.cassandra.db.ColumnFamily
 
delete(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamily
If `columns` has any tombstones (top-level or range tombstones), they will be applied to this set of columns.
delete(DeletionInfo, ColumnFamily) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
delete(ByteBuffer, Cell, OpOrder.Group) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
delete(CompositesIndex.IndexedEntry, OpOrder.Group) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
 
delete(ByteBuffer, Cell, OpOrder.Group) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
 
delete(ByteBuffer, Cell, OpOrder.Group) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
 
delete(ByteBuffer, Cell, OpOrder.Group) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
Called when a column has been tombstoned or replaced.
delete(DecoratedKey, OpOrder.Group) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
cleans up deleted columns from cassandra cleanup compaction
delete(String, long) - Method in class org.apache.cassandra.db.Mutation
 
delete(String, CellName, long) - Method in class org.apache.cassandra.db.Mutation
 
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
 
delete() - Method in class org.apache.cassandra.streaming.StreamLockfile
 
deleteAsync(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
DeletedCell - Interface in org.apache.cassandra.db
 
deleteForCleanup(ByteBuffer, Cell, OpOrder.Group) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
deleteForCleanup(ByteBuffer, Cell, OpOrder.Group) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
Called when a column has been removed due to a cleanup operation.
deleteFromIndexes(DecoratedKey, List<Cell>, OpOrder.Group) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
Delete all columns from all indexes for this 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`.
deleteOldSnapshots() - Static method in class org.apache.cassandra.db.WindowsFailedSnapshotTracker
 
deleteOp() - Method in class org.apache.cassandra.cql3.CqlParser
 
Deleter(ColumnDefinition) - Constructor for class org.apache.cassandra.cql3.Constants.Deleter
 
deleteRange(String, Composite, Composite, long) - Method in class org.apache.cassandra.db.Mutation
 
deleteRecursive(File) - Static method in class org.apache.cassandra.io.util.FileUtils
Deletes all files and subdirectories under "dir".
deleteRecursiveOnExit(File) - Static method in class org.apache.cassandra.io.util.FileUtils
Schedules deletion of all file and subdirectories under "dir" on JVM shutdown.
deleteSelection() - Method in class org.apache.cassandra.cql3.CqlParser
 
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.Parsed - Class in org.apache.cassandra.cql3.statements
 
deleteWithConfirm(String, boolean, Throwable) - Static method in class org.apache.cassandra.io.util.FileUtils
 
deleteWithConfirm(File, boolean, Throwable) - Static method in class org.apache.cassandra.io.util.FileUtils
 
deleteWithConfirm(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
deleteWithConfirm(File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
deleting - Variable in class org.apache.cassandra.notifications.SSTableDeletingNotification
 
DELETION_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
 
deletionInfo() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
deletionInfo() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
deletionInfo() - Method in class org.apache.cassandra.db.ColumnFamily
 
DeletionInfo - Class in org.apache.cassandra.db
A combination of a top-level (or row) tombstone and range tombstones describing the deletions within a ColumnFamily (or row).
DeletionInfo(long, int) - Constructor for class org.apache.cassandra.db.DeletionInfo
Creates a DeletionInfo with only a top-level (row) tombstone.
DeletionInfo(DeletionTime) - Constructor for class org.apache.cassandra.db.DeletionInfo
 
DeletionInfo(Composite, Composite, Comparator<Composite>, long, int) - Constructor for class org.apache.cassandra.db.DeletionInfo
 
DeletionInfo(RangeTombstone, Comparator<Composite>) - Constructor for class org.apache.cassandra.db.DeletionInfo
 
DeletionInfo.InOrderTester - Class in org.apache.cassandra.db
This object allow testing whether a given column (name/timestamp) is deleted or not by this DeletionInfo, assuming that the columns given to this object are passed in forward or reversed comparator sorted order.
DeletionInfo.Serializer - Class in org.apache.cassandra.db
 
deletionInfoSerializer() - Method in class org.apache.cassandra.db.composites.AbstractCType
 
deletionInfoSerializer() - Method in interface org.apache.cassandra.db.composites.CType
 
DeletionTime - Class in org.apache.cassandra.db
A top-level (row) tombstone.
DeletionTime(long, int) - Constructor for class org.apache.cassandra.db.DeletionTime
 
deletionTime() - Method in class org.apache.cassandra.db.RowIndexEntry
 
DeletionTime.Serializer - Class in org.apache.cassandra.db
 
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
 
deliverHints(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
delta() - Method in class org.apache.cassandra.db.BufferCounterUpdateCell
 
delta() - Method in interface org.apache.cassandra.db.CounterUpdateCell
 
denseCFMetaData(String, String, AbstractType<?>, AbstractType<?>) - Static method in class org.apache.cassandra.config.CFMetaData
 
denseCFMetaData(String, String, AbstractType<?>) - Static method in class org.apache.cassandra.config.CFMetaData
 
deoverlapSlices(ColumnSlice[], Comparator<Composite>) - Static method in class org.apache.cassandra.db.filter.ColumnSlice
Takes an array of slices (potentially overlapping and in any order, though each individual slice must have its start before or equal its end in comparator orde) and return an equivalent array of non-overlapping slices in comparator order.
depth(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
 
depth - Variable in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
desc - Variable in class org.apache.cassandra.cache.KeyCacheKey
 
desc - Variable in exception org.apache.cassandra.exceptions.RepairException
 
desc - Variable in class org.apache.cassandra.repair.messages.RepairMessage
 
desc - Variable in class org.apache.cassandra.repair.RepairResult
 
desc - Variable in class org.apache.cassandra.repair.SyncTask
 
desc - Variable in class org.apache.cassandra.repair.Validator
 
desc - Variable in class org.apache.cassandra.streaming.StreamReader
 
descendingIterator() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
descendingSet() - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
 
descendingSet() - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
descendingSet() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
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_local_ring(String) - 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 - Class in org.apache.cassandra.tools.nodetool
 
DescribeCluster() - Constructor for class org.apache.cassandra.tools.nodetool.DescribeCluster
 
describeLocalRing(String) - Method in class org.apache.cassandra.service.StorageService
The same as describeRing(String) but considers only the part of the ring formed by nodes in the local DC.
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
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
 
DescribeRing - Class in org.apache.cassandra.tools.nodetool
 
DescribeRing() - Constructor for class org.apache.cassandra.tools.nodetool.DescribeRing
 
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.
description - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
 
description - Variable in class org.apache.cassandra.streaming.StreamResultFuture
 
description() - Method in class org.apache.cassandra.streaming.StreamSession
 
description - Variable in class org.apache.cassandra.streaming.StreamState
 
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, Descriptor.Type) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
A descriptor that assumes CURRENT_VERSION.
Descriptor(File, String, String, int, Descriptor.Type, SSTableFormat.Type) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
 
Descriptor(String, File, String, String, int, Descriptor.Type, SSTableFormat.Type) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
 
Descriptor(Version, File, String, String, int, Descriptor.Type, SSTableFormat.Type) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
 
descriptor - Variable in class org.apache.cassandra.io.sstable.SSTable
 
descriptor - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
Descriptor.Type - Enum in org.apache.cassandra.io.sstable
 
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, ColumnSerializer.Flag, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserialize(DataInput, ColumnFamily.Factory, ColumnSerializer.Flag, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserialize(DataInput) - Method in class org.apache.cassandra.db.ColumnSerializer
 
deserialize(DataInput, ColumnSerializer.Flag) - Method in class org.apache.cassandra.db.ColumnSerializer
 
deserialize(DataInput, ColumnSerializer.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.CounterMutation.CounterMutationSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
 
deserialize(DataInput) - Method in class org.apache.cassandra.db.DeletionTime.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) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter.Serializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
 
deserialize(DataInput, int, ColumnSerializer.Flag) - Method in class org.apache.cassandra.db.Mutation.MutationSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.db.Mutation.MutationSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
 
deserialize(DataInput, int, ColumnSerializer.Flag) - Method in class org.apache.cassandra.db.Row.RowSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.db.Row.RowSerializer
 
deserialize(DataInput, Version) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
 
deserialize(DataInput, Version) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
 
deserialize(DataInput, IPartitioner, int) - 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, IPartitioner, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
 
deserialize(DataInput, IPartitioner, int) - Method in interface org.apache.cassandra.dht.IPartitionerDependentSerializer
Deserialize into the specified DataInputStream instance.
deserialize(DataInput, IPartitioner, int) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.gms.EchoMessage.EchoMessageSerializer
 
deserialize(IPartitioner, DataInput) - Static method in class org.apache.cassandra.gms.TokenSerializer
 
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) - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo.Serializer
 
deserialize(DataInputStream, IPartitioner, boolean, int, int) - Method in class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
 
deserialize(Version, DataInput) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
 
deserialize(Version, DataInput) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataComponentSerializer
Deserialize metadata component from given input.
deserialize(Descriptor, EnumSet<MetadataType>) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
Deserialize specified metadata components from given descriptor.
deserialize(Descriptor, MetadataType) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
Deserialized only metadata component specified from given descriptor.
deserialize(Descriptor, EnumSet<MetadataType>) - Method in class org.apache.cassandra.io.sstable.metadata.LegacyMetadataSerializer
Deprecated.
Legacy serializer deserialize all components no matter what types are specified.
deserialize(Descriptor, EnumSet<MetadataType>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
 
deserialize(Descriptor, MetadataType) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
 
deserialize(Descriptor, FileDataInput, EnumSet<MetadataType>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
 
deserialize(Version, DataInput) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata.StatsMetadataSerializer
 
deserialize(Version, DataInput) - Method in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata.ValidationMetadataSerializer
 
deserialize(DataInput) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.repair.messages.AnticompactionRequest.AnticompactionRequestSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.repair.messages.CleanupMessage.CleanupMessageSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.repair.messages.PrepareMessage.PrepareMessageSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.repair.messages.SnapshotMessage.SnapshotMessageSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.repair.NodePair.NodePairSerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.BooleanSerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.ByteSerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.CollectionSerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.DecimalSerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.DoubleSerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.EmptySerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.FloatSerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.Int32Serializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.IntegerSerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.LongSerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.ShortSerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimeSerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimestampSerializer
 
deserialize(ByteBuffer) - Method in interface org.apache.cassandra.serializers.TypeSerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.UUIDSerializer
 
deserialize(DataInputStream, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.CounterCacheSerializer
 
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(ByteBuffer) - Static method in class org.apache.cassandra.service.pager.PagingState
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.service.paxos.Commit.CommitSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
 
deserialize(ReadableByteChannel, int, StreamSession) - Static method in class org.apache.cassandra.streaming.messages.StreamMessage
 
deserialize(ReadableByteChannel, int, StreamSession) - Method in interface org.apache.cassandra.streaming.messages.StreamMessage.Serializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
 
deserialize(byte) - Static method in enum org.apache.cassandra.tracing.Tracing.TraceType
 
deserialize(ByteBuf, int) - Static method in class org.apache.cassandra.transport.Event
 
deserialize(int) - Static method in enum org.apache.cassandra.transport.Frame.Header.Flag
 
deserialize(DataInput, int) - Method in class org.apache.cassandra.utils.BooleanSerializer
 
deserialize(DataInput) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
deserialize(DataInput, 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, 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
 
deserializeBody(DataInput, Composite, Version) - Method in class org.apache.cassandra.db.RangeTombstone.Serializer
 
deserializeBounds(DataInput) - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile.Builder
 
deserializeBounds(DataInput) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
 
deserializeCfId(DataInput, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserializeEvent(ByteBuf, int) - Static method in class org.apache.cassandra.transport.Event.SchemaChange
 
deserializeForNativeProtocol(ByteBuffer, int) - Method in class org.apache.cassandra.serializers.CollectionSerializer
 
deserializeForNativeProtocol(ByteBuffer, int) - Method in class org.apache.cassandra.serializers.ListSerializer
 
deserializeForNativeProtocol(ByteBuffer, int) - Method in class org.apache.cassandra.serializers.MapSerializer
 
deserializeForNativeProtocol(ByteBuffer, int) - Method in class org.apache.cassandra.serializers.SetSerializer
 
deserializeFromSSTable(DataInput, Version) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserializeFromSSTable(DataInput, Version) - Method in class org.apache.cassandra.db.OnDiskAtom.Serializer
 
deserializeFromSSTable(DataInput, ColumnSerializer.Flag, int, Version) - Method in class org.apache.cassandra.db.OnDiskAtom.Serializer
 
deserializeFromSSTable(DataInput, Version) - Method in class org.apache.cassandra.db.RangeTombstone.Serializer
 
deserializeFromSSTable(DataInput, Version) - Method in interface org.apache.cassandra.io.ISSTableSerializer
Deserialize into the specified DataInputStream instance in the format suited for SSTables.
deserializerSuperColumnFamily(DataInput, ColumnFamily, ColumnSerializer.Flag, int) - Static method in class org.apache.cassandra.db.SuperColumns
 
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
 
detail - Variable in exception org.apache.cassandra.exceptions.FunctionExecutionException
 
dfa13 - Variable in class org.apache.cassandra.cql3.CqlLexer
 
DFA13(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlLexer.DFA13
 
dfa13 - Variable in class org.apache.cassandra.cql3.CqlParser
 
DFA13(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlParser.DFA13
 
dfa130 - Variable in class org.apache.cassandra.cql3.CqlParser
 
DFA130(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlParser.DFA130
 
dfa131 - Variable in class org.apache.cassandra.cql3.CqlParser
 
DFA131(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlParser.DFA131
 
dfa149 - Variable in class org.apache.cassandra.cql3.CqlParser
 
DFA149(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlParser.DFA149
 
dfa151 - Variable in class org.apache.cassandra.cql3.CqlParser
 
DFA151(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlParser.DFA151
 
dfa153 - Variable in class org.apache.cassandra.cql3.CqlParser
 
DFA153(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlParser.DFA153
 
dfa155 - Variable in class org.apache.cassandra.cql3.CqlParser
 
DFA155(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlParser.DFA155
 
dfa158 - Variable in class org.apache.cassandra.cql3.CqlParser
 
DFA158(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlParser.DFA158
 
dfa164 - Variable in class org.apache.cassandra.cql3.CqlParser
 
DFA164(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlParser.DFA164
 
dfa169 - Variable in class org.apache.cassandra.cql3.CqlParser
 
DFA169(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlParser.DFA169
 
dfa170 - Variable in class org.apache.cassandra.cql3.CqlParser
 
DFA170(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlParser.DFA170
 
dfa179 - Variable in class org.apache.cassandra.cql3.CqlParser
 
DFA179(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlParser.DFA179
 
dfa2 - Variable in class org.apache.cassandra.cql3.CqlParser
 
DFA2(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlParser.DFA2
 
dfa21 - Variable in class org.apache.cassandra.cql3.CqlLexer
 
DFA21(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlLexer.DFA21
 
dfa40 - Variable in class org.apache.cassandra.cql3.CqlParser
 
DFA40(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlParser.DFA40
 
dfile - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
dfile - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
diff(Cell) - Method in class org.apache.cassandra.db.AbstractCell
 
diff(Cell) - Method in class org.apache.cassandra.db.BufferCounterCell
 
diff(Cell) - Method in class org.apache.cassandra.db.BufferCounterUpdateCell
 
diff(Cell) - Method in interface org.apache.cassandra.db.Cell
 
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(DeletionInfo) - Method in class org.apache.cassandra.db.DeletionInfo
Evaluates difference between this deletion info and superset for read repair
diff(Cell) - Method in class org.apache.cassandra.db.NativeCounterCell
 
diff(RangeTombstoneList) - Method in class org.apache.cassandra.db.RangeTombstoneList
Evaluates a diff between superset (known to be all merged tombstones) and this list for read repair
diffCounter(Cell) - Method in class org.apache.cassandra.db.AbstractCell
 
difference() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
 
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
DifferencingCounter(InetAddress) - Constructor for 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
 
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.cql3.CqlLexer
 
DIGIT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
directCheckSum(Adler32, ByteBuffer) - Static method in class org.apache.cassandra.utils.FBUtilities
 
direction - Variable in class org.apache.cassandra.streaming.ProgressInfo
 
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(CFMetaData) - Constructor for class org.apache.cassandra.db.Directories
Create Directories of given ColumnFamily.
Directories.DataDirectory - Class in org.apache.cassandra.db
 
Directories.FileAction - Enum in org.apache.cassandra.db
 
Directories.SSTableLister - Class in org.apache.cassandra.db
 
directory - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
directory - Variable in class org.apache.cassandra.io.sstable.Descriptor
canonicalized path to the directory where SSTable resides
dirtyString() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
disable() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
disable() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
disableAutoCompaction() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
disableAutoCompaction() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
disableAutoCompaction(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
disableAutoCompaction(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
disableAutoCompaction(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
DisableAutoCompaction - Class in org.apache.cassandra.tools.nodetool
 
DisableAutoCompaction() - Constructor for class org.apache.cassandra.tools.nodetool.DisableAutoCompaction
 
DisableBackup - Class in org.apache.cassandra.tools.nodetool
 
DisableBackup() - Constructor for class org.apache.cassandra.tools.nodetool.DisableBackup
 
DisableBinary - Class in org.apache.cassandra.tools.nodetool
 
DisableBinary() - Constructor for class org.apache.cassandra.tools.nodetool.DisableBinary
 
disabled() - Static method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
disableEarlyOpeningForTests - Static variable in class org.apache.cassandra.io.sstable.SSTableRewriter
 
DisableGossip - Class in org.apache.cassandra.tools.nodetool
 
DisableGossip() - Constructor for class org.apache.cassandra.tools.nodetool.DisableGossip
 
DisableHandoff - Class in org.apache.cassandra.tools.nodetool
 
DisableHandoff() - Constructor for class org.apache.cassandra.tools.nodetool.DisableHandoff
 
disableHintedHandoff() - Method in class org.apache.cassandra.tools.NodeProbe
 
DisableThrift - Class in org.apache.cassandra.tools.nodetool
 
DisableThrift() - Constructor for class org.apache.cassandra.tools.nodetool.DisableThrift
 
disableTombstoneCompactions - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
discardCompactionsInProgress() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
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.
Discarder(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Lists.Discarder
 
Discarder(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Discarder
 
DiscarderByIndex(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Lists.DiscarderByIndex
 
DiscarderByKey(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Maps.DiscarderByKey
 
discardFlushResults - Static variable in class org.apache.cassandra.db.ColumnFamilyStore
 
discardSSTables(long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Discard all SSTables that were created before given timestamp.
discoverComponentsFor(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTable
 
disk_access_mode - Variable in class org.apache.cassandra.config.Config
 
disk_failure_policy - Variable in class org.apache.cassandra.config.Config
 
diskAtomFilterSerializer() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
diskAtomFilterSerializer() - Method in interface org.apache.cassandra.db.composites.CellNameType
 
Dispatcher() - Constructor for class org.apache.cassandra.transport.Message.Dispatcher
 
displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql3.CqlLexer
 
displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql3.CqlParser
 
doAbort(Throwable) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
doAbort(Throwable) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
undo all of the changes made by this transaction, resetting the state to its original form
doAbort(Throwable) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter.TransactionalProxy
 
doAbort(Throwable) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
doAbort(Throwable) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
doAbort(Throwable) - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter.TransactionalProxy
 
doAbort(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter.TransactionalProxy
 
doAbort(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
 
doAntiCompaction(UUID, Collection<Range<Token>>) - Method in class org.apache.cassandra.service.ActiveRepairService
Submit anti-compaction jobs to CompactionManager.
doCallbackOnFailure() - Method in class org.apache.cassandra.net.MessageIn
 
doCommit(Throwable) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
doCommit(Throwable) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
point of no return: commit all changes, but leave all readers marked as compacting
doCommit(Throwable) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter.TransactionalProxy
 
doCommit(Throwable) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
doCommit(Throwable) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
doCommit(Throwable) - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter.TransactionalProxy
 
doCommit(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter.TransactionalProxy
 
doCommit(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
 
doFlush(int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
doFlush(int) - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
doFlush(int) - Method in class org.apache.cassandra.io.util.DataOutputBufferFixed
 
doMergeWith(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
 
doMergeWith(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQ
 
doMergeWith(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.IN
 
doMergeWith(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
 
doMergeWith(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
 
doMergeWith(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
 
doMergeWith(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQ
 
doMergeWith(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IN
 
doMergeWith(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
 
doMergeWith(TokenRestriction) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
Merges this restriction with the specified TokenRestriction.
doMergeWith(TokenRestriction) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQ
 
doMergeWith(TokenRestriction) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.Slice
 
doneWithNonLocalSession(TraceState) - Method in class org.apache.cassandra.tracing.Tracing
 
doPostCleanup(Throwable) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
doPostCleanup(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
perform an exception-safe post-abort cleanup
doPreCleanup(Throwable) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
doPreCleanup(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter.TransactionalProxy
 
doPreCleanup(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
perform an exception-safe pre-abort cleanup; this will still be run *after* commit
doPrepare() - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
doPrepare() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
doPrepare() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter.TransactionalProxy
 
doPrepare() - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
doPrepare() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
doPrepare() - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter.TransactionalProxy
 
doPrepare() - Method in class org.apache.cassandra.io.util.SequentialWriter.TransactionalProxy
 
doPrepare() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
Do any preparatory work prior to commit.
doShadowRound() - Method in class org.apache.cassandra.gms.Gossiper
Do a single 'shadow' round of gossip by retrieving endpoint states that will be stored exclusively in the map return value, instead of endpointStateMap.
DoubleSerializer - Class in org.apache.cassandra.serializers
 
DoubleSerializer() - Constructor for class org.apache.cassandra.serializers.DoubleSerializer
 
DoubleType - Class in org.apache.cassandra.db.marshal
 
doVerb(MessageIn<CounterMutation>, int) - Method in class org.apache.cassandra.db.CounterMutationVerbHandler
 
doVerb(MessageIn<Collection<Mutation>>, int) - Method in class org.apache.cassandra.db.DefinitionsUpdateVerbHandler
 
doVerb(MessageIn, int) - Method in class org.apache.cassandra.db.MigrationRequestVerbHandler
 
doVerb(MessageIn<Mutation>, int) - Method in class org.apache.cassandra.db.MutationVerbHandler
 
doVerb(MessageIn<Mutation>, int) - Method in class org.apache.cassandra.db.ReadRepairVerbHandler
 
doVerb(MessageIn<ReadCommand>, int) - Method in class org.apache.cassandra.db.ReadVerbHandler
 
doVerb(MessageIn, int) - Method in class org.apache.cassandra.db.SchemaCheckVerbHandler
 
doVerb(MessageIn<Truncation>, int) - Method in class org.apache.cassandra.db.TruncateVerbHandler
 
doVerb(MessageIn<GossipDigestAck2>, int) - Method in class org.apache.cassandra.gms.GossipDigestAck2VerbHandler
 
doVerb(MessageIn<GossipDigestAck>, int) - Method in class org.apache.cassandra.gms.GossipDigestAckVerbHandler
 
doVerb(MessageIn<GossipDigestSyn>, int) - Method in class org.apache.cassandra.gms.GossipDigestSynVerbHandler
 
doVerb(MessageIn, int) - Method in class org.apache.cassandra.gms.GossipShutdownVerbHandler
 
doVerb(MessageIn<T>, int) - 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, int) - Method in class org.apache.cassandra.net.ResponseVerbHandler
 
doVerb(MessageIn<RepairMessage>, int) - Method in class org.apache.cassandra.repair.RepairMessageVerbHandler
 
doVerb(MessageIn<EchoMessage>, int) - Method in class org.apache.cassandra.service.EchoVerbHandler
 
doVerb(MessageIn<Commit>, int) - Method in class org.apache.cassandra.service.paxos.CommitVerbHandler
 
doVerb(MessageIn<Commit>, int) - Method in class org.apache.cassandra.service.paxos.PrepareVerbHandler
 
doVerb(MessageIn<Commit>, int) - Method in class org.apache.cassandra.service.paxos.ProposeVerbHandler
 
doVerb(MessageIn<AbstractRangeCommand>, int) - Method in class org.apache.cassandra.service.RangeSliceVerbHandler
 
doVerb(MessageIn<SnapshotCommand>, int) - Method in class org.apache.cassandra.service.SnapshotVerbHandler
 
doVerb(MessageIn, int) - Method in class org.apache.cassandra.streaming.ReplicationFinishedVerbHandler
 
downsample(IndexSummary, int, int, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
Downsamples an existing index summary to a new sampling level.
Downsampling - Class in org.apache.cassandra.io.sstable
 
Downsampling() - Constructor for class org.apache.cassandra.io.sstable.Downsampling
 
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
 
Drain - Class in org.apache.cassandra.tools.nodetool
 
Drain() - Constructor for class org.apache.cassandra.tools.nodetool.Drain
 
driverType(AbstractType) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
Returns the Java Driver DataType for the C* internal type.
driverTypes(List<AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
Construct an array containing the Java Driver DataTypes for the C* internal types.
dropAggregate(UDAggregate) - Method in class org.apache.cassandra.config.Schema
 
dropAggregateStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
DropAggregateStatement - Class in org.apache.cassandra.cql3.statements
A DROP AGGREGATE statement parsed from a CQL query.
DropAggregateStatement(FunctionName, List<CQL3Type.Raw>, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropAggregateStatement
 
dropCf(UUID) - Method in class org.apache.cassandra.db.Keyspace
 
dropFunction(UDFunction) - Method in class org.apache.cassandra.config.Schema
 
dropFunctionStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
DropFunctionStatement - Class in org.apache.cassandra.cql3.statements
A DROP FUNCTION statement parsed from a CQL query.
DropFunctionStatement(FunctionName, List<CQL3Type.Raw>, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropFunctionStatement
 
dropIndexStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
DropIndexStatement - Class in org.apache.cassandra.cql3.statements
 
DropIndexStatement(IndexName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropIndexStatement
 
dropKeyspace(String) - Method in class org.apache.cassandra.config.Schema
 
dropKeyspaceStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
DropKeyspaceStatement - Class in org.apache.cassandra.cql3.statements
 
DropKeyspaceStatement(String, boolean) - 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.
dropPageCache(long) - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
 
dropPageCache(long) - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
 
dropPageCache(long) - Method in class org.apache.cassandra.io.util.SegmentedFile
 
dropped - Variable in class org.apache.cassandra.metrics.DroppedMessageMetrics
Number of dropped messages
droppedColumns(Map<ColumnIdentifier, Long>) - Method in class org.apache.cassandra.config.CFMetaData
 
DroppedMessageMetrics - Class in org.apache.cassandra.metrics
Metrics for dropped messages by verb.
DroppedMessageMetrics(MessagingService.Verb) - Constructor for class org.apache.cassandra.metrics.DroppedMessageMetrics
 
dropRole(AuthenticatedUser, RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
dropRole(AuthenticatedUser, RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
Called during execution of DROP ROLE statement, as well we removing any main record of the role from the system this implies that we want to revoke this role from all other roles that it has been granted to.
dropRoleStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
DropRoleStatement - Class in org.apache.cassandra.cql3.statements
 
DropRoleStatement(RoleName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropRoleStatement
 
dropSSTables() - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
dropSSTables(Throwable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
dropSSTables(Predicate<SSTableReader>, OperationType, Throwable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
removes all sstables that are not busy compacting.
dropSSTablesIfInvalid(Throwable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
dropTable(String, String) - Method in class org.apache.cassandra.config.Schema
 
dropTableStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
DropTableStatement - Class in org.apache.cassandra.cql3.statements
 
DropTableStatement(CFName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropTableStatement
 
dropTriggerStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
DropTriggerStatement - Class in org.apache.cassandra.cql3.statements
 
DropTriggerStatement(CFName, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropTriggerStatement
 
dropType(UserType) - Method in class org.apache.cassandra.config.Schema
 
dropTypeFromSchemaMutation(KSMetaData, UserType, long) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
dropTypeStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
DropTypeStatement - Class in org.apache.cassandra.cql3.statements
 
DropTypeStatement(UTName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropTypeStatement
 
dropUserStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
dst - Variable in class org.apache.cassandra.repair.messages.SyncRequest
 
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
 
duplicateByteBuffer(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
duplicateDirectByteBuffer(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
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.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
 
EchoMessage - Class in org.apache.cassandra.gms
 
EchoMessage.EchoMessageSerializer - Class in org.apache.cassandra.gms
 
EchoMessageSerializer() - Constructor for class org.apache.cassandra.gms.EchoMessage.EchoMessageSerializer
 
EchoVerbHandler - Class in org.apache.cassandra.service
 
EchoVerbHandler() - Constructor for class org.apache.cassandra.service.EchoVerbHandler
 
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
 
element - Variable in class org.apache.cassandra.db.composites.SimpleComposite
 
ElementDeletion(ColumnIdentifier.Raw, Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.ElementDeletion
 
ElementDiscarder(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Sets.ElementDiscarder
 
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.cql3.Tuples.DelayedValue
 
elements - Variable in class org.apache.cassandra.cql3.Tuples.Value
 
elements - Variable in class org.apache.cassandra.serializers.ListSerializer
 
elements - Variable in class org.apache.cassandra.serializers.SetSerializer
 
elementsCopy(AbstractAllocator) - Method in class org.apache.cassandra.db.composites.CompoundComposite
 
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.cql3.CqlLexer
 
empty(CFMetaData) - Static method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Creates a new empty StatementRestrictions.
EMPTY - Static variable in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
empty() - Static method in class org.apache.cassandra.cql3.VariableSpecifications
Returns an empty instance of VariableSpecifications.
EMPTY - Static variable in class org.apache.cassandra.db.composites.Composites
 
empty() - Static method in class org.apache.cassandra.db.lifecycle.SSTableIntervalTree
 
empty() - Static method in class org.apache.cassandra.utils.btree.BTree
Returns an empty BTree
EMPTY_BYTE_BUFFER - Static variable in class org.apache.cassandra.utils.ByteBufferUtil
 
EMPTY_PARSER - Static variable in class org.apache.cassandra.db.marshal.TypeParser
 
emptyColumnFamily - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
emptyCommit(ByteBuffer, CFMetaData) - Static method in class org.apache.cassandra.service.paxos.Commit
 
emptyRows - Variable in class org.apache.cassandra.db.compaction.Scrubber.ScrubResult
 
EmptySerializer - Class in org.apache.cassandra.serializers
 
EmptySerializer() - Constructor for class org.apache.cassandra.serializers.EmptySerializer
 
EmptySSTableScanner(String) - Constructor for class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
 
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.db.compaction.AbstractCompactionStrategy
 
enable() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
enable_user_defined_functions - Variable in class org.apache.cassandra.config.Config
 
enableActivityNotification(String) - Method in class org.apache.cassandra.tracing.TraceState
Activate notification with provided tag name.
enableAutoCompaction() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
enableAutoCompaction(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
used for tests - to be able to check things after a minor compaction
enableAutoCompaction(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
enableAutoCompaction(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
enableAutoCompaction(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
EnableAutoCompaction - Class in org.apache.cassandra.tools.nodetool
 
EnableAutoCompaction() - Constructor for class org.apache.cassandra.tools.nodetool.EnableAutoCompaction
 
EnableBackup - Class in org.apache.cassandra.tools.nodetool
 
EnableBackup() - Constructor for class org.apache.cassandra.tools.nodetool.EnableBackup
 
EnableBinary - Class in org.apache.cassandra.tools.nodetool
 
EnableBinary() - Constructor for class org.apache.cassandra.tools.nodetool.EnableBinary
 
enabled - Variable in class org.apache.cassandra.config.EncryptionOptions.ClientEncryptionOptions
 
enabled - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
EnableGossip - Class in org.apache.cassandra.tools.nodetool
 
EnableGossip() - Constructor for class org.apache.cassandra.tools.nodetool.EnableGossip
 
EnableHandoff - Class in org.apache.cassandra.tools.nodetool
 
EnableHandoff() - Constructor for class org.apache.cassandra.tools.nodetool.EnableHandoff
 
enableHintedHandoff() - Method in class org.apache.cassandra.tools.NodeProbe
 
enableHintedHandoff(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
enableSSTableDevelopmentTestMode - Static variable in interface org.apache.cassandra.io.sstable.format.SSTableFormat
 
EnableThrift - Class in org.apache.cassandra.tools.nodetool
 
EnableThrift() - Constructor for class org.apache.cassandra.tools.nodetool.EnableThrift
 
enableUserDefinedFunctions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
encode(ResultSet, ByteBuf, int) - Method in class org.apache.cassandra.cql3.ResultSet.Codec
 
encode(T, ByteBuf, int) - Method in interface org.apache.cassandra.transport.CBCodec
 
encode(ChannelHandlerContext, Frame, List<Object>) - Method in class org.apache.cassandra.transport.Frame.Compressor
 
encode(ChannelHandlerContext, Frame, List<Object>) - Method in class org.apache.cassandra.transport.Frame.Encoder
 
encode(ChannelHandlerContext, Message, List) - Method in class org.apache.cassandra.transport.Message.ProtocolEncoder
 
encode(Map<T, Object>, int) - Method in class org.apache.cassandra.transport.OptionCodec
 
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
 
encodedSize(ResultSet, int) - Method in class org.apache.cassandra.cql3.ResultSet.Codec
 
encodedSize(T, int) - Method in interface org.apache.cassandra.transport.CBCodec
 
encodedUTF8Length(String) - Static method in class org.apache.cassandra.db.TypeSizes
 
Encoder() - Constructor for class org.apache.cassandra.transport.Frame.Encoder
 
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.ServerEncryptionOptions - Class in org.apache.cassandra.config
 
EncryptionOptions.ServerEncryptionOptions.InternodeEncryption - Enum in org.apache.cassandra.config
 
end() - Method in class org.apache.cassandra.db.AbstractNativeCell
 
end() - Method in class org.apache.cassandra.db.composites.AbstractComposite
 
end() - Method in interface org.apache.cassandra.db.composites.Composite
 
END_OF_ROW - Static variable in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
endOf(ByteBuffer) - Static method in class org.apache.cassandra.db.SuperColumns
 
endPoint() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
endpoint - Variable in class org.apache.cassandra.repair.TreeResponse
 
endpoint - Variable in class org.apache.cassandra.tools.nodetool.HostStat
 
endpoint1 - Variable in class org.apache.cassandra.repair.NodePair
 
endpoint2 - Variable in class org.apache.cassandra.repair.NodePair
 
endpoint_snitch - Variable in class org.apache.cassandra.config.Config
 
EndpointFilter(String, Multimap<String, InetAddress>) - Constructor for class org.apache.cassandra.db.BatchlogManager.EndpointFilter
 
endpoints - Variable in class org.apache.cassandra.repair.RepairSession
 
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.
endTimerPeriod(int) - Static method in class org.apache.cassandra.utils.WindowsTimer
 
enforceLimit(ColumnDefinition, List<Cell>, int) - Method in class org.apache.cassandra.db.marshal.CollectionType
 
enqueue(MessageOut<?>, int) - Method in class org.apache.cassandra.net.OutboundTcpConnection
 
ensureHashInitialised() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
ensureHasPermission(Permission, IResource) - Method in class org.apache.cassandra.service.ClientState
 
ensureHasPermission(Permission, Function) - Method in class org.apache.cassandra.service.ClientState
 
ensureIsSuper(String) - Method in class org.apache.cassandra.service.ClientState
 
ensureNotAnonymous() - Method in class org.apache.cassandra.service.ClientState
 
ensureReleased(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Ref
 
ensureReleased() - Method in class org.apache.cassandra.utils.concurrent.Ref
 
ensureRemaining(int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
entity - Variable in exception org.apache.cassandra.exceptions.UnrecognizedEntityException
The unrecognized entity.
entries - Variable in class org.apache.cassandra.cql3.Maps.Literal
 
entries - Variable in class org.apache.cassandra.cql3.UserTypes.Literal
 
entries - Variable in class org.apache.cassandra.metrics.CacheMetrics
Total number of cache entries
entriesAtSamplingLevel(int, int) - Static method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
entriesLength - Variable in class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
 
ENTRY_OVERHEAD_SIZE - Static variable in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
entrySet() - Method in class org.apache.cassandra.utils.BiMultiValMap
 
entrySet() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
enumeratekeys(Descriptor, PrintStream, CFMetaData) - Static method in class org.apache.cassandra.tools.SSTableExport
Enumerate row keys from an SSTableReader and write the result to a PrintStream.
eoc() - Method in class org.apache.cassandra.db.AbstractNativeCell
 
eoc() - Method in class org.apache.cassandra.db.composites.AbstractComposite
 
eoc() - Method in class org.apache.cassandra.db.composites.BoundedComposite
 
eoc() - Method in interface org.apache.cassandra.db.composites.Composite
 
EOF - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
EOF - Static variable in class org.apache.cassandra.cql3.CqlParser
 
EQ(List<ColumnDefinition>, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQ
 
EQ(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQ
 
EQ(CType, List<ColumnDefinition>, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQ
 
EQ - Static variable in class org.apache.cassandra.io.sstable.format.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.FunctionResource
 
equals(Object) - Method in class org.apache.cassandra.auth.PermissionDetails
 
equals(Object) - Method in class org.apache.cassandra.auth.RoleResource
 
equals(Object) - Method in class org.apache.cassandra.cache.CachingOptions
 
equals(Object) - Method in class org.apache.cassandra.cache.CachingOptions.KeyCache
 
equals(Object) - Method in class org.apache.cassandra.cache.CachingOptions.RowCache
 
equals(Object) - Method in class org.apache.cassandra.cache.CounterCacheKey
 
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.CFMetaData.SpeculativeRetry
 
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.config.ParameterizedClass
 
equals(ParameterizedClass) - Method in class org.apache.cassandra.config.ParameterizedClass
 
equals(Object) - Method in class org.apache.cassandra.config.TriggerDefinition
 
equals(Object) - Method in class org.apache.cassandra.config.UTMetaData
 
equals(Object) - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
equals(Object) - Method in class org.apache.cassandra.cql3.ColumnIdentifier.Raw
 
equals(Object) - Method in class org.apache.cassandra.cql3.ColumnSpecification
 
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.cql3.CQL3Type.Tuple
 
equals(Object) - Method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.FunctionName
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
equals(ListType, Lists.Value) - Method in class org.apache.cassandra.cql3.Lists.Value
 
equals(MapType, Maps.Value) - Method in class org.apache.cassandra.cql3.Maps.Value
 
equals(Object) - Method in class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
 
equals(Object) - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
equals(SetType, Sets.Value) - Method in class org.apache.cassandra.cql3.Sets.Value
 
equals(Object) - Method in class org.apache.cassandra.db.AbstractCell
 
equals(Cell) - Method in class org.apache.cassandra.db.AbstractCell
 
equals(Object) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
equals(CellName) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
equals(Cell) - Method in class org.apache.cassandra.db.BufferCounterCell
 
equals(Cell) - Method in class org.apache.cassandra.db.BufferExpiringCell
 
equals(Object) - Method in class org.apache.cassandra.db.ClockAndCount
 
equals(Object) - Method in class org.apache.cassandra.db.ColumnFamily
 
equals(Object) - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
equals(CommitLogDescriptor) - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
equals(Object) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition
 
equals(Object) - Method in class org.apache.cassandra.db.composites.AbstractComposite
 
equals(Object) - Method in class org.apache.cassandra.db.composites.AbstractCType
 
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.filter.ColumnSlice
 
equals(Object) - Method in class org.apache.cassandra.db.IndexExpression
 
equals(Object) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState
 
equals(LifecycleTransaction.ReaderState) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState
 
equals(Object) - Method in class org.apache.cassandra.db.marshal.TupleType
 
equals(Object) - Method in class org.apache.cassandra.db.marshal.UserType
 
equals(Cell) - Method in class org.apache.cassandra.db.NativeCounterCell
 
equals(Cell) - Method in class org.apache.cassandra.db.NativeExpiringCell
 
equals(Object) - Method in class org.apache.cassandra.db.RangeTombstoneList
 
equals(Object) - Method in class org.apache.cassandra.dht.Bounds
 
equals(Object) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.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.LocalPartitioner.LocalToken
 
equals(Object) - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
equals(Object) - Method in class org.apache.cassandra.dht.Range
 
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.format.SSTableReader
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.format.Version
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
 
equals(Object) - Method in class org.apache.cassandra.io.util.Memory
 
equals(Object) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
 
equals(Object) - Method in class org.apache.cassandra.repair.messages.ValidationRequest
 
equals(Object) - Method in class org.apache.cassandra.repair.NodePair
 
equals(Object) - Method in class org.apache.cassandra.repair.RepairJobDesc
 
equals(Object) - Method in class org.apache.cassandra.service.FileCacheService.CacheKey
 
equals(Object) - Method in class org.apache.cassandra.service.paxos.Commit
 
equals(Object) - Method in class org.apache.cassandra.streaming.messages.FileMessageHeader
 
equals(Object) - Method in class org.apache.cassandra.streaming.ProgressInfo
ProgressInfo is considered to be equal only when all attributes except currentBytes are equal.
equals(Object) - Method in class org.apache.cassandra.streaming.StreamResultFuture
 
equals(Object) - Method in class org.apache.cassandra.streaming.StreamSummary
 
equals(Object) - Method in class org.apache.cassandra.transport.Event.SchemaChange
 
equals(Object) - Method in class org.apache.cassandra.transport.Event.StatusChange
 
equals(Object) - Method in class org.apache.cassandra.transport.Event.TopologyChange
 
equals(Object) - Method in class org.apache.cassandra.utils.CassandraVersion
 
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.RMIServerSocketFactoryImpl
 
equals(Object) - Method in class org.apache.cassandra.utils.StreamingHistogram
 
equalsIgnoringCompression(CommitLogDescriptor) - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
equalsNativeFunction(FunctionName) - Method in class org.apache.cassandra.cql3.functions.FunctionName
 
error - Variable in class org.apache.cassandra.transport.messages.ErrorMessage
 
error(long, String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
error(String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
error(long, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
 
error(Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
 
ErrorCollector - Class in org.apache.cassandra.cql3
ErrorListener that collect and enhance the errors send by the CQL lexer and parser.
ErrorCollector(String) - Constructor for class org.apache.cassandra.cql3.ErrorCollector
Creates a new ErrorCollector instance to collect the syntax errors associated to the specified CQL query.
ErrorListener - Interface in org.apache.cassandra.cql3
Listener used to collect the syntax errors emitted by the Lexer and Parser.
ErrorMessage - Class in org.apache.cassandra.transport.messages
Message to indicate an error to the client.
ErrorMessage.WrappedException - Exception in org.apache.cassandra.transport.messages
 
escape(String) - Static method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
establishConnection() - Method in class org.apache.cassandra.transport.SimpleClient
 
estimateCompactionGain(Set<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
Estimates how much of the keys we would keep if the sstables were compacted together
estimatedColumnCount - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
estimatedColumnCount(EstimatedHistogram) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
estimatedColumnCount - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
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(int, boolean) - Constructor for class org.apache.cassandra.utils.EstimatedHistogram
 
EstimatedHistogram(long[]) - Constructor for class org.apache.cassandra.utils.EstimatedHistogram
Create EstimatedHistogram from only bucket data.
EstimatedHistogram(long[], long[]) - Constructor for class org.apache.cassandra.utils.EstimatedHistogram
 
EstimatedHistogram.EstimatedHistogramSerializer - Class in org.apache.cassandra.utils
 
EstimatedHistogramSerializer() - Constructor for class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
estimatedKeys() - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
estimated number of keys we should write
estimatedKeys() - Method in class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
 
estimatedKeys() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
estimatedKeys - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
 
estimatedKeys - Variable in class org.apache.cassandra.streaming.StreamReader
 
estimatedKeys - Variable in class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
 
estimatedKeysForRange(Range<Token>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
estimatedKeysForRanges(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
estimatedRemainingTasks - Variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
 
estimatedRemainingTasks - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
estimatedRowCount - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Approximate number of keys in table.
estimatedRowSize - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
estimatedRowSize(EstimatedHistogram) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
estimatedRowSize - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
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.metadata.MetadataCollector
 
estimatedTombstoneDropTime - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
estimatedTotalKeys - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
estimateKeys() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
estimateKeys() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
estimateResultRows() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
estimateResultRows() - Method in class org.apache.cassandra.db.index.SecondaryIndex
 
estimateRowsFromIndex(RandomAccessReader) - Method in class org.apache.cassandra.io.sstable.SSTable
 
evaluateResponse(byte[]) - Method in interface org.apache.cassandra.auth.IAuthenticator.SaslNegotiator
Evaluates the client response data and generates a byte[] reply which may be a further challenge or purely informational in the case that the negotiation is completed on this round.
Event - Class in org.apache.cassandra.transport
 
event - Variable in class org.apache.cassandra.transport.messages.EventMessage
 
Event.NodeEvent - Class in org.apache.cassandra.transport
 
Event.SchemaChange - Class in org.apache.cassandra.transport
 
Event.SchemaChange.Change - Enum in org.apache.cassandra.transport
 
Event.SchemaChange.Target - 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 - Static variable in class org.apache.cassandra.tracing.TraceKeyspace
 
eventSerializedSize(int) - Method in class org.apache.cassandra.transport.Event
 
eventSerializedSize(int) - Method in class org.apache.cassandra.transport.Event.SchemaChange
 
eventSerializedSize(int) - Method in class org.apache.cassandra.transport.Event.StatusChange
 
eventSerializedSize(int) - Method in class org.apache.cassandra.transport.Event.TopologyChange
 
eventType - Variable in class org.apache.cassandra.streaming.StreamEvent
 
eventTypes - Variable in class org.apache.cassandra.transport.messages.RegisterMessage
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.cassandra.transport.Message.ExceptionHandler
 
ExceptionCode - Enum in org.apache.cassandra.exceptions
Exceptions code, as defined by the binary protocol.
ExceptionHandler() - Constructor for class org.apache.cassandra.transport.Message.ExceptionHandler
 
exceptions - Static variable in class org.apache.cassandra.metrics.StorageMetrics
 
ExcludeLocalNodeFilter() - Constructor for class org.apache.cassandra.dht.RangeStreamer.ExcludeLocalNodeFilter
 
ExcludingBounds<T extends RingPosition<T>> - 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) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
execute(Runnable, ExecutorLocals) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
execute(Runnable, ExecutorLocals) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
execute(Runnable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
execute(Runnable, ExecutorLocals) - Method in interface org.apache.cassandra.concurrent.LocalAwareExecutorService
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Constants.Adder
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Constants.Deleter
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Constants.Setter
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Constants.Substracter
 
execute(QueryState, QueryOptions) - Method in interface org.apache.cassandra.cql3.CQLStatement
Execute the statement and return the resulting result or null if there is no result.
execute(int, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.FromJsonFct
 
execute(int, List<ByteBuffer>) - Method in interface org.apache.cassandra.cql3.functions.ScalarFunction
Applies this function to the specified parameter.
execute(int, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.ToJsonFct
 
execute(int, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.TokenFct
 
execute(int, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.Appender
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.Discarder
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.DiscarderByIndex
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.Prepender
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.Setter
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.SetterByIndex
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Maps.DiscarderByKey
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Maps.Putter
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Maps.Setter
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Maps.SetterByKey
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Operation
Execute the operation.
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Sets.Adder
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Sets.Discarder
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Sets.ElementDiscarder
 
execute(ByteBuffer, ColumnFamily, Composite, UpdateParameters) - Method in class org.apache.cassandra.cql3.Sets.Setter
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterRoleStatement
 
execute(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
 
execute(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
execute(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
execute(QueryState, BatchQueryOptions) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateRoleStatement
 
execute(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropRoleStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.GrantPermissionsStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.GrantRoleStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListRolesStatement
 
execute(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.RevokePermissionsStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.RevokeRoleStatement
 
execute(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
 
execute(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
execute(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
 
execute(QueryState, QueryOptions) - 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() - Method in interface org.apache.cassandra.service.StartupCheck
Run some test to determine whether the system is safe to be started In the case where a test determines it is not safe to proceed, the test should log a message regarding the reason for the failure and ideally the steps required to remedy the problem.
execute() - Method in class org.apache.cassandra.streaming.StreamPlan
Execute this StreamPlan asynchronously.
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Assassinate
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.BootstrapResume
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Cleanup
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ClearSnapshot
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Compact
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.CompactionHistory
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.CompactionStats
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Decommission
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DescribeCluster
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DescribeRing
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DisableAutoCompaction
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DisableBackup
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DisableBinary
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DisableGossip
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DisableHandoff
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DisableThrift
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Drain
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.EnableAutoCompaction
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.EnableBackup
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.EnableBinary
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.EnableGossip
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.EnableHandoff
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.EnableThrift
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.FailureDetectorInfo
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Flush
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GcStats
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetCompactionThreshold
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetCompactionThroughput
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetEndpoints
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetInterDCStreamThroughput
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetLoggingLevels
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetSSTables
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetStreamThroughput
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetTraceProbability
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GossipInfo
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Info
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.InvalidateCounterCache
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.InvalidateKeyCache
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.InvalidateRowCache
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Join
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ListSnapshots
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Move
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.NetStats
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.PauseHandoff
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ProxyHistograms
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.RangeKeySample
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Rebuild
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.RebuildIndex
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Refresh
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.RefreshSizeEstimates
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ReloadTriggers
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.RemoveNode
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Repair
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ResetLocalSchema
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ResumeHandoff
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Ring
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Scrub
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetCacheCapacity
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetCacheKeysToSave
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetCompactionThreshold
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetCompactionThroughput
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetHintedHandoffThrottleInKB
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetInterDCStreamThroughput
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetLoggingLevel
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetStreamThroughput
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetTraceProbability
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Snapshot
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Status
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.StatusBackup
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.StatusBinary
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.StatusGossip
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.StatusHandoff
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.StatusThrift
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Stop
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.StopDaemon
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.TableHistograms
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.TableStats
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.TopPartitions
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.TpStats
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.TruncateHints
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.UpgradeSSTable
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Verify
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Version
 
execute(QueryState) - Method in class org.apache.cassandra.transport.Message.Request
 
execute(QueryState) - Method in class org.apache.cassandra.transport.messages.AuthResponse
 
execute(QueryState) - Method in class org.apache.cassandra.transport.messages.BatchMessage
 
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(Runnable) - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
 
execute(String, ConsistencyLevel) - Method in class org.apache.cassandra.transport.SimpleClient
 
execute(String, List<ByteBuffer>, ConsistencyLevel) - Method in class org.apache.cassandra.transport.SimpleClient
 
execute(Message.Request) - Method in class org.apache.cassandra.transport.SimpleClient
 
execute(ByteBuffer, ColumnFamily) - Method in class org.apache.cassandra.triggers.TriggerExecutor
Augment a partition update by executing triggers to generate an intermediate set of mutations, then merging the ColumnFamily from each mutation with those supplied.
execute(Collection<? extends IMutation>) - Method in class org.apache.cassandra.triggers.TriggerExecutor
Takes a collection of mutations and possibly augments it by adding extra mutations generated by configured triggers.
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
 
executeAsync() - Method in class org.apache.cassandra.service.AbstractReadExecutor
send the initial set of requests
executeInternal(QueryState, QueryOptions) - Method in interface org.apache.cassandra.cql3.CQLStatement
Variant of execute used for internal query against the system tables, and thus only query the local node.
executeInternal(String, Object...) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
executeInternal(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
 
executeInternal(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
executeInternal(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
executeInternal(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
executeInternal(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
 
executeInternal(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
executeInternal(QueryState, QueryOptions, long) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
executeInternal(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
 
executeInternal(QueryState, QueryOptions) - 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
 
executeInternalWithCondition(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
executeInternalWithNow(long, String, Object...) - Static method in class org.apache.cassandra.cql3.QueryProcessor
A special version of executeInternal that takes the time used as "now" for the query in argument.
executeInternalWithoutCondition(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
executeInternalWithPaging(String, int, Object...) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
executeLocally() - Method in class org.apache.cassandra.db.AbstractRangeCommand
 
executeLocally() - Method in class org.apache.cassandra.db.PagedRangeCommand
 
executeLocally() - Method in class org.apache.cassandra.db.RangeSliceCommand
 
ExecuteMessage - Class in org.apache.cassandra.transport.messages
 
ExecuteMessage(MD5Digest, QueryOptions) - Constructor for class org.apache.cassandra.transport.messages.ExecuteMessage
 
executeOnceInternal(String, Object...) - Static method in class org.apache.cassandra.cql3.QueryProcessor
Same than executeInternal, but to use for queries we know are only executed once so that the created statement object is not cached.
executePrepared(byte[], List<ByteBuffer>, ConsistencyLevel) - Method in class org.apache.cassandra.transport.SimpleClient
 
executeUserDefined(int, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.ScriptBasedUDF
 
executeUserDefined(int, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
executeWithCondition(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
ExecutorLocal<T> - Interface in org.apache.cassandra.concurrent
 
ExecutorLocals - Class in org.apache.cassandra.concurrent
 
exists() - Method in class org.apache.cassandra.auth.DataResource
 
exists() - Method in class org.apache.cassandra.auth.FunctionResource
 
exists() - Method in interface org.apache.cassandra.auth.IResource
 
exists() - Method in class org.apache.cassandra.auth.RoleResource
 
EXPIRATION_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
 
EXPIRED_SSTABLE_CHECK_FREQUENCY_SECONDS_KEY - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
expiredSSTableCheckFrequency - Variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
ExpiredTraceState - Class in org.apache.cassandra.tracing
 
ExpiredTraceState(UUID, Tracing.TraceType) - Constructor for class org.apache.cassandra.tracing.ExpiredTraceState
 
ExpiringCell - Interface in org.apache.cassandra.db
Alternative to Cell that have an expiring time.
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[], CFMetaData) - 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, DataRange, int, boolean, long) - Constructor for class org.apache.cassandra.db.filter.ExtendedFilter
 
ExtendedFilter.WithClauses - Class in org.apache.cassandra.db.filter
 
ExternalClient(Configuration) - Constructor for class org.apache.cassandra.hadoop.BulkRecordWriter.ExternalClient
Deprecated.
 
ExternalClient(Configuration) - Constructor for class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter.ExternalClient
 
extractComponent(ByteBuffer, int) - Static method in class org.apache.cassandra.db.marshal.CompositeType
 
extractExpireTime(String[]) - Method in class org.apache.cassandra.service.StorageService
 
extractFromVersion(int) - Static method in enum org.apache.cassandra.transport.Message.Direction
 
extractIOExceptionCause(Throwable) - Static method in class org.apache.cassandra.utils.Throwables
 
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.cql3.CqlLexer
 
F - Static variable in class org.apache.cassandra.cql3.CqlParser
 
Factory() - Constructor for class org.apache.cassandra.cql3.selection.Selector.Factory
 
factory - Static variable in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
factory - Static variable in class org.apache.cassandra.db.AtomicBTreeColumns
 
Factory() - Constructor for class org.apache.cassandra.db.ColumnFamily.Factory
 
Factory() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader.Factory
 
Factory() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableWriter.Factory
 
factory - Static variable in class org.apache.cassandra.metrics.CommitLogMetrics
 
factory - Static variable in class org.apache.cassandra.metrics.CompactionMetrics
 
factory - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
 
factory - Variable in class org.apache.cassandra.metrics.LatencyMetrics
 
Factory() - Constructor for class org.apache.cassandra.thrift.CustomTNonBlockingServer.Factory
 
Factory() - Constructor for class org.apache.cassandra.thrift.CustomTThreadPoolServer.Factory
 
Factory() - Constructor for class org.apache.cassandra.thrift.THsHaDisruptorServer.Factory
 
fail() - Method in class org.apache.cassandra.repair.Validator
Called when some error during the validation happened.
failedRepairJob(UUID, String, String, Throwable) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
failParentRepair(UUID, Throwable) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
failRepairs(UUID, String, String[], Throwable) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
FAILURE_CALLBACK_PARAM - Static variable in class org.apache.cassandra.net.MessagingService
 
FAILURE_RESPONSE_PARAM - Static variable in class org.apache.cassandra.net.MessagingService
 
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
 
FailureDetectorInfo - Class in org.apache.cassandra.tools.nodetool
 
FailureDetectorInfo() - Constructor for class org.apache.cassandra.tools.nodetool.FailureDetectorInfo
 
FailureDetectorMBean - Interface in org.apache.cassandra.gms
 
FailureDetectorSourceFilter(IFailureDetector) - Constructor for class org.apache.cassandra.dht.RangeStreamer.FailureDetectorSourceFilter
 
failures - Variable in exception org.apache.cassandra.exceptions.RequestFailureException
 
failures - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
 
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.
FastByteOperations - Class in org.apache.cassandra.utils
Utility code to do optimized byte-array comparison.
FastByteOperations() - Constructor for class org.apache.cassandra.utils.FastByteOperations
 
FastByteOperations.ByteOperations - Interface in org.apache.cassandra.utils
 
FastByteOperations.PureJavaOperations - Class in org.apache.cassandra.utils
 
FastByteOperations.UnsafeOperations - Class in org.apache.cassandra.utils
 
FBUtilities - Class in org.apache.cassandra.utils
 
FBUtilities() - Constructor for class org.apache.cassandra.utils.FBUtilities
 
fetchAsync() - Method in class org.apache.cassandra.dht.RangeStreamer
 
fetchPage(int) - Method in class org.apache.cassandra.service.pager.NamesQueryPager
 
fetchPage(int) - Method in interface org.apache.cassandra.service.pager.QueryPager
Fetches the next page.
field - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection
 
fieldName(int) - Method in class org.apache.cassandra.db.marshal.UserType
 
fieldNameAsString(int) - Method in class org.apache.cassandra.db.marshal.UserType
 
fieldNames() - Method in class org.apache.cassandra.db.marshal.UserType
 
fields - Variable in class org.apache.cassandra.serializers.TupleSerializer
 
fields - Variable in class org.apache.cassandra.serializers.UserTypeSerializer
 
fieldSpecOf(ColumnSpecification, int) - Static method in class org.apache.cassandra.cql3.UserTypes
 
fieldType(int) - Method in class org.apache.cassandra.db.marshal.UserType
 
fieldTypes() - Method in class org.apache.cassandra.db.marshal.UserType
 
fifteenMinuteRate() - Method in class org.apache.cassandra.metrics.RestorableMeter
Returns the 15-minute rate in terms of events per second.
file - Variable in exception org.apache.cassandra.io.util.ChecksummedRandomAccessReader.CorruptFileException
 
file_cache_size_in_mb - Variable in class org.apache.cassandra.config.Config
 
FILE_EXT - Static variable in class org.apache.cassandra.streaming.StreamLockfile
 
FileCacheMetrics - Class in org.apache.cassandra.metrics
 
FileCacheMetrics() - Constructor for class org.apache.cassandra.metrics.FileCacheMetrics
 
FileCacheService - Class in org.apache.cassandra.service
 
FileCacheService() - Constructor for class org.apache.cassandra.service.FileCacheService
 
FileCacheService.CacheKey - Class in org.apache.cassandra.service
 
FileDataInput - Interface in org.apache.cassandra.io.util
 
fileDigestValidator(Descriptor) - Static method in class org.apache.cassandra.io.util.DataIntegrityMetadata
 
FileDigestValidator(Descriptor) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.FileDigestValidator
 
FileMark - Interface in org.apache.cassandra.io.util
 
FileMessageHeader - Class in org.apache.cassandra.streaming.messages
StreamingFileHeader is appended before sending actual data to describe what it's sending.
FileMessageHeader(UUID, int, String, SSTableFormat.Type, long, List<Pair<Long, Long>>, CompressionInfo, long, int) - Constructor for class org.apache.cassandra.streaming.messages.FileMessageHeader
 
FileMessageHeader(UUID, int, String, SSTableFormat.Type, long, List<Pair<Long, Long>>, CompressionMetadata, long, int) - Constructor for class org.apache.cassandra.streaming.messages.FileMessageHeader
 
fileName() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
fileName - Variable in class org.apache.cassandra.streaming.ProgressInfo
 
filenameFor(Component) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
filenameFor(String) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
filePath() - Method in class org.apache.cassandra.io.util.ChannelProxy
 
files - Variable in class org.apache.cassandra.streaming.StreamSummary
Number of files to transfer.
files - Variable in class org.apache.cassandra.streaming.StreamTransferTask
 
fileSent(FileMessageHeader) - Method in class org.apache.cassandra.streaming.StreamSession
Call back after sending FileMessageHeader.
fileSeqNum - Variable in class org.apache.cassandra.streaming.StreamReader
 
FileUtils - Class in org.apache.cassandra.io.util
 
filter() - Method in class org.apache.cassandra.db.BatchlogManager.EndpointFilter
 
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
 
filterCipherSuites(String[], String[]) - Static method in class org.apache.cassandra.security.SSLFactory
 
FilterFactory - Class in org.apache.cassandra.utils
 
FilterFactory() - Constructor for class org.apache.cassandra.utils.FilterFactory
 
filterForQuery(Keyspace, List<InetAddress>) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
filterForQuery(Keyspace, List<InetAddress>, ReadRepairDecision) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
filterHash(long[]) - Method in class org.apache.cassandra.db.CachedHashDecoratedKey
 
filterHash(long[]) - Method in class org.apache.cassandra.db.DecoratedKey
 
filterHash(long[]) - Method in class org.apache.cassandra.db.PreHashedDecoratedKey
 
filterHash(long[]) - Method in interface org.apache.cassandra.utils.IFilter.FilterKey
Places the murmur3 hash of the key in the given long array of size at least two.
filterPermissions(Set<Permission>, IResource) - Method in class org.apache.cassandra.cql3.CqlParser
 
filterSSTablesForReads(List<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
filterSSTablesForReads(List<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
filterSuspectSSTables(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
Filters SSTables that are to be blacklisted from the given collection
finalFunction() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
finalizeLength(long, int) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
finalizeMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
finalizeMetadata(String, double, long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
finalReader - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter.TransactionalProxy
 
finalState - Variable in exception org.apache.cassandra.streaming.StreamException
 
find(FunctionName) - Static method in class org.apache.cassandra.cql3.functions.Functions
 
find(FunctionName, List<AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.functions.Functions
 
find(String) - Method in class org.apache.cassandra.db.Directories
 
find(Object[], Comparator<V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
 
findNested(Throwable) - Static method in error org.apache.cassandra.io.FSError
Unwraps the Throwable cause chain looking for an FSError instance
findPositionOf(ByteBuffer, CounterId) - Method in class org.apache.cassandra.db.context.CounterContext
Finds the position of a shard with the given id within the context (via binary search).
findSupportingVersion(CassandraVersion...) - Method in class org.apache.cassandra.utils.CassandraVersion
Returns a version that is backward compatible with this version amongst a list of provided version, or null if none can be found.
finish() - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
we are done, return the finished sstables so that the caller can mark the old ones as compacted
finish - Variable in class org.apache.cassandra.db.filter.ColumnSlice
 
finish() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
finish(long, long, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
finish(boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
finish() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
Finishes the new file(s) Creates final files, adds the new files to the Tracker (via replaceReader).
finish(long, boolean) - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile.Builder.Boundaries
 
finish() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
finish() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
convenience method to both prepareToCommit() and commit() in one operation; only of use to outer-most transactional object of an object graph
finishAddingAtoms() - Method in class org.apache.cassandra.db.ColumnIndex.Builder
 
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(UUID) - Static method in class org.apache.cassandra.db.SystemKeyspace
Deletes the entry for this compaction from the set of compactions in progress.
finishCompaction(CompactionInfo.Holder) - Method in class org.apache.cassandra.metrics.CompactionMetrics
 
finishCompactionsAndShutdown(long, TimeUnit) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
finished() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
remove the event complete
finished() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
Open the resultant SSTableReader once it has been fully written, and all related state is ready to be finalised including other sstables being written involved in the same operation
finished() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
finishLocalSampling(String, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
finishLocalSampling(String, int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
finishOnClose() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
finishParentSession(UUID, Set<InetAddress>, Collection<Range<Token>>) - Method in class org.apache.cassandra.service.ActiveRepairService
Run final process of repair.
finishSampling(int) - Method in class org.apache.cassandra.utils.TopKSampler
Call to stop collecting samples, and gather the results
finishShadowRound(Map<InetAddress, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
 
finishStartup() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
finishTransfer() - Method in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
 
finishWriteFor(CommitLogSegment.Allocation) - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
Block for @param alloc to be sync'd as necessary, and handle bookkeeping
fireErrorAndComplete(String, int, int, String) - Method in class org.apache.cassandra.repair.RepairRunnable
 
fireProgressEvent(String, ProgressEvent) - Method in class org.apache.cassandra.repair.RepairRunnable
 
fireProgressEvent(String, ProgressEvent) - Method in class org.apache.cassandra.utils.progress.ProgressEventNotifierSupport
 
first - Variable in class org.apache.cassandra.io.sstable.SSTable
 
first() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
firstKeyBeyond(RowPosition) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Finds and returns the first key beyond a given token in this SSTable or null if no such key exists.
firstName - Variable in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
firstNotCovered(Iterable<ReplayPosition.ReplayFilter>) - Static method in class org.apache.cassandra.db.commitlog.ReplayPosition
 
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
 
fixedRows - Variable in class org.apache.cassandra.db.compaction.Scrubber.NegativeLocalDeletionInfoMetrics
 
flag - Variable in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
flags - Variable in class org.apache.cassandra.transport.Frame.Header
 
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
 
FloatSerializer - Class in org.apache.cassandra.serializers
 
FloatSerializer() - Constructor for class org.apache.cassandra.serializers.FloatSerializer
 
FloatType - Class in org.apache.cassandra.db.marshal
 
floor(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
flush() - Method in class org.apache.cassandra.db.Keyspace
 
flush() - Method in class org.apache.cassandra.db.Memtable
 
flush() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
flush() - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
flush() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
flush() - Method in class org.apache.cassandra.io.util.SequentialWriter
If buffer is dirty, flush it's contents to the operating system.
flush() - Method in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
 
Flush - Class in org.apache.cassandra.tools.nodetool
 
Flush() - Constructor for class org.apache.cassandra.tools.nodetool.Flush
 
flushBeforeTransfer(boolean) - Method in class org.apache.cassandra.streaming.StreamPlan
Set flushBeforeTransfer option.
flushData() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
flushData() - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter
 
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
flushingMemtables - Variable in class org.apache.cassandra.db.lifecycle.View
contains all memtables that are no longer referenced for writing and are queued for / in the process of being flushed.
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
 
FlushLargestColumnFamily() - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.FlushLargestColumnFamily
 
fmix(long) - Static method in class org.apache.cassandra.utils.MurmurHash
 
folderSize(File) - Static method in class org.apache.cassandra.io.util.FileUtils
Get the size of a directory in bytes
FOLLOW_167_in_relationType9107 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_cfamColumns3633 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_cfamDefinition3528 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_cfamProperty3750 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_createAggregateStatement2611 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_createFunctionStatement3044 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_createIndexStatement3995 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_createTypeStatement3877 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_dropAggregateStatement2857 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_dropFunctionStatement3275 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_function8278 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_function8312 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_functionResource5872 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_indexIdent4097 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_indexIdent4118 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_indexIdent4136 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_normalInsertStatement1636 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_normalInsertStatement1674 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_pkDef3680 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_relation9318 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_relation9526 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_selectionFunctionArgs1379 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_selectionFunctionArgs1391 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_singleColumnInValues9647 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_term8458 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_tupleLiteral7825 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_tupleOfIdentifiers9598 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_tupleOfMarkersForTuples9789 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_tupleOfTupleLiterals9703 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_unaliasedSelector1223 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_unaliasedSelector1254 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_168_in_unaliasedSelector1294 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_cfamColumns3650 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_cfamDefinition3544 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_cfamProperty3763 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_createAggregateStatement2679 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_createFunctionStatement3120 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_createIndexStatement4001 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_createTypeStatement3893 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_dropAggregateStatement2935 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_dropFunctionStatement3353 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_function8280 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_function8318 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_functionResource5950 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_indexIdent4103 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_indexIdent4124 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_indexIdent4142 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_normalInsertStatement1658 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_normalInsertStatement1695 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_pkDef3703 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_relation9320 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_relation9531 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_selectionFunctionArgs1381 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_selectionFunctionArgs1428 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_singleColumnInValues9673 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_term8464 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_tupleLiteral7846 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_tupleOfIdentifiers9617 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_tupleOfMarkersForTuples9808 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_tupleOfTupleLiterals9722 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_unaliasedSelector1227 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_unaliasedSelector1260 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_169_in_unaliasedSelector1300 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_170_in_normalColumnOperation8555 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_cfamColumns3639 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_cfamDefinition3535 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_cfamProperty3756 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_collection_type10266 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_collectionLiteral7648 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_createAggregateStatement2651 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_createFunctionStatement3088 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_createTypeStatement3884 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_deleteSelection2272 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_dropAggregateStatement2903 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_dropFunctionStatement3321 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_functionArgs8357 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_functionResource5918 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_mapLiteral7471 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_normalInsertStatement1647 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_normalInsertStatement1684 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_pkDef3692 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_selectClause1078 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_selectionFunctionArgs1411 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_selectStatement996 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_setOrMapLiteral7541 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_setOrMapLiteral7586 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_singleColumnInValues9660 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_tuple_type10378 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_tupleLiteral7835 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_tupleOfIdentifiers9607 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_tupleOfMarkersForTuples9798 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_tupleOfTupleLiterals9712 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_updateStatement2014 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_171_in_usertypeLiteral7771 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_172_in_constant7403 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_173_in_columnFamilyName6877 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_173_in_functionName8092 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_173_in_indexName6838 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_173_in_unaliasedSelector1347 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_173_in_userTypeName6908 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_174_in_inMarker9562 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_174_in_inMarkerForTuple9839 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_174_in_intValue8041 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_174_in_jsonValue1850 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_174_in_mapLiteral7461 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_174_in_mapLiteral7477 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_174_in_markerForTuple9753 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_174_in_setOrMapLiteral7521 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_174_in_setOrMapLiteral7547 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_174_in_usertypeLiteral7761 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_174_in_usertypeLiteral7777 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_174_in_value7959 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_175_in_batchStatement2453 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_175_in_query75 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_176_in_collection_type10260 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_176_in_collection_type10292 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_176_in_collection_type10319 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_176_in_comparatorType9926 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_176_in_relationType9065 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_176_in_tuple_type10358 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_177_in_relationType9076 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_178_in_columnOperationDifferentiator8512 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_178_in_property8962 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_178_in_property8980 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_178_in_relationType9054 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_178_in_roleOption6542 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_178_in_roleOption6559 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_178_in_roleOption6576 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_178_in_roleOption6593 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_178_in_specializedColumnOperation8642 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_179_in_collection_type10272 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_179_in_collection_type10298 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_179_in_collection_type10325 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_179_in_comparatorType9932 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_179_in_relationType9086 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_179_in_tuple_type10394 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_180_in_relationType9097 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_181_in_collectionLiteral7624 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_181_in_columnCondition8777 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_181_in_columnOperationDifferentiator8523 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_181_in_deleteOp2332 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_181_in_relation9268 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_182_in_countArgument1447 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_182_in_selectClause1094 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_183_in_collectionLiteral7668 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_183_in_columnCondition8783 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_183_in_columnOperationDifferentiator8529 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_183_in_deleteOp2338 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_183_in_relation9274 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_184_in_collectionLiteral7678 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_184_in_collectionLiteral7709 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_184_in_mapLiteral7441 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_184_in_usertypeLiteral7755 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_185_in_collectionLiteral7691 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_185_in_collectionLiteral7711 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_185_in_mapLiteral7497 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_185_in_usertypeLiteral7788 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_allowedFunctionName_in_createAggregateStatement2693 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_allowedFunctionName_in_createAggregateStatement2731 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_allowedFunctionName_in_functionName8098 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_alterKeyspaceStatement_in_cqlStatement425 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_alterRoleStatement_in_cqlStatement753 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_alterTableStatement_in_cqlStatement405 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_alterTypeStatement_in_cqlStatement624 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_alterUserStatement_in_cqlStatement504 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_basic_unreserved_keyword_in_non_type_ident10512 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_basic_unreserved_keyword_in_unreserved_function_keyword10622 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_batchStatement_in_cqlStatement188 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_batchStatementObjective_in_batchStatement2451 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_BOOLEAN_in_constant7344 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_BOOLEAN_in_roleOption6580 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_BOOLEAN_in_roleOption6597 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamColumns_in_cfamDefinition3530 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamColumns_in_cfamDefinition3537 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamDefinition_in_createTableStatement3509 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamOrdering_in_cfamProperty3752 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamOrdering_in_cfamProperty3758 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamProperty_in_cfamDefinition3556 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfamProperty_in_cfamDefinition3563 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cfName_in_columnFamilyName6881 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_alterTableStatement4403 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_alterTableStatement4431 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_alterTableStatement4463 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_alterTableStatement4593 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_alterTableStatement4599 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_alterTableStatement4624 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_alterTableStatement4630 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_columnCondition8679 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_columnOperation8491 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_createTriggerStatement4199 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_deleteOp2303 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_deleteOp2330 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_dropTriggerStatement4278 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_indexIdent4067 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_indexIdent4101 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_indexIdent4122 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_indexIdent4140 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_normalColumnOperation8559 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_normalColumnOperation8580 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_normalColumnOperation8612 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_normalInsertStatement1640 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_normalInsertStatement1651 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_orderByClause1525 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_relation9129 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_relation9179 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_relation9205 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_relation9231 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_relation9266 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_tupleOfIdentifiers9602 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_tupleOfIdentifiers9611 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_unaliasedSelector1175 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_unaliasedSelector1258 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_unaliasedSelector1298 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cident_in_unaliasedSelector1351 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_collection_type_in_comparatorType9884 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_collectionLiteral_in_value7891 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnCondition_in_updateConditions2095 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnCondition_in_updateConditions2102 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_alterTableStatement4385 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_createIndexStatement3993 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_createTableStatement3499 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_createTriggerStatement4214 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_dataResource5732 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_deleteStatement2162 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_dropTableStatement4965 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_dropTriggerStatement4285 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_insertStatement1567 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_selectStatement960 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_truncateStatement5105 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnFamilyName_in_updateStatement1986 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnOperation_in_updateStatement2010 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnOperation_in_updateStatement2016 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_columnOperationDifferentiator_in_columnOperation8493 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_alterTableStatement4409 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_alterTableStatement4435 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_alterTypeStatement4706 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_alterTypeStatement4732 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_cfamColumns3593 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_collection_type10264 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_collection_type10270 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_collection_type10296 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_collection_type10323 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_comparatorType9930 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_createAggregateStatement2635 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_createAggregateStatement2655 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_createAggregateStatement2707 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_createFunctionStatement3072 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_createFunctionStatement3096 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_createFunctionStatement3163 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_dropAggregateStatement2885 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_dropAggregateStatement2907 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_dropFunctionStatement3303 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_dropFunctionStatement3325 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_functionResource5900 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_functionResource5922 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_term8462 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_tuple_type10373 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_tuple_type10382 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_comparatorType_in_typeColumns3917 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_constant_in_propertyValue9009 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_constant_in_value7869 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_countArgument_in_unaliasedSelector1225 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_cqlStatement_in_query72 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_createAggregateStatement_in_cqlStatement701 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_createFunctionStatement_in_cqlStatement667 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_createIndexStatement_in_cqlStatement326 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_createKeyspaceStatement_in_cqlStatement290 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_createRoleStatement_in_cqlStatement733 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_createTableStatement_in_cqlStatement307 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_createTriggerStatement_in_cqlStatement568 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_createTypeStatement_in_cqlStatement604 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_createUserStatement_in_cqlStatement484 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_dataResource_in_resource5646 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_deleteOp_in_deleteSelection2257 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_deleteOp_in_deleteSelection2276 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_deleteSelection_in_deleteStatement2145 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_deleteStatement_in_batchStatementObjective2526 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_deleteStatement_in_cqlStatement214 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_dropAggregateStatement_in_cqlStatement716 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_dropFunctionStatement_in_cqlStatement683 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_dropIndexStatement_in_cqlStatement384 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_dropKeyspaceStatement_in_cqlStatement345 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_dropRoleStatement_in_cqlStatement774 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_dropTableStatement_in_cqlStatement363 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_dropTriggerStatement_in_cqlStatement585 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_dropTypeStatement_in_cqlStatement645 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_dropUserStatement_in_cqlStatement525 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_EOF_in_query79 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_FLOAT_in_constant7323 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_function_in_term8426 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_functionArgs_in_function8316 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_functionName_in_createAggregateStatement2603 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_functionName_in_createFunctionStatement3036 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_functionName_in_dropAggregateStatement2839 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_functionName_in_dropFunctionStatement3257 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_functionName_in_function8276 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_functionName_in_function8310 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_functionName_in_functionResource5854 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_functionName_in_unaliasedSelector1328 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_functionResource_in_resource5670 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_grantPermissionsStatement_in_cqlStatement442 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_grantRoleStatement_in_cqlStatement817 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_HEXNUMBER_in_constant7385 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IDENT_in_allowedFunctionName8125 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_alterTypeStatement4700 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_alterTypeStatement4728 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_alterTypeStatement4793 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_alterTypeStatement4799 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_alterTypeStatement4826 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_alterTypeStatement4832 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_cfamColumns3589 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_cfamColumns3643 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_cfamOrdering3791 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IDENT_in_cfName7045 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IDENT_in_cident6654 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_createFunctionStatement3068 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_createFunctionStatement3092 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IDENT_in_createFunctionStatement3177 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IDENT_in_ident6724 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IDENT_in_idxName7121 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_inMarker9566 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_inMarkerForTuple9843 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_intValue8045 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_jsonValue1854 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IDENT_in_ksName6969 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_markerForTuple9757 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IDENT_in_non_type_ident10456 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_pkDef3670 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_pkDef3686 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_pkDef3696 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_property8960 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_property8978 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IDENT_in_roleName7197 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_selector1134 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_typeColumns3913 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_IDENT_in_username10413 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_usertypeLiteral7759 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_usertypeLiteral7775 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_userTypeName6906 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ident_in_value7963 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_idxName_in_createIndexStatement3984 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_idxName_in_indexName6842 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_indexIdent_in_createIndexStatement3999 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_indexName_in_dropIndexStatement5065 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_inMarker_in_columnCondition8749 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_inMarker_in_columnCondition8869 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_inMarker_in_relation9185 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_inMarkerForTuple_in_relation9352 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_insertStatement_in_batchStatementObjective2500 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_insertStatement_in_cqlStatement138 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_INTEGER_in_constant7304 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_INTEGER_in_countArgument1457 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_INTEGER_in_intValue8027 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_INTEGER_in_normalColumnOperation8616 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_intValue_in_selectStatement1019 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_intValue_in_usingClauseDelete2364 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_intValue_in_usingClauseObjective1934 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_intValue_in_usingClauseObjective1948 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_jsonInsertStatement_in_insertStatement1600 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_jsonValue_in_jsonInsertStatement1770 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ADD_in_alterTableStatement4425 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ADD_in_alterTypeStatement4722 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AGGREGATE_in_createAggregateStatement2576 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AGGREGATE_in_dropAggregateStatement2813 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALL_in_dataResource5693 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALL_in_functionResource5811 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALL_in_functionResource5823 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALL_in_permissionOrAll5589 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALL_in_roleResource5761 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALLOW_in_selectStatement1034 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALTER_in_alterKeyspaceStatement4325 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALTER_in_alterRoleStatement6337 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALTER_in_alterTableStatement4379 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALTER_in_alterTableStatement4399 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALTER_in_alterTypeStatement4676 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALTER_in_alterTypeStatement4696 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ALTER_in_alterUserStatement6094 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AND_in_alterTableStatement4620 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AND_in_alterTypeStatement4822 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AND_in_cfamDefinition3561 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AND_in_properties8935 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AND_in_roleOptions6516 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AND_in_updateConditions2100 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AND_in_usingClause1906 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AND_in_whereClause1492 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_APPLY_in_batchStatement2467 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AS_in_createFunctionStatement3185 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_AS_in_selector1130 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ASC_in_cfamOrdering3794 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ASC_in_orderByClause1528 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ASCII_in_native_type9979 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BATCH_in_batchStatement2427 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BATCH_in_batchStatement2469 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BEGIN_in_batchStatement2398 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BIGINT_in_native_type9993 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BLOB_in_native_type10006 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BOOLEAN_in_native_type10021 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BY_in_cfamProperty3748 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_BY_in_selectStatement989 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CALLED_in_createFunctionStatement3139 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CLUSTERING_in_cfamProperty3744 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COLUMNFAMILY_in_alterTableStatement4381 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COLUMNFAMILY_in_createTableStatement3477 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COLUMNFAMILY_in_dataResource5723 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COLUMNFAMILY_in_dropTableStatement4951 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COLUMNFAMILY_in_truncateStatement5099 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COMPACT_in_cfamProperty3732 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CONTAINS_in_relation9233 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COUNT_in_allowedFunctionName8229 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COUNT_in_unaliasedSelector1221 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COUNTER_in_batchStatement2414 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_COUNTER_in_native_type10033 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CREATE_in_createAggregateStatement2559 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CREATE_in_createFunctionStatement2992 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CREATE_in_createIndexStatement3952 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CREATE_in_createKeyspaceStatement3412 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CREATE_in_createRoleStatement6264 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CREATE_in_createTableStatement3475 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CREATE_in_createTriggerStatement4180 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CREATE_in_createTypeStatement3837 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CREATE_in_createUserStatement5998 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_CUSTOM_in_createIndexStatement3955 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DATE_in_native_type10214 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DECIMAL_in_native_type10045 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DELETE_in_deleteStatement2139 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DESC_in_cfamOrdering3798 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DESC_in_orderByClause1532 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DISTINCT_in_selectStatement937 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DOUBLE_in_native_type10057 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DROP_in_alterTableStatement4458 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DROP_in_dropAggregateStatement2811 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DROP_in_dropFunctionStatement3229 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DROP_in_dropIndexStatement5049 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DROP_in_dropKeyspaceStatement4899 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DROP_in_dropRoleStatement6399 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DROP_in_dropTableStatement4949 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DROP_in_dropTriggerStatement4261 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DROP_in_dropTypeStatement4999 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_DROP_in_dropUserStatement6188 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ENTRIES_in_indexIdent4116 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_createAggregateStatement2589 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_createFunctionStatement3022 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_createIndexStatement3968 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_createKeyspaceStatement3421 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_createRoleStatement6273 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_createTableStatement3484 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_createTriggerStatement4189 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_createTypeStatement3846 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_createUserStatement6007 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_deleteStatement2202 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_dropAggregateStatement2824 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_dropFunctionStatement3242 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_dropIndexStatement5056 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_dropKeyspaceStatement4906 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_dropRoleStatement6406 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_dropTableStatement4956 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_dropTriggerStatement4268 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_dropTypeStatement5006 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_dropUserStatement6195 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_jsonInsertStatement1784 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_normalInsertStatement1709 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_EXISTS_in_updateStatement2045 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FILTERING_in_selectStatement1036 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FINALFUNC_in_createAggregateStatement2725 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FLOAT_in_native_type10070 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FROM_in_deleteStatement2158 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FROM_in_revokePermissionsStatement5255 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FROM_in_revokeRoleStatement5389 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FROM_in_selectStatement956 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FROZEN_in_comparatorType9924 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FULL_in_indexIdent4134 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FUNCTION_in_createFunctionStatement3009 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FUNCTION_in_dropFunctionStatement3231 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FUNCTION_in_functionResource5850 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FUNCTIONS_in_functionResource5813 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_FUNCTIONS_in_functionResource5825 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_GRANT_in_grantPermissionsStatement5130 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_GRANT_in_grantRoleStatement5300 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_createAggregateStatement2585 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_createFunctionStatement3018 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_createIndexStatement3964 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_createKeyspaceStatement3417 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_createRoleStatement6269 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_createTableStatement3480 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_createTriggerStatement4185 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_createTypeStatement3842 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_createUserStatement6003 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_deleteStatement2198 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_dropAggregateStatement2822 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_dropFunctionStatement3240 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_dropIndexStatement5054 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_dropKeyspaceStatement4904 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_dropRoleStatement6404 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_dropTableStatement4954 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_dropTriggerStatement4266 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_dropTypeStatement5004 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_dropUserStatement6193 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_jsonInsertStatement1780 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_normalInsertStatement1705 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IF_in_updateStatement2041 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IN_in_columnCondition8711 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IN_in_columnCondition8823 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IN_in_functionResource5827 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IN_in_relation9181 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IN_in_relation9207 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_IN_in_relation9304 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_INDEX_in_createIndexStatement3961 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_INDEX_in_dropIndexStatement5051 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_INET_in_native_type10084 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_INITCOND_in_createAggregateStatement2758 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_INPUT_in_createFunctionStatement3149 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_INSERT_in_insertStatement1561 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_INT_in_native_type10099 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_INTO_in_insertStatement1563 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_JSON_in_insertStatement1596 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_JSON_in_selectStatement920 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEY_in_cfamColumns3617 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEY_in_cfamColumns3631 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEY_in_non_type_ident10524 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEY_in_relation9238 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEYS_in_indexIdent4095 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEYSPACE_in_alterKeyspaceStatement4327 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEYSPACE_in_createKeyspaceStatement3414 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEYSPACE_in_dataResource5705 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEYSPACE_in_dropKeyspaceStatement4901 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEYSPACE_in_functionResource5829 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_KEYSPACES_in_dataResource5695 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_LANGUAGE_in_createFunctionStatement3171 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_LIMIT_in_selectStatement1015 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_LIST_in_collection_type10290 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_LIST_in_listPermissionsStatement5441 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_LIST_in_listRolesStatement6454 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_LIST_in_listUsersStatement6228 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_LOGIN_in_roleOption6591 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_MAP_in_collection_type10257 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NORECURSIVE_in_listPermissionsStatement5496 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NORECURSIVE_in_listRolesStatement6481 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NOSUPERUSER_in_alterUserStatement6142 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NOSUPERUSER_in_createUserStatement6049 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NOT_in_createAggregateStatement2587 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NOT_in_createFunctionStatement3020 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NOT_in_createIndexStatement3966 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NOT_in_createKeyspaceStatement3419 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NOT_in_createRoleStatement6271 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NOT_in_createTableStatement3482 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NOT_in_createTriggerStatement4187 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NOT_in_createTypeStatement3844 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NOT_in_createUserStatement6005 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NOT_in_jsonInsertStatement1782 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NOT_in_normalInsertStatement1707 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NULL_in_createFunctionStatement3133 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NULL_in_createFunctionStatement3147 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_NULL_in_value7935 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_OF_in_listPermissionsStatement5480 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_OF_in_listRolesStatement6466 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ON_in_createFunctionStatement3145 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ON_in_createIndexStatement3989 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ON_in_createTriggerStatement4210 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ON_in_dropTriggerStatement4281 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ON_in_grantPermissionsStatement5150 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ON_in_listPermissionsStatement5463 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ON_in_revokePermissionsStatement5235 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_OPTIONS_in_roleOption6557 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_OR_in_createAggregateStatement2562 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_OR_in_createFunctionStatement2995 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ORDER_in_cfamProperty3746 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ORDER_in_selectStatement987 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_PASSWORD_in_roleOption6540 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_PASSWORD_in_userPassword6619 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_PERMISSION_in_permissionOrAll5618 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_PERMISSIONS_in_permissionOrAll5593 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_PRIMARY_in_cfamColumns3615 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_PRIMARY_in_cfamColumns3629 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_RENAME_in_alterTableStatement4539 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_RENAME_in_alterTypeStatement4755 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_REPLACE_in_createAggregateStatement2564 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_REPLACE_in_createFunctionStatement2997 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_RETURNS_in_createFunctionStatement3131 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_RETURNS_in_createFunctionStatement3157 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_REVOKE_in_revokePermissionsStatement5215 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_REVOKE_in_revokeRoleStatement5367 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ROLE_in_alterRoleStatement6339 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ROLE_in_createRoleStatement6266 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ROLE_in_dropRoleStatement6401 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ROLE_in_roleResource5773 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ROLES_in_listRolesStatement6456 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_ROLES_in_roleResource5763 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_SELECT_in_selectStatement909 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_SET_in_collection_type10316 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_SET_in_updateStatement2008 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_SFUNC_in_createAggregateStatement2687 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_SMALLINT_in_native_type10115 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_STATIC_in_alterTableStatement4440 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_STATIC_in_cfamColumns3598 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_STORAGE_in_cfamProperty3734 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_STYPE_in_createAggregateStatement2701 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_SUPERUSER_in_alterUserStatement6128 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_SUPERUSER_in_createUserStatement6043 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_SUPERUSER_in_roleOption6574 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TEXT_in_native_type10126 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TIME_in_native_type10229 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TIMESTAMP_in_native_type10141 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TIMESTAMP_in_usingClauseDelete2360 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TIMESTAMP_in_usingClauseObjective1930 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TIMEUUID_in_native_type10203 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TINYINT_in_native_type10151 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TO_in_alterTableStatement4595 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TO_in_alterTableStatement4626 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TO_in_alterTypeStatement4795 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TO_in_alterTypeStatement4828 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TO_in_grantPermissionsStatement5170 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TO_in_grantRoleStatement5322 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TOKEN_in_allowedFunctionName8197 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TOKEN_in_relation9147 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TRIGGER_in_createTriggerStatement4182 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TRIGGER_in_dropTriggerStatement4263 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TRUNCATE_in_truncateStatement5096 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TTL_in_unaliasedSelector1286 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TTL_in_usingClauseObjective1944 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TUPLE_in_tuple_type10356 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TYPE_in_alterTableStatement4405 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TYPE_in_alterTypeStatement4678 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TYPE_in_alterTypeStatement4702 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TYPE_in_createTypeStatement3839 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_TYPE_in_dropTypeStatement5001 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_UNLOGGED_in_batchStatement2408 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_UPDATE_in_updateStatement1982 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USE_in_useStatement871 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USER_in_alterUserStatement6096 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USER_in_createUserStatement6000 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USER_in_dropUserStatement6190 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USERS_in_listUsersStatement6230 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USING_in_createIndexStatement4012 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USING_in_createTriggerStatement4216 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USING_in_usingClause1899 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_USING_in_usingClauseDelete2358 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_UUID_in_native_type10163 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_VALUES_in_normalInsertStatement1666 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_VARCHAR_in_native_type10178 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_VARINT_in_native_type10190 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WHERE_in_deleteStatement2184 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WHERE_in_selectStatement970 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WHERE_in_updateStatement2027 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WITH_in_alterKeyspaceStatement4341 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WITH_in_alterRoleStatement6353 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WITH_in_alterTableStatement4503 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WITH_in_alterUserStatement6112 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WITH_in_cfamDefinition3554 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WITH_in_createIndexStatement4031 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WITH_in_createKeyspaceStatement3438 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WITH_in_createRoleStatement6291 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WITH_in_createUserStatement6027 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_K_WRITETIME_in_unaliasedSelector1252 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_keyspaceName_in_alterKeyspaceStatement4331 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_keyspaceName_in_createKeyspaceStatement3430 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_keyspaceName_in_dataResource5711 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_keyspaceName_in_dropKeyspaceStatement4915 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_keyspaceName_in_functionName8090 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_keyspaceName_in_functionResource5835 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_keyspaceName_in_useStatement875 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ksName_in_columnFamilyName6874 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ksName_in_indexName6835 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_ksName_in_keyspaceName6801 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_listPermissionsStatement_in_cqlStatement469 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_listRolesStatement_in_cqlStatement796 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_listUsersStatement_in_cqlStatement547 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_mapLiteral_in_property8984 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_mapLiteral_in_roleOption6563 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_markerForTuple_in_relation9496 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_markerForTuple_in_tupleOfMarkersForTuples9793 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_markerForTuple_in_tupleOfMarkersForTuples9802 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_native_type_in_comparatorType9868 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_native_type_in_unreserved_function_keyword10634 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_non_type_ident_in_userTypeName6914 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_normalColumnOperation_in_columnOperationDifferentiator8514 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_normalInsertStatement_in_insertStatement1581 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_orderByClause_in_selectStatement991 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_orderByClause_in_selectStatement998 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_permission_in_permissionOrAll5614 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_permissionOrAll_in_grantPermissionsStatement5142 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_permissionOrAll_in_listPermissionsStatement5453 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_permissionOrAll_in_revokePermissionsStatement5227 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_pkDef_in_cfamColumns3635 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_properties_in_alterKeyspaceStatement4343 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_properties_in_alterTableStatement4506 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_properties_in_createIndexStatement4033 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_properties_in_createKeyspaceStatement3440 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_property_in_cfamProperty3723 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_property_in_properties8931 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_property_in_properties8937 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_propertyValue_in_property8966 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QMARK_in_cfName7099 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QMARK_in_idxName7175 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QMARK_in_inMarker9552 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QMARK_in_inMarkerForTuple9829 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QMARK_in_intValue8056 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QMARK_in_jsonValue1868 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QMARK_in_ksName7023 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QMARK_in_markerForTuple9743 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QMARK_in_roleName7267 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QMARK_in_value7981 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QUOTED_NAME_in_allowedFunctionName8159 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QUOTED_NAME_in_cfName7070 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QUOTED_NAME_in_cident6679 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QUOTED_NAME_in_ident6749 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QUOTED_NAME_in_idxName7146 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QUOTED_NAME_in_ksName6994 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QUOTED_NAME_in_non_type_ident10487 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QUOTED_NAME_in_roleName7238 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_QUOTED_NAME_in_username10429 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_relation_in_relation9528 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_relation_in_whereClause1488 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_relation_in_whereClause1494 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_relationType_in_columnCondition8693 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_relationType_in_columnCondition8801 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_relationType_in_relation9133 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_relationType_in_relation9155 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_relationType_in_relation9278 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_relationType_in_relation9462 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_relationType_in_relation9492 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_resource_in_grantPermissionsStatement5162 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_resource_in_listPermissionsStatement5465 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_resource_in_revokePermissionsStatement5247 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_revokePermissionsStatement_in_cqlStatement456 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_revokeRoleStatement_in_cqlStatement838 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_roleName_in_listPermissionsStatement5482 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_roleName_in_listRolesStatement6468 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_roleName_in_userOrRoleName6946 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_roleOption_in_roleOptions6512 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_roleOption_in_roleOptions6518 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_roleOptions_in_alterRoleStatement6355 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_roleOptions_in_createRoleStatement6293 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_roleResource_in_resource5658 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_selectClause_in_selectStatement946 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_selectionFunctionArgs_in_unaliasedSelector1332 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_selector_in_selectClause1073 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_selector_in_selectClause1082 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_selectStatement_in_cqlStatement113 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_set_in_basic_unreserved_keyword10672 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_set_in_constant7412 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_set_in_normalColumnOperation8584 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_set_in_permission5532 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_set_in_unreserved_keyword10583 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_setOrMapLiteral_in_collectionLiteral7686 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_singleColumnInValues_in_columnCondition8729 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_singleColumnInValues_in_columnCondition8845 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_singleColumnInValues_in_relation9211 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_specializedColumnOperation_in_columnOperationDifferentiator8531 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_STRING_LITERAL_in_comparatorType9950 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_STRING_LITERAL_in_constant7292 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_STRING_LITERAL_in_createFunctionStatement3191 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_STRING_LITERAL_in_createIndexStatement4016 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_STRING_LITERAL_in_createTriggerStatement4220 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_STRING_LITERAL_in_jsonValue1840 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_STRING_LITERAL_in_roleName7222 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_STRING_LITERAL_in_roleOption6546 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_STRING_LITERAL_in_username10421 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_STRING_LITERAL_in_userPassword6623 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_collectionLiteral7642 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_collectionLiteral7652 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_collectionLiteral7682 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_columnCondition8697 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_columnCondition8781 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_columnCondition8805 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_columnOperationDifferentiator8527 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_createAggregateStatement2764 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_deleteOp2336 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_functionArgs8351 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_functionArgs8361 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_mapLiteral7459 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_mapLiteral7465 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_mapLiteral7475 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_mapLiteral7481 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_normalColumnOperation8552 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_normalColumnOperation8594 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_normalInsertStatement1678 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_normalInsertStatement1688 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_relation9137 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_relation9159 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_relation9254 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_relation9272 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_relation9282 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_setOrMapLiteral7525 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_setOrMapLiteral7545 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_setOrMapLiteral7551 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_setOrMapLiteral7590 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_singleColumnInValues9655 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_singleColumnInValues9664 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_specializedColumnOperation8646 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_term8468 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_tupleLiteral7829 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_tupleLiteral7839 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_usertypeLiteral7765 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_term_in_usertypeLiteral7781 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_truncateStatement_in_cqlStatement267 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_tuple_type_in_comparatorType9896 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_tupleLiteral_in_relation9466 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_tupleLiteral_in_tupleOfTupleLiterals9707 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_tupleLiteral_in_tupleOfTupleLiterals9716 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_tupleLiteral_in_value7919 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_tupleOfIdentifiers_in_relation9151 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_tupleOfIdentifiers_in_relation9294 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_tupleOfMarkersForTuples_in_relation9420 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_tupleOfTupleLiterals_in_relation9386 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_typeColumns_in_createTypeStatement3879 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_typeColumns_in_createTypeStatement3886 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unaliasedSelector_in_selectionFunctionArgs1395 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unaliasedSelector_in_selectionFunctionArgs1415 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unaliasedSelector_in_selector1127 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unreserved_function_keyword_in_allowedFunctionName8187 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unreserved_function_keyword_in_unreserved_keyword10567 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unreserved_keyword_in_cfName7089 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unreserved_keyword_in_cident6698 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unreserved_keyword_in_ident6768 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unreserved_keyword_in_idxName7165 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unreserved_keyword_in_ksName7013 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unreserved_keyword_in_propertyValue9031 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_unreserved_keyword_in_roleName7257 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_updateConditions_in_deleteStatement2210 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_updateConditions_in_updateStatement2053 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_updateStatement_in_batchStatementObjective2513 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_updateStatement_in_cqlStatement163 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_username_in_alterUserStatement6100 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_username_in_createUserStatement6015 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_username_in_dropUserStatement6203 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userOrRoleName_in_alterRoleStatement6343 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userOrRoleName_in_createRoleStatement6281 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userOrRoleName_in_dropRoleStatement6414 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userOrRoleName_in_grantPermissionsStatement5184 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userOrRoleName_in_grantRoleStatement5314 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userOrRoleName_in_grantRoleStatement5336 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userOrRoleName_in_revokePermissionsStatement5269 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userOrRoleName_in_revokeRoleStatement5381 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userOrRoleName_in_revokeRoleStatement5403 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userOrRoleName_in_roleResource5779 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userPassword_in_alterUserStatement6114 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userPassword_in_createUserStatement6029 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usertypeLiteral_in_value7904 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userTypeName_in_alterTypeStatement4682 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userTypeName_in_comparatorType9912 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userTypeName_in_createTypeStatement3864 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_userTypeName_in_dropTypeStatement5015 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_useStatement_in_cqlStatement239 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClause_in_batchStatement2431 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClause_in_jsonInsertStatement1799 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClause_in_normalInsertStatement1724 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClause_in_updateStatement1996 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClauseDelete_in_deleteStatement2172 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClauseObjective_in_usingClause1901 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_usingClauseObjective_in_usingClause1908 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_UUID_in_constant7363 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_value_in_term8389 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_whereClause_in_deleteStatement2188 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_whereClause_in_selectStatement974 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
FOLLOW_whereClause_in_updateStatement2031 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
force(MappedByteBuffer) - Static method in class org.apache.cassandra.utils.SyncUtil
 
force(FileChannel, boolean) - Static method in class org.apache.cassandra.utils.SyncUtil
 
forceAnnounceNewColumnFamily(CFMetaData) - Static method in class org.apache.cassandra.service.MigrationManager
Announces the table even if the definition is already know locally.
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.SystemKeyspace
 
forceCleanup(int) - 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.format.SSTableReader
For testing purposes only.
forceFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Flush if there is unflushed data in the memtables
forceFlush(ReplayPosition) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Flush if there is unflushed data that was written to the CommitLog before @param flushIfDirtyBefore (inclusive).
forceKeyspaceCleanup(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceKeyspaceCleanup(int, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceKeyspaceCleanup(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
forceKeyspaceCleanup(int, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
forceKeyspaceCleanup(int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceKeyspaceCleanup(PrintStream, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceKeyspaceCompaction(boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceKeyspaceCompaction(boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Forces major compaction of a single keyspace
forceKeyspaceCompaction(boolean, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceKeyspaceFlush(String, String...) - Method in class org.apache.cassandra.service.StorageService
Flush all memtables for a keyspace and column families.
forceKeyspaceFlush(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Flush all memtables for the given column families, or all columnfamilies for the given keyspace if none are explicitly listed.
forceKeyspaceFlush(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceMajorCompaction() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceMajorCompaction(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceMajorCompaction(boolean) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
force a major compaction of this column family
forceNewerGeneration() - Method in class org.apache.cassandra.gms.Gossiper
 
forceRecycleAllSegments(Iterable<UUID>) - Method in class org.apache.cassandra.db.commitlog.CommitLog
Flushes all dirty CFs, waiting for them to free and recycle any segments they were retaining
forceRecycleAllSegments() - Method in class org.apache.cassandra.db.commitlog.CommitLog
Flushes all dirty CFs, waiting for them to free and recycle any segments they were retaining
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, Collection<String>, Collection<String>, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
Deprecated.
forceRepairAsync(String, int, Collection<String>, Collection<String>, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
Deprecated.
forceRepairAsync(String, boolean, boolean, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
Deprecated.
forceRepairAsync(String, RepairOption, boolean) - Method in class org.apache.cassandra.service.StorageService
 
forceRepairAsync(String, boolean, Collection<String>, Collection<String>, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
forceRepairAsync(String, int, Collection<String>, Collection<String>, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
forceRepairAsync(String, boolean, boolean, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
forceRepairRangeAsync(String, String, String, boolean, Collection<String>, Collection<String>, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
Deprecated.
forceRepairRangeAsync(String, String, String, int, Collection<String>, Collection<String>, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
Deprecated.
forceRepairRangeAsync(String, String, String, boolean, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
Deprecated.
forceRepairRangeAsync(String, String, String, boolean, Collection<String>, Collection<String>, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
forceRepairRangeAsync(String, String, String, int, Collection<String>, Collection<String>, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
forceRepairRangeAsync(String, String, String, boolean, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
forceShutdown() - Method in class org.apache.cassandra.db.compaction.CompactionManager
Shutdowns both compaction and validation executors, cancels running compaction / validation, and waits for tasks to complete if tasks were not cancelable.
forceShutdown(Throwable) - Method in class org.apache.cassandra.repair.RepairSession
clear all RepairJobs and terminate this session.
forceStaticInitialization() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
forceTerminateAllRepairSessions() - Method in class org.apache.cassandra.service.StorageService
 
forceTerminateAllRepairSessions() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
forceUserDefinedCompaction(String) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
forceUserDefinedCompaction(String) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Triggers the compaction of user specified sstables.
forColumns(CFMetaData, List<ColumnDefinition>) - Static method in class org.apache.cassandra.cql3.selection.Selection
 
forExternalCalls(SocketAddress) - Static method in class org.apache.cassandra.service.ClientState
 
forInternalCalls(ConsistencyLevel, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryOptions
 
forInternalCalls(List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryOptions
 
forInternalCalls() - Static method in class org.apache.cassandra.service.ClientState
 
forInternalCalls() - Static method in class org.apache.cassandra.service.QueryState
 
ForKey() - Constructor for class org.apache.cassandra.db.RowPosition.ForKey
 
forKeyRange(Range<RowPosition>) - Static method in class org.apache.cassandra.db.DataRange
 
format - Static variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
format - Variable in class org.apache.cassandra.io.sstable.format.Version
 
format - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
SSTable format
format - Variable in class org.apache.cassandra.streaming.StreamReader
 
formatResults(List<RoleResource>) - Method in class org.apache.cassandra.cql3.statements.ListRolesStatement
 
formatResults(List<RoleResource>) - Method in class org.apache.cassandra.cql3.statements.ListUsersStatement
 
formatType - Variable in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
 
formatType - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
forProgress(long, long) - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
forProtocolVersion(int) - Static method in class org.apache.cassandra.cql3.QueryOptions
 
forStatement(int) - Method in class org.apache.cassandra.cql3.BatchQueryOptions
 
forSubRange(AbstractBounds<RowPosition>) - Method in class org.apache.cassandra.db.AbstractRangeCommand
 
forSubRange(AbstractBounds<RowPosition>) - Method in class org.apache.cassandra.db.PagedRangeCommand
 
forSubRange(AbstractBounds<RowPosition>) - Method in class org.apache.cassandra.db.RangeSliceCommand
 
forTable(String) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
The schema (CREATE TABLE statement) for the table for which sstable are to be created.
forThrift(int, List<ColumnSpecification>) - Static method in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
 
forTokenRange(Range<Token>) - Static method in class org.apache.cassandra.db.DataRange
 
FORWARD_FROM - Static variable in class org.apache.cassandra.db.Mutation
 
FORWARD_TO - Static variable in class org.apache.cassandra.db.Mutation
 
forwardMap - Variable in class org.apache.cassandra.utils.BiMultiValMap
 
forwardMap - Variable in class org.apache.cassandra.utils.ConcurrentBiMap
 
Frame - Class in org.apache.cassandra.transport
 
Frame.Compressor - Class in org.apache.cassandra.transport
 
Frame.Decoder - Class in org.apache.cassandra.transport
 
Frame.Decompressor - Class in org.apache.cassandra.transport
 
Frame.Encoder - Class in org.apache.cassandra.transport
 
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.LZ4Compressor - Class in org.apache.cassandra.transport
 
FrameCompressor.SnappyCompressor - Class in org.apache.cassandra.transport
 
free() - Method in class org.apache.cassandra.cache.RefCountedMemory
 
free() - Method in class org.apache.cassandra.io.util.Memory
 
free() - Method in class org.apache.cassandra.io.util.SafeMemory
 
free(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
freeze() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
freeze() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
freeze() - Method in class org.apache.cassandra.db.marshal.ListType
 
freeze() - Method in class org.apache.cassandra.db.marshal.MapType
 
freeze() - Method in class org.apache.cassandra.db.marshal.SetType
 
from(CQL3Type) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
from(UntypedResultSet) - Static method in class org.apache.cassandra.db.compaction.CompactionHistoryTabularData
 
from(int) - Static method in enum org.apache.cassandra.db.composites.Composite.EOC
 
from(String, String, String, Map.Entry<String, Pair<Long, Long>>, TabularDataSupport) - Static method in class org.apache.cassandra.db.SnapshotDetailsTabularData
 
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
 
from - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
 
fromAbstractType(AbstractType<?>, boolean) - Static method in class org.apache.cassandra.db.composites.CellNames
 
fromByte(byte) - Static method in enum org.apache.cassandra.repair.messages.RepairMessage.Type
 
fromByte(byte) - Static method in enum org.apache.cassandra.streaming.ProgressInfo.Direction
 
fromByteArray(ByteBuffer) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
fromByteBuffer(ByteBuffer) - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
 
fromByteBuffer(ByteBuffer) - Method in class org.apache.cassandra.db.composites.CompoundCType
 
fromByteBuffer(ByteBuffer) - Method in interface org.apache.cassandra.db.composites.CType
Deserialize a Composite from a ByteBuffer.
fromByteBuffer(ByteBuffer) - Method in class org.apache.cassandra.db.composites.SimpleCType
 
fromByteBuffer(ByteBuffer) - Method in class org.apache.cassandra.db.composites.SimpleDenseCellNameType
 
fromByteBuffer(ByteBuffer) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellNameType
 
fromBytes(ByteBuffer) - Static method in class org.apache.cassandra.db.ColumnFamily
 
fromCode(int) - Static method in enum org.apache.cassandra.db.ConsistencyLevel
 
fromColumnDefinition(ColumnDefinition) - Static method in enum org.apache.cassandra.cql3.statements.IndexTarget.TargetType
 
fromCompositeData(CompositeData) - Static method in class org.apache.cassandra.streaming.management.ProgressInfoCompositeData
 
fromCompositeData(CompositeData) - Static method in class org.apache.cassandra.streaming.management.SessionInfoCompositeData
 
fromCompositeData(CompositeData) - Static method in class org.apache.cassandra.streaming.management.StreamStateCompositeData
 
fromCompositeData(CompositeData) - Static method in class org.apache.cassandra.streaming.management.StreamSummaryCompositeData
 
fromException(Throwable) - Static method in class org.apache.cassandra.transport.messages.ErrorMessage
 
fromException(Throwable, Predicate<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 "<ksname>/<cfname>-[tmp-][<version>-]<gen>-<component>",
fromFilename(String) - Static method in class org.apache.cassandra.io.sstable.Descriptor
 
fromFilename(String, SSTableFormat.Type) - Static method in class org.apache.cassandra.io.sstable.Descriptor
 
fromFilename(String, boolean) - Static method in class org.apache.cassandra.io.sstable.Descriptor
 
fromFilename(File, String) - Static method in class org.apache.cassandra.io.sstable.Descriptor
 
fromFilename(File, String, boolean) - Static method in class org.apache.cassandra.io.sstable.Descriptor
Filename of the form is vary by version: <ksname>-<cfname>-(tmp-)?<version>-<gen>-<component> for cassandra 2.0 and before (<tmp marker>-)?<version>-<gen>-<component> for cassandra 3.0 and later If this is for SSTable of secondary index, directory should ends with index name for 2.1+.
fromHeader(File) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
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.
FromJsonFct - Class in org.apache.cassandra.cql3.functions
 
fromJsonList(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
fromJsonMap(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.AbstractType
Given a parsed JSON string, return a byte representation of the object.
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.BooleanType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.BytesType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ByteType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.DateType
Deprecated.
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.EmptyType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.FloatType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.FrozenType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.InetAddressType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ListType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.LongType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.MapType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.SetType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ShortType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.TimestampType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.TimeType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.TupleType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.UserType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
fromMap(Map<String, String>) - Static method in class org.apache.cassandra.cache.CachingOptions
 
fromName(String) - Static method in class org.apache.cassandra.auth.DataResource
Parses a data resource name into a DataResource instance.
fromName(String) - Static method in class org.apache.cassandra.auth.FunctionResource
Parses a resource name into a FunctionResource instance.
fromName(String) - Static method in class org.apache.cassandra.auth.Resources
Creates an IResource instance from its external name.
fromName(String) - Static method in class org.apache.cassandra.auth.RoleResource
Parses a role resource name into a RoleResource instance.
fromName(String) - Static method in enum org.apache.cassandra.repair.RepairParallelism
Return RepairParallelism that match given name.
fromOpcode(int, Message.Direction) - Static method in enum org.apache.cassandra.transport.Message.Type
 
fromPreV3Batch(ConsistencyLevel) - Static method in class org.apache.cassandra.cql3.QueryOptions
 
fromProtocolV1(ConsistencyLevel, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryOptions
 
fromProtocolV2(ConsistencyLevel, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryOptions
 
fromSCFilter(CellNameType, ByteBuffer, IDiskAtomFilter) - Static method in class org.apache.cassandra.db.SuperColumns
 
fromSCNamesFilter(CellNameType, ByteBuffer, NamesQueryFilter) - Static method in class org.apache.cassandra.db.SuperColumns
 
fromSCSliceFilter(CellNameType, ByteBuffer, SliceQueryFilter) - Static method in class org.apache.cassandra.db.SuperColumns
 
fromSelectors(CFMetaData, List<RawSelector>) - Static method in class org.apache.cassandra.cql3.selection.Selection
 
fromSerialized(ByteBuffer, ListType, int) - Static method in class org.apache.cassandra.cql3.Lists.Value
 
fromSerialized(ByteBuffer, MapType, int) - Static method in class org.apache.cassandra.cql3.Maps.Value
 
fromSerialized(ByteBuffer, SetType, int) - Static method in class org.apache.cassandra.cql3.Sets.Value
 
fromSerialized(ByteBuffer, ListType, QueryOptions) - Static method in class org.apache.cassandra.cql3.Tuples.InValue
 
fromSerialized(ByteBuffer, TupleType) - Static method in class org.apache.cassandra.cql3.Tuples.Value
 
fromSerializedValue(byte) - Static method in enum org.apache.cassandra.db.ReadCommand.Type
 
fromString(String) - Static method in class org.apache.cassandra.cache.CachingOptions
 
fromString(String) - Static method in class org.apache.cassandra.cache.CachingOptions.KeyCache
 
fromString(String) - Static method in class org.apache.cassandra.cache.CachingOptions.RowCache
 
fromString(String) - Static method in class org.apache.cassandra.config.CFMetaData.SpeculativeRetry
 
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.ByteType
 
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
Deprecated.
 
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.FrozenType
 
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.ShortType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.TimestampType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.TimeType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.TupleType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
fromString(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
fromThrift(String, String) - Static method in class org.apache.cassandra.cache.CachingOptions
 
fromThrift(ConsistencyLevel) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
fromThrift(KsDef, CFMetaData...) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
fromThrift(CfDef) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
fromThrift(String, String, AbstractType<?>, AbstractType<?>, ColumnDef) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
fromThriftCqlRow(CqlRow, CqlResult) - Static method in class org.apache.cassandra.thrift.ThriftConversion
Create CFMetaData from thrift CqlRow that contains columns from schema_columnfamilies.
fromThriftForUpdate(CfDef, CFMetaData) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
fromTimeInMillis(long) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
fromTimeInMillis(long) - Method in class org.apache.cassandra.db.marshal.TimestampType
 
fromType(AbstractType, int) - Static method in enum org.apache.cassandra.transport.DataType
 
fromValue(int) - Static method in enum org.apache.cassandra.exceptions.ExceptionCode
 
frozen - Variable in class org.apache.cassandra.cql3.CQL3Type.Raw
 
frozen(CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
FrozenType - Class in org.apache.cassandra.db.marshal
A fake type that is only used for parsing type strings that include frozen types.
FrozenType() - Constructor for class org.apache.cassandra.db.marshal.FrozenType
 
FSError - Error in org.apache.cassandra.io
 
FSError(Throwable, File) - Constructor for error org.apache.cassandra.io.FSError
 
FSErrorHandler - Interface in org.apache.cassandra.io
Interface for handling file system errors.
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
 
fullCollection(ColumnIdentifier.Raw) - Static method in class org.apache.cassandra.cql3.statements.IndexTarget.Raw
 
fullRange - Variable in class org.apache.cassandra.utils.MerkleTree
The top level range that this MerkleTree covers.
fullSize - Variable in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
 
fullType - Variable in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
 
FULLY_INCONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
 
function(String, String, List<AbstractType<?>>) - Static method in class org.apache.cassandra.auth.FunctionResource
Creates a FunctionResource representing a specific, keyspace-scoped function.
function() - Method in class org.apache.cassandra.cql3.CqlParser
 
Function - Interface in org.apache.cassandra.cql3.functions
 
functionArgs() - Method in class org.apache.cassandra.cql3.CqlParser
 
FunctionCall - Class in org.apache.cassandra.cql3.functions
 
FunctionCall.Raw - Class in org.apache.cassandra.cql3.functions
 
FunctionExecutionException - Exception in org.apache.cassandra.exceptions
 
FunctionExecutionException(FunctionName, List<String>, String) - Constructor for exception org.apache.cassandra.exceptions.FunctionExecutionException
 
functionFromCql(String, String, List<CQL3Type.Raw>) - Static method in class org.apache.cassandra.auth.FunctionResource
Creates a FunctionResource representing a specific, keyspace-scoped function.
functionName() - Method in class org.apache.cassandra.cql3.CqlParser
 
FunctionName - Class in org.apache.cassandra.cql3.functions
 
FunctionName(String, String) - Constructor for class org.apache.cassandra.cql3.functions.FunctionName
 
functionName - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithFunction
 
functionName - Variable in exception org.apache.cassandra.exceptions.FunctionExecutionException
 
FunctionResource - Class in org.apache.cassandra.auth
IResource implementation representing functions.
functionResource() - Method in class org.apache.cassandra.cql3.CqlParser
 
Functions - Class in org.apache.cassandra.cql3.functions
 
FUNCTIONS - Static variable in class org.apache.cassandra.schema.LegacySchemaTables
 
functionSignatureWithNameAndTypes(AbstractFunction) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
functionSignatureWithTypes(AbstractFunction) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 

G

G - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
G - Static variable in class org.apache.cassandra.cql3.CqlParser
 
gatherTombstones(ColumnFamily, Iterator<? extends 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_log_threshold_in_ms - Variable in class org.apache.cassandra.config.Config
 
gc_warn_threshold_in_ms - Variable in class org.apache.cassandra.config.Config
 
gcBefore(long) - 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
 
gcBefore - Variable in class org.apache.cassandra.repair.messages.ValidationRequest
 
gcBefore - Variable in class org.apache.cassandra.repair.Validator
 
gceRegion - Variable in class org.apache.cassandra.locator.GoogleCloudSnitch
 
gceZone - Variable in class org.apache.cassandra.locator.GoogleCloudSnitch
 
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
 
GCInspectorMXBean - Interface in org.apache.cassandra.service
 
GcStats - Class in org.apache.cassandra.tools.nodetool
 
GcStats() - Constructor for class org.apache.cassandra.tools.nodetool.GcStats
 
gcUpdaterFor(DecoratedKey) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
Updated closure with only the modified row key.
GE - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader.Operator
 
generate() - Static method in class org.apache.cassandra.utils.CounterId
 
generateLegacyCfId(String, String) - Static method in class org.apache.cassandra.config.CFMetaData
Generates deterministic UUID from keyspace/columnfamily name pair.
generation - Static variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
generation - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
generations - Variable in class org.apache.cassandra.db.compaction.LeveledManifest
 
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() - Method in interface org.apache.cassandra.concurrent.ExecutorLocal
This is called when scheduling the task, and also before calling ExecutorLocal#set(T) when running on a executor thread.
get(int) - Method in class org.apache.cassandra.cql3.Constants.Value
 
get(String, FunctionName, List<? extends AssignmentTestable>, String, String, AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.Functions
 
get(int) - Method in class org.apache.cassandra.cql3.Lists.Value
 
get(int) - Method in class org.apache.cassandra.cql3.Maps.Value
 
get(int) - Method in class org.apache.cassandra.cql3.Sets.Value
 
get(int) - Method in class org.apache.cassandra.cql3.Term.Terminal
 
get(int) - Method in class org.apache.cassandra.cql3.Tuples.InValue
 
get(int) - Method in class org.apache.cassandra.cql3.Tuples.Value
 
get(int) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
get(int) - Method in class org.apache.cassandra.db.composites.BoundedComposite
 
get(int) - Method in interface org.apache.cassandra.db.composites.Composite
 
get(int) - Method in class org.apache.cassandra.db.composites.CompoundComposite
 
get(int) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
 
get(int) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName.WithCollection
 
get(int) - Method in class org.apache.cassandra.db.composites.SimpleComposite
 
get(int) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
 
get(boolean, boolean) - Static method in enum org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState.Action
 
get(int) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
get(ByteBuffer, IPartitioner) - Static method in class org.apache.cassandra.db.RowPosition.ForKey
 
get() - Method in class org.apache.cassandra.io.sstable.ColumnStats.MaxIntTracker
 
get() - Method in class org.apache.cassandra.io.sstable.ColumnStats.MaxLongTracker
 
get() - Method in class org.apache.cassandra.io.sstable.ColumnStats.MinLongTracker
 
get(String, String) - Method in class org.apache.cassandra.locator.SnitchProperties
Get a snitch property value or return defaultValue if not defined.
get(InetAddress) - Static method in class org.apache.cassandra.metrics.StreamingMetrics
 
get(long, TimeUnit) - Method in class org.apache.cassandra.net.AsyncOneResponse
 
get() - Method in class org.apache.cassandra.service.AbstractReadExecutor
wait for an answer.
get() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
get() - Method in class org.apache.cassandra.service.ClientWarn
 
get(FileCacheService.CacheKey) - Method in class org.apache.cassandra.service.FileCacheService
 
get() - Method in class org.apache.cassandra.service.ReadCallback
 
get() - Method in class org.apache.cassandra.service.TruncateResponseHandler
 
get(byte) - Static method in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
 
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(int) - Method in class org.apache.cassandra.utils.concurrent.Accumulator
 
get() - Method in class org.apache.cassandra.utils.concurrent.Ref
 
get(T) - Method in class org.apache.cassandra.utils.concurrent.Refs
 
get(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
get(K) - Method in class org.apache.cassandra.utils.ExpiringMap
 
get(List<? extends Iterator<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.
get50thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
get50thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
get75thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
get75thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
get95thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
get95thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
get98thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
get98thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
get999thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
get999thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
get99thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
get99thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
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_multi_slice(MultiSliceRequest) - 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
 
getAcceptCount() - Method in class org.apache.cassandra.service.paxos.ProposeCallback
 
getActiveCompactions() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getActiveContentSize() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getActiveContentSize() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
 
getActiveCount() - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
getActiveOnDiskSize() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getActiveOnDiskSize() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
 
getActiveRepairedSSTableRefsForAntiCompaction(UUID, UUID) - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
Get the still active sstables we should run anticompaction on note that validation and streaming do not call this method - they have to work on the actual active sstables on the node, we only call this to know which sstables are still there that were there when we started the repair
getActiveSegmentCompressionRatios() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getActiveSegmentCompressionRatios() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
 
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.CommitLogSegmentManager
 
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
 
getAllMemtables() - Method in class org.apache.cassandra.db.lifecycle.View
 
getAllocator() - Method in class org.apache.cassandra.db.Memtable
 
getAllRanges(List<Token>) - Method in class org.apache.cassandra.service.StorageService
Get all ranges that span the ring given a set of tokens.
getAllRoles() - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
getAllRoles() - Method in interface org.apache.cassandra.auth.IRoleManager
Called during the execution of an unqualified LIST ROLES query.
getAllSessionInfo() - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
getAllSSTables() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
getAllSSTables() - Method in class org.apache.cassandra.db.Keyspace
 
getAllStreamSessions() - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
getAllTypes() - Method in class org.apache.cassandra.config.UTMetaData
 
getAncestors() - Method in class org.apache.cassandra.io.sstable.format.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(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
like getOverlappingSSTables, but acquires references before returning
getAndResetGCStats() - Method in class org.apache.cassandra.tools.NodeProbe
 
getAndResetStats() - Method in class org.apache.cassandra.service.GCInspector
 
getAndResetStats() - Method in interface org.apache.cassandra.service.GCInspectorMXBean
 
getApplicationState(ApplicationState) - Method in class org.apache.cassandra.gms.EndpointState
 
getApproximateKeyCount(Collection<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
Calculate approximate key count.
getArchiveCommand() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getArchiveCommand() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
Command to execute to archive a commitlog segment.
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.
getAsMap() - Method in class org.apache.cassandra.utils.StreamingHistogram
 
getAuthenticatedUser() - Method in interface org.apache.cassandra.auth.IAuthenticator.SaslNegotiator
Following a sucessful negotiation, get the AuthenticatedUser representing the logged in subject.
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
 
getAvailableRanges(String, IPartitioner) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
getAvailableRanges(String, IPartitioner) - Method in class org.apache.cassandra.dht.StreamStateStore
 
getAvailableSpace() - Method in class org.apache.cassandra.db.Directories.DataDirectory
 
getAverageIndexInterval() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
 
getAverageIndexInterval() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
 
getBackgroundCompactionTaskSubmitter() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
getBackingFiles() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
 
getBackingFiles() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
getBackingFiles() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
 
getBackupsDirectory(Descriptor) - Static method in class org.apache.cassandra.db.Directories
 
getBackupsDirectory(File) - 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
 
getBaseCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndex
 
getBatchlogMutationFor(Collection<Mutation>, UUID, int) - Static method in class org.apache.cassandra.db.BatchlogManager
 
getBatchlogReplayThrottleInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBatchlogTimeout() - Method in class org.apache.cassandra.db.BatchlogManager
 
getBatchSizeFailThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBatchSizeFailThresholdInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBatchSizeFailureThreshold() - Method in class org.apache.cassandra.service.StorageService
 
getBatchSizeFailureThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the threshold for rejecting queries due to a large batch size
getBatchSizeWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBits(int, int, int) - Static method in class org.apache.cassandra.net.MessagingService
 
getBlob(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getblock(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.MurmurHash
 
getBloomFilter() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getBloomFilterFpChance() - Method in class org.apache.cassandra.config.CFMetaData
 
getBloomFilterOffHeapSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Returns the amount of memory in bytes used off heap by the bloom filter.
getBloomFilterSerializedSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getBoolean(String, Boolean) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
getBoolean(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getBootstrapState() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
getBootstrapTokens(TokenMetadata) - 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
 
getBoundTerms() - Method in interface org.apache.cassandra.cql3.CQLStatement
Returns the number of bound terms in this statement.
getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
 
getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
 
getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
 
getBoundTerms() - Method in class org.apache.cassandra.cql3.statements.UseStatement
 
getBoundVariables() - Method in class org.apache.cassandra.cql3.statements.ParsedStatement
 
getBroadcastAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBroadcastAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getBroadcastRpcAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
May be null, please use FBUtilities.getBroadcastRpcAddress() instead.
getBroadcastRpcAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getBucketOffsets() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
getBuckets(Collection<Pair<T, Long>>, double, double, long) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
getBuckets(boolean) - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
getBuilder(Config.DiskAccessMode, boolean) - 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(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getByte(long) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
getByte(long) - Method in class org.apache.cassandra.io.util.Memory
 
getByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getByteBuffer(long, int) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
getByteBuffer(long, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getByteOrderAsymmetricColumnComparator(boolean) - Method in class org.apache.cassandra.db.composites.AbstractCType
 
getByteOrderAsymmetricColumnComparator(boolean) - Method in class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
 
getByteOrderColumnComparator(boolean) - Method in class org.apache.cassandra.db.composites.AbstractCType
 
getByteOrderColumnComparator(boolean) - Method in class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
 
getBytes(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getBytes(long, byte[], int, int) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
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
getBytes(long, byte[], int, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
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
 
getCacheCrcPath(String) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
getCacheDataPath(String) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
getCachedCounter(ByteBuffer, CellName) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getCachedEndpoints(Token) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getCachedPosition(DecoratedKey, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getCachedPosition(KeyCacheKey, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getCacheKey(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getCacheMetric(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
Retrieve cache metrics based on the cache type (KeyCache, RowCache, or CounterCache)
getCacheServiceMBean() - Method in class org.apache.cassandra.tools.NodeProbe
 
getCaching() - Method in class org.apache.cassandra.config.CFMetaData
 
getCachingOptions() - Method in class org.apache.cassandra.cql3.statements.CFPropDefs
 
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
 
getCasContentionTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCasContentionTimeout() - Method in class org.apache.cassandra.service.StorageProxy
 
getCasContentionTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getCassandraServer() - Method in class org.apache.cassandra.thrift.ThriftServer
 
getCellIterator(ColumnFamily) - Method in class org.apache.cassandra.db.filter.ColumnCounter
 
getCellIterator(ColumnFamily) - Method in class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefixReversed
 
getCF(UUID) - Method in class org.apache.cassandra.config.Schema
 
getCfDef(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
return the CfInfo for the column family
getCfDef(String) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
get the columnfamily definition for the signature
getCFDirectories() - Method in class org.apache.cassandra.db.Directories
 
getCfInfo(String) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
get the columnfamily definition for the signature
getCfInfo(Session) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
return the CfInfo for the column family
getCFMetaData(String, String) - Method in class org.apache.cassandra.config.Schema
Given a keyspace name and 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() - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
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
 
getCFMetaData(String, String, Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
get CFMetaData of a column family
getCFMetaData() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
 
getCfName() - Method in class org.apache.cassandra.cql3.IndexName
 
getCfsProxy(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getChannel() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
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
 
getClause() - Method in class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
 
getClientAddress() - Method in class org.apache.cassandra.service.QueryState
 
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
 
getClockAndCountOf(ByteBuffer, CounterId) - Method in class org.apache.cassandra.db.context.CounterContext
Returns the clock and the count associated with the given counter id, or (0, 0) if no such shard is present.
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
 
getCluster(String[], Configuration, int) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getClusteringColumn(int) - Method in interface org.apache.cassandra.cql3.CQL3Row
 
getClusteringColumnsAsComposites(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Returns the requested clustering columns as Composites.
getClusteringColumnsBounds(Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Returns the bounds (start or end) of the clustering columns.
getClusteringColumnsBoundsAsComposites(Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Returns the bounds (start or end) of the clustering columns as Composites.
getClusterName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getClusterName() - Method in class org.apache.cassandra.service.StorageService
Returns the name of the cluster
getClusterName() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the name of the cluster
getClusterName() - Method in class org.apache.cassandra.tools.NodeProbe
 
getCmd(String) - Static method in class org.apache.cassandra.utils.progress.jmx.LegacyJMXProgressSupport
 
getCollectionElementValue() - Method in class org.apache.cassandra.cql3.ColumnCondition.Bound
 
getCollectionsParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
 
getColumn(ColumnIdentifier) - Method in interface org.apache.cassandra.cql3.CQL3Row
 
getColumn(CellName) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
getColumn(CellName) - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
getColumn(CellName) - Method in class org.apache.cassandra.db.ColumnFamily
Get a column given its name, returning null if the column is not present.
getColumnComparator(CellNameType) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
 
getColumnComparator(CellNameType) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getColumnComparator(CellNameType) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getColumnCount() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
getColumnCount() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
getColumnCount() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
getColumnCount() - Method in class org.apache.cassandra.db.ColumnFamily
Returns the number of columns in this map.
getColumnDefinition(ColumnIdentifier) - Method in class org.apache.cassandra.config.CFMetaData
Returns the ColumnDefinition for name.
getColumnDefinition(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
 
getColumnDefinition(CellName) - Method in class org.apache.cassandra.config.CFMetaData
Returns a ColumnDefinition given a cell name.
getColumnDefinitionComparator(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
 
getColumnDefinitionForIndex(String) - Method in class org.apache.cassandra.config.CFMetaData
 
getColumnDefs() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
 
getColumnDefs() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Returns the column definitions in position order.
getColumnDefs() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
 
getColumnDefs() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
getColumnDefs() - Method in class org.apache.cassandra.db.index.SecondaryIndex
 
getColumnFamilies() - Method in class org.apache.cassandra.db.CounterMutation
 
getColumnFamilies() - Method in interface org.apache.cassandra.db.IMutation
 
getColumnFamilies() - Method in class org.apache.cassandra.db.Mutation
 
getColumnFamilies() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
getColumnFamily() - Method in class org.apache.cassandra.cql3.CFName
 
getColumnFamily(DecoratedKey, Composite, Composite, boolean, int, long) - 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.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.Mutation
 
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
Deprecated.
 
getColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleWriter
Deprecated.
 
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.Mutation
 
getColumnFamilyMetric(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
Retrieve ColumnFamily metrics
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.Keyspace
 
getColumnFamilyStore(UUID) - Method in class org.apache.cassandra.db.Keyspace
 
getColumnFamilyStoreIncludingIndexes(Pair<String, String>) - Method in class org.apache.cassandra.config.Schema
Retrieve a CFS by name even if that CFS is an index An index is identified by looking for '.' in the CF name and separating to find the base table containing the index
getColumnFamilyStoreInstance(UUID) - Method in class org.apache.cassandra.config.Schema
 
getColumnFamilyStoreMBeanProxies() - Method in class org.apache.cassandra.tools.NodeProbe
 
getColumnFamilyStores() - Method in class org.apache.cassandra.db.Keyspace
 
getColumnIndex(ColumnDefinition) - Method in class org.apache.cassandra.cql3.selection.Selection
Returns the index of the specified column
getColumnIndexSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getColumnIterator(ColumnFamily) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
returns an iterator that returns columns from the given columnFamily matching the Filter criteria in sorted order.
getColumnIterator(DecoratedKey, ColumnFamily) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
 
getColumnIterator(ColumnFamily) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getColumnIterator(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getColumnIterator(ColumnFamily) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getColumnIterator(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getColumnMapping() - Method in class org.apache.cassandra.cql3.selection.Selection
 
getColumnMeta(Cassandra.Client, boolean, boolean) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
get column meta data
getColumnMetadata() - Method in class org.apache.cassandra.config.CFMetaData
 
getColumnMetadata(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
get a list of column for the column family
getColumnName() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Returns the name of the column corresponding to the output value of the selector instances created by this factory.
getColumnNames() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
getColumnNames() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
getColumnNames() - Method in class org.apache.cassandra.db.ColumnFamily
Returns an iterable with the names of columns in this column map in the same order as the underlying columns themselves.
getColumnNamesAsString() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
Returns the column names as a comma separated String.
getColumns() - Method in class org.apache.cassandra.cql3.selection.Selection
 
getColumns() - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getColumnsInCommons(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
Returns the names of the columns that are specified within this Restrictions and the other one as a comma separated String.
getColumnSpecification(CFMetaData) - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Returns the column specification corresponding to the output value of the selector instances created by this factory.
getColumnSpecifications() - Method in class org.apache.cassandra.cql3.QueryOptions
Returns the column specifications for the bound variables (optional operation).
getColumnSpecifications() - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
getColumnSpecifications() - Method in interface org.apache.cassandra.cql3.selection.SelectionColumns
 
getColumnsString(CellNameType, Iterable<Cell>) - Static method in class org.apache.cassandra.db.composites.CellNames
 
getColumnStats() - Method in class org.apache.cassandra.db.ColumnFamily
 
getColumnsWithConditions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
getComment() - Method in class org.apache.cassandra.config.CFMetaData
 
getCommitFailurePolicy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCommitLogCompression() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
getCommitLogLowerBound() - Method in class org.apache.cassandra.db.Memtable
 
getCommitLogMaxCompressionBuffersInPool() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
 
getCompactedRowWriter(CompactionController, ImmutableList<OnDiskAtomIterator>) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
 
getCompactedRowWriter(CompactionController, ImmutableList<OnDiskAtomIterator>) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
 
getCompacting() - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
getCompactionAwareWriter(ColumnFamilyStore, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
getCompactionAwareWriter(ColumnFamilyStore, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
getCompactionAwareWriter(ColumnFamilyStore, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
 
getCompactionAwareWriter(ColumnFamilyStore, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
 
getCompactionCandidates() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
getCompactionController(Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
getCompactionController(Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
 
getCompactionHistory() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getCompactionHistory() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
compaction history
getCompactionHistory() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
getCompactionHistory() - Method in class org.apache.cassandra.tools.NodeProbe
 
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
 
getCompactionInfo() - Method in class org.apache.cassandra.io.sstable.IndexSummaryRedistribution
 
getCompactionLargePartitionWarningThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCompactionManagerProxy() - Method in class org.apache.cassandra.tools.NodeProbe
 
getCompactionMetric(String) - Method in class org.apache.cassandra.tools.NodeProbe
Retrieve Proxy metrics
getCompactionOptions() - Method in class org.apache.cassandra.cql3.statements.CFPropDefs
 
getCompactionParameters() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getCompactionParameters() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getCompactionParametersJson() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getCompactionParametersJson() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
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.statements.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
Deprecated.
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.
getCompactionTask(LifecycleTransaction, int, long) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getCompactionTask(LifecycleTransaction, int, long) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
getCompactionTask(LifecycleTransaction, int, long) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
GetCompactionThreshold - Class in org.apache.cassandra.tools.nodetool
 
GetCompactionThreshold() - Constructor for class org.apache.cassandra.tools.nodetool.GetCompactionThreshold
 
getCompactionThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
 
GetCompactionThroughput - Class in org.apache.cassandra.tools.nodetool
 
GetCompactionThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.GetCompactionThroughput
 
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() - Method in class org.apache.cassandra.db.ColumnFamily
 
getComparator() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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(CType, boolean) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
 
getComparatorFor(CFMetaData, ByteBuffer) - Static method in class org.apache.cassandra.db.SuperColumns
 
getComparatorFor(CFMetaData, boolean) - Static method in class org.apache.cassandra.db.SuperColumns
 
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 class org.apache.cassandra.concurrent.SEPExecutor
 
getCompletedTasks() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
 
getCompletedTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getComponent(int) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
getComponentComparator(Integer, ColumnDefinition.Kind) - Method in class org.apache.cassandra.config.CFMetaData
 
getComponents() - Method in class org.apache.cassandra.db.marshal.AbstractType
Return a list of the "subcomponents" this type has.
getComponents() - Method in class org.apache.cassandra.db.marshal.CompositeType
 
getCompressedBuilder(CompressedSequentialWriter) - Static method in class org.apache.cassandra.io.util.SegmentedFile
 
getCompressionMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Returns the compression metadata for this sstable.
getCompressionMetadataOffHeapSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Returns the amount of memory in bytes used off heap by the compression meta-data.
getCompressionOptions() - Method in class org.apache.cassandra.cql3.statements.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.io.sstable.format.SSTableReader
 
getCompressor() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
Returns the compressor used to compress the segments.
getCompressor() - Method in class org.apache.cassandra.transport.Connection
 
getCompressorClass() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
Returns the compressor class.
getCompressorName() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
Returns the compressor name.
getConcurrentCompactors() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConcurrentCounterWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConcurrentReaders() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConcurrentWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConfiguration(JobContext) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
Invoke getConfiguration() on JobContext.
getConnectedClients() - Method in class org.apache.cassandra.thrift.ThriftSessionManager
 
getConnectedClients() - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
 
getConnection(InetAddress, MessageOut) - Method in class org.apache.cassandra.net.MessagingService
 
getConnectionFactory() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
Provides connection factory.
getConnectionPool(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
getConsistency() - Method in class org.apache.cassandra.cql3.BatchQueryOptions
 
getConsistency() - Method in class org.apache.cassandra.cql3.QueryOptions
 
getContactedReplicas() - Method in class org.apache.cassandra.service.AbstractReadExecutor
Get the replicas involved in the [finished] request.
getContext() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getContext() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
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
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
 
getCount() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxCounterMBean
 
getCount() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
getCount() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
 
getCounter(TaskInputOutputContext, String, String) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
Invoke getCounter() on TaskInputOutputContext.
getCounter(Enum<?>) - Method in class org.apache.cassandra.hadoop.ReporterWrapper
 
getCounter(String, String) - Method in class org.apache.cassandra.hadoop.ReporterWrapper
 
getCounterCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCounterCacheKeysToSave() - Method in class org.apache.cassandra.service.CacheService
 
getCounterCacheKeysToSave() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getCounterCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCounterCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
 
getCounterCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getCounterCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCounterId() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
getCounterWriteRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCounterWriteRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
 
getCounterWriteRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getCQLQueryHandler() - Static method in class org.apache.cassandra.service.ClientState
 
getCQLSupportedVersion() - Static method in class org.apache.cassandra.service.ClientState
 
getCrc() - Method in class org.apache.cassandra.utils.PureJavaCrc32
 
getCrcCheckChance() - Method in class org.apache.cassandra.io.compress.CompressionParameters
 
getCreationTimeFor(Component) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getCurrent() - Method in class org.apache.cassandra.utils.concurrent.OpOrder
 
getCurrentDescriptor() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
getCurrentDescriptor() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
 
getCurrentDescriptor() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
Deprecated.
 
getCurrentDescriptor() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleWriter
Deprecated.
 
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
Deprecated.
 
getCurrentKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
getCurrentlyBlockedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
getCurrentMemtable() - Method in class org.apache.cassandra.db.lifecycle.View
 
getCurrentPosition() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
 
getCurrentPosition() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
getCurrentPosition() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
 
getCurrentStat() - Method in class org.apache.cassandra.repair.SyncTask
 
getCurrentState() - Method in class org.apache.cassandra.streaming.StreamResultFuture
 
getCurrentStreams() - Method in class org.apache.cassandra.streaming.StreamManager
 
getCurrentStreams() - Method in interface org.apache.cassandra.streaming.StreamManagerMBean
Returns the current state of all ongoing streams.
getCurrentValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
Deprecated.
 
getCurrentValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
getCustomOptions(RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
getCustomOptions(RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
Where an implementation supports OPTIONS in CREATE and ALTER operations this method should return the Map representing the custom options associated with the role, as supplied to CREATE or ALTER.
getCustomOptions() - Method in class org.apache.cassandra.auth.RoleOptions
Return a Map representing custom options It is the responsiblity of IRoleManager implementations which support IRoleManager.Option.OPTION to handle type checking and conversion of these values, if present
getCustomPayload() - Method in class org.apache.cassandra.transport.Message
 
getData() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
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() - Static method in class org.apache.cassandra.db.SystemKeyspace
Gets the stored data center for the local node, or null if none have been set yet.
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.CloudstackSnitch
 
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() - 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() - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
Provides the Datacenter name depending on the respective snitch used for this node
getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.GoogleCloudSnitch
 
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
 
getDataCenters() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
getDcLocalReadRepairChance() - Method in class org.apache.cassandra.config.CFMetaData
 
getDefaultGcBefore(ColumnFamilyStore) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
 
getDefaultIndexName(String, ColumnIdentifier) - Static method in class org.apache.cassandra.config.CFMetaData
 
getDefaultMarshallers(CfDef) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
construct a map to store the mashaller type to cassandra data type mapping
getDefaultTimeToLive() - Method in class org.apache.cassandra.config.CFMetaData
 
getDefaultTimeToLive() - Method in class org.apache.cassandra.cql3.statements.CFPropDefs
 
getDefaultValidator() - Method in class org.apache.cassandra.config.CFMetaData
 
getDelegates() - Method in class org.apache.cassandra.cql3.CqlLexer
 
getDelegates() - Method in class org.apache.cassandra.cql3.CqlParser
 
getDeleteSourceOnSuccess(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
getDescription() - Method in class org.apache.cassandra.cql3.CqlLexer.DFA13
 
getDescription() - Method in class org.apache.cassandra.cql3.CqlLexer.DFA21
 
getDescription() - Method in class org.apache.cassandra.cql3.CqlParser.DFA13
 
getDescription() - Method in class org.apache.cassandra.cql3.CqlParser.DFA130
 
getDescription() - Method in class org.apache.cassandra.cql3.CqlParser.DFA131
 
getDescription() - Method in class org.apache.cassandra.cql3.CqlParser.DFA149
 
getDescription() - Method in class org.apache.cassandra.cql3.CqlParser.DFA151
 
getDescription() - Method in class org.apache.cassandra.cql3.CqlParser.DFA153
 
getDescription() - Method in class org.apache.cassandra.cql3.CqlParser.DFA155
 
getDescription() - Method in class org.apache.cassandra.cql3.CqlParser.DFA158
 
getDescription() - Method in class org.apache.cassandra.cql3.CqlParser.DFA164
 
getDescription() - Method in class org.apache.cassandra.cql3.CqlParser.DFA169
 
getDescription() - Method in class org.apache.cassandra.cql3.CqlParser.DFA170
 
getDescription() - Method in class org.apache.cassandra.cql3.CqlParser.DFA179
 
getDescription() - Method in class org.apache.cassandra.cql3.CqlParser.DFA2
 
getDescription() - Method in class org.apache.cassandra.cql3.CqlParser.DFA40
 
getDirectories() - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
The directories we can write to
getDirectoryForNewSSTables() - Method in class org.apache.cassandra.db.Directories
Basically the same as calling Directories.getWriteableLocationAsFile(long) with an unknown size (-1L), which may return any non-blacklisted directory - even a data directory that has no usable space.
getDirtyCFIDs() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getDisableSTCSInL0() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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.statements.PropertyDefinitions
 
getDouble(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getDownEndpointCount() - Method in class org.apache.cassandra.gms.FailureDetector
 
getDownEndpointCount() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
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)
getDroppableTombstonesBefore(int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getDroppableTombstonesBefore(int) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
getDroppedColumns() - Method in class org.apache.cassandra.config.CFMetaData
 
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
 
getDurationUnit() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
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
 
getEffectiveIndexInterval() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getEffectiveIndexInterval() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
getEffectiveIndexIntervalAfterIndex(int, int, int) - Static method in class org.apache.cassandra.io.sstable.Downsampling
Calculates the effective index interval after the entry at `index` in an IndexSummary.
getEffectiveIndexIntervalAfterIndex(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
Returns the number of primary (on-disk) index entries between the index summary entry at `index` and the next index summary entry (assuming there is one).
getElement(ByteBuffer, int) - Method in class org.apache.cassandra.serializers.ListSerializer
Returns the element at the given index in a list.
getElementCount(T) - Method in class org.apache.cassandra.serializers.CollectionSerializer
 
getElementCount(List<T>) - Method in class org.apache.cassandra.serializers.ListSerializer
 
getElementCount(Map<K, V>) - Method in class org.apache.cassandra.serializers.MapSerializer
 
getElementCount(Set<T>) - Method in class org.apache.cassandra.serializers.SetSerializer
 
getElementIndex() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
getElements() - Method in class org.apache.cassandra.cql3.Lists.Value
 
getElements() - Method in class org.apache.cassandra.cql3.Term.MultiItemTerminal
 
getElements() - Method in class org.apache.cassandra.cql3.Tuples.Value
 
getElementsType() - Method in class org.apache.cassandra.db.marshal.ListType
 
getElementsType() - Method in class org.apache.cassandra.db.marshal.SetType
 
getEndInSummary(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
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) - Static 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
 
GetEndpoints - Class in org.apache.cassandra.tools.nodetool
 
GetEndpoints() - Constructor for class org.apache.cassandra.tools.nodetool.GetEndpoints
 
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
 
getEndpointToHostId() - Method in class org.apache.cassandra.service.StorageService
 
getEndpointToHostId() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve the mapping of endpoint to host ID
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
 
getEntities() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
getEntity() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
getEntryIterator(RowPosition, RowPosition) - Method in class org.apache.cassandra.db.Memtable
 
getEstimatedColumnCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getEstimatedDroppableTombstoneRatio(int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getEstimatedDroppableTombstoneRatio(int) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
getEstimatedKeyCount() - Method in class org.apache.cassandra.io.sstable.IndexSummary
Returns an estimate of the total number of keys in the SSTable.
getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
 
getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
getEstimatedRowSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getEstimatedTasks() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
getExceptionCount() - Method in class org.apache.cassandra.tools.NodeProbe
 
getExpectedCompactedFileSize(Iterable<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Calculate expected file size of SSTable after compaction.
getExpireTimeForEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
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(DecoratedKey, 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.
getExtraFilter(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
 
getFactory() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
getFactory() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
getFactory() - Method in class org.apache.cassandra.db.ColumnFamily
Returns the factory used for this ISortedColumns implementation.
getFailedHosts() - Method in class org.apache.cassandra.io.sstable.SSTableLoader
 
getFailureDetectorPhilValues() - Method in class org.apache.cassandra.tools.NodeProbe
 
getFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getfd(FileChannel) - Static method in class org.apache.cassandra.utils.CLibrary
 
getfd(FileDescriptor) - Static method in class org.apache.cassandra.utils.CLibrary
Get system file descriptor from FileDescriptor object.
getfd(String) - Static method in class org.apache.cassandra.utils.CLibrary
 
getFifteenMinuteRate() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
 
getFileCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFileDataInput(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getFileDescriptor() - Method in class org.apache.cassandra.io.util.ChannelProxy
 
getFileMessages() - Method in class org.apache.cassandra.streaming.StreamTransferTask
 
getFilename() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getFilename() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getFilePointer() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
getFilePointer() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
getFilePointer() - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
 
getFilePointer() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
getFilePointer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
getFilePointer() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
getFileStore(Path) - Static method in class org.apache.cassandra.io.util.FileUtils
Returns the FileStore representing the file store where a file is located.
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
 
getFirstColumn() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
 
getFirstColumn() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Returns the definition of the first column.
getFirstColumn() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
 
getFirstColumn() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
getFirstEmptyKey() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
getFiveMinuteRate() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
 
getFlushWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFormat() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
getFormatType(Collection<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
 
getFreeSpace(File) - Static method in class org.apache.cassandra.io.util.FileUtils
Returns the number of unallocated bytes on the specified partition.
getFullyExpiredSSTables() - Method in class org.apache.cassandra.db.compaction.CompactionController
 
getFullyExpiredSSTables(ColumnFamilyStore, Iterable<SSTableReader>, Iterable<SSTableReader>, int) - Static method in class org.apache.cassandra.db.compaction.CompactionController
Finds expired sstables works something like this; 1.
getFullyQualifiedClassName(String) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
get the full class name
getFullyQualifiedClassName(String) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
get the full class name
getFunctionName() - Method in class org.apache.cassandra.auth.FunctionResource
 
getFunctions() - Method in class org.apache.cassandra.cql3.AbstractMarker
 
getFunctions() - Method in class org.apache.cassandra.cql3.Attributes
 
getFunctions() - Method in class org.apache.cassandra.cql3.ColumnCondition
 
getFunctions() - Method in interface org.apache.cassandra.cql3.CQLStatement
Return an Iterable over all of the functions (both native and user-defined) used by any component of the statement
getFunctions() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
getFunctions() - Method in interface org.apache.cassandra.cql3.functions.Function
 
getFunctions() - Method in class org.apache.cassandra.cql3.functions.FunctionCall
 
getFunctions() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
getFunctions() - Method in class org.apache.cassandra.cql3.Lists.DelayedValue
 
getFunctions() - Method in class org.apache.cassandra.cql3.Maps.DelayedValue
 
getFunctions() - Method in class org.apache.cassandra.cql3.Operation
 
getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQ
 
getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InWithMarker
 
getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InWithValues
 
getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
 
getFunctions() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Return an Iterable over all of the functions (both native and user-defined) used by any component of the restriction
getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
 
getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQ
 
getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InWithMarker
 
getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InWithValues
 
getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
 
getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQ
 
getFunctions() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.Slice
 
getFunctions() - Method in class org.apache.cassandra.cql3.selection.Selection
 
getFunctions() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
 
getFunctions() - Method in class org.apache.cassandra.cql3.Sets.DelayedValue
 
getFunctions() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
getFunctions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
getFunctions() - Method in class org.apache.cassandra.cql3.statements.ParsedStatement
 
getFunctions() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
getFunctions() - Method in interface org.apache.cassandra.cql3.Term
 
getFunctions() - Method in class org.apache.cassandra.cql3.Term.Terminal
 
getFunctions(Iterable<Term>) - Static method in class org.apache.cassandra.cql3.Terms
 
getFunctions() - Method in class org.apache.cassandra.cql3.Tuples.DelayedValue
 
getFunctions() - Method in class org.apache.cassandra.cql3.UserTypes.DelayedValue
 
getGcGraceSeconds() - Method in class org.apache.cassandra.config.CFMetaData
 
getGCLogThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getGCWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getGossipInfo() - Method in class org.apache.cassandra.tools.NodeProbe
 
getGossipMessageCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getGossipMessageCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Completed tasks for gossip message TCP Connections
getGossipMessageDroppedTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getGossipMessageDroppedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Dropped tasks for gossip message TCP Connections
getGossipMessagePendingTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getGossipMessagePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Pending tasks for gossip message TCP Connections
getGrammarFileName() - Method in class org.apache.cassandra.cql3.CqlLexer
 
getGrammarFileName() - Method in class org.apache.cassandra.cql3.CqlParser
 
getGroup() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Returns the group to which the Metric belongs.
getHashBuckets(IFilter.FilterKey, int, long) - Method in class org.apache.cassandra.utils.BloomFilter
 
getHeapMemoryUsage() - Method in class org.apache.cassandra.tools.NodeProbe
 
getHeapSize() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
getHeapSize() - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
 
getHeapSize() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
getHeapSize() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner.StringToken
 
getHeapSize() - Method in class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
 
getHeapSize() - Method in class org.apache.cassandra.dht.Token
 
getHighestSelectivityIndexSearcher(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
getHintedHandoffEnabled() - Method in class org.apache.cassandra.service.StorageProxy
 
getHintedHandoffEnabled() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getHintedHandoffEnabledByDC() - Method in class org.apache.cassandra.service.StorageProxy
 
getHintedHandoffEnabledByDC() - 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
 
getHollowByteBuffer() - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getHollowDirectByteBuffer() - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getHostId(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
getHostId(InetAddress, Map<InetAddress, EndpointState>) - 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
Deprecated.
getHostIdMap() - Method in class org.apache.cassandra.tools.NodeProbe
 
getHostIdToEndpoint() - Method in class org.apache.cassandra.service.StorageService
 
getHostIdToEndpoint() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve the mapping of host ID to endpoint
getHosts() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
getId(String, String) - Method in class org.apache.cassandra.config.Schema
Lookup keyspace/ColumnFamily identifier
getId() - Method in class org.apache.cassandra.cql3.statements.CFPropDefs
 
getId() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getId() - Method in class org.apache.cassandra.repair.RepairSession
 
getId(int) - Method in enum org.apache.cassandra.transport.DataType
 
getId(int) - Method in interface org.apache.cassandra.transport.OptionCodec.Codecable
 
getIdentityFilter(DecoratedKey, String, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
return a QueryFilter object that includes every column in the row.
getIdx() - Method in class org.apache.cassandra.cql3.IndexName
 
getIfExists(UUID) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
Returns a ColumnFamilyStore by cfId if it exists, null otherwise Differently from others, this method does not throw exception if the table does not exist.
getIfExists(String, String) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
Returns a ColumnFamilyStore by ksname and cfname if it exists, null otherwise Differently from others, this method does not throw exception if the keyspace or table does not exist.
getIgnoreHosts(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
Get the hosts to ignore as a collection of strings
getIndexAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getIndexByName(String) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
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() - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
 
getIndexComparator(CFMetaData, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.composites.CompositesIndex
 
getIndexComparator(CFMetaData, ColumnDefinition) - Static method in class org.apache.cassandra.db.index.SecondaryIndex
Returns the index comparator for index backed by CFS, or null.
getIndexedValue(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
getIndexedValue(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
 
getIndexedValue(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKey
 
getIndexedValue(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKeyAndValue
 
getIndexedValue(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionValue
 
getIndexedValue(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
 
getIndexedValue(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
 
getIndexedValue(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
getIndexes() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
getIndexes() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
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
 
getIndexExpressions(SecondaryIndexManager, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
getIndexFilename() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getIndexForColumn(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
getIndexIntervals() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
 
getIndexIntervals() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
Returns a map of SSTable filenames to their current effective index interval.
getIndexKeyComparator() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
getIndexKeyComparator() - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKey
 
getIndexKeyComparator() - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKeyAndValue
 
getIndexKeyComparator() - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionValue
 
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.db.index.AbstractSimplePerColumnSecondaryIndex
 
getIndexName() - Method in class org.apache.cassandra.db.index.SecondaryIndex
 
getIndexOptions() - Method in class org.apache.cassandra.config.ColumnDefinition
 
getIndexScanPosition(RowPosition) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Gets the position in the index file to start scanning to find the given key (at most indexInterval keys away, modulo downsampling of the index summary).
getIndexScanPositionFromBinarySearchResult(int, IndexSummary) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getIndexSearchersForQuery(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
Get a list of IndexSearchers from the union of expression index types
getIndexSerializer(CFMetaData) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
 
getIndexSerializer(CFMetaData) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
 
getIndexSummaryCapacityInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getIndexSummaryIndexFromBinarySearchResult(int) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getIndexSummaryKey(int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Returns the key for the index summary entry at `index`.
getIndexSummaryOffHeapSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getIndexSummaryResizeIntervalInMinutes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getIndexSummarySamplingLevel() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getIndexSummarySize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Returns the number of entries in the IndexSummary.
getIndexType() - Method in class org.apache.cassandra.config.ColumnDefinition
 
getIndexType(String) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
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
 
getInputCluster(String, Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputCluster(String[], Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputColumnFamily(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputcolumns(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputCoreConnections(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputCql(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputFormat() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
getInputFormat() - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
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
 
getInputMaxConnections(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputMaxSimultReqPerConnections(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeAuthProvider(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeConnectionTimeout(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeKeepAlive(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativePort(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeReadConnectionTimeout(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeReceiveBufferSize(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeReuseAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeSendBufferSize(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeSolinger(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeSSLCipherSuites(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeSSLKeystorePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeSSLKeystorePath(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeSSLTruststorePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeSSLTruststorePath(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeTcpNodelay(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
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
 
getInputSplit() - Method in class org.apache.cassandra.hadoop.ReporterWrapper
 
getInputSplitSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputSplitSizeInMb(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
cassandra.input.split.size will be used if the value is undefined or negative.
getInputStream(File, File) - Method in interface org.apache.cassandra.cache.AutoSavingCache.IStreamFactory
 
getInputWhereClauses(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInstance(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.FromJsonFct
 
getInstance(List<AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.functions.ToJsonFct
 
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(AbstractType...) - 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.FrozenType
 
getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.ListType
 
getInstance(AbstractType<T>, boolean) - 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>, boolean) - 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>, boolean) - Static method in class org.apache.cassandra.db.marshal.SetType
 
getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.TupleType
 
getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.UserType
 
getInstance(TypeSerializer<T>) - Static method in class org.apache.cassandra.serializers.ListSerializer
 
getInstance(TypeSerializer<K>, TypeSerializer<V>) - Static method in class org.apache.cassandra.serializers.MapSerializer
 
getInstance(TypeSerializer<T>) - Static method in class org.apache.cassandra.serializers.SetSerializer
 
getInt(String, Integer) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
getInt(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getInt(long) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
getInt(long) - Method in class org.apache.cassandra.io.util.Memory
 
getInt(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getIntByByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getInterDCStreamThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
 
GetInterDCStreamThroughput - Class in org.apache.cassandra.tools.nodetool
 
GetInterDCStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.GetInterDCStreamThroughput
 
getInterDCStreamThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
 
getInterDCStreamThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getInterDCStreamThroughputOutboundMegabitsPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
 
getIOWait() - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
 
getIsDense() - Method in class org.apache.cassandra.config.CFMetaData
 
getIterator(ColumnFamily) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
getIterator(Iterable<Memtable>, Collection<SSTableReader>, DataRange, ColumnFamilyStore, long) - 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.
getJmxMetric(MBeanServerConnection, String, String, String) - Static method in class org.apache.cassandra.metrics.ThreadPoolMetrics
 
getJmxName() - Method in enum org.apache.cassandra.concurrent.Stage
 
getJmxThreadPools(MBeanServerConnection) - Static method in class org.apache.cassandra.metrics.ThreadPoolMetrics
 
getJmxType() - Method in enum org.apache.cassandra.concurrent.Stage
 
getJobThreads() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
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
 
getJsonColumnValue(int, ColumnIdentifier, Collection<ColumnDefinition>) - Method in class org.apache.cassandra.cql3.QueryOptions
Returns the term corresponding to column columnName in the JSON value of bind index bindIndex.
getJsonDateFormatter() - Static method in class org.apache.cassandra.serializers.TimestampSerializer
 
getKey() - Method in class org.apache.cassandra.db.BufferDecoratedKey
 
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.DecoratedKey
 
getKey() - Method in class org.apache.cassandra.db.NativeDecoratedKey
 
getKey(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
getKey() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
getKeyCache() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getKeyCacheHit() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getKeyCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getKeyCacheKeysToSave() - Method in class org.apache.cassandra.service.CacheService
 
getKeyCacheKeysToSave() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getKeyCacheRequest() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
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
 
getKeyCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getKeySamples(Range<Token>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getKeyspace() - Method in class org.apache.cassandra.auth.DataResource
 
getKeyspace() - Method in class org.apache.cassandra.auth.FunctionResource
Get the name of the keyspace this resource relates to.
getKeyspace() - Method in class org.apache.cassandra.cql3.UTName
 
getKeyspace() - Method in class org.apache.cassandra.db.AbstractRangeCommand
 
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.ReadCommand
 
getKeyspace() - Method in class org.apache.cassandra.service.ClientState
 
getKeyspace() - Method in interface org.apache.cassandra.service.IReadCommand
 
getKeyspaceDefinitions() - Method in class org.apache.cassandra.config.Schema
 
getKeyspaceInstance(String) - Method in class org.apache.cassandra.config.Schema
Get keyspace instance by name
getKeyspaceMetaData(String) - Method in class org.apache.cassandra.config.Schema
Get metadata about keyspace inner ColumnFamilies
getKeyspaceName() - Method in class org.apache.cassandra.db.CounterMutation
 
getKeyspaceName() - Method in interface org.apache.cassandra.db.IMutation
 
getKeyspaceName() - Method in class org.apache.cassandra.db.Mutation
 
getKeyspaceName() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getKeyspaces() - Method in class org.apache.cassandra.config.Schema
 
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
 
getKeysType() - Method in class org.apache.cassandra.db.marshal.MapType
 
getKeyValidator() - Method in class org.apache.cassandra.config.CFMetaData
 
getKeyValidatorAsCType() - Method in class org.apache.cassandra.config.CFMetaData
 
getKeyValueParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
 
getKSChildDirectories(String) - Static method in class org.apache.cassandra.db.Directories
 
getKSMetaData(String) - Method in class org.apache.cassandra.config.Schema
Get metadata about keyspace by its name
getLargeMessageCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getLargeMessageCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Completed tasks for large message) TCP Connections
getLargeMessageDroppedTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getLargeMessageDroppedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Dropped tasks for large message TCP Connections
getLargeMessagePendingTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getLargeMessagePendingTasks(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
getLargeMessagePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Pending tasks for large message TCP Connections
getLargestBucketOffset() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
getLastColumn() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
 
getLastColumn() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Returns the definition of the last column.
getLastColumn() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
 
getLastColumn() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
getLastFlushOffset() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
getLastReadableBoundary() - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
getLatestVersion() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
 
getLatestVersion() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
 
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
 
getLegacyUserdata(String, ProgressEvent) - Static method in class org.apache.cassandra.utils.progress.jmx.LegacyJMXProgressSupport
 
getLength() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
getLength() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
getLengthInBytes() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
 
getLengthInBytes() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
getLengthInBytes() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
 
getLevel() - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
getLevel() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
 
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
 
getLimit(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
May be used by custom QueryHandler implementations
getLimit() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
getList(String, AbstractType<T>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getListenAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getLiveCount(ColumnFamily, long) - Method in class org.apache.cassandra.db.DataRange
 
getLiveCount(ColumnFamily, long) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
 
getLiveCount(ColumnFamily, long) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getLiveCount(ColumnFamily, long) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getLiveCount(IDiskAtomFilter, long) - Method in class org.apache.cassandra.db.Row
 
getLiveDataSize() - Method in class org.apache.cassandra.db.Memtable
 
getLiveMembers() - Method in class org.apache.cassandra.gms.Gossiper
 
getLiveNaturalEndpoints(Keyspace, 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(Keyspace, 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
 
getLiveRingMembers() - Method in class org.apache.cassandra.service.StorageService
 
getLiveRingMembers(boolean) - Method in class org.apache.cassandra.service.StorageService
 
getLiveSortedEndpoints(Keyspace, ByteBuffer) - Static method in class org.apache.cassandra.service.StorageProxy
 
getLiveTokenOwners() - Method in class org.apache.cassandra.gms.Gossiper
 
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
 
getLocalAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
Please use getBroadcastAddress instead.
getLocalClockAndCount(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Returns the clock and the count associated with the local counter id, or (0, 0) if no such shard is present.
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.AbstractCell
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.BufferDeletedCell
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.BufferExpiringCell
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.NativeDeletedCell
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.NativeExpiringCell
 
getLocalDeletionTime() - Method in interface org.apache.cassandra.db.OnDiskAtom
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.RangeTombstone
 
getLocalHostId() - Static method in class org.apache.cassandra.db.SystemKeyspace
Read the host ID from the system keyspace, 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
 
getLocalizedMessage() - Method in exception org.apache.cassandra.db.filter.TombstoneOverwhelmingException
 
getLocalRanges(String) - Method in class org.apache.cassandra.service.StorageService
 
getLocalTokens() - Method in class org.apache.cassandra.service.StorageService
 
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
 
getLogger(Logger, long, TimeUnit) - Static method in class org.apache.cassandra.utils.NoSpamLogger
 
getLoggingLevels() - Method in class org.apache.cassandra.service.StorageService
 
getLoggingLevels() - Method in interface org.apache.cassandra.service.StorageServiceMBean
get the runtime logging levels
getLoggingLevels() - Method in class org.apache.cassandra.tools.NodeProbe
 
GetLoggingLevels - Class in org.apache.cassandra.tools.nodetool
 
GetLoggingLevels() - Constructor for class org.apache.cassandra.tools.nodetool.GetLoggingLevels
 
getLogin() - Method in class org.apache.cassandra.auth.RoleOptions
Return a boolean value of the login option
getLong(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getLong(long) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
getLong(long) - Method in class org.apache.cassandra.io.util.Memory
 
getLong(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getLongByByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getMap(String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
getMap(String, AbstractType<K>, AbstractType<V>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getMapKey() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
getMappings() - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
getMappings() - Method in interface org.apache.cassandra.cql3.selection.SelectionColumns
 
getMax() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
getMax() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
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, boolean) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
 
getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
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
getMaximumThreads() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
getMaximumThreads() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
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
getMaxIndexInterval() - Method in class org.apache.cassandra.config.CFMetaData
 
getMaxIndexSummarySize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Returns the approximate number of entries the IndexSummary would contain if it were at full sampling.
getMaxLiveCount() - Method in class org.apache.cassandra.service.RowDataResolver
 
getMaxNumberOfEntries() - Method in class org.apache.cassandra.io.sstable.IndexSummary
Returns the number of entries this summary would have if it were at the full sampling level, which is equal to the number of entries in the primary on-disk index divided by the min index interval.
getMaxSizeFile(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
 
getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
getMaxTimestamp() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getMBeanName() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Returns the MBean name for the Metric identified by this metric name.
getMean() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
getMean() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
getMeanColumns() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMeanRate() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
 
getMemoryPoolCapacityInMB() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
 
getMemoryPoolCapacityInMB() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
 
getMemoryPoolSizeInMB() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
Returns the actual space consumed by index summaries for all sstables.
getMemoryPoolSizeInMB() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
Returns the current actual off-heap memory usage of the index summaries for all non-compacting sstables.
getMemtableAllocatorPool() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getMemtableFlushPeriod() - Method in class org.apache.cassandra.config.CFMetaData
 
getMemtableFor(OpOrder.Group, ReplayPosition) - Method in class org.apache.cassandra.db.lifecycle.Tracker
get the Memtable that the ordered writeOp should be directed to
getMemtableReservedSize() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
If not affected by MeteredFlusher (and handling flushing on its own), override to tell MF how much space to reserve for this CF, i.e., how much space to subtract from `memtable_total_space_in_mb` when deciding if other memtables should be flushed or not.
getMergedRowCounts() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
getMessage() - Method in exception org.apache.cassandra.db.filter.TombstoneOverwhelmingException
 
getMessage() - Method in exception org.apache.cassandra.exceptions.RepairException
 
getMessage() - Method in interface org.apache.cassandra.exceptions.TransportException
The exception message.
getMessage() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
 
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.db.Keyspace
 
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
 
getMetadataSerializer() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
getMetricName() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
 
getMetrics() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
getMin() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
getMin() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
getMinCompactionThreshold() - Method in class org.apache.cassandra.config.CFMetaData
 
getMinimalKey(DecoratedKey) - Static method in class org.apache.cassandra.io.sstable.SSTable
If the given @param key occupies only part of a larger buffer, allocate a new buffer that is only as large as necessary.
getMinimumCompactionThreshold() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMinimumCompactionThreshold() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Gets the minimum number of sstables in queue before compaction kicks off
getMinimumToken() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
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
 
getMinIndexInterval() - Method in class org.apache.cassandra.config.CFMetaData
 
getMinIndexInterval() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getMinIndexInterval() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
getMinRepairedAt(Set<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
 
getMinRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getMinTimestamp() - Method in class org.apache.cassandra.db.Memtable
 
getMinTimestamp() - Method in class org.apache.cassandra.io.sstable.format.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
 
getMultiCellColumn(ColumnIdentifier) - Method in interface org.apache.cassandra.cql3.CQL3Row
 
getMutation() - Method in class org.apache.cassandra.db.CounterMutation
 
getName() - Method in class org.apache.cassandra.auth.AuthenticatedUser
 
getName() - Method in class org.apache.cassandra.auth.DataResource
 
getName() - Method in class org.apache.cassandra.auth.FunctionResource
 
getName() - Method in interface org.apache.cassandra.auth.IResource
 
getName() - Method in class org.apache.cassandra.auth.RoleResource
 
getName() - Method in class org.apache.cassandra.cql3.RoleName
 
getName() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getName() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getName() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
getName() - Method in class org.apache.cassandra.db.Keyspace
 
getName() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Returns the name of the Metric.
getName() - Method in enum org.apache.cassandra.repair.RepairParallelism
 
getNameAsString() - Method in class org.apache.cassandra.db.marshal.UserType
 
getNameForSystemKeyspace(ByteBuffer) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
 
getNameForSystemKeyspace(ByteBuffer) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
 
getNameForSystemKeyspace(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
Return the unique name for this index and column to be stored in the SystemKeyspace that tracks if each column is built
getNamesFilter(DecoratedKey, String, SortedSet<CellName>, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
 
getNativeProtocolVersion() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
Return native version protocol of the cluster connection
getNativeTransportMaxConcurrentConnections() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNativeTransportMaxConcurrentConnections() - Method in class org.apache.cassandra.service.StorageProxy
 
getNativeTransportMaxConcurrentConnections() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getNativeTransportMaxConcurrentConnectionsPerIp() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNativeTransportMaxConcurrentConnectionsPerIp() - Method in class org.apache.cassandra.service.StorageProxy
 
getNativeTransportMaxFrameSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNativeTransportMaxThreads() - 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
 
getNeighbors(String, Collection<Range<Token>>, Range<Token>, Collection<String>, Collection<String>) - Static method in class org.apache.cassandra.service.ActiveRepairService
Return all of the neighbors with whom we share the provided range.
getNetworkInterface(InetAddress) - Static method in class org.apache.cassandra.utils.FBUtilities
 
getNewEphemeralSnapshotMarkerFile(String) - Method in class org.apache.cassandra.db.Directories
 
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
Deprecated.
read next row
getNext() - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
get next row
getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
 
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
 
getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
getNextLevel(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
getNextVersion() - Static method in class org.apache.cassandra.gms.VersionGenerator
 
getNextWide() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
read wide row
getNonOverlappingBounds(Iterable<Bounds<T>>) - Static method in class org.apache.cassandra.dht.Bounds
Retrieves non-overlapping bounds for the list of input bounds Assume we have the following bounds (brackets representing left/right bound): [ ] [ ] [ ] [ ] [ ] [ ] This method will return the following bounds: [ ] [ ]
getNonSystemKeyspaces() - Method in class org.apache.cassandra.config.Schema
 
getNonSystemKeyspaces() - Method in class org.apache.cassandra.service.StorageService
 
getNonSystemKeyspaces() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getNonSystemKeyspaces() - Method in class org.apache.cassandra.tools.NodeProbe
 
getNormalAndBootstrappingTokenToEndpointMap() - Method in class org.apache.cassandra.locator.TokenMetadata
 
getNormalizedLoadAvg() - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
 
getNotificationInfo() - Method in class org.apache.cassandra.streaming.StreamManager
 
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
getOffHeapSize() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
getOnDiskDeserializer(DataInput, Version) - Method in class org.apache.cassandra.config.CFMetaData
 
getOnDiskFilePointer() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
getOnDiskFilePointer() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
getOnDiskFilePointer() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
getOnDiskFilePointer() - Method in class org.apache.cassandra.io.util.SequentialWriter
Returns the current file pointer of the underlying on-disk file.
getOnDiskIterator(FileDataInput, Version) - Method in class org.apache.cassandra.config.CFMetaData
 
getOnDiskIterator(FileDataInput, ColumnSerializer.Flag, int, Version) - Method in class org.apache.cassandra.config.CFMetaData
 
getOnDiskIterator(FileDataInput, ColumnSerializer.Flag, int, CFMetaData, Version) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
 
getOnDiskIterator(FileDataInput, ColumnSerializer.Flag, int, CFMetaData, Version) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
 
getOneMinuteRate() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
 
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.cql3.statements.ModificationStatement
 
getOperations() - Method in class org.apache.cassandra.db.Memtable
 
getOptions() - Method in class org.apache.cassandra.auth.RoleOptions
Return a map of all the options which have been set
getOptions() - Method in class org.apache.cassandra.cql3.statements.IndexPropDefs
 
getOrCreateNextSession(InetAddress, InetAddress) - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
getOrCreateSessionById(InetAddress, int, InetAddress) - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
getOrderingIndex(boolean) - Method in class org.apache.cassandra.cql3.selection.Selection
 
getOriginalIndexes(int) - Static method in class org.apache.cassandra.io.sstable.Downsampling
Returns a list that can be used to translate current index summary indexes to their original index before downsampling.
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.
getOtcCoalescingEnoughCoalescedMessages() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getOtcCoalescingStrategy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getOtcCoalescingWindow() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getOutboundBindAny() - Static method in class org.apache.cassandra.config.Config
 
getOutboundBindAny() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getOutput(int) - Method in class org.apache.cassandra.cql3.selection.Selector
Returns the selector output.
getOutput(int) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
 
getOutputCluster(String, Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getOutputCluster(String[], Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getOutputColumnFamily(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
Deprecated.
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Deprecated.
The OutputCommitter for this format does not write any data to the DFS.
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
The OutputCommitter for this format does not write any data to the DFS.
getOutputCompressionChunkLength(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputCompressionClass(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputCompressionParamaters(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputCql(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getOutputFormat() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
output format
getOutputFormat() - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
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
 
getOutputLocalDCOnly(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputLocation() - Method in class org.apache.cassandra.hadoop.BulkRecordWriter
Deprecated.
 
getOutputLocation() - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
getOutputNativePort(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getOutputPartitioner(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputRpcPort(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputStream(File, File) - Method in interface org.apache.cassandra.cache.AutoSavingCache.IStreamFactory
 
getOverlappingSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getOverloadCount(FunctionName) - Static method in class org.apache.cassandra.cql3.functions.Functions
 
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
 
getOwnershipByDc(NodeProbe, boolean, Map<String, String>, Map<InetAddress, Float>) - Static method in class org.apache.cassandra.tools.NodeTool
 
getPage(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
getPageableCommand(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
getPageCount() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
getPageSize() - Method in class org.apache.cassandra.cql3.QueryOptions
The pageSize for this query.
getPageSize() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
getPagingState() - Method in class org.apache.cassandra.cql3.QueryOptions
The paging state for this query, or null if not relevant.
getParallelism() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
getParent() - Method in class org.apache.cassandra.auth.DataResource
 
getParent() - Method in class org.apache.cassandra.auth.FunctionResource
 
getParent() - Method in interface org.apache.cassandra.auth.IResource
Gets next resource in the hierarchy.
getParent() - Method in class org.apache.cassandra.auth.RoleResource
 
getParentColumnFamilyName() - Method in class org.apache.cassandra.config.CFMetaData
 
getParentRepairSession(UUID) - Method in class org.apache.cassandra.service.ActiveRepairService
 
getPartitioner() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPartitioner() - Method in class org.apache.cassandra.db.DecoratedKey
 
getPartitioner() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
getPartitioner() - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
 
getPartitioner() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
getPartitioner() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner.StringToken
 
getPartitioner() - Method in class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
 
getPartitioner() - Method in interface org.apache.cassandra.dht.RingPosition
 
getPartitioner() - Method in class org.apache.cassandra.dht.Token
 
getPartitioner() - Method in class org.apache.cassandra.dht.Token.KeyBound
 
getPartitioner() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
 
getPartitioner() - Static method in class org.apache.cassandra.service.StorageService
 
getPartitioner() - Method in class org.apache.cassandra.tools.NodeProbe
 
getPartitionerName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPartitionerName() - Method in class org.apache.cassandra.service.StorageService
Returns the cluster partitioner
getPartitionerName() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the cluster partitioner
getPartitionKeyBindIndexes(CFMetaData) - Method in class org.apache.cassandra.cql3.VariableSpecifications
Returns an array with the same length as the number of partition key columns for the table corresponding to cfm.
getPartitionKeyBounds(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Returns the partition key bounds.
getPartitionKeys(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Returns the partition keys for which the data is requested.
getPartitionKeys(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
return partition keys
getPartitionKeys(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
return partition keys
getPartitionSample(String, String, int, int, int, List<ColumnFamilyMetrics.Sampler>) - Method in class org.apache.cassandra.tools.NodeProbe
 
getPassword() - Method in class org.apache.cassandra.auth.RoleOptions
Return the string value of the password option
getPath() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getPath() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
getPath() - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
 
getPath() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
getPath() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
getPath() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
getPeers() - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
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
 
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
 
getPendingRangesMM(String) - 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 class org.apache.cassandra.concurrent.SEPExecutor
 
getPendingTasks() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
 
getPendingTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getPermissions(IResource) - Method in class org.apache.cassandra.auth.AuthenticatedUser
 
getPermissions(AuthenticatedUser, IResource) - Method in class org.apache.cassandra.auth.PermissionsCache
 
getPermissionsCacheMaxEntries() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPermissionsUpdateInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPermissionsValidity() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPermittedToCompact() - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
getPermittedToCompactSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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
 
getPhiValues() - Method in class org.apache.cassandra.gms.FailureDetector
 
getPhiValues() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
getPid() - Method in class org.apache.cassandra.utils.SigarLibrary
 
getPigType(AbstractType) - Static method in class org.apache.cassandra.hadoop.pig.StorageHelper
Deprecated.
get pig type for the cassandra data type
getPos() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
Deprecated.
 
getPos() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
getPosition(RowPosition, SSTableReader.Operator, boolean, boolean) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
 
getPosition(RowPosition, SSTableReader.Operator) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Get position updating key cache and stats.
getPosition(RowPosition, SSTableReader.Operator, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getPosition(RowPosition, SSTableReader.Operator, boolean, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getPosition(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
getPosition() - Method in class org.apache.cassandra.io.util.AbstractDataInput
 
getPosition() - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
 
getPosition() - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
getPosition() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
getPosition() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
 
getPositionInSummary(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
Gets the position of the actual index summary entry in our Memory attribute, 'bytes'.
getPositionLimit() - Method in class org.apache.cassandra.io.util.AbstractDataInput
 
getPositionLimit() - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
 
getPositionLimit() - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
getPositionLimit() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
getPositionLimit() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
 
getPositionsForRanges(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Determine the minimal set of sections that can be extracted from this SSTable to cover the given ranges.
getPredecessor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getPreferredIP(InetAddress) - Static method in class org.apache.cassandra.db.SystemKeyspace
Get preferred IP for given endpoint if it is known.
getPrefetchedList(ByteBuffer, ColumnIdentifier, ColumnFamily) - Method in class org.apache.cassandra.cql3.UpdateParameters
Returns the prefetched list with the already performed modifications.
getPrepared(MD5Digest) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
 
getPrepared(MD5Digest) - Method in interface org.apache.cassandra.cql3.QueryHandler
 
getPrepared(MD5Digest) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
getPreparedForThrift(Integer) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
 
getPreparedForThrift(Integer) - Method in interface org.apache.cassandra.cql3.QueryHandler
 
getPreparedForThrift(Integer) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
getPrimaryKeyValueForColumn(ColumnDefinition) - Method in class org.apache.cassandra.cql3.Json.Prepared
 
getPrimaryRangeFor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
Deprecated.
getPrimaryRangeForEndpointWithinDC(String, InetAddress) - Method in class org.apache.cassandra.service.StorageService
Get the "primary ranges" within local DC for the specified keyspace and endpoint.
getPrimaryRanges(String) - Method in class org.apache.cassandra.service.StorageService
 
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.
getPrimaryRangesWithinDC(String) - Method in class org.apache.cassandra.service.StorageService
 
getPrimaryRole() - Method in class org.apache.cassandra.auth.AuthenticatedUser
 
getPriority() - Method in class org.apache.cassandra.streaming.messages.StreamMessage
 
getProcessor(CassandraServer) - Method in class org.apache.cassandra.thrift.ThriftServer
 
getProgress() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
Deprecated.
 
getProgress() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
getProgress() - Method in class org.apache.cassandra.hadoop.ReporterWrapper
 
getProgressCount() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
 
getProgressPercentage() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
 
getProtectedConstructor(Class<T>, 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
getProtocolVersion() - Method in class org.apache.cassandra.cql3.QueryOptions
The protocol version for the query.
getProtocolVersion() - Method in enum org.apache.cassandra.transport.DataType
 
getProxyMetric(String) - Method in class org.apache.cassandra.tools.NodeProbe
Retrieve Proxy metrics
getPurgeEvaluator(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.CompactionController
 
getPurgeEvaluator(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplitController
 
getQueryMap(String) - Static method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
decompose the query to store the parameters in a map
getQueryMap(String) - Static method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
decompose the query to store the parameters in a map
getQueryOrIdList() - Method in class org.apache.cassandra.cql3.BatchQueryOptions
 
getQueryState() - Method in class org.apache.cassandra.thrift.ThriftClientState
 
getRack() - Static method in class org.apache.cassandra.db.SystemKeyspace
Gets the stored rack for the local node, or null if none have been set yet.
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.CloudstackSnitch
 
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() - 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() - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
Provides the Rack name depending on the respective snitch used for this node
getRack(InetAddress) - Method in class org.apache.cassandra.locator.GoogleCloudSnitch
 
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
 
getRandomInt(int) - Method in class org.apache.cassandra.db.BatchlogManager.EndpointFilter
 
getRandomTimeUUIDFromMicros(long) - Static method in class org.apache.cassandra.utils.UUIDGen
Similar to getTimeUUIDFromMicros, but randomize (using SecureRandom) the clock and sequence.
getRandomToken() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
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
 
getRange() - Method in class org.apache.cassandra.repair.RepairSession
 
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.
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
 
getRanges() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
getRangeSlice(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRangeSlice(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int, long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRangeSlice(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int, long, boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRangeSlice(ExtendedFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRangeSlice(AbstractRangeCommand, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
 
getRangeToAddressMap(String) - Method in class org.apache.cassandra.service.StorageService
 
getRangeToAddressMapInLocalDC(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.
getRangeTombstoneIterator(ColumnFamily) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
 
getRangeTombstoneIterator(ColumnFamily) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getRangeTombstoneIterator(ColumnFamily) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
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.
getRateLimiter(InetAddress) - Static method in class org.apache.cassandra.streaming.StreamManager
Gets streaming rate limiter.
getRateUnit() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
 
getRawCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRawKeyspace() - Method in class org.apache.cassandra.service.ClientState
 
getRawOptions() - Method in class org.apache.cassandra.cql3.statements.IndexPropDefs
 
getRawTermForColumn(ColumnDefinition) - Method in class org.apache.cassandra.cql3.Json.Prepared
 
getRawText() - Method in class org.apache.cassandra.cql3.Constants.Literal
 
getRawVersion(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
getReadConsistencyLevel(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getReaderFactory() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
 
getReaderFactory() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
 
getReadExecutor(ReadCommand, ConsistencyLevel) - Static method in class org.apache.cassandra.service.AbstractReadExecutor
 
getReadMeter() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
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
 
getReceivingFiles() - Method in class org.apache.cassandra.streaming.SessionInfo
 
getReceivingStream(UUID) - Method in class org.apache.cassandra.streaming.StreamManager
 
getRecentBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getRecentBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getRecentFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getRecentTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
Deprecated.
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.cassandra.hadoop.cql3.CqlInputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
Deprecated.
getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat
Deprecated.
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Deprecated.
getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Deprecated.
Get the RecordWriter for the given task.
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
Deprecated.
getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
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.
getReduced() - Method in class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
 
getReduced() - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow.Reducer
Called after reduce() has been called for each cell sharing the same name.
getReduced() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
 
getReferencesTo(Function) - Static method in class org.apache.cassandra.cql3.functions.Functions
 
getRegisteredCallback(int) - Method in class org.apache.cassandra.net.MessagingService
 
getRegisteredCallbackAge(int) - Method in class org.apache.cassandra.net.MessagingService
 
getReleaseVersion(InetAddress) - Static method in class org.apache.cassandra.db.SystemKeyspace
Get release version for given endpoint.
getReleaseVersion() - Method in class org.apache.cassandra.service.StorageService
 
getReleaseVersion() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Fetch a string representation of the Cassandra version.
getReleaseVersion() - Method in class org.apache.cassandra.tools.NodeProbe
 
getReleaseVersionString() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getRemainingPart() - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
 
getRemoteAddress() - Method in class org.apache.cassandra.service.ClientState
 
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
 
getRepairedAt() - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
getRepairedSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getReplaceAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getReplacementNode(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getReplaceNode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getReplaceTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getReplacingNode(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
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.statements.KSPropDefs
 
getReplicationStrategy() - Method in class org.apache.cassandra.db.Keyspace
 
getReplicationStrategyClass() - Method in class org.apache.cassandra.cql3.statements.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
 
getResizeIntervalInMinutes() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
 
getResizeIntervalInMinutes() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
 
getResponse(ReadCommand, Row) - Static method in class org.apache.cassandra.db.ReadVerbHandler
 
getResponseCount() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
 
getRestoreCommand() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getRestoreCommand() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
Command to execute to make an archived commitlog live again
getRestoreDirectories() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getRestoreDirectories() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
Directory to scan the recovery files in
getRestorePointInTime() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getRestorePointInTime() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
Restore mutations created up to and including this timestamp in GMT Format: yyyy:MM:dd HH:mm:ss (2012:04:31 20:43:12) Recovery will continue through the segment when the first client-supplied timestamp greater than this time is encountered, but only mutations less than or equal to this timestamp will be applied.
getRestorePrecision() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getRestorePrecision() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
get precision of the timestamp used in the restore (MILLISECONDS, MICROSECONDS, ...) to determine if passed the restore point in time.
getRestrictions() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
May be used by custom QueryHandler implementations
getResultMetadata(boolean) - Method in class org.apache.cassandra.cql3.selection.Selection
 
getResultMetadata() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
getResultSetIndex(ColumnDefinition) - Method in class org.apache.cassandra.cql3.selection.Selection
Returns the index of the specified column within the resultset
getReturnType() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Returns the type of the values returned by the selector instances created by this factory.
getReverseSortedColumns() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
getReverseSortedColumns() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
getReverseSortedColumns() - Method in class org.apache.cassandra.db.ColumnFamily
Returns the columns of this column map as a collection.
getRingVersion() - Method in class org.apache.cassandra.locator.TokenMetadata
 
getRoleManager() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRoleName() - Method in class org.apache.cassandra.auth.RoleResource
 
getRoles() - Method in class org.apache.cassandra.auth.AuthenticatedUser
Get the roles that have been granted to the user via the IRoleManager
getRoles(RoleResource, boolean) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
getRoles(RoleResource, boolean) - Method in interface org.apache.cassandra.auth.IRoleManager
Called during execution of a LIST ROLES query.
getRoles(RoleResource) - Static method in class org.apache.cassandra.auth.Roles
Get all roles granted to the supplied Role, including both directly granted and inherited roles.
getRoles(RoleResource) - Method in class org.apache.cassandra.auth.RolesCache
 
getRolesCacheMaxEntries() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRolesUpdateInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRolesValidity() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRow(QueryFilter) - Method in class org.apache.cassandra.db.Keyspace
 
getRow(Keyspace) - Method in class org.apache.cassandra.db.ReadCommand
 
getRow(Keyspace) - Method in class org.apache.cassandra.db.SliceByNamesReadCommand
 
getRow(Keyspace) - Method in class org.apache.cassandra.db.SliceFromReadCommand
 
getRowCacheClassName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRowCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRowCacheKeysToSave() - Method in class org.apache.cassandra.service.CacheService
 
getRowCacheKeysToSave() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getRowCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRowCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
 
getRowCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
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
 
getRpcListenBacklog() - 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
 
getSamplingLevel() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
getSamplingPattern(int) - Static method in class org.apache.cassandra.io.sstable.Downsampling
Gets a list L of starting indices for downsampling rounds: the first round should start with the offset given by L[0], the second by the offset in L[1], etc.
getSaslNegotiator() - Method in class org.apache.cassandra.transport.ServerConnection
 
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.SystemKeyspace
 
getScanner(DataRange, RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
 
getScanner(Collection<Range<Token>>, RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
Direct I/O SSTableScanner over a defined collection of ranges of tokens.
getScanner(SSTableReader, DataRange, RateLimiter) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
getScanner(SSTableReader, Collection<Range<Token>>, RateLimiter) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
getScanner() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
I/O SSTableScanner
getScanner(RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getScanner(DataRange) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getScanner(Range<Token>, RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Direct I/O SSTableScanner over a defined range of tokens.
getScanner(Collection<Range<Token>>, RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Direct I/O SSTableScanner over a defined collection of ranges of tokens.
getScanner(DataRange, RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.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
 
getScanners(Collection<SSTableReader>, Range<Token>) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
getSchedulingValue() - Method in class org.apache.cassandra.thrift.ThriftClientState
 
getSchema(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
define the schema
getSchema(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
schema: (value, value, value) where keys are in the front.
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
 
getSchemaVersions() - Method in class org.apache.cassandra.service.StorageProxy
 
getSchemaVersions() - Method in interface org.apache.cassandra.service.StorageProxyMBean
Returns each live node's schema version
getScope() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Returns the scope of the Metric.
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.MmappedSegmentedFile
 
getSegment(long) - Method in class org.apache.cassandra.io.util.PoolingSegmentedFile
 
getSegment(long) - Method in class org.apache.cassandra.io.util.SegmentedFile
 
getSelection() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
May be used by custom QueryHandler implementations
getSendingFiles() - Method in class org.apache.cassandra.streaming.SessionInfo
 
getSerialConsistency() - Method in class org.apache.cassandra.cql3.BatchQueryOptions
 
getSerialConsistency() - Method in class org.apache.cassandra.cql3.QueryOptions
Serial consistency for conditional updates.
getSerializedCachePath(CacheService.CacheType, String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSerializedValue(ByteBuffer, ByteBuffer, AbstractType) - Method in class org.apache.cassandra.serializers.MapSerializer
Given a serialized map, gets the value associated with a given key.
getSerializer() - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.AsciiType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.BooleanType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.BytesType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.ByteType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.CollectionType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.DateType
Deprecated.
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.DecimalType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.DoubleType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.EmptyType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.FloatType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.FrozenType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.InetAddressType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.Int32Type
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.IntegerType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.ListType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.LongType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.MapType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.ReversedType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.SetType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.ShortType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.TimestampType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.TimeType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.TupleType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.UserType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.UUIDType
 
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.tracing.Tracing
 
getSessionInfo() - Method in class org.apache.cassandra.streaming.StreamSession
 
getSet(String, AbstractType<T>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getSetOperationForColumn(ColumnDefinition) - Method in class org.apache.cassandra.cql3.Json.Prepared
 
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
 
getSeverity(InetAddress) - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
 
getShort(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getShort(long) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
getShort(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getShortByByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getShortLength(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
getSimple(String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
getSimpleStates() - Method in class org.apache.cassandra.gms.FailureDetector
 
getSimpleStates() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
getSliceFilter(DecoratedKey, String, Composite, Composite, boolean, int, long) - Static method in class org.apache.cassandra.db.filter.QueryFilter
 
getSmallMessageCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getSmallMessageCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Completed tasks for small message TCP Connections
getSmallMessageDroppedTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getSmallMessageDroppedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Dropped tasks for small message TCP Connections
getSmallMessagePendingTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getSmallMessagePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Pending tasks for small message TCP Connections
getSnapshot() - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
Returns a snapshot of the decaying values in this reservoir.
getSnapshotCreationTime(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getSnapshotDetails() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getSnapshotDetails() - Method in class org.apache.cassandra.db.Directories
 
getSnapshotDetails() - Method in class org.apache.cassandra.service.StorageService
 
getSnapshotDetails() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Get the details of all the snapshot
getSnapshotDetails() - Method in class org.apache.cassandra.tools.NodeProbe
 
getSnapshotDirectory(Descriptor, String) - Static method in class org.apache.cassandra.db.Directories
 
getSnapshotDirectory(File, String) - Static method in class org.apache.cassandra.db.Directories
Returns directory to write snapshot.
getSnapshotManifestFile(String) - Method in class org.apache.cassandra.db.Directories
 
getSnapshotSSTableReader(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getSnitchName() - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
 
getSnitchName() - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
Provides the snitch name of the cluster
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.
getSocketThreads() - Method in class org.apache.cassandra.net.MessagingService
 
getSortedColumns() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
getSortedColumns() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
getSortedColumns() - Method in class org.apache.cassandra.db.ColumnFamily
Returns the columns of this column map as a collection.
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
getSourceFrame() - Method in class org.apache.cassandra.transport.Message
 
getSpecifications() - Method in class org.apache.cassandra.cql3.VariableSpecifications
 
getSpeculativeRetry() - Method in class org.apache.cassandra.config.CFMetaData
 
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
 
getSplitValues() - Method in class org.apache.cassandra.cql3.Tuples.InValue
 
getSpProxy() - Method in class org.apache.cassandra.tools.NodeProbe
 
getSSLOptions(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getSSLStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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, 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
 
getSSTableCountPerLevel() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
getSSTableFormat() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSSTableFormat() - Method in class org.apache.cassandra.io.sstable.format.Version
 
getSSTableLevel() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getSSTableMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getSSTablePreempiveOpenIntervalInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSSTableReadMeter(String, String, int) - Static method in class org.apache.cassandra.db.SystemKeyspace
Returns a RestorableMeter tracking the average read rate of a particular SSTable, restoring the last-seen rate from values in system.sstable_activity if present.
getSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getSSTables() - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
getSSTables(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
GetSSTables - Class in org.apache.cassandra.tools.nodetool
 
GetSSTables() - Constructor for class org.apache.cassandra.tools.nodetool.GetSSTables
 
getSSTableSectionsForRanges(Collection<Range<Token>>, Collection<ColumnFamilyStore>, long, boolean) - Static method in class org.apache.cassandra.streaming.StreamSession
 
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
 
getSStablesPerLevelSnapshot() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
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
 
getStartPoints(int, int) - Static method in class org.apache.cassandra.io.sstable.Downsampling
 
getStartToken() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
getStatement(String, ClientState) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
getStatement(Logger, String, long, TimeUnit) - Static method in class org.apache.cassandra.utils.NoSpamLogger
 
getStatement(String) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
getStatement(String, long, TimeUnit) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
getStatement(String, long) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
getStatements() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
getStaticRow() - Method in interface org.apache.cassandra.cql3.CQL3Row.RowIterator
 
getStatistics(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
getStatistics(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
getStatus() - Method in class org.apache.cassandra.gms.EndpointState
 
getStatus(ProgressEvent) - Static method in class org.apache.cassandra.utils.progress.jmx.LegacyJMXProgressSupport
 
getStdDev() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
getStdDev() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
getStorageMetric(String) - Method in class org.apache.cassandra.tools.NodeProbe
Retrieve Proxy metrics
getStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getStreamId() - Method in class org.apache.cassandra.transport.Message
 
getStreamId() - Method in exception org.apache.cassandra.transport.messages.ErrorMessage.WrappedException
 
getStreamingSocketTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getStreamStatus() - Method in class org.apache.cassandra.tools.NodeProbe
 
getStreamThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
 
GetStreamThroughput - Class in org.apache.cassandra.tools.nodetool
 
GetStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.GetStreamThroughput
 
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(String, String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
getString(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getString(CellNameType) - Method in class org.apache.cassandra.db.AbstractCell
 
getString(CellNameType) - Method in class org.apache.cassandra.db.BufferCounterCell
 
getString(CellNameType) - Method in class org.apache.cassandra.db.BufferCounterUpdateCell
 
getString(CellNameType) - Method in class org.apache.cassandra.db.BufferExpiringCell
 
getString(CellNameType) - Method in interface org.apache.cassandra.db.Cell
 
getString(Composite) - Method in class org.apache.cassandra.db.composites.AbstractCType
 
getString(Composite) - Method in interface org.apache.cassandra.db.composites.CType
Converts a composite to a user-readable string.
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.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.EmptyType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FrozenType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TupleType
 
getString(CellNameType) - Method in class org.apache.cassandra.db.NativeCounterCell
 
getString(CellNameType) - Method in class org.apache.cassandra.db.NativeExpiringCell
 
getString(AbstractType<?>) - Method in class org.apache.cassandra.dht.AbstractBounds
 
getStringTypeName() - Method in class org.apache.cassandra.cql3.UTName
 
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
 
getSummary() - Method in class org.apache.cassandra.streaming.StreamTask
 
getSuperuser() - Method in class org.apache.cassandra.auth.RoleOptions
Return a boolean value of the superuser option
getSyncPoint() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
returns the Group we are waiting on - any Group with .compareTo(getSyncPoint()) <= 0 must complete before await() returns
getTable() - Method in class org.apache.cassandra.auth.DataResource
 
getTableForAlias(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
getTableInsertStatement(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
getTableMetadata(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.
getTableMetadata(String) - Method in class org.apache.cassandra.utils.NativeSSTableLoaderClient
 
getTableSchema(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
getTargetVersion() - Method in class org.apache.cassandra.net.OutboundTcpConnection
 
getTaskAttemptID(TaskAttemptContext) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
returns TaskAttemptContext.getTaskAttemptID().
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
 
getTempSSTablePath(File, SSTableFormat.Type) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getThreadLocalScratchBuffer() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getThreadPoolMetric(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getThreadPools() - Method in class org.apache.cassandra.tools.NodeProbe
Retrieve threadpool paths and names for threadpools with metrics.
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.AbstractRangeCommand
 
getTimeout() - Method in class org.apache.cassandra.db.CounterMutation
 
getTimeout() - Method in interface org.apache.cassandra.db.IMutation
 
getTimeout() - Method in class org.apache.cassandra.db.Mutation
 
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
getTimestamp(long, QueryOptions) - Method in class org.apache.cassandra.cql3.Attributes
 
getTimestamp(QueryState) - Method in class org.apache.cassandra.cql3.BatchQueryOptions
 
getTimestamp(QueryState) - Method in class org.apache.cassandra.cql3.QueryOptions
 
getTimestamp(long, QueryOptions) - 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.ClientState
This clock guarantees that updates for the same ClientState will be ordered in the sequence seen, even if multiple updates happen in the same millisecond.
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.Keyspace
 
getTimestampForPaxos(long) - Method in class org.apache.cassandra.service.ClientState
Returns a timestamp suitable for paxos given the timestamp of the last known commit (or in progress update).
getTimeToLive(QueryOptions, CFMetaData) - Method in class org.apache.cassandra.cql3.Attributes
 
getTimeToLive(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
getTimeToLive() - Method in class org.apache.cassandra.db.BufferExpiringCell
 
getTimeToLive() - Method in interface org.apache.cassandra.db.ExpiringCell
 
getTimeToLive() - Method in class org.apache.cassandra.db.NativeExpiringCell
 
getTimeUUID() - Static method in class org.apache.cassandra.utils.UUIDGen
Creates a type 1 UUID (time-based UUID).
getTimeUUID(long) - Static method in class org.apache.cassandra.utils.UUIDGen
Creates a type 1 UUID (time-based UUID) with the timestamp of @param when, in milliseconds.
getTimeUUID(long, long) - Static method in class org.apache.cassandra.utils.UUIDGen
 
getTimeUUID(long, long, long) - Static method in class org.apache.cassandra.utils.UUIDGen
 
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, 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).
getTimeUUIDFromMicros(long) - Static method in class org.apache.cassandra.utils.UUIDGen
Returns a version 1 UUID using the provided timestamp and the local clock and sequence.
getToken() - Method in class org.apache.cassandra.db.DecoratedKey
 
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.
getToken() - Method in class org.apache.cassandra.transport.messages.AuthChallenge
 
getToken() - Method in class org.apache.cassandra.transport.messages.AuthSuccess
 
getTokenFactory() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
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.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.ByteOrderedPartitioner
 
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
 
getTokenValue() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
getTokenValue() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
getTokenValue() - Method in class org.apache.cassandra.dht.Token
 
getTombstoneFailureThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTombstoneFailureThreshold() - Method in class org.apache.cassandra.service.StorageService
 
getTombstoneFailureThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the threshold for abandoning queries with many tombstones
getTombstoneWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTombstoneWarnThreshold() - Method in class org.apache.cassandra.service.StorageService
 
getTombstoneWarnThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the threshold for warning of queries with many tombstones
getToolsOutputDirectory() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getTopLevelColumns(boolean) - Method in class org.apache.cassandra.db.CollationController
 
getTopLevelColumns(QueryFilter, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTopLevelDeletion() - Method in class org.apache.cassandra.db.DeletionInfo
Returns the top-level (or "row") tombstone.
getTopology() - Method in class org.apache.cassandra.locator.TokenMetadata
 
getTotal() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getTotal() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
 
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
 
getTotalBufferSize() - Method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
 
getTotalBufferSize() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
getTotalBytes(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getTotalBytes() - Method in class org.apache.cassandra.io.sstable.KeyIterator
 
getTotalBytes() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
getTotalBytesCompacted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getTotalCommitlogSpaceInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTotalCompactionsCompleted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getTotalCompressedBytesRead() - Method in class org.apache.cassandra.streaming.compress.CompressedInputStream
 
getTotalFilesReceived() - Method in class org.apache.cassandra.streaming.SessionInfo
 
getTotalFilesSent() - Method in class org.apache.cassandra.streaming.SessionInfo
 
getTotalFilesToReceive() - Method in class org.apache.cassandra.streaming.SessionInfo
 
getTotalFilesToSend() - Method in class org.apache.cassandra.streaming.SessionInfo
 
getTotalHints() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalHints() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamReceiveTask
 
getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamTask
 
getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamTransferTask
 
getTotalSinceLastCheck() - Method in class org.apache.cassandra.service.GCInspector
 
getTotalSize() - Method in class org.apache.cassandra.streaming.StreamReceiveTask
 
getTotalSize() - Method in class org.apache.cassandra.streaming.StreamTask
 
getTotalSize() - Method in class org.apache.cassandra.streaming.StreamTransferTask
 
getTotalSizeForSections(Collection<Pair<Long, Long>>) - Method in class org.apache.cassandra.io.compress.CompressionMetadata
 
getTotalSizeReceived() - Method in class org.apache.cassandra.streaming.SessionInfo
 
getTotalSizeSent() - Method in class org.apache.cassandra.streaming.SessionInfo
 
getTotalSizeToReceive() - Method in class org.apache.cassandra.streaming.SessionInfo
 
getTotalSizeToSend() - Method in class org.apache.cassandra.streaming.SessionInfo
 
getTotalSpace(File) - Static method in class org.apache.cassandra.io.util.FileUtils
Returns the size of the specified partition.
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
getTotalUncompressedBytes(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getTraceProbability() - Method in class org.apache.cassandra.service.StorageService
 
getTraceProbability() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the configured tracing probability.
getTraceProbability() - Method in class org.apache.cassandra.tools.NodeProbe
 
GetTraceProbability - Class in org.apache.cassandra.tools.nodetool
 
GetTraceProbability() - Constructor for class org.apache.cassandra.tools.nodetool.GetTraceProbability
 
getTraceType() - Method in class org.apache.cassandra.tracing.Tracing
 
getTracetypeQueryTTL() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTracetypeRepairTTL() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTracingId() - Method in class org.apache.cassandra.transport.Message.Response
 
getTracker() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Package protected for access from the CompactionManager.
getTracker() - Method in class org.apache.cassandra.transport.Connection
 
getTransport() - Method in class org.apache.cassandra.thrift.CustomTNonBlockingServer.CustomFrameBuffer
 
getTransportFactory() - Method in class org.apache.cassandra.thrift.ThriftServer
 
getTrickleFsync() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTrickleFsyncIntervalInKb() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTriggers() - Method in class org.apache.cassandra.config.CFMetaData
 
getTrueAllocatedSizeIn(File) - Method in class org.apache.cassandra.db.Directories
 
getTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getTruncatedAt(UUID) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
getTruncatedPosition(UUID) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
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
 
getTTL() - Method in class org.apache.cassandra.tracing.Tracing
 
getTTL() - Method in enum org.apache.cassandra.tracing.Tracing.TraceType
 
getType(ByteBuffer) - Method in class org.apache.cassandra.config.UTMetaData
 
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.cql3.CQL3Type.Tuple
 
getType() - Method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
 
getType() - Method in class org.apache.cassandra.cql3.selection.Selector
Returns the Selector output type.
getType() - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
 
getType() - Method in class org.apache.cassandra.db.ColumnFamily
 
getType() - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
 
getType() - Method in class org.apache.cassandra.io.sstable.metadata.MetadataComponent
 
getType() - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
getType() - Method in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
 
getType() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Returns the type to which the Metric belongs.
getType() - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
 
getType() - Method in class org.apache.cassandra.serializers.BooleanSerializer
 
getType() - Method in class org.apache.cassandra.serializers.ByteSerializer
 
getType() - Method in class org.apache.cassandra.serializers.BytesSerializer
 
getType() - Method in class org.apache.cassandra.serializers.DecimalSerializer
 
getType() - Method in class org.apache.cassandra.serializers.DoubleSerializer
 
getType() - Method in class org.apache.cassandra.serializers.EmptySerializer
 
getType() - Method in class org.apache.cassandra.serializers.FloatSerializer
 
getType() - Method in class org.apache.cassandra.serializers.InetAddressSerializer
 
getType() - Method in class org.apache.cassandra.serializers.Int32Serializer
 
getType() - Method in class org.apache.cassandra.serializers.IntegerSerializer
 
getType() - Method in class org.apache.cassandra.serializers.ListSerializer
 
getType() - Method in class org.apache.cassandra.serializers.LongSerializer
 
getType() - Method in class org.apache.cassandra.serializers.MapSerializer
 
getType() - Method in class org.apache.cassandra.serializers.SetSerializer
 
getType() - Method in class org.apache.cassandra.serializers.ShortSerializer
 
getType() - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
 
getType() - Method in class org.apache.cassandra.serializers.TimeSerializer
 
getType() - Method in class org.apache.cassandra.serializers.TimestampSerializer
 
getType() - Method in interface org.apache.cassandra.serializers.TypeSerializer
 
getType() - Method in class org.apache.cassandra.serializers.UUIDSerializer
 
getType() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
 
getTypeParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
 
getUncompacting() - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
getUncompacting(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
getUncompacting(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.View
 
getUncompactingSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getUnfinishedCompactions() - Static method in class org.apache.cassandra.db.SystemKeyspace
Returns a Map whose keys are KS.CF pairs and whose values are maps from sstable generation numbers to the task ID of the compaction they were participating in.
getUnleveledSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getUnleveledSSTables() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getUnleveledSSTables() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
getUnloggedBatchAcrossPartitionsWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
 
getUnreachableTokenOwners() - Method in class org.apache.cassandra.gms.Gossiper
 
getUnreadableDirectories() - Method in class org.apache.cassandra.db.BlacklistedDirectories
 
getUnreadableDirectories() - Method in interface org.apache.cassandra.db.BlacklistedDirectoriesMBean
 
getUnrepairedSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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.auth.PermissionsCache
 
getUpdateInterval() - Method in interface org.apache.cassandra.auth.PermissionsCacheMBean
 
getUpdateInterval() - Method in class org.apache.cassandra.auth.RolesCache
 
getUpdateInterval() - Method in interface org.apache.cassandra.auth.RolesCacheMBean
 
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
 
getUpEndpointCount() - Method in class org.apache.cassandra.gms.FailureDetector
 
getUpEndpointCount() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
getUptime() - Method in class org.apache.cassandra.tools.NodeProbe
 
getUsableSpace(File) - Static method in class org.apache.cassandra.io.util.FileUtils
Returns the number of available bytes on the specified partition.
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.DateTieredCompactionStrategy
 
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
 
getUserDefinedTask(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
getUserKeyspaces() - Method in class org.apache.cassandra.config.Schema
 
getUserTypeName() - Method in class org.apache.cassandra.cql3.UTName
 
getUserTypeParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
 
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.
getValidatedIndexExpressions(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
May be used by custom QueryHandler implementations
getValidatorMap(CfDef) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
get the validators
getValidatorMap(TableInfo) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
get the validators
getValidColumnFamilies(boolean, boolean, String...) - Method in class org.apache.cassandra.db.Keyspace
 
getValidColumnFamilies(boolean, boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
getValidity() - Method in class org.apache.cassandra.auth.PermissionsCache
 
getValidity() - Method in interface org.apache.cassandra.auth.PermissionsCacheMBean
 
getValidity() - Method in class org.apache.cassandra.auth.RolesCache
 
getValidity() - Method in interface org.apache.cassandra.auth.RolesCacheMBean
 
getValue() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxGaugeMBean
 
getValue() - Method in class org.apache.cassandra.utils.PureJavaCrc32
 
getValues() - Method in class org.apache.cassandra.cql3.QueryOptions
 
getValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IN
 
getValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InWithMarker
 
getValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InWithValues
 
getValuesType() - Method in class org.apache.cassandra.db.marshal.MapType
 
getValueValidator(CellName) - Method in class org.apache.cassandra.config.CFMetaData
 
getVariablesForStatement(int) - Method in interface org.apache.cassandra.cql3.statements.BatchStatement.BatchVariables
 
getVerbHandler(MessagingService.Verb) - Method in class org.apache.cassandra.net.MessagingService
This method returns the verb handler associated with the registered verb.
getVerifyInfo() - Method in class org.apache.cassandra.db.compaction.Verifier
 
getVersion() - Method in class org.apache.cassandra.config.Schema
 
getVersion(String) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
 
getVersion(String) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
 
getVersion() - Method in class org.apache.cassandra.io.sstable.format.Version
 
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
 
getVersion() - Method in class org.apache.cassandra.transport.Connection
 
getView() - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
getWaiting() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
Return how many threads are waiting
getWarnings() - Method in class org.apache.cassandra.service.ClientWarn
 
getWarnings() - Method in class org.apache.cassandra.transport.Message.Response
 
getWindowsTimerInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getWorkMap(Multimap<Range<Token>, InetAddress>, String, IFailureDetector, boolean) - Static method in class org.apache.cassandra.dht.RangeStreamer
 
getWrappedStrategies() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
getWriteableLocation(long) - Method in class org.apache.cassandra.db.Directories
Returns a non-blacklisted data directory that _currently_ has writeSize bytes as usable space.
getWriteableLocationAsFile(long) - Method in class org.apache.cassandra.db.Directories
Returns a non-blacklisted data directory that _currently_ has writeSize bytes as usable space.
getWriteConsistencyLevel(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getWriteDirectory(long) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
Return a directory where we can expect expectedWriteSize to fit.
getWriteEndpoints(Token, String, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.TokenMetadata
Deprecated.
retained for benefit of old tests
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
 
getWriterFactory() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
 
getWriterFactory() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
 
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
 
globalCount() - Method in class org.apache.cassandra.utils.concurrent.Ref
A convenience method for reporting:
globalPartitioner() - Static method in class org.apache.cassandra.net.MessagingService
 
globalRangeLatency - Static variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
 
globalReadLatency - Static variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
 
globalSerializer - Static variable in class org.apache.cassandra.repair.messages.PrepareMessage
 
globalWriteLatency - Static variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
 
goodRows - Variable in class org.apache.cassandra.db.compaction.Scrubber.ScrubResult
 
GoogleCloudSnitch - Class in org.apache.cassandra.locator
A snitch that assumes an GCE region is a DC and an GCE availability_zone is a rack.
GoogleCloudSnitch() - Constructor for class org.apache.cassandra.locator.GoogleCloudSnitch
 
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
 
GossipInfo - Class in org.apache.cassandra.tools.nodetool
 
GossipInfo() - Constructor for class org.apache.cassandra.tools.nodetool.GossipInfo
 
GossipingPropertyFileSnitch - Class in org.apache.cassandra.locator
 
GossipingPropertyFileSnitch() - Constructor for class org.apache.cassandra.locator.GossipingPropertyFileSnitch
 
gossipMessageCompletedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
Completed tasks for gossip message TCP Connections
gossipMessageDroppedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
Dropped tasks for gossip message TCP Connections
gossipMessagePendingTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
Pending tasks for gossip message TCP Connections
gossipMessages - Variable in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
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, RoleResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
grant(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
grant(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
Grants a set of permissions on a resource to a role.
grantee - Variable in class org.apache.cassandra.auth.PermissionDetails
 
grantee - Variable in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
 
grantee - Variable in class org.apache.cassandra.cql3.statements.RoleManagementStatement
 
grantPermissionsStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
GrantPermissionsStatement - Class in org.apache.cassandra.cql3.statements
 
GrantPermissionsStatement(Set<Permission>, IResource, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.GrantPermissionsStatement
 
grantPermissionsToCreator(QueryState) - Method in class org.apache.cassandra.cql3.statements.CreateAggregateStatement
 
grantPermissionsToCreator(QueryState) - Method in class org.apache.cassandra.cql3.statements.CreateFunctionStatement
 
grantPermissionsToCreator(QueryState) - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
 
grantPermissionsToCreator(QueryState) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
 
grantPermissionsToCreator(QueryState) - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
Schema alteration may result in a new database object (keyspace, table, role, function) being created capable of having permissions GRANTed on it.
grantRole(AuthenticatedUser, RoleResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
grantRole(AuthenticatedUser, RoleResource, RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
Called during execution of GRANT ROLE query.
grantRoleStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
GrantRoleStatement - Class in org.apache.cassandra.cql3.statements
 
GrantRoleStatement(RoleName, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.GrantRoleStatement
 
group(Iterator<Cell>) - Method in interface org.apache.cassandra.cql3.CQL3Row.Builder
 
GROUP_NAME - Static variable in class org.apache.cassandra.metrics.DefaultNameFactory
 
GroupByPrefix(long, CellNameType, int, boolean) - 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.
GroupByPrefixReversed(long, CellNameType, int, boolean) - Constructor for class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefixReversed
 
groupSSTablesForAntiCompaction(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
Method for grouping similar SSTables together, This will be used by anti-compaction to determine which SSTables should be anitcompacted as a group.
groupSSTablesForAntiCompaction(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
DTCS should not group sstables for anticompaction - this can mix new and old data
groupSSTablesForAntiCompaction(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
Leveled compaction strategy has guarantees on the data contained within each level so we have to make sure we only create groups of SSTables with members from the same level.
groupSSTablesForAntiCompaction(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
GT - Static variable in class org.apache.cassandra.io.sstable.format.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.cql3.CqlLexer
 
H - Static variable in class org.apache.cassandra.cql3.CqlParser
 
HadoopCompat - Class in org.apache.cassandra.hadoop
Utility methods to allow applications to deal with inconsistencies between MapReduce Context Objects API between Hadoop 1.x and 2.x.
HadoopCompat() - Constructor for class org.apache.cassandra.hadoop.HadoopCompat
 
HALF_TIME_IN_S - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
handleCaseSensitivity(Map<String, Object>) - Static method in class org.apache.cassandra.cql3.Json
Handles unquoting and case-insensitivity in map keys.
handleCommitError(String, Throwable) - Static method in class org.apache.cassandra.db.commitlog.CommitLog
 
handleConnectionClosed(long, String) - Method in class org.apache.cassandra.tools.BootstrapMonitor
 
handleConnectionClosed(long, String) - Method in class org.apache.cassandra.tools.RepairRunner
 
handleConnectionClosed(long, String) - Method in class org.apache.cassandra.utils.progress.jmx.JMXNotificationProgressListener
Called when JMX connection is closed.
handleConnectionFailed(long, String) - Method in class org.apache.cassandra.tools.BootstrapMonitor
 
handleConnectionFailed(long, String) - Method in class org.apache.cassandra.tools.RepairRunner
 
handleConnectionFailed(long, String) - Method in class org.apache.cassandra.utils.progress.jmx.JMXNotificationProgressListener
Called when JMX connection is failed.
handleCorruptSSTable(CorruptSSTableException) - Method in interface org.apache.cassandra.io.FSErrorHandler
 
handleCorruptSSTable(CorruptSSTableException) - Static method in class org.apache.cassandra.io.util.FileUtils
 
handleCorruptSSTable(CorruptSSTableException) - Method in class org.apache.cassandra.service.DefaultFSErrorHandler
 
handleFailedSnapshot(File) - Static method in class org.apache.cassandra.db.WindowsFailedSnapshotTracker
 
handleFSError(FSError) - Method in interface org.apache.cassandra.io.FSErrorHandler
 
handleFSError(FSError) - Static method in class org.apache.cassandra.io.util.FileUtils
 
handleFSError(FSError) - Method in class org.apache.cassandra.service.DefaultFSErrorHandler
 
handleMessage(InetAddress, RepairMessage) - Method in class org.apache.cassandra.service.ActiveRepairService
 
handleNotification(INotification, Object) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
handleNotification(INotification, Object) - Method in interface org.apache.cassandra.notifications.INotificationConsumer
 
handleNotification(Notification, Object) - Method in class org.apache.cassandra.service.GCInspector
 
handleNotification(Notification, Object) - Method in class org.apache.cassandra.utils.progress.jmx.JMXNotificationProgressListener
 
handleNotificationLost(long, String) - Method in class org.apache.cassandra.tools.BootstrapMonitor
 
handleNotificationLost(long, String) - Method in class org.apache.cassandra.tools.RepairRunner
 
handleNotificationLost(long, String) - Method in class org.apache.cassandra.utils.progress.jmx.JMXNotificationProgressListener
Called when receiving JMXConnectionNotification.NOTIFS_LOST message.
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
handleProgress(ProgressInfo) - Method in class org.apache.cassandra.streaming.StreamResultFuture
 
handler - Variable in class org.apache.cassandra.service.AbstractReadExecutor
 
handler - Variable in class org.apache.cassandra.streaming.StreamSession
 
handleStreamEvent(StreamEvent) - Method in class org.apache.cassandra.dht.StreamStateStore
When StreamSession completes, make all keyspaces/ranges in session available to be served.
handleStreamEvent(StreamEvent) - Method in class org.apache.cassandra.io.sstable.SSTableLoader
 
handleStreamEvent(StreamEvent) - Method in class org.apache.cassandra.repair.LocalSyncTask
 
handleStreamEvent(StreamEvent) - Method in class org.apache.cassandra.repair.StreamingRepairTask
 
handleStreamEvent(StreamEvent) - Method in class org.apache.cassandra.streaming.management.StreamEventJMXNotifier
 
handleStreamEvent(StreamEvent) - Method in interface org.apache.cassandra.streaming.StreamEventHandler
Callback for various streaming events.
has(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
hasActiveSessions() - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
hasAllAdlerChecksums() - Method in class org.apache.cassandra.io.sstable.format.Version
 
hasAllKeyspacesAccess(Permission) - Method in class org.apache.cassandra.service.ClientState
 
hasAvailableDiskSpace(long, long) - Method in class org.apache.cassandra.db.Directories
 
hasBallot(UUID) - Method in class org.apache.cassandra.service.paxos.Commit
 
hasBound(Bound) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
 
hasBound(Bound) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Checks if the specified bound is set or not.
hasBound(Bound) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
 
hasBound(Bound) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
 
hasBound(Bound) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.Slice
 
hasCF(Pair<String, String>) - Method in class org.apache.cassandra.config.Schema
 
hasClusteringColumnsRestriction() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the query has some restrictions on the clustering columns.
hasCollections() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
hasCollections() - Method in interface org.apache.cassandra.db.composites.CellNameType
Whether or not there is some collections defined in this type.
hasCollections() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType.WithCollection
 
hasColumnFamilyAccess(String, String, Permission) - Method in class org.apache.cassandra.service.ClientState
 
hasColumns() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
hasColumns() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
hasColumns() - Method in class org.apache.cassandra.db.ColumnFamily
Returns whether or not there are any columns present.
hasColumnSpecifications() - Method in class org.apache.cassandra.cql3.QueryOptions
Tells whether or not this QueryOptions contains the column specifications for the bound variables.
hasCommitLogLowerBound() - Method in class org.apache.cassandra.io.sstable.format.Version
 
hasConditions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
hasCrossNodeTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
hasFailedSession() - Method in class org.apache.cassandra.streaming.StreamState
 
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
 
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, 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.FunctionResource
 
hashCode() - Method in class org.apache.cassandra.auth.PermissionDetails
 
hashCode() - Method in class org.apache.cassandra.auth.RoleResource
 
hashCode() - Method in class org.apache.cassandra.cache.CachingOptions
 
hashCode() - Method in class org.apache.cassandra.cache.CachingOptions.KeyCache
 
hashCode() - Method in class org.apache.cassandra.cache.CachingOptions.RowCache
 
hashCode() - Method in class org.apache.cassandra.cache.CounterCacheKey
 
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.CFMetaData.SpeculativeRetry
 
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.config.TriggerDefinition
 
hashCode() - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
hashCode() - Method in class org.apache.cassandra.cql3.ColumnIdentifier.Raw
 
hashCode() - Method in class org.apache.cassandra.cql3.ColumnSpecification
 
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.cql3.CQL3Type.Tuple
 
hashCode() - Method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.FunctionName
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
hashCode() - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
hashCode() - Method in class org.apache.cassandra.db.AbstractCell
 
hashCode() - Method in class org.apache.cassandra.db.ClockAndCount
 
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.composites.AbstractComposite
 
hashCode() - Method in class org.apache.cassandra.db.composites.AbstractCType
 
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.filter.ColumnSlice
 
hashCode() - Method in class org.apache.cassandra.db.IndexExpression
 
hashCode() - Method in class org.apache.cassandra.db.marshal.TupleType
 
hashCode() - Method in class org.apache.cassandra.db.marshal.UserType
 
hashCode() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
hashCode() - Method in class org.apache.cassandra.dht.AbstractBounds
 
hashCode() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
hashCode() - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
 
hashCode() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
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.format.SSTableReader
 
hashCode() - Method in class org.apache.cassandra.io.sstable.format.Version
 
hashCode() - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
 
hashCode() - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
hashCode() - Method in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
 
hashCode() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
 
hashCode() - Method in class org.apache.cassandra.repair.messages.ValidationRequest
 
hashCode() - Method in class org.apache.cassandra.repair.NodePair
 
hashCode() - Method in class org.apache.cassandra.repair.RepairJobDesc
 
hashCode() - Method in class org.apache.cassandra.service.FileCacheService.CacheKey
 
hashCode() - Method in class org.apache.cassandra.service.paxos.Commit
 
hashCode() - Method in class org.apache.cassandra.streaming.messages.FileMessageHeader
 
hashCode() - Method in class org.apache.cassandra.streaming.ProgressInfo
 
hashCode() - Method in class org.apache.cassandra.streaming.StreamResultFuture
 
hashCode() - Method in class org.apache.cassandra.streaming.StreamSummary
 
hashCode() - Method in class org.apache.cassandra.transport.Event.SchemaChange
 
hashCode() - Method in class org.apache.cassandra.transport.Event.StatusChange
 
hashCode() - Method in class org.apache.cassandra.transport.Event.TopologyChange
 
hashCode() - Method in class org.apache.cassandra.utils.CassandraVersion
 
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.RMIServerSocketFactoryImpl
 
hashCode() - Method in class org.apache.cassandra.utils.StreamingHistogram
 
hashCount - Variable in class org.apache.cassandra.utils.BloomFilter
 
hashdepth - Variable in class org.apache.cassandra.utils.MerkleTree
 
hashToBigInteger(ByteBuffer) - Static method in class org.apache.cassandra.utils.FBUtilities
 
hasIfExistCondition() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
hasIfNotExistCondition() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
hasIndexes() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
hasIndexFor(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
hasIndexOption(String) - Method in class org.apache.cassandra.config.ColumnDefinition
Checks if the index option with the specified name has been specified.
hasKeyspace() - Method in class org.apache.cassandra.cql3.functions.FunctionName
 
hasKeyspace() - Method in class org.apache.cassandra.cql3.UTName
 
hasKeyspaceAccess(String, Permission) - Method in class org.apache.cassandra.service.ClientState
 
hasLargeAddressSpace() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
hasLegacyCounterShards - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow.Reducer
 
hasLegacyCounterShards - Variable in class org.apache.cassandra.io.sstable.ColumnStats
 
hasLegacyCounterShards - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
hasLegacyCounterShards - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
hasLegacyShards() - Method in class org.apache.cassandra.db.BufferCounterCell
 
hasLegacyShards(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Detects whether or not the context has any legacy (local or remote) shards in it.
hasLegacyShards() - Method in interface org.apache.cassandra.db.CounterCell
 
hasLegacyShards() - Method in class org.apache.cassandra.db.NativeCounterCell
 
hasMissingElements() - Method in class org.apache.cassandra.db.composites.CompositesBuilder
Checks if some empty list of values have been added
hasName() - Method in class org.apache.cassandra.cql3.RoleName
 
hasNewFileName() - Method in class org.apache.cassandra.io.sstable.format.Version
 
hasNewStatsFile() - Method in class org.apache.cassandra.io.sstable.format.Version
 
hasNext() - Method in class org.apache.cassandra.db.AtomDeserializer
Whether or not there is more atom to read.
hasNext() - Method in interface org.apache.cassandra.db.composites.CellNameType.Deserializer
Whether this deserializer is done or not, i.e.
hasNext() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
 
hasNext() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
hasNext() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
hasNext() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
hasNext() - Method in class org.apache.cassandra.utils.btree.BTreeSearchIterator
 
hasNext() - Method in class org.apache.cassandra.utils.btree.Cursor
 
hasNext() - Method in interface org.apache.cassandra.utils.SearchIterator
 
hasNoClusteringColumnsRestriction() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the query does not contains any restriction on the clustering columns.
hasNonPrimaryKeyRestrictions() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the restrictions contain any non-primary key restrictions
hasOnlyTombstones(long) - Method in class org.apache.cassandra.db.ColumnFamily
 
hasParent() - Method in class org.apache.cassandra.auth.DataResource
 
hasParent() - Method in class org.apache.cassandra.auth.FunctionResource
 
hasParent() - Method in interface org.apache.cassandra.auth.IResource
Indicates whether or not this resource has a parent in the hierarchy.
hasParent() - Method in class org.apache.cassandra.auth.RoleResource
 
hasPartitionKeyRestrictions() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
hasPrivilege(File, Directories.FileAction) - Static method in enum org.apache.cassandra.db.Directories.FileAction
 
hasProcFS() - Static method in class org.apache.cassandra.utils.FBUtilities
 
hasProperty(String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
hasPurgeableTombstones(int) - Method in class org.apache.cassandra.db.DeletionInfo
Returns true if purge would remove the top-level tombstone or any of the range tombstones, false otherwise.
hasPurgeableTombstones(int) - Method in class org.apache.cassandra.db.RangeTombstoneList
Returns whether purge(gcBefore) would remove something or not.
hasRanges() - Method in class org.apache.cassandra.db.DeletionInfo
 
hasReferenceTo(Function) - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
hasReferenceTo(Function) - Method in interface org.apache.cassandra.cql3.functions.Function
 
hasReferenceTo(Function) - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
hasRegularColumnsRestriction() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
hasRegularConditions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
hasRemaining() - Method in class org.apache.cassandra.db.composites.CompositesBuilder
Checks if some elements can still be added to the composites.
hasRemaining() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
hasRepairedAt() - Method in class org.apache.cassandra.io.sstable.format.Version
 
hasRoom() - Method in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
 
hasSameSettings(AbstractReplicationStrategy) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
hasSameSettings(AbstractReplicationStrategy) - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
hasSamplingLevel() - Method in class org.apache.cassandra.io.sstable.format.Version
 
hasScope() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Returns true if the Metric has a scope, false otherwise.
hasStaticColumns() - Method in class org.apache.cassandra.config.CFMetaData
 
hasStaticConditions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
hasStaticSlice(CFMetaData) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
hasSuperuserStatus(RoleResource) - Static method in class org.apache.cassandra.auth.Roles
Returns true if the supplied role or any other role granted to it (directly or indirectly) has superuser status.
hasSupportingIndex(SecondaryIndexManager) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
 
hasSupportingIndex(SecondaryIndexManager) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Check if the restriction is on indexed columns.
hasSupportingIndex(SecondaryIndexManager) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
 
hasSupportingIndex(SecondaryIndexManager) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
hasUnprocessed() - Method in class org.apache.cassandra.db.AtomDeserializer
Whether or not some atom has been read but not processed (neither readNext() nor skipNext() has been called for that atom) yet.
hasUnprocessed() - Method in interface org.apache.cassandra.db.composites.CellNameType.Deserializer
Whether or not some name has been read but not consumed by readNext.
hasUnreclaimedSpace() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
hasUnwrittenTombstones() - Method in class org.apache.cassandra.db.RangeTombstone.Tracker
 
hasWaiters() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
 
haveWork - Variable in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
 
header - Variable in class org.apache.cassandra.streaming.messages.IncomingFileMessage
 
header - Variable in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
 
header - Variable in class org.apache.cassandra.transport.Frame
 
headerLength - Variable in class org.apache.cassandra.db.context.CounterContext.ContextState
 
headerOffset() - Method in class org.apache.cassandra.db.RowIndexEntry
 
headSet(V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
 
headSet(V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
headSet(V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
headSet(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
HeapAllocator - Class in org.apache.cassandra.utils.memory
 
HeapPool - Class in org.apache.cassandra.utils.memory
 
HeapPool(long, float, Runnable) - Constructor for class org.apache.cassandra.utils.memory.HeapPool
 
HeapPool.Allocator - Class in org.apache.cassandra.utils.memory
 
HeapUtils - Class in org.apache.cassandra.utils
Utility to log heap histogram.
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
 
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
 
higher(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
highestSelectivityIndex(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
 
highestSelectivityPredicate(List<IndexExpression>, boolean) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
 
hinted_handoff_enabled - Variable in class org.apache.cassandra.config.Config
 
hinted_handoff_enabled_by_dc - Variable in class org.apache.cassandra.config.Config
 
hinted_handoff_enabled_global - 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
 
hintedHandoffEnabled(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
hintedHandoffEnabledByDC() - 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
 
hintFor(Mutation, long, int, Pair<InetAddress, UUID>) - Method in class org.apache.cassandra.db.HintedHandOffManager
Returns a mutation representing a Hint to be sent to targetId as soon as it becomes available again.
HINTS - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
Hints - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
histogram(CassandraMetricsRegistry.MetricName, boolean) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
HistogramBuilder - Class in org.apache.cassandra.utils
Simple class for constructing an EsimtatedHistogram from a set of predetermined values
HistogramBuilder() - Constructor for class org.apache.cassandra.utils.HistogramBuilder
 
HistogramBuilder(long[]) - Constructor for class org.apache.cassandra.utils.HistogramBuilder
 
histogramOfRowCountPerLeaf() - Method in class org.apache.cassandra.utils.MerkleTree
 
histogramOfRowSizePerLeaf() - Method in class org.apache.cassandra.utils.MerkleTree
 
hitRate - Variable in class org.apache.cassandra.metrics.CacheMetrics
cache hit rate
hitRate - Variable in class org.apache.cassandra.metrics.FileCacheMetrics
hit rate
hits - Variable in class org.apache.cassandra.metrics.CacheMetrics
Total number of cache hits
hits - Variable in class org.apache.cassandra.metrics.FileCacheMetrics
Total number of hits
Holder() - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo.Holder
 
host - Variable in class org.apache.cassandra.tools.AbstractJmxClient
 
host - Variable in class org.apache.cassandra.transport.SimpleClient
 
hostId(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
HOSTS_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
HostStat - Class in org.apache.cassandra.tools.nodetool
 
HostStat(String, InetAddress, boolean, Float) - Constructor for class org.apache.cassandra.tools.nodetool.HostStat
 
hotKeyIterator(int) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
hotKeyIterator(int) - Method in interface org.apache.cassandra.cache.ICache
 
hotKeyIterator(int) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
hotKeyIterator(int) - Method in class org.apache.cassandra.cache.SerializingCache
 
HSHA - Static variable in class org.apache.cassandra.thrift.ThriftServer
 

I

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.
IAsyncCallbackWithFailure<T> - Interface in org.apache.cassandra.net
 
IAuthenticator - Interface in org.apache.cassandra.auth
 
IAuthenticator.SaslNegotiator - Interface in org.apache.cassandra.auth
Performs the actual SASL negotiation for a single authentication attempt.
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.
IColumnIteratorFactory - Interface in org.apache.cassandra.db.columniterator
 
ICompressedFile - Interface in org.apache.cassandra.io.util
 
ICompressor - Interface in org.apache.cassandra.io.compress
 
id - Variable in class org.apache.cassandra.concurrent.NamedThreadFactory
 
id - Variable in class org.apache.cassandra.cql3.selection.Selectable.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 exception org.apache.cassandra.exceptions.PreparedQueryNotFoundException
 
id - Variable in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
 
IDENT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
IDENT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
ident() - Method in class org.apache.cassandra.cql3.CqlParser
 
IdentityQueryFilter - Class in org.apache.cassandra.db.columniterator
 
IdentityQueryFilter() - Constructor for class org.apache.cassandra.db.columniterator.IdentityQueryFilter
Will read entire CF into memory.
idFor(ByteBuffer) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
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
 
IDLE_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
 
idx - Variable in enum org.apache.cassandra.cql3.statements.Bound
 
idxName(IndexName) - Method in class org.apache.cassandra.cql3.CqlParser
 
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.
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.
ifExists - Variable in class org.apache.cassandra.cql3.statements.DropIndexStatement
 
ifile - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
ifile - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
IFilter - Interface in org.apache.cassandra.utils
 
IFilter.FilterKey - Interface in org.apache.cassandra.utils
 
IGNORE_HOSTS - Static variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
IGNORE_TOMBSTONED_PARTITIONS - Static variable in class org.apache.cassandra.db.filter.SliceQueryFilter
A special value for compositesToGroup that indicates that partitioned tombstones should not be included in results or count towards the limit.
ignoredTombstonedPartitions() - Method in class org.apache.cassandra.db.AbstractRangeCommand
Returns true if tombstoned partitions should not be included in results or count towards the limit.
ignoredTombstonedPartitions() - Method in class org.apache.cassandra.db.DataRange
Returns true if tombstoned partitions should not be included in results or count towards the limit.
ignores - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
ignoreTombstonedPartitions() - Method in class org.apache.cassandra.db.filter.ExtendedFilter
Returns true if tombstoned partitions should not be included in results or count towards the limit, false otherwise.
IInternodeAuthenticator - Interface in org.apache.cassandra.auth
 
ILatencySubscriber - Interface in org.apache.cassandra.locator
 
IMeasurableMemory - Interface in org.apache.cassandra.cache
 
IMergeIterator<In,Out> - Interface in org.apache.cassandra.utils
 
IMessageSink - Interface in org.apache.cassandra.net
 
IMetadataComponentSerializer<T extends MetadataComponent> - Interface in org.apache.cassandra.io.sstable.metadata
Metadata component serializer
IMetadataSerializer - Interface in org.apache.cassandra.io.sstable.metadata
Interface for SSTable metadata serializer
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(List<ColumnDefinition>) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.IN
 
IN(ColumnDefinition) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IN
 
includeBackups(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
includes(Comparator<Composite>, Composite) - Method in class org.apache.cassandra.db.filter.ColumnSlice
 
includes(Comparator<Composite>, Composite) - Method in class org.apache.cassandra.db.RangeTombstone
 
IncludingExcludingBounds<T extends RingPosition<T>> - 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
 
inclusive - Variable in class org.apache.cassandra.dht.AbstractBounds.Boundary
 
inclusiveLeft() - Method in class org.apache.cassandra.dht.AbstractBounds
 
inclusiveLeft() - Method in class org.apache.cassandra.dht.Bounds
 
inclusiveLeft() - Method in class org.apache.cassandra.dht.ExcludingBounds
 
inclusiveLeft() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
inclusiveLeft() - Method in class org.apache.cassandra.dht.Range
 
inclusiveLowerBound - Variable in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
inclusiveRight() - Method in class org.apache.cassandra.dht.AbstractBounds
 
inclusiveRight() - Method in class org.apache.cassandra.dht.Bounds
 
inclusiveRight() - Method in class org.apache.cassandra.dht.ExcludingBounds
 
inclusiveRight() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
inclusiveRight() - Method in class org.apache.cassandra.dht.Range
 
inclusiveUpperBound - Variable in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
incomingBytes - Variable in class org.apache.cassandra.metrics.StreamingMetrics
 
IncomingFileMessage - Class in org.apache.cassandra.streaming.messages
IncomingFileMessage is used to receive the part(or whole) of a SSTable data file.
IncomingFileMessage(SSTableWriter, FileMessageHeader) - Constructor for class org.apache.cassandra.streaming.messages.IncomingFileMessage
 
IncomingStreamingConnection - Class in org.apache.cassandra.net
Thread to consume stream init messages.
IncomingStreamingConnection(int, Socket, Set<Closeable>) - Constructor for class org.apache.cassandra.net.IncomingStreamingConnection
 
IncomingTcpConnection - Class in org.apache.cassandra.net
 
IncomingTcpConnection(int, boolean, Socket, Set<Closeable>) - Constructor for class org.apache.cassandra.net.IncomingTcpConnection
 
inCondition(ColumnDefinition, List<Term>) - Static method in class org.apache.cassandra.cql3.ColumnCondition
 
inCondition(ColumnDefinition, Term, List<Term>) - Static method in class org.apache.cassandra.cql3.ColumnCondition
 
inCondition(ColumnDefinition, Term) - Static method in class org.apache.cassandra.cql3.ColumnCondition
 
inCondition(ColumnDefinition, Term, Term) - Static method in class org.apache.cassandra.cql3.ColumnCondition
 
incrCompactionSeverity(double) - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
 
incrCounter(Enum<?>, long) - Method in class org.apache.cassandra.hadoop.ReporterWrapper
 
incrCounter(String, String, long) - Method in class org.apache.cassandra.hadoop.ReporterWrapper
 
incrCreatedHints(InetAddress) - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
 
incremental_backups - Variable in class org.apache.cassandra.config.Config
 
INCREMENTAL_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
incrementAndGetGeneration() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
incrementCounter(Counter, long) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
Increment the counter.
incrementDroppedMessages(MessagingService.Verb) - Method in class org.apache.cassandra.net.MessagingService
 
incrementDroppedMessages(MessagingService.Verb, boolean) - Method in class org.apache.cassandra.net.MessagingService
 
incrementReadCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Increment the total row read count and read rate for this SSTable.
incrementTimeout() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
incrManualSeverity(double) - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
 
incrPastWindow(InetAddress) - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
 
index(ByteBuffer, ColumnFamily) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
Index the given row.
INDEX_ENTRIES_OPTION_NAME - Static variable in class org.apache.cassandra.db.index.SecondaryIndex
The name of the option used to specify that the index is on the collection (map) entries.
index_interval - Variable in class org.apache.cassandra.config.Config
Deprecated.
INDEX_KEYS_OPTION_NAME - Static variable in class org.apache.cassandra.db.index.SecondaryIndex
The name of the option used to specify that the index is on the collection keys.
index_summary_capacity_in_mb - Variable in class org.apache.cassandra.config.Config
 
index_summary_resize_interval_in_minutes - Variable in class org.apache.cassandra.config.Config
 
INDEX_VALUES_OPTION_NAME - Static variable in class org.apache.cassandra.db.index.SecondaryIndex
The name of the option used to specify that the index is on the collection values.
indexBuilder - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
indexCfs - Variable in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
indexColumnFamilyName(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
generate a column family name for an index corresponding to the given column.
indexComparator() - Method in class org.apache.cassandra.db.composites.AbstractCType
 
indexComparator() - Method in interface org.apache.cassandra.db.composites.CType
 
IndexedEntry(DecoratedKey, CellName, long, ByteBuffer, Composite) - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
 
IndexedEntry(DecoratedKey, CellName, long, ByteBuffer, Composite, ByteBuffer) - Constructor for class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
 
indexedEntryCollectionKey - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
 
indexedEntryPrefix - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
 
indexedKey - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
 
indexEntry - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
 
indexer - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
indexes(CellName) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexIncludingCollectionKey
 
indexes(CellName) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
 
indexes(CellName) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionValue
 
indexes(CellName) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
 
indexes(CellName) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
 
indexes(CellName) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
indexes(CellName) - Method in class org.apache.cassandra.db.index.SecondaryIndex
Returns true if the provided cell name is indexed by this secondary index.
indexes(ColumnDefinition) - Method in class org.apache.cassandra.db.index.SecondaryIndex
Returns true if the provided column definition is indexed by this secondary index.
indexes(CellName, Collection<SecondaryIndex>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
indexes(Cell) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
indexes(CellName) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
IndexExpression - Class in org.apache.cassandra.db
 
IndexExpression(ByteBuffer, Operator, ByteBuffer) - Constructor for class org.apache.cassandra.db.IndexExpression
 
indexExpressionsFromThrift(List<IndexExpression>) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
indexFilePath - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
 
indexFor(CellName, Collection<SecondaryIndex>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
indexFor(CellName) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
indexFor(Composite, List<IndexHelper.IndexInfo>, CType, 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.Serializer - Class in org.apache.cassandra.io.sstable
 
indexIdent() - Method in class org.apache.cassandra.cql3.CqlParser
 
IndexInfo(Composite, Composite, long, long) - Constructor for class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
indexLength - Variable in class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
 
indexManager - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
indexManager - Variable in class org.apache.cassandra.db.index.SecondaryIndexSearcher
 
indexName() - Method in class org.apache.cassandra.cql3.CqlParser
 
IndexName - Class in org.apache.cassandra.cql3
 
IndexName() - Constructor for class org.apache.cassandra.cql3.IndexName
 
indexName - Variable in class org.apache.cassandra.cql3.statements.DropIndexStatement
 
IndexNotAvailableException - Exception in org.apache.cassandra.db.index
Thrown if a secondary index is not currently available.
IndexNotAvailableException(String) - Constructor for exception org.apache.cassandra.db.index.IndexNotAvailableException
Creates a new IndexNotAvailableException for the specified index.
indexOption() - Method in enum org.apache.cassandra.cql3.statements.IndexTarget.TargetType
 
IndexPropDefs - Class in org.apache.cassandra.cql3.statements
 
IndexPropDefs() - Constructor for class org.apache.cassandra.cql3.statements.IndexPropDefs
 
indexReverseComparator() - Method in class org.apache.cassandra.db.composites.AbstractCType
 
indexReverseComparator() - Method in interface org.apache.cassandra.db.composites.CType
 
indexRow(ByteBuffer, ColumnFamily, OpOrder.Group) - 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.Keyspace
 
indexSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Lists
 
indexSummary - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
IndexSummary - Class in org.apache.cassandra.io.sstable
 
IndexSummary(IPartitioner, Memory, int, Memory, long, int, int, int) - Constructor for class org.apache.cassandra.io.sstable.IndexSummary
 
IndexSummary.IndexSummarySerializer - Class in org.apache.cassandra.io.sstable
 
IndexSummaryBuilder - Class in org.apache.cassandra.io.sstable
 
IndexSummaryBuilder(long, int, int) - Constructor for class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
IndexSummaryBuilder.ReadableBoundary - Class in org.apache.cassandra.io.sstable
Represents a boundary that is guaranteed fully readable in the summary, index file and data file.
IndexSummaryManager - Class in org.apache.cassandra.io.sstable
Manages the fixed-size memory pool for index summaries, periodically resizing them in order to give more memory to hot sstables and less memory to cold sstables.
IndexSummaryManagerMBean - Interface in org.apache.cassandra.io.sstable
 
indexSummaryOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Off heap memory used by index summary
indexSummaryOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Off heap memory used by index summary
IndexSummaryRedistribution - Class in org.apache.cassandra.io.sstable
 
IndexSummaryRedistribution(List<SSTableReader>, Map<UUID, LifecycleTransaction>, long) - Constructor for class org.apache.cassandra.io.sstable.IndexSummaryRedistribution
 
IndexSummarySerializer() - Constructor for class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
 
IndexTarget - Class in org.apache.cassandra.cql3.statements
 
IndexTarget.Raw - Class in org.apache.cassandra.cql3.statements
 
IndexTarget.TargetType - Enum in org.apache.cassandra.cql3.statements
 
IndexType - Enum in org.apache.cassandra.config
 
indexValue - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
 
inDirectory(String) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
The directory where to write the sstables.
inDirectory(File) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
The directory where to write the sstables (mandatory option).
InetAddressSerializer - Class in org.apache.cassandra.serializers
 
InetAddressSerializer() - Constructor for class org.apache.cassandra.serializers.InetAddressSerializer
 
InetAddressType - Class in org.apache.cassandra.db.marshal
 
inEventLoop(Thread) - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
 
info - Variable in enum org.apache.cassandra.io.sstable.format.SSTableFormat.Type
 
Info - Class in org.apache.cassandra.tools.nodetool
 
Info() - Constructor for class org.apache.cassandra.tools.nodetool.Info
 
info(long, String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
info(String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
info(long, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
 
info(Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
 
init() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
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(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamSession
Bind this session to report to specific StreamResultFuture and perform pre-streaming initialization.
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.
init(String) - Method in class org.apache.cassandra.utils.NativeSSTableLoaderClient
 
initCf(CFMetaData, boolean) - Method in class org.apache.cassandra.db.Keyspace
adds a cf to internal structures, ends up creating disk files).
initcond - Variable in class org.apache.cassandra.cql3.functions.UDAggregate
 
initDatabaseDescriptor() - Static method in class org.apache.cassandra.tools.Util
This is used by standalone tools to force static initialization of DatabaseDescriptor, and fail if configuration is bad.
initHostAddress - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
initHostAddress - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
initial_token - Variable in class org.apache.cassandra.config.Config
 
INITIAL_VALUE_NANOS - Static variable in class org.apache.cassandra.gms.FailureDetector
 
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
 
initialCondition() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
Deprecated.
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
initialized() - Method in class org.apache.cassandra.utils.SigarLibrary
 
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
 
initiate() - Method in class org.apache.cassandra.streaming.ConnectionHandler
Set up incoming message handler and initiate streaming.
initiateOnReceivingSide(IncomingStreamingConnection, boolean, int) - Method in class org.apache.cassandra.streaming.ConnectionHandler
Set up outgoing message handler on receiving side.
initiator - Variable in class org.apache.cassandra.repair.messages.SyncRequest
 
initiator - Variable in class org.apache.cassandra.repair.Validator
 
initReceivingSide(int, UUID, String, InetAddress, IncomingStreamingConnection, boolean, int, boolean, boolean) - Static method in class org.apache.cassandra.streaming.StreamResultFuture
 
initSchema(String) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
Methods to get the column family schema from Cassandra
initSchema(String) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
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
 
initSigarLibrary - Static variable in class org.apache.cassandra.service.StartupChecks
 
injectApplicationState(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.Gossiper
 
inMarker() - Method in class org.apache.cassandra.cql3.CqlParser
 
InMarker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Tuples.InMarker
 
inMarkerForTuple() - Method in class org.apache.cassandra.cql3.CqlParser
 
inOrderDeletionTester() - Method in class org.apache.cassandra.db.ColumnFamily
Returns a DeletionInfo.InOrderTester for the deletionInfo() of this column family.
inOrderTester() - Method in class org.apache.cassandra.db.DeletionInfo
Returns a new DeletionInfo.InOrderTester in forward order.
inOrderTester(boolean) - Method in class org.apache.cassandra.db.DeletionInfo
Returns a new DeletionInfo.InOrderTester given the order in which columns will be passed to it.
InOrderTester() - Constructor for class org.apache.cassandra.db.RangeTombstoneList.InOrderTester
 
INotification - Interface in org.apache.cassandra.notifications
Created by IntelliJ IDEA.
INotificationConsumer - Interface in org.apache.cassandra.notifications
 
inProgressCommit - Variable in class org.apache.cassandra.service.paxos.PrepareResponse
 
inputFormatClass - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
inputFormatClass - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
inputStream(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
inputVersion - Variable in class org.apache.cassandra.streaming.StreamReader
 
INRaw(int) - Constructor for class org.apache.cassandra.cql3.AbstractMarker.INRaw
 
INRaw(int) - Constructor for class org.apache.cassandra.cql3.Tuples.INRaw
 
inSerializer - Variable in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
 
insert(ByteBuffer, Cell, OpOrder.Group) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
insert(ByteBuffer, Cell, OpOrder.Group) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
insert a column to the index
insert(Cell) - 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.cql3.CqlParser
 
inspectCommitLogThrowable(Throwable) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
 
inspectJvmOptions - Static variable in class org.apache.cassandra.service.StartupChecks
 
inspectThrowable(Throwable) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
Certain Throwables and Exceptions represent "Die" conditions for the server.
instance - Static variable in class org.apache.cassandra.config.Schema
 
instance - Static variable in class org.apache.cassandra.cql3.QueryProcessor
 
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.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.ByteType
 
instance - Static variable in class org.apache.cassandra.db.marshal.CounterColumnType
 
instance - Static variable in class org.apache.cassandra.db.marshal.DateType
Deprecated.
 
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.ShortType
 
instance - Static variable in class org.apache.cassandra.db.marshal.SimpleDateType
 
instance - Static variable in class org.apache.cassandra.db.marshal.TimestampType
 
instance - Static variable in class org.apache.cassandra.db.marshal.TimeType
 
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.db.SizeEstimatesRecorder
 
instance - Static variable in class org.apache.cassandra.dht.BootStrapper.StringSerializer
 
instance - Static variable in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
instance - Static variable in class org.apache.cassandra.dht.Murmur3Partitioner
 
instance - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
instance - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 
instance - Static variable in class org.apache.cassandra.gms.EchoMessage
 
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.LZ4Compressor
 
instance - Static variable in class org.apache.cassandra.io.compress.SnappyCompressor
 
instance - Static variable in class org.apache.cassandra.io.sstable.format.big.BigFormat
 
instance - Static variable in class org.apache.cassandra.io.sstable.IndexSummaryManager
 
instance - Static variable in class org.apache.cassandra.metrics.ClientMetrics
 
instance() - Static method in class org.apache.cassandra.net.MessagingService
 
instance - Static variable in class org.apache.cassandra.serializers.AsciiSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.BooleanSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.ByteSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.BytesSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.DecimalSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.DoubleSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.EmptySerializer
 
instance - Static variable in class org.apache.cassandra.serializers.FloatSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.InetAddressSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.Int32Serializer
 
instance - Static variable in class org.apache.cassandra.serializers.IntegerSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.LongSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.ShortSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.SimpleDateSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.TimeSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.TimestampSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.TimeUUIDSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.UTF8Serializer
 
instance - Static variable in class org.apache.cassandra.serializers.UUIDSerializer
 
instance - Static variable in class org.apache.cassandra.service.ActiveRepairService
 
instance - Static variable in class org.apache.cassandra.service.CacheService
 
instance - Static variable in class org.apache.cassandra.service.ClientWarn
 
instance - Static variable in class org.apache.cassandra.service.FileCacheService
 
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 variable in class org.apache.cassandra.service.PendingRangeCalculatorService
 
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.StreamManager
 
instance - Static variable in class org.apache.cassandra.thrift.ThriftSessionManager
 
instance - Static variable in class org.apache.cassandra.tracing.Tracing
 
instance - Static variable in class org.apache.cassandra.transport.FrameCompressor.LZ4Compressor
 
instance - Static variable in class org.apache.cassandra.transport.FrameCompressor.SnappyCompressor
 
instance - Static variable in class org.apache.cassandra.triggers.TriggerExecutor
 
instance() - Static method in class org.apache.cassandra.utils.btree.UpdateFunction.NoOp
 
instance - Static variable in class org.apache.cassandra.utils.CRC32Factory
 
instance - Static variable in class org.apache.cassandra.utils.memory.HeapAllocator
 
instance - Static variable in class org.apache.cassandra.utils.SigarLibrary
 
instanceId - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
instanceOrConstruct(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
Constructs an instance of the given class, which must have a no-arg or default constructor.
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
 
Int32Serializer - Class in org.apache.cassandra.serializers
 
Int32Serializer() - Constructor for class org.apache.cassandra.serializers.Int32Serializer
 
Int32Type - Class in org.apache.cassandra.db.marshal
 
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
 
IntegerSerializer - Class in org.apache.cassandra.serializers
 
IntegerSerializer() - Constructor for class org.apache.cassandra.serializers.IntegerSerializer
 
IntegerType - Class in org.apache.cassandra.db.marshal
 
inter_dc_stream_throughput_outbound_megabits_per_sec - Variable in class org.apache.cassandra.config.Config
 
inter_dc_tcp_nodelay - Variable in class org.apache.cassandra.config.Config
 
internalClose() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
Close the segment file.
internalClose() - Method in class org.apache.cassandra.db.commitlog.CompressedSegment
 
internalClose() - Method in class org.apache.cassandra.db.commitlog.MemoryMappedSegment
 
internalIP(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
internalOpen(Descriptor, Set<Component>, CFMetaData, IPartitioner, SegmentedFile, SegmentedFile, IndexSummary, IFilter, long, StatsMetadata, SSTableReader.OpenReason) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
Open a RowIndexedReader which already has its state initialized (by SSTableWriter).
internalSize() - Method in class org.apache.cassandra.db.AbstractNativeCell
 
internedIds - Variable in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
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
 
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
 
interruptCompactionFor(Iterable<CFMetaData>, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
Try to stop all of the compactions for given ColumnFamilies.
interruptCompactionForCFs(Iterable<ColumnFamilyStore>, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
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(List<ByteBuffer>, List<ByteBuffer>, CellNameType, boolean) - Method in class org.apache.cassandra.db.filter.ColumnSlice
 
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 - Variable in class org.apache.cassandra.db.lifecycle.View
 
IntervalTree<C extends java.lang.Comparable<? super C>,D,I extends Interval<C,D>> - Class in org.apache.cassandra.utils
 
IntervalTree(Collection<I>) - Constructor for class org.apache.cassandra.utils.IntervalTree
 
IntervalTree.Serializer<C extends java.lang.Comparable<? super C>,D,I extends Interval<C,D>> - Class in org.apache.cassandra.utils
 
inTransportFactory - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
 
intValue() - Method in class org.apache.cassandra.cql3.CqlParser
 
invalidate() - Method in class org.apache.cassandra.auth.PermissionsCache
 
invalidate() - Method in interface org.apache.cassandra.auth.PermissionsCacheMBean
 
invalidate() - Method in class org.apache.cassandra.auth.RolesCache
 
invalidate() - Method in interface org.apache.cassandra.auth.RolesCacheMBean
 
invalidate() - Method in class org.apache.cassandra.db.ColumnFamilyStore
call when dropping or renaming a CF.
invalidate(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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(FileCacheService.CacheKey, String) - Method in class org.apache.cassandra.service.FileCacheService
 
invalidate(Token) - Method in class org.apache.cassandra.utils.MerkleTree
Invalidates the ranges containing the given token.
invalidateCachedRings() - Method in class org.apache.cassandra.locator.TokenMetadata
 
invalidateCachedRow(RowCacheKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
invalidateCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
invalidateCounterCache(Collection<Bounds<Token>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
invalidateCounterCache() - Method in class org.apache.cassandra.service.CacheService
 
invalidateCounterCache() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
invalidateCounterCache() - Method in class org.apache.cassandra.tools.NodeProbe
 
InvalidateCounterCache - Class in org.apache.cassandra.tools.nodetool
 
InvalidateCounterCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidateCounterCache
 
invalidateCounterCacheForCf(Pair<String, String>) - Method in class org.apache.cassandra.service.CacheService
 
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
 
InvalidateKeyCache - Class in org.apache.cassandra.tools.nodetool
 
InvalidateKeyCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidateKeyCache
 
invalidateKeyCacheForCf(Pair<String, String>) - Method in class org.apache.cassandra.service.CacheService
 
invalidateRowCache(Collection<Bounds<Token>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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
 
InvalidateRowCache - Class in org.apache.cassandra.tools.nodetool
 
InvalidateRowCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidateRowCache
 
invalidateRowCacheForCf(Pair<String, String>) - Method in class org.apache.cassandra.service.CacheService
 
invalidRequest(String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Returns an InvalidRequestException with the specified message.
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.
InValue(List<List<ByteBuffer>>) - Constructor for class org.apache.cassandra.cql3.Tuples.InValue
 
inverse() - Method in class org.apache.cassandra.utils.BiMultiValMap
 
inverse() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
INVERTED_ORDER - Static variable in class org.apache.cassandra.utils.memory.MemoryUtil
 
invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
InWithMarker(List<ColumnDefinition>, AbstractMarker) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InWithMarker
 
InWithMarker(ColumnDefinition, AbstractMarker) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InWithMarker
 
InWithValues(List<ColumnDefinition>, List<Term>) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InWithValues
 
InWithValues(ColumnDefinition, List<Term>) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InWithValues
 
IOWAIT_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
 
IPartitioner - Interface in org.apache.cassandra.dht
 
IPartitionerDependentSerializer<T> - Interface in org.apache.cassandra.dht
Versioned serializer where the serialization depends on partitioner.
ipOrDns() - Method in class org.apache.cassandra.tools.nodetool.HostStat
 
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
 
IRoleManager - Interface in org.apache.cassandra.auth
Responsible for managing roles (which also includes what used to be known as users), including creation, deletion, alteration and the granting and revoking of roles to other roles.
IRoleManager.Option - Enum in org.apache.cassandra.auth
Supported options for CREATE ROLE/ALTER ROLE (and CREATE USER/ALTER USER, which are aliases provided for backwards compatibility).
IRowCacheEntry - Interface in org.apache.cassandra.cache
 
IRQ_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
 
isActive - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
pause/resume/getNextBackgroundTask must synchronize.
isAffectedByMeteredFlusher() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
isAfter(Commit) - Method in class org.apache.cassandra.service.paxos.Commit
 
isAfter(OpOrder.Group) - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
 
isAggregate() - Method in interface org.apache.cassandra.cql3.functions.Function
Checks whether the function is an aggregate function or not.
isAggregate() - Method in class org.apache.cassandra.cql3.functions.NativeAggregateFunction
 
isAggregate() - Method in class org.apache.cassandra.cql3.functions.NativeScalarFunction
 
isAggregate() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
isAggregate() - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
isAggregate() - Method in class org.apache.cassandra.cql3.selection.Selection
 
isAggregate() - Method in class org.apache.cassandra.cql3.selection.Selector
Checks if this Selector is creating aggregates.
isAggregateSelectorFactory() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Checks if this factory creates selectors instances that creates aggregates.
isAlive() - Method in class org.apache.cassandra.gms.EndpointState
 
isAlive(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
 
isAlive(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
isAlive(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
Failure Detector's knowledge of whether a node is up or down.
isAlive - Static variable in interface org.apache.cassandra.net.IAsyncCallback
 
isAlwaysEmpty(CellNameType, 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.
isAssignable() - Method in enum org.apache.cassandra.cql3.AssignmentTestable.TestResult
 
isAutoBootstrap() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isAutoCompactionDisabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isAutoCompactionDisabled() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
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
 
isBefore(Comparator<Composite>, Composite) - Method in class org.apache.cassandra.db.filter.ColumnSlice
 
isBlocking() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
 
isBlockingSignal() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
register to be signalled when a barrier waiting on us is, or maybe, blocking general progress, so we should try more aggressively to progress
isBlockingSignal(WaitQueue.Signal) - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
wrap the provided signal to also be signalled if the operation gets marked blocking
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
 
isByteOrderComparable - Variable in class org.apache.cassandra.db.composites.AbstractCType
 
isByteOrderComparable(Iterable<AbstractType<?>>) - Static method in class org.apache.cassandra.db.composites.AbstractCType
 
isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.AsciiType
 
isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.BytesType
 
isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.DateType
Deprecated.
 
isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.InetAddressType
 
isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.MapType
 
isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.SetType
 
isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.TimeType
 
isByteOrderComparable() - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
isCallableWrtNullable(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
isCalledOnNullInput() - Method in class org.apache.cassandra.cql3.functions.NativeScalarFunction
 
isCalledOnNullInput() - Method in interface org.apache.cassandra.cql3.functions.ScalarFunction
 
isCalledOnNullInput() - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
isCancelled() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
 
isClean() - Method in class org.apache.cassandra.db.Memtable
 
isCleanedUp() - Method in class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
 
isCleanerAvailable() - Static method in class org.apache.cassandra.io.util.FileUtils
 
isClientMode() - Static method in class org.apache.cassandra.config.Config
 
isClusteringColumn() - Method in class org.apache.cassandra.config.ColumnDefinition
 
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.cql3.CQL3Type.Raw
 
isCollection() - Method in class org.apache.cassandra.cql3.CQL3Type.Tuple
 
isCollection() - Method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
 
isCollection() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isCollection() - Method in class org.apache.cassandra.db.marshal.CollectionType
 
isCollectionCell() - Method in class org.apache.cassandra.db.AbstractNativeCell
 
isCollectionCell() - Method in interface org.apache.cassandra.db.composites.CellName
 
isCollectionCell() - Method in class org.apache.cassandra.db.composites.CompoundDenseCellName
 
isCollectionCell() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
 
isCollectionCell() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName.WithCollection
 
isCollectionCell() - Method in class org.apache.cassandra.db.composites.SimpleDenseCellName
 
isCollectionCell() - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
 
isColumnRange() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the query returns a range of columns.
isCompacting(Iterable<ColumnFamilyStore>) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
isCompactionManager - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
 
isCompactValue() - Method in class org.apache.cassandra.config.ColumnDefinition
 
isCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
isCompatible() - Method in class org.apache.cassandra.io.sstable.format.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(CType) - Method in class org.apache.cassandra.db.composites.AbstractCType
 
isCompatibleWith(CType) - Method in interface org.apache.cassandra.db.composites.CType
See AbstractType#isCompatibleWith.
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.CollectionType
 
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.DateType
Deprecated.
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TimestampType
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TupleType
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
isCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.CollectionType
A version of isCompatibleWith() to deal with non-multicell (frozen) collections
isCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.ListType
 
isCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.MapType
 
isCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.SetType
 
isComplete() - Method in interface org.apache.cassandra.auth.IAuthenticator.SaslNegotiator
Called after each invocation of IAuthenticator.SaslNegotiator.evaluateResponse(byte[]) to determine whether the authentication has completed successfully or should be continued.
isCompleted() - Method in class org.apache.cassandra.streaming.ProgressInfo
 
isCompound() - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
 
isCompound() - Method in class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
 
isCompound() - Method in class org.apache.cassandra.db.composites.CompoundCType
 
isCompound() - Method in interface org.apache.cassandra.db.composites.CType
Returns whether this is a "truly-composite" underneath.
isCompound() - Method in class org.apache.cassandra.db.composites.SimpleCType
 
isCompressed() - Method in class org.apache.cassandra.streaming.messages.FileMessageHeader
 
isContains() - Method in class org.apache.cassandra.cql3.Relation
Checks if the operator of this relation is a CONTAINS.
isContains() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
 
isContains() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
 
isContains() - Method in class org.apache.cassandra.db.IndexExpression
Checks if the operator of this IndexExpression is a CONTAINS operator.
isContainsKey() - Method in class org.apache.cassandra.cql3.Relation
Checks if the operator of this relation is a CONTAINS_KEY.
isContainsKey() - Method in class org.apache.cassandra.db.IndexExpression
Checks if the operator of this IndexExpression is a CONTAINS_KEY operator.
isCounter() - Method in class org.apache.cassandra.config.CFMetaData
 
isCounter() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
isCounter() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
isCounter() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isCounter() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
isCounterCacheEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isCountRows(Function) - Static method in class org.apache.cassandra.cql3.functions.AggregateFcts
Checks if the specified function is the count rows (e.g.
isCQL3Table() - Method in class org.apache.cassandra.config.CFMetaData
 
isCustom - Variable in class org.apache.cassandra.cql3.statements.IndexPropDefs
 
isDaemonInitialized() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isDataAvailable(String, Token) - Method in class org.apache.cassandra.dht.StreamStateStore
Check if given token's data is available in this node.
isDatacenterLocal() - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
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
 
isDeadState(EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
 
isDeleted(Cell) - Method in class org.apache.cassandra.db.DeletionInfo.InOrderTester
 
isDeleted(Cell) - Method in class org.apache.cassandra.db.DeletionInfo
Return whether a given cell is deleted by the container having this deletion info.
isDeleted(OnDiskAtom) - Method in class org.apache.cassandra.db.DeletionTime
 
isDeleted(Cell) - Method in class org.apache.cassandra.db.RangeTombstone.Tracker
Tests if the provided column is deleted by one of the tombstone tracked by this tracker.
isDeleted(Cell) - Method in class org.apache.cassandra.db.RangeTombstoneList.InOrderTester
 
isDeleted(Cell) - 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.
isDense(Boolean) - Method in class org.apache.cassandra.config.CFMetaData
 
isDense() - Method in interface org.apache.cassandra.db.composites.CellNameType
Whether or not the cell names for this type are dense.
isDense() - Method in class org.apache.cassandra.db.composites.CompoundDenseCellNameType
 
isDense() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
isDense() - Method in class org.apache.cassandra.db.composites.SimpleDenseCellNameType
 
isDense() - Method in class org.apache.cassandra.db.composites.SimpleSparseCellNameType
 
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
 
isDistinct - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
 
isDummy() - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
isEmpty() - Method in class org.apache.cassandra.auth.RoleOptions
Return true if there are no options with values set, false otherwise
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.ResultSet
 
isEmpty() - Method in class org.apache.cassandra.cql3.UntypedResultSet
 
isEmpty() - Method in class org.apache.cassandra.db.AbstractNativeCell
 
isEmpty() - Method in class org.apache.cassandra.db.ColumnFamily
Returns true if this contains no columns or deletion info
isEmpty() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isEmpty() - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayFilter
 
isEmpty() - Method in class org.apache.cassandra.db.composites.AbstractComposite
 
isEmpty() - Method in interface org.apache.cassandra.db.composites.Composite
 
isEmpty() - Method in class org.apache.cassandra.db.composites.CompositesBuilder
Checks if this builder is empty.
isEmpty() - Method in class org.apache.cassandra.db.Mutation
 
isEmpty() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
isEmpty(AbstractBounds.Boundary<T>, AbstractBounds.Boundary<T>) - Static method in class org.apache.cassandra.dht.AbstractBounds
 
isEmpty() - Method in class org.apache.cassandra.streaming.StreamPlan
 
isEmpty() - Method in class org.apache.cassandra.utils.BiMultiValMap
 
isEmpty(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
 
isEmpty() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
isEmpty() - Method in class org.apache.cassandra.utils.concurrent.Accumulator
 
isEmpty() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
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
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.AbstractType
Returns true for types where empty should be handled like null like Int32Type.
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.BooleanType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.DateType
Deprecated.
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.DecimalType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.DoubleType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.FloatType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.InetAddressType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.Int32Type
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.IntegerType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.LongType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.ReversedType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.TimestampType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.UUIDType
 
isEnabled() - Method in class org.apache.cassandra.cache.CachingOptions.KeyCache
 
isEnabled() - Method in class org.apache.cassandra.cache.CachingOptions.RowCache
 
isEnabled() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
isEnabled() - Method in class org.apache.cassandra.gms.Gossiper
 
isEncryptedChannel(InetAddress) - Static method in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
isEnd() - Method in enum org.apache.cassandra.cql3.statements.Bound
 
isEOF() - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
 
isEOF() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
isEOF() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
isEQ() - Method in class org.apache.cassandra.cql3.Relation
Checks if the operator of this relation is a EQ.
isEQ() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
 
isEQ() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQ
 
isEQ() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQ
 
ISerializer<T> - Interface in org.apache.cassandra.io
 
isExactMatch() - Method in enum org.apache.cassandra.cql3.AssignmentTestable.TestResult
 
isExhausted() - Method in class org.apache.cassandra.service.pager.NamesQueryPager
 
isExhausted() - Method in interface org.apache.cassandra.service.pager.QueryPager
Whether or not this pager is exhausted, i.e.
isExistingRole(RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
isExistingRole(RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
Return true is a Role with the given name exists in the system.
isExpired() - Method in class org.apache.cassandra.db.Memtable
 
isFailed() - Method in class org.apache.cassandra.streaming.SessionInfo
 
isFailed() - Method in class org.apache.cassandra.tools.NodeProbe
 
isFailureCallback() - Method in class org.apache.cassandra.net.CallbackInfo
 
isFailureResponse() - Method in class org.apache.cassandra.net.MessageIn
 
isFilterFullyCoveredBy(IDiskAtomFilter, ColumnFamily, long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isForOutgoing - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
 
isFrozen() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
isFrozenCollection() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isFullRowSlice(SliceQueryFilter) - Static method in class org.apache.cassandra.db.DataRange
 
isFullyCoveredBy(ColumnFamily, long) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
Whether the provided cf, that is assumed to contain the head of the partition, contains enough data to cover this filter.
isFullyCoveredBy(ColumnFamily, long) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
isFullyCoveredBy(ColumnFamily, long) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
isFullyRefused() - Method in class org.apache.cassandra.service.paxos.ProposeCallback
 
isGcAble(int) - Method in class org.apache.cassandra.db.DeletionTime
 
isGlobal() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
isGlobal() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
isGlobal - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
isGossipOnlyMember(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
isGossipRunning() - Method in class org.apache.cassandra.service.StorageService
 
isGossipRunning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isGossipRunning() - Method in class org.apache.cassandra.tools.NodeProbe
 
isHandoffEnabled() - Method in class org.apache.cassandra.tools.NodeProbe
 
isHeadFilter() - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
 
isHeadFilter() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
isHeadFilter() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
isIN() - Method in class org.apache.cassandra.cql3.Relation
Checks if the operator of this relation is a IN.
isIN() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.IN
 
isIN() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
 
isIN() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IN
 
isInBounds(T, Iterable<Bounds<T>>) - Static method in class org.apache.cassandra.dht.Bounds
 
isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
 
isInclusive(Bound) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Checks if the specified bound is inclusive or not.
isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
 
isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
 
isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.Slice
 
isIncremental - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
 
isIncremental() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
isIncremental - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
isIncremental - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
 
isIncremental() - Method in class org.apache.cassandra.streaming.StreamSession
 
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
 
isIncrementalBackupsEnabled() - Method in class org.apache.cassandra.tools.NodeProbe
 
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.SystemKeyspace
 
isIndexed() - Method in class org.apache.cassandra.config.ColumnDefinition
 
isIndexed() - Method in class org.apache.cassandra.db.RowIndexEntry
 
isIndexEntryStale(ByteBuffer, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
isIndexNameValid(String) - Static method in class org.apache.cassandra.config.CFMetaData
 
isInitialized() - Method in class org.apache.cassandra.service.StorageService
 
isInitialized() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isInitialized() - Method in class org.apache.cassandra.tools.NodeProbe
 
isInLocalDCOnly() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
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.AtomicBTreeColumns
 
isInsertReversed() - Method in class org.apache.cassandra.db.ColumnFamily
Returns if this map only support inserts in reverse order.
isInShadowRound() - Method in class org.apache.cassandra.gms.Gossiper
 
isInShutdownHook() - Method in class org.apache.cassandra.service.StorageService
 
isInterestedIn(String) - Method in class org.apache.cassandra.tools.BootstrapMonitor
 
isInterestedIn(String) - Method in class org.apache.cassandra.tools.RepairRunner
 
isInterestedIn(String) - Method in class org.apache.cassandra.utils.progress.jmx.JMXNotificationProgressListener
 
isInternal - Variable in class org.apache.cassandra.service.ClientState
 
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
 
isJson - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
 
isKeyCacheEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isKeyRange() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the query request a range of partition keys.
isKeyspaceLevel() - Method in class org.apache.cassandra.auth.DataResource
 
isKnownEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
isLatencyForSnitch() - Method in class org.apache.cassandra.net.AsyncOneResponse
 
isLatencyForSnitch() - Method in interface org.apache.cassandra.net.IAsyncCallback
 
isLatencyForSnitch() - Method in class org.apache.cassandra.repair.AnticompactionTask.AnticompactionCallback
 
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.paxos.AbstractPaxosCallback
 
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() - Method in class org.apache.cassandra.io.sstable.format.Version
 
isLeaving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
isListening() - Method in class org.apache.cassandra.net.MessagingService
 
isLive() - Method in class org.apache.cassandra.db.AbstractCell
 
isLive(long) - Method in class org.apache.cassandra.db.AbstractCell
 
isLive() - Method in class org.apache.cassandra.db.BufferDeletedCell
 
isLive(long) - Method in class org.apache.cassandra.db.BufferDeletedCell
 
isLive() - Method in class org.apache.cassandra.db.BufferExpiringCell
 
isLive(long) - Method in class org.apache.cassandra.db.BufferExpiringCell
 
isLive() - Method in interface org.apache.cassandra.db.Cell
 
isLive(long) - Method in interface org.apache.cassandra.db.Cell
 
isLive() - Method in class org.apache.cassandra.db.DeletionInfo
Returns whether this DeletionInfo is live, that is deletes no columns.
isLive() - Method in class org.apache.cassandra.db.DeletionTime
Returns whether this DeletionTime is live, that is deletes no columns.
isLive() - Method in class org.apache.cassandra.db.Memtable
 
isLive() - Method in class org.apache.cassandra.db.NativeDeletedCell
 
isLive(long) - Method in class org.apache.cassandra.db.NativeDeletedCell
 
isLive() - Method in class org.apache.cassandra.db.NativeExpiringCell
 
isLive(long) - Method in class org.apache.cassandra.db.NativeExpiringCell
 
isLive() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
 
isLocal(InetAddress) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
isLocal() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
isLocalId() - Method in class org.apache.cassandra.utils.CounterId
 
isMap() - Method in class org.apache.cassandra.db.marshal.CollectionType
Checks if this collection is Map.
isMarkedCompacted() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
isMarkedForDelete() - Method in class org.apache.cassandra.db.ColumnFamily
 
isMarkedSuspect() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
isMember(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
isMemoryLockable() - Method in interface org.apache.cassandra.service.NativeAccessMBean
 
isMinimum() - Method in class org.apache.cassandra.db.DecoratedKey
 
isMinimum() - Method in interface org.apache.cassandra.db.RowPosition
 
isMinimum() - Method in interface org.apache.cassandra.dht.RingPosition
 
isMinimum() - Method in class org.apache.cassandra.dht.Token
 
isMinimum() - 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.DefaultInteger
 
isMoving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
isMultiCell() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isMultiCell() - Method in class org.apache.cassandra.db.marshal.ListType
 
isMultiCell() - Method in class org.apache.cassandra.db.marshal.MapType
 
isMultiCell() - Method in class org.apache.cassandra.db.marshal.SetType
 
isMultiColumn() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
isMultiColumn() - Method in class org.apache.cassandra.cql3.Relation
Checks if this relation apply to multiple columns.
isMultiColumn() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
 
isMultiColumn() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
 
isNameValid(String) - Static method in class org.apache.cassandra.config.CFMetaData
 
isNative() - Method in interface org.apache.cassandra.cql3.functions.Function
Checks whether the function is a native/hard coded one or not.
isNative() - Method in class org.apache.cassandra.cql3.functions.NativeFunction
 
isNative() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
isNative() - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
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
 
isNonCompositeSliceWithExclusiveBounds() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
isNotReturningAnyRows(CFMetaData, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQ
 
isNotReturningAnyRows(CFMetaData, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
 
isNotReturningAnyRows(CFMetaData, QueryOptions) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Checks if this restriction will prevent the query to return any rows.
isNotReturningAnyRows(CFMetaData, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQ
 
isNotReturningAnyRows(CFMetaData, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
 
isNotReturningAnyRows(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the query will never return any rows.
isNullOrEmpty(AbstractType<?>, ByteBuffer) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
 
isObsolete(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
indicates if the reader has been marked for obsoletion
isOffline() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
isOnAllComponents() - Method in class org.apache.cassandra.config.ColumnDefinition
 
isOnToken() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
 
isOnToken() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
isOpen() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
isOpen() - Method in class org.apache.cassandra.thrift.TCustomSocket
Checks whether the socket is connected.
isOutgoingConnected() - Method in class org.apache.cassandra.streaming.ConnectionHandler
 
isOverflowed() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
isPaging - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
isPartitionKey() - Method in class org.apache.cassandra.config.ColumnDefinition
 
isPartOfCellName() - Method in class org.apache.cassandra.config.ColumnDefinition
Whether the name of this definition is serialized in the cell nane, i.e.
isPrefix(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
isPrefixOf(CType, Composite) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
isPrefixOf(CType, Composite) - Method in class org.apache.cassandra.db.composites.AbstractComposite
 
isPrefixOf(CType, Composite) - Method in interface org.apache.cassandra.db.composites.Composite
 
isPresent(IFilter.FilterKey) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
 
isPresent(IFilter.FilterKey) - Method in class org.apache.cassandra.utils.BloomFilter
 
isPresent(IFilter.FilterKey) - Method in interface org.apache.cassandra.utils.IFilter
 
isPrimaryKeyColumn() - Method in class org.apache.cassandra.config.ColumnDefinition
 
isPrimaryRange() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
isPurged() - Method in class org.apache.cassandra.config.CFMetaData
 
isQueryable() - Method in class org.apache.cassandra.db.index.SecondaryIndex
Checks if the index is ready.
isReadyForBootstrap() - Static method in class org.apache.cassandra.service.MigrationManager
 
isReceiving() - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
isRegular() - Method in class org.apache.cassandra.config.ColumnDefinition
 
isRemote() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
isRepaired() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
isReplaced() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
isReplacing() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isReplacingSameAddress() - Static method in class org.apache.cassandra.service.StorageService
 
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
 
isReversed() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isReversed() - Method in class org.apache.cassandra.db.marshal.ReversedType
 
isReversed() - Method in class org.apache.cassandra.service.pager.RangeNamesQueryPager
 
isReversed() - Method in class org.apache.cassandra.service.pager.RangeSliceQueryPager
 
isReversed() - Method in class org.apache.cassandra.service.pager.SliceQueryPager
 
isReversedType() - Method in class org.apache.cassandra.cql3.ColumnSpecification
 
isRootLevel() - Method in class org.apache.cassandra.auth.DataResource
 
isRowCacheEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isRpcReady() - Method in class org.apache.cassandra.gms.EndpointState
 
isRpcReady(InetAddress) - Method in class org.apache.cassandra.service.StorageService
 
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
 
isSafeForBootstrap(InetAddress, Map<InetAddress, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
Check if this endpoint can safely bootstrap into the cluster.
isSameCQL3RowAs(CellNameType, CellName) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
isSameCQL3RowAs(CellNameType, CellName) - Method in interface org.apache.cassandra.db.composites.CellName
Whether this cell is part of the same CQL3 row as the other cell.
isSameCQL3RowAs(CellNameType, CellName) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellName
 
isSameCQL3RowAs(CellNameType, CellName) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
 
isSameCQL3RowAs(CellNameType, CellName) - Method in class org.apache.cassandra.db.composites.SimpleDenseCellName
 
isSameCQL3RowAs(CellNameType, CellName) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
 
isSatisfiedBy(DecoratedKey, ColumnFamily, Composite, ByteBuffer) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
 
isSatisfiedBy(DecoratedKey, ColumnFamily, Composite, ByteBuffer) - Method in class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
 
isSatisfiedByValue(ByteBuffer, Cell, AbstractType<?>, Operator, long) - Method in class org.apache.cassandra.cql3.ColumnCondition.Bound
 
isSecondaryIndex() - Method in class org.apache.cassandra.config.CFMetaData
The '.' char is the only way to identify if the CFMetadata is for a secondary index
isSerialConsistency() - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
isSet() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
 
isSetupCompleted() - Method in class org.apache.cassandra.service.StorageService
 
isShutdown() - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
isShutdown() - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
 
isShuttingDown() - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
 
isSignaled() - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
 
isSignalled() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
 
isSilentShutdownState(EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
 
isSimpleSelectorFactory(int) - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Checks if this factory creates Selectors that simply return the specified column.
isSlice() - Method in class org.apache.cassandra.cql3.Relation
Checks if the operator of this relation is a Slice (GT, GTE, LTE, LT).
isSlice() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
 
isSlice() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
 
isSlice() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
 
isSlice() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.Slice
 
isSnapshotBeforeCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
ISSTableScanner - Interface in org.apache.cassandra.io.sstable
An ISSTableScanner is an abstraction allowing multiple SSTableScanners to be chained together under the hood.
ISSTableSerializer<T> - Interface in org.apache.cassandra.io
 
isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
 
isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
 
isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKey
 
isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKeyAndValue
 
isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionValue
 
isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
 
isStale(CompositesIndex.IndexedEntry, ColumnFamily, long) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
 
isStart() - Method in enum org.apache.cassandra.cql3.statements.Bound
 
isStarting() - Method in class org.apache.cassandra.service.StorageService
 
isStarting() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns whether the storage service is starting or not
isStarting() - Method in class org.apache.cassandra.tools.NodeProbe
 
isStatic() - Method in class org.apache.cassandra.config.ColumnDefinition
 
isStatic() - Method in class org.apache.cassandra.db.AbstractNativeCell
 
isStatic() - Method in class org.apache.cassandra.db.composites.AbstractComposite
 
isStatic() - Method in class org.apache.cassandra.db.composites.BoundedComposite
 
isStatic() - Method in interface org.apache.cassandra.db.composites.Composite
 
isStatic() - Method in class org.apache.cassandra.db.composites.CompoundComposite
 
isStaticName(ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.CompositeType
 
isStillAllocating() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
isStopRequested() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
 
isSubDirectory(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
isSubrangeRepair() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
isSuccess() - Method in class org.apache.cassandra.streaming.StreamSession
Return if this session completed successfully.
isSuccessful() - Method in class org.apache.cassandra.service.paxos.ProposeCallback
 
issue() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
Issues (seals) the barrier, meaning no new operations may be issued against it, and expires the current Group.
isSufficientLiveNodes(Keyspace, 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(RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
isSuper(RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
Return true if there exists a Role with the given name that also has superuser status.
isSuper() - Method in class org.apache.cassandra.config.CFMetaData
 
isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQ
 
isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.IN
 
isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
Check if this type of restriction is supported for by the specified index.
isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
 
isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
 
isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQ
 
isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IN
 
isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
Check if this type of restriction is supported by the specified index.
isSupportedBy(SecondaryIndex) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
 
isSupportedBy(CassandraVersion) - Method in class org.apache.cassandra.utils.CassandraVersion
 
isSuspect - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
isSystem() - Method in class org.apache.cassandra.auth.AuthenticatedUser
Some internal operations are performed on behalf of Cassandra itself, in those cases the system user should be used where an identity is required see CreateRoleStatement#execute() and overrides of SchemaAlteringStatement#grantPermissionsToCreator()
isTableLevel() - Method in class org.apache.cassandra.auth.DataResource
 
isTemporary - Variable in enum org.apache.cassandra.io.sstable.Descriptor.Type
 
isTerminated() - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
isTerminated() - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
 
isThriftCompatible() - Method in class org.apache.cassandra.config.CFMetaData
Returns whether this CFMetaData can be returned to thrift.
isThriftCompatible() - Method in class org.apache.cassandra.config.ColumnDefinition
 
isThriftServerRunning() - Method in class org.apache.cassandra.tools.NodeProbe
 
isTimestampSet() - Method in class org.apache.cassandra.cql3.Attributes
 
isTimestampSet() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
isTimeToLiveSet() - Method in class org.apache.cassandra.cql3.Attributes
 
isTraced() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
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
 
isTTLSelectorFactory() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Checks if this factory creates TTL selectors instances.
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(InetAddress) - Method in class org.apache.cassandra.db.BatchlogManager.EndpointFilter
 
isValid() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isValid(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
isValueCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.AbstractType
Returns true if values of the other AbstractType can be read and "reasonably" interpreted by the this AbstractType.
isValueCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
isValueCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.CollectionType
A version of isValueCompatibleWith() to deal with non-multicell (frozen) collections
isValueCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.ListType
 
isValueCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.MapType
 
isValueCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.SetType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.AbstractType
Needed to handle ReversedType in value-compatibility checks.
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.BytesType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.CollectionType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.DateType
Deprecated.
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.LongType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TimestampType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TimeType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TupleType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
isVersion2x() - Static method in class org.apache.cassandra.hadoop.HadoopCompat
True if runtime Hadoop version is 2.x, false otherwise.
isWellFormed(Object[], Comparator<? extends Object>) - Static method in class org.apache.cassandra.utils.btree.BTree
 
isWildcard() - Method in class org.apache.cassandra.cql3.selection.Selection
 
isWindows() - Static method in class org.apache.cassandra.utils.FBUtilities
 
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() - Method in class org.apache.cassandra.db.DataRange
 
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.selection.Selectable.WritetimeOrTTL
 
isWritetimeSelectorFactory() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Checks if this factory creates writetime selectors instances.
iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
iterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ColumnFamily
Returns an iterator over the columns of this map that returns only the matching @param slices.
iterator() - Method in class org.apache.cassandra.db.ColumnFamily
 
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.RangeTombstoneList
 
iterator(Composite, Composite) - Method in class org.apache.cassandra.db.RangeTombstoneList
 
iterator(DecoratedKey, SortedSet<CellName>) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
 
iterator(FileDataInput, DecoratedKey, SortedSet<CellName>, RowIndexEntry) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
 
iterator(DecoratedKey, ColumnSlice[], boolean) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
 
iterator(FileDataInput, DecoratedKey, ColumnSlice[], boolean, RowIndexEntry) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
 
iterator - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
iterator(DecoratedKey, SortedSet<CellName>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
iterator(FileDataInput, DecoratedKey, SortedSet<CellName>, RowIndexEntry) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
iterator(DecoratedKey, ColumnSlice[], boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
iterator(FileDataInput, DecoratedKey, ColumnSlice[], boolean, RowIndexEntry) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
iterator(long) - Method in class org.apache.cassandra.io.util.SegmentedFile
 
iterator() - Method in class org.apache.cassandra.locator.PendingRangeMaps
 
iterator() - Method in class org.apache.cassandra.tools.nodetool.SetHostStat
 
iterator() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
iterator() - Method in class org.apache.cassandra.utils.concurrent.Accumulator
 
iterator() - Method in class org.apache.cassandra.utils.concurrent.Refs
 
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.
ITrigger - Interface in org.apache.cassandra.triggers
Trigger interface, For every Mutation received by the coordinator ITrigger.augment(ByteBuffer, ColumnFamily) is called.
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.cql3.CqlLexer
 
J - Static variable in class org.apache.cassandra.cql3.CqlParser
 
JavaSourceUDFFactory - Class in org.apache.cassandra.cql3.functions
Java source UDF code generation.
JavaSourceUDFFactory() - Constructor for class org.apache.cassandra.cql3.functions.JavaSourceUDFFactory
 
javaTypes(DataType[], boolean) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
Construct an array containing the Java classes for the given Java Driver DataTypes.
JavaUtils - Class in org.apache.cassandra.utils
Utility method to retrieve information about the JRE.
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
 
jmxEnabledStages() - Static method in enum org.apache.cassandra.concurrent.Stage
 
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
 
JMXNotificationProgressListener - Class in org.apache.cassandra.utils.progress.jmx
JMXNotificationProgressListener uses JMX Notification API to convert JMX Notification message to progress event and notifies its ProgressListeners.
JMXNotificationProgressListener() - Constructor for class org.apache.cassandra.utils.progress.jmx.JMXNotificationProgressListener
 
JMXProgressSupport - Class in org.apache.cassandra.utils.progress.jmx
ProgressListener that translates ProgressEvent to JMX Notification message.
JMXProgressSupport(NotificationBroadcasterSupport) - Constructor for class org.apache.cassandra.utils.progress.jmx.JMXProgressSupport
 
jnaAvailable() - Static method in class org.apache.cassandra.utils.CLibrary
 
jnaMemoryLockable() - Static method in class org.apache.cassandra.utils.CLibrary
 
JOB_THREADS_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
Join - Class in org.apache.cassandra.tools.nodetool
 
Join() - Constructor for class org.apache.cassandra.tools.nodetool.Join
 
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
 
Json - Class in org.apache.cassandra.cql3
Term-related classes for INSERT JSON support.
Json() - Constructor for class org.apache.cassandra.cql3.Json
 
json(Object) - Static method in class org.apache.cassandra.utils.FBUtilities
 
Json.Literal - Class in org.apache.cassandra.cql3
Represents a literal JSON string in an INSERT JSON statement.
Json.Marker - Class in org.apache.cassandra.cql3
Represents a marker for a JSON string in an INSERT JSON statement.
Json.Prepared - Class in org.apache.cassandra.cql3
A prepared, full set of JSON values.
Json.Raw - Interface in org.apache.cassandra.cql3
 
JSON_COLUMN_ID - Static variable in class org.apache.cassandra.cql3.Json
 
JSON_OBJECT_MAPPER - Static variable in class org.apache.cassandra.cql3.Json
 
jsonInsertStatement(CFName) - Method in class org.apache.cassandra.cql3.CqlParser
 
jsonValue() - Method in class org.apache.cassandra.cql3.CqlParser
 
JVMStabilityInspector - Class in org.apache.cassandra.utils
Responsible for deciding whether to kill the JVM if it gets in an "unstable" state (think OOM).
JVMStabilityInspector.Killer - Class in org.apache.cassandra.utils
 

K

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.cql3.CqlLexer
 
K_ADD - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_AGGREGATE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_AGGREGATE - 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.cql3.CqlLexer
 
K_ALTER - Static variable in class org.apache.cassandra.cql3.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.cql3.CqlLexer
 
K_APPLY - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_AS - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_AS - 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.cql3.CqlLexer
 
K_BATCH - Static variable in class org.apache.cassandra.cql3.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_CALLED - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_CALLED - 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.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_CONTAINS - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_CONTAINS - Static variable in class org.apache.cassandra.cql3.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.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_DATE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_DATE - 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.cql3.CqlLexer
 
K_DELETE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_DESC - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_DESC - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_DESCRIBE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_DESCRIBE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_DISTINCT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_DISTINCT - 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.cql3.CqlLexer
 
K_DROP - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_ENTRIES - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_ENTRIES - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_EXECUTE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_EXECUTE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_EXISTS - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_EXISTS - 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_FINALFUNC - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_FINALFUNC - Static variable in class org.apache.cassandra.cql3.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.cql3.CqlLexer
 
K_FROM - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_FROZEN - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_FROZEN - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_FULL - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_FULL - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_FUNCTION - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_FUNCTION - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_FUNCTIONS - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_FUNCTIONS - 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_IF - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_IF - Static variable in class org.apache.cassandra.cql3.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.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_INFINITY - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_INFINITY - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_INITCOND - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_INITCOND - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_INPUT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_INPUT - Static variable in class org.apache.cassandra.cql3.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.cql3.CqlLexer
 
K_INTO - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_JSON - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_JSON - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_KEY - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_KEY - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_KEYS - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_KEYS - Static variable in class org.apache.cassandra.cql3.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_LANGUAGE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_LANGUAGE - Static variable in class org.apache.cassandra.cql3.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_LOGIN - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_LOGIN - 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_NAN - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_NAN - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_NOLOGIN - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_NOLOGIN - 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_NOT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_NOT - 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.cql3.CqlLexer
 
K_ON - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_OPTIONS - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_OPTIONS - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_OR - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_OR - 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.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_REPLACE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_REPLACE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_RETURNS - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_RETURNS - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_REVOKE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_REVOKE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_ROLE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_ROLE - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_ROLES - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_ROLES - Static variable in class org.apache.cassandra.cql3.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.cql3.CqlLexer
 
K_SET - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_SFUNC - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_SFUNC - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_SMALLINT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_SMALLINT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_STATIC - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_STATIC - 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_STYPE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_STYPE - 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_TIME - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_TIME - Static variable in class org.apache.cassandra.cql3.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_TINYINT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_TINYINT - 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_TRIGGER - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_TRIGGER - Static variable in class org.apache.cassandra.cql3.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.cql3.CqlLexer
 
K_TTL - Static variable in class org.apache.cassandra.cql3.CqlParser
 
K_TUPLE - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
K_TUPLE - Static variable in class org.apache.cassandra.cql3.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.cql3.CqlLexer
 
K_UPDATE - Static variable in class org.apache.cassandra.cql3.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.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.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.cql3.CqlLexer
 
K_WHERE - Static variable in class org.apache.cassandra.cql3.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
 
keepSSTableLevel - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
 
keepSSTableLevel() - Method in class org.apache.cassandra.streaming.StreamSession
 
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.db.compaction.AbstractCompactedRow
 
key() - Method in class org.apache.cassandra.db.CounterMutation
 
key - Variable in class org.apache.cassandra.db.filter.QueryFilter
 
key() - Method in interface org.apache.cassandra.db.IMutation
 
key() - Method in class org.apache.cassandra.db.Mutation
 
key - Variable in class org.apache.cassandra.db.ReadCommand
 
key - Variable in class org.apache.cassandra.db.Row
 
key - Variable in class org.apache.cassandra.service.AbstractRowResolver
 
key() - Method in class org.apache.cassandra.service.pager.NamesQueryPager
 
key() - Method in interface org.apache.cassandra.service.pager.SinglePartitionPager
 
key() - Method in class org.apache.cassandra.service.pager.SliceQueryPager
 
key - Variable in class org.apache.cassandra.service.paxos.Commit
 
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_in_mb - Variable in class org.apache.cassandra.config.Config
 
keyCache - Variable in class org.apache.cassandra.cache.CachingOptions
 
KeyCache(CachingOptions.KeyCache.Type) - Constructor for class org.apache.cassandra.cache.CachingOptions.KeyCache
 
keyCache - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
keyCache - Variable in class org.apache.cassandra.service.CacheService
 
keyCacheHit - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
keyCacheHitRate - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Key cache hit rate for this CF
KeyCacheKey - Class in org.apache.cassandra.cache
 
KeyCacheKey(Pair<String, String>, Descriptor, ByteBuffer) - Constructor for class org.apache.cassandra.cache.KeyCacheKey
 
keyCacheRequest - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
KeyCacheSerializer() - Constructor for class org.apache.cassandra.service.CacheService.KeyCacheSerializer
 
keyComparator - Static variable in class org.apache.cassandra.db.index.SecondaryIndex
 
keyCount - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
keyIsInRelation() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the restrictions on the partition key is an IN restriction.
keyIterator() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
keyIterator() - Method in interface org.apache.cassandra.cache.ICache
 
keyIterator() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
keyIterator() - Method in class org.apache.cassandra.cache.SerializingCache
 
KeyIterator - Class in org.apache.cassandra.io.sstable
 
KeyIterator(Descriptor) - Constructor for class org.apache.cassandra.io.sstable.KeyIterator
 
keyRange - Variable in class org.apache.cassandra.db.AbstractRangeCommand
 
keyRange - Variable in class org.apache.cassandra.db.DataRange
 
keyRange() - Method in class org.apache.cassandra.db.DataRange
 
keys - Variable in class org.apache.cassandra.serializers.MapSerializer
 
KEYS_ONLY - Static variable in class org.apache.cassandra.cache.CachingOptions
 
keySamples(Range<Token>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
keysAndValuesOf(ColumnIdentifier.Raw) - Static method in class org.apache.cassandra.cql3.statements.IndexTarget.Raw
 
KeyScanningIterator() - Constructor for class org.apache.cassandra.io.sstable.format.big.BigTableScanner.KeyScanningIterator
 
keySet() - Method in class org.apache.cassandra.utils.BiMultiValMap
 
keySet() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
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.
KeysIndex() - Constructor for class org.apache.cassandra.db.index.keys.KeysIndex
 
keysOf(ColumnIdentifier.Raw) - Static method in class org.apache.cassandra.cql3.statements.IndexTarget.Raw
 
keyspace(String) - Static method in class org.apache.cassandra.auth.DataResource
Creates a DataResource representing a keyspace.
keyspace(String) - Static method in class org.apache.cassandra.auth.FunctionResource
Creates a FunctionResource representing the collection of functions scoped to a specific keyspace.
keyspace() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
keyspace - Variable in class org.apache.cassandra.cql3.functions.FunctionName
 
keyspace() - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
 
keyspace() - Method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
 
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.CreateTypeStatement
 
keyspace() - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
 
keyspace() - Method in class org.apache.cassandra.cql3.statements.DropTypeStatement
 
keyspace() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
keyspace() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
keyspace - Variable in class org.apache.cassandra.db.AbstractRangeCommand
 
keyspace - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
Keyspace - Class in org.apache.cassandra.db
It represents a Keyspace.
keyspace - Variable in class org.apache.cassandra.db.marshal.UserType
 
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.CassandraStorage
Deprecated.
 
keyspace - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
keyspace - Variable in class org.apache.cassandra.repair.RepairJobDesc
 
keyspace - Variable in class org.apache.cassandra.repair.RepairSession
 
keyspace - Variable in class org.apache.cassandra.repair.RepairSessionResult
 
keyspace - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
keyspace - Variable in class org.apache.cassandra.streaming.StreamRequest
 
keyspace - Variable in class org.apache.cassandra.transport.Event.SchemaChange
 
keyspace - Variable in class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
 
KeyspaceMetrics - Class in org.apache.cassandra.metrics
Metrics for ColumnFamilyStore.
KeyspaceMetrics(Keyspace) - Constructor for class org.apache.cassandra.metrics.KeyspaceMetrics
Creates metrics for given ColumnFamilyStore.
keyspaceName() - Method in class org.apache.cassandra.cql3.CqlParser
 
keyspaceName - Variable in class org.apache.cassandra.service.AbstractRowResolver
 
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.schema.LegacySchemaTables
 
keyspaceTransformer - Static variable in class org.apache.cassandra.db.Keyspace
 
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 - Static variable in class org.apache.cassandra.thrift.SSLTransportFactory
 
keystore_password - Variable in class org.apache.cassandra.config.EncryptionOptions
 
KEYSTORE_PASSWORD - Static variable in class org.apache.cassandra.thrift.SSLTransportFactory
 
keyValidator(AbstractType<?>) - Method in class org.apache.cassandra.config.CFMetaData
 
keywords - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
keywords - Static variable in class org.apache.cassandra.cql3.statements.IndexPropDefs
 
keywords - Static variable in class org.apache.cassandra.cql3.statements.KSPropDefs
 
killCurrentJVM(Throwable, boolean) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
 
killCurrentJVM(Throwable) - Method in class org.apache.cassandra.utils.JVMStabilityInspector.Killer
Certain situations represent "Die" conditions for the server, and if so, the reason is logged and the current JVM is killed.
killCurrentJVM(Throwable, boolean) - Method in class org.apache.cassandra.utils.JVMStabilityInspector.Killer
 
Killer() - Constructor for class org.apache.cassandra.utils.JVMStabilityInspector.Killer
 
kind - Variable in class org.apache.cassandra.config.ColumnDefinition
 
kind() - Method in class org.apache.cassandra.db.DecoratedKey
 
kind - Variable in class org.apache.cassandra.db.marshal.CollectionType
 
kind() - Method in interface 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
 
ksAndCFBytes - Variable in class org.apache.cassandra.config.CFMetaData
 
ksAndCFName - Variable in class org.apache.cassandra.cache.CacheKey
 
ksAndCFName - Variable in class org.apache.cassandra.config.CFMetaData
 
KSMetaData - Class in org.apache.cassandra.config
 
KSMetaData(String, Class<? extends AbstractReplicationStrategy>, Map<String, String>, boolean) - Constructor for class org.apache.cassandra.config.KSMetaData
 
KSMetaData(String, Class<? extends AbstractReplicationStrategy>, Map<String, String>, boolean, Iterable<CFMetaData>) - Constructor for class org.apache.cassandra.config.KSMetaData
 
ksName - Variable in class org.apache.cassandra.config.CFMetaData
 
ksName - Variable in class org.apache.cassandra.cql3.ColumnSpecification
 
ksName(KeyspaceElementName) - Method in class org.apache.cassandra.cql3.CqlParser
 
ksName - Variable in class org.apache.cassandra.db.ReadCommand
 
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.statements
 
KSPropDefs() - Constructor for class org.apache.cassandra.cql3.statements.KSPropDefs
 
KW_BF_FP_CHANCE - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
KW_CACHING - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
KW_COMMENT - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
KW_COMPACTION - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
KW_COMPRESSION - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
KW_DCLOCALREADREPAIRCHANCE - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
KW_DEFAULT_TIME_TO_LIVE - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
KW_DURABLE_WRITES - Static variable in class org.apache.cassandra.cql3.statements.KSPropDefs
 
KW_GCGRACESECONDS - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
KW_ID - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
KW_MAX_INDEX_INTERVAL - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
KW_MAXCOMPACTIONTHRESHOLD - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
KW_MEMTABLE_FLUSH_PERIOD - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
KW_MIN_INDEX_INTERVAL - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
KW_MINCOMPACTIONTHRESHOLD - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
KW_OPTIONS - Static variable in class org.apache.cassandra.cql3.statements.IndexPropDefs
 
KW_READREPAIRCHANCE - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
KW_REPLICATION - Static variable in class org.apache.cassandra.cql3.statements.KSPropDefs
 
KW_SPECULATIVE_RETRY - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 

L

L - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
L - Static variable in class org.apache.cassandra.cql3.CqlParser
 
LANDMARK_RESET_INTERVAL_IN_MS - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
language - Variable in class org.apache.cassandra.cql3.functions.UDFunction
 
language() - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
LARGE_MESSAGE_THRESHOLD - Static variable in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
largeMessageCompletedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
Completed tasks for large message TCP Connections
largeMessageDroppedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
Dropped tasks for large message TCP Connections
largeMessagePendingTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
Pending tasks for large message TCP Connections
largeMessages - Variable in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
last - Variable in class org.apache.cassandra.io.sstable.SSTable
 
last() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
lastCounted(ColumnFamily) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
 
lastCounted() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
lastFlushOffset - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
lastIndexOf(ByteBuffer, byte, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
ByteBuffer adaptation of org.apache.commons.lang3.ArrayUtils.lastIndexOf method
lastKey - Variable in class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
 
lastLive() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
lastName - Variable in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
LastReplayPosition(ReplayPosition) - Constructor for class org.apache.cassandra.db.Memtable.LastReplayPosition
 
lastSyncedAt - Variable in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
 
lastTombstones() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
lastWriteFuture - Variable in class org.apache.cassandra.transport.SimpleClient
 
latch - Variable in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
 
latency - Variable in class org.apache.cassandra.metrics.LatencyMetrics
Latency
LatencyMetrics - Class in org.apache.cassandra.metrics
Metrics about latencies
LatencyMetrics(String, String) - Constructor for class org.apache.cassandra.metrics.LatencyMetrics
Create LatencyMetrics with given group, type, and scope.
LatencyMetrics(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.
LatencyMetrics(MetricNameFactory, String, LatencyMetrics...) - Constructor for class org.apache.cassandra.metrics.LatencyMetrics
Create LatencyMetrics with given group, type, prefix to append to each metric name, and scope.
latestVersion - Static variable in class org.apache.cassandra.io.sstable.format.big.BigFormat
 
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 OnDiskAtomIterator>) - Constructor for class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
LazilyCompactedRow.Reducer - Class in org.apache.cassandra.db.compaction
 
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
 
leftBoundary() - Method in class org.apache.cassandra.dht.AbstractBounds
 
LEGACY_CREDENTIALS_TABLE - Static variable in class org.apache.cassandra.auth.PasswordAuthenticator
 
LEGACY_LENGTH - Static variable in class org.apache.cassandra.transport.Frame.Header
 
LEGACY_USERS_TABLE - Static variable in class org.apache.cassandra.auth.CassandraRoleManager
 
legacyAuthenticate(Map<String, String>) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
legacyAuthenticate(Map<String, String>) - Method in interface org.apache.cassandra.auth.IAuthenticator
For implementations which support the Thrift login method that accepts arbitrary key/value pairs containing credentials data.
legacyAuthenticate(Map<String, String>) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
LegacyJMXProgressSupport - Class in org.apache.cassandra.utils.progress.jmx
ProgressListener that translates ProgressEvent to legacy JMX Notification message (backward compatibility support)
LegacyJMXProgressSupport(NotificationBroadcasterSupport, ObjectName) - Constructor for class org.apache.cassandra.utils.progress.jmx.LegacyJMXProgressSupport
 
LegacyMetadataSerializer - Class in org.apache.cassandra.io.sstable.metadata
Deprecated.
LegacyMetadataSerializer() - Constructor for class org.apache.cassandra.io.sstable.metadata.LegacyMetadataSerializer
Deprecated.
 
LegacySchemaTables - Class in org.apache.cassandra.schema
system.schema_* tables used to store keyspace/table/type attributes prior to C* 3.0
LegacySchemaTables() - Constructor for class org.apache.cassandra.schema.LegacySchemaTables
 
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.MemoryInputStream
 
length() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
length() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
length - Variable in class org.apache.cassandra.io.util.SegmentedFile
 
length() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
LENGTH - Static variable in class org.apache.cassandra.utils.CounterId
 
length() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
length() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
 
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.cql3.CqlLexer
 
LETTER - Static variable in class org.apache.cassandra.cql3.CqlParser
 
level - Variable in class org.apache.cassandra.db.compaction.LeveledManifest.CompactionCandidate
 
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, LifecycleTransaction, int, int, long, boolean) - Constructor for class org.apache.cassandra.db.compaction.LeveledCompactionTask
 
LeveledManifest - Class in org.apache.cassandra.db.compaction
 
LeveledManifest.CompactionCandidate - Class in org.apache.cassandra.db.compaction
 
LexicalUUIDType - Class in org.apache.cassandra.db.marshal
 
LifecycleTransaction - Class in org.apache.cassandra.db.lifecycle
 
LifecycleTransaction.ReaderState - Class in org.apache.cassandra.db.lifecycle
 
LifecycleTransaction.ReaderState.Action - Enum in org.apache.cassandra.db.lifecycle
 
limit() - Method in class org.apache.cassandra.db.AbstractRangeCommand
 
limit - Variable in class org.apache.cassandra.db.PagedRangeCommand
 
limit() - Method in class org.apache.cassandra.db.PagedRangeCommand
 
limit() - Method in class org.apache.cassandra.db.RangeSliceCommand
 
limit - Variable in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
 
limiter - Variable in class org.apache.cassandra.streaming.StreamWriter
 
limitForQuery - Variable in class org.apache.cassandra.service.pager.Pageable.ReadCommands
 
list(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
list(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
list(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
Returns a list of permissions on a resource granted to a role.
list(CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
list() - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
listen() - Method in class org.apache.cassandra.net.MessagingService
 
listen() - Method in class org.apache.cassandra.thrift.TCustomServerSocket
 
listen_address - Variable in class org.apache.cassandra.config.Config
 
listen_interface - Variable in class org.apache.cassandra.config.Config
 
listen_interface_prefer_ipv6 - Variable in class org.apache.cassandra.config.Config
 
listen_on_broadcast_address - Variable in class org.apache.cassandra.config.Config
 
listenBacklog - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
 
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.
listeners(StreamEventHandler, StreamEventHandler...) - Method in class org.apache.cassandra.streaming.StreamPlan
 
listEphemeralSnapshots() - Method in class org.apache.cassandra.db.Directories
 
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, RoleName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
listRolesStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
ListRolesStatement - Class in org.apache.cassandra.cql3.statements
 
ListRolesStatement() - Constructor for class org.apache.cassandra.cql3.statements.ListRolesStatement
 
ListRolesStatement(RoleName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.ListRolesStatement
 
Lists - Class in org.apache.cassandra.cql3
Static helper methods and classes for lists.
Lists.Appender - Class in org.apache.cassandra.cql3
 
Lists.DelayedValue - Class in org.apache.cassandra.cql3
Basically similar to a Value, but with some non-pure function (that need to be evaluated at execution time) in it.
Lists.Discarder - Class in org.apache.cassandra.cql3
 
Lists.DiscarderByIndex - Class in org.apache.cassandra.cql3
 
Lists.Literal - Class in org.apache.cassandra.cql3
 
Lists.Marker - Class in org.apache.cassandra.cql3
A marker for List values and IN relations
Lists.Prepender - Class in org.apache.cassandra.cql3
 
Lists.Setter - Class in org.apache.cassandra.cql3
 
Lists.SetterByIndex - Class in org.apache.cassandra.cql3
 
Lists.Value - Class in org.apache.cassandra.cql3
 
ListSerializer<T> - Class in org.apache.cassandra.serializers
 
ListSnapshots - Class in org.apache.cassandra.tools.nodetool
 
ListSnapshots() - Constructor for class org.apache.cassandra.tools.nodetool.ListSnapshots
 
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
 
Literal(String) - Constructor for class org.apache.cassandra.cql3.Json.Literal
 
Literal(List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.Lists.Literal
 
Literal(List<Pair<Term.Raw, Term.Raw>>) - Constructor for class org.apache.cassandra.cql3.Maps.Literal
 
Literal(List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.Sets.Literal
 
Literal(List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.Tuples.Literal
 
Literal(Map<ColumnIdentifier, Term.Raw>) - Constructor for class org.apache.cassandra.cql3.UserTypes.Literal
 
live() - Static method in class org.apache.cassandra.db.DeletionInfo
Returns a new DeletionInfo that has no top-level tombstone or any range tombstones.
LIVE - Static variable in class org.apache.cassandra.db.DeletionTime
A special DeletionTime that signifies that there is no top-level (row) tombstone.
live - Variable in class org.apache.cassandra.db.filter.ColumnCounter
 
live() - Method in class org.apache.cassandra.db.filter.ColumnCounter
 
liveCQL3RowCount(long) - Method in class org.apache.cassandra.db.ColumnFamily
 
liveDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Disk space used by SSTables belonging to this CF
liveDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Disk space used by SSTables belonging to this CF
liveMemtables - Variable in class org.apache.cassandra.db.lifecycle.View
ordinarily a list of size 1, but when preparing to flush will contain both the memtable we will flush and the new replacement memtable, until all outstanding write operations on the old table complete.
liveScannedHistogram - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Live cells scanned in queries on this CF
liveScannedHistogram - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Live cells scanned in queries on this Keyspace
liveSSTableCount - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Number of SSTables on disk for this CF
load(Collection<KSMetaData>) - Method in class org.apache.cassandra.config.Schema
Load up non-system keyspaces
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
 
LoadBroadcaster - Class in org.apache.cassandra.service
 
loadClass(String) - Method in class org.apache.cassandra.triggers.CustomClassLoader
 
loadClassInternal(String) - Method in class org.apache.cassandra.triggers.CustomClassLoader
 
loadConfig() - Method in interface org.apache.cassandra.config.ConfigurationLoader
Loads a Config object to use to configure a node.
loadConfig() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
loadConfig() - Method in class org.apache.cassandra.config.YamlConfigurationLoader
 
loadConfig(URL) - Method in class org.apache.cassandra.config.YamlConfigurationLoader
 
loadDcRackInfo() - Static method in class org.apache.cassandra.db.SystemKeyspace
Return a map of IP addresses containing a map of dc and rack info
loader - Variable in class org.apache.cassandra.hadoop.BulkRecordWriter
Deprecated.
 
loader - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
loadFromDisk() - Method in class org.apache.cassandra.config.Schema
load keyspace (keyspace) definitions, but do not initialize the keyspace instances.
loadFromDisk(boolean) - Method in class org.apache.cassandra.config.Schema
Load schema definitions from disk.
loadHostIds() - Static method in class org.apache.cassandra.db.SystemKeyspace
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
 
loadPaxosState(ByteBuffer, CFMetaData, long) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
loadSaved() - Method in class org.apache.cassandra.cache.AutoSavingCache
 
loadSavedAsync() - Method in class org.apache.cassandra.cache.AutoSavingCache
 
loadSignature - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
loadSignature - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
loadsstables - Variable in class org.apache.cassandra.db.lifecycle.Tracker
 
loadSummary(SegmentedFile.Builder, SegmentedFile.Builder) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Load index summary from Summary.db file if it exists.
loadTokens() - Static method in class org.apache.cassandra.db.SystemKeyspace
Return a map of stored tokens to IP addresses
loadTriggerInstance(String) - Method in class org.apache.cassandra.triggers.TriggerExecutor
 
LOCAL - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
LocalAwareExecutorService - Interface in org.apache.cassandra.concurrent
 
LocalByPartionerType - Class in org.apache.cassandra.db.marshal
for sorting columns representing row keys in the row ordering as determined by a partitioner.
LocalByPartionerType(IPartitioner) - Constructor for class org.apache.cassandra.db.marshal.LocalByPartionerType
 
localCopy(ColumnFamily, AbstractAllocator) - Static method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
localCopy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.BufferCell
 
localCopy(CFMetaData, MemtableAllocator, OpOrder.Group) - Method in class org.apache.cassandra.db.BufferCell
 
localCopy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.BufferCounterCell
 
localCopy(CFMetaData, MemtableAllocator, OpOrder.Group) - Method in class org.apache.cassandra.db.BufferCounterCell
 
localCopy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.BufferCounterUpdateCell
 
localCopy(CFMetaData, MemtableAllocator, OpOrder.Group) - Method in class org.apache.cassandra.db.BufferCounterUpdateCell
 
localCopy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.BufferDeletedCell
 
localCopy(CFMetaData, MemtableAllocator, OpOrder.Group) - Method in class org.apache.cassandra.db.BufferDeletedCell
 
localCopy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.BufferExpiringCell
 
localCopy(CFMetaData, MemtableAllocator, OpOrder.Group) - Method in class org.apache.cassandra.db.BufferExpiringCell
 
localCopy(CFMetaData, AbstractAllocator) - Method in interface org.apache.cassandra.db.Cell
 
localCopy(CFMetaData, MemtableAllocator, OpOrder.Group) - Method in interface org.apache.cassandra.db.Cell
 
localCopy(CFMetaData, AbstractAllocator) - Method in interface org.apache.cassandra.db.CounterCell
 
localCopy(CFMetaData, MemtableAllocator, OpOrder.Group) - Method in interface org.apache.cassandra.db.CounterCell
 
localCopy(CFMetaData, AbstractAllocator) - Method in interface org.apache.cassandra.db.DeletedCell
 
localCopy(CFMetaData, MemtableAllocator, OpOrder.Group) - Method in interface org.apache.cassandra.db.DeletedCell
 
localCopy(CFMetaData, AbstractAllocator) - Method in interface org.apache.cassandra.db.ExpiringCell
 
localCopy(CFMetaData, MemtableAllocator, OpOrder.Group) - Method in interface org.apache.cassandra.db.ExpiringCell
 
localCopy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.NativeCell
 
localCopy(CFMetaData, MemtableAllocator, OpOrder.Group) - Method in class org.apache.cassandra.db.NativeCell
 
localCopy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.NativeCounterCell
 
localCopy(CFMetaData, MemtableAllocator, OpOrder.Group) - Method in class org.apache.cassandra.db.NativeCounterCell
 
localCopy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.NativeDeletedCell
 
localCopy(CFMetaData, MemtableAllocator, OpOrder.Group) - Method in class org.apache.cassandra.db.NativeDeletedCell
 
localCopy(CFMetaData, AbstractAllocator) - Method in class org.apache.cassandra.db.NativeExpiringCell
 
localCopy(CFMetaData, MemtableAllocator, OpOrder.Group) - Method in class org.apache.cassandra.db.NativeExpiringCell
 
localDeletionTime - Variable in class org.apache.cassandra.cql3.UpdateParameters
 
localDeletionTime - Variable in class org.apache.cassandra.db.DeletionTime
The local server timestamp, in seconds since the unix epoch, at which this tombstone was created.
localPager(Pageable) - Static method in class org.apache.cassandra.service.pager.QueryPagers
 
LocalPartitioner - Class in org.apache.cassandra.dht
 
LocalPartitioner(AbstractType<?>) - Constructor for class org.apache.cassandra.dht.LocalPartitioner
 
LocalPartitioner.LocalToken - Class in org.apache.cassandra.dht
 
LocalStrategy - Class in org.apache.cassandra.locator
 
LocalStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.LocalStrategy
 
LocalSyncTask - Class in org.apache.cassandra.repair
LocalSyncTask performs streaming between local(coordinator) node and remote replica.
LocalSyncTask(RepairJobDesc, TreeResponse, TreeResponse, long) - Constructor for class org.apache.cassandra.repair.LocalSyncTask
 
LocalToken(ByteBuffer) - Constructor for class org.apache.cassandra.dht.LocalPartitioner.LocalToken
 
location - Variable in class org.apache.cassandra.db.commitlog.CommitLog
 
location - Variable in class org.apache.cassandra.db.Directories.DataDirectory
 
Locks - Class in org.apache.cassandra.utils.concurrent
 
Locks() - Constructor for class org.apache.cassandra.utils.concurrent.Locks
 
log(Config) - Static method in class org.apache.cassandra.config.Config
 
log() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
 
log(Logger) - Method in class org.apache.cassandra.utils.EstimatedHistogram
log.trace() every record in the histogram
log(Logger, NoSpamLogger.Level, long, TimeUnit, String, Object...) - Static method in class org.apache.cassandra.utils.NoSpamLogger
 
log(Logger, NoSpamLogger.Level, long, TimeUnit, long, String, Object...) - Static method in class org.apache.cassandra.utils.NoSpamLogger
 
log(NoSpamLogger.Level, String, long, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
log(NoSpamLogger.Level, long, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
 
log() - Static method in class org.apache.cassandra.utils.StatusLogger
 
logAndCheckIfShouldSkip(File, CommitLogDescriptor) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
logBuffer - Variable in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
 
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 interface org.apache.cassandra.cql3.CQL3Type
 
logger - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
 
logger - Static variable in class org.apache.cassandra.cql3.functions.UDAggregate
 
logger - Static variable in class org.apache.cassandra.cql3.functions.UDFunction
 
logger - Static variable in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
logger - Static variable in class org.apache.cassandra.db.compaction.CompactionTask
 
logger - Static variable in class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
 
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.locator.CloudstackSnitch
 
logger - Static variable in class org.apache.cassandra.locator.Ec2Snitch
 
logger - Static variable in class org.apache.cassandra.locator.GoogleCloudSnitch
 
logger - Static variable in class org.apache.cassandra.service.AbstractRowResolver
 
logger - Static variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
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.transport.Message
 
logger - Variable in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
 
logger - Static variable in class org.apache.cassandra.utils.CoalescingStrategies
 
logHeapHistogram() - Static method in class org.apache.cassandra.utils.HeapUtils
Generates a HEAP dump in the directory specified by the HeapDumpPath JVM option or in the CASSANDRA_HOME directory.
login(String, String, Cassandra.Client) - Static method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Deprecated.
 
login(AuthenticatedUser) - Method in class org.apache.cassandra.service.ClientState
Attempts to login the given user.
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.format.SSTableReader
 
LogOutput() - Constructor for class org.apache.cassandra.utils.OutputHandler.LogOutput
 
logStackTrace - Variable in exception org.apache.cassandra.exceptions.ConfigurationException
 
LongSerializer - Class in org.apache.cassandra.serializers
 
LongSerializer() - Constructor for class org.apache.cassandra.serializers.LongSerializer
 
LongToken(long) - Constructor for class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
LongType - Class in org.apache.cassandra.db.marshal
 
lower(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
lowerBound - Variable in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
LZ4Compressor - Class in org.apache.cassandra.io.compress
 

M

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.cql3.CqlLexer
 
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.NodeTool
 
main(String[]) - Static method in class org.apache.cassandra.tools.SSTableExpiredBlockers
 
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.SSTableLevelResetter
 
main(String[]) - Static method in class org.apache.cassandra.tools.SSTableMetadataViewer
 
main(String[]) - Static method in class org.apache.cassandra.tools.SSTableOfflineRelevel
 
main(String[]) - Static method in class org.apache.cassandra.tools.SSTableRepairedAtSetter
 
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.tools.StandaloneVerifier
 
main(String[]) - Static method in class org.apache.cassandra.transport.Client
 
major - Variable in class org.apache.cassandra.utils.CassandraVersion
 
MajorLeveledCompactionWriter - Class in org.apache.cassandra.db.compaction.writers
 
MajorLeveledCompactionWriter(ColumnFamilyStore, LifecycleTransaction, Set<SSTableReader>, long, boolean, OperationType) - Constructor for class org.apache.cassandra.db.compaction.writers.MajorLeveledCompactionWriter
 
make(Object...) - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
make(Object...) - Method in class org.apache.cassandra.db.composites.AbstractCType
 
make(Object...) - Method in interface org.apache.cassandra.db.composites.CType
Convenience method to build composites from their component.
makeArgSpec(String, String, Function, int) - Static method in class org.apache.cassandra.cql3.functions.Functions
 
makeCellName(Object...) - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
makeCellName(ByteBuffer[]) - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
makeCellName(ByteBuffer[]) - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
 
makeCellName(ByteBuffer[]) - Method in class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
 
makeCellName(Object...) - Method in interface org.apache.cassandra.db.composites.CellNameType
Convenience method to create cell names given its components.
makeCollectionReceiver(ColumnSpecification, boolean) - Method in enum org.apache.cassandra.db.marshal.CollectionType.Kind
 
makeCollectionReceiver(ColumnSpecification, boolean) - Method in class org.apache.cassandra.db.marshal.CollectionType
 
makeColumn(CellName, ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
makeCounter(CellName, long) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
makeCountFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.AggregateFcts
Creates a COUNT function for the specified type.
makeCreateAggregateMutation(KSMetaData, UDAggregate, long) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
makeCreateFunctionMutation(KSMetaData, UDFunction, long) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
makeCreateKeyspaceMutation(KSMetaData, long) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
makeCreateTableMutation(KSMetaData, CFMetaData, long) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
makeCreateTypeMutation(KSMetaData, UserType, long) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
makeCType(CompoundCType, AbstractType<?>, ColumnToCollectionType) - Static method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
makeDataRequests(Iterable<InetAddress>) - Method in class org.apache.cassandra.service.AbstractReadExecutor
 
makeDenseCQL3RowBuilder(long) - Static method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
makeDigestRequests(Iterable<InetAddress>) - Method in class org.apache.cassandra.service.AbstractReadExecutor
 
makeDropAggregateMutation(KSMetaData, UDAggregate, long) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
makeDropFunctionMutation(KSMetaData, UDFunction, long) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
makeDropKeyspaceMutation(KSMetaData, long) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
makeDropTableMutation(KSMetaData, CFMetaData, long) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
makeExtendedFilter(AbstractBounds<RowPosition>, SliceQueryFilter, Composite, Composite, List<IndexExpression>, int, boolean, long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Allows generic range paging with the slice column filter.
makeExtendedFilter(AbstractBounds<RowPosition>, IDiskAtomFilter, List<IndexExpression>, int, boolean, boolean, long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
makeFromBlobFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.BytesConversionFcts
 
makeIndexColumnName(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
makeIndexColumnName(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
 
makeIndexColumnName(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.keys.KeysIndex
 
makeIndexColumnPrefix(ByteBuffer, Composite) - Method in class org.apache.cassandra.db.index.composites.CompositesIndex
 
makeIndexColumnPrefix(ByteBuffer, Composite) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexIncludingCollectionKey
 
makeIndexColumnPrefix(ByteBuffer, Composite) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
 
makeIndexColumnPrefix(ByteBuffer, Composite) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionValue
 
makeIndexColumnPrefix(ByteBuffer, Composite) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnPartitionKey
 
makeIndexColumnPrefix(ByteBuffer, Composite) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnRegular
 
makeMaxFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.AggregateFcts
Creates a MAX function for the specified type.
makeMinFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.AggregateFcts
Creates a MIN function for the specified type.
makeMutation() - Method in class org.apache.cassandra.service.paxos.Commit
 
makeMutationMessage() - Method in class org.apache.cassandra.db.CounterMutation
 
makeRangeTombstone(ColumnSlice) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
makeRawAbstractType(AbstractType<?>, AbstractType<?>) - Static method in class org.apache.cassandra.config.CFMetaData
 
makeRowBounds(Token, Token) - Static method in class org.apache.cassandra.dht.Bounds
Compute a bounds of keys corresponding to a given bounds of token.
makeRowRange(Token, Token) - Static method in class org.apache.cassandra.dht.Range
Compute a range of keys corresponding to a given range of token.
makeRowRange(Range<Token>) - Static method in class org.apache.cassandra.dht.Range
 
makeSparseCQL3RowBuilder(CFMetaData, CellNameType, long) - Static method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
makeToBlobFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.BytesConversionFcts
 
makeTombstone(CellName) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
makeTombstoneForOverwrite(ColumnSlice) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
makeUpdatedType(UserType) - Method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
 
makeUpdateParameters(Collection<ByteBuffer>, Composite, QueryOptions, boolean, long) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
makeUpdates(ColumnFamily) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
 
makeUpdates(ColumnFamily) - Method in interface org.apache.cassandra.service.CASRequest
The updates to perform of a CAS success.
makeUpdateTableMutation(KSMetaData, CFMetaData, CFMetaData, long) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
makeWith(ByteBuffer[], int, Composite.EOC, boolean) - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
 
makeWith(ByteBuffer[], int, Composite.EOC, boolean) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellNameType
 
makeWith(ByteBuffer[], int, Composite.EOC, boolean) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
makeWith(ByteBuffer[], int, Composite.EOC, boolean) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType.WithCollection
 
manages(String) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManager
 
map(CQL3Type.Raw, CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
map - Variable in class org.apache.cassandra.cql3.Maps.Value
 
map(FileChannel.MapMode, long, long) - Method in class org.apache.cassandra.io.util.ChannelProxy
 
mapLiteral() - Method in class org.apache.cassandra.cql3.CqlParser
 
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.DiscarderByKey - Class in org.apache.cassandra.cql3
 
Maps.Literal - Class in org.apache.cassandra.cql3
 
Maps.Marker - Class in org.apache.cassandra.cql3
 
Maps.Putter - Class in org.apache.cassandra.cql3
 
Maps.Setter - Class in org.apache.cassandra.cql3
 
Maps.SetterByKey - Class in org.apache.cassandra.cql3
 
Maps.Value - Class in org.apache.cassandra.cql3
 
MapSerializer<K,V> - Class in org.apache.cassandra.serializers
 
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.format.big.BigTableWriter
 
mark() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
mark() - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
 
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.RandomAccessReader
 
mark() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
mark() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
 
mark() - Method in class org.apache.cassandra.metrics.RestorableMeter
Mark the occurrence of an event.
mark(long) - Method in class org.apache.cassandra.metrics.RestorableMeter
Mark the occurrence of a given number of events.
markAllCompacting(OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
markAsShutdown(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
This method is used to mark a node as shutdown; that is it gracefully exited on its own and told us about it
markBlocking() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
Mark all prior operations as blocking, potentially signalling them to more aggressively make progress
markClean(UUID, ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
Marks the ColumnFamily specified by cfId as clean for this log segment.
markDataSynced(long) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
markDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
 
markedForDeleteAt - Variable in class org.apache.cassandra.db.DeletionTime
A timestamp (typically in microseconds since the unix epoch, although this is not enforced) after which data should be considered deleted.
markedPointer - Variable in class org.apache.cassandra.io.util.RandomAccessReader
 
Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Constants.Marker
 
Marker(int) - Constructor for class org.apache.cassandra.cql3.Json.Marker
 
Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Lists.Marker
 
Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Maps.Marker
 
marker - Variable in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InWithMarker
 
marker - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InWithMarker
 
Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Sets.Marker
 
Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Tuples.Marker
 
marker - Variable in enum org.apache.cassandra.io.sstable.Descriptor.Type
 
markerForTuple() - Method in class org.apache.cassandra.cql3.CqlParser
 
markFlushing(Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
markIndexSynced(long) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
markLocalToBeCleared() - Method in class org.apache.cassandra.db.BufferCounterCell
 
markLocalToBeCleared(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Mark context to delete local references afterward.
markLocalToBeCleared() - Method in interface org.apache.cassandra.db.CounterCell
 
markLocalToBeCleared() - Method in class org.apache.cassandra.db.NativeCounterCell
 
markObsolete(Collection<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
markObsolete(Tracker) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Mark the sstable as obsolete, i.e., compacted into newer sstables.
markSSTablesRepairing(UUID, UUID) - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
Mark sstables repairing - either all sstables or only the unrepaired ones depending on whether this is an incremental or full repair
markSupported() - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
 
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.NIODataInputStream
 
markSuspect() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
MarshalException - Exception in org.apache.cassandra.serializers
 
MarshalException(String) - Constructor for exception org.apache.cassandra.serializers.MarshalException
 
MarshalException(String, Throwable) - Constructor for exception org.apache.cassandra.serializers.MarshalException
 
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_COALESCED_MESSAGES - Static variable in class org.apache.cassandra.net.OutboundTcpConnection
 
MAX_DELETION_TIME - Static variable in class org.apache.cassandra.db.BufferExpiringCell
 
MAX_ELEMENTS - Static variable in class org.apache.cassandra.db.marshal.CollectionType
 
MAX_FAILED_HOSTS - Static variable in class org.apache.cassandra.hadoop.BulkRecordWriter
Deprecated.
 
MAX_FAILED_HOSTS - Static variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
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_JOB_THREADS - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
MAX_NAME_LENGTH - Static variable in interface org.apache.cassandra.db.Cell
 
MAX_SEGMENT_SIZE - Static variable in class org.apache.cassandra.io.util.MmappedSegmentedFile
 
MAX_SSTABLE_AGE_KEY - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
Deprecated.
max_streaming_retries - Variable in class org.apache.cassandra.config.Config
Deprecated.
retry support removed on CASSANDRA-10992
MAX_TTL - Static variable in interface org.apache.cassandra.db.ExpiringCell
 
MAX_UNSIGNED_SHORT - Static variable in class org.apache.cassandra.utils.FBUtilities
 
MAX_WINDOW_SIZE_KEY - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
maxAge - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
maxBucketsPerElement(long) - Static method in class org.apache.cassandra.utils.BloomCalculations
Calculates the maximum number of buckets per element that this implementation can support.
maxBytesForLevel(int, long) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
 
maxColumnNames - Variable in class org.apache.cassandra.io.sstable.ColumnStats
 
maxColumnNames - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
maxColumnNames - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
maxColumnNameSeen - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow.Reducer
 
maxColumns() - Method in class org.apache.cassandra.db.filter.ExtendedFilter
 
maxCompactionThreshold(int) - Method in class org.apache.cassandra.config.CFMetaData
 
maxComponents(List<ByteBuffer>, Composite, CellNameType) - Static method in class org.apache.cassandra.io.sstable.ColumnNameHelper
finds the max cell name component(s) Note that this method *can modify maxSeen*.
maxDataAge - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
maxDataAge is a timestamp in local server time (e.g.
maxDataAge - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
maxFailures - Variable in class org.apache.cassandra.hadoop.BulkRecordWriter
Deprecated.
 
maxFailures - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
MAXIMUM - Static variable in class org.apache.cassandra.dht.Murmur3Partitioner
 
MAXIMUM - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 
MAXIMUM_EXPIRATION_DATE_EXCEEDED_REJECT_MESSAGE - Static variable in class org.apache.cassandra.cql3.Attributes
 
MAXIMUM_EXPIRATION_DATE_EXCEEDED_WARNING - Static variable in class org.apache.cassandra.cql3.Attributes
 
maxIndexInterval(int) - Method in class org.apache.cassandra.config.CFMetaData
 
MaxIntTracker(int) - Constructor for class org.apache.cassandra.io.sstable.ColumnStats.MaxIntTracker
 
maxKeyBound() - Method in class org.apache.cassandra.dht.Token
 
maxLeft(AbstractBounds.Boundary<T>, T, boolean) - Static method in class org.apache.cassandra.dht.AbstractBounds
 
maxLeft(AbstractBounds.Boundary<T>, AbstractBounds.Boundary<T>) - Static method in class org.apache.cassandra.dht.AbstractBounds
 
maxLocalDeletionTime - Variable in class org.apache.cassandra.io.sstable.ColumnStats
 
maxLocalDeletionTime - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
maxLocalDeletionTime - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
MaxLongTracker(long) - Constructor for class org.apache.cassandra.io.sstable.ColumnStats.MaxLongTracker
 
maxMarkedAt() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
maxOrdering() - Static method in class org.apache.cassandra.utils.Interval
 
maxPoolSize - Variable in class org.apache.cassandra.metrics.SEPMetrics
Maximum number of threads before it will start queuing tasks
maxPoolSize - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
Maximum number of threads before it will start queuing tasks
maxRemaining() - Method in class org.apache.cassandra.service.pager.NamesQueryPager
 
maxRemaining() - Method in interface org.apache.cassandra.service.pager.QueryPager
The maximum number of cells/CQL3 row that we may still have to return.
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
maxRowTombstone - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
maxsize() - Method in class org.apache.cassandra.utils.MerkleTree
 
maxsize(long) - Method in class org.apache.cassandra.utils.MerkleTree
 
maxSSTableAge - Variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
Deprecated.
maxSSTableBytes - Variable in class org.apache.cassandra.db.compaction.LeveledManifest.CompactionCandidate
 
MaxSSTableSizeWriter - Class in org.apache.cassandra.db.compaction.writers
 
MaxSSTableSizeWriter(ColumnFamilyStore, LifecycleTransaction, Set<SSTableReader>, long, int, boolean, OperationType) - Constructor for class org.apache.cassandra.db.compaction.writers.MaxSSTableSizeWriter
 
maxTimestamp() - Method in class org.apache.cassandra.db.AbstractNativeCell
 
maxTimestamp() - Method in class org.apache.cassandra.db.ColumnFamily
 
maxTimestamp() - Method in class org.apache.cassandra.db.DeletionInfo
Returns the maximum timestamp in any of the range tombstones or the top-level tombstone.
maxTimestamp - Variable in class org.apache.cassandra.io.sstable.ColumnStats
 
maxTimestamp - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
maxTimestamp - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
maxTimestampComparator - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
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.TimeFcts
 
maxWindowSize - Variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
maxWorkers - Variable in class org.apache.cassandra.concurrent.SEPExecutor
 
maybeAddEntry(DecoratedKey, long) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
maybeAddEntry(DecoratedKey, long, long, long) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
maybeAddLatency(IAsyncCallback, InetAddress, long) - Method in class org.apache.cassandra.net.MessagingService
Track latency information for the dynamic snitch
maybeAppendColumn(Cell, DeletionInfo.InOrderTester, int) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
Adds a cell, assuming that: - it's non-gc-able (if a tombstone) or not a tombstone - it has a more recent timestamp than any partition/range tombstone shadowing it - it sorts *strictly after* the current-last cell in the array.
maybeAppendColumn(Cell, DeletionInfo.InOrderTester, int) - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
maybeAppendColumn(Cell, DeletionInfo.InOrderTester, int) - Method in class org.apache.cassandra.db.ColumnFamily
Adds a cell if it's non-gc-able and isn't shadowed by a partition/range tombstone with a higher timestamp.
maybeApplyExpirationDateOverflowPolicy(CFMetaData, int, boolean) - Static method in class org.apache.cassandra.cql3.Attributes
 
maybeArchive(CommitLogSegment) - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
maybeArchive(String, String) - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
Differs from the above because it can be used on any file, rather than only managed commit log segments (and thus cannot call waitForFinalSync).
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(IResource, ClientState) - Static method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
maybeExecuteImmediately(Runnable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
maybeExecuteImmediately(Runnable) - Method in interface org.apache.cassandra.concurrent.LocalAwareExecutorService
 
maybeExecuteImmediately(Runnable) - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
maybeFail(Throwable) - Static method in class org.apache.cassandra.utils.Throwables
 
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.lifecycle.Tracker
 
maybeInitializeLocalState(int) - Method in class org.apache.cassandra.gms.Gossiper
 
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.
maybeReloadCompactionStrategy(CFMetaData) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
maybeRepair(CFMetaData, Descriptor, IndexSummary, SegmentedFile.Builder, SegmentedFile.Builder) - Static method in class org.apache.cassandra.io.util.MmappedSegmentedFile
 
maybeResetTraceSessionWrapper(Runnable) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
maybeRestoreArchive() - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
maybeSnapshot(UUID, UUID) - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
maybeTrim(Row) - Method in class org.apache.cassandra.db.ReadCommand
 
maybeTrim(Row) - Method in class org.apache.cassandra.db.SliceFromReadCommand
 
maybeTryAdditionalReplicas() - Method in class org.apache.cassandra.service.AbstractReadExecutor
Perform additional requests if it looks like the original will time out.
maybeUpdateRowCache(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
maybeWaitForArchiving(String) - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
maybeWaitForSync(CommitLogSegment.Allocation) - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
 
maybeWriteEmptyRowHeader() - Method in class org.apache.cassandra.db.ColumnIndex.Builder
 
mayContainDataBefore(ReplayPosition) - Method in class org.apache.cassandra.db.Memtable
 
mayModify(DeletionInfo) - Method in class org.apache.cassandra.db.DeletionInfo
Whether this deletion info may modify the provided one if added to it.
mayNeedPaging(Pageable, int) - Static method in class org.apache.cassandra.service.pager.QueryPagers
 
maySelectPrefix(CType, Composite) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
 
maySelectPrefix(CType, Composite) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
maySelectPrefix(CType, Composite) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
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.gms.Gossiper
 
MBEAN_NAME - Static variable in class org.apache.cassandra.io.sstable.IndexSummaryManager
 
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.GCInspector
 
MBEAN_NAME - Static variable in class org.apache.cassandra.service.StorageProxy
 
MBEAN_OBJECT_NAME - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
 
mBOOLEAN() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mC() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mCOMMENT() - Method in class org.apache.cassandra.cql3.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.
mDIGIT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mean() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
MEAN_LIFETIME_IN_S - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
meanRate() - Method in class org.apache.cassandra.metrics.RestorableMeter
Returns the mean rate of events per second since this object was created.
meanRowSize - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Size of the smallest compacted row
measure(Object) - Static method in class org.apache.cassandra.utils.ObjectSizes
 
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
 
Memory(Memory) - Constructor for class org.apache.cassandra.io.util.Memory
 
memory_allocator - Variable in class org.apache.cassandra.config.Config
Deprecated.
MemoryInputStream - Class in org.apache.cassandra.io.util
 
MemoryInputStream(Memory) - Constructor for class org.apache.cassandra.io.util.MemoryInputStream
 
MemoryMappedSegment - Class in org.apache.cassandra.db.commitlog
 
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
 
MemoryUtil - Class in org.apache.cassandra.utils.memory
 
MemoryUtil() - Constructor for class org.apache.cassandra.utils.memory.MemoryUtil
 
Memtable - Class in org.apache.cassandra.db
 
Memtable(AtomicReference<ReplayPosition>, ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.Memtable
 
Memtable(CFMetaData) - Constructor for class org.apache.cassandra.db.Memtable
 
Memtable.LastReplayPosition - Class in org.apache.cassandra.db
 
memtable_allocation_type - Variable in class org.apache.cassandra.config.Config
 
memtable_cleanup_threshold - Variable in class org.apache.cassandra.config.Config
 
memtable_flush_writers - Variable in class org.apache.cassandra.config.Config
 
memtable_heap_space_in_mb - Variable in class org.apache.cassandra.config.Config
 
memtable_offheap_space_in_mb - Variable in class org.apache.cassandra.config.Config
 
MemtableAllocator - Class in org.apache.cassandra.utils.memory
 
MemtableAllocator.DataReclaimer - Interface in org.apache.cassandra.utils.memory
 
MemtableAllocator.SubAllocator - Class in org.apache.cassandra.utils.memory
Mark the BB as unused, permitting it to be reclaimed
MemtableBufferAllocator - Class in org.apache.cassandra.utils.memory
 
MemtableBufferAllocator(MemtableAllocator.SubAllocator, MemtableAllocator.SubAllocator) - Constructor for class org.apache.cassandra.utils.memory.MemtableBufferAllocator
 
memtableColumnsCount - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Total number of columns present in the memtable.
memtableColumnsCount - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Total number of columns present in the memtable.
memtableFlushPeriod(int) - Method in class org.apache.cassandra.config.CFMetaData
 
memtableLiveDataSize - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Total amount of live data stored in the memtable, excluding any data structure overhead
memtableLiveDataSize - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Total amount of live data stored in the memtable, excluding any data structure overhead
memtableOffHeapDataSize - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Total amount of data stored in the memtable that resides off-heap, including column related overhead and overwritten rows.
memtableOffHeapSize - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Total amount of data stored in the memtable that resides off-heap, including column related overhead and overwritten rows.
memtableOnHeapDataSize - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Total amount of data stored in the memtable that resides on-heap, including column related overhead and overwritten rows.
memtableOnHeapSize - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Total amount of data stored in the memtable that resides on-heap, including column related overhead and overwritten rows.
MemtablePool - Class in org.apache.cassandra.utils.memory
Represents an amount of memory used for a given purpose, that can be allocated to specific tasks through child MemtableAllocator objects.
MemtablePool.SubPool - Class in org.apache.cassandra.utils.memory
Note the difference between acquire() and allocate(); allocate() makes more resources available to all owners, and acquire() makes shared resources unavailable but still recorded.
MemtableRenewedNotification - Class in org.apache.cassandra.notifications
 
MemtableRenewedNotification(Memtable) - Constructor for class org.apache.cassandra.notifications.MemtableRenewedNotification
 
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.
memtableSwitchCount - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Number of times flush has resulted in the memtable being switched out.
merge(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Return a context w/ an aggregated count for each counter id.
merge(StreamingHistogram) - Method in class org.apache.cassandra.utils.StreamingHistogram
Merges given histogram with this histogram.
merge(Throwable, Throwable) - Static method in class org.apache.cassandra.utils.Throwables
 
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 Iterator<In>>, MergeIterator.Reducer<In, Out>) - Constructor for class org.apache.cassandra.utils.MergeIterator
 
MergeIterator.Candidate<In> - Class in org.apache.cassandra.utils
 
MergeIterator.Reducer<In,Out> - Class in org.apache.cassandra.utils
Accumulator that collects values of type A, and outputs a value of type B.
mergeMax(List<ByteBuffer>, List<ByteBuffer>, CellNameType) - Static method in class org.apache.cassandra.io.sstable.ColumnNameHelper
Merge 2 lists of max cell name components.
mergeMin(List<ByteBuffer>, List<ByteBuffer>, CellNameType) - Static method in class org.apache.cassandra.io.sstable.ColumnNameHelper
Merge 2 lists of min cell name components.
merger - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
mergeSchema(Collection<Mutation>) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
Merge remote schema in form of mutations with local and mutate ks/cf metadata objects (which also involves fs operations on add/drop ks/cf)
mergeSchema(Collection<Mutation>, boolean) - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
mergeTombstoneHistogram(StreamingHistogram) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
mergeWith(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
 
mergeWith(Restriction) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Merges this restriction with the specified one.
mergeWith(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
 
mergeWith(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
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.RowHash - Class in org.apache.cassandra.utils
Hash value representing a row, to be used to pass hashes to the MerkleTree.
MerkleTree.TreeDifference - Class in org.apache.cassandra.utils
 
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.
MerkleTreeSerializer() - Constructor for class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
 
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.ExceptionHandler - Class in org.apache.cassandra.transport
 
Message.ProtocolDecoder - Class in org.apache.cassandra.transport
 
Message.ProtocolEncoder - Class in org.apache.cassandra.transport
 
Message.Request - Class in org.apache.cassandra.transport
 
Message.Response - Class in org.apache.cassandra.transport
 
Message.Type - Enum in org.apache.cassandra.transport
 
MessageDeliveryTask - Class in org.apache.cassandra.net
 
MessageDeliveryTask(MessageIn, int, long, boolean) - 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(StreamMessage) - Method in class org.apache.cassandra.streaming.StreamSession
 
messageType - Variable in class org.apache.cassandra.repair.messages.RepairMessage
 
MessagingService - Class in org.apache.cassandra.net
 
MessagingService.SocketThread - 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.ResultSet
 
metadata() - Method in class org.apache.cassandra.cql3.UntypedResultSet
 
metadata - Variable in class org.apache.cassandra.cql3.UpdateParameters
 
metadata - Variable in class org.apache.cassandra.db.ColumnFamily
 
metadata() - Method in class org.apache.cassandra.db.ColumnFamily
 
metadata - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
metadata - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
metadata - Variable in class org.apache.cassandra.io.sstable.SSTable
 
metadata - Variable in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
 
metadata(String, long) - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile.Builder
 
metadata - Variable in class org.apache.cassandra.io.util.CompressedSegmentedFile
 
metadata - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
Describes the variables to be bound in the prepared statement
metadataCollector - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
MetadataCollector - Class in org.apache.cassandra.io.sstable.metadata
 
MetadataCollector(CellNameType) - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
MetadataCollector(Iterable<SSTableReader>, CellNameType, int, boolean) - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
MetadataCollector(Iterable<SSTableReader>, CellNameType, int) - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
MetadataComponent - Class in org.apache.cassandra.io.sstable.metadata
MetadataComponent is a component for SSTable metadata and serialized to Stats.db.
MetadataComponent() - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataComponent
 
MetadataSerializer - Class in org.apache.cassandra.io.sstable.metadata
Metadata serializer for SSTables version >= 'k'.
MetadataSerializer() - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
 
MetadataType - Enum in org.apache.cassandra.io.sstable.metadata
Defines Metadata component type.
meter(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
metric - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
metric - Variable in class org.apache.cassandra.db.Keyspace
 
MetricName(Class<?>, String) - Constructor for class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Creates a new CassandraMetricsRegistry.MetricName without a scope.
MetricName(String, String, String) - Constructor for class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Creates a new CassandraMetricsRegistry.MetricName without a scope.
MetricName(Class<?>, String, String) - Constructor for class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Creates a new CassandraMetricsRegistry.MetricName without a scope.
MetricName(String, String, String, String) - Constructor for class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Creates a new CassandraMetricsRegistry.MetricName without a scope.
MetricName(String, String, String, String, String) - Constructor for class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Creates a new CassandraMetricsRegistry.MetricName without a scope.
MetricNameFactory - Interface in org.apache.cassandra.metrics
 
metricPercentilesAsArray(CassandraMetricsRegistry.JmxHistogramMBean) - Method in class org.apache.cassandra.tools.NodeProbe
 
metricPercentilesAsArray(CassandraMetricsRegistry.JmxTimerMBean) - Method in class org.apache.cassandra.tools.NodeProbe
 
metrics - Variable in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
metrics - Static variable in class org.apache.cassandra.cql3.QueryProcessor
 
metrics - Variable in class org.apache.cassandra.db.HintedHandOffManager
 
Metrics - Static variable in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
mEXPONENT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mF() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mFLOAT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mG() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mH() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mHEX() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mHEXNUMBER() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mI() - Method in class org.apache.cassandra.cql3.CqlLexer
 
microsTimestamp(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
 
mIDENT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
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.
MIGRATION_DELAY_IN_MS - Static variable in class org.apache.cassandra.service.MigrationManager
 
MigrationListener - Class in org.apache.cassandra.service
 
MigrationListener() - Constructor for class org.apache.cassandra.service.MigrationListener
 
MigrationManager - Class in org.apache.cassandra.service
 
MigrationManager.MigrationsSerializer - Class in org.apache.cassandra.service
 
MigrationRequestVerbHandler - Class in org.apache.cassandra.db
Sends it's current schema state in form of mutations in reply to the remote node's request.
MigrationRequestVerbHandler() - Constructor for class org.apache.cassandra.db.MigrationRequestVerbHandler
 
MigrationsSerializer() - Constructor for class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
 
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_SSTABLE_SIZE_KEY - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
minColumnNames - Variable in class org.apache.cassandra.io.sstable.ColumnStats
max and min column names according to comparator
minColumnNames - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
minColumnNames - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
minColumnNameSeen - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow.Reducer
 
minCompactionThreshold(int) - Method in class org.apache.cassandra.config.CFMetaData
 
minComponents(List<ByteBuffer>, Composite, CellNameType) - Static method in class org.apache.cassandra.io.sstable.ColumnNameHelper
finds the min cell name component(s) Note that this method *can modify maxSeen*.
minimalBufferFor(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
trims size of bytebuffer to exactly number of bytes in it, to do not hold too much memory
MINIMUM - Static variable in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
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
 
minimumVersion - Variable in enum org.apache.cassandra.transport.Event.Type
 
minIndexInterval(int) - Method in class org.apache.cassandra.config.CFMetaData
 
minKeyBound() - Method in class org.apache.cassandra.dht.Token
 
MinLongTracker(long) - Constructor for class org.apache.cassandra.io.sstable.ColumnStats.MinLongTracker
 
minMarkedAt() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
minor - Variable in class org.apache.cassandra.utils.CassandraVersion
 
minOrdering() - Static method in class org.apache.cassandra.utils.Interval
 
minRepairedAt - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
minRight(AbstractBounds.Boundary<T>, T, boolean) - Static method in class org.apache.cassandra.dht.AbstractBounds
 
minRight(AbstractBounds.Boundary<T>, AbstractBounds.Boundary<T>) - Static method in class org.apache.cassandra.dht.AbstractBounds
 
minRowSize - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Size of the smallest compacted row
minSSTableSize - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
minSupportedBloomFilterFpChance() - Static method in class org.apache.cassandra.utils.BloomCalculations
Retrieves the minimum supported BloomFilterFpChance value
mINTEGER() - Method in class org.apache.cassandra.cql3.CqlLexer
 
minTimestamp() - Method in class org.apache.cassandra.db.AbstractNativeCell
 
minTimestamp() - Method in class org.apache.cassandra.db.DeletionInfo
Returns the minimum timestamp in any of the range tombstones or the top-level tombstone.
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.metadata.MetadataCollector
 
minTimestamp - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
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.TimeFcts
 
minValue() - Method in class org.apache.cassandra.db.DecoratedKey
 
minValue() - Method in interface org.apache.cassandra.dht.RingPosition
 
minValue() - Method in class org.apache.cassandra.dht.Token.KeyBound
 
minValue() - Method in class org.apache.cassandra.dht.Token
 
mJ() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_ADD() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_AGGREGATE() - 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.cql3.CqlLexer
 
mK_AND() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_APPLY() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_AS() - 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.cql3.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_CALLED() - 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.cql3.CqlLexer
 
mK_COMPACT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_CONTAINS() - Method in class org.apache.cassandra.cql3.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.cql3.CqlLexer
 
mK_CUSTOM() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_DATE() - 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.cql3.CqlLexer
 
mK_DESC() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_DESCRIBE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_DISTINCT() - 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.cql3.CqlLexer
 
mK_ENTRIES() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_EXECUTE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_EXISTS() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_FILTERING() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_FINALFUNC() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_FLOAT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_FROM() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_FROZEN() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_FULL() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_FUNCTION() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_FUNCTIONS() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_GRANT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_IF() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_IN() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_INDEX() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_INET() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_INFINITY() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_INITCOND() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_INPUT() - Method in class org.apache.cassandra.cql3.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.cql3.CqlLexer
 
mK_JSON() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_KEY() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_KEYS() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_KEYSPACE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_KEYSPACES() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_LANGUAGE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_LIMIT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_LIST() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_LOGIN() - 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_NAN() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_NOLOGIN() - 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_NOT() - 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.cql3.CqlLexer
 
mK_OPTIONS() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_OR() - 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.cql3.CqlLexer
 
mK_RENAME() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_REPLACE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_RETURNS() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_REVOKE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_ROLE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_ROLES() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_SELECT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_SET() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_SFUNC() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_SMALLINT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_STATIC() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_STORAGE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_STYPE() - 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_TIME() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_TIMESTAMP() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_TIMEUUID() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_TINYINT() - 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_TRIGGER() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_TRUNCATE() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_TTL() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_TUPLE() - Method in class org.apache.cassandra.cql3.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.cql3.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.cql3.CqlLexer
 
mK_UUID() - Method in class org.apache.cassandra.cql3.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.cql3.CqlLexer
 
mK_WITH() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mK_WRITETIME() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mL() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mLETTER() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mM() - Method in class org.apache.cassandra.cql3.CqlLexer
 
MmappedSegmentedFile - Class in org.apache.cassandra.io.util
 
MmappedSegmentedFile(ChannelProxy, long, SegmentedFile.Segment[]) - Constructor for class org.apache.cassandra.io.util.MmappedSegmentedFile
 
MmappedSegmentedFile.Builder - Class in org.apache.cassandra.io.util
Overrides the default behaviour to create segments of a maximum size.
MmappedSegmentedFile.Builder.Boundaries - Class in org.apache.cassandra.io.util
 
mMULTILINE_COMMENT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mN() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mO() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mockKS(KSMetaData) - Static method in class org.apache.cassandra.db.Keyspace
 
MODERN_LENGTH - Static variable in class org.apache.cassandra.transport.Frame.Header
 
ModificationStatement - Class in org.apache.cassandra.cql3.statements
 
ModificationStatement(ModificationStatement.StatementType, int, CFMetaData, Attributes) - Constructor for class org.apache.cassandra.cql3.statements.ModificationStatement
 
ModificationStatement.Parsed - Class in org.apache.cassandra.cql3.statements
 
ModificationStatement.StatementType - Enum in org.apache.cassandra.cql3.statements
 
monitorEnterUnsafe(Object) - Static method in class org.apache.cassandra.utils.concurrent.Locks
 
monitorExitUnsafe(Object) - Static method in class org.apache.cassandra.utils.concurrent.Locks
 
mostInterestingBucket(List<List<SSTableReader>>, int, int) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
mostRecentCommit - Variable in class org.apache.cassandra.service.paxos.PrepareCallback
 
mostRecentCommit - Variable in class org.apache.cassandra.service.paxos.PrepareResponse
 
mostRecentInProgressCommit - Variable in class org.apache.cassandra.service.paxos.PrepareCallback
 
mostRecentInProgressCommitWithUpdate - Variable in class org.apache.cassandra.service.paxos.PrepareCallback
 
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
 
Move - Class in org.apache.cassandra.tools.nodetool
 
Move() - Constructor for class org.apache.cassandra.tools.nodetool.Move
 
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.cql3.CqlLexer
 
mQ() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mQMARK() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mQUOTED_NAME() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mR() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mS() - Method in class org.apache.cassandra.cql3.CqlLexer
 
msProxy - Variable in class org.apache.cassandra.tools.NodeProbe
 
mSTRING_LITERAL() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__167() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__168() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__169() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__170() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__171() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__172() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__173() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__174() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__175() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__176() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__177() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__178() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__179() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__180() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__181() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__182() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__183() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__184() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mT__185() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mTokens() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mU() - Method in class org.apache.cassandra.cql3.CqlLexer
 
MultiColumnRelation - Class in org.apache.cassandra.cql3
A relation using the tuple notation, which typically affects multiple columns.
MultiColumnRestriction - Class in org.apache.cassandra.cql3.restrictions
 
MultiColumnRestriction(List<ColumnDefinition>) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
 
MultiColumnRestriction.EQ - Class in org.apache.cassandra.cql3.restrictions
 
MultiColumnRestriction.IN - Class in org.apache.cassandra.cql3.restrictions
 
MultiColumnRestriction.InWithMarker - Class in org.apache.cassandra.cql3.restrictions
An IN restriction that uses a single marker for a set of IN values that are tuples.
MultiColumnRestriction.InWithValues - Class in org.apache.cassandra.cql3.restrictions
An IN restriction that has a set of terms for in values.
MultiColumnRestriction.Slice - Class in org.apache.cassandra.cql3.restrictions
 
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
 
MultiItemTerminal() - Constructor for class org.apache.cassandra.cql3.Term.MultiItemTerminal
 
MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql3.CqlParser
 
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
 
Murmur3Partitioner.LongToken - Class in org.apache.cassandra.dht
 
MurmurHash - Class in org.apache.cassandra.utils
This is a very fast, non-cryptographic hash suitable for general hash-based lookup.
MurmurHash() - Constructor for class org.apache.cassandra.utils.MurmurHash
 
mutate(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<Mutation>, 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.
mutateLevel(Descriptor, int) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
Mutate SSTable level
mutateLevel(Descriptor, int) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
 
mutateLevel(int) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
mutateRepairedAt(Descriptor, long) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
Mutate repairedAt time
mutateRepairedAt(Descriptor, long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
 
mutateRepairedAt(long) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
mutateWithTracing(ByteBuffer, String, int, int) - Static method in class org.apache.cassandra.tracing.TraceState
Called from OutboundTcpConnection for non-local traces (traces that are not initiated by local node == coordinator).
mutateWithTriggers(Collection<? extends IMutation>, ConsistencyLevel, boolean) - Static method in class org.apache.cassandra.service.StorageProxy
 
Mutation - Class in org.apache.cassandra.db
 
Mutation(String, ByteBuffer) - Constructor for class org.apache.cassandra.db.Mutation
 
Mutation(String, ByteBuffer, ColumnFamily) - Constructor for class org.apache.cassandra.db.Mutation
 
Mutation(String, Row) - Constructor for class org.apache.cassandra.db.Mutation
 
Mutation(String, ByteBuffer, Map<UUID, ColumnFamily>) - Constructor for class org.apache.cassandra.db.Mutation
 
Mutation(ByteBuffer, ColumnFamily) - Constructor for class org.apache.cassandra.db.Mutation
 
Mutation.MutationSerializer - Class in org.apache.cassandra.db
 
MutationSerializer() - Constructor for class org.apache.cassandra.db.Mutation.MutationSerializer
 
MutationVerbHandler - Class in org.apache.cassandra.db
 
MutationVerbHandler() - Constructor for class org.apache.cassandra.db.MutationVerbHandler
 
mUUID() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mV() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mW() - Method in class org.apache.cassandra.cql3.CqlLexer
 
mWS() - Method in class org.apache.cassandra.cql3.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.cql3.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.cql3.CqlLexer
 
N - Static variable in class org.apache.cassandra.cql3.CqlParser
 
NAME - Static variable in class org.apache.cassandra.auth.AuthKeyspace
 
name - Variable in class org.apache.cassandra.config.KSMetaData
 
name - Variable in class org.apache.cassandra.config.TriggerDefinition
 
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 - Static variable in class org.apache.cassandra.cql3.functions.FromJsonFct
 
name() - Method in interface org.apache.cassandra.cql3.functions.Function
 
name - Variable in class org.apache.cassandra.cql3.functions.FunctionName
 
NAME - Static variable in class org.apache.cassandra.cql3.functions.ToJsonFct
 
name - Variable in class org.apache.cassandra.cql3.statements.AlterTypeStatement
 
name - Variable in class org.apache.cassandra.db.BufferCell
 
name() - Method in class org.apache.cassandra.db.BufferCell
 
name() - Method in interface org.apache.cassandra.db.Cell
 
name - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
name - Variable in class org.apache.cassandra.db.marshal.UserType
 
name() - Method in class org.apache.cassandra.db.NativeCell
 
name() - Method in interface org.apache.cassandra.db.OnDiskAtom
 
name() - Method in class org.apache.cassandra.db.RangeTombstone
 
NAME - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
name - Variable in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader.Column
Deprecated.
 
name - Variable in class org.apache.cassandra.io.sstable.Component
 
name() - Method in class org.apache.cassandra.io.sstable.Component
 
name - Variable in enum org.apache.cassandra.io.sstable.format.SSTableFormat.Type
 
name() - Method in class org.apache.cassandra.io.util.SegmentedFile.Cleanup
 
NAME - Static variable in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
NAME - Static variable in class org.apache.cassandra.tracing.TraceKeyspace
 
name - Variable in class org.apache.cassandra.transport.Event.SchemaChange
 
name() - Method in interface org.apache.cassandra.utils.concurrent.RefCounted.Tidy
 
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.PreparedMetadata
 
names - Variable in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
NamesQueryFilter - Class in org.apache.cassandra.db.filter
 
NamesQueryFilter(SortedSet<CellName>) - Constructor for class org.apache.cassandra.db.filter.NamesQueryFilter
 
NamesQueryFilter(SortedSet<CellName>, boolean) - Constructor for class org.apache.cassandra.db.filter.NamesQueryFilter
 
NamesQueryFilter.Serializer - Class in org.apache.cassandra.db.filter
 
namesQueryFilterSerializer() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
namesQueryFilterSerializer() - Method in interface org.apache.cassandra.db.composites.CellNameType
 
NamesQueryPager - Class in org.apache.cassandra.service.pager
Pager over a SliceByNamesReadCommand.
NanoTimeToCurrentTimeMillis - Class in org.apache.cassandra.utils
 
NanoTimeToCurrentTimeMillis() - Constructor for class org.apache.cassandra.utils.NanoTimeToCurrentTimeMillis
 
NATIVE - Static variable in class org.apache.cassandra.db.TypeSizes
 
native_transport_max_concurrent_connections - Variable in class org.apache.cassandra.config.Config
 
native_transport_max_concurrent_connections_per_ip - Variable in class org.apache.cassandra.config.Config
 
native_transport_max_frame_size_in_mb - Variable in class org.apache.cassandra.config.Config
 
native_transport_max_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
 
NativeAggregateFunction - Class in org.apache.cassandra.cql3.functions
Base class for the AggregateFunction native classes.
NativeAggregateFunction(String, AbstractType<?>, AbstractType<?>...) - Constructor for class org.apache.cassandra.cql3.functions.NativeAggregateFunction
 
NativeAllocator - Class in org.apache.cassandra.utils.memory
This NativeAllocator uses global slab allocation strategy with slab size that scales exponentially from 8kb to 1Mb to serve allocation of up to 128kb.
NativeAllocator(NativePool) - Constructor for class org.apache.cassandra.utils.memory.NativeAllocator
 
NativeCell - Class in org.apache.cassandra.db
 
NativeCell(NativeAllocator, OpOrder.Group, Cell) - Constructor for class org.apache.cassandra.db.NativeCell
 
NativeCounterCell - Class in org.apache.cassandra.db
 
NativeCounterCell(NativeAllocator, OpOrder.Group, CounterCell) - Constructor for class org.apache.cassandra.db.NativeCounterCell
 
NativeDBTypeSizes() - Constructor for class org.apache.cassandra.db.TypeSizes.NativeDBTypeSizes
 
NativeDecoratedKey - Class in org.apache.cassandra.db
 
NativeDecoratedKey(Token, NativeAllocator, OpOrder.Group, ByteBuffer) - Constructor for class org.apache.cassandra.db.NativeDecoratedKey
 
NativeDeletedCell - Class in org.apache.cassandra.db
 
NativeDeletedCell(NativeAllocator, OpOrder.Group, DeletedCell) - Constructor for class org.apache.cassandra.db.NativeDeletedCell
 
NativeExpiringCell - Class in org.apache.cassandra.db
 
NativeExpiringCell(NativeAllocator, OpOrder.Group, ExpiringCell) - Constructor for class org.apache.cassandra.db.NativeExpiringCell
 
nativeFunction(String) - Static method in class org.apache.cassandra.cql3.functions.FunctionName
 
NativeFunction - Class in org.apache.cassandra.cql3.functions
Base class for our native/hardcoded functions.
NativeFunction(String, AbstractType<?>, AbstractType<?>...) - Constructor for class org.apache.cassandra.cql3.functions.NativeFunction
 
NativePool - Class in org.apache.cassandra.utils.memory
 
NativePool(long, long, float, Runnable) - Constructor for class org.apache.cassandra.utils.memory.NativePool
 
nativeProtocolVersion - Variable in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
nativeProtocolVersion - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
nativeProtocolVersion - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
NativeScalarFunction - Class in org.apache.cassandra.cql3.functions
Base class for the ScalarFunction native classes.
NativeScalarFunction(String, AbstractType<?>, AbstractType<?>...) - Constructor for class org.apache.cassandra.cql3.functions.NativeScalarFunction
 
nativeServer - Variable in class org.apache.cassandra.service.CassandraDaemon
 
NativeSSTableLoaderClient - Class in org.apache.cassandra.utils
 
NativeSSTableLoaderClient(Collection<InetAddress>, int, String, String, SSLOptions) - Constructor for class org.apache.cassandra.utils.NativeSSTableLoaderClient
 
naturalEndpoints - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
needFiltering() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the query need to use filtering.
needsCleanup(SSTableReader, Collection<Range<Token>>) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
Determines if a cleanup would actually remove any data in this SSTable based on a set of owned ranges.
needsFiltering() - Method in class org.apache.cassandra.db.ColumnFamilyStore.AbstractScanIterator
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
Deprecated.
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
 
needToCopyOnHeap() - Method in class org.apache.cassandra.utils.memory.HeapPool
 
needToCopyOnHeap() - Method in class org.apache.cassandra.utils.memory.MemtablePool
 
needToCopyOnHeap() - Method in class org.apache.cassandra.utils.memory.NativePool
 
needToCopyOnHeap() - Method in class org.apache.cassandra.utils.memory.SlabPool
 
NegativeLocalDeletionInfoMetrics() - Constructor for class org.apache.cassandra.db.compaction.Scrubber.NegativeLocalDeletionInfoMetrics
 
NetStats - Class in org.apache.cassandra.tools.nodetool
 
NetStats() - Constructor for class org.apache.cassandra.tools.nodetool.NetStats
 
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
 
newAggregate() - Method in interface org.apache.cassandra.cql3.functions.AggregateFunction
Creates a new Aggregate instance.
newAggregate() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
newAllocator() - Method in class org.apache.cassandra.utils.memory.HeapPool
 
newAllocator() - Method in class org.apache.cassandra.utils.memory.MemtablePool
 
newAllocator() - Method in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
 
newAllocator() - Method in class org.apache.cassandra.utils.memory.NativePool
 
newAllocator() - Method in class org.apache.cassandra.utils.memory.SlabPool
 
newAuthenticator(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newAuthorizer(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newBarrier() - Method in class org.apache.cassandra.utils.concurrent.OpOrder
Creates a new barrier.
newBindVariables(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.CqlParser
 
newCoalescingStrategy(String, int, Logger, String) - Static method in class org.apache.cassandra.utils.CoalescingStrategies
 
newConnection(Channel, int) - Method in interface org.apache.cassandra.transport.Connection.Factory
 
newContainsRestriction(CFMetaData, VariableSpecifications, boolean) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
newContainsRestriction(CFMetaData, VariableSpecifications, boolean) - Method in class org.apache.cassandra.cql3.Relation
Creates a new Contains restriction instance.
newContainsRestriction(CFMetaData, VariableSpecifications, boolean) - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
newContainsRestriction(CFMetaData, VariableSpecifications, boolean) - Method in class org.apache.cassandra.cql3.TokenRelation
 
newDefaultChannel() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
newDefaultChannel() - Method in class org.apache.cassandra.io.util.DataOutputStreamPlus
 
newDeserializer(DataInput) - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
 
newDeserializer(DataInput) - Method in class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
 
newDeserializer(DataInput) - Method in interface org.apache.cassandra.db.composites.CellNameType
Creates a new Deserializer.
newEQRestriction(CFMetaData, VariableSpecifications) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
newEQRestriction(CFMetaData, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Relation
Creates a new EQ restriction instance.
newEQRestriction(CFMetaData, VariableSpecifications) - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
newEQRestriction(CFMetaData, VariableSpecifications) - Method in class org.apache.cassandra.cql3.TokenRelation
 
newExecutor(int, int, String, String) - Method in class org.apache.cassandra.concurrent.SharedExecutorPool
 
newFactory(ColumnDefinition, int) - Static method in class org.apache.cassandra.cql3.selection.SimpleSelector
 
newGenericCounter(String, String, long) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
 
newINBindVariables(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.CqlParser
 
newIndexMetadata(CFMetaData, ColumnDefinition, CellNameType) - Static method in class org.apache.cassandra.config.CFMetaData
Creates CFMetaData for secondary index CF.
newINRestriction(CFMetaData, VariableSpecifications) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
newINRestriction(CFMetaData, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Relation
Creates a new IN restriction instance.
newINRestriction(CFMetaData, VariableSpecifications) - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
newINRestriction(CFMetaData, VariableSpecifications) - Method in class org.apache.cassandra.cql3.TokenRelation
 
newInstance() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Creates a new Selector instance.
newJobContext(Configuration, JobID) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
Creates JobContext from a JobConf and jobId using the correct constructor for based on Hadoop version.
newJsonBindVariables(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.CqlParser
 
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
 
newMapContext(Configuration, TaskAttemptID, RecordReader, RecordWriter, OutputCommitter, StatusReporter, InputSplit) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
Instantiates MapContext under Hadoop 1 and MapContextImpl under Hadoop 2.
newMapping() - Static method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
newMessageDigest(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newNode(InetAddress, int) - Static method in class org.apache.cassandra.transport.Event.TopologyChange
 
newOffsets(int, boolean) - Static method in class org.apache.cassandra.utils.EstimatedHistogram
 
newPartitioner(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newPrepare(ByteBuffer, CFMetaData, UUID) - Static method in class org.apache.cassandra.service.paxos.Commit
 
newProposal(ByteBuffer, UUID, ColumnFamily) - Static method in class org.apache.cassandra.service.paxos.Commit
 
newReadRepairDecision() - Method in class org.apache.cassandra.config.CFMetaData
 
newRoleManager(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newRow(int) - Method in class org.apache.cassandra.cql3.selection.Selection.ResultSetBuilder
 
newRow(ByteBuffer) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
Start a new row whose key is key.
newSaslNegotiator() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
newSaslNegotiator() - Method in interface org.apache.cassandra.auth.IAuthenticator
Provide a SASL handler to perform authentication for an single connection.
newSaslNegotiator() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
newSelectorFactory(CFMetaData, List<ColumnDefinition>) - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
newSelectorFactory(CFMetaData, List<ColumnDefinition>) - Method in class org.apache.cassandra.cql3.selection.Selectable
 
newSelectorFactory(CFMetaData, List<ColumnDefinition>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection
 
newSelectorFactory(CFMetaData, List<ColumnDefinition>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFunction
 
newSelectorFactory(CFMetaData, List<ColumnDefinition>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL
 
newSelectors() - Method in class org.apache.cassandra.cql3.selection.Selection
 
newSession() - Method in class org.apache.cassandra.tracing.Tracing
 
newSession(Tracing.TraceType) - 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.format.SSTableReader
Tests if the sstable contains data newer than the given age param (in localhost currentMilli time).
newSliceRestriction(CFMetaData, VariableSpecifications, Bound, boolean) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
newSliceRestriction(CFMetaData, VariableSpecifications, Bound, boolean) - Method in class org.apache.cassandra.cql3.Relation
Creates a new Slice restriction instance.
newSliceRestriction(CFMetaData, VariableSpecifications, Bound, boolean) - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
newSliceRestriction(CFMetaData, VariableSpecifications, Bound, boolean) - Method in class org.apache.cassandra.cql3.TokenRelation
 
newSocket() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
newSocket(InetAddress) - Static method in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
newSuperColumn(ByteBuffer) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
Start a new super column with name name.
newTaskAttemptContext(Configuration, TaskAttemptID) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
Creates TaskAttempContext from a JobConf and jobId using the correct constructor for based on Hadoop version.
newTaskFor(Runnable, T) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
newTaskFor(Runnable, T, ExecutorLocals) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
newTaskFor(Callable<T>) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
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
 
newTupleBindVariables(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.CqlParser
 
newTupleINBindVariables(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.CqlParser
 
next(ByteBuffer, SortedMap<ByteBuffer, ColumnFamilyRecordReader.Column>) - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
Deprecated.
 
next(Long, Row) - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
next() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
 
next() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
next() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
next() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
next(K) - Method in class org.apache.cassandra.utils.btree.BTreeSearchIterator
 
next() - Method in class org.apache.cassandra.utils.btree.Cursor
 
next(K) - Method in interface org.apache.cassandra.utils.SearchIterator
 
nextIsRangeTombstone() - Method in class org.apache.cassandra.db.AtomDeserializer
Returns whether the next atom is a range tombstone or not.
nextKeyValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
Deprecated.
 
nextKeyValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
nextToken() - Method in class org.apache.cassandra.cql3.CqlLexer
 
NICE_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
 
NIODataInputStream - Class in org.apache.cassandra.io.util
Rough equivalent of BufferedInputStream and DataInputStream wrapping the input stream of a File or Socket Created to work around the fact that when BIS + DIS delegate to NIO for socket IO they will allocate large thread local direct byte buffers when a large array is used to read.
NIODataInputStream(ReadableByteChannel, int) - Constructor for class org.apache.cassandra.io.util.NIODataInputStream
 
NO_BYTE_BUFFERS - Static variable in class org.apache.cassandra.io.util.Memory
 
NO_COMPRESSION_RATIO - Static variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
NO_GC - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
 
NO_OP - Static variable in class org.apache.cassandra.utils.memory.MemtableAllocator
 
NO_OP_TASK - Static variable in class org.apache.cassandra.concurrent.StageManager
 
node - Variable in class org.apache.cassandra.transport.Event.NodeEvent
 
nodeAddress() - Method in class org.apache.cassandra.transport.Event.NodeEvent
 
nodeDown(InetAddress, int) - Static method in class org.apache.cassandra.transport.Event.StatusChange
 
NodePair - Class in org.apache.cassandra.repair
NodePair is used for repair message body to indicate the pair of nodes.
NodePair(InetAddress, InetAddress) - Constructor for class org.apache.cassandra.repair.NodePair
 
NodePair.NodePairSerializer - Class in org.apache.cassandra.repair
 
NodePairSerializer() - Constructor for class org.apache.cassandra.repair.NodePair.NodePairSerializer
 
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.
nodes - Variable in class org.apache.cassandra.repair.messages.SyncComplete
nodes that involved in this sync
nodes - Variable in class org.apache.cassandra.repair.SyncStat
 
NodeTool - Class in org.apache.cassandra.tools
 
NodeTool() - Constructor for class org.apache.cassandra.tools.NodeTool
 
NodeTool.NodeToolCmd - Class in org.apache.cassandra.tools
 
NodeToolCmd() - Constructor for class org.apache.cassandra.tools.NodeTool.NodeToolCmd
 
nodeUp(InetAddress, int) - Static method in class org.apache.cassandra.transport.Event.StatusChange
 
non_type_ident() - Method in class org.apache.cassandra.cql3.CqlParser
 
nonCompactingSStables() - Method in class org.apache.cassandra.db.lifecycle.View
 
NONE - Static variable in enum org.apache.cassandra.auth.Permission
 
NONE - Static variable in class org.apache.cassandra.cache.CachingOptions
 
none() - Static method in class org.apache.cassandra.cql3.Attributes
 
NONE - Static variable in class org.apache.cassandra.db.commitlog.ReplayPosition
 
noneStrictlyWrapsAround(Collection<AbstractBounds<T>>) - Static method in class org.apache.cassandra.dht.AbstractBounds
 
nonExpiredSSTables - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
nonPeriodicTasks - Static variable in class org.apache.cassandra.concurrent.ScheduledExecutors
This executor is used for tasks that can have longer execution times, and usually are non periodic.
nonSystem() - Static method in class org.apache.cassandra.db.Keyspace
 
NonTerminal() - Constructor for class org.apache.cassandra.cql3.Term.NonTerminal
 
NopCacheProvider - Class in org.apache.cassandra.cache
 
NopCacheProvider() - Constructor for class org.apache.cassandra.cache.NopCacheProvider
 
normal(Collection<Token>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
normalColumnOperation(List<Pair<ColumnIdentifier.Raw, Operation.RawUpdate>>, ColumnIdentifier.Raw) - Method in class org.apache.cassandra.cql3.CqlParser
 
normalInsertStatement(CFName) - Method in class org.apache.cassandra.cql3.CqlParser
 
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
 
NoSpamLogger - Class in org.apache.cassandra.utils
Logging that limits each log statement to firing based on time since the statement last fired.
NoSpamLogger.Level - Enum in org.apache.cassandra.utils
Levels for programmatically specifying the severity of a log statement
NoSpamLogger.NoSpamLogStatement - Class in org.apache.cassandra.utils
 
NoSpamLogStatement(String, long) - Constructor for class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
 
nothing() - Static method in class org.apache.cassandra.db.ColumnIndex
 
notifyAdded(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
notifyCreateAggregate(UDAggregate) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyCreateColumnFamily(CFMetaData) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyCreateFunction(UDFunction) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyCreateKeyspace(KSMetaData) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyCreateUserType(UserType) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyDeleting(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
notifyDropAggregate(UDAggregate) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyDropColumnFamily(CFMetaData) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyDropFunction(UDFunction) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyDropKeyspace(KSMetaData) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyDropUserType(UserType) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyRenewed(Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
notifySSTableRepairedStatusChanged(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
notifyTruncated(long) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
notifyUpdateAggregate(UDAggregate) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyUpdateColumnFamily(CFMetaData, boolean) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyUpdateFunction(UDFunction) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyUpdateKeyspace(KSMetaData) - Method in class org.apache.cassandra.service.MigrationManager
 
notifyUpdateUserType(UserType) - Method in class org.apache.cassandra.service.MigrationManager
 
nowFct - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
 
NULL_LITERAL - Static variable in class org.apache.cassandra.cql3.Constants
 
NULL_VALUE - Static variable in class org.apache.cassandra.cql3.Constants
 
NULL_VERSION - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
NullOutputCommitter() - Constructor for class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
Deprecated.
 
NullOutputCommitter() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
 
NullOutputHandler() - Constructor for class org.apache.cassandra.hadoop.BulkRecordWriter.NullOutputHandler
Deprecated.
 
nullToBB() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
nullToBB() - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
nullUpdater - Static variable in class org.apache.cassandra.db.index.SecondaryIndexManager
 
num_tokens - Variable in class org.apache.cassandra.config.Config
 
numberOfDifferences - Variable in class org.apache.cassandra.repair.SyncStat
 
numberOfEntries() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
 
numberOfKeys() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
 
numberOfValues() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
 

O

O - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
O - Static variable in class org.apache.cassandra.cql3.CqlParser
 
OBJECT_NAME - Static variable in interface org.apache.cassandra.streaming.StreamManagerMBean
 
objectName() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricMBean
 
ObjectSizes - Class in org.apache.cassandra.utils
A convenience class for wrapping access to MemoryMeter
ObjectSizes() - Constructor for class org.apache.cassandra.utils.ObjectSizes
 
objToBB(Object) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
convert object to ByteBuffer
objToBB(Object) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
convert object to ByteBuffer
obsolete(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
mark this reader as for obsoletion.
obsoleteKeywords - Static variable in class org.apache.cassandra.cql3.statements.CFPropDefs
 
obsoleteKeywords - Static variable in class org.apache.cassandra.cql3.statements.IndexPropDefs
 
obsoleteKeywords - Static variable in class org.apache.cassandra.cql3.statements.KSPropDefs
 
obsoleteOriginals() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
obsolete every file in the original transaction
offHeap() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
 
offHeap - Variable in class org.apache.cassandra.utils.memory.MemtablePool
 
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
 
offHeapSize() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
Returns the amount of memory in bytes used off heap.
offHeapSize() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
 
offHeapSize() - Method in class org.apache.cassandra.utils.BloomFilter
 
offHeapSize() - Method in interface org.apache.cassandra.utils.IFilter
Returns the amount of memory in bytes used off heap.
offHeapSize() - Method in interface org.apache.cassandra.utils.obs.IBitSet
Returns the amount of memory in bytes used off heap.
offHeapSize() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
offHeapSize() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
offline(OperationType, SSTableReader) - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
construct a Transaction for use in an offline operation
offline(OperationType, Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
construct a Transaction for use in an offline operation
offset - Variable in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
 
offset - Variable in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
OHCProvider - Class in org.apache.cassandra.cache
 
OHCProvider() - Constructor for class org.apache.cassandra.cache.OHCProvider
 
OldNetworkTopologyStrategy - Class in org.apache.cassandra.locator
This Replication Strategy returns the nodes responsible for a given key but respects rack awareness.
OldNetworkTopologyStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.OldNetworkTopologyStrategy
 
onAlive(InetAddress, EndpointState) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.locator.ReconnectableSnitchHelper
 
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.repair.AnticompactionTask
 
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.repair.RepairSession
 
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.ActiveRepairService
 
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.streaming.StreamSession
 
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.repair.AnticompactionTask
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.repair.RepairSession
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.ActiveRepairService
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.StorageService
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.streaming.StreamSession
 
onCompletion() - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
onCompletion() - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
onCreateAggregate(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.service.MigrationListener
 
onCreateColumnFamily(String, String) - Method in class org.apache.cassandra.service.MigrationListener
 
onCreateFunction(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.service.MigrationListener
 
onCreateKeyspace(String) - Method in class org.apache.cassandra.service.MigrationListener
 
onCreateUserType(String, String) - Method in class org.apache.cassandra.service.MigrationListener
 
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.repair.AnticompactionTask
 
onDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.repair.RepairSession
 
onDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.ActiveRepairService
 
onDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.streaming.StreamSession
 
OnDiskAtom - Interface in org.apache.cassandra.db
 
OnDiskAtom.Serializer - Class in org.apache.cassandra.db
 
OnDiskAtom.SerializerForWriting - Interface in org.apache.cassandra.db
 
onDiskAtomComparator() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
onDiskAtomComparator() - Method in interface org.apache.cassandra.db.composites.CellNameType
 
OnDiskAtomIterator - Interface in org.apache.cassandra.db.columniterator
 
onDiskAtomSerializer() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
onDiskAtomSerializer() - Method in interface org.apache.cassandra.db.composites.CellNameType
 
onDiskIterator(DataInput, ColumnSerializer.Flag, int, Version, CellNameType) - Static method in class org.apache.cassandra.db.AbstractCell
 
onDiskIterator(DataInput, int, ColumnSerializer.Flag, int, CellNameType) - Static method in class org.apache.cassandra.db.SuperColumns
 
onDiskLength() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
onDiskLength - Variable in class org.apache.cassandra.io.util.SegmentedFile
 
onDiskSize() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
onDiskSize() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManager
 
onDiskSize() - Method in class org.apache.cassandra.db.commitlog.CompressedSegment
 
onDiskSize() - Method in class org.apache.cassandra.db.commitlog.MemoryMappedSegment
 
onDown(InetAddress) - Method in interface org.apache.cassandra.service.IEndpointLifecycleSubscriber
Called when a node is marked DOWN.
onDropAggregate(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.auth.AuthMigrationListener
 
onDropAggregate(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.service.MigrationListener
 
onDropColumnFamily(String, String) - Method in class org.apache.cassandra.auth.AuthMigrationListener
 
onDropColumnFamily(String, String) - Method in class org.apache.cassandra.db.SizeEstimatesRecorder
 
onDropColumnFamily(String, String) - Method in class org.apache.cassandra.service.MigrationListener
 
onDropFunction(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.auth.AuthMigrationListener
 
onDropFunction(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.service.MigrationListener
 
onDropKeyspace(String) - Method in class org.apache.cassandra.auth.AuthMigrationListener
 
onDropKeyspace(String) - Method in class org.apache.cassandra.service.MigrationListener
 
onDropUserType(String, String) - Method in class org.apache.cassandra.service.MigrationListener
 
one() - Method in class org.apache.cassandra.cql3.UntypedResultSet
 
ONE_BYTE - Static variable in class org.apache.cassandra.net.MessagingService
 
ONE_GB - Static variable in class org.apache.cassandra.io.util.FileUtils
 
ONE_KB - Static variable in class org.apache.cassandra.io.util.FileUtils
 
ONE_MB - Static variable in class org.apache.cassandra.io.util.FileUtils
 
ONE_TB - Static variable in class org.apache.cassandra.io.util.FileUtils
 
onError(Throwable) - Method in class org.apache.cassandra.streaming.StreamSession
l Call back for handling exception during streaming.
oneSerializedSize(Pair<T, Object>, int) - Method in class org.apache.cassandra.transport.OptionCodec
 
onEvent(Event) - Method in interface org.apache.cassandra.transport.SimpleClient.EventHandler
 
onEvent(Event) - Method in class org.apache.cassandra.transport.SimpleClient.SimpleEventHandler
 
onFailure(Throwable) - Method in class org.apache.cassandra.dht.StreamStateStore
 
onFailure(Throwable) - Method in class org.apache.cassandra.io.sstable.SSTableLoader
 
onFailure(InetAddress) - Method in interface org.apache.cassandra.net.IAsyncCallbackWithFailure
Called when there is an exception on the remote node or timeout happens
onFailure(InetAddress) - Method in class org.apache.cassandra.repair.AnticompactionTask.AnticompactionCallback
 
onFailure(Throwable) - Method in class org.apache.cassandra.repair.LocalSyncTask
 
onFailure(Throwable) - Method in class org.apache.cassandra.repair.StreamingRepairTask
If we failed on either stream in or out, reply fail to coordinator
onFailure(InetAddress) - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
onFailure(InetAddress) - Method in class org.apache.cassandra.service.ReadCallback
 
onFailure(Throwable) - Method in class org.apache.cassandra.streaming.management.StreamEventJMXNotifier
 
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
 
onHeap() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
 
onHeap - Variable in class org.apache.cassandra.utils.memory.MemtablePool
 
onInitializationComplete() - Method in class org.apache.cassandra.streaming.StreamSession
Call back when connection initialization is complete to start the prepare phase.
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.repair.AnticompactionTask
 
onJoin(InetAddress, EndpointState) - Method in class org.apache.cassandra.repair.RepairSession
 
onJoin(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.ActiveRepairService
 
onJoin(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onJoin(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onJoin(InetAddress, EndpointState) - Method in class org.apache.cassandra.streaming.StreamSession
 
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 beginning 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).
ONLY_EXPLICITLY_REPAIRED - Static variable in class org.apache.cassandra.tools.nodetool.Repair
 
onlyBackups(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
onlyOne() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
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.repair.AnticompactionTask
 
onRemove(InetAddress) - Method in class org.apache.cassandra.repair.RepairSession
 
onRemove(InetAddress) - Method in class org.apache.cassandra.service.ActiveRepairService
 
onRemove(InetAddress) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onRemove(InetAddress) - Method in class org.apache.cassandra.service.StorageService
 
onRemove(InetAddress) - Method in class org.apache.cassandra.streaming.StreamSession
 
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.repair.AnticompactionTask
 
onRestart(InetAddress, EndpointState) - Method in class org.apache.cassandra.repair.RepairSession
 
onRestart(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.ActiveRepairService
 
onRestart(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onRestart(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onRestart(InetAddress, EndpointState) - Method in class org.apache.cassandra.streaming.StreamSession
 
onSuccess(StreamState) - Method in class org.apache.cassandra.dht.StreamStateStore
 
onSuccess(StreamState) - Method in class org.apache.cassandra.io.sstable.SSTableLoader
 
onSuccess(StreamState) - Method in class org.apache.cassandra.repair.LocalSyncTask
 
onSuccess(StreamState) - Method in class org.apache.cassandra.repair.StreamingRepairTask
If we succeeded on both stream in and out, reply back to coordinator
onSuccess(StreamState) - Method in class org.apache.cassandra.streaming.management.StreamEventJMXNotifier
 
onToken() - Method in class org.apache.cassandra.cql3.Relation
Checks if this relation is a token relation (e.g.
onToken() - Method in class org.apache.cassandra.cql3.TokenRelation
 
onUp(InetAddress) - Method in interface org.apache.cassandra.service.IEndpointLifecycleSubscriber
Called when a node is marked UP.
onUpdateAggregate(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.service.MigrationListener
 
onUpdateColumnFamily(String, String, boolean) - Method in class org.apache.cassandra.service.MigrationListener
 
onUpdateFunction(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.service.MigrationListener
 
onUpdateKeyspace(String) - Method in class org.apache.cassandra.service.MigrationListener
 
onUpdateUserType(String, String) - Method in class org.apache.cassandra.service.MigrationListener
 
opcode - Variable in enum org.apache.cassandra.transport.Message.Type
 
open(String) - Static method in class org.apache.cassandra.db.Keyspace
 
open(ChannelProxy, CompressionMetadata) - Static method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
 
open(ICompressedFile) - Static method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
 
open(long) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
open(ICompressedFile, RateLimiter) - Static method in class org.apache.cassandra.io.compress.CompressedThrottledReader
 
open(CompressionParameters, String) - Static method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
open(long, long) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
open(Descriptor, Set<Component>, CFMetaData, IPartitioner, Long, StatsMetadata, SSTableReader.OpenReason) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Factory
 
open(Descriptor) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
open(Descriptor, CFMetaData) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
open(Descriptor, Set<Component>, CFMetaData, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
open(Descriptor, Set<Component>, CFMetaData, IPartitioner, boolean, boolean) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
open(Descriptor, long, long, CFMetaData, IPartitioner, MetadataCollector) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Factory
 
open(File, File) - Static method in class org.apache.cassandra.io.util.ChecksummedRandomAccessReader
 
open(ChannelProxy, long, PoolingSegmentedFile) - Static method in class org.apache.cassandra.io.util.RandomAccessReader
 
open(File) - Static method in class org.apache.cassandra.io.util.RandomAccessReader
 
open(ChannelProxy) - Static method in class org.apache.cassandra.io.util.RandomAccessReader
 
open(ChannelProxy, long) - Static method in class org.apache.cassandra.io.util.RandomAccessReader
 
open(File) - Static method in class org.apache.cassandra.io.util.SequentialWriter
Open a heap-based, non-compressed SequentialWriter
open(File, File) - Static method in class org.apache.cassandra.io.util.SequentialWriter
 
open(String, String, CompressionParameters, MetadataCollector) - Static method in class org.apache.cassandra.io.util.SequentialWriter
 
open(ChannelProxy, long, 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.
openAll(Set<Map.Entry<Descriptor, Set<Component>>>, CFMetaData, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.format.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
 
openChannel(File) - Static method in class org.apache.cassandra.io.util.ChannelProxy
 
openDataReader(RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
openDataReader() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
openEarly() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
openEarly() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
Open the resultant SSTableReader before it has been fully written
openFinalEarly() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
openFinalEarly() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
Open the resultant SSTableReader once it has been fully written, but before the _set_ of tables that are being written together as one atomic operation are all ready
openForBatch(Descriptor, Set<Component>, CFMetaData, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
Open SSTable reader to be used in batch mode(such as sstableloader).
openIndexReader() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
openNoValidation(Descriptor, Set<Component>, ColumnFamilyStore) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
openReason - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
openResult - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter.TransactionalProxy
 
openSSTables(Map<InetAddress, Collection<Range<Token>>>) - Method in class org.apache.cassandra.io.sstable.SSTableLoader
 
openTransport(String, int) - Method in interface org.apache.cassandra.thrift.ITransportFactory
Opens a client transport to a thrift server.
openTransport(String, int) - Method in class org.apache.cassandra.thrift.SSLTransportFactory
 
openTransport(String, int) - Method in class org.apache.cassandra.thrift.TFramedTransportFactory
 
openWithoutSSTables(String) - Static method in class org.apache.cassandra.db.Keyspace
 
Operation - Class in org.apache.cassandra.cql3
An UPDATE or DELETE operation.
Operation(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Operation
 
Operation.Addition - Class in org.apache.cassandra.cql3
 
Operation.ColumnDeletion - Class in org.apache.cassandra.cql3
 
Operation.ElementDeletion - Class in org.apache.cassandra.cql3
 
Operation.Prepend - Class in org.apache.cassandra.cql3
 
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.SetValue - Class in org.apache.cassandra.cql3
 
Operation.Substraction - Class in org.apache.cassandra.cql3
 
OperationType - Enum in org.apache.cassandra.db.compaction
 
operator - Variable in class org.apache.cassandra.cql3.ColumnCondition.Bound
 
operator - Variable in class org.apache.cassandra.cql3.ColumnCondition
 
Operator - Enum in org.apache.cassandra.cql3
 
operator() - Method in class org.apache.cassandra.cql3.Relation
 
operator - Variable in class org.apache.cassandra.db.IndexExpression
 
Operator() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader.Operator
 
OpOrder - Class in org.apache.cassandra.utils.concurrent
A class for providing synchronization between producers and consumers that do not communicate directly with each other, but where the consumers need to process their work in contiguous batches.
OpOrder() - Constructor for class org.apache.cassandra.utils.concurrent.OpOrder
 
OpOrder.Barrier - Class in org.apache.cassandra.utils.concurrent
This class represents a synchronisation point providing ordering guarantees on operations started against the enclosing OpOrder.
OpOrder.Group - Class in org.apache.cassandra.utils.concurrent
Represents a group of identically ordered operations, i.e.
optional - Variable in class org.apache.cassandra.config.EncryptionOptions.ClientEncryptionOptions
 
optionalTasks - Static variable in class org.apache.cassandra.concurrent.ScheduledExecutors
This executor is used for 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.cql3.UpdateParameters
 
options - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
options - Variable in class org.apache.cassandra.transport.messages.BatchMessage
 
options - Variable in class org.apache.cassandra.transport.messages.ExecuteMessage
 
options - Variable in class org.apache.cassandra.transport.messages.QueryMessage
 
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
 
order(ByteOrder) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
order(ByteOrder) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
orderByClause(Map<ColumnIdentifier.Raw, Boolean>) - Method in class org.apache.cassandra.cql3.CqlParser
 
OrderedRangeContainmentChecker(Collection<Range<Token>>) - Constructor for class org.apache.cassandra.dht.Range.OrderedRangeContainmentChecker
 
orderings - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
 
OrderPreservingPartitioner - Class in org.apache.cassandra.dht
 
OrderPreservingPartitioner() - Constructor for class org.apache.cassandra.dht.OrderPreservingPartitioner
 
OrderPreservingPartitioner.StringToken - Class in org.apache.cassandra.dht
 
org.apache.cassandra.auth - package org.apache.cassandra.auth
 
org.apache.cassandra.cache - package org.apache.cassandra.cache
 
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.cql3 - package org.apache.cassandra.cql3
 
org.apache.cassandra.cql3.functions - package org.apache.cassandra.cql3.functions
 
org.apache.cassandra.cql3.restrictions - package org.apache.cassandra.cql3.restrictions
 
org.apache.cassandra.cql3.selection - package org.apache.cassandra.cql3.selection
 
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.compaction.writers - package org.apache.cassandra.db.compaction.writers
 
org.apache.cassandra.db.composites - package org.apache.cassandra.db.composites
 
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.lifecycle - package org.apache.cassandra.db.lifecycle
 
org.apache.cassandra.db.marshal - package org.apache.cassandra.db.marshal
 
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.sstable.format - package org.apache.cassandra.io.sstable.format
 
org.apache.cassandra.io.sstable.format.big - package org.apache.cassandra.io.sstable.format.big
 
org.apache.cassandra.io.sstable.metadata - package org.apache.cassandra.io.sstable.metadata
 
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.notifications - package org.apache.cassandra.notifications
 
org.apache.cassandra.repair - package org.apache.cassandra.repair
 
org.apache.cassandra.repair.messages - package org.apache.cassandra.repair.messages
 
org.apache.cassandra.scheduler - package org.apache.cassandra.scheduler
 
org.apache.cassandra.schema - package org.apache.cassandra.schema
 
org.apache.cassandra.security - package org.apache.cassandra.security
 
org.apache.cassandra.serializers - package org.apache.cassandra.serializers
 
org.apache.cassandra.service - package org.apache.cassandra.service
 
org.apache.cassandra.service.pager - package org.apache.cassandra.service.pager
 
org.apache.cassandra.service.paxos - package org.apache.cassandra.service.paxos
 
org.apache.cassandra.streaming - package org.apache.cassandra.streaming
 
org.apache.cassandra.streaming.compress - package org.apache.cassandra.streaming.compress
 
org.apache.cassandra.streaming.management - package org.apache.cassandra.streaming.management
 
org.apache.cassandra.streaming.messages - package org.apache.cassandra.streaming.messages
 
org.apache.cassandra.thrift - package org.apache.cassandra.thrift
 
org.apache.cassandra.tools - package org.apache.cassandra.tools
 
org.apache.cassandra.tools.nodetool - package org.apache.cassandra.tools.nodetool
 
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.triggers - package org.apache.cassandra.triggers
 
org.apache.cassandra.utils - package org.apache.cassandra.utils
 
org.apache.cassandra.utils.btree - package org.apache.cassandra.utils.btree
 
org.apache.cassandra.utils.concurrent - package org.apache.cassandra.utils.concurrent
 
org.apache.cassandra.utils.memory - package org.apache.cassandra.utils.memory
 
org.apache.cassandra.utils.obs - package org.apache.cassandra.utils.obs
 
org.apache.cassandra.utils.progress - package org.apache.cassandra.utils.progress
 
org.apache.cassandra.utils.progress.jmx - package org.apache.cassandra.utils.progress.jmx
 
org.apache.cassandra.utils.vint - package org.apache.cassandra.utils.vint
 
originalCount - Variable in class org.apache.cassandra.db.RetriedSliceFromReadCommand
 
originals() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
the set of readers guarded by this transaction _in their original instance/state_ call current(SSTableReader) on any reader in this set to get the latest instance
otc_coalescing_enough_coalesced_messages - Variable in class org.apache.cassandra.config.Config
 
otc_coalescing_strategy - Variable in class org.apache.cassandra.config.Config
 
otc_coalescing_window_us - Variable in class org.apache.cassandra.config.Config
 
otc_coalescing_window_us_default - Static variable in class org.apache.cassandra.config.Config
 
otherOptions - Variable in class org.apache.cassandra.io.compress.CompressionParameters
 
oType - Variable in class org.apache.cassandra.cql3.statements.AlterTableStatement
 
out - Variable in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
 
out - Variable in class org.apache.cassandra.tools.AbstractJmxClient
 
outboundBindAny - Static variable in class org.apache.cassandra.config.Config
Deprecated.
No longer needed for streaming protocol. See CASSANDRA-12673 for details.
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
 
OutgoingFileMessage - Class in org.apache.cassandra.streaming.messages
OutgoingFileMessage is used to transfer the part(or whole) of a SSTable data file.
OutgoingFileMessage(Ref<SSTableReader>, int, long, List<Pair<Long, Long>>, long, boolean) - Constructor for class org.apache.cassandra.streaming.messages.OutgoingFileMessage
 
output(String) - Method in class org.apache.cassandra.hadoop.BulkRecordWriter.NullOutputHandler
Deprecated.
 
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
 
OUTPUT_LOCATION - Static variable in class org.apache.cassandra.hadoop.BulkRecordWriter
Deprecated.
 
OUTPUT_LOCATION - Static variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
outputFormatClass - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
outputFormatClass - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
OutputHandler - Interface in org.apache.cassandra.utils
 
OutputHandler.LogOutput - Class in org.apache.cassandra.utils
 
OutputHandler.SystemOutput - Class in org.apache.cassandra.utils
 
outSerializer - Variable in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
 
outTransportFactory - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
 
OverlapIterator<I extends java.lang.Comparable<? super I>,V> - Class in org.apache.cassandra.utils
A class for iterating sequentially through an ordered collection and efficiently finding the overlapping set of matching intervals.
OverlapIterator(Collection<Interval<I, V>>) - Constructor for class org.apache.cassandra.utils.OverlapIterator
 
overlaps(List<ByteBuffer>, List<ByteBuffer>, List<ByteBuffer>, List<ByteBuffer>, CellNameType) - Static method in class org.apache.cassandra.io.sstable.ColumnNameHelper
Checks if the given min/max column names could overlap (i.e they could share some column names based on the max/min column names in the sstables)
overlaps() - Method in class org.apache.cassandra.utils.OverlapIterator
 
OverloadedException - Exception in org.apache.cassandra.exceptions
 
OverloadedException(String) - Constructor for exception org.apache.cassandra.exceptions.OverloadedException
 
overrideReadMeter(RestorableMeter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
owner - Variable in class org.apache.cassandra.io.util.RandomAccessReader
 
ownershipRatio() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator.SubAllocator
 
owns - Variable in class org.apache.cassandra.tools.nodetool.HostStat
 
owns() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator.SubAllocator
 

P

P - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
P - Static variable in class org.apache.cassandra.cql3.CqlParser
 
pack(Collection<ByteBuffer>, int, int) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
 
Pageable - Interface in org.apache.cassandra.service.pager
Marker interface for commands that can be paged.
Pageable.ReadCommands - Class in org.apache.cassandra.service.pager
 
PagedRangeCommand - Class in org.apache.cassandra.db
 
PagedRangeCommand(String, String, long, AbstractBounds<RowPosition>, SliceQueryFilter, Composite, Composite, List<IndexExpression>, int, boolean) - Constructor for class org.apache.cassandra.db.PagedRangeCommand
 
pager(Pageable, ConsistencyLevel, ClientState) - Static method in class org.apache.cassandra.service.pager.QueryPagers
 
pager(Pageable, ConsistencyLevel, ClientState, PagingState) - Static method in class org.apache.cassandra.service.pager.QueryPagers
 
pageRowLocally(ColumnFamilyStore, ByteBuffer, int) - Static method in class org.apache.cassandra.service.pager.QueryPagers
Convenience method to (locally) page an internal row.
Paging(AbstractBounds<RowPosition>, SliceQueryFilter, Composite, Composite, CFMetaData) - Constructor for class org.apache.cassandra.db.DataRange.Paging
 
PagingState - Class in org.apache.cassandra.service.pager
 
PagingState(ByteBuffer, ByteBuffer, int) - Constructor for class org.apache.cassandra.service.pager.PagingState
 
Pair<T1,T2> - Class in org.apache.cassandra.utils
 
Pair(T1, T2) - Constructor for class org.apache.cassandra.utils.Pair
 
PARALLELISM_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
parallelismDegree - Variable in class org.apache.cassandra.repair.RepairSession
 
ParameterizedClass - Class in org.apache.cassandra.config
 
ParameterizedClass(String, Map<String, String>) - Constructor for class org.apache.cassandra.config.ParameterizedClass
 
ParameterizedClass(LinkedHashMap<String, ?>) - Constructor for class org.apache.cassandra.config.ParameterizedClass
 
parameters - Variable in class org.apache.cassandra.config.ParameterizedClass
 
parameters - Variable in class org.apache.cassandra.cql3.statements.SelectStatement
 
Parameters(Map<ColumnIdentifier.Raw, Boolean>, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
 
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
 
parent() - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
 
PARENT_REPAIR_HISTORY - Static variable in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
parentRepairSession - Variable in class org.apache.cassandra.repair.messages.AnticompactionRequest
 
parentRepairSession - Variable in class org.apache.cassandra.repair.messages.CleanupMessage
 
parentRepairSession - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
 
parentRepairSession - Variable in class org.apache.cassandra.repair.RepairSession
 
ParentRepairSession(InetAddress, List<ColumnFamilyStore>, Collection<Range<Token>>, boolean, boolean, long) - Constructor for class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
parentSessionId - Variable in class org.apache.cassandra.repair.RepairJobDesc
 
parker - Variable in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
 
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.
parse(Map<String, String>, IPartitioner) - Static method in class org.apache.cassandra.repair.messages.RepairOption
Construct RepairOptions object from given map of Strings.
parseChunkLength(String) - Static method in class org.apache.cassandra.io.compress.CompressionParameters
Parse the chunk length (in KB) and returns it as bytes.
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
 
parseCqlCollectionOrFrozenType(String) - Static method in class org.apache.cassandra.db.marshal.TypeParser
 
parseCqlName(String) - Static method in class org.apache.cassandra.db.marshal.TypeParser
Turns user facing type names into Abstract Types, 'text' -> UTF8Type
parseCqlNativeType(String) - Static method in class org.apache.cassandra.db.marshal.TypeParser
 
Parsed(BatchStatement.Type, Attributes.Raw, List<ModificationStatement.Parsed>) - Constructor for class org.apache.cassandra.cql3.statements.BatchStatement.Parsed
 
Parsed(CFName, Attributes.Raw, List<Operation.RawDeletion>, List<Relation>, List<Pair<ColumnIdentifier.Raw, ColumnCondition.Raw>>, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DeleteStatement.Parsed
 
Parsed(CFName, Attributes.Raw, List<Pair<ColumnIdentifier.Raw, ColumnCondition.Raw>>, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
 
parseDefaultParameters(AbstractType<?>, TypeParser) - Static method in class org.apache.cassandra.db.marshal.AbstractType
 
ParsedInsert(CFName, Attributes.Raw, List<ColumnIdentifier.Raw>, List<Term.Raw>, boolean) - Constructor for class org.apache.cassandra.cql3.statements.UpdateStatement.ParsedInsert
A parsed INSERT statement.
ParsedInsertJson(CFName, Attributes.Raw, Json.Raw, boolean) - Constructor for class org.apache.cassandra.cql3.statements.UpdateStatement.ParsedInsertJson
 
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
 
ParsedUpdate(CFName, Attributes.Raw, List<Pair<ColumnIdentifier.Raw, Operation.RawUpdate>>, List<Relation>, List<Pair<ColumnIdentifier.Raw, ColumnCondition.Raw>>, boolean) - Constructor for class org.apache.cassandra.cql3.statements.UpdateStatement.ParsedUpdate
Creates a new UpdateStatement from a column family name, columns map, consistency level, and key term.
parseHintedHandoffEnabledDCs(String) - Static method in class org.apache.cassandra.config.Config
 
parseJson(String, Collection<ColumnDefinition>) - Static method in class org.apache.cassandra.cql3.Json
Given a JSON string, return a map of columns to their values for the insert.
parseOptionalColumnFamilies(List<String>) - Method in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
 
parseOptionalKeyspace(List<String>, NodeProbe) - Method in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
 
parseOptionalKeyspace(List<String>, NodeProbe, boolean) - Method in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
 
parseStatement(String, QueryState) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
parseStatement(String) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
parseType(String) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
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.StorageHelper
Deprecated.
 
partitionCount() - Method in class org.apache.cassandra.db.Memtable
 
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.io.sstable.metadata.ValidationMetadata
 
partitioner - Variable in class org.apache.cassandra.io.sstable.SSTable
 
partitioner() - Method in class org.apache.cassandra.utils.MerkleTree
 
partitionerClass - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
partitionerClass - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
partitionKey - Variable in class org.apache.cassandra.cache.CounterCacheKey
 
partitionKey - Variable in class org.apache.cassandra.service.pager.PagingState
 
partitionKeyBindIndexes - Variable in class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
 
partitionKeyColumns() - Method in class org.apache.cassandra.config.CFMetaData
 
partitionKeyDef(CFMetaData, ByteBuffer, AbstractType<?>, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
partitionKeyDef(String, String, ByteBuffer, AbstractType<?>, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
passiveAnnounce(UUID) - Static method in class org.apache.cassandra.service.MigrationManager
Announce my version passively over gossip.
password - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
password - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
password - Variable in class org.apache.cassandra.tools.AbstractJmxClient
 
PASSWORD_KEY - Static variable in class org.apache.cassandra.auth.PasswordAuthenticator
 
PasswordAuthenticator - Class in org.apache.cassandra.auth
PasswordAuthenticator is an IAuthenticator implementation that keeps credentials (rolenames and bcrypt-hashed passwords) internally in C* - in system_auth.roles CQL3 table.
PasswordAuthenticator() - Constructor for class org.apache.cassandra.auth.PasswordAuthenticator
 
patch - Variable in class org.apache.cassandra.utils.CassandraVersion
 
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.sstable.SnapshotDeletingTask
 
path() - Method in class org.apache.cassandra.io.util.SegmentedFile
 
Path<V> - Class in org.apache.cassandra.utils.btree
An internal class for searching and iterating through a tree.
pause() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
For internal, temporary suspension of background compactions so that we can do exceptional things like truncate or major compaction
pauseDeletions(boolean) - Static method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
 
PauseHandoff - Class in org.apache.cassandra.tools.nodetool
 
PauseHandoff() - Constructor for class org.apache.cassandra.tools.nodetool.PauseHandoff
 
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
 
PAXOS - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
PaxosState - Class in org.apache.cassandra.service.paxos
 
PaxosState(ByteBuffer, CFMetaData) - Constructor for class org.apache.cassandra.service.paxos.PaxosState
 
PaxosState(Commit, Commit, Commit) - Constructor for class org.apache.cassandra.service.paxos.PaxosState
 
paxosTtl(CFMetaData) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
payload - Variable in class org.apache.cassandra.net.MessageIn
 
payload - Variable in class org.apache.cassandra.net.MessageOut
 
payloadSize(int) - Method in class org.apache.cassandra.net.MessageOut
Calculate the size of the payload of this message for the specified protocol version and memoize the result for the specified protocol version.
peer - Variable in class org.apache.cassandra.io.util.Memory
 
peer - Variable in class org.apache.cassandra.streaming.ProgressInfo
 
peer - Variable in class org.apache.cassandra.streaming.SessionInfo
 
peer - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
 
peer - Variable in class org.apache.cassandra.streaming.StreamSession
Streaming endpoint.
PEER_EVENTS - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
PEERS - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
pending - Variable in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
 
pendingCompactions - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Estimate of number of pending compactios for this CF
pendingCompactions - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Estimate of number of pending compactios for this CF
pendingDeletionCount() - Static method in class org.apache.cassandra.io.sstable.SnapshotDeletingTask
 
pendingEndpoints - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
pendingEndpointsFor(Token) - Method in class org.apache.cassandra.locator.PendingRangeMaps
 
pendingEndpointsFor(Token, String) - Method in class org.apache.cassandra.locator.TokenMetadata
 
pendingFlushes - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Estimated number of tasks pending for this column family
pendingFlushes - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Estimated number of tasks pending for this column family
PendingRangeCalculatorService - Class in org.apache.cassandra.service
 
PendingRangeCalculatorService() - Constructor for class org.apache.cassandra.service.PendingRangeCalculatorService
 
pendingRangeChanges(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
PendingRangeMaps - Class in org.apache.cassandra.locator
 
PendingRangeMaps() - Constructor for class org.apache.cassandra.locator.PendingRangeMaps
 
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.SEPMetrics
Number of tasks waiting to be executed.
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
 
performAnticompaction(ColumnFamilyStore, Collection<Range<Token>>, Refs<SSTableReader>, LifecycleTransaction, long) - Method in class org.apache.cassandra.db.compaction.CompactionManager
Make sure the {validatedForRepair} are marked for compaction before calling this.
performCleanup(ColumnFamilyStore, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
performMaximal(ColumnFamilyStore, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
performScrub(ColumnFamilyStore, boolean, boolean, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
performScrub(ColumnFamilyStore, boolean, boolean, boolean, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
performSSTableRewrite(ColumnFamilyStore, boolean, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
performVerify(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
 
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.ListPermissionsStatement
 
permissions - Variable in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
 
permissions_cache_max_entries - Variable in class org.apache.cassandra.config.Config
 
permissions_update_interval_in_ms - Variable in class org.apache.cassandra.config.Config
 
permissions_validity_in_ms - Variable in class org.apache.cassandra.config.Config
 
PermissionsCache - Class in org.apache.cassandra.auth
 
PermissionsCache(IAuthorizer) - Constructor for class org.apache.cassandra.auth.PermissionsCache
 
PermissionsCacheMBean - Interface in org.apache.cassandra.auth
 
PermissionsManagementStatement - Class in org.apache.cassandra.cql3.statements
 
PermissionsManagementStatement(Set<Permission>, IResource, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
 
permitCompactionOfFlushed(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.Tracker
permit compaction of the provided sstable; this translates to notifying compaction strategies of its existence, and potentially submitting a background task
permitRedundantTransitions() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
permitRedundantTransitions() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
 
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
 
persistLocalMetadata() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
persistSSTableReadMeter(String, String, int, RestorableMeter) - Static method in class org.apache.cassandra.db.SystemKeyspace
Writes the current read rates for a given SSTable to system.sstable_activity
phi_convict_threshold - Variable in class org.apache.cassandra.config.Config
 
PIG_ALLOW_DELETES - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
PIG_INITIAL_ADDRESS - Static variable in class org.apache.cassandra.hadoop.pig.StorageHelper
Deprecated.
 
PIG_INPUT_FORMAT - Static variable in class org.apache.cassandra.hadoop.pig.StorageHelper
Deprecated.
 
PIG_INPUT_INITIAL_ADDRESS - Static variable in class org.apache.cassandra.hadoop.pig.StorageHelper
Deprecated.
 
PIG_INPUT_PARTITIONER - Static variable in class org.apache.cassandra.hadoop.pig.StorageHelper
Deprecated.
 
PIG_INPUT_RPC_PORT - Static variable in class org.apache.cassandra.hadoop.pig.StorageHelper
Deprecated.
 
PIG_INPUT_SPLIT_SIZE - Static variable in class org.apache.cassandra.hadoop.pig.StorageHelper
Deprecated.
 
PIG_OUTPUT_FORMAT - Static variable in class org.apache.cassandra.hadoop.pig.StorageHelper
Deprecated.
 
PIG_OUTPUT_INITIAL_ADDRESS - Static variable in class org.apache.cassandra.hadoop.pig.StorageHelper
Deprecated.
 
PIG_OUTPUT_PARTITIONER - Static variable in class org.apache.cassandra.hadoop.pig.StorageHelper
Deprecated.
 
PIG_OUTPUT_RPC_PORT - Static variable in class org.apache.cassandra.hadoop.pig.StorageHelper
Deprecated.
 
PIG_PARTITIONER - Static variable in class org.apache.cassandra.hadoop.pig.StorageHelper
Deprecated.
 
PIG_RPC_PORT - Static variable in class org.apache.cassandra.hadoop.pig.StorageHelper
Deprecated.
 
PIG_USE_SECONDARY - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
PIG_WIDEROW_INPUT - Static variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
pkDef(CreateTableStatement.RawStatement) - Method in class org.apache.cassandra.cql3.CqlParser
 
planId - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
 
planId - Variable in class org.apache.cassandra.streaming.StreamEvent
 
planId - Variable in class org.apache.cassandra.streaming.StreamResultFuture
 
planId() - Method in class org.apache.cassandra.streaming.StreamSession
 
planId - Variable in class org.apache.cassandra.streaming.StreamState
 
pointInTimeExceeded(Mutation) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
policy - Static variable in class org.apache.cassandra.cql3.Attributes
 
pollFirst() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
pollLast() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
PoolingSegmentedFile - Class in org.apache.cassandra.io.util
 
PoolingSegmentedFile(PoolingSegmentedFile.Cleanup, ChannelProxy, long) - Constructor for class org.apache.cassandra.io.util.PoolingSegmentedFile
 
PoolingSegmentedFile(PoolingSegmentedFile.Cleanup, ChannelProxy, long, long) - Constructor for class org.apache.cassandra.io.util.PoolingSegmentedFile
 
PoolingSegmentedFile(PoolingSegmentedFile) - Constructor for class org.apache.cassandra.io.util.PoolingSegmentedFile
 
PoolingSegmentedFile.Cleanup - Class in org.apache.cassandra.io.util
 
port - Variable in class org.apache.cassandra.thrift.ThriftServer
 
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() - Method in class org.apache.cassandra.config.ColumnDefinition
 
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
 
postfixSize() - Method in class org.apache.cassandra.db.AbstractNativeCell
 
postfixSize() - Method in class org.apache.cassandra.db.NativeCounterCell
 
postfixSize() - Method in class org.apache.cassandra.db.NativeExpiringCell
 
postReconciliationProcessing(List<Row>) - Method in class org.apache.cassandra.db.AbstractRangeCommand
 
postReconciliationProcessing(List<IndexExpression>, List<Row>) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
Combines index query results from multiple nodes.
precision - Variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
predicate - Variable in class org.apache.cassandra.db.AbstractRangeCommand
 
preferredBufferType() - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
preferredBufferType() - Method in interface org.apache.cassandra.io.compress.ICompressor
Returns the preferred (most efficient) buffer type for this compressor.
preferredBufferType() - Method in class org.apache.cassandra.io.compress.LZ4Compressor
 
preferredBufferType() - Method in class org.apache.cassandra.io.compress.SnappyCompressor
 
prefix - Variable in class org.apache.cassandra.db.CFRowAdder
 
prefixBuilder() - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
 
prefixBuilder() - Method in interface org.apache.cassandra.db.composites.CellNameType
A builder for the clustering prefix.
prefixBuilder() - Method in class org.apache.cassandra.db.composites.SimpleDenseCellNameType
 
prefixBuilder() - Method in class org.apache.cassandra.db.composites.SimpleSparseCellNameType
 
prefixComparisonResult - Variable in enum org.apache.cassandra.db.composites.Composite.EOC
 
PreHashedDecoratedKey - Class in org.apache.cassandra.db
 
PreHashedDecoratedKey(Token, ByteBuffer, long, long) - Constructor for class org.apache.cassandra.db.PreHashedDecoratedKey
 
premature - Variable in class org.apache.cassandra.db.lifecycle.View
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.AbstractMarker.INRaw
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
 
prepare(String, String) - Method in class org.apache.cassandra.cql3.Attributes.Raw
 
prepare(String, ColumnDefinition) - Method in class org.apache.cassandra.cql3.ColumnCondition.Raw
 
prepare(CFMetaData) - Method in class org.apache.cassandra.cql3.ColumnIdentifier.Raw
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Constants.Literal
 
prepare(String) - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
prepare(String, QueryState, Map<String, ByteBuffer>) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Lists.Literal
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Maps.Literal
 
prepare(String, ColumnDefinition) - Method in class org.apache.cassandra.cql3.Operation.Addition
 
prepare(String, ColumnDefinition) - Method in class org.apache.cassandra.cql3.Operation.ColumnDeletion
 
prepare(String, ColumnDefinition) - Method in class org.apache.cassandra.cql3.Operation.ElementDeletion
 
prepare(String, ColumnDefinition) - Method in class org.apache.cassandra.cql3.Operation.Prepend
 
prepare(String, ColumnDefinition) - Method in interface org.apache.cassandra.cql3.Operation.RawDeletion
This method validates the operation (i.e.
prepare(String, ColumnDefinition) - Method in interface org.apache.cassandra.cql3.Operation.RawUpdate
This method validates the operation (i.e.
prepare(String, ColumnDefinition) - Method in class org.apache.cassandra.cql3.Operation.SetElement
 
prepare(String, ColumnDefinition) - Method in class org.apache.cassandra.cql3.Operation.SetValue
 
prepare(String, ColumnDefinition) - Method in class org.apache.cassandra.cql3.Operation.Substraction
 
prepare(String, QueryState, Map<String, ByteBuffer>) - Method in interface org.apache.cassandra.cql3.QueryHandler
 
prepare(List<ColumnSpecification>) - Method in class org.apache.cassandra.cql3.QueryOptions
 
prepare(String, QueryState, Map<String, ByteBuffer>) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
prepare(String, QueryState) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
prepare(String, ClientState, boolean) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
prepare(CFMetaData) - Method in interface org.apache.cassandra.cql3.selection.Selectable.Raw
 
prepare(CFMetaData) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection.Raw
 
prepare(CFMetaData) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFunction.Raw
 
prepare(CFMetaData) - Method in class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL.Raw
 
prepare(String, 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() - Method in class org.apache.cassandra.cql3.statements.BatchStatement.Parsed
 
prepare() - Method in class org.apache.cassandra.cql3.statements.CreateAggregateStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.CreateFunctionStatement
 
prepare() - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
Transform this raw statement into a CreateTableStatement.
prepare() - Method in class org.apache.cassandra.cql3.statements.DropFunctionStatement
 
prepare(CFMetaData) - Method in class org.apache.cassandra.cql3.statements.IndexTarget.Raw
 
prepare() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
 
prepare(VariableSpecifications) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
 
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() - Method in class org.apache.cassandra.cql3.statements.UseStatement
 
prepare(String, List<? extends ColumnSpecification>) - Method in interface org.apache.cassandra.cql3.Term.MultiColumnRaw
 
prepare(String, 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(String, List<? extends ColumnSpecification>) - Method in class org.apache.cassandra.cql3.Tuples.INRaw
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Tuples.INRaw
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Tuples.Literal
 
prepare(String, List<? extends ColumnSpecification>) - Method in class org.apache.cassandra.cql3.Tuples.Literal
 
prepare(String, List<? extends ColumnSpecification>) - Method in class org.apache.cassandra.cql3.Tuples.Raw
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Tuples.Raw
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.TypeCast
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.UserTypes.Literal
 
prepare(ColumnFamilyStore, MerkleTree) - Method in class org.apache.cassandra.repair.Validator
 
prepare(Commit) - Static method in class org.apache.cassandra.service.paxos.PaxosState
 
prepare(Collection<StreamRequest>, Collection<StreamSummary>) - Method in class org.apache.cassandra.streaming.StreamSession
Prepare this session for sending/receiving files.
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
 
prepareAndCollectMarkers(CFMetaData, Collection<ColumnDefinition>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Json.Literal
 
prepareAndCollectMarkers(CFMetaData, Collection<ColumnDefinition>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Json.Marker
 
prepareAndCollectMarkers(CFMetaData, Collection<ColumnDefinition>, VariableSpecifications) - Method in interface org.apache.cassandra.cql3.Json.Raw
 
PrepareCallback - Class in org.apache.cassandra.service.paxos
 
PrepareCallback(ByteBuffer, CFMetaData, int, ConsistencyLevel) - Constructor for class org.apache.cassandra.service.paxos.PrepareCallback
 
Prepared(String) - Constructor for class org.apache.cassandra.cql3.Json.Prepared
 
Prepared(CQLStatement, List<ColumnSpecification>, Short[]) - Constructor for class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
 
Prepared(CQLStatement, VariableSpecifications, Short[]) - Constructor for class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
 
Prepared(CQLStatement) - Constructor for class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
 
Prepared(MD5Digest, ParsedStatement.Prepared) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Prepared
 
PreparedMetadata(List<ColumnSpecification>, Short[]) - Constructor for class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
 
PreparedQueryNotFoundException - Exception in org.apache.cassandra.exceptions
 
PreparedQueryNotFoundException(MD5Digest) - Constructor for exception org.apache.cassandra.exceptions.PreparedQueryNotFoundException
 
preparedStatementsCount() - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
preparedStatementsCount - Variable in class org.apache.cassandra.metrics.CQLMetrics
 
preparedStatementsEvicted - Variable in class org.apache.cassandra.metrics.CQLMetrics
 
preparedStatementsExecuted - Variable in class org.apache.cassandra.metrics.CQLMetrics
 
preparedStatementsRatio - Variable in class org.apache.cassandra.metrics.CQLMetrics
 
prepareForRepair(UUID, InetAddress, Set<InetAddress>, RepairOption, List<ColumnFamilyStore>) - Method in class org.apache.cassandra.service.ActiveRepairService
 
prepareInternal(String) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
prepareInternal(CFMetaData, VariableSpecifications, Attributes) - Method in class org.apache.cassandra.cql3.statements.DeleteStatement.Parsed
 
prepareInternal(CFMetaData, VariableSpecifications, Attributes) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
 
prepareInternal(CFMetaData, VariableSpecifications, Attributes) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement.ParsedInsert
 
prepareInternal(CFMetaData, VariableSpecifications, Attributes) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement.ParsedInsertJson
 
prepareInternal(CFMetaData, VariableSpecifications, Attributes) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement.ParsedUpdate
 
prepareKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
 
prepareKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement.Parsed
 
prepareKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.CFStatement
 
prepareKeyspace(String) - Method in class org.apache.cassandra.cql3.statements.CFStatement
 
prepareKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateAggregateStatement
 
prepareKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateFunctionStatement
 
prepareKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
 
prepareKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropAggregateStatement
 
prepareKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropFunctionStatement
 
prepareKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTypeStatement
 
prepareKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
 
PrepareMessage - Class in org.apache.cassandra.repair.messages
 
PrepareMessage(UUID, List<UUID>, Collection<Range<Token>>, boolean, boolean) - Constructor for class org.apache.cassandra.repair.messages.PrepareMessage
 
PrepareMessage - Class in org.apache.cassandra.streaming.messages
 
PrepareMessage() - Constructor for class org.apache.cassandra.streaming.messages.PrepareMessage
 
PrepareMessage - Class in org.apache.cassandra.transport.messages
 
PrepareMessage(String) - Constructor for class org.apache.cassandra.transport.messages.PrepareMessage
 
PrepareMessage.PrepareMessageSerializer - Class in org.apache.cassandra.repair.messages
 
PrepareMessageSerializer(boolean) - Constructor for class org.apache.cassandra.repair.messages.PrepareMessage.PrepareMessageSerializer
 
prepareReplacementInfo() - Method in class org.apache.cassandra.service.StorageService
 
PrepareResponse - Class in org.apache.cassandra.service.paxos
 
PrepareResponse(boolean, Commit, Commit) - Constructor for class org.apache.cassandra.service.paxos.PrepareResponse
 
PrepareResponse.PrepareResponseSerializer - Class in org.apache.cassandra.service.paxos
 
PrepareResponseSerializer() - Constructor for class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
 
prepareStatement(int, List<ColumnSpecification>) - Method in class org.apache.cassandra.cql3.BatchQueryOptions
 
prepareToCommit() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
prepareToCommit() - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
prepareToCommit() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
prepareToCommit() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
The first phase of commit: delegates to doPrepare(), with valid state transition enforcement.
prepareToCommit() - Method in interface org.apache.cassandra.utils.concurrent.Transactional
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
prepareToRead(RecordReader, PigSplit) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
prepareToWrite(RecordWriter) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
prepare writer
prepareToWrite(RecordWriter) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
prepareTracingSession(UUID) - Method in class org.apache.cassandra.service.QueryState
 
PrepareVerbHandler - Class in org.apache.cassandra.service.paxos
 
PrepareVerbHandler() - Constructor for class org.apache.cassandra.service.paxos.PrepareVerbHandler
 
Prepend(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.Prepend
 
Prepender(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Lists.Prepender
 
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.ByteOrderedPartitioner
 
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
 
prettyPrintMemory(long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
previous - Variable in class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefix
 
PRIMARY_INDEX - Static variable in class org.apache.cassandra.io.sstable.Component
 
PRIMARY_RANGE_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
printDebugInfo() - Method in class org.apache.cassandra.utils.concurrent.Ref
 
printHelp(String, String) - Static method in class org.apache.cassandra.tools.AbstractJmxClient
 
printPendingRanges() - Method in class org.apache.cassandra.locator.PendingRangeMaps
 
printStack - Variable in class org.apache.cassandra.utils.OutputHandler.SystemOutput
 
priority - Variable in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
 
process(String, QueryState, QueryOptions, Map<String, ByteBuffer>) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
 
process(String, QueryState, QueryOptions, Map<String, ByteBuffer>) - Method in interface org.apache.cassandra.cql3.QueryHandler
 
process(String, ConsistencyLevel, QueryState) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
process(String, QueryState, QueryOptions, Map<String, ByteBuffer>) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
process(String, QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
process(String, ConsistencyLevel) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
process(String, ConsistencyLevel, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
process(List<Row>) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
processArguments(String[]) - Static method in class org.apache.cassandra.tools.AbstractJmxClient
 
processBatch(BatchStatement, QueryState, BatchQueryOptions, Map<String, ByteBuffer>) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
 
processBatch(BatchStatement, QueryState, BatchQueryOptions, Map<String, ByteBuffer>) - Method in interface org.apache.cassandra.cql3.QueryHandler
 
processBatch(BatchStatement, QueryState, BatchQueryOptions, Map<String, ByteBuffer>) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
processBatch(BatchStatement, QueryState, BatchQueryOptions) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
processedKeys - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement
 
processesSelection() - Method in class org.apache.cassandra.cql3.ColumnIdentifier.Raw
 
processesSelection() - Method in class org.apache.cassandra.cql3.selection.RawSelector
 
processesSelection() - Method in interface org.apache.cassandra.cql3.selection.Selectable.Raw
Returns true if any processing is performed on the selected column.
processesSelection() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection.Raw
 
processesSelection() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFunction.Raw
 
processesSelection() - Method in class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL.Raw
 
processor - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
 
processPrepared(CQLStatement, QueryState, QueryOptions, Map<String, ByteBuffer>) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
 
processPrepared(CQLStatement, QueryState, QueryOptions, Map<String, ByteBuffer>) - Method in interface org.apache.cassandra.cql3.QueryHandler
 
processPrepared(CQLStatement, QueryState, QueryOptions, Map<String, ByteBuffer>) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
processPrepared(CQLStatement, QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
processResults(List<Row>, QueryOptions, int, long) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
processStatement(CQLStatement, QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
processWhereClause(List<Relation>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
progress - Variable in class org.apache.cassandra.hadoop.BulkRecordWriter
Deprecated.
 
progress - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
progress(TaskAttemptContext) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
Invoke TaskAttemptContext.progress().
progress() - Method in class org.apache.cassandra.hadoop.ReporterWrapper
 
progress - Variable in class org.apache.cassandra.streaming.StreamEvent.ProgressEvent
 
progress(Descriptor, ProgressInfo.Direction, long, long) - Method in class org.apache.cassandra.streaming.StreamSession
 
progress(String, ProgressEvent) - Method in class org.apache.cassandra.tools.BootstrapMonitor
 
progress(String, ProgressEvent) - Method in class org.apache.cassandra.tools.RepairRunner
 
progress(String, ProgressEvent) - Method in class org.apache.cassandra.utils.progress.jmx.JMXProgressSupport
 
progress(String, ProgressEvent) - Method in class org.apache.cassandra.utils.progress.jmx.LegacyJMXProgressSupport
 
progress(String, ProgressEvent) - Method in interface org.apache.cassandra.utils.progress.ProgressListener
Called when some progress is made by progress publisher.
ProgressEvent(UUID, ProgressInfo) - Constructor for class org.apache.cassandra.streaming.StreamEvent.ProgressEvent
 
ProgressEvent - Class in org.apache.cassandra.utils.progress
Progress event
ProgressEvent(ProgressEventType, int, int) - Constructor for class org.apache.cassandra.utils.progress.ProgressEvent
 
ProgressEvent(ProgressEventType, int, int, String) - Constructor for class org.apache.cassandra.utils.progress.ProgressEvent
 
ProgressEventNotifier - Interface in org.apache.cassandra.utils.progress
Interface for ProgressEvent publisher.
ProgressEventNotifierSupport - Class in org.apache.cassandra.utils.progress
Provides basic, thread safe ProgressEvent notification support
ProgressEventNotifierSupport() - Constructor for class org.apache.cassandra.utils.progress.ProgressEventNotifierSupport
 
ProgressEventType - Enum in org.apache.cassandra.utils.progress
Progress event type.
ProgressInfo - Class in org.apache.cassandra.streaming
ProgressInfo contains file transfer progress.
ProgressInfo(InetAddress, int, String, ProgressInfo.Direction, long, long) - Constructor for class org.apache.cassandra.streaming.ProgressInfo
 
ProgressInfo.Direction - Enum in org.apache.cassandra.streaming
Direction of the stream.
ProgressInfoCompositeData - Class in org.apache.cassandra.streaming.management
 
ProgressInfoCompositeData() - Constructor for class org.apache.cassandra.streaming.management.ProgressInfoCompositeData
 
ProgressListener - Interface in org.apache.cassandra.utils.progress
Listener interface to handle ProgressEvent
promised - Variable in class org.apache.cassandra.service.paxos.PrepareCallback
 
promised - Variable in class org.apache.cassandra.service.paxos.PrepareResponse
 
promotedSize(ISerializer<T>) - Method in class org.apache.cassandra.db.RowIndexEntry
 
properties(PropertyDefinitions) - Method in class org.apache.cassandra.cql3.CqlParser
 
properties - Variable in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
 
properties - Variable in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
property(PropertyDefinitions) - Method in class org.apache.cassandra.cql3.CqlParser
 
PROPERTY_KEY - Static variable in interface org.apache.cassandra.thrift.ITransportFactory
 
PROPERTY_PREFIX - Static variable in class org.apache.cassandra.config.Config
 
PropertyDefinitions - Class in org.apache.cassandra.cql3.statements
 
PropertyDefinitions() - Constructor for class org.apache.cassandra.cql3.statements.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
 
PropertyFileSnitch(int) - Constructor for class org.apache.cassandra.locator.PropertyFileSnitch
 
propertyValue() - Method in class org.apache.cassandra.cql3.CqlParser
 
propose(Commit) - Static method in class org.apache.cassandra.service.paxos.PaxosState
 
ProposeCallback - Class in org.apache.cassandra.service.paxos
ProposeCallback has two modes of operation, controlled by the failFast parameter.
ProposeCallback(int, int, boolean, ConsistencyLevel) - Constructor for class org.apache.cassandra.service.paxos.ProposeCallback
 
ProposeVerbHandler - Class in org.apache.cassandra.service.paxos
 
ProposeVerbHandler() - Constructor for class org.apache.cassandra.service.paxos.ProposeVerbHandler
 
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 class org.apache.cassandra.auth.CassandraRoleManager
 
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 interface org.apache.cassandra.auth.IRoleManager
Set of resources that should be made inaccessible to users and only accessible internally.
protectedResources() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
protocol - Variable in class org.apache.cassandra.config.EncryptionOptions
 
PROTOCOL - Static variable in class org.apache.cassandra.thrift.SSLTransportFactory
 
PROTOCOL_MAGIC - Static variable in class org.apache.cassandra.net.MessagingService
we preface every message with this number so the recipient can validate the sender is sane
PROTOCOL_VERSION_MASK - Static variable in class org.apache.cassandra.transport.Frame
 
ProtocolDecoder() - Constructor for class org.apache.cassandra.transport.Message.ProtocolDecoder
 
ProtocolEncoder() - Constructor for class org.apache.cassandra.transport.Message.ProtocolEncoder
 
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
 
ProxyHistograms - Class in org.apache.cassandra.tools.nodetool
 
ProxyHistograms() - Constructor for class org.apache.cassandra.tools.nodetool.ProxyHistograms
 
prune(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
 
prune(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
 
PureJavaCrc32 - Class in org.apache.cassandra.utils
NOTE: You should be using CRCFactory class because it will pick a better version based on your JDK version 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.
PureJavaOperations() - Constructor for class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
 
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.
purgeEvaluator - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
purgeTombstones(int) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
Purges any tombstones with a local deletion time before gcBefore.
purgeTombstones(int) - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
purgeTombstones(int) - Method in class org.apache.cassandra.db.ColumnFamily
Purges top-level and range tombstones whose localDeletionTime 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(long, Memory, long, long) - Method in class org.apache.cassandra.io.util.Memory
 
put(FileCacheService.CacheKey, RandomAccessReader) - Method in class org.apache.cassandra.service.FileCacheService
 
put(K, V) - Method in class org.apache.cassandra.utils.BiMultiValMap
 
put(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
put(K, V) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
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 K, ? extends V>) - Method in class org.apache.cassandra.utils.BiMultiValMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
putCachedCounter(ByteBuffer, CellName, ClockAndCount) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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
 
putIntByByte(long, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
putLongByByte(long, long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
putNext(Tuple) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
write next row
putNext(Tuple) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
output: (((name, value), (name, value)), (value ...
Putter(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Maps.Putter
 

Q

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.cql3.CqlLexer
 
QMARK - Static variable in class org.apache.cassandra.cql3.CqlParser
 
QUARANTINE_DELAY - Static variable in class org.apache.cassandra.gms.Gossiper
 
query() - Method in class org.apache.cassandra.cql3.CqlParser
 
query - Variable in class org.apache.cassandra.transport.messages.QueryMessage
 
QueryFilter - Class in org.apache.cassandra.db.filter
 
QueryFilter(DecoratedKey, String, IDiskAtomFilter, long) - Constructor for class org.apache.cassandra.db.filter.QueryFilter
 
QueryHandler - Interface in org.apache.cassandra.cql3
 
QueryMessage - Class in org.apache.cassandra.transport.messages
A CQL query
QueryMessage(String, QueryOptions) - Constructor for class org.apache.cassandra.transport.messages.QueryMessage
 
queryNextPage(int, ConsistencyLevel, boolean) - Method in class org.apache.cassandra.service.pager.RangeNamesQueryPager
 
queryNextPage(int, ConsistencyLevel, boolean) - Method in class org.apache.cassandra.service.pager.RangeSliceQueryPager
 
queryNextPage(int, ConsistencyLevel, boolean) - Method in class org.apache.cassandra.service.pager.SliceQueryPager
 
QueryOptions - Class in org.apache.cassandra.cql3
Options for a query.
QueryOptions() - Constructor for class org.apache.cassandra.cql3.QueryOptions
 
queryOrIdList - Variable in class org.apache.cassandra.transport.messages.BatchMessage
 
QueryPager - Interface in org.apache.cassandra.service.pager
Perform a query, paging it by page of a given size.
QueryPagers - Class in org.apache.cassandra.service.pager
Static utility methods to create query pagers.
QueryProcessor - Class in org.apache.cassandra.cql3
 
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(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 - Variable in class org.apache.cassandra.transport.SimpleClient.SimpleEventHandler
 
QUEUE_SIZE - Static variable in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Deprecated.
 
quoteAsJsonString(String) - Static method in class org.apache.cassandra.cql3.Json
Quotes string contents using standard JSON quoting.
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.cql3.CqlLexer
 
R - Static variable in class org.apache.cassandra.cql3.CqlParser
 
r1 - Variable in class org.apache.cassandra.repair.SyncTask
 
r2 - Variable in class org.apache.cassandra.repair.SyncTask
 
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(ChannelProxy, int, long, BufferType, 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
RandomPartitioner - Class in org.apache.cassandra.dht
This class generates a BigIntegerToken using MD5 hash.
RandomPartitioner() - Constructor for class org.apache.cassandra.dht.RandomPartitioner
 
RandomPartitioner.BigIntegerToken - Class in org.apache.cassandra.dht
 
Range<T extends RingPosition<T>> - 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 - Variable in class org.apache.cassandra.repair.RepairJobDesc
repairing range
range - Variable in class org.apache.cassandra.repair.RepairSession
Range to repair
range - Variable in class org.apache.cassandra.repair.RepairSessionResult
 
Range.OrderedRangeContainmentChecker - Class in org.apache.cassandra.dht
Helper class to check if a token is contained within a given collection of ranges
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 - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
rangeCount() - Method in class org.apache.cassandra.db.DeletionInfo
 
rangeCovering(Composite) - Method in class org.apache.cassandra.db.DeletionInfo
 
rangeIterator() - Method in class org.apache.cassandra.db.DeletionInfo
 
rangeIterator(Composite, Composite) - Method in class org.apache.cassandra.db.DeletionInfo
 
RangeKeySample - Class in org.apache.cassandra.tools.nodetool
 
RangeKeySample() - Constructor for class org.apache.cassandra.tools.nodetool.RangeKeySample
 
rangeLatency - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
(Local) range slice metrics
rangeLatency - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
(Local) range slice metrics
RangeNamesQueryPager - Class in org.apache.cassandra.service.pager
Pages a RangeSliceCommand whose predicate is a name query.
ranges - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
 
ranges - Variable in class org.apache.cassandra.repair.messages.SyncRequest
 
ranges - Variable in class org.apache.cassandra.streaming.StreamRequest
 
RANGES_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
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, long, IDiskAtomFilter, AbstractBounds<RowPosition>, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
 
RangeSliceCommand(String, String, long, IDiskAtomFilter, AbstractBounds<RowPosition>, List<IndexExpression>, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
 
RangeSliceCommand(String, String, long, IDiskAtomFilter, AbstractBounds<RowPosition>, List<IndexExpression>, int, boolean, boolean) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
 
RangeSliceQueryPager - Class in org.apache.cassandra.service.pager
Pages a RangeSliceCommand whose predicate is a slice query.
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, long) - 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, Collection<Token>, InetAddress, String, boolean, IEndpointSnitch, StreamStateStore) - Constructor for class org.apache.cassandra.dht.RangeStreamer
 
RangeStreamer.ExcludeLocalNodeFilter - Class in org.apache.cassandra.dht
Source filter which excludes the current node from source calculations
RangeStreamer.FailureDetectorSourceFilter - Class in org.apache.cassandra.dht
Source filter which excludes any endpoints that are not alive according to a failure detector.
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.
RangeTombstone - Class in org.apache.cassandra.db
 
RangeTombstone(Composite, Composite, long, int) - Constructor for class org.apache.cassandra.db.RangeTombstone
 
RangeTombstone(Composite, Composite, DeletionTime) - Constructor for class org.apache.cassandra.db.RangeTombstone
 
RangeTombstone.Serializer - Class in org.apache.cassandra.db
 
RangeTombstone.Tracker - Class in org.apache.cassandra.db
Tracks opened RangeTombstones when iterating over a partition.
RangeTombstoneList - Class in org.apache.cassandra.db
Data structure holding the range tombstones of a ColumnFamily.
RangeTombstoneList(Comparator<Composite>, int) - Constructor for class org.apache.cassandra.db.RangeTombstoneList
 
RangeTombstoneList.InOrderTester - Class in org.apache.cassandra.db
This object allow testing whether a given column (name/timestamp) is deleted or not by this RangeTombstoneList, assuming that the column given to this object are passed in (comparator) sorted order.
RangeTombstoneList.Serializer - Class in org.apache.cassandra.db
 
rangeTombstoneSerializer() - Method in class org.apache.cassandra.db.composites.AbstractCType
 
rangeTombstoneSerializer() - Method in interface org.apache.cassandra.db.composites.CType
 
Raw(int) - Constructor for class org.apache.cassandra.cql3.AbstractMarker.Raw
 
Raw() - Constructor for class org.apache.cassandra.cql3.Attributes.Raw
 
Raw(String, boolean) - Constructor for class org.apache.cassandra.cql3.ColumnIdentifier.Raw
 
Raw() - Constructor for class org.apache.cassandra.cql3.CQL3Type.Raw
 
Raw(FunctionName, List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.functions.FunctionCall.Raw
 
Raw(Selectable.Raw, ColumnIdentifier.Raw) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection.Raw
 
Raw(FunctionName, List<Selectable.Raw>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithFunction.Raw
 
Raw(ColumnIdentifier.Raw, boolean) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL.Raw
 
Raw(int) - Constructor for class org.apache.cassandra.cql3.Tuples.Raw
 
rawAddRow(ByteBuffer...) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
Adds a new row to the writer given already serialized values.
rawAddRow(List<ByteBuffer>) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
Adds a new row to the writer given already serialized values.
rawAddRow(Map<String, ByteBuffer>) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
Adds a new row to the writer given already serialized values.
rawColumnName - Variable in class org.apache.cassandra.cql3.statements.AlterTableStatement
 
rawMean() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
RawSelector - Class in org.apache.cassandra.cql3.selection
 
RawSelector(Selectable.Raw, ColumnIdentifier) - Constructor for class org.apache.cassandra.cql3.selection.RawSelector
 
RawStatement(CFName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
 
RawStatement(CFName, SelectStatement.Parameters, List<RawSelector>, List<Relation>, Term.Raw) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
 
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.ByteBufferDataInput
 
read(ByteBuffer, long) - Method in class org.apache.cassandra.io.util.ChannelProxy
 
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.MemoryInputStream
 
read(byte[], int, int) - Method in class org.apache.cassandra.io.util.NIODataInputStream
 
read() - Method in class org.apache.cassandra.io.util.NIODataInputStream
 
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, int) - Static method in class org.apache.cassandra.net.MessageIn
 
read(List<ReadCommand>, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
 
read(List<ReadCommand>, ConsistencyLevel, ClientState) - 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(ReadableByteChannel) - Method in class org.apache.cassandra.streaming.compress.CompressedStreamReader
 
read(ReadableByteChannel) - Method in class org.apache.cassandra.streaming.StreamReader
 
read(DataInput, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
read() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
 
read_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
ReadableBoundary(DecoratedKey, long, long, int, long) - Constructor for class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
 
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.io.util.NIODataInputStream
 
readBoolean() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readBoundValue(ByteBuf, int) - Static method in class org.apache.cassandra.transport.CBUtil
 
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.io.util.NIODataInputStream
 
readByte() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readBytes(int) - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
Does the same thing as readFully do but without copying data (thread safe)
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.RandomAccessReader
 
readBytes(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readBytes(DataInput, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
readBytes(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
readBytesMap(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readBytesWithShortLength(ByteBuffer) - 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.
ReadCallback(IResponseResolver<TMessage, TResolved>, ConsistencyLevel, int, IReadCommand, Keyspace, List<InetAddress>) - Constructor for class org.apache.cassandra.service.ReadCallback
 
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.io.util.NIODataInputStream
 
readChar() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readCollectionSize(ByteBuffer, int) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
 
readColumnFamily(List<ReadCommand>, ConsistencyLevel, ClientState) - Method in class org.apache.cassandra.thrift.CassandraServer
 
ReadCommand - Class in org.apache.cassandra.db
 
ReadCommand(String, ByteBuffer, String, long, ReadCommand.Type) - Constructor for class org.apache.cassandra.db.ReadCommand
 
ReadCommand.Type - Enum in org.apache.cassandra.db
 
ReadCommands(List<ReadCommand>, int) - Constructor for class org.apache.cassandra.service.pager.Pageable.ReadCommands
 
readConsistencyLevel(ByteBuf) - 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.io.util.NIODataInputStream
 
readDouble() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readEnumValue(Class<T>, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
ReaderState(LifecycleTransaction.ReaderState.Action, LifecycleTransaction.ReaderState.Action, SSTableReader, SSTableReader, boolean) - Constructor for class org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState
 
readException - Variable in class org.apache.cassandra.streaming.compress.CompressedInputStream
 
ReadFailureException - Exception in org.apache.cassandra.exceptions
 
ReadFailureException(ConsistencyLevel, int, int, int, boolean) - Constructor for exception org.apache.cassandra.exceptions.ReadFailureException
 
readFields(DataInput) - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
readFilter() - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
 
readFilter() - Method in interface org.apache.cassandra.service.CASRequest
The filter to use to fetch the value to compare for the CAS.
readFilterForCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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.io.util.NIODataInputStream
 
readFloat() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readFrom(DataInput) - Static method in enum org.apache.cassandra.cql3.Operator
Deserializes a Operator instance from the specified input.
readFrom(DataInput) - Static method in class org.apache.cassandra.db.IndexExpression
Deserializes an IndexExpression instance from the specified input.
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.ByteBufferDataInput
 
readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
 
readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
readFully(byte[]) - Method in class org.apache.cassandra.io.util.NIODataInputStream
 
readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.NIODataInputStream
 
readFully(byte[], int, int) - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readFully(byte[]) - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readHeader(DataInput) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
readInet(ByteBuf) - 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.io.util.NIODataInputStream
 
readInt() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readInt() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
 
readIsStatic(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
readIsStatic(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
readIsStatic(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
readLatency - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
(Local) read metrics
readLatency - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
(Local) 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.io.util.NIODataInputStream
 
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.io.util.NIODataInputStream
 
readLong() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readLong() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
 
readLongString(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readNameAndValueList(ByteBuf, int) - Static method in class org.apache.cassandra.transport.CBUtil
 
readNext() - Method in class org.apache.cassandra.db.AtomDeserializer
Returns the next atom.
readNext() - Method in interface org.apache.cassandra.db.composites.CellNameType.Deserializer
Actually consume the next name and return it.
readNextIdentifier() - Method in class org.apache.cassandra.db.marshal.TypeParser
 
readOrdering - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
readRawBytes(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
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
 
readRequiredRows(Collection<ByteBuffer>, Composite, boolean, ConsistencyLevel) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
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
 
ReadResponse(Row, ByteBuffer) - Constructor for class org.apache.cassandra.db.ReadResponse
 
readSchemaFromSystemTables() - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
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.io.util.NIODataInputStream
 
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
 
readShortLength(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
readString(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readStringList(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readStringMap(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readStringToStringListMap(ByteBuf) - 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
 
readTOC(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTable
Reads the list of components from the TOC component.
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.io.util.NIODataInputStream
 
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.io.util.NIODataInputStream
 
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.io.util.NIODataInputStream
 
readUTF() - Method in class org.apache.cassandra.utils.BytesReadTracker
 
readUUID(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readValue(ByteBuffer, int) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
 
readValue(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readValue(ByteBuf, int) - Method in enum org.apache.cassandra.transport.DataType
 
readValue(ByteBuf, int) - Method in interface org.apache.cassandra.transport.OptionCodec.Codecable
 
readValueList(ByteBuf, int) - Static method in class org.apache.cassandra.transport.CBUtil
 
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
 
reallocate(long) - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
reallocate(long) - Method in class org.apache.cassandra.io.util.DataOutputBufferFixed
 
reallocate(long) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
realMarkAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
 
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.ChecksummedRandomAccessReader
 
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() - Method in class org.apache.cassandra.config.CFMetaData
 
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
 
Rebuild - Class in org.apache.cassandra.tools.nodetool
 
Rebuild() - Constructor for class org.apache.cassandra.tools.nodetool.Rebuild
 
rebuildIndex(String, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
RebuildIndex - Class in org.apache.cassandra.tools.nodetool
 
RebuildIndex() - Constructor for class org.apache.cassandra.tools.nodetool.RebuildIndex
 
rebuildOnFailedScrub(Throwable) - Method in class org.apache.cassandra.db.ColumnFamilyStore
CASSANDRA-5174 : For an index cfs we may be able to discard everything and just rebuild the index when a scrub fails.
rebuildSecondaryIndex(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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, int, long, boolean) - Method in class org.apache.cassandra.net.MessagingService
 
receive(IncomingFileMessage) - Method in class org.apache.cassandra.streaming.StreamSession
Call back after receiving FileMessageHeader.
received - Variable in exception org.apache.cassandra.exceptions.RequestFailureException
 
received - Variable in exception org.apache.cassandra.exceptions.RequestTimeoutException
 
received - Variable in class org.apache.cassandra.service.AsyncRepairCallback
 
received(SSTableWriter) - Method in class org.apache.cassandra.streaming.StreamReceiveTask
Process received file.
received(UUID, int) - Method in class org.apache.cassandra.streaming.StreamSession
 
ReceivedMessage - Class in org.apache.cassandra.streaming.messages
 
ReceivedMessage(UUID, int) - Constructor for class org.apache.cassandra.streaming.messages.ReceivedMessage
 
receiver - Variable in class org.apache.cassandra.cql3.AbstractMarker
 
receivers(CFMetaData) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
receiveTiming(InetAddress, long) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
receiveTiming(InetAddress, long) - Method in interface org.apache.cassandra.locator.ILatencySubscriber
 
receivingSummaries - Variable in class org.apache.cassandra.streaming.SessionInfo
Immutable collection of receiving summaries
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
reclaim(Cell) - Method in interface org.apache.cassandra.utils.memory.MemtableAllocator.DataReclaimer
 
reclaimer() - Method in class org.apache.cassandra.utils.memory.HeapPool.Allocator
 
reclaimer() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
 
reclaimer() - Method in class org.apache.cassandra.utils.memory.NativeAllocator
 
reclaimer() - Method in class org.apache.cassandra.utils.memory.SlabAllocator
 
reclaimImmediately(Cell) - Method in interface org.apache.cassandra.utils.memory.MemtableAllocator.DataReclaimer
 
reclaimImmediately(DecoratedKey) - Method in interface org.apache.cassandra.utils.memory.MemtableAllocator.DataReclaimer
 
reclaimingRatio() - Method in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
 
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(Cell) - Method in class org.apache.cassandra.db.AbstractCell
 
reconcile(Cell) - Method in class org.apache.cassandra.db.BufferCounterCell
 
reconcile(Cell) - Method in class org.apache.cassandra.db.BufferCounterUpdateCell
 
reconcile(Cell) - Method in class org.apache.cassandra.db.BufferDeletedCell
 
reconcile(Cell) - Method in class org.apache.cassandra.db.BufferExpiringCell
 
reconcile(Cell) - Method in interface org.apache.cassandra.db.Cell
 
reconcile(Cell) - Method in class org.apache.cassandra.db.NativeCounterCell
 
reconcile(Cell) - Method in class org.apache.cassandra.db.NativeDeletedCell
 
reconcile(Cell) - Method in class org.apache.cassandra.db.NativeExpiringCell
 
reconcileCounter(Cell) - Method in class org.apache.cassandra.db.AbstractCell
This is temporary until we start creating Cells of the different type (buffer vs.
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
 
recordColumnDrop(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
 
recordLast(Row) - Method in class org.apache.cassandra.service.pager.RangeNamesQueryPager
 
recordLast(Row) - Method in class org.apache.cassandra.service.pager.RangeSliceQueryPager
 
recordLast(Row) - Method in class org.apache.cassandra.service.pager.SliceQueryPager
 
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, boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
recursive - Variable in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
recvBufferSize - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
 
recycle(RandomAccessReader) - Method in class org.apache.cassandra.io.util.PoolingSegmentedFile
 
redistributeSummaries() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
 
redistributeSummaries(IndexSummaryRedistribution) - Static method in class org.apache.cassandra.io.sstable.IndexSummaryManager
Attempts to fairly distribute a fixed pool of memory for index summaries across a set of SSTables based on their recent read rates.
redistributeSummaries() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
 
redistributeSummaries() - Method in class org.apache.cassandra.io.sstable.IndexSummaryRedistribution
 
reduce(OnDiskAtomIterator) - Method in class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
 
reduce(OnDiskAtom) - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow.Reducer
Called once per version of a cell that we need to merge, after which getReduced() is called.
reduce(In) - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
combine this object with the previous ones.
Reducer() - Constructor for class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
 
reducer - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
Reducer() - Constructor for class org.apache.cassandra.db.compaction.LazilyCompactedRow.Reducer
 
reducer - Variable in class org.apache.cassandra.utils.MergeIterator
 
Reducer() - Constructor for class org.apache.cassandra.utils.MergeIterator.Reducer
 
reduceScopeForLimitedSpace(long) - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
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
 
ref() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
ref - Variable in class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
 
Ref<T> - Class in org.apache.cassandra.utils.concurrent
An object that needs ref counting does the two following: - defines a Tidy object that will cleanup once it's gone, (this must retain no references to the object we're tracking (only its resources and how to clean up)) Then, one of two options: 1) Construct a Ref directly pointing to it, and always use this Ref; or 2) - implements RefCounted - encapsulates a Ref, we'll call selfRef, to which it proxies all calls to RefCounted behaviours - users must ensure no references to the selfRef leak, or are retained outside of a method scope.
Ref(T, RefCounted.Tidy) - Constructor for class org.apache.cassandra.utils.concurrent.Ref
 
ref() - Method in class org.apache.cassandra.utils.concurrent.Ref
 
ref() - Method in interface org.apache.cassandra.utils.concurrent.RefCounted
 
ref(Iterable<T>) - Static method in class org.apache.cassandra.utils.concurrent.Refs
 
RefCounted<T> - Interface in org.apache.cassandra.utils.concurrent
An object that needs ref counting does the two following: - defines a Tidy object that will cleanup once it's gone, (this must retain no references to the object we're tracking (only its resources and how to clean up)) Then, one of two options: 1) Construct a Ref directly pointing to it, and always use this Ref; or 2) - implements RefCounted - encapsulates a Ref, we'll call selfRef, to which it proxies all calls to RefCounted behaviours - users must ensure no references to the selfRef leak, or are retained outside of a method scope.
RefCounted.Tidy - Interface in org.apache.cassandra.utils.concurrent
 
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
 
references(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.AbstractType
Checks whether this type or any of the types this type contains references the given type.
references(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
references(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.ListType
 
references(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.MapType
 
references(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
references(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.SetType
 
references(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TupleType
 
Refresh - Class in org.apache.cassandra.tools.nodetool
 
Refresh() - Constructor for class org.apache.cassandra.tools.nodetool.Refresh
 
refreshEndpointMap() - Method in class org.apache.cassandra.client.RingCache
 
refreshSizeEstimates() - Method in class org.apache.cassandra.service.StorageService
 
refreshSizeEstimates() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Forces refresh of values stored in system.size_estimates of all column families.
refreshSizeEstimates() - Method in class org.apache.cassandra.tools.NodeProbe
 
RefreshSizeEstimates - Class in org.apache.cassandra.tools.nodetool
 
RefreshSizeEstimates() - Constructor for class org.apache.cassandra.tools.nodetool.RefreshSizeEstimates
 
refs - Variable in class org.apache.cassandra.db.ColumnFamilyStore.RefViewFragment
 
Refs<T extends RefCounted<T>> - Class in org.apache.cassandra.utils.concurrent
A collection of managed Ref references to RefCounted objects, and the objects they are referencing.
Refs() - Constructor for class org.apache.cassandra.utils.concurrent.Refs
 
Refs(Map<T, Ref<T>>) - Constructor for class org.apache.cassandra.utils.concurrent.Refs
 
RefViewFragment(List<SSTableReader>, Iterable<Memtable>, Refs<SSTableReader>) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.RefViewFragment
 
register(IEndpointStateChangeSubscriber) - Method in class org.apache.cassandra.gms.Gossiper
Register for interesting state changes.
register(CassandraMetricsRegistry.MetricName, T) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
register(ILatencySubscriber) - Method in class org.apache.cassandra.net.MessagingService
 
register() - Static method in class org.apache.cassandra.service.GCInspector
 
register(MigrationListener) - Method in class org.apache.cassandra.service.MigrationManager
 
register(IEndpointLifecycleSubscriber) - Method in class org.apache.cassandra.service.StorageService
 
register(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamManager
 
register(Event.Type, Channel) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
 
register() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
Register to be signalled once allPriorOpsAreFinished() or allPriorOpsAreFinishedOrSafe() may return true
register() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
The calling thread MUST be the thread that uses the signal
register(Timer.Context) - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
The calling thread MUST be the thread that uses the signal.
registerDaemon(CassandraDaemon) - Method in class org.apache.cassandra.service.StorageService
 
registerFailureDetectionEventListener(IFailureDetectionEventListener) - Method in class org.apache.cassandra.gms.FailureDetector
 
registerFailureDetectionEventListener(IFailureDetectionEventListener) - Method in interface org.apache.cassandra.gms.IFailureDetector
Register interest for Failure Detector events.
registerMBean(Metric, ObjectName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
RegisterMessage - Class in org.apache.cassandra.transport.messages
 
RegisterMessage(List<Event.Type>) - Constructor for class org.apache.cassandra.transport.messages.RegisterMessage
 
registerParentRepairSession(UUID, InetAddress, List<ColumnFamilyStore>, Collection<Range<Token>>, boolean, boolean) - Method in class org.apache.cassandra.service.ActiveRepairService
 
registerReceiving(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamManager
 
registerVerbHandlers(MessagingService.Verb, IVerbHandler) - Method in class org.apache.cassandra.net.MessagingService
Register a verb and the corresponding verb handler with the Messaging Service.
regularAndStaticColumns() - Method in class org.apache.cassandra.config.CFMetaData
 
regularColumns() - Method in class org.apache.cassandra.config.CFMetaData
 
regularDef(CFMetaData, ByteBuffer, AbstractType<?>, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
regularStatementsExecuted - Variable in class org.apache.cassandra.metrics.CQLMetrics
 
REINSERT_OVERFLOWED_TTL_OPTION_DESCRIPTION - Static variable in class org.apache.cassandra.tools.StandaloneScrubber
 
rejectedExecutionHandler - Static variable in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
 
relaseAllExcept(Collection<T>) - Method in class org.apache.cassandra.utils.concurrent.Refs
 
relation(List<Relation>) - Method in class org.apache.cassandra.cql3.CqlParser
 
Relation - Class in org.apache.cassandra.cql3
 
Relation() - Constructor for class org.apache.cassandra.cql3.Relation
 
relation - Variable in exception org.apache.cassandra.exceptions.UnrecognizedEntityException
The entity relation.
relationType() - Method in class org.apache.cassandra.cql3.CqlParser
 
relationType - Variable in class org.apache.cassandra.cql3.Relation
 
relativeFilenameFor(Component) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
relativeToAbsolutePath(String, Path) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
release() - Method in class org.apache.cassandra.db.ColumnFamilyStore.RefViewFragment
 
release() - Method in class org.apache.cassandra.metrics.CASClientRequestMetrics
 
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.KeyspaceMetrics
Release all associated metrics.
release() - Method in class org.apache.cassandra.metrics.LatencyMetrics
 
release() - Method in class org.apache.cassandra.metrics.SEPMetrics
 
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
 
release() - Method in class org.apache.cassandra.transport.Frame
 
release() - Method in class org.apache.cassandra.utils.concurrent.Ref
Must be called exactly once, when the logical operation for which this Ref was created has terminated.
release() - Method in class org.apache.cassandra.utils.concurrent.Refs
Release ALL of the references held by this Refs collection
release(T) - Method in class org.apache.cassandra.utils.concurrent.Refs
 
release(Collection<T>) - Method in class org.apache.cassandra.utils.concurrent.Refs
Release a retained Ref to all of the provided objects; if any is not held, an exception will be thrown
release(Iterable<? extends Ref<?>>) - Static method in class org.apache.cassandra.utils.concurrent.Refs
 
release(Iterable<? extends Ref<?>>, Throwable) - Static method in class org.apache.cassandra.utils.concurrent.Refs
 
releaseFileHandle() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
releaseIfHolds(T) - Method in class org.apache.cassandra.utils.concurrent.Refs
Release the retained Ref to the provided object, if held, return false otherwise
releaseReference() - Method in class org.apache.cassandra.tracing.TraceState
 
releaseSummary() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
releaseVersion() - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
reload() - Method in class org.apache.cassandra.config.CFMetaData
Updates this object in place to match the definition in the system schema tables.
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
reloadClasses() - Method in class org.apache.cassandra.triggers.TriggerExecutor
Reload the triggers which is already loaded, Invoking this will update the class loader so new jars can be loaded.
reloadCompactionStrategy(CFMetaData) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
reloadConfiguration(boolean) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
 
reloadSecondaryIndexMetadata(CFMetaData) - Method in class org.apache.cassandra.config.CFMetaData
 
reloadSSTableMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Reloads the sstable metadata from disk.
reloadTriggerClasses() - Method in class org.apache.cassandra.service.StorageProxy
 
reloadTriggerClasses() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
reloadTriggers() - Method in class org.apache.cassandra.tools.NodeProbe
 
ReloadTriggers - Class in org.apache.cassandra.tools.nodetool
 
ReloadTriggers() - Constructor for class org.apache.cassandra.tools.nodetool.ReloadTriggers
 
relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
remaining - Variable in class org.apache.cassandra.service.pager.PagingState
 
remainingCount() - Method in interface org.apache.cassandra.db.composites.CBuilder
 
remainingCount() - Method in class org.apache.cassandra.db.composites.CompositesBuilder
Returns the number of elements that can be added to the composites.
remainingCount() - Method in class org.apache.cassandra.db.composites.CompoundCType.CompoundCBuilder
 
remainingCount() - Method in class org.apache.cassandra.db.composites.SimpleCType.SimpleCBuilder
 
remainingCount() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
RemoteSyncTask - Class in org.apache.cassandra.repair
RemoteSyncTask sends SyncRequest to remote(non-coordinator) node to repair(stream) data with other replica.
RemoteSyncTask(RepairJobDesc, TreeResponse, TreeResponse) - Constructor for class org.apache.cassandra.repair.RemoteSyncTask
 
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(SSTableReader) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
remove(Cell) - Method in interface org.apache.cassandra.db.index.SecondaryIndexManager.Updater
called when lazy-updating the index during compaction (CASSANDRA-2897)
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.format.big.BigTableScanner.EmptySSTableScanner
 
remove() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
remove() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
remove() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
remove(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
remove(ByteBuffer, ColumnPath, long, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
remove(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
 
remove(Object) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
remove() - Method in class org.apache.cassandra.utils.btree.Cursor
 
remove(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
remove(K) - Method in class org.apache.cassandra.utils.ExpiringMap
 
remove_counter(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
removeAll(Collection<?>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
removeBootstrapTokens(Collection<Token>) - Method in class org.apache.cassandra.locator.TokenMetadata
 
removeColumnDefinition(ColumnDefinition) - Method in class org.apache.cassandra.config.CFMetaData
 
removeCQL3Column(ColumnIdentifier) - Method in interface org.apache.cassandra.db.composites.CellNameType
 
removeCQL3Column(ColumnIdentifier) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellNameType
 
removeCQL3Column(ColumnIdentifier) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
removeCQL3Column(ColumnIdentifier) - Method in class org.apache.cassandra.db.composites.SimpleDenseCellNameType
 
removeCQL3Column(ColumnIdentifier) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellNameType
 
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
Removes deleted columns and purges gc-able tombstones.
removeDeleted(ColumnFamily, int, SecondaryIndexManager.Updater) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
removeDeletedCF(ColumnFamily, int) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
Purges gc-able top-level and range tombstones, returning `cf` if there are any columns or tombstones left, null otherwise.
removeDeletedColumnsOnly(ColumnFamily, int, SecondaryIndexManager.Updater) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
Removes only per-cell tombstones, cells that are shadowed by a row-level or range tombstone, or columns that have been dropped from the schema (for CQL3 tables only).
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.SystemKeyspace
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
 
removeErrorListener(ErrorListener) - Method in class org.apache.cassandra.cql3.CqlLexer
 
removeErrorListener(ErrorListener) - Method in class org.apache.cassandra.cql3.CqlParser
 
removeFromMoving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
Remove pair of token/address from moving endpoints
removeFunction(FunctionName, List<AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.functions.Functions
 
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
removeKeyspaceInstance(String) - Method in class org.apache.cassandra.config.Schema
Remove keyspace from schema
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
 
RemoveNode - Class in org.apache.cassandra.tools.nodetool
 
RemoveNode() - Constructor for class org.apache.cassandra.tools.nodetool.RemoveNode
 
removeNotificationListener(NotificationListener) - Method in class org.apache.cassandra.streaming.StreamManager
 
removeNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class org.apache.cassandra.streaming.StreamManager
 
removeParentRepairSession(UUID) - Method in class org.apache.cassandra.service.ActiveRepairService
called when the repair session is done - either failed or anticompaction has completed clears out any snapshots created by this repair
removeProgressListener(ProgressListener) - Method in class org.apache.cassandra.repair.RepairRunnable
 
removeProgressListener(ProgressListener) - Method in class org.apache.cassandra.tracing.TraceState
 
removeProgressListener(ProgressListener) - Method in interface org.apache.cassandra.utils.progress.ProgressEventNotifier
Remove progress listener from this publisher.
removeProgressListener(ProgressListener) - Method in class org.apache.cassandra.utils.progress.ProgressEventNotifierSupport
 
removeRegisteredCallback(int) - Method in class org.apache.cassandra.net.MessagingService
 
removeShutdownHook() - Method in class org.apache.cassandra.service.StorageService
In the event of forceful termination we need to remove the shutdown hook to prevent hanging (OOM for instance)
removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
 
removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
removeTrigger(String) - Method in class org.apache.cassandra.config.CFMetaData
 
removeTruncationRecord(UUID) - Static method in class org.apache.cassandra.db.SystemKeyspace
This method is used to remove information about truncation time for specified column family
removeType(UserType) - Method in class org.apache.cassandra.config.UTMetaData
 
removeUnfinishedCompactionLeftovers(CFMetaData, Map<Integer, UUID>) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
Replacing compacted sstables is atomic as far as observers of Tracker are concerned, but not on the filesystem: first the new sstables are renamed to "live" status (i.e., the tmp marker is removed), then their ancestors are removed.
removeUnreadableSSTables(File) - Static method in class org.apache.cassandra.db.Keyspace
Removes every SSTable in the directory from the appropriate Tracker's view.
removeUnreadableSSTables(File) - Method in class org.apache.cassandra.db.lifecycle.Tracker
Removes every SSTable in the directory from the Tracker'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(Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
rename(Descriptor, Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
renameColumn(ColumnIdentifier, ColumnIdentifier) - Method in class org.apache.cassandra.config.CFMetaData
 
renames(UTName, Map<ColumnIdentifier, ColumnIdentifier>) - Static method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
 
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
 
renewed - Variable in class org.apache.cassandra.notifications.MemtableRenewedNotification
 
reorderTimestampBytes(long) - Static method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
Repair - Class in org.apache.cassandra.tools.nodetool
 
Repair() - Constructor for class org.apache.cassandra.tools.nodetool.Repair
 
REPAIR_HISTORY - Static variable in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
repairAsync(String, Map<String, String>) - Method in class org.apache.cassandra.service.StorageService
 
repairAsync(String, Map<String, String>) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Invoke repair asynchronously.
repairAsync(PrintStream, String, Map<String, String>) - Method in class org.apache.cassandra.tools.NodeProbe
 
repairedAt - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
repairedAt - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
repairedAt - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
repairedAt - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
 
repairedAt - Variable in class org.apache.cassandra.streaming.StreamReader
 
repairedAt - Variable in class org.apache.cassandra.streaming.StreamRequest
 
repairedAt - Variable in class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
 
repairedBackground - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
 
repairedBlocking - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
 
RepairException - Exception in org.apache.cassandra.exceptions
Exception thrown during repair
RepairException(RepairJobDesc, String) - Constructor for exception org.apache.cassandra.exceptions.RepairException
 
RepairException(RepairJobDesc, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.RepairException
 
RepairJob - Class in org.apache.cassandra.repair
RepairJob runs repair on given ColumnFamily.
RepairJob(RepairSession, String, RepairParallelism, long, ListeningExecutorService) - Constructor for class org.apache.cassandra.repair.RepairJob
Create repair job to run on specific columnfamily
RepairJobDesc - Class in org.apache.cassandra.repair
RepairJobDesc is used from various repair processes to distinguish one RepairJob to another.
RepairJobDesc(UUID, UUID, String, String, Range<Token>) - Constructor for class org.apache.cassandra.repair.RepairJobDesc
 
repairJobResults - Variable in class org.apache.cassandra.repair.RepairSessionResult
 
RepairMessage - Class in org.apache.cassandra.repair.messages
Base class of all repair related request/response messages.
RepairMessage(RepairMessage.Type, RepairJobDesc) - Constructor for class org.apache.cassandra.repair.messages.RepairMessage
 
RepairMessage.MessageSerializer<T extends RepairMessage> - Interface in org.apache.cassandra.repair.messages
 
RepairMessage.RepairMessageSerializer - Class in org.apache.cassandra.repair.messages
 
RepairMessage.Type - Enum in org.apache.cassandra.repair.messages
 
RepairMessageSerializer() - Constructor for class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
 
RepairMessageVerbHandler - Class in org.apache.cassandra.repair
Handles all repair related message.
RepairMessageVerbHandler() - Constructor for class org.apache.cassandra.repair.RepairMessageVerbHandler
 
RepairOption - Class in org.apache.cassandra.repair.messages
Repair options.
RepairOption(RepairParallelism, boolean, boolean, boolean, int, Collection<Range<Token>>, boolean) - Constructor for class org.apache.cassandra.repair.messages.RepairOption
 
repairOverlappingSSTables(int) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
RepairParallelism - Enum in org.apache.cassandra.repair
Specify the degree of parallelism when calculating the merkle trees in a repair job.
RepairResult - Class in org.apache.cassandra.repair
RepairJob's result
RepairResult(RepairJobDesc, List<SyncStat>) - Constructor for class org.apache.cassandra.repair.RepairResult
 
repairResults - Variable in class org.apache.cassandra.service.RangeSliceResponseResolver
 
repairResults - Variable in class org.apache.cassandra.service.RowDataResolver
 
RepairRunnable - Class in org.apache.cassandra.repair
 
RepairRunnable(StorageService, int, RepairOption, String) - Constructor for class org.apache.cassandra.repair.RepairRunnable
 
RepairRunner - Class in org.apache.cassandra.tools
 
RepairRunner(PrintStream, StorageServiceMBean, String, Map<String, String>) - Constructor for class org.apache.cassandra.tools.RepairRunner
 
RepairSession - Class in org.apache.cassandra.repair
Coordinates the (active) repair of a token range.
RepairSession(UUID, UUID, Range<Token>, String, RepairParallelism, Set<InetAddress>, long, String...) - Constructor for class org.apache.cassandra.repair.RepairSession
Create new repair session.
RepairSessionResult - Class in org.apache.cassandra.repair
Repair session result
RepairSessionResult(UUID, String, Range<Token>, Collection<RepairResult>) - Constructor for class org.apache.cassandra.repair.RepairSessionResult
 
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(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
replaceColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
Deprecated.
 
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.compaction.AbstractCompactionStrategy
Handle a flushed memtable.
replaceFlushed(Memtable, SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
replaceKiller(JVMStabilityInspector.Killer) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
 
replacementQuarantine(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
Quarantine endpoint specifically for replacement purposes.
replaceSSTables(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
replaceSSTables(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
replaceSSTables(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
ReplayFilter(Iterable<SSTableReader>, ReplayPosition) - Constructor for class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayFilter
 
ReplayPosition - Class in org.apache.cassandra.db.commitlog
 
ReplayPosition(long, int) - Constructor for class org.apache.cassandra.db.commitlog.ReplayPosition
 
ReplayPosition.ReplayFilter - Class in org.apache.cassandra.db.commitlog
A filter of known safe-to-discard commit log replay positions, based on the range covered by on disk sstables and those prior to the most recent truncation record
ReplayPosition.ReplayPositionSerializer - Class in org.apache.cassandra.db.commitlog
 
ReplayPositionSerializer() - Constructor for class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
 
replicasMissingMostRecentCommit(CFMetaData, long) - Method in class org.apache.cassandra.service.paxos.PrepareCallback
 
REPLICATION_STRATEGY_CLASS_KEY - Static variable in class org.apache.cassandra.cql3.statements.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.
ReporterWrapper - Class in org.apache.cassandra.hadoop
A reporter that works with both mapred and mapreduce APIs.
ReporterWrapper(Reporter) - Constructor for class org.apache.cassandra.hadoop.ReporterWrapper
 
reportManualSeverity(double) - Method in class org.apache.cassandra.service.StorageService
 
reportSeverity(double) - Method in class org.apache.cassandra.service.StorageService
Increment about the known Compaction severity of the events in this node
Request(Message.Type) - Constructor for class org.apache.cassandra.transport.Message.Request
 
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
 
requestExtraSync() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
Sync immediately, but don't block for the sync to cmplete
requestExtraSync() - Method in class org.apache.cassandra.db.commitlog.CommitLog
Preempts the CLExecutor, telling to to sync immediately
RequestFailureException - Exception in org.apache.cassandra.exceptions
 
RequestFailureException(ExceptionCode, ConsistencyLevel, int, int, int) - Constructor for exception org.apache.cassandra.exceptions.RequestFailureException
 
requestInvoke(AbstractNonblockingServer.FrameBuffer) - Method in class org.apache.cassandra.thrift.CustomTNonBlockingServer
 
requestNames() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
Return only the column names requested by the user, excluding those added for post-query re-orderings, see definition of names and columnCount.
requestRanges(InetAddress, InetAddress, String, Collection<Range<Token>>) - Method in class org.apache.cassandra.streaming.StreamPlan
Request data in keyspace and ranges from specific node.
requestRanges(InetAddress, InetAddress, String, Collection<Range<Token>>, String...) - Method in class org.apache.cassandra.streaming.StreamPlan
Request data in columnFamilies under keyspace and ranges from specific node.
requests - Variable in class org.apache.cassandra.metrics.CacheMetrics
Total number of cache requests
requests - Variable in class org.apache.cassandra.metrics.FileCacheMetrics
Total number of requests
requests - Variable in class org.apache.cassandra.streaming.messages.PrepareMessage
Streaming requests
requests - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
 
requests - Variable in class org.apache.cassandra.streaming.StreamSession
 
RequestSchedulerOptions - Class in org.apache.cassandra.config
 
RequestSchedulerOptions() - Constructor for class org.apache.cassandra.config.RequestSchedulerOptions
 
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
 
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
 
RequestValidations - Class in org.apache.cassandra.cql3.statements
Utility methods use to perform request validation.
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.PasswordAuthenticator
 
required - Variable in exception org.apache.cassandra.exceptions.UnavailableException
 
requireFullClusteringKey() - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
 
requireFullClusteringKey() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
requireFullClusteringKey() - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
 
REQUIRES_ALLOW_FILTERING_MESSAGE - Static variable in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
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
 
requiresRead() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
requiresScanningAllRanges() - Method in class org.apache.cassandra.db.AbstractRangeCommand
 
requiresScanningAllRanges(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
Returns true if the specified list of IndexExpressions require a full scan of all the nodes.
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.SnapshotDeletingTask
Retry all failed deletions.
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.
reserializeToV3(ByteBuffer) - Method in class org.apache.cassandra.serializers.CollectionSerializer
 
reservedTypeNames - Static variable in class org.apache.cassandra.cql3.CqlParser
 
reset() - Method in interface org.apache.cassandra.cql3.functions.AggregateFunction.Aggregate
Reset this aggregate.
reset() - Method in class org.apache.cassandra.cql3.selection.Selector
Reset the internal state of this Selector.
reset() - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
 
reset() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
reset(Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
(Re)initializes the tracker, purging all references.
reset(FileMark) - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
 
reset() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
Resets this stream to the last marked location.
reset(FileMark) - Method in interface org.apache.cassandra.io.util.FileDataInput
 
reset() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
 
reset() - Method in class org.apache.cassandra.io.util.NIODataInputStream
 
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(Object[], boolean) - Method in class org.apache.cassandra.utils.btree.Cursor
Reset this cursor for the provided tree, to iterate over its entire range
reset(Object[], Comparator<K>, K, K, boolean) - Method in class org.apache.cassandra.utils.btree.Cursor
Reset this cursor for the provided tree, to iterate between the provided start and end
reset(Object[], Comparator<K>, K, boolean, K, boolean, boolean) - Method in class org.apache.cassandra.utils.btree.Cursor
Reset this cursor for the provided tree, to iterate between the provided start and end
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() - Static method in class org.apache.cassandra.utils.FBUtilities
 
reset() - Method in class org.apache.cassandra.utils.PureJavaCrc32
 
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.format.big.BigTableWriter
 
resetAndTruncate() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
resetAndTruncate(FileMark) - Method in class org.apache.cassandra.io.util.SequentialWriter
Drops all buffered data that's past the limits of our new file mark + buffer capacity, or syncs and truncates the underlying file to the marked position
resetAvailableRanges() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
resetBuffer() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
resetCollection(String) - Method in class org.apache.cassandra.db.CFRowAdder
 
resetConfiguration() - Method in class org.apache.cassandra.db.commitlog.CommitLog
FOR TESTING PURPOSES.
resetForTests() - Static method in class org.apache.cassandra.db.WindowsFailedSnapshotTracker
 
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
 
ResetLocalSchema - Class in org.apache.cassandra.tools.nodetool
 
ResetLocalSchema() - Constructor for class org.apache.cassandra.tools.nodetool.ResetLocalSchema
 
resetTidying() - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
resetToNewerVersion(int) - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
resetUnsafe(boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLog
FOR TESTING PURPOSES.
resetVersion(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
resetWarnings() - Method in class org.apache.cassandra.service.ClientWarn
 
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
 
resolveIp - Variable in class org.apache.cassandra.tools.nodetool.HostStat
 
resolver - Variable in class org.apache.cassandra.service.AbstractReadExecutor
 
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.ListPermissionsStatement
 
resource - Variable in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
 
RESOURCE_ROLE_INDEX - Static variable in class org.apache.cassandra.auth.AuthKeyspace
 
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
 
respectTombstoneThresholds() - Method in class org.apache.cassandra.db.columniterator.IdentityQueryFilter
 
respectTombstoneThresholds() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
response(MessageIn<T>) - Method in class org.apache.cassandra.net.AsyncOneResponse
 
response(MessageIn<T>) - Method in interface org.apache.cassandra.net.IAsyncCallback
 
response(MessageIn) - Method in class org.apache.cassandra.repair.AnticompactionTask.AnticompactionCallback
 
response(MessageIn<T>) - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
null message means "response from local write"
response(MessageIn<ReadResponse>) - Method in class org.apache.cassandra.service.AsyncRepairCallback
 
response(MessageIn<T>) - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
response(MessageIn<T>) - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
response(MessageIn<PrepareResponse>) - Method in class org.apache.cassandra.service.paxos.PrepareCallback
 
response(MessageIn<Boolean>) - Method in class org.apache.cassandra.service.paxos.ProposeCallback
 
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<T>) - Method in class org.apache.cassandra.service.WriteResponseHandler
 
Response(Message.Type) - Constructor for class org.apache.cassandra.transport.Message.Response
 
responseHandler - Variable in class org.apache.cassandra.transport.SimpleClient
 
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
 
restartUnsafe() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
FOR TESTING ONLY
restartUnsafe() - Method in class org.apache.cassandra.db.commitlog.CommitLog
FOR TESTING PURPOSES.
RestorableMeter - Class in org.apache.cassandra.metrics
A meter metric which measures mean throughput as well as fifteen-minute and two-hour exponentially-weighted moving average throughputs.
RestorableMeter() - Constructor for class org.apache.cassandra.metrics.RestorableMeter
Creates a new, uninitialized RestorableMeter.
RestorableMeter(double, double) - Constructor for class org.apache.cassandra.metrics.RestorableMeter
Restores a RestorableMeter from the last seen 15m and 2h rates.
restorePointInTime - Variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
Restriction - Interface in org.apache.cassandra.cql3.restrictions
A restriction/clause on a column.
result - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Rows
 
resultify(String, Row) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
resultify(String, List<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.Rows - Class in org.apache.cassandra.transport.messages
 
ResultMessage.SchemaChange - Class in org.apache.cassandra.transport.messages
 
ResultMessage.SetKeyspace - Class in org.apache.cassandra.transport.messages
 
ResultMessage.Void - Class in org.apache.cassandra.transport.messages
 
ResultMetadata(List<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
resultMetadata - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
Describes the results of executing this prepared statement
ResultSet - Class in org.apache.cassandra.cql3
 
ResultSet(List<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.ResultSet
 
ResultSet(ResultSet.ResultMetadata, List<List<ByteBuffer>>) - Constructor for class org.apache.cassandra.cql3.ResultSet
 
ResultSet.Codec - Class in org.apache.cassandra.cql3
 
ResultSet.Flag - Enum in org.apache.cassandra.cql3
 
ResultSet.PreparedMetadata - Class in org.apache.cassandra.cql3
The metadata for the query parameters in a prepared statement.
ResultSet.ResultMetadata - Class in org.apache.cassandra.cql3
The metadata for the results of executing a query or prepared statement.
resultSetBuilder(long, boolean) - Method in class org.apache.cassandra.cql3.selection.Selection
 
resume() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
For internal, temporary suspension of background compactions so that we can do exceptional things like truncate or major compaction
resumeBootstrap() - Method in class org.apache.cassandra.service.StorageService
 
resumeBootstrap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Resume bootstrap streaming when there is failed data streaming.
resumeBootstrap(PrintStream) - Method in class org.apache.cassandra.tools.NodeProbe
 
resumeFlushing() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
ResumeHandoff - Class in org.apache.cassandra.tools.nodetool
 
ResumeHandoff() - Constructor for class org.apache.cassandra.tools.nodetool.ResumeHandoff
 
resumeHintsDelivery() - Method in class org.apache.cassandra.tools.NodeProbe
 
retain() - Method in class org.apache.cassandra.transport.Frame
 
retainAll(Collection<?>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
rethrow(RequestExecutionException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
RetriedSliceFromReadCommand - Class in org.apache.cassandra.db
 
RetriedSliceFromReadCommand(String, ByteBuffer, String, long, SliceQueryFilter, int) - Constructor for class org.apache.cassandra.db.RetriedSliceFromReadCommand
 
retrieveTemporaryBuffer(int) - Static method in class org.apache.cassandra.io.util.DataOutputStreamPlus
 
RetryMessage - Class in org.apache.cassandra.streaming.messages
Deprecated.
retry support removed on CASSANDRA-10992
RetryMessage(UUID, int) - Constructor for class org.apache.cassandra.streaming.messages.RetryMessage
Deprecated.
 
returnCode - Variable in exception org.apache.cassandra.exceptions.StartupException
 
returnDataType - Variable in class org.apache.cassandra.cql3.functions.UDFunction
 
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 enum org.apache.cassandra.cql3.Operator
Returns the reverse operator if this one.
reverse() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
reverse() - Method in class org.apache.cassandra.cql3.ResultSet
 
reverse() - Method in enum org.apache.cassandra.cql3.statements.Bound
 
reverse() - Method in class org.apache.cassandra.utils.AsymmetricOrdering
 
reverseComparator() - Method in class org.apache.cassandra.db.composites.AbstractCType
 
reverseComparator() - Method in interface org.apache.cassandra.db.composites.CType
 
reverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
reversed - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
ReversedType<T> - Class in org.apache.cassandra.db.marshal
 
reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
reverseIterator(ColumnSlice[]) - Method in class org.apache.cassandra.db.ColumnFamily
Returns a reversed iterator over the columns of this map that returns only the matching @param slices.
reverseIterator() - Method in class org.apache.cassandra.db.ColumnFamily
 
reverseMap - Variable in class org.apache.cassandra.utils.BiMultiValMap
 
reverseMap - Variable in class org.apache.cassandra.utils.ConcurrentBiMap
 
revoke(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
revoke(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
revoke(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
Revokes a set of permissions on a resource from a user.
revokeAllFrom(RoleResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
revokeAllFrom(RoleResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
revokeAllFrom(RoleResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
Called before deleting a role with DROP ROLE statement (or the alias provided for compatibility, DROP USER) so that a new role with the same name wouldn't inherit permissions of the deleted one in the future.
revokeAllOn(IResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
revokeAllOn(IResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
revokeAllOn(IResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
This method is called after a resource is removed (i.e.
revokePermissionsStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
RevokePermissionsStatement - Class in org.apache.cassandra.cql3.statements
 
RevokePermissionsStatement(Set<Permission>, IResource, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.RevokePermissionsStatement
 
revokeRole(AuthenticatedUser, RoleResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
revokeRole(AuthenticatedUser, RoleResource, RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
Called during the execution of a REVOKE ROLE query.
revokeRoleStatement() - Method in class org.apache.cassandra.cql3.CqlParser
 
RevokeRoleStatement - Class in org.apache.cassandra.cql3.statements
 
RevokeRoleStatement(RoleName, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.RevokeRoleStatement
 
right - Variable in class org.apache.cassandra.dht.AbstractBounds
 
right - Variable in class org.apache.cassandra.utils.Pair
 
rightBoundary() - Method in class org.apache.cassandra.dht.AbstractBounds
 
Ring - Class in org.apache.cassandra.tools.nodetool
 
Ring() - Constructor for class org.apache.cassandra.tools.nodetool.Ring
 
RING_DELAY - Static variable in class org.apache.cassandra.service.StorageService
 
RingCache - Class in org.apache.cassandra.client
A class for caching the ring map at the client.
RingCache(Configuration) - Constructor for class org.apache.cassandra.client.RingCache
 
ringIterator(ArrayList<Token>, Token, boolean) - Static method in class org.apache.cassandra.locator.TokenMetadata
iterator over the Tokens in the given ring, starting with the token for the node owning start (which does not have to be a Token in the ring)
RingPosition<C extends RingPosition<C>> - Interface in org.apache.cassandra.dht
Interface representing a position on the ring.
RMIServerSocketFactoryImpl - Class in org.apache.cassandra.utils
 
RMIServerSocketFactoryImpl() - Constructor for class org.apache.cassandra.utils.RMIServerSocketFactoryImpl
 
role(String) - Static method in class org.apache.cassandra.auth.RoleResource
Creates a RoleResource representing an individual Role.
role - Variable in class org.apache.cassandra.cql3.statements.RoleManagementStatement
 
role_manager - Variable in class org.apache.cassandra.config.Config
 
ROLE_MEMBERS - Static variable in class org.apache.cassandra.auth.AuthKeyspace
 
ROLE_PERMISSIONS - Static variable in class org.apache.cassandra.auth.AuthKeyspace
 
RoleManagementStatement - Class in org.apache.cassandra.cql3.statements
 
RoleManagementStatement(RoleName, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.RoleManagementStatement
 
roleName(RoleName) - Method in class org.apache.cassandra.cql3.CqlParser
 
RoleName - Class in org.apache.cassandra.cql3
 
RoleName() - Constructor for class org.apache.cassandra.cql3.RoleName
 
roleOption(RoleOptions) - Method in class org.apache.cassandra.cql3.CqlParser
 
RoleOptions - Class in org.apache.cassandra.auth
 
RoleOptions() - Constructor for class org.apache.cassandra.auth.RoleOptions
 
roleOptions(RoleOptions) - Method in class org.apache.cassandra.cql3.CqlParser
 
RoleResource - Class in org.apache.cassandra.auth
IResource implementation representing database roles.
roleResource() - Method in class org.apache.cassandra.cql3.CqlParser
 
ROLES - Static variable in class org.apache.cassandra.auth.AuthKeyspace
 
Roles - Class in org.apache.cassandra.auth
 
Roles() - Constructor for class org.apache.cassandra.auth.Roles
 
roles_cache_max_entries - Variable in class org.apache.cassandra.config.Config
 
roles_update_interval_in_ms - Variable in class org.apache.cassandra.config.Config
 
roles_validity_in_ms - Variable in class org.apache.cassandra.config.Config
 
RolesCache - Class in org.apache.cassandra.auth
 
RolesCache(IRoleManager) - Constructor for class org.apache.cassandra.auth.RolesCache
 
RolesCacheMBean - Interface in org.apache.cassandra.auth
 
root() - Static method in class org.apache.cassandra.auth.DataResource
 
root() - Static method in class org.apache.cassandra.auth.FunctionResource
 
ROOT - Static variable in class org.apache.cassandra.auth.Resources
Deprecated.
root() - Static method in class org.apache.cassandra.auth.RoleResource
 
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
 
Row(Map<String, ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.UntypedResultSet.Row
 
Row(List<ColumnSpecification>, List<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.UntypedResultSet.Row
 
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(ByteBuffer, ColumnFamily) - Constructor for class org.apache.cassandra.db.Row
 
Row.RowSerializer - Class in org.apache.cassandra.db
 
row_cache_class_name - Variable in class org.apache.cassandra.config.Config
 
row_cache_keys_to_save - Variable in class org.apache.cassandra.config.Config
 
row_cache_save_period - Variable in class org.apache.cassandra.config.Config
 
row_cache_size_in_mb - Variable in class org.apache.cassandra.config.Config
 
rowCache - Variable in class org.apache.cassandra.cache.CachingOptions
 
RowCache(CachingOptions.RowCache.Type) - Constructor for class org.apache.cassandra.cache.CachingOptions.RowCache
 
RowCache(CachingOptions.RowCache.Type, int) - Constructor for class org.apache.cassandra.cache.CachingOptions.RowCache
 
rowCache - Variable in class org.apache.cassandra.service.CacheService
 
rowCacheHit - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Number of row cache hits
rowCacheHitOutOfRange - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Row cache hits, but result out of range
RowCacheKey - Class in org.apache.cassandra.cache
 
RowCacheKey(Pair<String, String>, byte[]) - Constructor for class org.apache.cassandra.cache.RowCacheKey
 
RowCacheKey(Pair<String, String>, DecoratedKey) - Constructor for class org.apache.cassandra.cache.RowCacheKey
 
RowCacheKey(Pair<String, String>, ByteBuffer) - Constructor for class org.apache.cassandra.cache.RowCacheKey
 
rowCacheMiss - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Number of row cache misses
RowCacheSentinel - Class in org.apache.cassandra.cache
A sentinel object for row caches.
RowCacheSentinel() - Constructor for class org.apache.cassandra.cache.RowCacheSentinel
 
RowCacheSerializer() - Constructor for class org.apache.cassandra.service.CacheService.RowCacheSerializer
 
rowCount() - Method in class org.apache.cassandra.utils.MerkleTree
 
RowDataResolver - Class in org.apache.cassandra.service
 
RowDataResolver(String, ByteBuffer, IDiskAtomFilter, long, int) - Constructor for class org.apache.cassandra.service.RowDataResolver
 
RowDigestResolver - Class in org.apache.cassandra.service
 
RowDigestResolver(String, ByteBuffer, int) - Constructor for class org.apache.cassandra.service.RowDigestResolver
 
rowFilter - Variable in class org.apache.cassandra.db.AbstractRangeCommand
 
RowHash(Token, byte[], long) - Constructor for class org.apache.cassandra.utils.MerkleTree.RowHash
 
RowIndexEntry<T> - Class in org.apache.cassandra.db
 
RowIndexEntry(long) - Constructor for class org.apache.cassandra.db.RowIndexEntry
 
RowIndexEntry.IndexSerializer<T> - Interface in org.apache.cassandra.db
 
RowIndexEntry.Serializer - Class in org.apache.cassandra.db
 
rowIndexEntrySerializer - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
rowIndexEntrySerializer - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
RowIteratorFactory - Class in org.apache.cassandra.db
 
RowIteratorFactory() - Constructor for class org.apache.cassandra.db.RowIteratorFactory
 
rowMarker(Composite) - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
rowMarker(Composite) - Method in interface org.apache.cassandra.db.composites.CellNameType
Creates a row marker for the CQL3 having the provided clustering prefix.
rowMarker(Composite) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
rowMarkerId - Static variable in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
RowPosition - Interface in org.apache.cassandra.db
 
RowPosition.ForKey - Class in org.apache.cassandra.db
 
RowPosition.Kind - Enum in org.apache.cassandra.db
 
RowPosition.RowPositionSerializer - Class in org.apache.cassandra.db
 
RowPositionSerializer() - Constructor for class org.apache.cassandra.db.RowPosition.RowPositionSerializer
 
rowPositionSerializer - Static variable in class org.apache.cassandra.dht.AbstractBounds
 
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.compaction.LazilyCompactedRow
 
rows - Variable in class org.apache.cassandra.db.RangeSliceReply
 
Rows(ResultSet) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Rows
 
ROWS_ONLY - Static variable in class org.apache.cassandra.cache.CachingOptions
 
RowSerializer() - Constructor for class org.apache.cassandra.db.Row.RowSerializer
 
rowsOnLeft() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
 
rowsOnRight() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
 
rowsToCache - Variable in class org.apache.cassandra.cache.CachingOptions.RowCache
 
rpc_address - Variable in class org.apache.cassandra.config.Config
 
rpc_interface - Variable in class org.apache.cassandra.config.Config
 
rpc_interface_prefer_ipv6 - Variable in class org.apache.cassandra.config.Config
 
rpc_keepalive - Variable in class org.apache.cassandra.config.Config
 
rpc_listen_backlog - 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
 
rpcPort - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
rpcPort - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
rpcReady(boolean) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
run() - Method in class org.apache.cassandra.db.ColumnFamilyStore.FlushLargestColumnFamily
 
run() - Method in class org.apache.cassandra.db.SizeEstimatesRecorder
 
run() - Method in class org.apache.cassandra.io.sstable.SnapshotDeletingTask
 
run() - Method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
 
run() - Method in class org.apache.cassandra.net.IncomingStreamingConnection
 
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.MessagingService.SocketThread
 
run() - Method in class org.apache.cassandra.net.OutboundTcpConnection
 
run() - Method in class org.apache.cassandra.repair.AnticompactionTask
 
run() - Method in class org.apache.cassandra.repair.RepairJob
Runs repair job.
run() - Method in class org.apache.cassandra.repair.SnapshotTask
 
run() - Method in class org.apache.cassandra.repair.StreamingRepairTask
 
run() - Method in class org.apache.cassandra.repair.SyncTask
Compares trees, and triggers repairs for any ranges that mismatch.
run() - Method in class org.apache.cassandra.repair.ValidationTask
Send ValidationRequest to replica
run() - Method in class org.apache.cassandra.repair.Validator
Called after the validation lifecycle to respond with the now valid tree.
run() - Method in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
 
run() - Method in class org.apache.cassandra.tools.RepairRunner
 
run() - Method in class org.apache.cassandra.transport.Client
 
run() - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor.BackgroundActivityReporter
 
run() - Method in class org.apache.cassandra.utils.ResourceWatcher.WatchedResource
 
run() - Method in class org.apache.cassandra.utils.WrappedRunnable
 
runIndexSummaryRedistribution(IndexSummaryRedistribution) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
runMayThrow() - Method in class org.apache.cassandra.db.compaction.CompactionTask
For internal use and testing only.
runMayThrow() - Method in class org.apache.cassandra.repair.RepairRunnable
 
runMayThrow() - Method in class org.apache.cassandra.utils.WrappedRunnable
 
runOnClose(Runnable) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
runPostFlush - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
runWithCompactionsDisabled(Callable<V>, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 

S

S - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
S - Static variable in class org.apache.cassandra.cql3.CqlParser
 
SafeMemory - Class in org.apache.cassandra.io.util
 
SafeMemory(long) - Constructor for class org.apache.cassandra.io.util.SafeMemory
 
SafeMemoryWriter - Class in org.apache.cassandra.io.util
 
SafeMemoryWriter(long) - Constructor for class org.apache.cassandra.io.util.SafeMemoryWriter
 
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
 
sampleLatencyNanos - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
SamplerResult(List<Counter<S>>, long) - Constructor for class org.apache.cassandra.utils.TopKSampler.SamplerResult
 
samplers - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
 
satisfies(int, Operator) - Static method in class org.apache.cassandra.db.filter.ExtendedFilter
 
saveCache() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
 
saveCaches() - Method in class org.apache.cassandra.service.CacheService
 
saveCaches() - Method in interface org.apache.cassandra.service.CacheServiceMBean
save row and key caches
saved_caches_directory - Variable in class org.apache.cassandra.config.Config
 
savePaxosCommit(Commit) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
savePaxosPromise(Commit) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
savePaxosProposal(Commit) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
saveSummary(SegmentedFile.Builder, SegmentedFile.Builder) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Save index summary to Summary.db file.
saveSummary(Descriptor, DecoratedKey, DecoratedKey, SegmentedFile.Builder, SegmentedFile.Builder, IndexSummary) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
Save index summary to Summary.db file.
saveSystemKeyspaceSchema() - Static method in class org.apache.cassandra.schema.LegacySchemaTables
add entries to system.schema_* for the hardcoded system definitions
saveTask - Variable in class org.apache.cassandra.cache.AutoSavingCache
 
saveTruncationRecord(ColumnFamilyStore, long, ReplayPosition) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
ScalarFunction - Interface in org.apache.cassandra.cql3.functions
Determines a single output value based on a single input value.
ScannerList(List<ISSTableScanner>) - Constructor for class org.apache.cassandra.db.compaction.AbstractCompactionStrategy.ScannerList
 
scanners - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
scanners - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy.ScannerList
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
 
ScheduledExecutors - Class in org.apache.cassandra.concurrent
Centralized location for shared executors
ScheduledExecutors() - Constructor for class org.apache.cassandra.concurrent.ScheduledExecutors
 
scheduledTasks - Static variable in class org.apache.cassandra.concurrent.ScheduledExecutors
This pool is used for periodic short (sub-second) tasks.
scheduleHintDelivery(InetAddress, boolean) - 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
 
scheduleSchemaPull(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.MigrationManager
 
scheduleTimeout(int, long, TimeUnit) - Method in class org.apache.cassandra.streaming.StreamTransferTask
Schedule timeout task to release reference for file sent.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
 
Schema - Class in org.apache.cassandra.config
 
Schema() - Constructor for class org.apache.cassandra.config.Schema
Initialize empty schema object and load the hardcoded system tables
schema(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
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
 
SchemaChange(Event.SchemaChange.Change, Event.SchemaChange.Target, String, String, List<String>) - Constructor for class org.apache.cassandra.transport.Event.SchemaChange
 
SchemaChange(Event.SchemaChange.Change, Event.SchemaChange.Target, String, String) - Constructor for class org.apache.cassandra.transport.Event.SchemaChange
 
SchemaChange(Event.SchemaChange.Change, String) - Constructor for class org.apache.cassandra.transport.Event.SchemaChange
 
SchemaChange(Event.SchemaChange) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
 
SchemaCheckVerbHandler - Class in org.apache.cassandra.db
 
SchemaCheckVerbHandler() - Constructor for class org.apache.cassandra.db.SchemaCheckVerbHandler
 
scName(Composite) - Static method in class org.apache.cassandra.db.SuperColumns
 
scNameType(CellNameType) - Static method in class org.apache.cassandra.db.SuperColumns
 
ScriptBasedUDF - Class in org.apache.cassandra.cql3.functions
 
scrub(boolean, boolean, boolean, boolean, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
scrub(boolean, boolean, boolean, boolean, boolean, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
scrub() - Method in class org.apache.cassandra.db.compaction.Scrubber
 
scrub(boolean, boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
scrub(boolean, boolean, boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
scrub(boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
scrub(boolean, boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
scrub(boolean, boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
scrub(boolean, boolean, boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
scrub(boolean, boolean, boolean, int, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
scrub(boolean, boolean, boolean, boolean, int, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
scrub(boolean, boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
scrub(PrintStream, boolean, boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
Scrub - Class in org.apache.cassandra.tools.nodetool
 
Scrub() - Constructor for class org.apache.cassandra.tools.nodetool.Scrub
 
Scrubber - Class in org.apache.cassandra.db.compaction
 
Scrubber(ColumnFamilyStore, LifecycleTransaction, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
 
Scrubber(ColumnFamilyStore, LifecycleTransaction, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
 
Scrubber(ColumnFamilyStore, LifecycleTransaction, boolean, OutputHandler, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
 
Scrubber.NegativeLocalDeletionInfoMetrics - Class in org.apache.cassandra.db.compaction
 
Scrubber.ScrubResult - Class in org.apache.cassandra.db.compaction
 
scrubDataDirectories(CFMetaData) - 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.
ScrubResult(Scrubber) - Constructor for class org.apache.cassandra.db.compaction.Scrubber.ScrubResult
 
scrubWithResult() - Method in class org.apache.cassandra.db.compaction.Scrubber
 
search(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
search(AbstractBounds<RowPosition>, List<IndexExpression>, IDiskAtomFilter, int, long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
search(ExtendedFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
search(ExtendedFilter) - Method in class org.apache.cassandra.db.index.composites.CompositesSearcher
 
search(ExtendedFilter) - Method in class org.apache.cassandra.db.index.keys.KeysSearcher
 
search(ExtendedFilter) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
Performs a search across a number of column indexes
search(ExtendedFilter) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
 
search(Composite) - Method in class org.apache.cassandra.db.RangeTombstoneList
 
search(Interval<C, D>) - Method in class org.apache.cassandra.utils.IntervalTree
 
search(C) - Method in class org.apache.cassandra.utils.IntervalTree
 
searchDeletionTime(Composite) - 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.
searcher - Variable in class org.apache.cassandra.db.AbstractRangeCommand
 
searchIterator() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
searchIterator() - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
searchIterator() - Method in class org.apache.cassandra.db.ColumnFamily
 
SearchIterator<K,V> - Interface in org.apache.cassandra.utils
 
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.messages.FileMessageHeader
 
sections - Variable in class org.apache.cassandra.streaming.StreamReader
 
sections - Variable in class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
 
sections - Variable in class org.apache.cassandra.streaming.StreamWriter
 
seed_provider - Variable in class org.apache.cassandra.config.Config
 
SeedProvider - Interface in org.apache.cassandra.locator
 
seek(long) - Method in class org.apache.cassandra.io.util.AbstractDataInput
 
seek(long) - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
 
seek(long) - Method in class org.apache.cassandra.io.util.ChecksummedRandomAccessReader
 
seek(long) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
 
seek(long) - Method in interface org.apache.cassandra.io.util.FileDataInput
 
seek(long) - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
seek(long) - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
seek(long) - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
 
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(SegmentedFile.Cleanup, ChannelProxy, long, long) - Constructor for class org.apache.cassandra.io.util.SegmentedFile
 
SegmentedFile(SegmentedFile) - 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.Cleanup - Class in org.apache.cassandra.io.util
 
select(Function<View, List<SSTableReader>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
selectable - Variable in class org.apache.cassandra.cql3.selection.RawSelector
 
Selectable - Class in org.apache.cassandra.cql3.selection
 
Selectable() - Constructor for class org.apache.cassandra.cql3.selection.Selectable
 
Selectable.Raw - Interface in org.apache.cassandra.cql3.selection
 
Selectable.WithFieldSelection - Class in org.apache.cassandra.cql3.selection
 
Selectable.WithFieldSelection.Raw - Class in org.apache.cassandra.cql3.selection
 
Selectable.WithFunction - Class in org.apache.cassandra.cql3.selection
 
Selectable.WithFunction.Raw - Class in org.apache.cassandra.cql3.selection
 
Selectable.WritetimeOrTTL - Class in org.apache.cassandra.cql3.selection
 
Selectable.WritetimeOrTTL.Raw - Class in org.apache.cassandra.cql3.selection
 
selectAndReference(Function<View, List<SSTableReader>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
selectClause() - Method in class org.apache.cassandra.cql3.CqlParser
 
selected - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection
 
selectFullRow - Variable in class org.apache.cassandra.db.DataRange
 
Selection - Class in org.apache.cassandra.cql3.selection
 
Selection(CFMetaData, List<ColumnDefinition>, SelectionColumnMapping, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.selection.Selection
 
Selection.ResultSetBuilder - Class in org.apache.cassandra.cql3.selection
 
SelectionColumnMapping - Class in org.apache.cassandra.cql3.selection
Separately maintains the ColumnSpecifications and their mappings to underlying columns as we may receive null mappings.
SelectionColumns - Interface in org.apache.cassandra.cql3.selection
Represents a mapping between the actual columns used to satisfy a Selection and the column definitions included in the resultset metadata for the query.
selectionFunctionArgs() - Method in class org.apache.cassandra.cql3.CqlParser
 
selector() - Method in class org.apache.cassandra.cql3.CqlParser
 
Selector - Class in org.apache.cassandra.cql3.selection
A Selector is used to convert the data returned by the storage engine into the data requested by the user.
Selector() - Constructor for class org.apache.cassandra.cql3.selection.Selector
 
Selector.Factory - Class in org.apache.cassandra.cql3.selection
A factory for Selector instances.
selectsFullRowFor(ByteBuffer) - Method in class org.apache.cassandra.db.DataRange.Paging
 
selectsFullRowFor(ByteBuffer) - Method in class org.apache.cassandra.db.DataRange
 
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(CFMetaData, int, SelectStatement.Parameters, Selection, StatementRestrictions, boolean, Comparator<List<ByteBuffer>>, Term) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement
 
SelectStatement.Parameters - Class in org.apache.cassandra.cql3.statements
 
SelectStatement.RawStatement - Class in org.apache.cassandra.cql3.statements
 
selfRef() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
selfRef() - Method in interface org.apache.cassandra.utils.concurrent.SelfRefCounted
 
SelfRefCounted<T extends SelfRefCounted<T>> - Interface in org.apache.cassandra.utils.concurrent
 
selfRefs(Iterable<T>) - Static method in class org.apache.cassandra.utils.concurrent.Refs
 
send(Event) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
 
sendBufferSize - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
 
sendingSummaries - Variable in class org.apache.cassandra.streaming.SessionInfo
Immutable collection of sending summaries
sendMessage(StreamMessage) - Method in class org.apache.cassandra.streaming.ConnectionHandler
 
sendMessages(Collection<? extends StreamMessage>) - Method in class org.apache.cassandra.streaming.ConnectionHandler
Enqueue messages to be sent.
sendOneWay(MessageOut, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
sendOneWay(MessageOut, int, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
Send a message to a given endpoint.
sendReply(MessageOut, int, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
sendRR(MessageOut, InetAddress, IAsyncCallback) - Method in class org.apache.cassandra.net.MessagingService
 
sendRR(MessageOut, InetAddress, IAsyncCallback, long, boolean) - Method in class org.apache.cassandra.net.MessagingService
Send a non-mutation message to a given endpoint.
sendRR(MessageOut<?>, InetAddress, AbstractWriteResponseHandler<?>, boolean) - Method in class org.apache.cassandra.net.MessagingService
Send a mutation message or a Paxos Commit to a given endpoint.
sendRR(MessageOut, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
sendRRWithFailure(MessageOut, InetAddress, IAsyncCallbackWithFailure) - Method in class org.apache.cassandra.net.MessagingService
 
sendToHintedEndpoints(Mutation, Iterable<InetAddress>, AbstractWriteResponseHandler<IMutation>, String) - Static method in class org.apache.cassandra.service.StorageProxy
Send the mutations to the right targets, write it locally if it corresponds or writes a hint when the node is not available.
separator - Static variable in class org.apache.cassandra.io.sstable.Component
 
SEPExecutor - Class in org.apache.cassandra.concurrent
 
SEPMetrics - Class in org.apache.cassandra.metrics
 
SEPMetrics(SEPExecutor, String, String) - Constructor for class org.apache.cassandra.metrics.SEPMetrics
Create metrics for the given LowSignalExecutor.
sequenceNumber - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
 
sequenceNumber - Variable in class org.apache.cassandra.streaming.messages.ReceivedMessage
 
sequenceNumber - Variable in class org.apache.cassandra.streaming.messages.RetryMessage
Deprecated.
 
SequentialWriter - Class in org.apache.cassandra.io.util
Adds buffering, mark, and fsyncing to OutputStream.
SequentialWriter(File, int, BufferType) - 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.TransactionalProxy - Class in org.apache.cassandra.io.util
 
serializationFlags() - Method in class org.apache.cassandra.db.AbstractCell
 
serializationFlags() - Method in class org.apache.cassandra.db.BufferCounterCell
 
serializationFlags() - Method in class org.apache.cassandra.db.BufferCounterUpdateCell
 
serializationFlags() - Method in class org.apache.cassandra.db.BufferDeletedCell
 
serializationFlags() - Method in class org.apache.cassandra.db.BufferExpiringCell
 
serializationFlags() - Method in interface org.apache.cassandra.db.Cell
 
serializationFlags() - Method in class org.apache.cassandra.db.NativeCounterCell
 
serializationFlags() - Method in class org.apache.cassandra.db.NativeDeletedCell
 
serializationFlags() - Method in class org.apache.cassandra.db.NativeExpiringCell
 
serialize(K, DataOutputPlus, ColumnFamilyStore) - 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, DataOutputPlus, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serialize(Cell, DataOutputPlus) - Method in class org.apache.cassandra.db.ColumnSerializer
 
serialize(ReplayPosition, DataOutputPlus) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
 
serialize(CounterMutation, DataOutputPlus, int) - Method in class org.apache.cassandra.db.CounterMutation.CounterMutationSerializer
 
serialize(DeletionInfo, DataOutputPlus, int) - Method in class org.apache.cassandra.db.DeletionInfo.Serializer
 
serialize(DeletionTime, DataOutputPlus) - Method in class org.apache.cassandra.db.DeletionTime.Serializer
 
serialize(ColumnSlice, DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.ColumnSlice.Serializer
 
serialize(IDiskAtomFilter, DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
 
serialize(NamesQueryFilter, DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter.Serializer
 
serialize(SliceQueryFilter, DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
 
serialize(Mutation, DataOutputPlus, int) - Method in class org.apache.cassandra.db.Mutation.MutationSerializer
 
serialize(RangeTombstoneList, DataOutputPlus, int) - Method in class org.apache.cassandra.db.RangeTombstoneList.Serializer
 
serialize(Row, DataOutputPlus, int) - Method in class org.apache.cassandra.db.Row.RowSerializer
 
serialize(RowIndexEntry<T>, DataOutputPlus) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
 
serialize(RowIndexEntry<IndexHelper.IndexInfo>, DataOutputPlus) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
 
serialize(RowPosition, DataOutputPlus, int) - Method in class org.apache.cassandra.db.RowPosition.RowPositionSerializer
 
serialize(TruncateResponse, DataOutputPlus, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
 
serialize(WriteResponse, DataOutputPlus, int) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
 
serialize(AbstractBounds<T>, DataOutputPlus, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
 
serialize(String, DataOutputPlus, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
 
serialize(T, DataOutputPlus, int) - Method in interface org.apache.cassandra.dht.IPartitionerDependentSerializer
Serialize the specified type into the specified DataOutputStream instance.
serialize(Token, DataOutputPlus, int) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
 
serialize(EchoMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.gms.EchoMessage.EchoMessageSerializer
 
serialize(IPartitioner, Collection<Token>, DataOutput) - Static method in class org.apache.cassandra.gms.TokenSerializer
 
serialize(T, DataOutputPlus) - Method in interface org.apache.cassandra.io.ISerializer
Serialize the specified type into the specified DataOutput instance.
serialize(T, DataOutputPlus, int) - Method in interface org.apache.cassandra.io.IVersionedSerializer
Serialize the specified type into the specified DataOutputStream instance.
serialize(IndexHelper.IndexInfo, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo.Serializer
 
serialize(IndexSummary, DataOutputPlus, boolean) - Method in class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
 
serialize(CompactionMetadata, Version, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
 
serialize(T, Version, DataOutputPlus) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataComponentSerializer
Serialize metadata component to given output.
serialize(Map<MetadataType, MetadataComponent>, Version, DataOutputPlus) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
Serialize given metadata components
serialize(Map<MetadataType, MetadataComponent>, Version, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.LegacyMetadataSerializer
Deprecated.
Legacy serialization is only used for SSTable level reset.
serialize(Map<MetadataType, MetadataComponent>, Version, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
 
serialize(StatsMetadata, Version, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata.StatsMetadataSerializer
 
serialize(ValidationMetadata, Version, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata.ValidationMetadataSerializer
 
serialize(InetAddress, DataOutput) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
 
serialize(DataOutputPlus, int) - Method in class org.apache.cassandra.net.MessageOut
 
serialize(AnticompactionRequest, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.AnticompactionRequest.AnticompactionRequestSerializer
 
serialize(CleanupMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.CleanupMessage.CleanupMessageSerializer
 
serialize(PrepareMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.PrepareMessage.PrepareMessageSerializer
 
serialize(RepairMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
 
serialize(SnapshotMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.SnapshotMessage.SnapshotMessageSerializer
 
serialize(SyncRequest, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
 
serialize(ValidationRequest, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
 
serialize(NodePair, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.NodePair.NodePairSerializer
 
serialize(String) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
 
serialize(Boolean) - Method in class org.apache.cassandra.serializers.BooleanSerializer
 
serialize(Byte) - Method in class org.apache.cassandra.serializers.ByteSerializer
 
serialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
 
serialize(T) - Method in class org.apache.cassandra.serializers.CollectionSerializer
 
serialize(BigDecimal) - Method in class org.apache.cassandra.serializers.DecimalSerializer
 
serialize(Double) - Method in class org.apache.cassandra.serializers.DoubleSerializer
 
serialize(Void) - Method in class org.apache.cassandra.serializers.EmptySerializer
 
serialize(Float) - Method in class org.apache.cassandra.serializers.FloatSerializer
 
serialize(InetAddress) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
 
serialize(Integer) - Method in class org.apache.cassandra.serializers.Int32Serializer
 
serialize(BigInteger) - Method in class org.apache.cassandra.serializers.IntegerSerializer
 
serialize(Long) - Method in class org.apache.cassandra.serializers.LongSerializer
 
serialize(Short) - Method in class org.apache.cassandra.serializers.ShortSerializer
 
serialize(Integer) - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
 
serialize(Long) - Method in class org.apache.cassandra.serializers.TimeSerializer
 
serialize(Date) - Method in class org.apache.cassandra.serializers.TimestampSerializer
 
serialize(T) - Method in interface org.apache.cassandra.serializers.TypeSerializer
 
serialize(UUID) - Method in class org.apache.cassandra.serializers.UUIDSerializer
 
serialize(CounterCacheKey, DataOutputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.CounterCacheSerializer
 
serialize(KeyCacheKey, DataOutputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.KeyCacheSerializer
 
serialize(RowCacheKey, DataOutputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.RowCacheSerializer
 
serialize(Collection<Mutation>, DataOutputPlus, int) - Method in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
 
serialize() - Method in class org.apache.cassandra.service.pager.PagingState
 
serialize(Commit, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.Commit.CommitSerializer
 
serialize(PrepareResponse, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
 
serialize(DataOutputStreamPlus, int, StreamSession) - Method in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
 
serialize(StreamMessage, DataOutputStreamPlus, int, StreamSession) - Static method in class org.apache.cassandra.streaming.messages.StreamMessage
 
serialize(V, DataOutputStreamPlus, int, StreamSession) - Method in interface org.apache.cassandra.streaming.messages.StreamMessage.Serializer
 
serialize(StreamRequest, DataOutputPlus, int) - Method in class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
 
serialize(StreamSummary, DataOutputPlus, int) - Method in class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
 
serialize(Tracing.TraceType) - Static method in enum org.apache.cassandra.tracing.Tracing.TraceType
 
serialize(ByteBuf, int) - 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(Boolean, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.BooleanSerializer
 
serialize(EstimatedHistogram, DataOutputPlus) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
serialize(T, IVersionedSerializer<T>, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
serialize(IFilter, DataOutputPlus) - Static method in class org.apache.cassandra.utils.FilterFactory
 
serialize(IntervalTree<C, D, I>, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
 
serialize(MerkleTree, DataOutputPlus, 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, DataOutputPlus) - Method in class org.apache.cassandra.utils.StreamingHistogram.StreamingHistogramSerializer
 
serialize(UUID, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
 
serializeBounds(DataOutput) - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile.Builder
 
serializeBounds(DataOutput) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
 
serializeCfId(UUID, DataOutputPlus, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializeComparator(ByteBuffer) - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
 
serializedSize(CellNameType, TypeSizes) - Method in class org.apache.cassandra.db.AbstractCell
 
serializedSize(CellNameType, TypeSizes) - Method in class org.apache.cassandra.db.BufferCounterCell
 
serializedSize(CellNameType, TypeSizes) - Method in class org.apache.cassandra.db.BufferExpiringCell
 
serializedSize(CellNameType, TypeSizes) - Method in interface org.apache.cassandra.db.Cell
 
serializedSize(ColumnFamily, TypeSizes, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializedSize(ColumnFamily, int) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializedSize(Cell, TypeSizes) - Method in class org.apache.cassandra.db.ColumnSerializer
 
serializedSize(ReplayPosition, TypeSizes) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
 
serializedSize(CounterMutation, int) - Method in class org.apache.cassandra.db.CounterMutation.CounterMutationSerializer
 
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(DeletionTime, TypeSizes) - Method in class org.apache.cassandra.db.DeletionTime.Serializer
 
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(SliceQueryFilter, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
 
serializedSize(Mutation, int) - Method in class org.apache.cassandra.db.Mutation.MutationSerializer
 
serializedSize(CellNameType, TypeSizes) - Method in class org.apache.cassandra.db.NativeCounterCell
 
serializedSize(CellNameType, TypeSizes) - Method in class org.apache.cassandra.db.NativeExpiringCell
 
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(RowIndexEntry<T>) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
 
serializedSize(RowIndexEntry<IndexHelper.IndexInfo>) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
 
serializedSize(RowPosition, int) - Method in class org.apache.cassandra.db.RowPosition.RowPositionSerializer
 
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<T>, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
 
serializedSize(String, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
 
serializedSize(T, int) - Method in interface org.apache.cassandra.dht.IPartitionerDependentSerializer
Calculate serialized size of object without actually serializing.
serializedSize(Token, int) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
 
serializedSize(EchoMessage, int) - Method in class org.apache.cassandra.gms.EchoMessage.EchoMessageSerializer
 
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(IndexHelper.IndexInfo, TypeSizes) - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo.Serializer
 
serializedSize(CompactionMetadata, Version) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
 
serializedSize(T, Version) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataComponentSerializer
Calculate and return serialized size.
serializedSize(StatsMetadata, Version) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata.StatsMetadataSerializer
 
serializedSize(ValidationMetadata, Version) - Method in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata.ValidationMetadataSerializer
 
serializedSize(InetAddress) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
 
serializedSize(int) - Method in class org.apache.cassandra.net.MessageOut
 
serializedSize(AnticompactionRequest, int) - Method in class org.apache.cassandra.repair.messages.AnticompactionRequest.AnticompactionRequestSerializer
 
serializedSize(CleanupMessage, int) - Method in class org.apache.cassandra.repair.messages.CleanupMessage.CleanupMessageSerializer
 
serializedSize(PrepareMessage, int) - Method in class org.apache.cassandra.repair.messages.PrepareMessage.PrepareMessageSerializer
 
serializedSize(RepairMessage, int) - Method in class org.apache.cassandra.repair.messages.RepairMessage.RepairMessageSerializer
 
serializedSize(SnapshotMessage, int) - Method in class org.apache.cassandra.repair.messages.SnapshotMessage.SnapshotMessageSerializer
 
serializedSize(SyncRequest, int) - Method in class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
 
serializedSize(ValidationRequest, int) - Method in class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
 
serializedSize(NodePair, int) - Method in class org.apache.cassandra.repair.NodePair.NodePairSerializer
 
serializedSize(Collection<Mutation>, int) - Method in class org.apache.cassandra.service.MigrationManager.MigrationsSerializer
 
serializedSize(Commit, int) - Method in class org.apache.cassandra.service.paxos.Commit.CommitSerializer
 
serializedSize(PrepareResponse, int) - Method in class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
 
serializedSize(StreamRequest, int) - Method in class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
 
serializedSize(StreamSummary, int) - Method in class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
 
serializedSize(int) - Method in class org.apache.cassandra.transport.Event
 
serializedSize() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
 
serializedSize() - Method in class org.apache.cassandra.utils.BloomFilter
 
serializedSize(Boolean, int) - Method in class org.apache.cassandra.utils.BooleanSerializer
 
serializedSize(EstimatedHistogram, TypeSizes) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
serializedSize() - Method in interface org.apache.cassandra.utils.IFilter
 
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(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(OnDiskAtom) - Method in class org.apache.cassandra.db.OnDiskAtom.Serializer
 
serializedSizeForSSTable(OnDiskAtom) - Method in interface org.apache.cassandra.db.OnDiskAtom.SerializerForWriting
 
serializedSizeForSSTable(RangeTombstone) - Method in class org.apache.cassandra.db.RangeTombstone.Serializer
 
serializedValue - Variable in enum org.apache.cassandra.db.ReadCommand.Type
 
serializedValues(List<Cell>) - Method in class org.apache.cassandra.db.marshal.CollectionType
 
serializedValues(List<Cell>) - Method in class org.apache.cassandra.db.marshal.ListType
 
serializedValues(List<Cell>) - Method in class org.apache.cassandra.db.marshal.MapType
 
serializedValues(List<Cell>) - Method in class org.apache.cassandra.db.marshal.SetType
 
serializedValueSize(Object, int) - Method in enum org.apache.cassandra.transport.DataType
 
serializedValueSize(Object, int) - Method in interface org.apache.cassandra.transport.OptionCodec.Codecable
 
serializeEvent(ByteBuf, int) - Method in class org.apache.cassandra.transport.Event.SchemaChange
 
serializeEvent(ByteBuf, int) - Method in class org.apache.cassandra.transport.Event
 
serializeEvent(ByteBuf, int) - Method in class org.apache.cassandra.transport.Event.StatusChange
 
serializeEvent(ByteBuf, int) - Method in class org.apache.cassandra.transport.Event.TopologyChange
 
serializeForNativeProtocol(ColumnDefinition, List<Cell>, int) - Method in class org.apache.cassandra.db.marshal.CollectionType
 
serializeForSSTable(ColumnFamily, DataOutputPlus) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializeForSSTable(OnDiskAtom, DataOutputPlus) - Method in class org.apache.cassandra.db.OnDiskAtom.Serializer
 
serializeForSSTable(OnDiskAtom, DataOutputPlus) - Method in interface org.apache.cassandra.db.OnDiskAtom.SerializerForWriting
 
serializeForSSTable(RangeTombstone, DataOutputPlus) - Method in class org.apache.cassandra.db.RangeTombstone.Serializer
 
serializeForSSTable(T, DataOutputPlus) - 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 variable in class org.apache.cassandra.db.ColumnFamily
 
serializer - Static variable in class org.apache.cassandra.db.commitlog.ReplayPosition
 
serializer() - Method in class org.apache.cassandra.db.composites.AbstractCType
 
serializer() - Method in interface org.apache.cassandra.db.composites.CType
 
serializer - Static variable in class org.apache.cassandra.db.CounterMutation
 
Serializer(CType) - Constructor for class org.apache.cassandra.db.DeletionInfo.Serializer
 
serializer - Static variable in class org.apache.cassandra.db.DeletionTime
 
Serializer() - Constructor for class org.apache.cassandra.db.DeletionTime.Serializer
 
Serializer(CType) - Constructor for class org.apache.cassandra.db.filter.ColumnSlice.Serializer
 
Serializer(CellNameType) - Constructor for class org.apache.cassandra.db.filter.IDiskAtomFilter.Serializer
 
Serializer(CellNameType) - Constructor for class org.apache.cassandra.db.filter.NamesQueryFilter.Serializer
 
Serializer(CType) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter.Serializer
 
serializer - Variable in class org.apache.cassandra.db.marshal.ListType
 
serializer - Static variable in class org.apache.cassandra.db.Mutation
 
Serializer(CellNameType) - Constructor for class org.apache.cassandra.db.OnDiskAtom.Serializer
 
serializer - Static variable in class org.apache.cassandra.db.PagedRangeCommand
 
serializer - Static variable in class org.apache.cassandra.db.RangeSliceCommand
 
serializer - Static variable in class org.apache.cassandra.db.RangeSliceReply
 
Serializer(CType) - Constructor for class org.apache.cassandra.db.RangeTombstone.Serializer
 
Serializer(CType) - Constructor for class org.apache.cassandra.db.RangeTombstoneList.Serializer
 
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(ISerializer<IndexHelper.IndexInfo>) - Constructor for class org.apache.cassandra.db.RowIndexEntry.Serializer
 
serializer - Static variable in interface org.apache.cassandra.db.RowPosition
 
serializer - Static variable in class org.apache.cassandra.db.SnapshotCommand
 
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.Token
 
serializer - Static variable in class org.apache.cassandra.gms.EchoMessage
 
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(CType) - Constructor for class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo.Serializer
 
serializer - Static variable in class org.apache.cassandra.io.sstable.IndexSummary
 
serializer - Static variable in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
 
serializer - Variable in enum org.apache.cassandra.io.sstable.metadata.MetadataType
 
serializer - Static variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
serializer - Static variable in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
 
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.repair.messages.AnticompactionRequest
 
serializer - Static variable in class org.apache.cassandra.repair.messages.CleanupMessage
 
serializer - Static variable in class org.apache.cassandra.repair.messages.PrepareMessage
 
serializer - Static variable in class org.apache.cassandra.repair.messages.RepairMessage
 
serializer - Static variable in class org.apache.cassandra.repair.messages.SnapshotMessage
 
serializer - Static variable in class org.apache.cassandra.repair.messages.SyncComplete
 
serializer - Static variable in class org.apache.cassandra.repair.messages.SyncRequest
 
serializer - Static variable in class org.apache.cassandra.repair.messages.ValidationComplete
 
serializer - Static variable in class org.apache.cassandra.repair.messages.ValidationRequest
 
serializer - Static variable in class org.apache.cassandra.repair.NodePair
 
serializer - Static variable in class org.apache.cassandra.repair.RepairJobDesc
 
serializer - Static variable in class org.apache.cassandra.service.paxos.Commit
 
serializer - Static variable in class org.apache.cassandra.service.paxos.PrepareResponse
 
serializer - Static variable in class org.apache.cassandra.streaming.compress.CompressionInfo
 
serializer - Static variable in class org.apache.cassandra.streaming.messages.CompleteMessage
 
serializer - Static variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
 
serializer - Static variable in class org.apache.cassandra.streaming.messages.IncomingFileMessage
 
serializer - Static variable in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
 
serializer - Static variable in class org.apache.cassandra.streaming.messages.PrepareMessage
 
serializer - Static variable in class org.apache.cassandra.streaming.messages.ReceivedMessage
 
serializer - Static variable in class org.apache.cassandra.streaming.messages.RetryMessage
Deprecated.
 
serializer - Static variable in class org.apache.cassandra.streaming.messages.SessionFailedMessage
 
serializer - Static variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
 
serializer - Static variable in class org.apache.cassandra.streaming.StreamRequest
 
serializer - Static variable in class org.apache.cassandra.streaming.StreamSummary
 
serializer - Static variable in class org.apache.cassandra.utils.BloomFilter
 
serializer - Static variable in class org.apache.cassandra.utils.BooleanSerializer
 
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.MerkleTree
 
serializer - Static variable in class org.apache.cassandra.utils.StreamingHistogram
 
serializer - Static variable in class org.apache.cassandra.utils.UUIDSerializer
 
serializeValues(T) - Method in class org.apache.cassandra.serializers.CollectionSerializer
 
serializeValues(List<T>) - Method in class org.apache.cassandra.serializers.ListSerializer
 
serializeValues(Map<K, V>) - Method in class org.apache.cassandra.serializers.MapSerializer
 
serializeValues(Set<T>) - Method in class org.apache.cassandra.serializers.SetSerializer
 
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.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.AbstractSecureIntializer - Class in org.apache.cassandra.transport
 
Server.ConnectionTracker - Class in org.apache.cassandra.transport
 
server_encryption_options - Variable in class org.apache.cassandra.config.Config
 
ServerConnection - Class in org.apache.cassandra.transport
 
ServerConnection(Channel, int, Connection.Tracker) - Constructor for class org.apache.cassandra.transport.ServerConnection
 
ServerEncryptionOptions() - Constructor for class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
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.streaming.StreamEvent.SessionPreparedEvent
 
session - Variable in class org.apache.cassandra.streaming.StreamReader
 
session - Variable in class org.apache.cassandra.streaming.StreamTask
StreamSession that this task belongs
session - Variable in class org.apache.cassandra.streaming.StreamWriter
 
SESSION_FAILED_MATCHER - Static variable in class org.apache.cassandra.utils.progress.jmx.LegacyJMXProgressSupport
 
SESSION_SUCCESS_MATCHER - Static variable in class org.apache.cassandra.utils.progress.jmx.LegacyJMXProgressSupport
 
SessionCompleteEvent(StreamSession) - Constructor for class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
 
SessionCompleteEventCompositeData - Class in org.apache.cassandra.streaming.management
 
SessionCompleteEventCompositeData() - Constructor for class org.apache.cassandra.streaming.management.SessionCompleteEventCompositeData
 
sessionFailed() - Method in class org.apache.cassandra.streaming.StreamSession
Call back on receiving StreamMessage.Type.SESSION_FAILED message.
SessionFailedMessage - Class in org.apache.cassandra.streaming.messages
 
SessionFailedMessage() - Constructor for class org.apache.cassandra.streaming.messages.SessionFailedMessage
 
sessionId - Variable in class org.apache.cassandra.repair.RepairJobDesc
RepairSession id
sessionId - Variable in class org.apache.cassandra.repair.RepairSessionResult
 
sessionId - Variable in class org.apache.cassandra.tracing.TraceState
 
sessionIdBytes - Variable in class org.apache.cassandra.tracing.TraceState
 
sessionIndex - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
 
sessionIndex - Variable in class org.apache.cassandra.streaming.ProgressInfo
 
sessionIndex - Variable in class org.apache.cassandra.streaming.SessionInfo
 
sessionIndex - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
 
sessionIndex() - Method in class org.apache.cassandra.streaming.StreamSession
 
SessionInfo - Class in org.apache.cassandra.streaming
Stream session info.
SessionInfo(InetAddress, int, InetAddress, Collection<StreamSummary>, Collection<StreamSummary>, StreamSession.State) - Constructor for class org.apache.cassandra.streaming.SessionInfo
 
SessionInfoCompositeData - Class in org.apache.cassandra.streaming.management
 
SessionInfoCompositeData() - Constructor for class org.apache.cassandra.streaming.management.SessionInfoCompositeData
 
SessionPreparedEvent(UUID, SessionInfo) - Constructor for class org.apache.cassandra.streaming.StreamEvent.SessionPreparedEvent
 
sessions - Variable in class org.apache.cassandra.streaming.StreamState
 
SESSIONS - Static variable in class org.apache.cassandra.tracing.TraceKeyspace
 
set(T) - Method in interface org.apache.cassandra.concurrent.ExecutorLocal
Before a task has been run, this will be called with the value from the thread that scheduled the task, and after the task is finished, the value that was previously retrieved from this thread is restored.
set(ExecutorLocals) - Static method in class org.apache.cassandra.concurrent.ExecutorLocals
 
set(CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
set(ClientWarn.State) - Method in class org.apache.cassandra.service.ClientWarn
 
set(TraceState) - Method in class org.apache.cassandra.tracing.Tracing
 
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
 
setAutoSnapshot(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setBatchSizeFailThresholdInKB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setBatchSizeFailureThreshold(int) - Method in class org.apache.cassandra.service.StorageService
 
setBatchSizeFailureThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Sets the threshold for rejecting queries due to a large batch size
setBatchSizeWarnThresholdInKB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setBootstrapState(SystemKeyspace.BootstrapState) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
setBoundVariables(List<ColumnIdentifier>) - Method in class org.apache.cassandra.cql3.statements.ParsedStatement
 
setBroadcastAddress(InetAddress) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setBroadcastRpcAddress(InetAddress) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setByte(long, byte) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
setByte(long, byte) - Method in class org.apache.cassandra.io.util.Memory
 
setByte(long, byte) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
setByteBuffer(ByteBuffer, long, int) - Method in class org.apache.cassandra.io.util.Memory
 
setByteBuffer(ByteBuffer, long, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
setBytes(long, ByteBuffer) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
setBytes(long, ByteBuffer) - 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
setBytes(long, ByteBuffer) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
setBytes(long, byte[], int, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
Transfers count bytes from buffer to Memory
setBytes(long, long, long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
setBytes(byte[], int, long, long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
setCacheCapacities(int, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetCacheCapacity - Class in org.apache.cassandra.tools.nodetool
 
SetCacheCapacity() - Constructor for class org.apache.cassandra.tools.nodetool.SetCacheCapacity
 
setCacheKeysToSave(int, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetCacheKeysToSave - Class in org.apache.cassandra.tools.nodetool
 
SetCacheKeysToSave() - Constructor for class org.apache.cassandra.tools.nodetool.SetCacheKeysToSave
 
setCallbackForTests(int, 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
 
setCapacity(long) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
setCasContentionTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCasContentionTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
 
setCasContentionTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
setClientMode(boolean) - Static method in class org.apache.cassandra.config.Config
 
setColumnFamily(String, boolean) - Method in class org.apache.cassandra.cql3.CFName
 
setCommitFailurePolicy(Config.CommitFailurePolicy) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCommitLogCompression(ParameterizedClass) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCommitLogSegmentSize(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCommitLogSync(Config.CommitLogSync) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCommitLogSyncBatchWindow(double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCommitLogSyncPeriod(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCompactionParameters(Map<String, String>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setCompactionParameters(Map<String, String>) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Sets the compaction parameters locally for this node Note that this will be set until an ALTER with compaction = {..} is executed or the node is restarted
setCompactionParametersJson(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setCompactionParametersJson(String) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Sets the compaction parameters locally for this node Note that this will be set until an ALTER with compaction = {..} is executed or the node is restarted
setCompactionStrategyClass(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setCompactionStrategyClass(String) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Deprecated.
setCompactionThreshold(String, String, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
Set the compaction threshold
SetCompactionThreshold - Class in org.apache.cassandra.tools.nodetool
 
SetCompactionThreshold() - Constructor for class org.apache.cassandra.tools.nodetool.SetCompactionThreshold
 
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
 
SetCompactionThroughput - Class in org.apache.cassandra.tools.nodetool
 
SetCompactionThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.SetCompactionThroughput
 
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.CreateTableStatement.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
 
setConnectionFactory(StreamConnectionFactory) - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
setConnectionInformation() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
set hadoop cassandra connection settings
setConnectionInformation() - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
set hadoop cassandra connection settings
setConnectionInformation(Configuration) - Static method in class org.apache.cassandra.hadoop.pig.StorageHelper
Deprecated.
 
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
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.
setCounterCacheCapacityInMB(long) - Method in class org.apache.cassandra.service.CacheService
 
setCounterCacheCapacityInMB(long) - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
setCounterCacheKeysToSave(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCounterCacheKeysToSave(int) - Method in class org.apache.cassandra.service.CacheService
 
setCounterCacheKeysToSave(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
setCounterCacheSavePeriod(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCounterCacheSavePeriodInSeconds(int) - Method in class org.apache.cassandra.service.CacheService
 
setCounterCacheSavePeriodInSeconds(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
setCounterWriteRpcTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCounterWriteRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
 
setCounterWriteRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
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
 
setCurrentSocket(SocketAddress) - Method in class org.apache.cassandra.thrift.ThriftSessionManager
 
setCustomPayload(Map<String, ByteBuffer>) - Method in class org.apache.cassandra.transport.Message
 
setDaemonInitialized() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setDeleteSourceOnSuccess(Configuration, boolean) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
setDeletionInfo(DeletionInfo) - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
 
setDeletionInfo(DeletionInfo) - Method in class org.apache.cassandra.db.AtomicBTreeColumns
 
setDeletionInfo(DeletionInfo) - Method in class org.apache.cassandra.db.ColumnFamily
 
setDescriptor(Descriptor) - Method in class org.apache.cassandra.io.util.SequentialWriter
 
setDigest(ByteBuffer) - Method in class org.apache.cassandra.db.ReadResponse
 
setDiscarded() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
Indicate the memory and resources owned by this allocator are no longer referenced, and can be reclaimed/reused.
setDiscarded() - Method in class org.apache.cassandra.utils.memory.NativeAllocator
 
setDiscarded() - Method in class org.apache.cassandra.utils.memory.SlabAllocator
 
setDiscarding(OpOrder.Barrier, AtomicReference<ReplayPosition>) - Method in class org.apache.cassandra.db.Memtable
 
setDiscarding() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
Mark this allocator reclaiming; this will permit any outstanding allocations to temporarily overshoot the maximum memory limit so that flushing can begin immediately
setDiskAccessMode(Config.DiskAccessMode) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
 
SetElement(Term.Raw, Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.SetElement
 
setEndpointSnitch(IEndpointSnitch) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setEventHandler(SimpleClient.EventHandler) - Method in class org.apache.cassandra.transport.SimpleClient
 
setFSErrorHandler(FSErrorHandler) - Static method in class org.apache.cassandra.io.util.FileUtils
 
setGossipTokens(Collection<Token>) - Method in class org.apache.cassandra.service.StorageService
 
setHasMorePages(PagingState) - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
setHintedHandoffEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setHintedHandoffEnabled(String) - 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
 
setHintedHandoffEnabledByDCList(String) - Method in class org.apache.cassandra.service.StorageProxy
 
setHintedHandoffEnabledByDCList(String) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
setHintedHandoffThrottleInKB(Integer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setHintedHandoffThrottleInKB(int) - Method in class org.apache.cassandra.service.StorageService
 
setHintedHandoffThrottleInKB(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Sets the hinted handoff throttle in kb per second, per delivery thread.
setHintedHandoffThrottleInKB(int) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetHintedHandoffThrottleInKB - Class in org.apache.cassandra.tools.nodetool
 
SetHintedHandoffThrottleInKB() - Constructor for class org.apache.cassandra.tools.nodetool.SetHintedHandoffThrottleInKB
 
SetHostStat - Class in org.apache.cassandra.tools.nodetool
 
SetHostStat(boolean) - Constructor for class org.apache.cassandra.tools.nodetool.SetHostStat
 
setIfExistCondition() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
setIfNotExistCondition() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
setIgnoreHosts(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
Set the hosts to ignore as comma delimited values.
setIgnoreHosts(Configuration, String...) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
Set the hosts to ignore.
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
 
setIndex(String, IndexType, Map<String, String>) - Method in class org.apache.cassandra.config.ColumnDefinition
 
setIndex(String, boolean) - Method in class org.apache.cassandra.cql3.IndexName
 
setIndexAccessMode(Config.DiskAccessMode) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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.SystemKeyspace
 
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.SystemKeyspace
 
setIndexType(IndexType, Map<String, String>) - Method in class org.apache.cassandra.config.ColumnDefinition
 
setInitialized() - Static method in class org.apache.cassandra.db.Keyspace
 
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.
setInputCoreConnections(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputCql(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
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
 
setInputMaxConnections(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputMaxSimultReqPerConnections(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeAuthProvider(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeConnectionTimeout(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeKeepAlive(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativePort(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeReadConnectionTimeout(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeReceiveBufferSize(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeReuseAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeSendBufferSize(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeSolinger(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeSSLCipherSuites(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeSSLKeystorePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeSSLKeystorePath(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeSSLTruststorePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeSSLTruststorePath(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeTcpNodelay(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
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.
setInputSplitSizeInMb(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.
setInt(long, int) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
setInt(long, int) - Method in class org.apache.cassandra.io.util.Memory
 
setInt(long, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
setInterDCStreamThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetInterDCStreamThroughput - Class in org.apache.cassandra.tools.nodetool
 
SetInterDCStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.SetInterDCStreamThroughput
 
setInterDCStreamThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
 
setInterDCStreamThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setInterDCStreamThroughputOutboundMegabitsPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setIsDigestQuery(boolean) - Method in class org.apache.cassandra.db.ReadCommand
 
setKeyCacheCapacityInMB(long) - Method in class org.apache.cassandra.service.CacheService
 
setKeyCacheCapacityInMB(long) - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
setKeyCacheKeysToSave(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setKeyCacheKeysToSave(int) - Method in class org.apache.cassandra.service.CacheService
 
setKeyCacheKeysToSave(int) - 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.cql3.UTName
 
setKeyspace(String) - Method in class org.apache.cassandra.service.ClientState
 
SetKeyspace(String) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
 
setKeyspaceDefinition(KSMetaData) - Method in class org.apache.cassandra.config.Schema
Update (or insert) new keyspace definition
setLastProcessedMessageAt(long) - Method in class org.apache.cassandra.gms.Gossiper
 
setLiveMetadata(CFMetaData) - Method in class org.apache.cassandra.io.compress.CompressionParameters
 
setLocalHostId(UUID) - Static method in class org.apache.cassandra.db.SystemKeyspace
Sets the local host ID explicitly.
setLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
set read configuration settings
setLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
set read configuration settings
setLoggingLevel(String, String) - Method in class org.apache.cassandra.service.StorageService
 
setLoggingLevel(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
set the logging level at runtime

If both classQualifer and level are empty/null, it will reload the configuration to reset.
If classQualifer is not empty but level is empty/null, it will set the level to null for the defined classQualifer
If level cannot be parsed, then the level will be defaulted to DEBUG

The logback configuration should have < jmxConfigurator /> set
setLoggingLevel(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetLoggingLevel - Class in org.apache.cassandra.tools.nodetool
 
SetLoggingLevel() - Constructor for class org.apache.cassandra.tools.nodetool.SetLoggingLevel
 
setLong(long, long) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
setLong(long, long) - Method in class org.apache.cassandra.io.util.Memory
 
setLong(long, long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
setMaxDataAge(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
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
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.
setMemory(long, long, byte) - Method in class org.apache.cassandra.io.util.Memory
 
setMemoryPoolCapacityInMB(long) - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
 
setMemoryPoolCapacityInMB(long) - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
 
setMetadata(KSMetaData) - Method in class org.apache.cassandra.db.Keyspace
 
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
setName(String, boolean) - Method in class org.apache.cassandra.cql3.RoleName
 
setNativeTransportMaxConcurrentConnections(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setNativeTransportMaxConcurrentConnections(Long) - Method in class org.apache.cassandra.service.StorageProxy
 
setNativeTransportMaxConcurrentConnections(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
setNativeTransportMaxConcurrentConnectionsPerIp(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setNativeTransportMaxConcurrentConnectionsPerIp(Long) - Method in class org.apache.cassandra.service.StorageProxy
 
setNewLocalCompactionStrategy(Class<? extends AbstractCompactionStrategy>, Map<String, String>) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
setOpenResult(boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
setOption(IRoleManager.Option, Object) - Method in class org.apache.cassandra.auth.RoleOptions
Set a value for a specific option.
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.SSLTransportFactory
 
setOptions(Map<String, String>) - Method in class org.apache.cassandra.thrift.TFramedTransportFactory
 
setOrdering(ColumnIdentifier, boolean) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement.RawStatement
 
setOrListToJsonString(ByteBuffer, AbstractType, int) - Static method in class org.apache.cassandra.db.marshal.ListType
 
setOrMapLiteral(Term.Raw) - Method in class org.apache.cassandra.cql3.CqlParser
 
setOtcCoalescingEnoughCoalescedMessages(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
 
setOutputLocalDCOnly(Configuration, boolean) - 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
Deprecated.
set partition filter
setPartitionFilter(Expression) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
setPermissionsUpdateInterval(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setPermissionsValidity(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
 
setPostFlushListener(Runnable) - Method in class org.apache.cassandra.io.util.SequentialWriter
 
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
 
setRate(double) - Method in class org.apache.cassandra.db.compaction.CompactionManager
Sets the rate for the rate limiter.
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
 
setRepairedAt(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
setRepairedAt(long) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
setReplaced() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
setResizeIntervalInMinutes(int) - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
 
setResizeIntervalInMinutes(int) - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
 
setRolesUpdateInterval(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRolesValidity(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRowCacheCapacityInMB(long) - Method in class org.apache.cassandra.service.CacheService
 
setRowCacheCapacityInMB(long) - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
setRowCacheKeysToSave(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRowCacheKeysToSave(int) - Method in class org.apache.cassandra.service.CacheService
 
setRowCacheKeysToSave(int) - 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
 
setRowCacheSizeInMB(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRpcReady(boolean) - Method in class org.apache.cassandra.service.StorageService
 
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.DelayedValue - Class in org.apache.cassandra.cql3
 
Sets.Discarder - Class in org.apache.cassandra.cql3
 
Sets.ElementDiscarder - Class in org.apache.cassandra.cql3
 
Sets.Literal - Class in org.apache.cassandra.cql3
 
Sets.Marker - Class in org.apache.cassandra.cql3
 
Sets.Setter - Class in org.apache.cassandra.cql3
 
Sets.Value - Class in org.apache.cassandra.cql3
 
SetSerializer<T> - Class in org.apache.cassandra.serializers
 
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.
setShort(long, short) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
setShort(long, short) - Method in class org.apache.cassandra.io.util.Memory
 
setShort(long, short) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
setSkipMetadata() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
setSourceFrame(Frame) - Method in class org.apache.cassandra.transport.Message
 
setSources(List<InetAddress>) - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
setSSTableFormatType(SSTableFormat.Type) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
setSSTablePreempiveOpenIntervalInMB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setStart(Composite) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
setStatus(TaskAttemptContext, String) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
Invoke setStatus() on TaskAttemptContext.
setStatus(String) - Method in class org.apache.cassandra.hadoop.ReporterWrapper
 
setStoreFuncUDFContextSignature(String) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
StoreFunc methods
setStoreFuncUDFContextSignature(String) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
StoreFunc methods
setStoreLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
set store configuration settings
setStoreLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
set store configuration settings
setStreamFactory(AutoSavingCache.IStreamFactory) - Static method in class org.apache.cassandra.cache.AutoSavingCache
 
setStreamId(int) - Method in class org.apache.cassandra.transport.Message
 
setStreamThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetStreamThroughput - Class in org.apache.cassandra.tools.nodetool
 
SetStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.SetStreamThroughput
 
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
 
setSubtype(int, AbstractType<?>) - Method in interface org.apache.cassandra.db.composites.CellNameType
Returns a new CellNameType that is equivalent to this one but with one of the subtype replaced by the provided new type.
setSubtype(int, AbstractType<?>) - Method in class org.apache.cassandra.db.composites.CompoundCType
 
setSubtype(int, AbstractType<?>) - Method in class org.apache.cassandra.db.composites.CompoundDenseCellNameType
 
setSubtype(int, AbstractType<?>) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
setSubtype(int, AbstractType<?>) - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType.WithCollection
 
setSubtype(int, AbstractType<?>) - Method in interface org.apache.cassandra.db.composites.CType
Returns a new CType that is equivalent to this CType but with one of the subtype replaced by the provided new type.
setSubtype(int, AbstractType<?>) - Method in class org.apache.cassandra.db.composites.SimpleCType
 
setSubtype(int, AbstractType<?>) - Method in class org.apache.cassandra.db.composites.SimpleDenseCellNameType
 
setSubtype(int, AbstractType<?>) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellNameType
 
setTableAlias(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
setTableInsertStatement(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
setTableMetadata(CFMetaData) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
 
setTableMetadata(CFMetaData) - Method in class org.apache.cassandra.utils.NativeSSTableLoaderClient
 
setTableSchema(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
Setter(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Setter
 
Setter(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Lists.Setter
 
Setter(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Maps.Setter
 
Setter(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Setter
 
SetterByIndex(ColumnDefinition, Term, Term) - Constructor for class org.apache.cassandra.cql3.Lists.SetterByIndex
 
SetterByKey(ColumnDefinition, Term, Term) - Constructor for class org.apache.cassandra.cql3.Maps.SetterByKey
 
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
setTokens(Collection<Token>) - Method in class org.apache.cassandra.service.StorageService
This method updates the local token on disk
setTombstoneFailureThreshold(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setTombstoneFailureThreshold(int) - Method in class org.apache.cassandra.service.StorageService
 
setTombstoneFailureThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Sets the threshold for abandoning queries with many tombstones
setTombstoneWarnThreshold(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setTombstoneWarnThreshold(int) - Method in class org.apache.cassandra.service.StorageService
 
setTombstoneWarnThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Sets the threshold for warning queries with many tombstones
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
 
SetTraceProbability - Class in org.apache.cassandra.tools.nodetool
 
SetTraceProbability() - Constructor for class org.apache.cassandra.tools.nodetool.SetTraceProbability
 
setTracingId(UUID) - Method in class org.apache.cassandra.transport.Message.Response
 
setTracingRequested() - Method in class org.apache.cassandra.transport.Message.Request
 
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) - Static method in class org.apache.cassandra.hadoop.pig.StorageHelper
Deprecated.
set the value to the position of the tuple
SetType<T> - Class in org.apache.cassandra.db.marshal
 
SetType(AbstractType<T>, boolean) - Constructor for class org.apache.cassandra.db.marshal.SetType
 
setUDFContextSignature(String) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
setup() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
setup() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
setup() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
setup() - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
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 interface org.apache.cassandra.auth.IRoleManager
Hook to perform implementation specific initialization, called once upon system startup.
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.
setupCompleted() - Method in class org.apache.cassandra.service.CassandraDaemon
 
setUpdateInterval(int) - Method in class org.apache.cassandra.auth.PermissionsCache
 
setUpdateInterval(int) - Method in interface org.apache.cassandra.auth.PermissionsCacheMBean
 
setUpdateInterval(int) - Method in class org.apache.cassandra.auth.RolesCache
 
setUpdateInterval(int) - Method in interface org.apache.cassandra.auth.RolesCacheMBean
 
setupJob(JobContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
Deprecated.
 
setupJob(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
 
setupKeyCache() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
setupTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.BulkOutputFormat.NullOutputCommitter
Deprecated.
 
setupTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
 
setUserDefined(boolean) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
setUserNameAndPassword(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setValidity(int) - Method in class org.apache.cassandra.auth.PermissionsCache
 
setValidity(int) - Method in interface org.apache.cassandra.auth.PermissionsCacheMBean
 
setValidity(int) - Method in class org.apache.cassandra.auth.RolesCache
 
setValidity(int) - Method in interface org.apache.cassandra.auth.RolesCacheMBean
 
SetValue(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.SetValue
 
setVersion(InetAddress, int) - Method in class org.apache.cassandra.net.MessagingService
 
setWarnings(List<String>) - Method in class org.apache.cassandra.transport.Message.Response
 
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
 
SHARED - Static variable in class org.apache.cassandra.concurrent.SharedExecutorPool
 
SharedCloseable - Interface in org.apache.cassandra.utils.concurrent
A simple extension of AutoCloseable, that represents a resource that can be utilised in multiple locations, each managing their own closure of the resource, so that when the last such instance is closed all are.
SharedCloseableImpl - Class in org.apache.cassandra.utils.concurrent
A simple abstract implementation of SharedCloseable
SharedCloseableImpl(RefCounted.Tidy) - Constructor for class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
 
SharedCloseableImpl(SharedCloseableImpl) - Constructor for class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
 
sharedCopy() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
sharedCopy() - Method in class org.apache.cassandra.io.util.BufferedPoolingSegmentedFile
 
sharedCopy() - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile
 
sharedCopy() - Method in class org.apache.cassandra.io.util.ChannelProxy
 
sharedCopy() - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
 
sharedCopy() - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile
 
sharedCopy() - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile
 
sharedCopy() - Method in class org.apache.cassandra.io.util.SafeMemory
 
sharedCopy() - Method in class org.apache.cassandra.io.util.SegmentedFile
 
sharedCopy() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
 
sharedCopy() - Method in class org.apache.cassandra.utils.BloomFilter
 
sharedCopy() - Method in interface org.apache.cassandra.utils.concurrent.SharedCloseable
 
sharedCopy() - Method in interface org.apache.cassandra.utils.IFilter
 
SharedExecutorPool - Class in org.apache.cassandra.concurrent
A pool of worker threads that are shared between all Executors created with it.
SharedExecutorPool(String) - Constructor for class org.apache.cassandra.concurrent.SharedExecutorPool
 
ShortSerializer - Class in org.apache.cassandra.serializers
 
ShortSerializer() - Constructor for class org.apache.cassandra.serializers.ShortSerializer
 
ShortType - Class in org.apache.cassandra.db.marshal
 
shouldBeEnabled() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
shouldClearLocal(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
 
shouldDefragment() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
shouldDefragment() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
shouldDefragment() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
shouldHint() - Method in class org.apache.cassandra.net.CallbackInfo
 
shouldHint() - Method in class org.apache.cassandra.net.WriteCallbackInfo
 
shouldHint(InetAddress) - Static method in class org.apache.cassandra.service.StorageProxy
 
shouldHintByDC() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
shouldInclude(SSTableReader) - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
 
shouldInclude(SSTableReader) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
shouldInclude(SSTableReader) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
shouldInclude(SSTableReader) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
shouldInclude(InetAddress) - Method in class org.apache.cassandra.dht.RangeStreamer.ExcludeLocalNodeFilter
 
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
 
shouldListenOnBroadcastAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
shouldLogAverage - Variable in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
 
shouldPullSchemaFrom(InetAddress) - Static method in class org.apache.cassandra.service.MigrationManager
 
shouldReplay(ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayFilter
 
shutdown() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
shutdown() - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
shutdown() - Static method in class org.apache.cassandra.db.BatchlogManager
 
shutdown() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
 
shutdown() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManager
Initiates the shutdown process for the management thread.
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.WrappingCompactionStrategy
 
SHUTDOWN - Static variable in class org.apache.cassandra.gms.VersionedValue
 
shutdown(boolean) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
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)
shutdown() - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
 
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
 
shutdownGracefully(long, long, TimeUnit) - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
 
shutdownNow() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
shutdownNow() - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
shutdownNow() - Static method in class org.apache.cassandra.concurrent.StageManager
This method shuts down all registered stages.
shutdownNow() - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
 
shutdownPostFlushExecutor() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
SigarLibrary - Class in org.apache.cassandra.utils
 
signal() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
signal() - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
 
signal() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
Signal one waiting thread
signalAll() - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
 
signalAll() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
Signal all waiting threads
SimpleCBuilder(CType) - Constructor for class org.apache.cassandra.db.composites.SimpleCType.SimpleCBuilder
 
SimpleClient - Class in org.apache.cassandra.transport
 
SimpleClient(String, int, int, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.SimpleClient
 
SimpleClient(String, int, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.SimpleClient
 
SimpleClient(String, int, int) - Constructor for class org.apache.cassandra.transport.SimpleClient
 
SimpleClient(String, int) - Constructor for class org.apache.cassandra.transport.SimpleClient
 
SimpleClient.EventHandler - Interface in org.apache.cassandra.transport
 
SimpleClient.SimpleEventHandler - Class in org.apache.cassandra.transport
 
SimpleComposite - Class in org.apache.cassandra.db.composites
A "simple" (not-truly-composite) Composite.
simpleCondition(Term.Raw, Operator) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
A condition on a column.
SimpleCondition - Class in org.apache.cassandra.utils.concurrent
 
SimpleCondition() - Constructor for class org.apache.cassandra.utils.concurrent.SimpleCondition
 
SimpleCType - Class in org.apache.cassandra.db.composites
A not truly-composite CType.
SimpleCType(AbstractType<?>) - Constructor for class org.apache.cassandra.db.composites.SimpleCType
 
SimpleCType.SimpleCBuilder - Class in org.apache.cassandra.db.composites
 
SimpleDateSerializer - Class in org.apache.cassandra.serializers
 
SimpleDateSerializer() - Constructor for class org.apache.cassandra.serializers.SimpleDateSerializer
 
SimpleDateType - Class in org.apache.cassandra.db.marshal
 
simpleDense(ByteBuffer) - Static method in class org.apache.cassandra.db.composites.CellNames
 
SimpleDenseCellName - Class in org.apache.cassandra.db.composites
 
SimpleDenseCellNameType - Class in org.apache.cassandra.db.composites
 
SimpleDenseCellNameType(AbstractType<?>) - Constructor for class org.apache.cassandra.db.composites.SimpleDenseCellNameType
 
SimpleEventHandler() - Constructor for class org.apache.cassandra.transport.SimpleClient.SimpleEventHandler
 
simpleInCondition(List<Term.Raw>) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
An IN condition on a column.
simpleInCondition(AbstractMarker.INRaw) - Static method in class org.apache.cassandra.cql3.ColumnCondition.Raw
An IN condition on a column with a single marker.
simpleMapping(Iterable<ColumnDefinition>) - Static method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
SimpleSeedProvider - Class in org.apache.cassandra.locator
 
SimpleSeedProvider(Map<String, String>) - Constructor for class org.apache.cassandra.locator.SimpleSeedProvider
 
SimpleSelector - Class in org.apache.cassandra.cql3.selection
 
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
 
simpleSparse(ColumnIdentifier) - Static method in class org.apache.cassandra.db.composites.CellNames
 
SimpleSparseCellName - Class in org.apache.cassandra.db.composites
 
SimpleSparseCellNameType - Class in org.apache.cassandra.db.composites
 
SimpleSparseCellNameType(AbstractType<?>) - Constructor for class org.apache.cassandra.db.composites.SimpleSparseCellNameType
 
SimpleSparseInternedCellName - Class in org.apache.cassandra.db.composites
 
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
 
simulateFailedFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
singleColumnInValues() - Method in class org.apache.cassandra.cql3.CqlParser
 
SingleColumnRelation - Class in org.apache.cassandra.cql3
Relations encapsulate the relationship between an entity of some kind, and a value (term).
SingleColumnRelation(ColumnIdentifier.Raw, Term.Raw, Operator, Term.Raw) - Constructor for class org.apache.cassandra.cql3.SingleColumnRelation
Creates a new relation.
SingleColumnRelation(ColumnIdentifier.Raw, Operator, Term.Raw) - Constructor for class org.apache.cassandra.cql3.SingleColumnRelation
Creates a new relation.
SingleColumnRestriction - Class in org.apache.cassandra.cql3.restrictions
 
SingleColumnRestriction(ColumnDefinition) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
 
SingleColumnRestriction.Contains - Class in org.apache.cassandra.cql3.restrictions
 
SingleColumnRestriction.EQ - Class in org.apache.cassandra.cql3.restrictions
 
SingleColumnRestriction.IN - Class in org.apache.cassandra.cql3.restrictions
 
SingleColumnRestriction.InWithMarker - Class in org.apache.cassandra.cql3.restrictions
 
SingleColumnRestriction.InWithValues - Class in org.apache.cassandra.cql3.restrictions
 
SingleColumnRestriction.Slice - Class in org.apache.cassandra.cql3.restrictions
 
SingleDatacenterFilter(IEndpointSnitch, String) - Constructor for class org.apache.cassandra.dht.RangeStreamer.SingleDatacenterFilter
 
SinglePartitionPager - Interface in org.apache.cassandra.service.pager
Common interface to single partition queries (by slice and by name).
singleton(T, Comparator<? super T>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
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.cql3.VariableSpecifications
 
size() - Method in class org.apache.cassandra.db.AbstractNativeCell
 
size() - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
 
size() - Method in class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
 
size() - Method in class org.apache.cassandra.db.composites.BoundedComposite
 
size() - Method in interface org.apache.cassandra.db.composites.Composite
 
size() - Method in class org.apache.cassandra.db.composites.CompoundComposite
 
size() - Method in class org.apache.cassandra.db.composites.CompoundCType
 
size() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
 
size() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName.WithCollection
 
size() - Method in interface org.apache.cassandra.db.composites.CType
The number of subtypes for this CType.
size() - Method in class org.apache.cassandra.db.composites.SimpleComposite
 
size() - Method in class org.apache.cassandra.db.composites.SimpleCType
 
size() - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
 
size() - Method in class org.apache.cassandra.db.marshal.TupleType
 
size() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
size() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
size() - Method in class org.apache.cassandra.io.util.ChannelProxy
 
size - Variable in class org.apache.cassandra.io.util.Memory
 
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() - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
Return the number of buckets where recorded values are stored.
size - Variable in class org.apache.cassandra.metrics.FileCacheMetrics
Total size of file cache, in bytes
size() - Method in class org.apache.cassandra.streaming.messages.FileMessageHeader
 
size() - Method in class org.apache.cassandra.tools.nodetool.SetHostStat
 
size() - Method in class org.apache.cassandra.utils.BiMultiValMap
 
size() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
size() - Method in class org.apache.cassandra.utils.concurrent.Accumulator
 
size() - Method in class org.apache.cassandra.utils.concurrent.Refs
 
size() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
size() - Method in class org.apache.cassandra.utils.ExpiringMap
 
size - Variable in class org.apache.cassandra.utils.MerkleTree.RowHash
 
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.
SIZE_ESTIMATES - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
SizeComparator() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader.SizeComparator
 
SizeEstimatesRecorder - Class in org.apache.cassandra.db
A very simplistic/crude partition count/size estimator.
sizeInBytes() - Method in class org.apache.cassandra.service.FileCacheService
 
sizeOf(Cell) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
sizeOf(Cell) - Method in class org.apache.cassandra.db.NativeCounterCell
 
sizeOf(Cell) - Method in class org.apache.cassandra.db.NativeExpiringCell
 
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
 
sizeOf(String) - Static method in class org.apache.cassandra.utils.ObjectSizes
Memory a String consumes
sizeOfArray(byte[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
Memory a byte array consumes
sizeOfArray(long[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
Memory a long array consumes
sizeOfArray(int[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
Memory an int array consumes
sizeOfArray(Object[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
Memory a reference array consumes itself only
sizeOfBytes(byte[]) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeOfBytesMap(Map<String, ByteBuffer>) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeOfCollectionSize(int, int) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
 
sizeOfConsistencyLevel(ConsistencyLevel) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeOfEnumValue(T) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeOfInet(InetSocketAddress) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeOfLongString(String) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeOfReferenceArray(int) - Static method in class org.apache.cassandra.utils.ObjectSizes
Memory a reference array consumes
sizeOfString(String) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeOfStringList(List<String>) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeOfStringMap(Map<String, String>) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeOfStringToStringListMap(Map<String, List<String>>) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeOfUUID(UUID) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeOfValue(ByteBuffer, int) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
 
sizeOfValue(byte[]) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeOfValue(ByteBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeOfValueList(List<ByteBuffer>) - Static method in class org.apache.cassandra.transport.CBUtil
 
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
 
sizeOnHeapExcludingData(ByteBuffer[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
 
sizeOnHeapExcludingData(ByteBuffer) - Static method in class org.apache.cassandra.utils.ObjectSizes
 
sizeOnHeapOf(ByteBuffer[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
Memory a ByteBuffer array consumes.
sizeOnHeapOf(ByteBuffer) - Static method in class org.apache.cassandra.utils.ObjectSizes
Memory a byte buffer consumes
sizeOnLeft() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
 
sizeOnRight() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
 
SizeTieredCompactionStrategy - Class in org.apache.cassandra.db.compaction
 
SizeTieredCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
SizeTieredCompactionStrategyOptions - Class in org.apache.cassandra.db.compaction
 
SizeTieredCompactionStrategyOptions(Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
SizeTieredCompactionStrategyOptions() - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
sizeTieredOptions - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
skip(DataInput) - Method in interface org.apache.cassandra.db.composites.CType.Serializer
 
skip(DataInput) - Method in class org.apache.cassandra.db.DeletionTime.Serializer
 
skip(DataInput) - Static 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
 
SKIP_SYNC - Static variable in class org.apache.cassandra.utils.SyncUtil
 
skipBloomFilter(DataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
 
skipBody(DataInput, Version) - Method in class org.apache.cassandra.db.RangeTombstone.Serializer
 
skipBytes(int) - Method in class org.apache.cassandra.io.util.AbstractDataInput
 
skipBytes(int) - Method in class org.apache.cassandra.io.util.NIODataInputStream
 
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
 
skipIndex(DataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
Skip the index
skipMetadata() - Method in class org.apache.cassandra.cql3.QueryOptions
 
skipNext() - Method in class org.apache.cassandra.db.AtomDeserializer
Skips the next atom.
skipNext() - Method in interface org.apache.cassandra.db.composites.CellNameType.Deserializer
Skip the next name (consuming it).
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.memory
+ * The SlabAllocator is a bump-the-pointer allocator that allocates + * large (1MB) global regions and then doles them out to threads that + * request smaller sized (up to 128kb) slices into the array.
SlabPool - Class in org.apache.cassandra.utils.memory
 
SlabPool(long, long, float, Runnable) - Constructor for class org.apache.cassandra.utils.memory.SlabPool
 
Slice(List<ColumnDefinition>, Bound, boolean, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
 
Slice(ColumnDefinition, Bound, boolean, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
 
Slice(CType, List<ColumnDefinition>, Bound, boolean, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.TokenRestriction.Slice
 
slice() - Method in class org.apache.cassandra.db.AbstractNativeCell
 
slice() - Method in class org.apache.cassandra.db.composites.AbstractComposite
 
slice() - Method in interface org.apache.cassandra.db.composites.Composite
 
slice(Object[], boolean) - Static method in class org.apache.cassandra.utils.btree.BTree
Returns an Iterator over the entire tree
slice(Object[], Comparator<K>, K, K, boolean) - Static method in class org.apache.cassandra.utils.btree.BTree
Returns an Iterator over a sub-range of the tree
slice(Object[], Comparator<K>, K, boolean, K, boolean, boolean) - Static method in class org.apache.cassandra.utils.btree.BTree
Returns an Iterator over a sub-range of the tree
slice(boolean, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
 
slice(boolean, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
slice(boolean, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
SliceByNamesReadCommand - Class in org.apache.cassandra.db
 
SliceByNamesReadCommand(String, ByteBuffer, String, long, NamesQueryFilter) - Constructor for class org.apache.cassandra.db.SliceByNamesReadCommand
 
sliceBytes(ByteBuffer, int, int) - Static method in class org.apache.cassandra.db.composites.AbstractCType
 
SliceFromReadCommand - Class in org.apache.cassandra.db
 
SliceFromReadCommand(String, ByteBuffer, String, long, SliceQueryFilter) - Constructor for class org.apache.cassandra.db.SliceFromReadCommand
 
SliceQueryFilter - Class in org.apache.cassandra.db.filter
 
SliceQueryFilter(Composite, Composite, boolean, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
 
SliceQueryFilter(Composite, Composite, 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
 
SliceQueryFilter(ColumnSlice, 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) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
 
SliceQueryFilter.Serializer - Class in org.apache.cassandra.db.filter
 
sliceQueryFilterSerializer() - Method in class org.apache.cassandra.db.composites.AbstractCType
 
sliceQueryFilterSerializer() - Method in interface org.apache.cassandra.db.composites.CType
 
SliceQueryPager - Class in org.apache.cassandra.service.pager
Pager over a SliceFromReadCommand.
slices - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
sliceSerializer() - Method in class org.apache.cassandra.db.composites.AbstractCType
 
sliceSerializer() - Method in interface org.apache.cassandra.db.composites.CType
 
smallMessageCompletedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
Completed tasks for small message TCP Connections
smallMessageDroppedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
Dropped tasks for small message TCP Connections
smallMessagePendingTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
Pending tasks for small message TCP Connections
smallMessages - Variable in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
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, Predicate<SSTableReader>, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
snapshot(String, String) - Method in class org.apache.cassandra.db.Keyspace
Take a snapshot of the specific column family, or the entire set of column families if columnFamily is null with a given timestamp
Snapshot - Class in org.apache.cassandra.tools.nodetool
 
Snapshot() - Constructor for class org.apache.cassandra.tools.nodetool.Snapshot
 
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
 
SnapshotDeletingTask - Class in org.apache.cassandra.io.sstable
 
SnapshotDetailsTabularData - Class in org.apache.cassandra.db
 
SnapshotDetailsTabularData() - Constructor for class org.apache.cassandra.db.SnapshotDetailsTabularData
 
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.Keyspace
Check whether snapshots already exists for a given name.
SnapshotMessage - Class in org.apache.cassandra.repair.messages
 
SnapshotMessage(RepairJobDesc) - Constructor for class org.apache.cassandra.repair.messages.SnapshotMessage
 
SnapshotMessage.SnapshotMessageSerializer - Class in org.apache.cassandra.repair.messages
 
SnapshotMessageSerializer() - Constructor for class org.apache.cassandra.repair.messages.SnapshotMessage.SnapshotMessageSerializer
 
snapshotOnVersionChange() - Static method in class org.apache.cassandra.db.SystemKeyspace
Compare the release version in the system.local table with the one included in the distro.
snapshots(String) - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
SnapshotTask - Class in org.apache.cassandra.repair
SnapshotTask is a task that sends snapshot request.
SnapshotTask(RepairJobDesc, InetAddress) - Constructor for class org.apache.cassandra.repair.SnapshotTask
 
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
 
snapshotWithoutFlush(String, Predicate<SSTableReader>, boolean) - 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.net.IncomingStreamingConnection
 
socket - Variable in class org.apache.cassandra.transport.Server
 
SOCKET_TIMEOUT - Static variable in class org.apache.cassandra.thrift.SSLTransportFactory
 
SOFTIRQ_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
 
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
 
sorted() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
Creates a CQLSSTableWriter that expects sorted inputs.
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
 
sparseCFMetaData(String, String, AbstractType<?>) - Static method in class org.apache.cassandra.config.CFMetaData
 
specializedColumnOperation(List<Pair<ColumnIdentifier.Raw, Operation.RawUpdate>>, ColumnIdentifier.Raw, Term.Raw) - Method in class org.apache.cassandra.cql3.CqlParser
 
speculativeRetries - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
 
speculativeRetry(CFMetaData.SpeculativeRetry) - Method in class org.apache.cassandra.config.CFMetaData
 
split() - Method in class org.apache.cassandra.db.compaction.SSTableSplitter
 
split(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
remove the provided readers from this Transaction, and return a new Transaction to manage them only permitted to be called if the current Transaction has never been used
split(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
Split a composite column names into it's components.
split(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
split(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TupleType
Split a tuple value into its component values.
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.
SplitController(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.SplitController
 
splitOutStaticSlice(CFMetaData) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
Splits this filter into two SliceQueryFilters: one that slices only the static columns, and one that slices the remainder of the normal data.
splitSize - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
splitSize - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
SplittingCompactionTask(ColumnFamilyStore, LifecycleTransaction, int) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
 
SplittingSizeTieredCompactionWriter - Class in org.apache.cassandra.db.compaction.writers
CompactionAwareWriter that splits input in differently sized sstables Biggest sstable will be total_compaction_size / 2, second biggest total_compaction_size / 4 etc until the result would be sub 50MB, all those are put in the same
SplittingSizeTieredCompactionWriter(ColumnFamilyStore, LifecycleTransaction, Set<SSTableReader>, OperationType) - Constructor for class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
 
SplittingSizeTieredCompactionWriter(ColumnFamilyStore, LifecycleTransaction, Set<SSTableReader>, OperationType, long) - Constructor for class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
 
splitValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.IN
 
splitValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InWithMarker
 
splitValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InWithValues
 
src - Variable in class org.apache.cassandra.repair.messages.SyncRequest
 
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.thrift
 
SSLTransportFactory() - Constructor for class org.apache.cassandra.thrift.SSLTransportFactory
 
sstable - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
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.notifications.SSTableRepairStatusChanged
 
sstable - Variable in class org.apache.cassandra.streaming.messages.IncomingFileMessage
 
sstable - Variable in class org.apache.cassandra.streaming.StreamWriter
 
SSTABLE_ACTIVITY - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
SSTABLE_COMPRESSION - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
 
sstable_preemptive_open_interval_in_mb - Variable in class org.apache.cassandra.config.Config
 
SSTableAddedNotification - Class in org.apache.cassandra.notifications
 
SSTableAddedNotification(SSTableReader) - Constructor for class org.apache.cassandra.notifications.SSTableAddedNotification
 
sstableComparator - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
sstableCompressor - Variable in class org.apache.cassandra.io.compress.CompressionParameters
 
SSTableDeletingNotification - Class in org.apache.cassandra.notifications
Fired right before removing an SSTable.
SSTableDeletingNotification(SSTableReader) - Constructor for class org.apache.cassandra.notifications.SSTableDeletingNotification
 
SSTableDeletingTask - Class in org.apache.cassandra.io.sstable
 
SSTableDeletingTask(Descriptor, Set<Component>, Counter, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableDeletingTask
realDescriptor is the actual descriptor for the sstable, the descriptor inside referent can be 'faked' as FINAL for early opened files.
SSTableExpiredBlockers - Class in org.apache.cassandra.tools
During compaction we can drop entire sstables if they only contain expired tombstones and if it is guaranteed to not cover anything in other sstables.
SSTableExpiredBlockers() - Constructor for class org.apache.cassandra.tools.SSTableExpiredBlockers
 
SSTableExport - Class in org.apache.cassandra.tools
Export SSTables to JSON format.
SSTableExport() - Constructor for class org.apache.cassandra.tools.SSTableExport
 
SSTableFormat - Interface in org.apache.cassandra.io.sstable.format
Provides the accessors to data on disk.
SSTableFormat.Type - Enum in org.apache.cassandra.io.sstable.format
 
SSTableIdentityIterator - Class in org.apache.cassandra.io.sstable
 
SSTableIdentityIterator(SSTableReader, RandomAccessReader, DecoratedKey) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
Used to iterate through the columns of a row.
SSTableIdentityIterator(SSTableReader, RandomAccessReader, DecoratedKey, boolean) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
Used to iterate through the columns of a row.
SSTableImport - Class in org.apache.cassandra.tools
Create SSTables from JSON input
SSTableImport() - Constructor for class org.apache.cassandra.tools.SSTableImport
 
SSTableImport(boolean) - Constructor for class org.apache.cassandra.tools.SSTableImport
 
SSTableImport(Integer, boolean) - Constructor for class org.apache.cassandra.tools.SSTableImport
 
SSTableIntervalTree - Class in org.apache.cassandra.db.lifecycle
 
sstableLevel - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
sstableLevel(int) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
sstableLevel - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
sstableLevel - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
 
sstableLevel - Variable in class org.apache.cassandra.streaming.StreamReader
 
SSTableLevelResetter - Class in org.apache.cassandra.tools
Reset level to 0 on a given set of sstables
SSTableLevelResetter() - Constructor for class org.apache.cassandra.tools.SSTableLevelResetter
 
SSTableListChangedNotification - Class in org.apache.cassandra.notifications
 
SSTableListChangedNotification(Collection<SSTableReader>, Collection<SSTableReader>, OperationType) - Constructor for class org.apache.cassandra.notifications.SSTableListChangedNotification
 
sstableLister() - Method in class org.apache.cassandra.db.Directories
 
SSTableLister() - Constructor for class org.apache.cassandra.db.Directories.SSTableLister
 
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(File, SSTableLoader.Client, OutputHandler, int) - Constructor for class org.apache.cassandra.io.sstable.SSTableLoader
 
SSTableLoader.Client - Class in org.apache.cassandra.io.sstable
 
sstableMap - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
sstableMetadata - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
SSTableMetadataViewer - Class in org.apache.cassandra.tools
Shows the contents of sstable metadata
SSTableMetadataViewer() - Constructor for class org.apache.cassandra.tools.SSTableMetadataViewer
 
SSTableOfflineRelevel - Class in org.apache.cassandra.tools
Create a decent leveling for the given keyspace/column family Approach is to sort the sstables by their last token given an original leveling like this (note that [ ] indicates token boundaries, not sstable size on disk, all sstables are the same size) L3 [][][][][][][][][][][] L2 [ ][ ][ ][ ] L1 [ ][ ] L0 [ ] Will look like this after being dropped to L0 and sorted by last token (and, to illustrate overlap, the overlapping ones are put on a new line): [][][] [ ][][][] [ ] [ ] ...
SSTableOfflineRelevel() - Constructor for class org.apache.cassandra.tools.SSTableOfflineRelevel
 
sstableOrdering - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
SSTableReader - Class in org.apache.cassandra.io.sstable.format
An SSTableReader can be constructed in a number of places, but typically is either read from disk at startup, or constructed from a flushed memtable, or after compaction to replace some existing sstables.
SSTableReader(Descriptor, Set<Component>, CFMetaData, IPartitioner, long, StatsMetadata, SSTableReader.OpenReason) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader
 
SSTableReader.Factory - Class in org.apache.cassandra.io.sstable.format
 
SSTableReader.OpenReason - Enum in org.apache.cassandra.io.sstable.format
 
SSTableReader.Operator - Class in org.apache.cassandra.io.sstable.format
TODO: Move someplace reusable
SSTableReader.SizeComparator - Class in org.apache.cassandra.io.sstable.format
 
SSTableReader.UniqueIdentifier - Class in org.apache.cassandra.io.sstable.format
 
SSTableRepairedAtSetter - Class in org.apache.cassandra.tools
Set repairedAt status on a given set of sstables.
SSTableRepairedAtSetter() - Constructor for class org.apache.cassandra.tools.SSTableRepairedAtSetter
 
SSTableRepairStatusChanged - Class in org.apache.cassandra.notifications
 
SSTableRepairStatusChanged(Collection<SSTableReader>) - Constructor for class org.apache.cassandra.notifications.SSTableRepairStatusChanged
 
SSTableRewriter - Class in org.apache.cassandra.io.sstable
Wraps one or more writers as output for rewriting one or more readers: every sstable_preemptive_open_interval_in_mb we look in the summary we're collecting for the latest writer for the penultimate key that we know to have been fully flushed to the index file, and then double check that the key is fully present in the flushed data file.
SSTableRewriter(ColumnFamilyStore, LifecycleTransaction, long, boolean) - Constructor for class org.apache.cassandra.io.sstable.SSTableRewriter
 
SSTableRewriter(ColumnFamilyStore, LifecycleTransaction, long, boolean, boolean) - Constructor for class org.apache.cassandra.io.sstable.SSTableRewriter
 
SSTableRewriter(ColumnFamilyStore, LifecycleTransaction, long, boolean, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableRewriter
 
sstables - Variable in class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
 
sstables - Variable in class org.apache.cassandra.db.compaction.LeveledManifest.CompactionCandidate
 
sstables - Variable in class org.apache.cassandra.db.lifecycle.View
 
sstables - Variable in class org.apache.cassandra.streaming.StreamReceiveTask
 
SSTableSimpleUnsortedWriter - Class in org.apache.cassandra.io.sstable
Deprecated.
this class is depracted in favor of CQLSSTableWriter.
SSTableSimpleUnsortedWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>, int, CompressionParameters) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
Deprecated.
Create a new buffering writer.
SSTableSimpleUnsortedWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>, int) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
Deprecated.
 
SSTableSimpleUnsortedWriter(File, CFMetaData, IPartitioner, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
Deprecated.
 
SSTableSimpleWriter - Class in org.apache.cassandra.io.sstable
Deprecated.
this class is depracted in favor of CQLSSTableWriter.
SSTableSimpleWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleWriter
Deprecated.
Create a new writer.
SSTableSimpleWriter(File, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleWriter
Deprecated.
 
sstablesInBounds(RowPosition, RowPosition) - Method in class org.apache.cassandra.db.lifecycle.View
Returns the sstables that have any partition between left and right, when both bounds are taken inclusively.
sstablesInBounds(RowPosition, RowPosition, SSTableIntervalTree) - Static method in class org.apache.cassandra.db.lifecycle.View
 
sstablesMap - Variable in class org.apache.cassandra.db.lifecycle.View
 
sstablesPerReadHistogram - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Histogram of the number of sstable data files accessed per read
sstablesPerReadHistogram - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Histogram of the number of sstable data files accessed per read
SSTableSplitter - Class in org.apache.cassandra.db.compaction
 
SSTableSplitter(ColumnFamilyStore, LifecycleTransaction, int) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter
 
SSTableSplitter.SplitController - Class in org.apache.cassandra.db.compaction
 
SSTableSplitter.SplittingCompactionTask - Class in org.apache.cassandra.db.compaction
 
SSTableSplitter.StatsCollector - Class in org.apache.cassandra.db.compaction
 
sstablesRewrite(boolean, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
SSTableStreamingSections(Ref<SSTableReader>, List<Pair<Long, Long>>, long, long) - Constructor for class org.apache.cassandra.streaming.StreamSession.SSTableStreamingSections
 
sstableWriter - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
SSTableWriter - Class in org.apache.cassandra.io.sstable.format
This is the API all table writers must implement.
SSTableWriter(Descriptor, long, long, CFMetaData, IPartitioner, MetadataCollector) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableWriter
 
SSTableWriter.Factory - Class in org.apache.cassandra.io.sstable.format
 
SSTableWriter.TransactionalProxy - Class in org.apache.cassandra.io.sstable.format
 
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
 
StandaloneVerifier - Class in org.apache.cassandra.tools
 
StandaloneVerifier() - Constructor for class org.apache.cassandra.tools.StandaloneVerifier
 
start() - Method in class org.apache.cassandra.db.AbstractNativeCell
 
start() - Method in class org.apache.cassandra.db.BatchlogManager
 
start() - Method in class org.apache.cassandra.db.composites.AbstractComposite
 
start() - Method in interface org.apache.cassandra.db.composites.Composite
 
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 - Variable in class org.apache.cassandra.db.PagedRangeCommand
 
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.net.OutboundTcpConnectionPool
 
start(ListeningExecutorService) - Method in class org.apache.cassandra.repair.RepairSession
Start RepairJob on given ColumnFamilies.
start - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
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.streaming.StreamSession
 
start() - Method in class org.apache.cassandra.thrift.ThriftServer
 
start() - Method in class org.apache.cassandra.transport.Server
 
start() - Method in class org.apache.cassandra.utils.concurrent.OpOrder
Start an operation against this OpOrder.
start_native_transport - Variable in class org.apache.cassandra.config.Config
 
start_rpc - Variable in class org.apache.cassandra.config.Config
 
startBatchlogReplay() - Method in class org.apache.cassandra.db.BatchlogManager
 
startBroadcasting() - Method in class org.apache.cassandra.service.LoadBroadcaster
 
startCompaction(ColumnFamilyStore, Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.SystemKeyspace
Write compaction log, except columfamilies under system keyspace.
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
 
startKey() - Method in class org.apache.cassandra.db.DataRange
 
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
 
startOf(ByteBuffer) - Static method in class org.apache.cassandra.db.SuperColumns
 
startParentRepair(UUID, String, String[], Collection<Range<Token>>) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
startRepairs(UUID, UUID, String, String[], Range<Token>, Iterable<InetAddress>) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
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
 
startSync(List<Range<Token>>) - Method in class org.apache.cassandra.repair.LocalSyncTask
Starts sending/receiving our list of differences to/from the remote endpoint: creates a callback that will be called out of band once the streams complete.
startSync(List<Range<Token>>) - Method in class org.apache.cassandra.repair.RemoteSyncTask
 
startSync(List<Range<Token>>) - Method in class org.apache.cassandra.repair.SyncTask
 
startThriftServer() - Method in class org.apache.cassandra.tools.NodeProbe
 
startTimerPeriod(int) - Static method in class org.apache.cassandra.utils.WindowsTimer
 
startTransfer() - Method in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
 
startup() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
Performs any extra initialization required
startup() - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
StartupCheck - Interface in org.apache.cassandra.service
A test to determine if the system is in a valid state to start up.
startupChecks - Variable in class org.apache.cassandra.service.CassandraDaemon
 
StartupChecks - Class in org.apache.cassandra.service
Verifies that the system and environment is in a fit state to be started.
StartupChecks() - Constructor for class org.apache.cassandra.service.StartupChecks
 
StartupException - Exception in org.apache.cassandra.exceptions
An exception thrown during system startup, indicating the environment or system is not in a valid state to startup.
StartupException(int, String) - Constructor for exception org.apache.cassandra.exceptions.StartupException
 
StartupException(int, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.StartupException
 
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
 
stat - Variable in class org.apache.cassandra.repair.SyncTask
 
state(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
State() - Constructor for class org.apache.cassandra.service.ClientWarn.State
 
state() - Method in class org.apache.cassandra.service.pager.NamesQueryPager
 
state() - Method in interface org.apache.cassandra.service.pager.QueryPager
Get the current state of the pager.
state() - Method in class org.apache.cassandra.service.pager.RangeNamesQueryPager
 
state() - Method in class org.apache.cassandra.service.pager.RangeSliceQueryPager
 
state() - Method in class org.apache.cassandra.service.pager.SliceQueryPager
 
state - Variable in class org.apache.cassandra.streaming.SessionInfo
Current session state
state(StreamSession.State) - Method in class org.apache.cassandra.streaming.StreamSession
Set current state to newState.
state() - Method in class org.apache.cassandra.streaming.StreamSession
 
state() - Method in class org.apache.cassandra.thrift.CassandraServer
 
state() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
 
stateFunction() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
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
 
StatementRestrictions - Class in org.apache.cassandra.cql3.restrictions
The restrictions corresponding to the relations specified on the where-clause of CQL query.
StatementRestrictions(CFMetaData, List<Relation>, VariableSpecifications, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
states() - Method in class org.apache.cassandra.gms.EndpointState
 
stateType - Variable in class org.apache.cassandra.cql3.functions.UDAggregate
 
stateType() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
STATIC_MARKER - Static variable in class org.apache.cassandra.db.marshal.CompositeType
 
staticBuilder(CompositeType) - Static method in class org.apache.cassandra.db.marshal.CompositeType.Builder
 
staticColumns() - Method in class org.apache.cassandra.config.CFMetaData
 
staticDef(CFMetaData, ByteBuffer, AbstractType<?>, Integer) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
staticPrefix() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
staticPrefix() - Method in interface org.apache.cassandra.db.composites.CellNameType
The prefix to use for static columns.
staticPrefix() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
STATS - Static variable in class org.apache.cassandra.io.sstable.Component
 
stats - Variable in class org.apache.cassandra.repair.RepairResult
 
StatsCollector() - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.StatsCollector
 
statsMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
StatsMetadata - Class in org.apache.cassandra.io.sstable.metadata
SSTable metadata that always stay on heap.
StatsMetadata(EstimatedHistogram, EstimatedHistogram, ReplayPosition, ReplayPosition, long, long, int, double, StreamingHistogram, int, List<ByteBuffer>, List<ByteBuffer>, boolean, long) - Constructor for class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
StatsMetadata.StatsMetadataSerializer - Class in org.apache.cassandra.io.sstable.metadata
 
StatsMetadataSerializer() - Constructor for class org.apache.cassandra.io.sstable.metadata.StatsMetadata.StatsMetadataSerializer
 
Status - Class in org.apache.cassandra.tools.nodetool
 
Status() - Constructor for class org.apache.cassandra.tools.nodetool.Status
 
status - Variable in class org.apache.cassandra.transport.Event.StatusChange
 
STATUS_BOOTSTRAPPING - Static variable in class org.apache.cassandra.gms.VersionedValue
 
STATUS_BOOTSTRAPPING_REPLACE - 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
 
StatusBackup - Class in org.apache.cassandra.tools.nodetool
 
StatusBackup() - Constructor for class org.apache.cassandra.tools.nodetool.StatusBackup
 
StatusBinary - Class in org.apache.cassandra.tools.nodetool
 
StatusBinary() - Constructor for class org.apache.cassandra.tools.nodetool.StatusBinary
 
statusCode - Variable in enum org.apache.cassandra.db.compaction.CompactionManager.AllSSTableOpStatus
 
StatusGossip - Class in org.apache.cassandra.tools.nodetool
 
StatusGossip() - Constructor for class org.apache.cassandra.tools.nodetool.StatusGossip
 
StatusHandoff - Class in org.apache.cassandra.tools.nodetool
 
StatusHandoff() - Constructor for class org.apache.cassandra.tools.nodetool.StatusHandoff
 
StatusLogger - Class in org.apache.cassandra.utils
 
StatusLogger() - Constructor for class org.apache.cassandra.utils.StatusLogger
 
StatusThrift - Class in org.apache.cassandra.tools.nodetool
 
StatusThrift() - Constructor for class org.apache.cassandra.tools.nodetool.StatusThrift
 
stop() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
 
stop - Variable in class org.apache.cassandra.db.PagedRangeCommand
 
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.CustomTThreadPoolServer
 
stop() - Method in class org.apache.cassandra.thrift.ThriftServer
 
stop(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
Stop - Class in org.apache.cassandra.tools.nodetool
 
Stop() - Constructor for class org.apache.cassandra.tools.nodetool.Stop
 
stop() - Method in class org.apache.cassandra.tracing.TraceState
 
stop() - Method in class org.apache.cassandra.transport.Server
 
stopById(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
stopCassandraDaemon() - Method in class org.apache.cassandra.tools.NodeProbe
 
stopClient() - Method in class org.apache.cassandra.service.StorageService
 
stopCompaction(String) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
stopCompaction(String) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Stop all running compaction-like tasks having the provided type.
stopCompactionById(String) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
stopCompactionById(String) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Stop an individual running compaction using the compactionId.
stopDaemon() - Method in class org.apache.cassandra.service.StorageService
 
stopDaemon() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
StopDaemon - Class in org.apache.cassandra.tools.nodetool
 
StopDaemon() - Constructor for class org.apache.cassandra.tools.nodetool.StopDaemon
 
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
 
stopKey() - Method in class org.apache.cassandra.db.DataRange
 
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
 
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
 
stopTransports() - Method in class org.apache.cassandra.service.StorageService
 
stopUnsafe(boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLog
FOR TESTING PURPOSES.
stopUnsafe(boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManager
Stops CL, for testing purposes.
storage_port - Variable in class org.apache.cassandra.config.Config
 
StorageHelper - Class in org.apache.cassandra.hadoop.pig
Deprecated.
StorageHelper() - Constructor for class org.apache.cassandra.hadoop.pig.StorageHelper
Deprecated.
 
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
 
storeKeyspaceInstance(Keyspace) - Method in class org.apache.cassandra.config.Schema
Store given Keyspace instance to the schema
storeSignature - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
storeSignature - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
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>, StreamEventHandler...) - Method in class org.apache.cassandra.io.sstable.SSTableLoader
 
stream - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
STREAM_THROTTLE_MBITS - Static variable in class org.apache.cassandra.hadoop.BulkRecordWriter
Deprecated.
 
STREAM_THROTTLE_MBITS - Static variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
stream_throughput_outbound_megabits_per_sec - Variable in class org.apache.cassandra.config.Config
 
StreamConnectionFactory - Interface in org.apache.cassandra.streaming
Interface that creates connection used by streaming.
StreamCoordinator - Class in org.apache.cassandra.streaming
StreamCoordinator is a helper class that abstracts away maintaining multiple StreamSession and ProgressInfo instances per peer.
StreamCoordinator(int, boolean, boolean, StreamConnectionFactory) - Constructor for class org.apache.cassandra.streaming.StreamCoordinator
 
StreamEvent - Class in org.apache.cassandra.streaming
 
StreamEvent(StreamEvent.Type, UUID) - Constructor for class org.apache.cassandra.streaming.StreamEvent
 
StreamEvent.ProgressEvent - Class in org.apache.cassandra.streaming
 
StreamEvent.SessionCompleteEvent - Class in org.apache.cassandra.streaming
 
StreamEvent.SessionPreparedEvent - Class in org.apache.cassandra.streaming
 
StreamEvent.Type - Enum in org.apache.cassandra.streaming
 
StreamEventHandler - Interface in org.apache.cassandra.streaming
 
StreamEventJMXNotifier - Class in org.apache.cassandra.streaming.management
 
StreamEventJMXNotifier() - Constructor for class org.apache.cassandra.streaming.management.StreamEventJMXNotifier
 
StreamException - Exception in org.apache.cassandra.streaming
 
StreamException(StreamState, String) - Constructor for exception org.apache.cassandra.streaming.StreamException
 
StreamException(StreamState, String, Throwable) - Constructor for exception org.apache.cassandra.streaming.StreamException
 
streamId - Variable in class org.apache.cassandra.transport.Frame.Header
 
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
 
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.repair
StreamingRepairTask performs data streaming between two remote replica which neither is not repair coordinator.
StreamingRepairTask(RepairJobDesc, SyncRequest, long) - Constructor for class org.apache.cassandra.repair.StreamingRepairTask
 
StreamInitMessage - Class in org.apache.cassandra.streaming.messages
StreamInitMessage is first sent from the node where StreamSession is started, to initiate corresponding StreamSession on the other side.
StreamInitMessage(InetAddress, int, UUID, String, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.streaming.messages.StreamInitMessage
 
StreamLockfile - Class in org.apache.cassandra.streaming
Encapsulates the behavior for 'locking' any streamed sttables to a node.
StreamLockfile(File, UUID) - Constructor for class org.apache.cassandra.streaming.StreamLockfile
 
StreamLockfile(File) - Constructor for class org.apache.cassandra.streaming.StreamLockfile
 
StreamManager - Class in org.apache.cassandra.streaming
StreamManager manages currently running StreamResultFutures and provides status of all operation invoked.
StreamManager() - Constructor for class org.apache.cassandra.streaming.StreamManager
 
StreamManager.StreamRateLimiter - Class in org.apache.cassandra.streaming
 
StreamManagerMBean - Interface in org.apache.cassandra.streaming
 
StreamMessage - Class in org.apache.cassandra.streaming.messages
StreamMessage is an abstract base class that every messages in streaming protocol inherit.
StreamMessage(StreamMessage.Type) - Constructor for class org.apache.cassandra.streaming.messages.StreamMessage
 
StreamMessage.Serializer<V extends StreamMessage> - Interface in org.apache.cassandra.streaming.messages
StreamMessage serializer
StreamMessage.Type - Enum in org.apache.cassandra.streaming.messages
StreamMessage types
StreamPlan - Class in org.apache.cassandra.streaming
StreamPlan is a helper class that builds StreamOperation of given configuration.
StreamPlan(String) - Constructor for class org.apache.cassandra.streaming.StreamPlan
Start building stream plan.
StreamPlan(String, boolean) - Constructor for class org.apache.cassandra.streaming.StreamPlan
 
StreamPlan(String, long, int, boolean, boolean) - Constructor for class org.apache.cassandra.streaming.StreamPlan
 
StreamRateLimiter(InetAddress) - Constructor for class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
 
StreamReader - Class in org.apache.cassandra.streaming
StreamReader reads from stream and writes to SSTable.
StreamReader(FileMessageHeader, StreamSession) - Constructor for class org.apache.cassandra.streaming.StreamReader
 
StreamReceiveTask - Class in org.apache.cassandra.streaming
Task that manages receiving files for the session for certain ColumnFamily.
StreamReceiveTask(StreamSession, UUID, int, long) - Constructor for class org.apache.cassandra.streaming.StreamReceiveTask
 
StreamRequest - Class in org.apache.cassandra.streaming
 
StreamRequest(String, Collection<Range<Token>>, Collection<String>, long) - Constructor for class org.apache.cassandra.streaming.StreamRequest
 
StreamRequest.StreamRequestSerializer - Class in org.apache.cassandra.streaming
 
StreamRequestSerializer() - Constructor for class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
 
StreamResultFuture - Class in org.apache.cassandra.streaming
A future on the result (StreamState) of a streaming plan.
StreamSession - Class in org.apache.cassandra.streaming
Handles the streaming a one or more section of one of more sstables to and from a specific remote node.
StreamSession(InetAddress, InetAddress, StreamConnectionFactory, int, boolean, boolean) - Constructor for class org.apache.cassandra.streaming.StreamSession
Create new streaming session with the peer.
StreamSession.SSTableStreamingSections - Class in org.apache.cassandra.streaming
 
StreamSession.State - Enum in org.apache.cassandra.streaming
 
StreamState - Class in org.apache.cassandra.streaming
Current snapshot of streaming progress.
StreamState(UUID, String, Set<SessionInfo>) - Constructor for class org.apache.cassandra.streaming.StreamState
 
StreamStateCompositeData - Class in org.apache.cassandra.streaming.management
 
StreamStateCompositeData() - Constructor for class org.apache.cassandra.streaming.management.StreamStateCompositeData
 
StreamStateStore - Class in org.apache.cassandra.dht
Store and update available ranges (data already received) to system keyspace.
StreamStateStore() - Constructor for class org.apache.cassandra.dht.StreamStateStore
 
StreamSummary - Class in org.apache.cassandra.streaming
Summary of streaming.
StreamSummary(UUID, int, long) - Constructor for class org.apache.cassandra.streaming.StreamSummary
 
StreamSummary.StreamSummarySerializer - Class in org.apache.cassandra.streaming
 
StreamSummaryCompositeData - Class in org.apache.cassandra.streaming.management
 
StreamSummaryCompositeData() - Constructor for class org.apache.cassandra.streaming.management.StreamSummaryCompositeData
 
StreamSummarySerializer() - Constructor for class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
 
StreamTask - Class in org.apache.cassandra.streaming
StreamTask is an abstraction of the streaming task performed over specific ColumnFamily.
StreamTask(StreamSession, UUID) - Constructor for class org.apache.cassandra.streaming.StreamTask
 
StreamTransferTask - Class in org.apache.cassandra.streaming
StreamTransferTask sends sections of SSTable files in certain ColumnFamily.
StreamTransferTask(StreamSession, UUID) - Constructor for class org.apache.cassandra.streaming.StreamTransferTask
 
StreamWriter - Class in org.apache.cassandra.streaming
StreamWriter writes given section of the SSTable to given channel.
StreamWriter(SSTableReader, Collection<Pair<Long, Long>>, StreamSession) - Constructor for class org.apache.cassandra.streaming.StreamWriter
 
strictlyWrapsAround(T, T) - Static method in class org.apache.cassandra.dht.AbstractBounds
Whether left and right forms a wrapping interval, that is if unwrapping wouldn't be a no-op.
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.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, ? extends 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.
stringifyTypeParameters(List<AbstractType<?>>, boolean) - Static method in class org.apache.cassandra.db.marshal.TypeParser
Helper function to ease the writing of AbstractType.toString() methods.
stringifyUserTypeParameters(String, ByteBuffer, List<ByteBuffer>, List<AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
 
StringSerializer() - Constructor for class org.apache.cassandra.dht.BootStrapper.StringSerializer
 
StringToken(String) - Constructor for class org.apache.cassandra.dht.OrderPreservingPartitioner.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
 
submit(Callable<T>) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
Task Submission / Creation / Objects
submit(Runnable) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
submit(Runnable, T) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
submitAntiCompaction(ColumnFamilyStore, Collection<Range<Token>>, Refs<SSTableReader>, long) - Method in class org.apache.cassandra.db.compaction.CompactionManager
Submit anti-compactions for a collection of SSTables over a set of repaired ranges and marks corresponding SSTables as repaired.
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(Mutation, InetAddress, AbstractWriteResponseHandler<IMutation>) - 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, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
submitRepairSession(UUID, Range<Token>, String, RepairParallelism, Set<InetAddress>, long, ListeningExecutorService, String...) - Method in class org.apache.cassandra.service.ActiveRepairService
Requests repairs for the given keyspace and column families.
submitUserDefined(ColumnFamilyStore, Collection<Descriptor>, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
submitValidation(ColumnFamilyStore, 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
 
subName(Composite) - Static method in class org.apache.cassandra.db.SuperColumns
 
SubPool(long, float) - Constructor for class org.apache.cassandra.utils.memory.MemtablePool.SubPool
 
subscribe(INotificationConsumer) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
subSet(V, boolean, V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
 
subSet(V, boolean, V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
subSet(V, boolean, V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
subSet(V, V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
subsnitch - Variable in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
Substracter(ColumnDefinition, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Substracter
 
Substraction(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.Substraction
 
subtract(Range<T>) - Method in class org.apache.cassandra.dht.Range
 
subtractAll(Collection<Range<T>>) - Method in class org.apache.cassandra.dht.Range
 
subtype(int) - Method in class org.apache.cassandra.db.composites.AbstractCompoundCellNameType
 
subtype(int) - Method in class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
 
subtype(int) - Method in class org.apache.cassandra.db.composites.CompoundCType
 
subtype(int) - Method in interface org.apache.cassandra.db.composites.CType
Gets a subtype of this CType.
subtype(int) - Method in class org.apache.cassandra.db.composites.SimpleCType
 
success - Variable in class org.apache.cassandra.db.TruncateResponse
 
success - Variable in class org.apache.cassandra.repair.messages.SyncComplete
true if sync success, false otherwise
success - Variable in class org.apache.cassandra.repair.messages.ValidationComplete
true if validation success, false otherwise
success - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
 
successfulParentRepair(UUID, Collection<Range<Token>>) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
successfulRanges - Variable in class org.apache.cassandra.repair.messages.AnticompactionRequest
Successfully repaired ranges.
successfulRepairJob(UUID, String, String) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
sum(double) - Method in class org.apache.cassandra.utils.StreamingHistogram
Calculates estimated number of points in interval [-inf,b].
sumArrays(int[], int[]) - Static method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
sumFunctionForByte - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for byte values (tinyint).
sumFunctionForCounter - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for counter column values.
sumFunctionForDecimal - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for decimal values.
sumFunctionForDouble - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for double values.
sumFunctionForFloat - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for float values.
sumFunctionForInt32 - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for int32 values.
sumFunctionForLong - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for long values.
sumFunctionForShort - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for short values (smallint).
sumFunctionForVarint - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for varint values.
summaries - Variable in class org.apache.cassandra.streaming.messages.PrepareMessage
Summaries of streaming out
SUMMARY - Static variable in class org.apache.cassandra.io.sstable.Component
 
summaryCount - Variable in class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
 
SuperColumns - Class in org.apache.cassandra.db
 
SuperColumns() - Constructor for class org.apache.cassandra.db.SuperColumns
 
supersedes(DeletionTime) - Method in class org.apache.cassandra.db.DeletionTime
 
supersedes(RangeTombstone, Comparator<Composite>) - 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.AuthKeyspace
 
supportCollections() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
 
supportCollections() - Method in interface org.apache.cassandra.db.composites.CellNameType
Whether or not this type layout support collections.
supportCollections() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellNameType
 
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.CassandraRoleManager
 
supportedOptions() - Method in interface org.apache.cassandra.auth.IRoleManager
Set of options supported by CREATE ROLE and ALTER ROLE queries.
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.SSLTransportFactory
 
supportedOptions() - Method in class org.apache.cassandra.thrift.TFramedTransportFactory
 
supportExitOnOutOfMemory(String) - Static method in class org.apache.cassandra.utils.JavaUtils
Checks if the specified JRE support ExitOnOutOfMemory and CrashOnOutOfMemory.
supports(BufferType) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
supports(BufferType) - Method in interface org.apache.cassandra.io.compress.ICompressor
Checks if the given buffer would be supported by the compressor.
supports(BufferType) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
 
supports(BufferType) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
 
SUPPORTS_GLOBAL_PREPARE_FLAG_VERSION - Static variable in class org.apache.cassandra.service.ActiveRepairService
 
supportsDirectChecksum() - Static method in class org.apache.cassandra.utils.FBUtilities
 
supportsFreezing() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
supportsOperator(Operator) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKey
 
supportsOperator(Operator) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionValue
 
supportsOperator(Operator) - Method in class org.apache.cassandra.db.index.SecondaryIndex
Returns true if the index supports lookups for the given operator, false otherwise.
switchMemtable() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
switchMemtable(boolean, Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
Switch the current memtable.
switchMemtableIfCurrent(Memtable) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Switches the memtable iff the live memtable is the one provided
switchWriter(SSTableWriter) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
sync(boolean) - 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.io.sstable.SSTableSimpleUnsortedWriter
Deprecated.
 
sync() - Method in class org.apache.cassandra.io.util.SequentialWriter
Synchronize file contents with disk.
SYNC - Static variable in class org.apache.cassandra.thrift.ThriftServer
 
sync(FileDescriptor) - Static method in class org.apache.cassandra.utils.SyncUtil
 
sync(RandomAccessFile) - Static method in class org.apache.cassandra.utils.SyncUtil
 
sync(FileOutputStream) - Static method in class org.apache.cassandra.utils.SyncUtil
 
syncComplete - Variable in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
 
SyncComplete - Class in org.apache.cassandra.repair.messages
 
SyncComplete(RepairJobDesc, NodePair, boolean) - Constructor for class org.apache.cassandra.repair.messages.SyncComplete
 
SyncComplete(RepairJobDesc, InetAddress, InetAddress, boolean) - Constructor for class org.apache.cassandra.repair.messages.SyncComplete
 
syncComplete(boolean) - Method in class org.apache.cassandra.repair.RemoteSyncTask
 
syncComplete(RepairJobDesc, NodePair, boolean) - Method in class org.apache.cassandra.repair.RepairSession
Notify this session that sync completed/failed with given NodePair.
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
 
SyncRequest - Class in org.apache.cassandra.repair.messages
Body part of SYNC_REQUEST repair message.
SyncRequest(RepairJobDesc, InetAddress, InetAddress, InetAddress, Collection<Range<Token>>) - Constructor for class org.apache.cassandra.repair.messages.SyncRequest
 
SyncRequest.SyncRequestSerializer - Class in org.apache.cassandra.repair.messages
 
SyncRequestSerializer() - Constructor for class org.apache.cassandra.repair.messages.SyncRequest.SyncRequestSerializer
 
SyncStat - Class in org.apache.cassandra.repair
Statistics about synchronizing two replica
SyncStat(NodePair, long) - Constructor for class org.apache.cassandra.repair.SyncStat
 
SyncTask - Class in org.apache.cassandra.repair
SyncTask will calculate the difference of MerkleTree between two nodes and perform necessary operation to repair replica.
SyncTask(RepairJobDesc, TreeResponse, TreeResponse) - Constructor for class org.apache.cassandra.repair.SyncTask
 
SyncUtil - Class in org.apache.cassandra.utils
 
SyncUtil() - Constructor for class org.apache.cassandra.utils.SyncUtil
 
syntaxError(BaseRecognizer, String[], RecognitionException) - Method in class org.apache.cassandra.cql3.ErrorCollector
Invoked when a syntax error occurs.
syntaxError(BaseRecognizer, String) - Method in class org.apache.cassandra.cql3.ErrorCollector
Invoked when a syntax error with a specified message occurs.
syntaxError(BaseRecognizer, String[], RecognitionException) - Method in interface org.apache.cassandra.cql3.ErrorListener
Invoked when a syntax error occurs.
syntaxError(BaseRecognizer, String) - Method in interface org.apache.cassandra.cql3.ErrorListener
Invoked when a syntax error with a specified message occurs.
SyntaxException - Exception in org.apache.cassandra.exceptions
 
SyntaxException(String) - Constructor for exception org.apache.cassandra.exceptions.SyntaxException
 
SYS_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
 
system() - Static method in class org.apache.cassandra.db.Keyspace
 
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_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.
SYSTEM_USER - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
 
SYSTEM_USERNAME - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
 
SystemDistributedKeyspace - Class in org.apache.cassandra.repair
 
SystemDistributedKeyspace() - Constructor for class org.apache.cassandra.repair.SystemDistributedKeyspace
 
SystemKeyspace - Class in org.apache.cassandra.db
 
SystemKeyspace() - Constructor for class org.apache.cassandra.db.SystemKeyspace
 
SystemKeyspace.BootstrapState - Enum in org.apache.cassandra.db
 
SystemOutput(boolean, boolean) - Constructor for class org.apache.cassandra.utils.OutputHandler.SystemOutput
 

T

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__167 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__167 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__168 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__168 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__169 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__169 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__170 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__170 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__171 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__171 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__172 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__172 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__173 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__173 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__174 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__174 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__175 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__175 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__176 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__176 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__177 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__177 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__178 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__178 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__179 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__179 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__180 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__180 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__181 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__181 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__182 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__182 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__183 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__183 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__184 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__184 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
T__185 - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
T__185 - Static variable in class org.apache.cassandra.cql3.CqlParser
 
table(String, String) - Static method in class org.apache.cassandra.auth.DataResource
Creates a DataResource instance representing a table.
TableHistograms - Class in org.apache.cassandra.tools.nodetool
 
TableHistograms() - Constructor for class org.apache.cassandra.tools.nodetool.TableHistograms
 
tables - Variable in class org.apache.cassandra.utils.NativeSSTableLoaderClient
 
TableStats - Class in org.apache.cassandra.tools.nodetool
 
TableStats() - Constructor for class org.apache.cassandra.tools.nodetool.TableStats
 
TABULAR_TYPE - Static variable in class org.apache.cassandra.db.SnapshotDetailsTabularData
 
tailSet(V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
 
tailSet(V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
tailSet(V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
tailSet(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
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.
takeMultipleColumnFamilySnapshot(String, String...) - Method in class org.apache.cassandra.service.StorageService
Takes the snapshot of a multiple column family from different keyspaces.
takeMultipleColumnFamilySnapshot(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Takes the snapshot of a multiple column family from different keyspaces.
takeMultipleColumnFamilySnapshot(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
Take a snapshot of all column family from different keyspaces.
takeSnapshot(String, String...) - Method in class org.apache.cassandra.service.StorageService
Takes the snapshot for the given keyspaces.
takeSnapshot(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Takes the snapshot for the given keyspaces.
takeSnapshot(String, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
Take a snapshot of all the keyspaces, optionally specifying only a specific column family.
target - Variable in class org.apache.cassandra.net.CallbackInfo
 
target - Variable in class org.apache.cassandra.transport.Event.SchemaChange
 
targetReplicas - Variable in class org.apache.cassandra.service.AbstractReadExecutor
 
targets - Variable in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
 
taskCompleted(StreamReceiveTask) - Method in class org.apache.cassandra.streaming.StreamSession
 
taskCompleted(StreamTransferTask) - Method in class org.apache.cassandra.streaming.StreamSession
 
tasks - Variable in class org.apache.cassandra.concurrent.SEPExecutor
 
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, 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.
term() - Method in class org.apache.cassandra.cql3.CqlParser
 
Term - Interface in org.apache.cassandra.cql3
A CQL3 term, i.e.
Term.MultiColumnRaw - Interface in org.apache.cassandra.cql3
 
Term.MultiItemTerminal - Class in org.apache.cassandra.cql3
 
Term.NonTerminal - Class in org.apache.cassandra.cql3
A non terminal term, i.e.
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.
Terminal() - Constructor for class org.apache.cassandra.cql3.Term.Terminal
 
terminate() - Method in class org.apache.cassandra.repair.RepairSession
 
terminateSessions() - Method in class org.apache.cassandra.service.ActiveRepairService
 
terminationFuture() - Method in class org.apache.cassandra.transport.RequestThreadPoolExecutor
 
Terms - Class in org.apache.cassandra.cql3
 
Terms() - Constructor for class org.apache.cassandra.cql3.Terms
 
testAll(String, ColumnSpecification, Collection<? extends AssignmentTestable>) - Static method in enum org.apache.cassandra.cql3.AssignmentTestable.TestResult
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
 
testAssignment(String, ColumnSpecification) - Method in interface org.apache.cassandra.cql3.AssignmentTestable
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Constants.Literal
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Lists.Literal
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Maps.Literal
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.selection.Selector
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Sets.Literal
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Tuples.Literal
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.TypeCast
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.UserTypes.Literal
 
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
 
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.
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(InetSocketAddress) - 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<Cell>, boolean, long) - Method in class org.apache.cassandra.thrift.CassandraServer
 
thriftServer - Variable in class org.apache.cassandra.service.CassandraDaemon
 
ThriftServer - Class in org.apache.cassandra.thrift
 
ThriftServer(InetAddress, int, 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_limit - Variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
ThrottledReader - Class in org.apache.cassandra.io.util
 
ThrottledReader(ChannelProxy, long, RateLimiter) - Constructor for class org.apache.cassandra.io.util.ThrottledReader
 
Throwables - Class in org.apache.cassandra.utils
 
Throwables() - Constructor for class org.apache.cassandra.utils.Throwables
 
throwDuringPrepare(boolean) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
throwFirstSyntaxError() - Method in class org.apache.cassandra.cql3.ErrorCollector
Throws the first syntax error found by the lexer or the parser if it exists.
THsHaDisruptorServer - Class in org.apache.cassandra.thrift
 
THsHaDisruptorServer(TDisruptorServer.Args) - Constructor for class org.apache.cassandra.thrift.THsHaDisruptorServer
All the arguments to Non Blocking Server will apply here.
THsHaDisruptorServer.Factory - Class in org.apache.cassandra.thrift
 
tidy() - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile.Cleanup
 
tidy() - Method in class org.apache.cassandra.io.util.PoolingSegmentedFile.Cleanup
 
tidy() - Method in class org.apache.cassandra.io.util.SegmentedFile.Cleanup
 
tidy() - Method in interface org.apache.cassandra.utils.concurrent.RefCounted.Tidy
 
TimeFcts - Class in org.apache.cassandra.cql3.functions
 
TimeFcts() - Constructor for class org.apache.cassandra.cql3.functions.TimeFcts
 
timeInMillisToDay(long) - Static method in class org.apache.cassandra.serializers.SimpleDateSerializer
 
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
timePattern - Static variable in class org.apache.cassandra.serializers.TimeSerializer
 
timer(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
TimeSerializer - Class in org.apache.cassandra.serializers
 
TimeSerializer() - Constructor for class org.apache.cassandra.serializers.TimeSerializer
 
timestamp - Variable in class org.apache.cassandra.cql3.Attributes.Raw
 
timestamp - Variable in class org.apache.cassandra.cql3.UpdateParameters
 
timestamp - Variable in class org.apache.cassandra.db.AbstractRangeCommand
 
timestamp - Variable in class org.apache.cassandra.db.BufferCell
 
timestamp() - Method in class org.apache.cassandra.db.BufferCell
 
timestamp - Variable in class org.apache.cassandra.db.CFRowAdder
 
timestamp - Variable in class org.apache.cassandra.db.filter.ColumnCounter
 
timestamp - Variable in class org.apache.cassandra.db.filter.ExtendedFilter
 
timestamp - Variable in class org.apache.cassandra.db.filter.QueryFilter
 
timestamp - Variable in class org.apache.cassandra.db.index.composites.CompositesIndex.IndexedEntry
 
timestamp() - Method in class org.apache.cassandra.db.NativeCell
 
timestamp() - Method in interface org.apache.cassandra.db.OnDiskAtom
For a standard column, this is the same as timestamp().
timestamp() - Method in class org.apache.cassandra.db.RangeTombstone
 
timestamp - Variable in class org.apache.cassandra.db.ReadCommand
 
timestamp - Variable in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader.Column
Deprecated.
 
timestamp() - Method in class org.apache.cassandra.service.pager.NamesQueryPager
 
TIMESTAMP_RESOLUTION_KEY - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
TIMESTAMP_UPDATE - Static variable in class org.apache.cassandra.utils.NanoTimeToCurrentTimeMillis
 
timestampMicros() - Static method in class org.apache.cassandra.utils.FBUtilities
 
timestampNanos() - Method in interface org.apache.cassandra.utils.CoalescingStrategies.Coalescable
 
timestampOfLastDelete() - Method in class org.apache.cassandra.db.BufferCounterCell
 
timestampOfLastDelete() - Method in interface org.apache.cassandra.db.CounterCell
 
timestampOfLastDelete() - Method in class org.apache.cassandra.db.NativeCounterCell
 
TimestampSerializer - Class in org.apache.cassandra.serializers
 
TimestampSerializer() - Constructor for class org.apache.cassandra.serializers.TimestampSerializer
 
timestampToDate - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
Function that convert a value of type TIMESTAMP into a DATE.
timestampToUnixTimestamp - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
Function that convert a value of type TIMESTAMP into an UNIX timestamp.
TimestampType - Class in org.apache.cassandra.db.marshal
Type for date-time values.
timeStringToLong(String) - Static method in class org.apache.cassandra.serializers.TimeSerializer
 
timeToLive - Variable in class org.apache.cassandra.cql3.Attributes.Raw
 
TimeType - Class in org.apache.cassandra.db.marshal
Nanosecond resolution time values
TimeUUIDSerializer - Class in org.apache.cassandra.serializers
 
TimeUUIDSerializer() - Constructor for class org.apache.cassandra.serializers.TimeUUIDSerializer
 
timeUuidtoDate - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
Function that convert a value of TIMEUUID into a value of type DATE.
timeUuidToTimestamp - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
Function that convert a value of type TIMEUUID into a value of type TIMESTAMP.
timeUuidToUnixTimestamp - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
Function that convert a value of type TIMEUUID into an UNIX timestamp.
TimeUUIDType - Class in org.apache.cassandra.db.marshal
 
toArray() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
toArray(T[]) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
toByteArray(Token) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
toByteArray() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
toByteBuffer() - Method in class org.apache.cassandra.db.AbstractNativeCell
 
toByteBuffer() - Method in class org.apache.cassandra.db.composites.AbstractComposite
 
toByteBuffer() - Method in class org.apache.cassandra.db.composites.BoundedComposite
 
toByteBuffer() - Method in interface org.apache.cassandra.db.composites.Composite
 
toByteBuffer() - Method in class org.apache.cassandra.db.composites.SimpleComposite
 
toByteBuffer() - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
 
toByteBuffers(List<Composite>) - Static method in class org.apache.cassandra.db.composites.Composites
Converts the specified Composites into ByteBuffers.
toBytes() - Method in class org.apache.cassandra.db.ColumnFamily
 
toBytes() - Method in class org.apache.cassandra.gms.VersionedValue
 
TOC - Static variable in class org.apache.cassandra.io.sstable.Component
 
toColumnDefinition(CFMetaData, ColumnIdentifier.Raw) - Method in class org.apache.cassandra.cql3.Relation
Converts the specified entity into a column definition.
toCompositeData(UUID, ProgressInfo) - Static method in class org.apache.cassandra.streaming.management.ProgressInfoCompositeData
 
toCompositeData(StreamEvent.SessionCompleteEvent) - Static method in class org.apache.cassandra.streaming.management.SessionCompleteEventCompositeData
 
toCompositeData(UUID, SessionInfo) - Static method in class org.apache.cassandra.streaming.management.SessionInfoCompositeData
 
toCompositeData(StreamState) - Static method in class org.apache.cassandra.streaming.management.StreamStateCompositeData
 
toCompositeData(StreamSummary) - Static method in class org.apache.cassandra.streaming.management.StreamSummaryCompositeData
 
TODELETEFILE - Static variable in class org.apache.cassandra.db.WindowsFailedSnapshotTracker
 
toDouble(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
toFloat(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
toGroup - Variable in class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefix
 
toIdentifiers(List<ColumnDefinition>) - Static method in class org.apache.cassandra.config.ColumnDefinition
Converts the specified column definitions into column identifiers.
toInt(String, String, Integer) - Static method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
toInt(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Convert a byte buffer to an integer.
ToJsonFct - Class in org.apache.cassandra.cql3.functions
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.AbstractType
Converts the specified value into its JSON representation.
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.BooleanType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.BytesType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.ByteType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.DateType
Deprecated.
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.EmptyType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.FloatType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.FrozenType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.InetAddressType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.ListType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.LongType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.MapType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.SetType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.ShortType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.TimestampType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.TimeType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.TupleType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.UserType
 
toJSONString(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
Token - Class in org.apache.cassandra.dht
 
Token() - Constructor for class org.apache.cassandra.dht.Token
 
token - Variable in class org.apache.cassandra.tools.nodetool.HostStat
 
token - Variable in class org.apache.cassandra.utils.MerkleTree.RowHash
 
Token.KeyBound - Class in org.apache.cassandra.dht
 
Token.TokenFactory - Class in org.apache.cassandra.dht
 
Token.TokenSerializer - Class in org.apache.cassandra.dht
 
TokenFactory() - Constructor for class org.apache.cassandra.dht.Token.TokenFactory
 
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.
tokenNames - Static variable in class org.apache.cassandra.cql3.CqlParser
 
TokenRelation - Class in org.apache.cassandra.cql3
A relation using the token function.
TokenRelation(List<ColumnIdentifier.Raw>, Operator, Term.Raw) - Constructor for class org.apache.cassandra.cql3.TokenRelation
 
TokenRestriction - Class in org.apache.cassandra.cql3.restrictions
Restriction using the token function.
TokenRestriction(CType, List<ColumnDefinition>) - Constructor for class org.apache.cassandra.cql3.restrictions.TokenRestriction
Creates a new TokenRestriction that apply to the specified columns.
TokenRestriction.EQ - Class in org.apache.cassandra.cql3.restrictions
 
TokenRestriction.Slice - Class in org.apache.cassandra.cql3.restrictions
 
tokens - Variable in class org.apache.cassandra.dht.BootStrapper
 
tokens(Collection<Token>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
tokenSerializer - Static variable in class org.apache.cassandra.dht.AbstractBounds
 
TokenSerializer() - Constructor for class org.apache.cassandra.dht.Token.TokenSerializer
 
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 - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow.Reducer
 
TOMBSTONE_COMPACTION_INTERVAL_OPTION - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
tombstone_failure_threshold - Variable in class org.apache.cassandra.config.Config
 
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
 
tombstone_warn_threshold - Variable in class org.apache.cassandra.config.Config
 
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
TombstoneOverwhelmingException - Exception in org.apache.cassandra.db.filter
 
TombstoneOverwhelmingException(int, int, String, String, String, String, String) - Constructor for exception org.apache.cassandra.db.filter.TombstoneOverwhelmingException
 
tombstones - Variable in class org.apache.cassandra.db.compaction.LazilyCompactedRow.Reducer
 
tombstones - Variable in class org.apache.cassandra.db.filter.ColumnCounter
 
tombstones() - Method in class org.apache.cassandra.db.filter.ColumnCounter
 
tombstoneScannedHistogram - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Tombstones scanned in queries on this CF
tombstoneScannedHistogram - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Tombstones scanned in queries on this Keyspace
tombstoneThreshold - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
tombstoneTracker() - Method in class org.apache.cassandra.db.ColumnIndex.Builder
 
topK - Variable in class org.apache.cassandra.utils.TopKSampler.SamplerResult
 
TopKSampler<T> - Class in org.apache.cassandra.utils
 
TopKSampler() - Constructor for class org.apache.cassandra.utils.TopKSampler
 
TopKSampler.SamplerResult<S> - Class in org.apache.cassandra.utils
Represents the cardinality and the topK ranked items collected during a sample period
TopPartitions - Class in org.apache.cassandra.tools.nodetool
 
TopPartitions() - Constructor for class org.apache.cassandra.tools.nodetool.TopPartitions
 
toRestriction(CFMetaData, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Relation
Converts this Relation into a Restriction.
toSelectables(List<RawSelector>, CFMetaData) - Static method in class org.apache.cassandra.cql3.selection.RawSelector
Converts the specified list of RawSelectors into a list of Selectables.
toShort(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Convert a byte buffer to a short.
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.FunctionResource
 
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.auth.RoleOptions
 
toString() - Method in class org.apache.cassandra.auth.RoleResource
 
toString() - Method in class org.apache.cassandra.cache.CachingOptions.KeyCache
 
toString() - Method in class org.apache.cassandra.cache.CachingOptions.RowCache
 
toString() - Method in class org.apache.cassandra.cache.CachingOptions
 
toString() - Method in class org.apache.cassandra.cache.CounterCacheKey
 
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.SpeculativeRetry
 
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.config.ParameterizedClass
 
toString() - Method in class org.apache.cassandra.config.TriggerDefinition
 
toString() - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
 
toString() - Method in class org.apache.cassandra.cql3.CFName
 
toString() - Method in class org.apache.cassandra.cql3.ColumnIdentifier.Raw
 
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.Constants.Value
 
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.CQL3Type.Tuple
 
toString() - Method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
 
toString() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
toString() - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
 
toString() - Method in class org.apache.cassandra.cql3.functions.FunctionName
 
toString() - Method in class org.apache.cassandra.cql3.IndexName
 
toString() - Method in class org.apache.cassandra.cql3.Lists.Literal
 
toString() - Method in class org.apache.cassandra.cql3.Maps.Literal
 
toString() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
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 enum org.apache.cassandra.cql3.Operator
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQ
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InWithMarker
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InWithValues
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.Slice
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Contains
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQ
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InWithMarker
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InWithValues
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.Slice
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.Slice
 
toString() - Method in class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
 
toString() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
toString() - Method in class org.apache.cassandra.cql3.ResultSet
 
toString() - Method in class org.apache.cassandra.cql3.RoleName
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFunction
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selection
 
toString() - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
toString() - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
 
toString() - Method in class org.apache.cassandra.cql3.Sets.Literal
 
toString() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
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.CFPropDefs
 
toString() - Method in enum org.apache.cassandra.cql3.statements.IndexTarget.TargetType
 
toString() - Method in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
 
toString() - Method in class org.apache.cassandra.cql3.TokenRelation
 
toString() - Method in class org.apache.cassandra.cql3.Tuples.DelayedValue
 
toString() - Method in class org.apache.cassandra.cql3.Tuples.Literal
 
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.UserTypes.Literal
 
toString() - Method in class org.apache.cassandra.cql3.UTName
 
toString() - Method in class org.apache.cassandra.cql3.VariableSpecifications
 
toString() - Method in class org.apache.cassandra.db.ClockAndCount
 
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.CommitLogDescriptor
 
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.DateTieredCompactionStrategy
 
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() - Method in class org.apache.cassandra.db.composites.AbstractCType
 
toString(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
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.DataRange.Paging
 
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.ExtendedFilter
 
toString() - Method in class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
 
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.SliceQueryFilter
 
toString(boolean) - Method in interface org.apache.cassandra.db.IMutation
 
toString() - Method in class org.apache.cassandra.db.index.SecondaryIndex
 
toString() - Method in class org.apache.cassandra.db.IndexExpression
 
toString() - Method in class org.apache.cassandra.db.Keyspace
 
toString() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState
 
toString() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
toString() - Method in class org.apache.cassandra.db.lifecycle.View
 
toString(boolean) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
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(boolean) - Method in class org.apache.cassandra.db.marshal.ListType
 
toString(boolean) - Method in class org.apache.cassandra.db.marshal.MapType
 
toString() - Method in class org.apache.cassandra.db.marshal.ReversedType
 
toString(boolean) - Method in class org.apache.cassandra.db.marshal.SetType
 
toString() - Method in class org.apache.cassandra.db.marshal.TupleType
 
toString() - Method in class org.apache.cassandra.db.marshal.UserType
 
toString() - Method in class org.apache.cassandra.db.Memtable
 
toString() - Method in class org.apache.cassandra.db.Mutation
 
toString(boolean) - Method in class org.apache.cassandra.db.Mutation
 
toString() - Method in class org.apache.cassandra.db.PagedRangeCommand
 
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.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.Truncation
 
toString() - Method in class org.apache.cassandra.dht.Bounds
 
toString() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.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.LocalPartitioner.LocalToken
 
toString() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
toString() - Method in class org.apache.cassandra.dht.Range
 
toString() - Method in class org.apache.cassandra.dht.Token.KeyBound
 
toString(Token) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
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.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.format.big.BigTableScanner
 
toString() - Method in class org.apache.cassandra.io.sstable.format.Version
 
toString() - Method in class org.apache.cassandra.io.sstable.SSTable
 
toString() - Method in class org.apache.cassandra.io.util.ByteBufferDataInput
 
toString() - Method in class org.apache.cassandra.io.util.ChannelProxy
 
toString() - Method in class org.apache.cassandra.io.util.Memory
 
toString(long, long) - Static method in class org.apache.cassandra.io.util.Memory
 
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.metrics.CassandraMetricsRegistry.MetricName
 
toString() - Method in class org.apache.cassandra.net.CallbackInfo
 
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.repair.messages.AnticompactionRequest
 
toString() - Method in class org.apache.cassandra.repair.messages.PrepareMessage
 
toString() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
toString() - Method in class org.apache.cassandra.repair.messages.SyncRequest
 
toString() - Method in class org.apache.cassandra.repair.messages.ValidationRequest
 
toString() - Method in class org.apache.cassandra.repair.RepairJobDesc
 
toString() - Method in enum org.apache.cassandra.repair.RepairParallelism
 
toString(String) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
 
toString(Boolean) - Method in class org.apache.cassandra.serializers.BooleanSerializer
 
toString(Byte) - Method in class org.apache.cassandra.serializers.ByteSerializer
 
toString(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
 
toString(BigDecimal) - Method in class org.apache.cassandra.serializers.DecimalSerializer
 
toString(Double) - Method in class org.apache.cassandra.serializers.DoubleSerializer
 
toString(Void) - Method in class org.apache.cassandra.serializers.EmptySerializer
 
toString(Float) - Method in class org.apache.cassandra.serializers.FloatSerializer
 
toString(InetAddress) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
 
toString(Integer) - Method in class org.apache.cassandra.serializers.Int32Serializer
 
toString(BigInteger) - Method in class org.apache.cassandra.serializers.IntegerSerializer
 
toString(List<T>) - Method in class org.apache.cassandra.serializers.ListSerializer
 
toString(Long) - Method in class org.apache.cassandra.serializers.LongSerializer
 
toString(Map<K, V>) - Method in class org.apache.cassandra.serializers.MapSerializer
 
toString(Set<T>) - Method in class org.apache.cassandra.serializers.SetSerializer
 
toString(Short) - Method in class org.apache.cassandra.serializers.ShortSerializer
 
toString(Integer) - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
 
toString(Long) - Method in class org.apache.cassandra.serializers.TimeSerializer
 
toString(Date) - Method in class org.apache.cassandra.serializers.TimestampSerializer
 
toString(T) - Method in interface org.apache.cassandra.serializers.TypeSerializer
 
toString(UUID) - Method in class org.apache.cassandra.serializers.UUIDSerializer
 
toString() - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
toString() - Method in enum org.apache.cassandra.service.CacheService.CacheType
 
toString() - Method in class org.apache.cassandra.service.pager.PagingState
 
toString() - Method in class org.apache.cassandra.service.paxos.Commit
 
toString() - Method in class org.apache.cassandra.service.paxos.PrepareResponse
 
toString() - Method in class org.apache.cassandra.streaming.messages.CompleteMessage
 
toString() - Method in class org.apache.cassandra.streaming.messages.FileMessageHeader
 
toString() - Method in class org.apache.cassandra.streaming.messages.IncomingFileMessage
 
toString() - Method in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
 
toString() - Method in class org.apache.cassandra.streaming.messages.PrepareMessage
 
toString() - Method in class org.apache.cassandra.streaming.messages.ReceivedMessage
 
toString() - Method in class org.apache.cassandra.streaming.messages.RetryMessage
Deprecated.
 
toString() - Method in class org.apache.cassandra.streaming.messages.SessionFailedMessage
 
toString() - Method in class org.apache.cassandra.streaming.ProgressInfo
 
toString() - Method in class org.apache.cassandra.streaming.StreamEvent.ProgressEvent
 
toString() - Method in class org.apache.cassandra.streaming.StreamSummary
 
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.BatchMessage
 
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.BloomCalculations.BloomSpecification
 
toString() - Method in class org.apache.cassandra.utils.CassandraVersion
 
toString() - Method in class org.apache.cassandra.utils.CounterId
 
toString(Map<?, ?>) - Static method in class org.apache.cassandra.utils.FBUtilities
Make straing out of the given Map.
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.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.obs.OffHeapBitSet
 
toString() - Method in class org.apache.cassandra.utils.Pair
 
total() - Method in class org.apache.cassandra.db.BufferCounterCell
 
total(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Returns the aggregated count across all counter ids.
total() - Method in interface org.apache.cassandra.db.CounterCell
 
total() - Method in class org.apache.cassandra.db.NativeCounterCell
 
totalBlocked - Variable in class org.apache.cassandra.metrics.SEPMetrics
Number of tasks that had blocked before being accepted (or rejected).
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
 
totalBlockFor() - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
totalBytes - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
totalBytes - Variable in class org.apache.cassandra.streaming.ProgressInfo
 
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
totalDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Total disk space used by SSTables belonging to this CF, including obsolete ones waiting to be GC'd
totalEndpoints() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
totalHints - Static variable in class org.apache.cassandra.metrics.StorageMetrics
 
totalHintsInProgress - Static variable in class org.apache.cassandra.metrics.StorageMetrics
 
totalIncomingBytes - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
 
totalLatency - Variable in class org.apache.cassandra.metrics.LatencyMetrics
Total latency in micro sec
totalOutgoingBytes - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
 
totalRows() - Method in class org.apache.cassandra.utils.MerkleTree.TreeDifference
 
totalSize() - Method in class org.apache.cassandra.streaming.compress.CompressedStreamReader
 
totalSize() - Method in class org.apache.cassandra.streaming.compress.CompressedStreamWriter
 
totalSize() - Method in class org.apache.cassandra.streaming.StreamReader
 
totalSize - Variable in class org.apache.cassandra.streaming.StreamSummary
 
totalSize() - Method in class org.apache.cassandra.streaming.StreamWriter
 
totalTimeouts - Static variable in class org.apache.cassandra.metrics.ConnectionMetrics
Total number of timeouts happened on this node
toTerm(List<? extends ColumnSpecification>, Term.Raw, String, VariableSpecifications) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
toTerm(List<? extends ColumnSpecification>, Term.Raw, String, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Relation
Converts the specified Raw into a Term.
toTerm(List<? extends ColumnSpecification>, Term.Raw, String, VariableSpecifications) - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
toTerm(List<? extends ColumnSpecification>, Term.Raw, String, VariableSpecifications) - Method in class org.apache.cassandra.cql3.TokenRelation
 
toTerms(List<? extends ColumnSpecification>, List<? extends Term.Raw>, String, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Relation
Converts the specified Raw terms into a Terms.
toThrift(ConsistencyLevel) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
toThrift(RequestValidationException) - 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
 
toThrift(RequestFailureException) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
toThrift(KSMetaData) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
toThrift(CFMetaData) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
toThrift(ColumnDefinition) - Static method in class org.apache.cassandra.thrift.ThriftConversion
 
toThriftCaching() - Method in class org.apache.cassandra.cache.CachingOptions
 
toThriftCellsPerRow() - Method in class org.apache.cassandra.cache.CachingOptions
 
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
 
toTimeInMillis(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
toType(Pair<DataType, Object>) - Static method in enum org.apache.cassandra.transport.DataType
 
toWriteUTFBytes(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
tProtocolFactory - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
 
TpStats - Class in org.apache.cassandra.tools.nodetool
 
TpStats() - Constructor for class org.apache.cassandra.tools.nodetool.TpStats
 
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(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_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
trace_next_query() - Method in class org.apache.cassandra.thrift.CassandraServer
 
TRACE_TYPE - Static variable in class org.apache.cassandra.tracing.Tracing
 
TraceKeyspace - Class in org.apache.cassandra.tracing
 
TraceKeyspace() - Constructor for class org.apache.cassandra.tracing.TraceKeyspace
 
traceNextQuery() - Method in class org.apache.cassandra.service.QueryState
 
traceRepair(String, Object...) - Static method in class org.apache.cassandra.tracing.Tracing
 
traceState - Variable in class org.apache.cassandra.concurrent.ExecutorLocals
 
traceState - Variable in class org.apache.cassandra.service.AbstractReadExecutor
 
TraceState - Class in org.apache.cassandra.tracing
ThreadLocal state for a tracing session.
TraceState(InetAddress, UUID, Tracing.TraceType) - Constructor for class org.apache.cassandra.tracing.TraceState
 
TraceState.Status - Enum in org.apache.cassandra.tracing
 
traceType - Variable in class org.apache.cassandra.tracing.TraceState
 
tracetype_query_ttl - Variable in class org.apache.cassandra.config.Config
 
tracetype_repair_ttl - Variable in class org.apache.cassandra.config.Config
 
Tracing - Class in org.apache.cassandra.tracing
A trace session context.
Tracing() - Constructor for class org.apache.cassandra.tracing.Tracing
 
Tracing.TraceType - Enum in org.apache.cassandra.tracing
 
tracingId - Variable in class org.apache.cassandra.transport.Message.Response
 
tracingRequested - Variable in class org.apache.cassandra.transport.Message.Request
 
tracker - Variable in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
Tracker - Class in org.apache.cassandra.db.lifecycle
Tracker tracks live View of data store for a table.
Tracker(Memtable, boolean) - Constructor for class org.apache.cassandra.db.lifecycle.Tracker
 
Tracker(Comparator<Composite>) - Constructor for class org.apache.cassandra.db.RangeTombstone.Tracker
Creates a new tracker given the table comparator.
tracker - Variable in class org.apache.cassandra.transport.SimpleClient
 
tracksLegacyCounterShards() - Method in class org.apache.cassandra.io.sstable.format.Version
 
transaction - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
Transactional - Interface in org.apache.cassandra.utils.concurrent
An abstraction for Transactional behaviour.
Transactional.AbstractTransactional - Class in org.apache.cassandra.utils.concurrent
A simple abstract implementation of Transactional behaviour.
Transactional.AbstractTransactional.State - Enum in org.apache.cassandra.utils.concurrent
 
TransactionalProxy() - Constructor for class org.apache.cassandra.io.compress.CompressedSequentialWriter.TransactionalProxy
 
TransactionalProxy() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableWriter.TransactionalProxy
 
TransactionalProxy() - Constructor for class org.apache.cassandra.io.util.ChecksummedSequentialWriter.TransactionalProxy
 
TransactionalProxy() - Constructor for class org.apache.cassandra.io.util.SequentialWriter.TransactionalProxy
 
transferFiles(InetAddress, Collection<StreamSession.SSTableStreamingSections>) - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
transferFiles(InetAddress, Collection<StreamSession.SSTableStreamingSections>) - Method in class org.apache.cassandra.streaming.StreamPlan
Add transfer task to send given SSTable files.
transferRanges(InetAddress, String, Collection<Range<Token>>, String...) - Method in class org.apache.cassandra.streaming.StreamPlan
Add transfer task to send data of specific columnFamilies under keyspace and ranges.
transferRanges(InetAddress, InetAddress, String, Collection<Range<Token>>) - Method in class org.apache.cassandra.streaming.StreamPlan
Add transfer task to send data of specific keyspace and ranges.
transferRanges(InetAddress, InetAddress, String, Collection<Range<Token>>, String...) - Method in class org.apache.cassandra.streaming.StreamPlan
Add transfer task to send data of specific columnFamilies under keyspace and ranges.
transfers - Variable in class org.apache.cassandra.streaming.StreamSession
 
transferTo(long, long, WritableByteChannel) - Method in class org.apache.cassandra.io.util.ChannelProxy
 
TransportException - Interface in org.apache.cassandra.exceptions
 
tree - Variable in class org.apache.cassandra.repair.messages.ValidationComplete
Merkle hash tree response.
tree - Variable in class org.apache.cassandra.repair.TreeResponse
 
tree - Variable in class org.apache.cassandra.utils.btree.BTreeSet
 
TreeDifference(Token, Token, byte) - Constructor for class org.apache.cassandra.utils.MerkleTree.TreeDifference
 
treeReceived(MerkleTree) - Method in class org.apache.cassandra.repair.ValidationTask
Receive MerkleTree from replica node.
TreeResponse - Class in org.apache.cassandra.repair
Merkle tree response sent from given endpoint.
TreeResponse(InetAddress, MerkleTree) - Constructor for class org.apache.cassandra.repair.TreeResponse
 
trickle_fsync - Variable in class org.apache.cassandra.config.Config
 
trickle_fsync_interval_in_kb - Variable in class org.apache.cassandra.config.Config
 
TriggerDefinition - Class in org.apache.cassandra.config
 
TriggerDefinition(String, String) - Constructor for class org.apache.cassandra.config.TriggerDefinition
 
TriggerExecutor - Class in org.apache.cassandra.triggers
 
triggers(Map<String, TriggerDefinition>) - Method in class org.apache.cassandra.config.CFMetaData
 
TRIGGERS - Static variable in class org.apache.cassandra.schema.LegacySchemaTables
 
trim(int) - Method in class org.apache.cassandra.cql3.ResultSet
 
trim(ColumnFamily, int, long) - 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
 
trueSnapshotsSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
trueSnapshotsSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
trueSnapshotsSize() - Method in class org.apache.cassandra.db.Directories
 
trueSnapshotsSize - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Disk space used by snapshot files which
trueSnapshotsSize() - Method in class org.apache.cassandra.service.StorageService
 
trueSnapshotsSize() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Get the true size taken by all snapshots across all keyspaces.
trueSnapshotsSize() - Method in class org.apache.cassandra.tools.NodeProbe
 
truncate(String, long) - Static method in class org.apache.cassandra.io.util.FileUtils
 
truncate() - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile.Builder.Boundaries
 
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
 
truncateAllHints() - Method in class org.apache.cassandra.db.HintedHandOffManager
 
truncateAllHints() - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
Truncate all the hints
truncateBlocking() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Truncate deletes the entire column family's data with no expensive tombstone creation
truncateBlocking(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Truncate deletes the column family's data with no expensive tombstone creation, optionally snapshotting the data.
truncateBlocking(long) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
truncateBlocking(long) - Method in class org.apache.cassandra.db.index.SecondaryIndex
Truncate all the data from the current index
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
truncatedAt - Variable in class org.apache.cassandra.notifications.TruncationNotification
 
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
 
truncateHints(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
truncateHints() - Method in class org.apache.cassandra.tools.NodeProbe
 
TruncateHints - Class in org.apache.cassandra.tools.nodetool
 
TruncateHints() - Constructor for class org.apache.cassandra.tools.nodetool.TruncateHints
 
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
 
TruncateResponseHandler - Class in org.apache.cassandra.service
 
TruncateResponseHandler(int) - Constructor for class org.apache.cassandra.service.TruncateResponseHandler
 
TruncateResponseSerializer() - Constructor for class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
 
truncateSchemaTables() - Static method in class org.apache.cassandra.schema.LegacySchemaTables
 
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
 
TruncationNotification - Class in org.apache.cassandra.notifications
Fired during truncate, after the memtable has been flushed but before any snapshot is taken and SSTables are discarded
TruncationNotification(long) - Constructor for class org.apache.cassandra.notifications.TruncationNotification
 
truststore - Variable in class org.apache.cassandra.config.EncryptionOptions
 
TRUSTSTORE - Static variable in class org.apache.cassandra.thrift.SSLTransportFactory
 
truststore_password - Variable in class org.apache.cassandra.config.EncryptionOptions
 
TRUSTSTORE_PASSWORD - Static variable in class org.apache.cassandra.thrift.SSLTransportFactory
 
tryAppend(AbstractCompactedRow) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
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
 
tryMlockall() - Static method in class org.apache.cassandra.utils.CLibrary
 
tryModify(SSTableReader, OperationType) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
tryModify(Iterable<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
tryOpenDirectory(String) - Static method in class org.apache.cassandra.utils.CLibrary
 
tryRef() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
tryRef() - Method in class org.apache.cassandra.utils.concurrent.Ref
 
tryRef() - Method in interface org.apache.cassandra.utils.concurrent.RefCounted
 
tryRef(T) - Method in class org.apache.cassandra.utils.concurrent.Refs
Attempt to take a reference to the provided object; if it has already been released, null will be returned
tryRef(Iterable<T>) - Static method in class org.apache.cassandra.utils.concurrent.Refs
Acquire a reference to all of the provided objects, or none
trySkipCache(String, long, long) - Static method in class org.apache.cassandra.utils.CLibrary
 
trySkipCache(int, long, long) - 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
 
trySync(int) - Static method in class org.apache.cassandra.utils.SyncUtil
 
TServerCustomFactory - Class in org.apache.cassandra.thrift
Helper implementation to create a thrift TServer based on one of the common types we support (sync, 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
 
ttl - Variable in class org.apache.cassandra.db.CFRowAdder
 
ttl - Variable in class org.apache.cassandra.tracing.TraceState
 
tuple(List<CQL3Type.Raw>) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
tuple_type() - Method in class org.apache.cassandra.cql3.CqlParser
 
tupleLiteral() - Method in class org.apache.cassandra.cql3.CqlParser
 
tupleOfIdentifiers() - Method in class org.apache.cassandra.cql3.CqlParser
 
tupleOfMarkersForTuples() - Method in class org.apache.cassandra.cql3.CqlParser
 
tupleOfTupleLiterals() - Method in class org.apache.cassandra.cql3.CqlParser
 
Tuples - Class in org.apache.cassandra.cql3
Static helper methods and classes for tuples.
Tuples.DelayedValue - Class in org.apache.cassandra.cql3
Similar to Value, but contains at least one NonTerminal, such as a non-pure functions or bind marker.
Tuples.InMarker - Class in org.apache.cassandra.cql3
Represents a marker for a set of IN values that are tuples, like "SELECT ...
Tuples.INRaw - Class in org.apache.cassandra.cql3
A raw marker for an IN list of tuples, like "SELECT ...
Tuples.InValue - Class in org.apache.cassandra.cql3
A terminal value for a list of IN values that are tuples.
Tuples.Literal - Class in org.apache.cassandra.cql3
A raw, literal tuple.
Tuples.Marker - Class in org.apache.cassandra.cql3
{@code Represents a marker for a single tuple, like "SELECT ...
Tuples.Raw - Class in org.apache.cassandra.cql3
A raw placeholder for a tuple of values for different multiple columns, each of which may have a different type.
Tuples.Value - Class in org.apache.cassandra.cql3
A tuple of terminal values (e.g (123, 'abc')).
TupleSerializer - Class in org.apache.cassandra.serializers
 
TupleSerializer(List<TypeSerializer<?>>) - Constructor for class org.apache.cassandra.serializers.TupleSerializer
 
tupleToString(List<?>) - Static method in class org.apache.cassandra.cql3.Tuples
 
TupleType - Class in org.apache.cassandra.db.marshal
This is essentially like a CompositeType, but it's not primarily meant for comparison, just to pack multiple values together so has a more friendly encoding.
TupleType(List<AbstractType<?>>) - Constructor for class org.apache.cassandra.db.marshal.TupleType
 
TWO - Static variable in class org.apache.cassandra.utils.FBUtilities
 
twoHourRate() - Method in class org.apache.cassandra.metrics.RestorableMeter
Returns the two-hour rate in terms of events per second.
txnProxy() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
txnProxy() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
txnProxy - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
txnProxy() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
txnProxy() - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter
 
txnProxy() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
type - Variable in class org.apache.cassandra.cache.CachingOptions.KeyCache
 
type - Variable in class org.apache.cassandra.cache.CachingOptions.RowCache
 
type - Variable in class org.apache.cassandra.config.CFMetaData.SpeculativeRetry
 
type - Variable in class org.apache.cassandra.cql3.ColumnSpecification
 
type - Variable in class org.apache.cassandra.cql3.statements.BatchStatement
 
type - Variable in class org.apache.cassandra.cql3.statements.IndexTarget
 
type - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement
 
type - Variable in class org.apache.cassandra.cql3.Tuples.DelayedValue
 
type - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
type - Variable in class org.apache.cassandra.db.composites.AbstractSimpleCellNameType
 
type - Variable in class org.apache.cassandra.db.composites.SimpleCType
 
type - Variable in class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefix
 
type(int) - Method in class org.apache.cassandra.db.marshal.TupleType
 
type - Variable in class org.apache.cassandra.io.sstable.Component
 
type - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
type - Variable in class org.apache.cassandra.streaming.messages.StreamMessage
 
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.ConnectionMetrics
 
TYPE_NAME - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
 
TypeCast - Class in org.apache.cassandra.cql3
 
TypeCast(CQL3Type.Raw, Term.Raw) - Constructor for class org.apache.cassandra.cql3.TypeCast
 
typeColumns(CreateTypeStatement) - Method in class org.apache.cassandra.cql3.CqlParser
 
typeEquals(AbstractType<?>, AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.Functions
 
typeEquals(List<AbstractType<?>>, List<AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.functions.Functions
 
typeHashCode(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.Functions
 
typeHashCode(List<AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.functions.Functions
 
typeOf(ByteBuffer) - Static method in enum org.apache.cassandra.io.compress.BufferType
 
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
 
types - Variable in class org.apache.cassandra.db.marshal.TupleType
 
TypeSerializer<T> - Interface in org.apache.cassandra.serializers
 
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.VIntEncodedTypeSizes - Class in org.apache.cassandra.db
 

U

U - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
U - Static variable in class org.apache.cassandra.cql3.CqlParser
 
UDAggregate - Class in org.apache.cassandra.cql3.functions
Base class for user-defined-aggregates.
UDAggregate(FunctionName, List<AbstractType<?>>, AbstractType<?>, ScalarFunction, ScalarFunction, ByteBuffer) - Constructor for class org.apache.cassandra.cql3.functions.UDAggregate
 
UDFunction - Class in org.apache.cassandra.cql3.functions
Base class for User Defined Functions.
UDFunction(FunctionName, List<ColumnIdentifier>, List<AbstractType<?>>, AbstractType<?>, boolean, String, String) - Constructor for class org.apache.cassandra.cql3.functions.UDFunction
 
UDFunction(FunctionName, List<ColumnIdentifier>, List<AbstractType<?>>, DataType[], AbstractType<?>, DataType, boolean, String, String) - Constructor for class org.apache.cassandra.cql3.functions.UDFunction
 
UDHelper - Class in org.apache.cassandra.cql3.functions
Helper class for User Defined Functions + Aggregates.
UDHelper() - Constructor for class org.apache.cassandra.cql3.functions.UDHelper
 
unaliasedSelector() - Method 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
 
UnavailableException(String, ConsistencyLevel, int, int) - Constructor for exception org.apache.cassandra.exceptions.UnavailableException
 
unavailables - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
 
UnbufferedDataOutputStreamPlus - Class in org.apache.cassandra.io.util
Base class for DataOutput implementations that does not have an optimized implementations of Plus methods and does no buffering.
UnbufferedDataOutputStreamPlus() - Constructor for class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
 
UnbufferedDataOutputStreamPlus(WritableByteChannel) - Constructor for class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
 
UNCHECKED_TOMBSTONE_COMPACTION_OPTION - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
uncheckedTombstoneCompaction - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
uncompress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
uncompress(byte[], int, int, byte[], int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
uncompress(byte[], int, int, byte[], int, 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(ByteBuffer, ByteBuffer) - Method in interface org.apache.cassandra.io.compress.ICompressor
Decompression for DirectByteBuffers.
uncompress(byte[], int, int, byte[], int) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
 
uncompress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
 
uncompress(byte[], int, int, byte[], int) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
 
uncompress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
 
uncompressBuffer(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
uncompressedLength() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
unfinishedCommit - Variable in class org.apache.cassandra.metrics.CASClientRequestMetrics
 
UniqueIdentifier() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader.UniqueIdentifier
 
unixTimestamp(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
 
unixTimestampOfFct - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
Deprecated.
Replaced by the TimeFcts.timeUuidToUnixTimestamp function
UnknownColumnFamilyException - Exception in org.apache.cassandra.db
 
UnknownColumnFamilyException(String, UUID) - Constructor for exception org.apache.cassandra.db.UnknownColumnFamilyException
 
unlogged_batch_across_partitions_warn_threshold - Variable in class org.apache.cassandra.config.Config
 
UNREACHABLE - Static variable in class org.apache.cassandra.service.StorageProxy
 
UNREADABLE_VERSION - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
UnrecognizedEntityException - Exception in org.apache.cassandra.exceptions
Exception thrown when an entity is not recognized within a relation.
UnrecognizedEntityException(ColumnIdentifier, Relation) - Constructor for exception org.apache.cassandra.exceptions.UnrecognizedEntityException
Creates a new UnrecognizedEntityException.
unreference() - Method in class org.apache.cassandra.cache.RefCountedMemory
decrement reference count.
unregister(IEndpointStateChangeSubscriber) - Method in class org.apache.cassandra.gms.Gossiper
Unregister interest for state changes.
unregister(MigrationListener) - Method in class org.apache.cassandra.service.MigrationManager
 
unregister(IEndpointLifecycleSubscriber) - Method in class org.apache.cassandra.service.StorageService
 
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
 
UNREPAIRED_SSTABLE - Static variable in class org.apache.cassandra.service.ActiveRepairService
 
UNREPAIRED_SSTABLES - Static variable in class org.apache.cassandra.db.ColumnFamilyStore
 
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
 
unsafeAssassinateEndpoint(String) - Method in interface org.apache.cassandra.gms.GossiperMBean
 
unsafeInitialize() - Method in class org.apache.cassandra.service.StorageService
 
UnsafeOperations() - Constructor for class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
UNSET_BYTE_BUFFER - Static variable in class org.apache.cassandra.utils.ByteBufferUtil
Represents an unset value in bound variables
UNSET_VALUE - Static variable in class org.apache.cassandra.cql3.Constants
 
unsharedHeapSize() - Method in class org.apache.cassandra.cache.CounterCacheKey
 
unsharedHeapSize() - Method in interface org.apache.cassandra.cache.IMeasurableMemory
 
unsharedHeapSize() - Method in class org.apache.cassandra.cache.KeyCacheKey
 
unsharedHeapSize() - Method in class org.apache.cassandra.cache.RowCacheKey
 
unsharedHeapSize() - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.ClockAndCount
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.composites.BoundedComposite
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.composites.CompoundComposite
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.composites.CompoundDenseCellName
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName.WithCollection
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.composites.SimpleComposite
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.composites.SimpleDenseCellName
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.composites.SimpleSparseInternedCellName
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.DeletionInfo
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.DeletionTime
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.NativeCell
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.NativeCounterCell
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.NativeDeletedCell
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.NativeExpiringCell
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.RowIndexEntry
 
unsharedHeapSize() - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.BufferCell
 
unsharedHeapSizeExcludingData() - Method in interface org.apache.cassandra.db.Cell
 
unsharedHeapSizeExcludingData() - Method in interface org.apache.cassandra.db.composites.CellName
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.composites.CompoundComposite
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.composites.CompoundDenseCellName
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.composites.CompoundSparseCellName.WithCollection
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.composites.SimpleDenseCellName
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.composites.SimpleSparseInternedCellName
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.NativeCell
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.NativeCounterCell
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.NativeDeletedCell
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.NativeExpiringCell
 
unsubscribe(INotificationConsumer) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
UntypedResultSet - Class in org.apache.cassandra.cql3
a utility for doing internal cql-based queries
UntypedResultSet() - Constructor for class org.apache.cassandra.cql3.UntypedResultSet
 
UntypedResultSet.Row - Class in org.apache.cassandra.cql3
 
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(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(ByteBuffer, Cell, Cell, OpOrder.Group) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
update(ByteBuffer, Cell, Cell, OpOrder.Group) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
update a column from the index
update(Cell, Cell) - Method in interface org.apache.cassandra.db.index.SecondaryIndexManager.Updater
called when updating the index from a memtable
update(SSTableReader, boolean) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
update a reader: if !original, this is a reader that is being introduced by this transaction; otherwise it must be in the originals() set, i.e.
update(OnDiskAtom, boolean) - Method in class org.apache.cassandra.db.RangeTombstone.Tracker
Update this tracker given an atom.
update(int) - Method in class org.apache.cassandra.io.sstable.ColumnStats.MaxIntTracker
 
update(long) - Method in class org.apache.cassandra.io.sstable.ColumnStats.MaxLongTracker
 
update(long) - Method in class org.apache.cassandra.io.sstable.ColumnStats.MinLongTracker
 
update(long, ColumnStats) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
update(long) - Method in class org.apache.cassandra.metrics.ColumnFamilyMetrics.ColumnFamilyHistogram
 
update(long) - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
Increments the count of the bucket closest to n, rounding UP.
update - Variable in class org.apache.cassandra.service.paxos.Commit
 
update() - Method in class org.apache.cassandra.service.PendingRangeCalculatorService
 
update(Object[], Comparator<V>, Collection<V>, boolean) - Static method in class org.apache.cassandra.utils.btree.BTree
Returns a new BTree with the provided set inserting/replacing as necessary any equal items
update(Object[], Comparator<V>, Collection<V>, boolean, UpdateFunction<V>) - Static method in class org.apache.cassandra.utils.btree.BTree
 
update(Object[], Comparator<V>, Iterable<V>, int, boolean, UpdateFunction<V>) - Static method in class org.apache.cassandra.utils.btree.BTree
Returns a new BTree with the provided set inserting/replacing as necessary any equal items
update(Collection<V>, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
update(I) - Method in class org.apache.cassandra.utils.OverlapIterator
 
update(byte[], int, int) - Method in class org.apache.cassandra.utils.PureJavaCrc32
 
update(ByteBuffer, 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.
updateAggregate(UDAggregate) - Method in class org.apache.cassandra.config.Schema
 
updateAllTimestamp(long) - Method in class org.apache.cassandra.db.DeletionInfo
 
updateAllTimestamp(long) - Method in class org.apache.cassandra.db.RangeTombstoneList
 
updateAvailableRanges(String, Collection<Range<Token>>) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
updateChecksumInt(Checksum, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
updateColumnsLimit(int) - Method in class org.apache.cassandra.db.DataRange.Paging
 
updateColumnsLimit(int) - Method in class org.apache.cassandra.db.DataRange
Sets a new limit on the number of (grouped) cells to fetch.
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
 
updateCompactionHistory(String, String, AbstractCompactionIterable, long, long) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
 
updateCompactionHistory(String, String, long, long, long, Map<Integer, Long>) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
updateConditions() - Method in class org.apache.cassandra.cql3.CqlParser
 
updateCounterFor(int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.AbstractCell
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.BufferCounterCell
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.BufferDeletedCell
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.BufferExpiringCell
 
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.DeletionInfo
Digests deletion info.
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.NativeCell
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.NativeCounterCell
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.NativeDeletedCell
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.NativeExpiringCell
 
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.RangeTombstoneList
Calculates digest for triggering read repair on mismatch
updateFilter(int) - Method in class org.apache.cassandra.db.filter.ExtendedFilter
 
updateFunction(UDFunction) - Method in class org.apache.cassandra.config.Schema
 
UpdateFunction<V> - Interface in org.apache.cassandra.utils.btree
An interface defining a function to be applied to both the object we are replacing in a BTree and the object that is intended to replace it, returning the object to actually replace it.
UpdateFunction.NoOp<V> - Class in org.apache.cassandra.utils.btree
 
updateHasLegacyCounterShards(boolean) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
updateHintsDropped(InetAddress, UUID, int) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
updateHostId(UUID, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
Store an end-point to host ID mapping.
updateInt(int) - Method in class org.apache.cassandra.utils.PureJavaCrc32
 
updateKeyspace(String) - Method in class org.apache.cassandra.config.Schema
 
updateMaxColumnNames(List<ByteBuffer>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
updateMaxLocalDeletionTime(int) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
updateMaxTimestamp(long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
updateMinColumnNames(List<ByteBuffer>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
updateMinTimestamp(long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
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(CFMetaData, QueryOptions, long, int, Map<ByteBuffer, CQL3Row>) - Constructor for class org.apache.cassandra.cql3.UpdateParameters
 
updatePeerInfo(InetAddress, String, Object) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
updatePreferredIP(InetAddress, InetAddress) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
updateProgress(ProgressInfo) - Method in class org.apache.cassandra.streaming.SessionInfo
Update progress of receiving/sending file.
updateProgress(ProgressInfo) - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
updaterFor(DecoratedKey, ColumnFamily, OpOrder.Group) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
This helper acts as a closure around the indexManager and updated cf data 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.SystemKeyspace
 
updateSizeEstimates(String, String, Map<Range<Token>, Pair<Long, Long>>) - Static method in class org.apache.cassandra.db.SystemKeyspace
Writes the current partition count and size estimates into SIZE_ESTIMATES_CF
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.cql3.CqlParser
 
UpdateStatement - Class in org.apache.cassandra.cql3.statements
An UPDATE statement parsed from a CQL query statement.
UpdateStatement.ParsedInsert - Class in org.apache.cassandra.cql3.statements
 
UpdateStatement.ParsedInsertJson - Class in org.apache.cassandra.cql3.statements
A parsed INSERT JSON statement.
UpdateStatement.ParsedUpdate - Class in org.apache.cassandra.cql3.statements
 
updateTable(String, String) - Method in class org.apache.cassandra.config.Schema
 
updateTokens(InetAddress, Collection<Token>) - Static method in class org.apache.cassandra.db.SystemKeyspace
Record tokens being used by another node
updateTokens(Collection<Token>) - Static method in class org.apache.cassandra.db.SystemKeyspace
This method is used to update the System Keyspace with the new tokens for this node
updateTopology(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
This is called when the snitch properties for this endpoint are updated, see CASSANDRA-10238.
updateTopology() - Method in class org.apache.cassandra.locator.TokenMetadata
This is called when the snitch properties for many endpoints are updated, it will update the topology mappings of any endpoints whose snitch has changed, see CASSANDRA-10238.
updateTopology(InetAddress) - Method in class org.apache.cassandra.service.StorageService
 
updateTopology() - Method in class org.apache.cassandra.service.StorageService
 
updateType(UserType) - Method in class org.apache.cassandra.config.Schema
 
updateVersion() - Method in class org.apache.cassandra.config.Schema
Read schema from system keyspace 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
 
updateWithByte(MessageDigest, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
updateWithInt(MessageDigest, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
updateWithLong(MessageDigest, long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
updateWithName(MessageDigest) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
updateWithShort(MessageDigest, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
updateWithValue(MessageDigest) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
upgrade() - Method in class org.apache.cassandra.db.compaction.Upgrader
 
Upgrader - Class in org.apache.cassandra.db.compaction
 
Upgrader(ColumnFamilyStore, LifecycleTransaction, OutputHandler) - Constructor for class org.apache.cassandra.db.compaction.Upgrader
 
UpgradeSSTable - Class in org.apache.cassandra.tools.nodetool
 
UpgradeSSTable() - Constructor for class org.apache.cassandra.tools.nodetool.UpgradeSSTable
 
upgradeSSTables(String, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
 
upgradeSSTables(String, boolean, int, String...) - Method in class org.apache.cassandra.service.StorageService
 
upgradeSSTables(String, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
upgradeSSTables(String, boolean, int, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
upgradeSSTables(String, boolean, int, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
upgradeSSTables(PrintStream, String, boolean, int, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
upperBound(Class<R>) - Method in class org.apache.cassandra.dht.Token
 
upperBound - Variable in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
USE_HEAP_ALLOCATOR - Static variable in class org.apache.cassandra.transport.CBUtil
 
useCompression() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
Checks if the segments must be compressed.
used() - Method in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
 
usedRatio() - Method in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
 
usePartitionFilter - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
usePartitionFilter - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
USER_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
 
USER_PERMISSIONS - Static variable in class org.apache.cassandra.auth.CassandraAuthorizer
 
USERNAME - Static variable in class org.apache.cassandra.auth.CassandraAuthorizer
 
username() - Method in class org.apache.cassandra.cql3.CqlParser
 
username - Variable in class org.apache.cassandra.hadoop.pig.CassandraStorage
Deprecated.
 
username - Variable in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
Deprecated.
 
username - Variable in class org.apache.cassandra.tools.AbstractJmxClient
 
USERNAME_KEY - Static variable in class org.apache.cassandra.auth.PasswordAuthenticator
 
username_return() - Constructor for class org.apache.cassandra.cql3.CqlParser.username_return
 
userOrRoleName() - Method in class org.apache.cassandra.cql3.CqlParser
 
userPassword(RoleOptions) - Method in class org.apache.cassandra.cql3.CqlParser
 
userType(UTName) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
UserType - Class in org.apache.cassandra.db.marshal
A user defined type.
UserType(String, ByteBuffer, List<ByteBuffer>, List<AbstractType<?>>) - Constructor for class org.apache.cassandra.db.marshal.UserType
 
usertypeLiteral() - Method in class org.apache.cassandra.cql3.CqlParser
 
userTypeName() - Method in class org.apache.cassandra.cql3.CqlParser
 
userTypes - Variable in class org.apache.cassandra.config.KSMetaData
 
UserTypes - Class in org.apache.cassandra.cql3
Static helper methods and classes for user types.
USERTYPES - Static variable in class org.apache.cassandra.schema.LegacySchemaTables
 
UserTypes.DelayedValue - Class in org.apache.cassandra.cql3
 
UserTypes.Literal - Class in org.apache.cassandra.cql3
 
UserTypeSerializer - Class in org.apache.cassandra.serializers
 
UserTypeSerializer(LinkedHashMap<String, TypeSerializer<?>>) - Constructor for class org.apache.cassandra.serializers.UserTypeSerializer
 
userTypeUpdated(String, String) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
usesSecondaryIndexing() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the secondary index need to be queried.
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
 
using(String) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
The INSERT statement defining the order of the values to add for a given CQL row.
usingClause(Attributes.Raw) - Method in class org.apache.cassandra.cql3.CqlParser
 
usingClauseDelete(Attributes.Raw) - Method in class org.apache.cassandra.cql3.CqlParser
 
usingClauseObjective(Attributes.Raw) - Method in class org.apache.cassandra.cql3.CqlParser
 
UTF8Serializer - Class in org.apache.cassandra.serializers
 
UTF8Type - Class in org.apache.cassandra.db.marshal
 
Util - Class in org.apache.cassandra.tools
 
UTMetaData - Class in org.apache.cassandra.config
Defined (and loaded) user types.
UTMetaData() - Constructor for class org.apache.cassandra.config.UTMetaData
 
UTMetaData(Map<ByteBuffer, UserType>) - Constructor for class org.apache.cassandra.config.UTMetaData
 
UTName - Class in org.apache.cassandra.cql3
 
UTName(ColumnIdentifier, ColumnIdentifier) - Constructor for class org.apache.cassandra.cql3.UTName
 
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
 
uuidFct - Static variable in class org.apache.cassandra.cql3.functions.UuidFcts
 
UuidFcts - Class in org.apache.cassandra.cql3.functions
 
UuidFcts() - Constructor for class org.apache.cassandra.cql3.functions.UuidFcts
 
UUIDGen - Class in org.apache.cassandra.utils
The goods are here: www.ietf.org/rfc/rfc4122.txt.
UUIDSerializer - Class in org.apache.cassandra.serializers
 
UUIDSerializer() - Constructor for class org.apache.cassandra.serializers.UUIDSerializer
 
UUIDSerializer - Class in org.apache.cassandra.utils
 
UUIDSerializer() - Constructor for class org.apache.cassandra.utils.UUIDSerializer
 
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.cql3.CqlLexer
 
V - Static variable in class org.apache.cassandra.cql3.CqlParser
 
validate() - Method in class org.apache.cassandra.auth.RoleOptions
Validate the contents of the options in two ways: - Ensure that only a subset of the options supported by the configured IRoleManager are set - Validate the type of any option values present.
validate() - Method in class org.apache.cassandra.config.CFMetaData
 
validate() - Method in class org.apache.cassandra.config.KSMetaData
 
validate(ClientState) - Method in interface org.apache.cassandra.cql3.CQLStatement
Perform additional validation required by the statment.
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterRoleStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
 
validate() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
validate() - Method in class org.apache.cassandra.cql3.statements.CFPropDefs
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateAggregateStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateFunctionStatement
 
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.CreateRoleStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTableStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTriggerStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateTypeStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropAggregateStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropFunctionStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropIndexStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropKeyspaceStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropRoleStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTableStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTypeStatement
 
validate() - Method in class org.apache.cassandra.cql3.statements.IndexPropDefs
 
validate() - Method in class org.apache.cassandra.cql3.statements.KSPropDefs
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListRolesStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
 
validate(Set<String>, Set<String>) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.RoleManagementStatement
 
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(Composite) - Method in class org.apache.cassandra.db.composites.AbstractCType
 
validate(Composite) - Method in interface org.apache.cassandra.db.composites.CType
Validates a composite.
validate(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
 
validate(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
 
validate(Cell) - Method in class org.apache.cassandra.db.index.PerColumnSecondaryIndex
 
validate(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
 
validate(Cell) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
 
validate(ByteBuffer, ColumnFamily) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
 
validate(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.SecondaryIndex
 
validate(ByteBuffer, Cell) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
validate(IndexExpression) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
Validates the specified IndexExpression.
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.ColumnToCollectionType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
validate(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
validate() - Method in class org.apache.cassandra.io.compress.CompressionParameters
 
validate(String) - Static method in enum org.apache.cassandra.io.sstable.format.SSTableFormat.Type
 
validate(String) - Static method in class org.apache.cassandra.io.sstable.format.Version
 
validate(byte[], int, int) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
 
validate() - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.FileDigestValidator
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.AsciiSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.BooleanSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.ByteSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.CollectionSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.DecimalSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.DoubleSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.EmptySerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.FloatSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.Int32Serializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.IntegerSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.LongSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.ShortSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimeSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimestampSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimeUUIDSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TupleSerializer
 
validate(ByteBuffer) - Method in interface org.apache.cassandra.serializers.TypeSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.UserTypeSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.UTF8Serializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.UUIDSerializer
 
validateCellName(CellName, CellNameType) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
validateCellNames(Iterable<CellName>, CellNameType) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
validateCellValue(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
Validate cell value.
validateCellValue(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CollectionType
 
validateClusteringRestrictions(boolean) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Validates whether or not restrictions are allowed for execution when secondary index is not used.
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
 
validateColumnData(CFMetaData, ByteBuffer, ByteBuffer, Column) - Static method in class org.apache.cassandra.thrift.ThriftValidation
Validates the data part of the column (everything in the column object but the name, which is assumed to be valid)
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
 
validateColumnNames(CFMetaData, ColumnParent, Iterable<ByteBuffer>) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateColumnOrSuperColumn(CFMetaData, ByteBuffer, 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>) - 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
 
validateComposite(Composite, CType) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
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 class org.apache.cassandra.auth.CassandraRoleManager
 
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 interface org.apache.cassandra.auth.IRoleManager
Hook to perform validation of an implementation's configuration (if supported).
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
Deprecated.
 
validateContext(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
 
validateCounterForWrite(CFMetaData) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
validateDeletion(CFMetaData, Deletion) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.AbstractCell
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.BufferCounterCell
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.BufferDeletedCell
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.BufferExpiringCell
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.NativeCounterCell
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.NativeDeletedCell
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.NativeExpiringCell
 
validateFields(CFMetaData) - Method in interface org.apache.cassandra.db.OnDiskAtom
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.RangeTombstone
 
validateFilterClauses(CFMetaData, List<IndexExpression>) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateForCas() - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
validateForCasCommit(String) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
validateForNativeProtocol(ByteBuffer, int) - Method in class org.apache.cassandra.serializers.CollectionSerializer
 
validateForNativeProtocol(ByteBuffer, int) - Method in class org.apache.cassandra.serializers.ListSerializer
 
validateForNativeProtocol(ByteBuffer, int) - Method in class org.apache.cassandra.serializers.MapSerializer
 
validateForNativeProtocol(ByteBuffer, int) - Method in class org.apache.cassandra.serializers.SetSerializer
 
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
 
validateIndexSearchersForQuery(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
Validates an union of expression index types.
validateKey(ByteBuffer) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
validateKey(CFMetaData, ByteBuffer) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateKeyRange(CFMetaData, ByteBuffer, KeyRange) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateKeyspace(String) - 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
 
validateMutation(CFMetaData, ByteBuffer, Mutation) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateName(CFMetaData) - Method in class org.apache.cassandra.db.AbstractCell
 
validateNewMessage(Message.Type, int, int) - 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.DateTieredCompactionStrategy
 
validateOptions(Map<String, String>, Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
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(Map<String, String>, Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
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
 
validatePartitioner(AbstractBounds<?>) - Static method in class org.apache.cassandra.net.MessagingService
 
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
 
validateReallocation(long) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
validateReplicationFactor(String) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
validateReplicationStrategy(String, Class<? extends AbstractReplicationStrategy>, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
validateRowLevelIndexes(ByteBuffer, ColumnFamily) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
 
validateSlicePredicate(CFMetaData, ByteBuffer, SlicePredicate) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateSlices(ColumnSlice[], CellNameType, boolean) - Static method in class org.apache.cassandra.db.filter.ColumnSlice
Validates that the provided slice array contains only non-overlapped slices valid for a query reversed or not on a table using comparator.
validateWhereClauseForConditions() - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
 
validateWhereClauseForConditions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
If there are conditions on the statement, this is called after the where clause and conditions have been processed to check that they are compatible.
ValidationComplete - Class in org.apache.cassandra.repair.messages
ValidationComplete message is sent when validation compaction completed successfully.
ValidationComplete(RepairJobDesc) - Constructor for class org.apache.cassandra.repair.messages.ValidationComplete
 
ValidationComplete(RepairJobDesc, MerkleTree) - Constructor for class org.apache.cassandra.repair.messages.ValidationComplete
 
validationComplete(RepairJobDesc, InetAddress, MerkleTree) - Method in class org.apache.cassandra.repair.RepairSession
Receive merkle tree response or failed response from endpoint for current repair job.
ValidationMetadata - Class in org.apache.cassandra.io.sstable.metadata
SSTable metadata component used only for validating SSTable.
ValidationMetadata(String, double) - Constructor for class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
 
ValidationMetadata.ValidationMetadataSerializer - Class in org.apache.cassandra.io.sstable.metadata
 
ValidationMetadataSerializer() - Constructor for class org.apache.cassandra.io.sstable.metadata.ValidationMetadata.ValidationMetadataSerializer
 
ValidationRequest - Class in org.apache.cassandra.repair.messages
ValidationRequest
ValidationRequest(RepairJobDesc, int) - Constructor for class org.apache.cassandra.repair.messages.ValidationRequest
 
ValidationRequest.ValidationRequestSerializer - Class in org.apache.cassandra.repair.messages
 
ValidationRequestSerializer() - Constructor for class org.apache.cassandra.repair.messages.ValidationRequest.ValidationRequestSerializer
 
ValidationTask - Class in org.apache.cassandra.repair
ValidationTask sends ValidationRequest to a replica.
ValidationTask(RepairJobDesc, InetAddress, int) - Constructor for class org.apache.cassandra.repair.ValidationTask
 
validator - Variable in class org.apache.cassandra.cql3.statements.AlterTableStatement
 
Validator - Class in org.apache.cassandra.repair
Handles the building of a merkle tree for a column family.
Validator(RepairJobDesc, InetAddress, int) - Constructor for class org.apache.cassandra.repair.Validator
 
Validator(RepairJobDesc, InetAddress, int, boolean) - Constructor for class org.apache.cassandra.repair.Validator
 
validBufferBytes - Variable in class org.apache.cassandra.streaming.compress.CompressedInputStream
 
value - Variable in class org.apache.cassandra.config.CFMetaData.SpeculativeRetry
 
Value(ByteBuffer) - Constructor for class org.apache.cassandra.cql3.Constants.Value
 
value() - Method in class org.apache.cassandra.cql3.CqlParser
 
Value(List<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Lists.Value
 
Value(Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Maps.Value
 
value - Variable in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQ
 
Value(SortedSet<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Sets.Value
 
Value(ByteBuffer[]) - Constructor for class org.apache.cassandra.cql3.Tuples.Value
 
value() - Method in class org.apache.cassandra.db.AbstractNativeCell
 
value - Variable in class org.apache.cassandra.db.BufferCell
 
value() - Method in class org.apache.cassandra.db.BufferCell
 
value() - Method in interface org.apache.cassandra.db.Cell
 
value - Variable in class org.apache.cassandra.db.IndexExpression
 
value - Variable in class org.apache.cassandra.db.marshal.AbstractCompositeType.CompositeComponent
 
value - Variable in enum org.apache.cassandra.exceptions.ExceptionCode
 
value - Variable in class org.apache.cassandra.gms.VersionedValue
 
value - Variable in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader.Column
Deprecated.
 
value() - Method in class org.apache.cassandra.utils.DefaultInteger
 
value - Variable in class org.apache.cassandra.utils.ExpiringMap.CacheableObject
 
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
 
valueCount() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
valueFactory - Variable in class org.apache.cassandra.service.StorageService
 
valueOf(String) - Static method in enum org.apache.cassandra.auth.IRoleManager.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.cache.CachingOptions.KeyCache.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cache.CachingOptions.RowCache.Type
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.SpeculativeRetry.RetryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.ColumnDefinition.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.Config.CommitFailurePolicy
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.MemtableAllocationType
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.IndexType
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.cql3.AssignmentTestable.TestResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cql3.Attributes.ExpirationDateOverflowPolicy
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.Operator
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.BatchStatement.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.Bound
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.IndexTarget.TargetType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.ModificationStatement.StatementType
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.ColumnSerializer.Flag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.compaction.CompactionManager.AllSSTableOpStatus
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.composites.Composite.EOC
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.CounterContext.Relationship
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.Directories.FileAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState.Action
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.ReadCommand.Type
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.SystemKeyspace.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.CassandraStorage.MarshallerType
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.io.compress.BufferType
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.io.sstable.Descriptor.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.format.SSTableFormat.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.format.SSTableReader.OpenReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.metadata.MetadataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.metrics.ColumnFamilyMetrics.Sampler
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.repair.messages.RepairMessage.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.repair.RepairParallelism
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.service.ActiveRepairService.Status
Deprecated.
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.messages.StreamMessage.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.streaming.ProgressInfo.Direction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.streaming.StreamEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.streaming.StreamSession.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.tracing.TraceState.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.tracing.Tracing.TraceType
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.SchemaChange.Target
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.utils.AsymmetricOrdering.Op
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.utils.NoSpamLogger.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.utils.progress.ProgressEventType
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.cassandra.auth.IRoleManager.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.cache.CachingOptions.KeyCache.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.cache.CachingOptions.RowCache.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.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.SpeculativeRetry.RetryType
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.ColumnDefinition.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.config.Config.CommitFailurePolicy
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.MemtableAllocationType
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.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.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.cql3.AssignmentTestable.TestResult
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.Attributes.ExpirationDateOverflowPolicy
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.Operator
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InWithValues
 
values - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InWithValues
 
values(CFMetaData, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQ
 
values(CFMetaData, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.Slice
 
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.BatchStatement.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.Bound
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.IndexTarget.TargetType
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.StatementType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.db.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.ColumnSerializer.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.db.compaction.CompactionManager.AllSSTableOpStatus
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.composites.Composite.EOC
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.CounterContext.Relationship
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.Directories.FileAction
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.lifecycle.LifecycleTransaction.ReaderState.Action
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() - Static method in enum org.apache.cassandra.db.ReadCommand.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.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.SystemKeyspace.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.CassandraStorage.MarshallerType
Deprecated.
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.compress.BufferType
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() - Static method in enum org.apache.cassandra.io.sstable.Descriptor.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.io.sstable.format.SSTableFormat.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.io.sstable.format.SSTableReader.OpenReason
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.metadata.MetadataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
values() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
values() - Static method in enum org.apache.cassandra.metrics.ColumnFamilyMetrics.Sampler
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.net.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.repair.messages.RepairMessage.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.repair.RepairParallelism
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.apache.cassandra.serializers.MapSerializer
 
values() - Static method in enum org.apache.cassandra.service.ActiveRepairService.Status
Deprecated.
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.messages.StreamMessage.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.streaming.ProgressInfo.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.streaming.StreamEvent.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.streaming.StreamSession.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.tracing.TraceState.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.tracing.Tracing.TraceType
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.SchemaChange.Target
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.BatchMessage
 
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.utils.AsymmetricOrdering.Op
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.concurrent.Transactional.AbstractTransactional.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
values() - Static method in enum org.apache.cassandra.utils.NoSpamLogger.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.utils.progress.ProgressEventType
Returns an array containing the constants of this enum type, in the order they are declared.
valuesAsComposites(CFMetaData, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
valueSet() - Method in class org.apache.cassandra.utils.BiMultiValMap
 
valuesOf(ColumnIdentifier.Raw) - Static method in class org.apache.cassandra.cql3.statements.IndexTarget.Raw
 
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
 
VariableSpecifications - Class in org.apache.cassandra.cql3
 
VariableSpecifications(List<ColumnIdentifier>) - Constructor for class org.apache.cassandra.cql3.VariableSpecifications
 
verb - Variable in class org.apache.cassandra.net.MessageIn
 
verb - Variable in class org.apache.cassandra.net.MessageOut
 
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
 
Verifier - Class in org.apache.cassandra.db.compaction
 
Verifier(ColumnFamilyStore, SSTableReader, boolean) - Constructor for class org.apache.cassandra.db.compaction.Verifier
 
Verifier(ColumnFamilyStore, SSTableReader, OutputHandler, boolean) - Constructor for class org.apache.cassandra.db.compaction.Verifier
 
verify(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
verify(boolean) - Method in class org.apache.cassandra.db.compaction.Verifier
 
verify() - Method in class org.apache.cassandra.service.StartupChecks
Run the configured tests and return a report detailing the results.
verify(boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
verify(boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Verify (checksums of) the given keyspace.
verify(boolean, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
verify(PrintStream, boolean, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
Verify - Class in org.apache.cassandra.tools.nodetool
 
Verify() - Constructor for class org.apache.cassandra.tools.nodetool.Verify
 
verifyBatchSize(Iterable<ColumnFamily>) - Static method in class org.apache.cassandra.cql3.statements.BatchStatement
Checks batch size to ensure threshold is met.
verifyFullPermissions(File, String) - Static method in class org.apache.cassandra.db.Directories
Checks whether Cassandra has RWX permissions to the specified directory.
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 - Class in org.apache.cassandra.io.sstable.format
A set of feature flags associated with a SSTable format versions are denoted as [major][minor].
Version(SSTableFormat, String) - Constructor for class org.apache.cassandra.io.sstable.format.Version
 
version - Variable in class org.apache.cassandra.io.sstable.format.Version
 
version - Variable in class org.apache.cassandra.net.MessageIn
 
version - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
SSTable version
Version - Class in org.apache.cassandra.tools.nodetool
 
Version() - Constructor for class org.apache.cassandra.tools.nodetool.Version
 
version - Variable in class org.apache.cassandra.transport.Frame.Header
 
version - Variable in class org.apache.cassandra.transport.SimpleClient
 
VERSION_1 - Static variable in class org.apache.cassandra.transport.Server
 
VERSION_12 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
VERSION_12 - Static variable in class org.apache.cassandra.net.MessagingService
 
VERSION_2 - Static variable in class org.apache.cassandra.transport.Server
 
VERSION_20 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
VERSION_20 - Static variable in class org.apache.cassandra.net.MessagingService
 
VERSION_20 - Static variable in class org.apache.cassandra.streaming.messages.StreamMessage
Streaming protocol version
VERSION_21 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
VERSION_21 - Static variable in class org.apache.cassandra.net.MessagingService
 
VERSION_22 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
VERSION_22 - Static variable in class org.apache.cassandra.net.MessagingService
 
VERSION_22 - Static variable in class org.apache.cassandra.streaming.messages.StreamMessage
 
VERSION_3 - Static variable in class org.apache.cassandra.transport.Server
 
VERSION_4 - Static variable in class org.apache.cassandra.transport.Server
 
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
 
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
 
View - Class in org.apache.cassandra.db.lifecycle
An immutable structure holding the current memtable, the memtables pending flush, the sstables for a column family, and the sstables that are active in compaction (a subset of the sstables).
viewFilter(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
viewFilter(AbstractBounds<RowPosition>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
viewFilter(Collection<AbstractBounds<RowPosition>>, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
ViewFragment(List<SSTableReader>, Iterable<Memtable>) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
 
VINT - Static variable in class org.apache.cassandra.db.TypeSizes
 
VIntEncodedTypeSizes() - Constructor for class org.apache.cassandra.db.TypeSizes.VIntEncodedTypeSizes
 
visible(SSTableReader, Predicate<SSTableReader>, Collection<SSTableReader>...) - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState
 
Void() - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Void
 

W

W - Static variable in class org.apache.cassandra.cql3.CqlLexer
 
W - Static variable in class org.apache.cassandra.cql3.CqlParser
 
WAIT_FOR_VERSION_MAX_TIME - Static variable in class org.apache.cassandra.net.OutboundTcpConnection
 
waitActivity(long) - Method in class org.apache.cassandra.tracing.TraceState
 
waitForCessation(Iterable<ColumnFamilyStore>) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
waitForDeletions() - Static method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
for tests
waitForPendingEvents() - Method in class org.apache.cassandra.tracing.TraceState
Post a no-op event to the TRACING stage, so that we can be sure that any previous mutations have at least been applied to one replica.
waitForStarted() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
 
waitForSync(Pair<RepairJobDesc, NodePair>, RemoteSyncTask) - Method in class org.apache.cassandra.repair.RepairSession
 
waitForValidation(Pair<RepairJobDesc, InetAddress>, ValidationTask) - Method in class org.apache.cassandra.repair.RepairSession
 
waitingFor(InetAddress) - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
waitingFor(InetAddress) - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
waitingOnCommit - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
The time spent waiting on CL sync; for Periodic this is only occurs when the sync is lagging its sync interval
waitingOnFreeMemtableSpace - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
Time spent waiting for free memtable space, either on- or off-heap
waitingOnSegmentAllocation - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
Time spent waiting for a CLS to be allocated - under normal conditions this should be zero
waitOnFuture(Future<T>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
waitOnFutures(Iterable<? extends Future<? extends T>>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
waitOnFutures(List<AsyncOneResponse>, long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
WaitQueue - Class in org.apache.cassandra.utils.concurrent
A relatively easy to use utility for general purpose thread signalling.
WaitQueue() - Constructor for class org.apache.cassandra.utils.concurrent.WaitQueue
 
WaitQueue.AbstractSignal - Class in org.apache.cassandra.utils.concurrent
An abstract signal implementation
WaitQueue.Signal - Interface in org.apache.cassandra.utils.concurrent
A Signal is a one-time-use mechanism for a thread to wait for notification that some condition state has transitioned that it may be interested in (and hence should check if it is).
waitUntilListening() - Method in class org.apache.cassandra.net.MessagingService
 
warn(String) - Method in class org.apache.cassandra.hadoop.BulkRecordWriter.NullOutputHandler
Deprecated.
 
warn(String, Throwable) - Method in class org.apache.cassandra.hadoop.BulkRecordWriter.NullOutputHandler
Deprecated.
 
warn(String) - Method in class org.apache.cassandra.service.ClientWarn
 
warn(long, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
 
warn(Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
 
warn(long, String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
warn(String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
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
 
warnIfRunningInDegradedMode() - Method in class org.apache.cassandra.utils.SigarLibrary
 
warnings - Variable in class org.apache.cassandra.transport.Message.Response
 
watch - Variable in class org.apache.cassandra.tracing.TraceState
 
watch(String, Runnable, int) - Static method in class org.apache.cassandra.utils.ResourceWatcher
 
WatchedResource(String, Runnable) - Constructor for class org.apache.cassandra.utils.ResourceWatcher.WatchedResource
 
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.cql3.CqlParser
 
width - Variable in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
wildcard(CFMetaData) - Static method in class org.apache.cassandra.cql3.selection.Selection
 
windows_timer_interval - Variable in class org.apache.cassandra.config.Config
 
WindowsFailedSnapshotTracker - Class in org.apache.cassandra.db
 
WindowsFailedSnapshotTracker() - Constructor for class org.apache.cassandra.db.WindowsFailedSnapshotTracker
 
WindowsTimer - Class in org.apache.cassandra.utils
 
with(ByteBuf) - Method in class org.apache.cassandra.transport.Frame
 
withAlias(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.ColumnSpecification
Returns a new ColumnSpecification for the same column but with the specified alias.
withBufferSizeInMB(int) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
The size of the buffer to use.
WithClauses(ColumnFamilyStore, DataRange, List<IndexExpression>, int, boolean, long) - Constructor for class org.apache.cassandra.db.filter.ExtendedFilter.WithClauses
 
WithCollection(List<AbstractType<?>>, ColumnToCollectionType) - Constructor for class org.apache.cassandra.db.composites.CompoundSparseCellNameType.WithCollection
 
withDefaultTests() - Method in class org.apache.cassandra.service.StartupChecks
 
withEOC(Composite.EOC) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
withEOC(Composite.EOC) - Method in class org.apache.cassandra.db.composites.AbstractComposite
 
withEOC(Composite.EOC) - Method in class org.apache.cassandra.db.composites.BoundedComposite
 
withEOC(Composite.EOC) - Method in interface org.apache.cassandra.db.composites.Composite
 
withEOC(Composite.EOC) - Method in class org.apache.cassandra.db.composites.SimpleComposite
 
withEOC(Composite.EOC) - Method in class org.apache.cassandra.db.composites.SimpleSparseCellName
 
WithFieldSelection(Selectable, ColumnIdentifier) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection
 
withFormatType(SSTableFormat.Type) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
WithFunction(FunctionName, List<Selectable>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithFunction
 
withGeneration(int) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
withNewName(ColumnIdentifier) - Method in class org.apache.cassandra.config.ColumnDefinition
 
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
 
withNewType(AbstractType<?>) - Method in class org.apache.cassandra.config.ColumnDefinition
 
withNonStrictOperator() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
without(UUID) - Method in class org.apache.cassandra.db.Mutation
 
withoutPerStatementVariables(QueryOptions) - Static method in class org.apache.cassandra.cql3.BatchQueryOptions
 
withParameter(String, byte[]) - Method in class org.apache.cassandra.net.MessageOut
 
withPartitioner(IPartitioner) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
The partitioner to use.
withPerStatementVariables(QueryOptions, List<List<ByteBuffer>>, List<Object>) - Static method in class org.apache.cassandra.cql3.BatchQueryOptions
 
withTest(StartupCheck) - Method in class org.apache.cassandra.service.StartupChecks
Add system test to be run before schema is loaded during startup
withUpdatedColumns(SortedSet<CellName>) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
withUpdatedCount(int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
withUpdatedFilter(SliceQueryFilter) - Method in class org.apache.cassandra.db.SliceFromReadCommand
 
withUpdatedLimit(int) - Method in class org.apache.cassandra.db.AbstractRangeCommand
 
withUpdatedLimit(int) - Method in class org.apache.cassandra.db.PagedRangeCommand
 
withUpdatedLimit(int) - Method in class org.apache.cassandra.db.RangeSliceCommand
 
withUpdatedName(CellName) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
withUpdatedName(CellName) - Method in class org.apache.cassandra.db.BufferCell
 
withUpdatedName(CellName) - Method in class org.apache.cassandra.db.BufferCounterCell
 
withUpdatedName(CellName) - Method in class org.apache.cassandra.db.BufferCounterUpdateCell
 
withUpdatedName(CellName) - Method in class org.apache.cassandra.db.BufferDeletedCell
 
withUpdatedName(CellName) - Method in class org.apache.cassandra.db.BufferExpiringCell
 
withUpdatedName(CellName) - Method in interface org.apache.cassandra.db.Cell
 
withUpdatedSlices(ColumnSlice[]) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
withUpdatedStart(Composite, CFMetaData) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
withUpdatedTimestamp(long) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
withUpdatedTimestamp(long) - Method in class org.apache.cassandra.db.BufferCell
 
withUpdatedTimestamp(long) - Method in class org.apache.cassandra.db.BufferDeletedCell
 
withUpdatedTimestamp(long) - Method in class org.apache.cassandra.db.BufferExpiringCell
 
withUpdatedTimestamp(long) - Method in interface org.apache.cassandra.db.Cell
 
withUpdatedTimestampAndLocalDeletionTime(long, int) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
withUpdatedTimestampAndLocalDeletionTime(long, int) - Method in class org.apache.cassandra.db.BufferCell
 
withUpdatedTimestampAndLocalDeletionTime(long, int) - Method in class org.apache.cassandra.db.BufferDeletedCell
 
withUpdatedTimestampAndLocalDeletionTime(long, int) - Method in class org.apache.cassandra.db.BufferExpiringCell
 
withUpdatedTimestampAndLocalDeletionTime(long, int) - Method in interface org.apache.cassandra.db.Cell
 
worthDroppingTombstones(SSTableReader, int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
Check if given sstable is worth dropping tombstones at gcBefore.
wrap(ByteBuffer) - Static method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
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.
wrapped - Variable in class org.apache.cassandra.cql3.BatchQueryOptions
 
WrappedDataOutputStreamPlus - Class in org.apache.cassandra.io.util
When possible use WrappedDataOutputStreamPlus instead of this class, as it will be more efficient when using Plus methods.
WrappedDataOutputStreamPlus(OutputStream) - Constructor for class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
 
WrappedDataOutputStreamPlus(OutputStream, WritableByteChannel) - Constructor for class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
 
WrappedException(Throwable, int) - Constructor for exception org.apache.cassandra.transport.messages.ErrorMessage.WrappedException
 
WrappedRunnable - Class in org.apache.cassandra.utils
 
WrappedRunnable() - Constructor for class org.apache.cassandra.utils.WrappedRunnable
 
WrappedSharedCloseable - Class in org.apache.cassandra.utils.concurrent
An implementation of SharedCloseable that wraps a normal AutoCloseable, ensuring its close method is only called when all instances of SharedCloseable have been
WrappedSharedCloseable(AutoCloseable) - Constructor for class org.apache.cassandra.utils.concurrent.WrappedSharedCloseable
 
WrappedSharedCloseable(AutoCloseable[]) - Constructor for class org.apache.cassandra.utils.concurrent.WrappedSharedCloseable
 
WrappedSharedCloseable(WrappedSharedCloseable) - Constructor for class org.apache.cassandra.utils.concurrent.WrappedSharedCloseable
 
WrappingCompactionStrategy - Class in org.apache.cassandra.db.compaction
 
WrappingCompactionStrategy(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
 
write(long, SequentialWriter) - 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(long, SequentialWriter) - Method in class org.apache.cassandra.db.compaction.LazilyCompactedRow
 
write(ByteBuffer, List<Mutation>) - Method in class org.apache.cassandra.hadoop.BulkRecordWriter
Deprecated.
 
write(DataOutput) - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
write(Object, List<ByteBuffer>) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
The column values must correspond to the order in which they appear in the insert stored procedure.
write(byte[]) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
write(byte[], int, int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
write(ByteBuffer) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
write(int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
write(Memory, long, long) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
write(ByteBuffer) - Method in interface org.apache.cassandra.io.util.DataOutputPlus
 
write(Memory, long, long) - Method in interface org.apache.cassandra.io.util.DataOutputPlus
 
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.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(ByteBuffer) - Method in class org.apache.cassandra.io.util.SequentialWriter
 
write(byte[]) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
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.UnbufferedDataOutputStreamPlus
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.UnbufferedDataOutputStreamPlus
Writes the specified byte oneByte to this RandomAccessFile starting at the current file pointer.
write(ByteBuffer) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
 
write(Memory, long, long) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
 
write(byte[], int, int) - Method in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
 
write(int) - Method in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
 
write(DataOutputStreamPlus) - Method in class org.apache.cassandra.streaming.compress.CompressedStreamWriter
 
write(DataOutputStreamPlus) - Method in class org.apache.cassandra.streaming.StreamWriter
Stream file of specified sections to given channel.
write(RandomAccessReader, DataIntegrityMetadata.ChecksumValidator, int, long, long) - Method in class org.apache.cassandra.streaming.StreamWriter
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(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
 
writeBoolean(boolean) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeBoolean(boolean) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes a boolean to this output stream.
writeByte(int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeByte(int) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes a 8-bit byte to this output stream.
writeBytes(String) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeBytes(String) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes the low order 8-bit bytes from a String to this output stream.
writeBytes(byte[], ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeBytesMap(Map<String, ByteBuffer>, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
WriteCallbackInfo - Class in org.apache.cassandra.net
 
WriteCallbackInfo(InetAddress, IAsyncCallback, MessageOut, IVersionedSerializer<?>, ConsistencyLevel, boolean) - Constructor for class org.apache.cassandra.net.WriteCallbackInfo
 
writeChar(int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeChar(int) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes the specified 16-bit character to the OutputStream.
writeChars(String) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeChars(String) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes the specified 16-bit characters contained in str to the OutputStream.
writeChunkSize(int) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumWriter
 
writeCollectionSize(ByteBuffer, int, int) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
 
writeComponentTo(MessageDigest, int, boolean) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
writeConsistencyLevel(ConsistencyLevel, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeDouble(double) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeDouble(double) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes a 64-bit double to this output stream.
writeEnumValue(T, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
WriteFailureException - Exception in org.apache.cassandra.exceptions
 
WriteFailureException(ConsistencyLevel, int, int, int, WriteType) - Constructor for exception org.apache.cassandra.exceptions.WriteFailureException
 
writeFloat(float) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeFloat(float) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes a 32-bit float to this output stream.
writeFullChecksum(Descriptor) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumWriter
 
writeGlobal(CounterId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
writeHeader(ByteBuffer, CommitLogDescriptor) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
writeHintForMutation(Mutation, long, int, InetAddress) - Static method in class org.apache.cassandra.service.StorageProxy
 
writeInet(InetSocketAddress, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeInt(int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeInt(int) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
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
(Local) write metrics
writeLatency - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
(Local) 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
 
writeLocal(CounterId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
writeLong(long) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeLong(long) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes a 64-bit long to this output stream.
writeLong(long) - Method in class org.apache.cassandra.utils.vint.EncodedDataOutputStream
 
writeLongString(String, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeMemoryTo(MessageDigest, int, int) - Method in class org.apache.cassandra.db.AbstractNativeCell
 
writeOne(Pair<T, Object>, ByteBuf, int) - Method in class org.apache.cassandra.transport.OptionCodec
 
writeOpenedMarkers(Composite, DataOutputPlus, OnDiskAtom.SerializerForWriting) - Method in class org.apache.cassandra.db.RangeTombstone.Tracker
Computes the RangeTombstone that are needed at the beginning of an index block starting with firstColumn.
writeOrder - Variable in class org.apache.cassandra.db.Keyspace
 
Writer(int) - Constructor for class org.apache.cassandra.cache.AutoSavingCache.Writer
 
writer - Variable in class org.apache.cassandra.hadoop.BulkRecordWriter
Deprecated.
 
writer - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
writer - Variable in class org.apache.cassandra.io.util.CompressedSegmentedFile.Builder
 
writeRemote(CounterId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
WriteResponse - Class in org.apache.cassandra.db
 
WriteResponse() - Constructor for class org.apache.cassandra.db.WriteResponse
 
WriteResponse.WriteResponseSerializer - Class in org.apache.cassandra.db
 
WriteResponseHandler<T> - 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, Keyspace, 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
 
WriteResponseSerializer() - Constructor for class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
 
writeRow(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
 
writeRow(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
Deprecated.
 
writeRow(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.io.sstable.SSTableSimpleWriter
Deprecated.
 
writeRow(DecoratedKey, SSTableWriter, DataInput, ColumnFamilyStore) - Method in class org.apache.cassandra.streaming.StreamReader
 
writeShort(int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeShort(int) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes the specified 16-bit short to the OutputStream.
writeShort(int) - Method in class org.apache.cassandra.utils.vint.EncodedDataOutputStream
 
writeShortLength(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
writeString(String, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeStringList(List<String>, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeStringMap(Map<String, String>, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeStringToStringListMap(Map<String, List<String>>, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeSyncMarker(ByteBuffer, int, int, int) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
WritetimeOrTTL(ColumnIdentifier, boolean) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL
 
WriteTimeoutException - Exception in org.apache.cassandra.exceptions
 
WriteTimeoutException(WriteType, ConsistencyLevel, int, int) - Constructor for exception org.apache.cassandra.exceptions.WriteTimeoutException
 
writeTo(DataOutput) - Method in enum org.apache.cassandra.cql3.Operator
Write the serialized version of this Operator to the specified output.
writeTo(DataOutputPlus) - Method in class org.apache.cassandra.db.IndexExpression
Write the serialized version of this IndexExpression to the specified output.
WriteType - Enum in org.apache.cassandra.db
 
writeType - Variable in exception org.apache.cassandra.exceptions.WriteFailureException
 
writeType - Variable in exception org.apache.cassandra.exceptions.WriteTimeoutException
 
writeUnwrittenTombstones(DataOutputPlus, OnDiskAtom.SerializerForWriting) - Method in class org.apache.cassandra.db.RangeTombstone.Tracker
Writes out all tombstones that have been accepted after the previous call of this method.
writeUTF(String) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeUTF(String, DataOutput) - Static method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes the specified String out in UTF format to the provided DataOutput
writeUTF(String) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes the specified String out in UTF format.
writeUUID(UUID, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeValue(ByteBuffer, ByteBuffer, int) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
 
writeValue(byte[], ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeValue(ByteBuffer, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeValue(Object, ByteBuf, int) - Method in enum org.apache.cassandra.transport.DataType
 
writeValue(Object, ByteBuf, int) - Method in interface org.apache.cassandra.transport.OptionCodec.Codecable
 
writeValueList(List<ByteBuffer>, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeWithLength(ByteBuffer, DataOutputPlus) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
writeWithLength(byte[], DataOutput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
writeWithShortLength(ByteBuffer, DataOutputPlus) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
writeWithShortLength(byte[], DataOutput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
writtenAtom() - Method in class org.apache.cassandra.db.RangeTombstone.Tracker
The total number of atoms written by calls to the above methods.
writtenAtomCount() - Method in class org.apache.cassandra.db.ColumnIndex.Builder
 
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.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.cql3.CqlLexer
 
Y - Static variable in class org.apache.cassandra.cql3.CqlParser
 
YamlConfigurationLoader - Class in org.apache.cassandra.config
 
YamlConfigurationLoader() - Constructor for class org.apache.cassandra.config.YamlConfigurationLoader
 

Z

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_URI - Static variable in class org.apache.cassandra.locator.CloudstackSnitch
 
ZONE_NAME_QUERY_URL - Static variable in class org.apache.cassandra.locator.Ec2Snitch
 
ZONE_NAME_QUERY_URL - Static variable in class org.apache.cassandra.locator.GoogleCloudSnitch
 
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 
Skip navigation links

Copyright © 2018 The Apache Software Foundation