- A - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- A - Static variable in class org.apache.cassandra.cql.CqlParser
-
- a - Variable in class org.apache.cassandra.cql.Operation
-
- A - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- A - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- abort() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- abort() - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
-
- abort() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- abort() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
After failure, attempt to close the index writer and data file before deleting all temp components for the sstable
- abort() - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter
-
- abort() - 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
-
- 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.AbstractBulkOutputFormat.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, IPartitioner) - Constructor for class org.apache.cassandra.dht.AbstractBounds
-
- AbstractBounds.AbstractBoundsSerializer - Class in org.apache.cassandra.dht
-
- AbstractBounds.Boundary<T extends RingPosition<T>> - Class in org.apache.cassandra.dht
-
- AbstractBoundsSerializer() - Constructor for class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
-
- AbstractBulkOutputFormat<K,V> - Class in org.apache.cassandra.hadoop
-
- AbstractBulkOutputFormat() - Constructor for class org.apache.cassandra.hadoop.AbstractBulkOutputFormat
-
- AbstractBulkOutputFormat.NullOutputCommitter - Class in org.apache.cassandra.hadoop
-
- AbstractBulkRecordWriter<K,V> - Class in org.apache.cassandra.hadoop
-
- AbstractBulkRecordWriter(TaskAttemptContext) - Constructor for class org.apache.cassandra.hadoop.AbstractBulkRecordWriter
-
- AbstractBulkRecordWriter(Configuration, Progressable) - Constructor for class org.apache.cassandra.hadoop.AbstractBulkRecordWriter
-
- AbstractBulkRecordWriter(Configuration) - Constructor for class org.apache.cassandra.hadoop.AbstractBulkRecordWriter
-
- AbstractBulkRecordWriter.ExternalClient - Class in org.apache.cassandra.hadoop
-
- AbstractBulkRecordWriter.NullOutputHandler - Class in org.apache.cassandra.hadoop
-
- AbstractByteOrderedPartitioner - Class in org.apache.cassandra.dht
-
- AbstractByteOrderedPartitioner() - Constructor for class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- AbstractCassandraStorage - Class in org.apache.cassandra.hadoop.pig
-
A LoadStoreFunc for retrieving data from and storing data to Cassandra
- AbstractCassandraStorage() - Constructor for class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- AbstractCassandraStorage.CfInfo - Class in org.apache.cassandra.hadoop.pig
-
- AbstractCassandraStorage.MarshallerType - Enum in org.apache.cassandra.hadoop.pig
-
- 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
-
- AbstractColumnFamilyOutputFormat<K,Y> - Class in org.apache.cassandra.hadoop
-
The ColumnFamilyOutputFormat
acts as a Hadoop-specific
OutputFormat that allows reduce tasks to store keys (and corresponding
values) as Cassandra rows (and respective columns) in a given
ColumnFamily.
- AbstractColumnFamilyOutputFormat() - Constructor for class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
-
- AbstractColumnFamilyRecordWriter<K,Y> - Class in org.apache.cassandra.hadoop
-
The ColumnFamilyRecordWriter
maps the output <key, value>
pairs to a Cassandra column family.
- AbstractColumnFamilyRecordWriter(Configuration) - Constructor for class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
- AbstractColumnFamilyRecordWriter.AbstractRangeClient<K> - Class in org.apache.cassandra.hadoop
-
A client that runs in a threadpool and connects to the list of endpoints for a particular
range.
- 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>) - 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, Set<SSTableReader>) - 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
-
- AbstractDataOutput - Class in org.apache.cassandra.io.util
-
- AbstractDataOutput() - Constructor for class org.apache.cassandra.io.util.AbstractDataOutput
-
- AbstractEndpointSnitch - Class in org.apache.cassandra.locator
-
- AbstractEndpointSnitch() - Constructor for class org.apache.cassandra.locator.AbstractEndpointSnitch
-
- AbstractFunction - Class in org.apache.cassandra.cql3.functions
-
- AbstractFunction(String, AbstractType<?>, AbstractType<?>...) - Constructor for class org.apache.cassandra.cql3.functions.AbstractFunction
-
- AbstractJmxClient - Class in org.apache.cassandra.tools
-
- AbstractJmxClient(String, Integer, String, String) - Constructor for class org.apache.cassandra.tools.AbstractJmxClient
-
- AbstractMarker - Class in org.apache.cassandra.cql3
-
A single bind marker.
- AbstractMarker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.AbstractMarker
-
- AbstractMarker.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.
- AbstractModification - Class in org.apache.cassandra.cql
-
- AbstractModification(String, String, String, Attributes) - Constructor for class org.apache.cassandra.cql.AbstractModification
-
- AbstractModification(String, String, String, ConsistencyLevel, Long, int) - Constructor for class org.apache.cassandra.cql.AbstractModification
-
- AbstractNativeCell - Class in org.apache.cassandra.db
-
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
-
- AbstractRangeClient(List<InetAddress>) - Constructor for class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
- 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) - 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
-
- AbstractTracingAwareExecutorService - Class in org.apache.cassandra.concurrent
-
- AbstractTracingAwareExecutorService() - Constructor for class org.apache.cassandra.concurrent.AbstractTracingAwareExecutorService
-
- AbstractType<T> - Class in org.apache.cassandra.db.marshal
-
Specifies a Comparator for a specific type of ByteBuffer.
- AbstractType() - Constructor for class org.apache.cassandra.db.marshal.AbstractType
-
- AbstractWriteResponseHandler - Class in org.apache.cassandra.service
-
- AbstractWriteResponseHandler(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
-
- ackCon - Variable in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- ackCount() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- ackCount() - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
-
- ackCount() - Method in class org.apache.cassandra.service.WriteResponseHandler
-
- 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() - Constructor for class org.apache.cassandra.service.ActiveRepairService
-
Protected constructor.
- 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
-
- 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.
- adaptor - Variable in class org.apache.cassandra.cli.CliParser
-
- add(ByteBuffer) - Method in class org.apache.cassandra.cql3.statements.Selection.ResultSetBuilder
-
- add(Cell) - Method in class org.apache.cassandra.cql3.statements.Selection.ResultSetBuilder
-
- add(Term, boolean) - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Contains
-
- 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(InetAddress) - Method in class org.apache.cassandra.repair.DatacenterAwareRequestCoordinator
-
- add(R) - Method in interface org.apache.cassandra.repair.IRequestCoordinator
-
- add(R) - Method in class org.apache.cassandra.repair.ParallelRequestCoordinator
-
- add(R) - Method in class org.apache.cassandra.repair.SequentialRequestCoordinator
-
- add(AbstractCompactedRow) - Method in class org.apache.cassandra.repair.Validator
-
Called (in order) for every row present in the CF.
- add(IMessageSink) - Static method in class org.apache.cassandra.sink.SinkManager
-
- add(IRequestSink) - Static method in class org.apache.cassandra.sink.SinkManager
-
- add(ByteBuffer, ColumnParent, CounterColumn, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- add(ByteBuffer) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- add(ByteBuffer) - Method in class org.apache.cassandra.utils.BloomFilter
-
- add(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- 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(ByteBuffer) - Method in interface org.apache.cassandra.utils.IFilter
-
- 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
-
- 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
-
- 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(Term, String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
Map a column name to a validator for its value
- 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
-
- 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
-
- addColumnFamily() - Method in class org.apache.cassandra.cli.CliParser
-
- addColumnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.addColumnFamily_return
-
- addColumnForOrdering(ColumnDefinition) - Method in class org.apache.cassandra.cql3.statements.Selection
-
- addColumnMetadataFromAliases(List<ByteBuffer>, AbstractType<?>, ColumnDefinition.Kind) - Method in class org.apache.cassandra.config.CFMetaData
-
- 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
-
- added - Variable in class org.apache.cassandra.notifications.SSTableAddedNotification
-
- added - Variable in class org.apache.cassandra.notifications.SSTableListChangedNotification
-
- 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).
- addFalsePositive() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- addHash(MerkleTree.RowHash) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
-
- addIndexedColumn(ColumnDefinition) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Adds and builds a index for a column
- addInitialSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
-
- 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(Term) - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Contains
-
- 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() - Method in class org.apache.cassandra.cli.CliParser
-
- addKeyspace_return() - Constructor for class org.apache.cassandra.cli.CliParser.addKeyspace_return
-
- 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.statements.SelectionColumnMapping
-
- addMapping(ColumnSpecification, Iterable<ColumnDefinition>) - Method in class org.apache.cassandra.cql3.statements.SelectionColumnMapping
-
- 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.Metadata
-
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
- 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
-
- 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
-
- addPostPreparationHook(PostPreparationHook) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- 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.
- addPreExecutionHook(PreExecutionHook) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- addProperty(String, String) - Method in class org.apache.cassandra.cql.CFPropDefs
-
Map a keyword to the corresponding value
- addProperty(String, String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
Map a keyword to the corresponding value
- addProperty(String, String) - Method in class org.apache.cassandra.cql3.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
-
- addRawUpdate(List<Pair<ColumnIdentifier.Raw, Operation.RawUpdate>>, ColumnIdentifier.Raw, Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.CqlParser
-
- 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(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
-
- addStreamRequest(String, Collection<Range<Token>>, Collection<String>, long) - Method in class org.apache.cassandra.streaming.StreamSession
-
Request data fetch task to this session.
- addTask(AbstractTracingAwareExecutorService.FutureTask<?>) - Method in class org.apache.cassandra.concurrent.AbstractTracingAwareExecutorService
-
- addTask(AbstractTracingAwareExecutorService.FutureTask<?>) - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- addToActiveSessions(RepairSession) - Method in class org.apache.cassandra.service.ActiveRepairService
-
- 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
- addTree(InetAddress, MerkleTree) - Method in class org.apache.cassandra.repair.RepairJob
-
Add a new received tree and return the number of remaining tree to
be received for the job to be complete.
- 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.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
-
- addValue(Term) - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Contains
-
- 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
-
- algorithm - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- alias - Variable in class org.apache.cassandra.cql3.statements.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 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(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
-
- ALL_DATA - Static variable in enum org.apache.cassandra.auth.Permission
-
- 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
-
- 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(long) - Method in interface org.apache.cassandra.io.util.IAllocator
-
- allocate(long) - Method in class org.apache.cassandra.io.util.JEMallocAllocator
-
- allocate(long) - Static method in class org.apache.cassandra.io.util.Memory
-
- allocate(long) - Method in class org.apache.cassandra.io.util.NativeAllocator
-
- 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, 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
-
- 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
-
- allowedKeywords - Static variable in class org.apache.cassandra.cql.CFPropDefs
-
- allowFiltering - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
-
- allowSimultaneousMoves - Static variable in class org.apache.cassandra.dht.RangeStreamer
-
- allPriorOpsAreFinished() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
-
- allSchemaCfs - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- allTypes() - Method in class org.apache.cassandra.db.marshal.TupleType
-
- Alnum - Static variable in class org.apache.cassandra.cli.CliLexer
-
- Alnum - Static variable in class org.apache.cassandra.cli.CliParser
-
- AlreadyExistsException - Exception in org.apache.cassandra.exceptions
-
- AlreadyExistsException(String, String) - Constructor for exception org.apache.cassandra.exceptions.AlreadyExistsException
-
- AlreadyExistsException(String) - Constructor for exception org.apache.cassandra.exceptions.AlreadyExistsException
-
- alter(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- alter(String, Map<IAuthenticator.Option, Object>) - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Called during execution of ALTER USER query.
- alter(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- alter(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- alter(UTName, ColumnIdentifier, CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
-
- alterableOptions() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- alterableOptions() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Subset of supportedOptions that users are allowed to alter when performing ALTER USER [themselves].
- alterableOptions() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- alterableOptions() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- alterKeyspaceStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- AlterKeyspaceStatement - Class in org.apache.cassandra.cql3.statements
-
- AlterKeyspaceStatement(String, KSPropDefs) - Constructor for class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
-
- AlterTableStatement - Class in org.apache.cassandra.cql
-
- AlterTableStatement(String, AlterTableStatement.OperationType, String) - Constructor for class org.apache.cassandra.cql.AlterTableStatement
-
- AlterTableStatement(String, AlterTableStatement.OperationType, String, String) - Constructor for class org.apache.cassandra.cql.AlterTableStatement
-
- AlterTableStatement(String, AlterTableStatement.OperationType, String, String, Map<String, String>) - Constructor for class org.apache.cassandra.cql.AlterTableStatement
-
- alterTableStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- alterTableStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- AlterTableStatement - Class in org.apache.cassandra.cql3.statements
-
- AlterTableStatement(CFName, AlterTableStatement.Type, ColumnIdentifier.Raw, CQL3Type.Raw, CFPropDefs, Map<ColumnIdentifier.Raw, ColumnIdentifier.Raw>, boolean) - Constructor for class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- AlterTableStatement.OperationType - Enum in org.apache.cassandra.cql
-
- AlterTableStatement.Type - Enum in org.apache.cassandra.cql3.statements
-
- 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
-
- AlterUserStatement - Class in org.apache.cassandra.cql3.statements
-
- AlterUserStatement(String, UserOptions, Boolean) - Constructor for class org.apache.cassandra.cql3.statements.AlterUserStatement
-
- 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 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- AND - Static variable in class org.apache.cassandra.cli.CliParser
-
- and(Term) - Method in class org.apache.cassandra.cql.SelectExpression
-
Add an additional column name to a SelectExpression.
- and(Relation) - Method in class org.apache.cassandra.cql.WhereClause
-
Add an additional relation to this WHERE clause.
- and(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- andKeyEquals(Term) - Method in class org.apache.cassandra.cql.WhereClause
-
The same as KEY = to avoid using Relation object
- announceColumnFamilyDrop(String, String) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceColumnFamilyDrop(String, String, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceColumnFamilyUpdate(CFMetaData, boolean) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceColumnFamilyUpdate(CFMetaData, boolean, 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.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.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.
- announceNewColumnFamily(CFMetaData) - Static method in class org.apache.cassandra.service.MigrationManager
-
- announceNewColumnFamily(CFMetaData, 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) - 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) - 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) - 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, boolean) - Constructor for class org.apache.cassandra.repair.AnticompactionTask
-
- AnticompactionTask.AnticompactionCallback - Class in org.apache.cassandra.repair
-
Callback for antitcompaction request.
- ANTLRNoCaseStringStream(String) - Constructor for class org.apache.cassandra.cli.CliCompiler.ANTLRNoCaseStringStream
-
- any(WaitQueue.Signal...) - Static method in class org.apache.cassandra.utils.concurrent.WaitQueue
-
- API_VERSION - Static variable in class org.apache.cassandra.cli.CliLexer
-
- API_VERSION - Static variable in class org.apache.cassandra.cli.CliParser
-
- append(AbstractCompactedRow) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- append(AbstractCompactedRow) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- append(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- append(byte[], int, int, 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, Descriptor.Version) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- appendTOC(Descriptor, Collection<Component>) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
Appends new component names to the TOC component.
- 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(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.SSTableReader.Operator
-
- apply(IMutation, Iterable<InetAddress>, AbstractWriteResponseHandler, 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
-
- 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
-
- applyPropertiesToCFMetadata(CFMetaData, CFPropDefs) - Static method in class org.apache.cassandra.cql.AlterTableStatement
-
- applyStateTransition(Message.Type, Message.Type) - Method in class org.apache.cassandra.transport.ServerConnection
-
- applyToCFMetadata(CFMetaData) - Method in class org.apache.cassandra.cql3.statements.CFPropDefs
-
- 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
-
- areAllNodesAtLeast21() - Method in class org.apache.cassandra.net.MessagingService
-
- args - Variable in class org.apache.cassandra.cql3.statements.Selectable.WithFunction
-
- Args() - Constructor for class org.apache.cassandra.thrift.TServerFactory.Args
-
- argsType - Variable in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- argsType() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- argsType() - Method in interface org.apache.cassandra.cql3.functions.Function
-
- ARRAY - Static variable in class org.apache.cassandra.cli.CliLexer
-
- ARRAY - Static variable in class org.apache.cassandra.cli.CliParser
-
- ArrayBackedSortedColumns - Class in org.apache.cassandra.db
-
A ColumnFamily backed by an array.
- ArrayBackedSortedColumns(CFMetaData, boolean) - Constructor for class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- arrayConstruct() - Method in class org.apache.cassandra.cli.CliParser
-
- arrayConstruct_return() - Constructor for class org.apache.cassandra.cli.CliParser.arrayConstruct_return
-
- 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/cql2 sake.
- asAbstractType() - Method in class org.apache.cassandra.db.composites.SimpleCType
-
- asByteBuffer() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
- 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.CollectionType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.DateType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.FloatType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.InetAddressType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.Int32Type
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.IntegerType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.LongType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.ReversedType
-
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.TimestampType
-
- 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
-
- asFailed() - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
- asIFilter(SlicePredicate, CFMetaData, ByteBuffer) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- 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
-
- AssignementTestable - Interface in org.apache.cassandra.cql3
-
- ASSUME - Static variable in class org.apache.cassandra.cli.CliLexer
-
- ASSUME - Static variable in class org.apache.cassandra.cli.CliParser
-
- assumeStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- assumeStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.assumeStatement_return
-
- 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
-
- 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, Descriptor.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(Connection) - Method in class org.apache.cassandra.transport.Message
-
- attempted - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
-
- attr_name() - Method in class org.apache.cassandra.cli.CliParser
-
- attr_name_return() - Constructor for class org.apache.cassandra.cli.CliParser.attr_name_return
-
- Attributes - Class in org.apache.cassandra.cql
-
Class to contain attributes for statements
- Attributes() - Constructor for class org.apache.cassandra.cql.Attributes
-
- Attributes(ConsistencyLevel, Long, int) - Constructor for class org.apache.cassandra.cql.Attributes
-
- Attributes - Class in org.apache.cassandra.cql3
-
Utility class for the Parser to gather attributes for modification
statements.
- Attributes.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
-
- attrValue() - Method in class org.apache.cassandra.cli.CliParser
-
- attrValue_return() - Constructor for class org.apache.cassandra.cli.CliParser.attrValue_return
-
- attrValueDouble() - Method in class org.apache.cassandra.cli.CliParser
-
- attrValueDouble_return() - Constructor for class org.apache.cassandra.cli.CliParser.attrValueDouble_return
-
- attrValueInt() - Method in class org.apache.cassandra.cli.CliParser
-
- attrValueInt_return() - Constructor for class org.apache.cassandra.cli.CliParser.attrValueInt_return
-
- attrValueString() - Method in class org.apache.cassandra.cli.CliParser
-
- attrValueString_return() - Constructor for class org.apache.cassandra.cli.CliParser.attrValueString_return
-
- augment(ByteBuffer, ColumnFamily) - Method in interface org.apache.cassandra.triggers.ITrigger
-
Called exactly once per CF update, returned mutations are atomically updated.
- Auth - Class in org.apache.cassandra.auth
-
- Auth() - Constructor for class org.apache.cassandra.auth.Auth
-
- Auth.AuthMigrationListener - Class in org.apache.cassandra.auth
-
MigrationListener implementation that cleans up permissions on dropped resources.
- AUTH_KS - Static variable in class org.apache.cassandra.auth.Auth
-
- 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(Map<String, String>) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- authenticate(InetAddress, int) - Method in class org.apache.cassandra.auth.AllowAllInternodeAuthenticator
-
- authenticate(Map<String, String>) - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Authenticates a user given a Map of credentials.
- authenticate(InetAddress, int) - Method in interface org.apache.cassandra.auth.IInternodeAuthenticator
-
Decides whether or not a peer is allowed to connect to this node.
- authenticate(Map<String, String>) - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- authenticate(Map<String, String>) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- AuthenticatedUser - Class in org.apache.cassandra.auth
-
Returned from IAuthenticator#authenticate(), represents an authenticated user everywhere internally.
- AuthenticatedUser(String) - Constructor for class org.apache.cassandra.auth.AuthenticatedUser
-
- AuthenticateMessage - Class in org.apache.cassandra.transport.messages
-
Message to indicate that the server is ready to receive requests.
- AuthenticateMessage(String) - Constructor for class org.apache.cassandra.transport.messages.AuthenticateMessage
-
- AuthenticationException - Exception in org.apache.cassandra.exceptions
-
- AuthenticationException(String) - Constructor for exception org.apache.cassandra.exceptions.AuthenticationException
-
- AuthenticationStatement - Class in org.apache.cassandra.cql3.statements
-
- AuthenticationStatement() - Constructor for class org.apache.cassandra.cql3.statements.AuthenticationStatement
-
- authenticator - Variable in class org.apache.cassandra.config.Config
-
- authenticator - Variable in class org.apache.cassandra.transport.messages.AuthenticateMessage
-
- AuthMigrationListener() - Constructor for class org.apache.cassandra.auth.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
-
The primary IAuthorizer method.
- authorize(AuthenticatedUser, List<Object>) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- authorize(AuthenticatedUser, IResource) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
Translates new-style authorize() method call to the old-style (including permissions and the hierarchy).
- authorizer - Variable in class org.apache.cassandra.config.Config
-
- 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
-
- aVeryLongTime - Static variable in class org.apache.cassandra.gms.Gossiper
-
- 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.
- 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.
- C - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- C - Static variable in class org.apache.cassandra.cql.CqlParser
-
- C - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- C - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- CACHE_FLUSH_INTERVAL_IN_BYTES - Static variable in class org.apache.cassandra.io.util.RandomAccessReader
-
- 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.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.
- 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
-
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
calculate the natural endpoints for the given token
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.LocalStrategy
-
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
calculate endpoints in one pass through the tokens by tracking our progress in each DC, rack etc.
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
-
- calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.SimpleStrategy
-
- calculatePendingRanges(AbstractReplicationStrategy, String) - Static method in class org.apache.cassandra.service.PendingRangeCalculatorService
-
Calculate pending ranges according to bootsrapping and leaving nodes.
- calculateSamplingLevel(int, int, long, int, int) - Static method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
- 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<?>) - Constructor for class org.apache.cassandra.net.CallbackInfo
-
- CallbackInfo(InetAddress, IAsyncCallback, IVersionedSerializer<?>, boolean) - Constructor for class org.apache.cassandra.net.CallbackInfo
-
Create CallbackInfo without sent message
- 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
-
- canEvaluateWithSlices() - Method in interface org.apache.cassandra.cql3.statements.Restriction
-
Returns true if, when applied to a clustering column, this restriction can be handled through one or more slices
alone without filtering.
- canEvaluateWithSlices() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Contains
-
- canEvaluateWithSlices() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.EQ
-
- canEvaluateWithSlices() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithMarker
-
- canEvaluateWithSlices() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithValues
-
- canEvaluateWithSlices() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Slice
-
- canHandleIndexClause(List<IndexExpression>) - Method in class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- canHaveOnlyOneValue() - Method in interface org.apache.cassandra.cql3.statements.Restriction.IN
-
- canHaveOnlyOneValue() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithMarker
-
- canHaveOnlyOneValue() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithValues
-
- 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)
- 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
-
- CassandraAuthorizer - Class in org.apache.cassandra.auth
-
CassandraAuthorizer is an IAuthorizer implementation that keeps
permissions internally in C* - in system_auth.permissions CQL3 table.
- CassandraAuthorizer() - Constructor for class org.apache.cassandra.auth.CassandraAuthorizer
-
- CassandraDaemon - Class in org.apache.cassandra.service
-
- CassandraDaemon() - Constructor for class org.apache.cassandra.service.CassandraDaemon
-
- CassandraDaemon.Server - Interface in org.apache.cassandra.service
-
- CassandraException - Exception in org.apache.cassandra.exceptions
-
- CassandraException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.CassandraException
-
- CassandraException(ExceptionCode, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.CassandraException
-
- CassandraServer - Class in org.apache.cassandra.thrift
-
- CassandraServer() - Constructor for class org.apache.cassandra.thrift.CassandraServer
-
- CassandraStorage - Class in org.apache.cassandra.hadoop.pig
-
A LoadStoreFunc for retrieving data from and storing data to Cassandra
A row from a standard CF will be returned as nested tuples: (key, ((name1, val1), (name2, val2))).
- CassandraStorage() - Constructor for class org.apache.cassandra.hadoop.pig.CassandraStorage
-
- CassandraStorage(int) - Constructor for class org.apache.cassandra.hadoop.pig.CassandraStorage
-
- cassandraToObj(AbstractType, ByteBuffer) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- cassandraTriggerDir() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- 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.AbstractCassandraStorage
-
convert string back to CfDef
- cfdefToString(CfDef) - Static method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
convert CfDef to string
- CfHistograms() - Constructor for class org.apache.cassandra.tools.NodeTool.CfHistograms
-
- 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
-
- 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
-
- CfInfo() - Constructor for class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage.CfInfo
-
- 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.cql
-
- CFPropDefs() - Constructor for class org.apache.cassandra.cql.CFPropDefs
-
- 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
-
- 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.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() - Constructor for class org.apache.cassandra.tools.NodeTool.CfStats
-
- cfstore - Variable in class org.apache.cassandra.db.DataTracker
-
- cfType - Variable in class org.apache.cassandra.config.CFMetaData
-
- chain(IResource) - Static method in class org.apache.cassandra.auth.Resources
-
Construct a chain of resource parents starting with the resource and ending with the root.
- change - Variable in class org.apache.cassandra.transport.Event.SchemaChange
-
- change - Variable in class org.apache.cassandra.transport.Event.TopologyChange
-
- change - Variable in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- 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.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.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 - Variable in class org.apache.cassandra.io.util.RandomAccessReader
-
- channel() - Method in class org.apache.cassandra.transport.Connection
-
- channel - Variable in class org.apache.cassandra.transport.SimpleClient
-
- channelRead0(ChannelHandlerContext, Message.Request) - Method in class org.apache.cassandra.transport.Message.Dispatcher
-
- CHAR_MASK - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- CharacterEscapeSequence - Static variable in class org.apache.cassandra.cli.CliLexer
-
- CharacterEscapeSequence - Static variable in class org.apache.cassandra.cli.CliParser
-
- checkAccess(ClientState) - Method in interface org.apache.cassandra.cql3.CQLStatement
-
Perform any access verification necessary for the statement.
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterKeyspaceStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterUserStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateIndexStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateKeyspaceStatement
-
- 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.CreateUserStatement
-
- 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.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.DropUserStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListUsersStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.PermissionAlteringStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
-
- checkAccess(ClientState) - Method in class org.apache.cassandra.cql3.statements.UseStatement
-
- checkAndClear() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
-
atomically: cancels the Signal if !isSet(), or returns true if isSignalled()
- checkAvailableDiskSpace(long) - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- checkBounds(long, long) - Method in class org.apache.cassandra.io.util.Memory
-
- checkBounds(long, long) - Method in class org.apache.cassandra.io.util.SafeMemory
-
- 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.
- checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.AbstractBulkOutputFormat
-
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.AbstractBulkOutputFormat
-
Deprecated.
- checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
-
Check for validity of the output-specification for the job.
- checkOutputSpecs(Configuration) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
-
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
-
Deprecated.
- checkRemaining(ByteBuffer, int, int) - Static method in class org.apache.cassandra.db.composites.AbstractCType
-
- checkSchema(ResourceSchema) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- ChecksummedSequentialWriter - Class in org.apache.cassandra.io.util
-
- ChecksummedSequentialWriter(File, int, File) - Constructor for class org.apache.cassandra.io.util.ChecksummedSequentialWriter
-
- checksumValidator(Descriptor) - Static method in class org.apache.cassandra.io.util.DataIntegrityMetadata
-
- ChecksumValidator(Descriptor) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- ChecksumWriter(DataOutput) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumWriter
-
- 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
-
- 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_name - Variable in class org.apache.cassandra.config.SeedProviderDef
-
- classForName(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- classOption - Variable in class org.apache.cassandra.config.TriggerDefinition
-
- clean(MappedByteBuffer) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- cleanThreshold - Variable in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
-
- Cleanup(String, CompressionMetadata) - Constructor for class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile.Cleanup
-
- Cleanup(String) - Constructor for class org.apache.cassandra.io.util.PoolingSegmentedFile.Cleanup
-
- Cleanup(String) - Constructor for class org.apache.cassandra.io.util.SegmentedFile.Cleanup
-
- cleanup() - Method in class org.apache.cassandra.streaming.StreamLockfile
-
- 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.AbstractBulkOutputFormat.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.AbstractCassandraStorage
-
- cleanupOnSuccess(String, Job) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- clear() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- clear() - Method in interface org.apache.cassandra.cache.ICache
-
- clear() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- clear() - Method in class org.apache.cassandra.cache.SerializingCache
-
- clear() - Method in class org.apache.cassandra.config.Schema
-
Clear all KS/CF metadata and reset version.
- clear() - Method in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- clear() - Method in class org.apache.cassandra.db.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() - Static method in class org.apache.cassandra.sink.SinkManager
-
- 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
-
- 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
-
- clearKeyspaceDefinition(KSMetaData) - Method in class org.apache.cassandra.config.Schema
-
Remove keyspace definition from system
- 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() - 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
- cLevel - Variable in class org.apache.cassandra.cql.AbstractModification
-
- CLibrary - Class in org.apache.cassandra.utils
-
- CliClient - Class in org.apache.cassandra.cli
-
- CliClient(CliSessionState, Cassandra.Client) - Constructor for class org.apache.cassandra.cli.CliClient
-
- CliClient.ColumnFamilyArgument - Enum in org.apache.cassandra.cli
-
- CliClient.Function - Enum in org.apache.cassandra.cli
-
Available value conversion functions
Used by convertValueByFunction(Tree functionCall) method
- CliCommandHelp - Class in org.apache.cassandra.cli
-
- CliCommandHelp() - Constructor for class org.apache.cassandra.cli.CliCommandHelp
-
- CliCompiler - Class in org.apache.cassandra.cli
-
- CliCompiler() - Constructor for class org.apache.cassandra.cli.CliCompiler
-
- CliCompiler.ANTLRNoCaseStringStream - Class in org.apache.cassandra.cli
-
- CliCompleter - Class in org.apache.cassandra.cli
-
- CliCompleter() - Constructor for class org.apache.cassandra.cli.CliCompleter
-
- client - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
- Client() - Constructor for class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
- Client - Class in org.apache.cassandra.transport
-
- Client(String, int, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.Client
-
- client_encryption_options - Variable in class org.apache.cassandra.config.Config
-
- 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 - Variable in class org.apache.cassandra.cql.hooks.ExecutionContext
-
- clientState - Variable in class org.apache.cassandra.cql.hooks.PreparationContext
-
- ClientState - Class in org.apache.cassandra.service
-
State related to a client connection.
- ClientState(SocketAddress) - Constructor for class org.apache.cassandra.service.ClientState
-
- CliLexer - Class in org.apache.cassandra.cli
-
- CliLexer() - Constructor for class org.apache.cassandra.cli.CliLexer
-
- CliLexer(CharStream) - Constructor for class org.apache.cassandra.cli.CliLexer
-
- CliLexer(CharStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cli.CliLexer
-
- CliLexer.DFA15 - Class in org.apache.cassandra.cli
-
- CliMain - Class in org.apache.cassandra.cli
-
Cassandra Command Line Interface (CLI) Main
- CliMain() - Constructor for class org.apache.cassandra.cli.CliMain
-
- CliOptions - Class in org.apache.cassandra.cli
-
Used to process, and act upon the arguments passed to the CLI.
- CliOptions() - Constructor for class org.apache.cassandra.cli.CliOptions
-
- CliParser - Class in org.apache.cassandra.cli
-
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
- CliParser(TokenStream) - Constructor for class org.apache.cassandra.cli.CliParser
-
- CliParser(TokenStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cli.CliParser
-
- CliParser.addColumnFamily_return - Class in org.apache.cassandra.cli
-
- CliParser.addKeyspace_return - Class in org.apache.cassandra.cli
-
- CliParser.arrayConstruct_return - Class in org.apache.cassandra.cli
-
- CliParser.assumeStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.attr_name_return - Class in org.apache.cassandra.cli
-
- CliParser.attrValue_return - Class in org.apache.cassandra.cli
-
- CliParser.attrValueDouble_return - Class in org.apache.cassandra.cli
-
- CliParser.attrValueInt_return - Class in org.apache.cassandra.cli
-
- CliParser.attrValueString_return - Class in org.apache.cassandra.cli
-
- CliParser.columnFamily_return - Class in org.apache.cassandra.cli
-
- CliParser.columnFamilyExpr_return - Class in org.apache.cassandra.cli
-
- CliParser.columnLimitExpr_return - Class in org.apache.cassandra.cli
-
- CliParser.columnName_return - Class in org.apache.cassandra.cli
-
- CliParser.columnOrSuperColumn_return - Class in org.apache.cassandra.cli
-
- CliParser.command_return - Class in org.apache.cassandra.cli
-
- CliParser.comparator_return - Class in org.apache.cassandra.cli
-
- CliParser.connectStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.consistencyLevelStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.countStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.delColumnFamily_return - Class in org.apache.cassandra.cli
-
- CliParser.delKeyspace_return - Class in org.apache.cassandra.cli
-
- CliParser.delStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.describeCluster_return - Class in org.apache.cassandra.cli
-
- CliParser.describeTable_return - Class in org.apache.cassandra.cli
-
- CliParser.dropIndex_return - Class in org.apache.cassandra.cli
-
- CliParser.entityName_return - Class in org.apache.cassandra.cli
-
- CliParser.exitStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.functionArgument_return - Class in org.apache.cassandra.cli
-
- CliParser.functionCall_return - Class in org.apache.cassandra.cli
-
- CliParser.getCondition_return - Class in org.apache.cassandra.cli
-
- CliParser.getStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.hashConstruct_return - Class in org.apache.cassandra.cli
-
- CliParser.hashElementPair_return - Class in org.apache.cassandra.cli
-
- CliParser.helpStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.host_name_return - Class in org.apache.cassandra.cli
-
- CliParser.host_return - Class in org.apache.cassandra.cli
-
- CliParser.incrementValue_return - Class in org.apache.cassandra.cli
-
- CliParser.incrStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.ip_address_return - Class in org.apache.cassandra.cli
-
- CliParser.keyRangeExpr_return - Class in org.apache.cassandra.cli
-
- CliParser.keyspace_return - Class in org.apache.cassandra.cli
-
- CliParser.keyspaceNewName_return - Class in org.apache.cassandra.cli
-
- CliParser.keyValuePair_return - Class in org.apache.cassandra.cli
-
- CliParser.keyValuePairExpr_return - Class in org.apache.cassandra.cli
-
- CliParser.listStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.newColumnFamily_return - Class in org.apache.cassandra.cli
-
- CliParser.operator_return - Class in org.apache.cassandra.cli
-
- CliParser.password_return - Class in org.apache.cassandra.cli
-
- CliParser.port_return - Class in org.apache.cassandra.cli
-
- CliParser.replica_placement_strategy_return - Class in org.apache.cassandra.cli
-
- CliParser.reversedExpr_return - Class in org.apache.cassandra.cli
-
- CliParser.root_return - Class in org.apache.cassandra.cli
-
- CliParser.rowKey_return - Class in org.apache.cassandra.cli
-
- CliParser.rowLimitExpr_return - Class in org.apache.cassandra.cli
-
- CliParser.rowValue_return - Class in org.apache.cassandra.cli
-
- CliParser.setStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.setTraceProbability_return - Class in org.apache.cassandra.cli
-
- CliParser.showClusterName_return - Class in org.apache.cassandra.cli
-
- CliParser.showKeyspaces_return - Class in org.apache.cassandra.cli
-
- CliParser.showSchema_return - Class in org.apache.cassandra.cli
-
- CliParser.showStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.showVersion_return - Class in org.apache.cassandra.cli
-
- CliParser.statement_return - Class in org.apache.cassandra.cli
-
- CliParser.traceNextQuery_return - Class in org.apache.cassandra.cli
-
- CliParser.traceSessionId_return - Class in org.apache.cassandra.cli
-
- CliParser.tracingProbability_return - Class in org.apache.cassandra.cli
-
- CliParser.truncateStatement_return - Class in org.apache.cassandra.cli
-
- CliParser.typeIdentifier_return - Class in org.apache.cassandra.cli
-
- CliParser.updateColumnFamily_return - Class in org.apache.cassandra.cli
-
- CliParser.updateKeyspace_return - Class in org.apache.cassandra.cli
-
- CliParser.useKeyspace_return - Class in org.apache.cassandra.cli
-
- CliParser.username_return - Class in org.apache.cassandra.cli
-
- CliParser.value_return - Class in org.apache.cassandra.cli
-
- CliSessionState - Class in org.apache.cassandra.cli
-
Used to hold the state for the CLI.
- CliSessionState() - Constructor for class org.apache.cassandra.cli.CliSessionState
-
- CliUserHelp - Class in org.apache.cassandra.cli
-
- CliUserHelp() - Constructor for class org.apache.cassandra.cli.CliUserHelp
-
- CliUtils - Class in org.apache.cassandra.cli
-
- CliUtils() - Constructor for class org.apache.cassandra.cli.CliUtils
-
- 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.
- cloneAsShadowed(Runnable) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- 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(KSMetaData, Iterable<CFMetaData>) - Static 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.SSTableReader
-
- cloneWithNewSummarySamplingLevel(ColumnFamilyStore, int) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Returns a new SSTableReader with the same properties as this SSTableReader except that a new IndexSummary will
be built at the target samplingLevel.
- 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.columniterator.SSTableNamesIterator
-
- close() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
- 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(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.AbstractBulkRecordWriter
-
- close(Reporter) - Method in class org.apache.cassandra.hadoop.AbstractBulkRecordWriter
-
Deprecated.
- close() - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
- close(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
Close this RecordWriter
to future operations, but not before
flushing out the batched mutations.
- close(Reporter) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
Deprecated.
- close() - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
- close() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- close() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- close() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
-
- close() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
-
- close(long, int) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
-
- close() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
Close this writer.
- close() - 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.SSTableScanner
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.EmptySSTableScanner
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
- close() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- close() - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter
-
- close() - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- close() - Method in class org.apache.cassandra.io.util.DataOutputStreamPlus
-
- close() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Closes this stream and frees resources associated with this stream.
- close() - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Closes this stream.
- close(Closeable...) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- close(Iterable<? extends Closeable>) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- close() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- close() - Method in class org.apache.cassandra.io.util.Memory
-
- close() - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- close() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- close() - Method in class org.apache.cassandra.io.util.SafeMemory
-
- close() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
-
- close() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- 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() - 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() - Method in class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
-
- 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
-
- CloseableIterator<T> - Interface in org.apache.cassandra.utils
-
- closeableIterator(Iterator<T>) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- closeAll() - Method in interface org.apache.cassandra.transport.Connection.Tracker
-
- closeAll() - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
-
- closeAndOpenReader() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- closeAndOpenReader(long) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- closeIncoming() - Method in class org.apache.cassandra.streaming.ConnectionHandler
-
- closeInternal() - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
- 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
-- 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
-
- 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
-
- cmdCon - Variable in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- 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.Metadata
-
- codec - Static variable in enum org.apache.cassandra.transport.DataType
-
- codec - Variable in enum org.apache.cassandra.transport.Message.Type
-
- codec - Static variable in class org.apache.cassandra.transport.messages.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
-
- COLD_READS_TO_OMIT_KEY - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
-
Deprecated.
- 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 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- COLUMN - Static variable in class org.apache.cassandra.cli.CliParser
-
- 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.AbstractCassandraStorage
-
- 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.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.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 - Variable in class org.apache.cassandra.streaming.StreamRequest
-
- columnFamily(String, String) - Static method in class org.apache.cassandra.auth.DataResource
-
Creates a DataResource instance representing a column family.
- columnFamily() - Method in class org.apache.cassandra.cli.CliParser
-
- columnFamily - Variable in class org.apache.cassandra.cql.AbstractModification
-
- columnFamily - Variable in class org.apache.cassandra.cql.AlterTableStatement
-
- columnFamily() - Method in class org.apache.cassandra.cql3.statements.CFStatement
-
- columnFamily() - Method in class org.apache.cassandra.cql3.statements.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
-
- columnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnFamily_return
-
- columnFamilyExpr() - Method in class org.apache.cassandra.cli.CliParser
-
- columnFamilyExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnFamilyExpr_return
-
- ColumnFamilyInputFormat - Class in org.apache.cassandra.hadoop
-
Hadoop InputFormat allowing map/reduce against Cassandra rows within one ColumnFamily.
- ColumnFamilyInputFormat() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
-
- ColumnFamilyMetrics - Class in org.apache.cassandra.metrics
-
- ColumnFamilyMetrics(ColumnFamilyStore) - Constructor for class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
- 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
-
The ColumnFamilyOutputFormat
acts as a Hadoop-specific
OutputFormat that allows reduce tasks to store keys (and corresponding
values) as Cassandra rows (and respective columns) in a given
ColumnFamily.
- ColumnFamilyOutputFormat() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
-
- ColumnFamilyRecordReader - Class in org.apache.cassandra.hadoop
-
- ColumnFamilyRecordReader() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- ColumnFamilyRecordReader(int) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- ColumnFamilySerializer - Class in org.apache.cassandra.db
-
- ColumnFamilySerializer() - Constructor for class org.apache.cassandra.db.ColumnFamilySerializer
-
- ColumnFamilySplit - Class in org.apache.cassandra.hadoop
-
- ColumnFamilySplit(String, String, String[]) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
-
Deprecated.
- ColumnFamilySplit(String, String, long, String[]) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- ColumnFamilySplit() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- ColumnFamilyStore - Class in org.apache.cassandra.db
-
- ColumnFamilyStore.AbstractScanIterator - Class in org.apache.cassandra.db
-
- ColumnFamilyStore.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
- columnFamilyStores - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
- 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.
- columnLimitExpr() - Method in class org.apache.cassandra.cli.CliParser
-
- columnLimitExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnLimitExpr_return
-
- columnName() - Method in class org.apache.cassandra.cli.CliParser
-
- columnName - Variable in class org.apache.cassandra.cql.AlterTableStatement
-
- columnName - Variable in class org.apache.cassandra.db.composites.CompoundSparseCellName
-
- columnName_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnName_return
-
- 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
-
- columnOrSuperColumn() - Method in class org.apache.cassandra.cli.CliParser
-
- columnOrSuperColumn_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnOrSuperColumn_return
-
- 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.columniterator.SSTableNamesIterator
-
- columns - Variable in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- columns - Variable in class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- ColumnSerializer - Class in org.apache.cassandra.db
-
- ColumnSerializer(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() - 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(Cell, AbstractCassandraStorage.CfInfo, AbstractType) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
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() - Method in class org.apache.cassandra.cli.CliParser
-
- command - Variable in class org.apache.cassandra.service.AbstractReadExecutor
-
- command_return() - Constructor for class org.apache.cassandra.cli.CliParser.command_return
-
- commandCompletedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Completed tasks for Command(Mutations, Read etc) TCP Connections
- commandDroppedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Dropped tasks for Command(Mutations, Read etc) TCP Connections
- commandPendingTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Pending tasks for Command(Mutations, Read etc) TCP Connections
- commands - Variable in class org.apache.cassandra.cli.CliUserHelp
-
- commands - Variable in class org.apache.cassandra.service.pager.Pageable.ReadCommands
-
- commandType - Variable in class org.apache.cassandra.db.ReadCommand
-
- COMMENT - Static variable in class org.apache.cassandra.cli.CliLexer
-
- COMMENT - Static variable in class org.apache.cassandra.cli.CliParser
-
- comment(String) - Method in class org.apache.cassandra.config.CFMetaData
-
- COMMENT - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- COMMENT - Static variable in class org.apache.cassandra.cql.CqlParser
-
- COMMENT - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- COMMENT - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- 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() - 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_directory - Variable in class org.apache.cassandra.config.Config
-
- commitlog_periodic_queue_size - Variable in class org.apache.cassandra.config.Config
-
Deprecated.
- commitlog_segment_recycling - Variable in class org.apache.cassandra.config.Config
-
- commitlog_segment_size_in_mb - Variable in class org.apache.cassandra.config.Config
-
- commitlog_sync - Variable in class org.apache.cassandra.config.Config
-
- commitlog_sync_batch_window_in_ms - Variable in class org.apache.cassandra.config.Config
-
- commitlog_sync_period_in_ms - Variable in class org.apache.cassandra.config.Config
-
- commitlog_total_space_in_mb - Variable in class org.apache.cassandra.config.Config
-
- CommitLogArchiver - Class in org.apache.cassandra.db.commitlog
-
- CommitLogArchiver() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- CommitLogDescriptor - Class in org.apache.cassandra.db.commitlog
-
- CommitLogDescriptor(int, long) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- CommitLogDescriptor(long) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- CommitLogMBean - Interface in org.apache.cassandra.db.commitlog
-
- CommitLogMetrics - Class in org.apache.cassandra.metrics
-
Metrics for commit log
- CommitLogMetrics(AbstractCommitLogService, CommitLogSegmentManager) - Constructor for class org.apache.cassandra.metrics.CommitLogMetrics
-
- CommitLogReplayer - Class in org.apache.cassandra.db.commitlog
-
- CommitLogReplayer() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogReplayer
-
- CommitLogSegment - Class in org.apache.cassandra.db.commitlog
-
- CommitLogSegment.CommitLogSegmentFileComparator - Class in org.apache.cassandra.db.commitlog
-
- 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.
- CommitLogSegmentManager() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegmentManager
-
- CommitSerializer() - Constructor for class org.apache.cassandra.service.paxos.Commit.CommitSerializer
-
- commitTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.AbstractBulkOutputFormat.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() - 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.DataTracker.View
-
- compacting - Variable in class org.apache.cassandra.notifications.SSTableCompactingNotification
-
- COMPACTION_ENABLED - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- COMPACTION_HISTORY_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- compaction_large_partition_warning_threshold_mb - Variable in class org.apache.cassandra.config.Config
-
- COMPACTION_LOG - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- COMPACTION_OPTIONS_PREFIX - Static variable in class org.apache.cassandra.cql.CFPropDefs
-
- 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
-
- 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() - Constructor for class org.apache.cassandra.tools.NodeTool.CompactionHistory
-
- CompactionHistoryCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- CompactionHistoryTabularData - Class in org.apache.cassandra.db.compaction
-
- CompactionHistoryTabularData() - Constructor for class org.apache.cassandra.db.compaction.CompactionHistoryTabularData
-
- CompactionInfo - Class in org.apache.cassandra.db.compaction
-
Implements serializable to allow structured info to be returned via JMX.
- CompactionInfo(CFMetaData, OperationType, long, long) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
-
- CompactionInfo(OperationType, long, long, String) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
-
- CompactionInfo(CFMetaData, OperationType, long, long, String) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
-
- CompactionInfo.Holder - Class in org.apache.cassandra.db.compaction
-
- 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) - Constructor for class org.apache.cassandra.db.compaction.CompactionIterable
-
- CompactionIterable.Reducer - Class in org.apache.cassandra.db.compaction
-
- CompactionLogCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- 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
-
- 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
-
- compactionStrategyClass - Variable in class org.apache.cassandra.cql.CFPropDefs
-
- compactionStrategyOptions - Variable in class org.apache.cassandra.config.CFMetaData
-
- compactionStrategyOptions(Map<String, String>) - Method in class org.apache.cassandra.config.CFMetaData
-
- compactionStrategyOptions - Variable in class org.apache.cassandra.cql.CFPropDefs
-
- CompactionTask - Class in org.apache.cassandra.db.compaction
-
- CompactionTask(ColumnFamilyStore, Iterable<SSTableReader>, 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() - Method in class org.apache.cassandra.cli.CliParser
-
- comparator - Variable in class org.apache.cassandra.config.CFMetaData
-
- comparator - Variable in class org.apache.cassandra.cql3.statements.CreateTableStatement
-
- comparator - Static variable in class org.apache.cassandra.db.commitlog.ReplayPosition
-
- comparator - Static variable in class org.apache.cassandra.db.DecoratedKey
-
- comparator - Variable in class org.apache.cassandra.db.marshal.AbstractCompositeType.CompositeComponent
-
- comparator() - Method in class org.apache.cassandra.db.RangeTombstoneList
-
- comparator - Variable in class org.apache.cassandra.utils.btree.BTreeSet
-
- comparator() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- comparator() - Method in class org.apache.cassandra.utils.IntervalTree
-
- comparator_return() - Constructor for class org.apache.cassandra.cli.CliParser.comparator_return
-
- comparators - Static variable in class org.apache.cassandra.cql.CFPropDefs
-
- comparatorType() - Method in class org.apache.cassandra.cql.CqlParser
-
- comparatorType() - Method in class org.apache.cassandra.cql3.CqlParser
-
- comparatorType_return() - Constructor for class org.apache.cassandra.cql.CqlParser.comparatorType_return
-
- 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.ColumnToCollectionType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DateType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
-
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.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.TimestampType
-
- 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.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
-
- 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
-
- 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(PermissionDetails) - Method in class org.apache.cassandra.auth.PermissionDetails
-
- 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(Token) - Method in class org.apache.cassandra.dht.BytesToken
-
- compareTo(Token) - Method in class org.apache.cassandra.dht.LocalToken
-
- compareTo(Token) - Method in class org.apache.cassandra.dht.LongToken
-
- compareTo(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
- 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(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
-
- compareTo(SemanticVersion) - Method in class org.apache.cassandra.utils.SemanticVersion
-
- 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.
- COMPIDENT - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- COMPIDENT - Static variable in class org.apache.cassandra.cql.CqlParser
-
- compile(String, String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- compileQuery(String) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- complete(String, long, boolean) - Method in class org.apache.cassandra.io.util.BufferedPoolingSegmentedFile.Builder
-
- complete(String, long, boolean) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile.Builder
-
- complete(String, long, boolean) - Method in class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile.Builder
-
- complete(String, long, boolean) - Method in class org.apache.cassandra.io.util.CompressedSegmentedFile.Builder
-
- complete(String, long, boolean) - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile.Builder
-
- complete(String, long, boolean) - 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, boolean) - 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
.
- completed(InetAddress) - Method in class org.apache.cassandra.repair.DatacenterAwareRequestCoordinator
-
- completed(R) - Method in interface org.apache.cassandra.repair.IRequestCoordinator
-
- completed(R) - Method in class org.apache.cassandra.repair.ParallelRequestCoordinator
-
- completed(R) - Method in class org.apache.cassandra.repair.SequentialRequestCoordinator
-
- 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
-
- componentBounds(Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.MultiColumnRestriction.Slice
-
Similar to bounds(), but returns one ByteBuffer per-component in the bound instead of a single
ByteBuffer to represent the entire bound.
- 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(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
-
- composeComposite(AbstractCompositeType, ByteBuffer) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
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
-
- 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
-
- 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
-
- 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(byte[], int, int, ICompressor.WrappedArray, int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- compress(byte[], int, int, ICompressor.WrappedArray, int) - Method in interface org.apache.cassandra.io.compress.ICompressor
-
- compress(byte[], int, int, ICompressor.WrappedArray, int) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- compress(byte[], int, int, ICompressor.WrappedArray, int) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- compress(Frame) - Method in interface org.apache.cassandra.transport.FrameCompressor
-
- compress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.LZ4Compressor
-
- compress(Frame) - Method in class org.apache.cassandra.transport.FrameCompressor.SnappyCompressor
-
- 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, boolean) - Constructor for class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- CompressedPoolingSegmentedFile - Class in org.apache.cassandra.io.util
-
- CompressedPoolingSegmentedFile(String, CompressionMetadata) - Constructor for class org.apache.cassandra.io.util.CompressedPoolingSegmentedFile
-
- CompressedPoolingSegmentedFile.Builder - Class in org.apache.cassandra.io.util
-
- CompressedPoolingSegmentedFile.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(String, CompressionMetadata, PoolingSegmentedFile) - Constructor for class org.apache.cassandra.io.compress.CompressedRandomAccessReader
-
- CompressedSegmentedFile - Class in org.apache.cassandra.io.util
-
- CompressedSegmentedFile(String, CompressionMetadata) - Constructor for class org.apache.cassandra.io.util.CompressedSegmentedFile
-
- CompressedSegmentedFile.Builder - Class in org.apache.cassandra.io.util
-
- 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
- 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(String, CompressionMetadata, RateLimiter) - Constructor for class org.apache.cassandra.io.compress.CompressedThrottledReader
-
- compression - Variable in class org.apache.cassandra.io.sstable.SSTable
-
- COMPRESSION - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
-
- COMPRESSION_INFO - Static variable in class org.apache.cassandra.io.sstable.Component
-
- COMPRESSION_PARAMETERS_PREFIX - Static variable in class org.apache.cassandra.cql.CFPropDefs
-
- 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 - Variable in class org.apache.cassandra.cql.CFPropDefs
-
- CompressionParameters - Class in org.apache.cassandra.io.compress
-
- CompressionParameters(String, Integer, Map<String, String>) - Constructor for class org.apache.cassandra.io.compress.CompressionParameters
-
- CompressionParameters(ICompressor) - Constructor for class org.apache.cassandra.io.compress.CompressionParameters
-
- CompressionParameters(ICompressor, Integer, Map<String, String>) - Constructor for class org.apache.cassandra.io.compress.CompressionParameters
-
- compressionRatio - Variable in class org.apache.cassandra.io.sstable.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(byte[]) - Static method in class org.apache.cassandra.utils.MD5Digest
-
- compute(String) - Static method in class org.apache.cassandra.utils.MD5Digest
-
- computeExpireTime() - Static method in class org.apache.cassandra.gms.Gossiper
-
- computeNext() - Method in class org.apache.cassandra.db.columniterator.LazyColumnIterator
-
- computeNext() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
-
- computeNext() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- computeNext() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
-
- 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 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- CONDITION - Static variable in class org.apache.cassandra.cli.CliParser
-
- 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 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- CONDITIONS - Static variable in class org.apache.cassandra.cli.CliParser
-
- conditions - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
-
- conf - Variable in class org.apache.cassandra.hadoop.AbstractBulkRecordWriter
-
- conf - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
- conf - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- CONFIG - Static variable in class org.apache.cassandra.cli.CliLexer
-
- CONFIG - Static variable in class org.apache.cassandra.cli.CliParser
-
- Config - Class in org.apache.cassandra.config
-
A class that contains configuration properties for the cassandra node it runs within.
- Config() - Constructor for class org.apache.cassandra.config.Config
-
- Config.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
-
- ConfigurationException - Exception in org.apache.cassandra.exceptions
-
- ConfigurationException(String) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
-
- ConfigurationException(String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
-
- ConfigurationException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
-
- ConfigurationLoader - Interface in org.apache.cassandra.config
-
- confirmReplication(InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
- CONNECT - Static variable in class org.apache.cassandra.cli.CliLexer
-
- connect(String, int) - Static method in class org.apache.cassandra.cli.CliMain
-
Establish a thrift connection to cassandra instance
- CONNECT - Static variable in class org.apache.cassandra.cli.CliParser
-
- connect(boolean) - Method in class org.apache.cassandra.transport.SimpleClient
-
- 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
-
- connectStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- connectStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.connectStatement_return
-
- consistency - Variable in class org.apache.cassandra.cql.BatchStatement
-
- consistency() - Method in class org.apache.cassandra.db.CounterMutation
-
- consistency - Variable in exception org.apache.cassandra.exceptions.RequestTimeoutException
-
- consistency - Variable in exception org.apache.cassandra.exceptions.UnavailableException
-
- CONSISTENCYLEVEL - Static variable in class org.apache.cassandra.cli.CliLexer
-
- CONSISTENCYLEVEL - Static variable in class org.apache.cassandra.cli.CliParser
-
- ConsistencyLevel - Enum in org.apache.cassandra.db
-
- consistencyLevel - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
- consistencyLevel - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
- consistencyLevelStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- consistencyLevelStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.consistencyLevelStatement_return
-
- 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(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() - Constructor for class org.apache.cassandra.cql3.statements.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
-
- 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
-
- 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
-
- containsTriggerDefinition(TriggerDefinition) - Method in class org.apache.cassandra.config.CFMetaData
-
- 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
-
- context - Variable in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- context - Variable in class org.apache.cassandra.hadoop.AbstractBulkRecordWriter
-
- context - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
- 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
-
- convert(long) - Static method in class org.apache.cassandra.utils.NanoTimeToCurrentTimeMillis
-
- CONVERT_TO_TYPE - Static variable in class org.apache.cassandra.cli.CliLexer
-
- CONVERT_TO_TYPE - Static variable in class org.apache.cassandra.cli.CliParser
-
- convertPropertyMap(Maps.Literal) - Method in class org.apache.cassandra.cql3.CqlParser
-
- convict(InetAddress, double) - Method in class org.apache.cassandra.gms.Gossiper
-
This method is part of IFailureDetectionEventListener interface.
- convict(InetAddress, double) - Method in interface org.apache.cassandra.gms.IFailureDetectionEventListener
-
Convict the specified endpoint.
- convict(InetAddress) - Method in 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.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.Metadata
-
- 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
-
- copyTo(CounterContext.ContextState) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- CorruptBlockException - Exception in org.apache.cassandra.io.compress
-
- CorruptBlockException(String, CompressionMetadata.Chunk) - Constructor for exception org.apache.cassandra.io.compress.CorruptBlockException
-
- CorruptBlockException(String, 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
-
- CorruptSSTableException - Exception in org.apache.cassandra.io.sstable
-
- CorruptSSTableException(Exception, File) - Constructor for exception org.apache.cassandra.io.sstable.CorruptSSTableException
-
- CorruptSSTableException(Exception, String) - Constructor for exception org.apache.cassandra.io.sstable.CorruptSSTableException
-
- COUNT - Static variable in class org.apache.cassandra.cli.CliLexer
-
- COUNT - Static variable in class org.apache.cassandra.cli.CliParser
-
- count - 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 - Variable in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
The number of bytes written.
- count() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
-
- count() - Method in class org.apache.cassandra.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
-
- COUNT_COLUMN - Static variable in class org.apache.cassandra.cql3.ResultSet
-
- countAlias - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
-
- 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.
- countColumn(Cell) - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
- 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_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
-
- countMapping(CFMetaData, ColumnIdentifier) - Static method in class org.apache.cassandra.cql3.statements.SelectionColumnMapping
-
- 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.
- countStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- countStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.countStatement_return
-
- 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.cql.QueryProcessor
-
- CQL_VERSION - Static variable in class org.apache.cassandra.cql3.QueryProcessor
-
- CQL_VERSION - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
-
- 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
ColumnFamily.
- CqlBulkOutputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- CqlBulkRecordWriter - Class in org.apache.cassandra.hadoop.cql3
-
The CqlBulkRecordWriter
maps the output <key, value>
pairs to a Cassandra column family.
- 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.cql
-
- CqlLexer() - Constructor for class org.apache.cassandra.cql.CqlLexer
-
- CqlLexer(CharStream) - Constructor for class org.apache.cassandra.cql.CqlLexer
-
- CqlLexer(CharStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cql.CqlLexer
-
- CqlLexer - Class in org.apache.cassandra.cql3
-
- CqlLexer() - Constructor for class org.apache.cassandra.cql3.CqlLexer
-
- CqlLexer(CharStream) - Constructor for class org.apache.cassandra.cql3.CqlLexer
-
- CqlLexer(CharStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cql3.CqlLexer
-
- CqlLexer.DFA11 - Class in org.apache.cassandra.cql3
-
- CqlLexer.DFA15 - Class in org.apache.cassandra.cql
-
- CqlLexer.DFA19 - Class in org.apache.cassandra.cql3
-
- CqlLexer.DFA7 - Class in org.apache.cassandra.cql
-
- CQLMetrics - Class in org.apache.cassandra.metrics
-
- CQLMetrics() - Constructor for class org.apache.cassandra.metrics.CQLMetrics
-
- CqlNativeStorage - Class in org.apache.cassandra.hadoop.pig
-
- CqlNativeStorage() - Constructor for class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
- CqlNativeStorage(int) - Constructor for class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
- CqlOutputFormat - Class in org.apache.cassandra.hadoop.cql3
-
The ColumnFamilyOutputFormat
acts as a Hadoop-specific
OutputFormat that allows reduce tasks to store keys (and corresponding
bound variable values) as CQL rows (and respective columns) in a given
ColumnFamily.
- CqlOutputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
-
- CqlParser - Class in org.apache.cassandra.cql
-
- CqlParser(TokenStream) - Constructor for class org.apache.cassandra.cql.CqlParser
-
- CqlParser(TokenStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cql.CqlParser
-
- CqlParser - Class in org.apache.cassandra.cql3
-
- CqlParser(TokenStream) - Constructor for class org.apache.cassandra.cql3.CqlParser
-
- CqlParser(TokenStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cql3.CqlParser
-
- CqlParser.comparatorType_return - Class in org.apache.cassandra.cql
-
- CqlParser.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 - Class in org.apache.cassandra.cql
-
- CQLStatement(StatementType, Object, int) - Constructor for class org.apache.cassandra.cql.CQLStatement
-
- cqlStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CQLStatement - Interface in org.apache.cassandra.cql3
-
- CqlStorage - Class in org.apache.cassandra.hadoop.pig
-
- CqlStorage() - Constructor for class org.apache.cassandra.hadoop.pig.CqlStorage
-
Deprecated.
- CqlStorage(int) - Constructor for class org.apache.cassandra.hadoop.pig.CqlStorage
-
Deprecated.
- CRC - Static variable in class org.apache.cassandra.io.sstable.Component
-
- CRC_CHECK_CHANCE - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- create(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- create(String, Map<IAuthenticator.Option, Object>) - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Called during execution of CREATE USER query (also may be called on startup, see seedSuperuserOptions method).
- create(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- create(String, Map<IAuthenticator.Option, Object>) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- create(long, EntryWeigher<K, V>) - Static method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
Initialize a cache with initial capacity with weightedCapacity
- create(long) - Static method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- create(Pair<String, String>, ByteBuffer, CellName) - Static method in class org.apache.cassandra.cache.CounterCacheKey
-
- create(long, Weigher<RefCountedMemory>, ISerializer<V>) - Static method in class org.apache.cassandra.cache.SerializingCache
-
- create(long, ISerializer<V>) - Static method in class org.apache.cassandra.cache.SerializingCache
-
- create(long) - Method in class org.apache.cassandra.cache.SerializingCacheProvider
-
- CREATE - Static variable in class org.apache.cassandra.cli.CliLexer
-
- CREATE - Static variable in class org.apache.cassandra.cli.CliParser
-
- create(String, String) - 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(String, String) - Method in interface org.apache.cassandra.cql3.functions.Function.Factory
-
- 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(String) - Static method in class org.apache.cassandra.io.compress.CompressionMetadata
-
Create metadata about given compressed file including uncompressed data length, chunk size
and list of the chunk offsets of the compressed data.
- create(Map<? extends CharSequence, ? extends CharSequence>) - Static method in class org.apache.cassandra.io.compress.CompressionParameters
-
- create(Map<String, String>) - Static method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- create(Map<String, String>) - Static method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- create(Map<String, String>) - Static method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- create() - Static method in class org.apache.cassandra.locator.EndpointSnitchInfo
-
- create(InetAddress, T, Map<String, byte[]>, MessagingService.Verb, int) - Static method in class org.apache.cassandra.net.MessageIn
-
- create(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
-
- createAllDirectories() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
Creates all storage-related directories.
- createAuthenticatedClient(String, int, Configuration) - Static method in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
-
- createAuthenticatedClient(String, int, Configuration) - Static method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
-
Connects to the given server:port and returns a client based on the given socket that points to the configured
keyspace, and is logged in with the configured credentials.
- createCfamColumns(CreateColumnFamilyStatement) - Method in class org.apache.cassandra.cql.CqlParser
-
- createCfamColumnValidator() - Method in class org.apache.cassandra.cql.CqlParser
-
- createCfamKeywordArgument() - Method in class org.apache.cassandra.cql.CqlParser
-
- createClusteringPrefix(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- createColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
- 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) - 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
- createColumnFamilyStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- CreateColumnFamilyStatement - Class in org.apache.cassandra.cql
-
A CREATE COLUMNFAMILY
parsed from a CQL query statement.
- CreateColumnFamilyStatement(String) - Constructor for class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
- createColumnFamilyStore(Keyspace, String, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
- createColumnFamilyStore(Keyspace, String, IPartitioner, CFMetaData) - 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.
- 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
-
- createDirectory(String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createDirectory(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- createFilter(int, IBitSet) - Method in class org.apache.cassandra.utils.Murmur3BloomFilter.Murmur3BloomFilterSerializer
-
- 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.
- 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.cql.CqlParser
-
- CreateIndexStatement - Class in org.apache.cassandra.cql
-
A CREATE INDEX
statement parsed from a CQL query.
- CreateIndexStatement(String, String, Term) - Constructor for class org.apache.cassandra.cql.CreateIndexStatement
-
- createIndexStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CreateIndexStatement - Class in org.apache.cassandra.cql3.statements
-
A CREATE INDEX
statement parsed from a CQL query.
- CreateIndexStatement(CFName, 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
-
- createKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- createKeyspaceStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- CreateKeyspaceStatement - Class in org.apache.cassandra.cql
-
A CREATE KEYSPACE
statement parsed from a CQL query.
- CreateKeyspaceStatement(String, Map<String, String>) - Constructor for class org.apache.cassandra.cql.CreateKeyspaceStatement
-
Creates a new CreateKeyspaceStatement
instance for a given
keyspace name and keyword arguments.
- createKeyspaceStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- CreateKeyspaceStatement - Class in org.apache.cassandra.cql3.statements
-
A CREATE KEYSPACE
statement parsed from a CQL query.
- CreateKeyspaceStatement(String, KSPropDefs, 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.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.
- 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
-
- 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
-
- 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
-
- 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
-
- CreateUserStatement - Class in org.apache.cassandra.cql3.statements
-
- CreateUserStatement(String, UserOptions, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateUserStatement
-
- createValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- createValue() - Method in class org.apache.cassandra.hadoop.cql3.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) - Method in class org.apache.cassandra.streaming.StreamReader
-
- creationTime() - Method in class org.apache.cassandra.db.Memtable
-
- credentials - Variable in class org.apache.cassandra.transport.messages.CredentialsMessage
-
- CredentialsMessage - Class in org.apache.cassandra.transport.messages
-
Message to indicate that the server is ready to receive requests.
- CredentialsMessage() - Constructor for class org.apache.cassandra.transport.messages.CredentialsMessage
-
- cross_node_timeout - Variable in class org.apache.cassandra.config.Config
-
- 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 - Static variable in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- current - Variable in class org.apache.cassandra.io.util.RandomAccessReader
-
- current - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- current_version - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
Increment this number if there is a changes in the commit log disc layout or MessagingVersion changes.
- current_version - Static variable in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- current_version - Static variable in class org.apache.cassandra.net.MessagingService
-
- CURRENT_VERSION - Static variable in class org.apache.cassandra.streaming.messages.StreamMessage
-
Streaming protocol version
- 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
-
- 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 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- D - Static variable in class org.apache.cassandra.cql.CqlParser
-
- D - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- D - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- DATA - Static variable in class org.apache.cassandra.io.sstable.Component
-
- data - Variable in class org.apache.cassandra.utils.Interval
-
- data_file_directories - Variable in class org.apache.cassandra.config.Config
-
- DatabaseDescriptor - Class in org.apache.cassandra.config
-
- DatabaseDescriptor() - Constructor for class org.apache.cassandra.config.DatabaseDescriptor
-
- datacenter(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- Datacenter() - Constructor for class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.Datacenter
-
- DatacenterAwareRequestCoordinator - Class in org.apache.cassandra.repair
-
- DatacenterAwareRequestCoordinator(IRequestProcessor<InetAddress>) - Constructor for class org.apache.cassandra.repair.DatacenterAwareRequestCoordinator
-
- DatacenterSyncWriteResponseHandler - Class in org.apache.cassandra.service
-
This class blocks for a quorum of responses _in all datacenters_ (CL.EACH_QUORUM).
- DatacenterSyncWriteResponseHandler(Collection<InetAddress>, Collection<InetAddress>, ConsistencyLevel, Keyspace, Runnable, WriteType) - Constructor for class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
-
- DatacenterWriteResponseHandler - Class in org.apache.cassandra.service
-
This class blocks for a quorum of responses _in the local datacenter only_ (CL.LOCAL_QUORUM).
- DatacenterWriteResponseHandler(Collection<InetAddress>, Collection<InetAddress>, ConsistencyLevel, 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
-
- dataLength - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
-
- DataOutputBuffer - Class in org.apache.cassandra.io.util
-
An implementation of the DataOutputStream interface using a FastByteArrayOutputStream and exposing
its buffer so copies can be avoided.
- DataOutputBuffer() - Constructor for class org.apache.cassandra.io.util.DataOutputBuffer
-
- DataOutputBuffer(int) - Constructor for class org.apache.cassandra.io.util.DataOutputBuffer
-
- DataOutputByteBuffer - 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.
- DataOutputByteBuffer(ByteBuffer) - Constructor for class org.apache.cassandra.io.util.DataOutputByteBuffer
-
- DataOutputPlus - Interface in org.apache.cassandra.io.util
-
- DataOutputStreamAndChannel - Class in org.apache.cassandra.io.util
-
- DataOutputStreamAndChannel(OutputStream, WritableByteChannel) - Constructor for class org.apache.cassandra.io.util.DataOutputStreamAndChannel
-
- DataOutputStreamAndChannel(WritableByteChannel) - Constructor for class org.apache.cassandra.io.util.DataOutputStreamAndChannel
-
- DataOutputStreamAndChannel(FileOutputStream) - Constructor for class org.apache.cassandra.io.util.DataOutputStreamAndChannel
-
- DataOutputStreamPlus - Class in org.apache.cassandra.io.util
-
- DataOutputStreamPlus(OutputStream) - Constructor for class org.apache.cassandra.io.util.DataOutputStreamPlus
-
- 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
-
- dataSize - Variable in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- DataTracker - Class in org.apache.cassandra.db
-
- DataTracker(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.DataTracker
-
- DataTracker.SSTableIntervalTree - Class in org.apache.cassandra.db
-
- DataTracker.View - Class in org.apache.cassandra.db
-
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).
- DataType - Enum in org.apache.cassandra.transport
-
- dateOfFct - Static variable in class org.apache.cassandra.cql3.functions.TimeuuidFcts
-
- dateStringToTimestamp(String) - Static method in class org.apache.cassandra.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
-
- DateType - Class in org.apache.cassandra.db.marshal
-
- dc_local_address - Variable in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.Node
-
- dc_name - Variable in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.Datacenter
-
- dcLocalReadRepairChance(double) - Method in class org.apache.cassandra.config.CFMetaData
-
- deactivate() - Method in class org.apache.cassandra.service.CassandraDaemon
-
A convenience method to stop and destroy the daemon in one shot.
- deallocate() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- debug - Variable in class org.apache.cassandra.cli.CliSessionState
-
- debug(String) - Method in class org.apache.cassandra.hadoop.AbstractBulkRecordWriter.NullOutputHandler
-
- 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
-
- DecimalDigit - Static variable in class org.apache.cassandra.cli.CliLexer
-
- DecimalDigit - Static variable in class org.apache.cassandra.cli.CliParser
-
- 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.CompositesIndexOnClusteringKey
-
- decodeEntry(DecoratedKey, Cell) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKey
-
- 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
-
- 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() - Constructor for class org.apache.cassandra.tools.NodeTool.Decommission
-
- 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.AbstractByteOrderedPartitioner
-
- decorateKey(ByteBuffer) - Method in interface org.apache.cassandra.dht.IPartitioner
-
Transform key to object representation of the on-disk format.
- decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- DECR - Static variable in class org.apache.cassandra.cli.CliLexer
-
- DECR - Static variable in class org.apache.cassandra.cli.CliParser
-
- DEFAULT - 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_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_dc_name - Variable in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.TopologyConfig
-
- 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.AbstractCassandraStorage
-
- 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_KEY_NAME - Static variable in class org.apache.cassandra.cql.QueryProcessor
-
- DEFAULT_MAX_COMPACTION_THRESHOLD - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_MAX_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.AbstractCassandraStorage
-
- default_rack_name - Variable in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.TopologyConfig
-
- DEFAULT_READ_REPAIR_CHANCE - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_SPECULATIVE_RETRY - Static variable in class org.apache.cassandra.config.CFMetaData
-
- DEFAULT_SSL_STORAGE_PORT - Static variable in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- DEFAULT_SSTABLE_SIZE - Static variable in class org.apache.cassandra.tools.StandaloneSplitter
-
- DEFAULT_STORAGE_PORT - Static variable in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- DEFAULT_SUPERUSER_NAME - Static variable in class org.apache.cassandra.auth.Auth
-
- DEFAULT_THROTTLE_LIMIT - Static variable in class org.apache.cassandra.config.RequestSchedulerOptions
-
- DEFAULT_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
-
- DefaultConnectionFactory - Class in org.apache.cassandra.streaming
-
- DefaultConnectionFactory() - Constructor for class org.apache.cassandra.streaming.DefaultConnectionFactory
-
- defaultConsistency - Static variable in class org.apache.cassandra.cql.AbstractModification
-
- 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
-
- defaultUser() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- defaultValidator(AbstractType<?>) - Method in class org.apache.cassandra.config.CFMetaData
-
- defined - Variable in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- 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
-
- DefsTables - Class in org.apache.cassandra.db
-
SCHEMA_{KEYSPACES, COLUMNFAMILIES, COLUMNS}_CF are used to store Keyspace/ColumnFamily attributes to make schema
load/distribution easy, it replaces old mechanism when local migrations where serialized, stored in system.Migrations
and used for schema distribution.
- DefsTables() - Constructor for class org.apache.cassandra.db.DefsTables
-
- DEL - Static variable in class org.apache.cassandra.cli.CliLexer
-
- DEL - Static variable in class org.apache.cassandra.cli.CliParser
-
- 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
-
- delColumnFamily() - Method in class org.apache.cassandra.cli.CliParser
-
- delColumnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.delColumnFamily_return
-
- 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.
- deleteFromSchema(Mutation, long) - Method in class org.apache.cassandra.config.ColumnDefinition
-
Drop specified column from the schema using given mutation.
- deleteFromSchema(Mutation, String, long) - Method in class org.apache.cassandra.config.TriggerDefinition
-
Drop specified trigger from the schema using given mutation.
- deleteHintsForEndpoint(String) - Method in class org.apache.cassandra.db.HintedHandOffManager
-
- deleteHintsForEndpoint(InetAddress) - Method in class org.apache.cassandra.db.HintedHandOffManager
-
- deleteHintsForEndpoint(String) - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
-
Nuke all hints from this node to `ep`.
- deleteOp() - Method in class org.apache.cassandra.cql3.CqlParser
-
- 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".
- deleteSelection() - Method in class org.apache.cassandra.cql3.CqlParser
-
- deleteStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- DeleteStatement - Class in org.apache.cassandra.cql
-
A DELETE
parsed from a CQL query statement.
- DeleteStatement(List<Term>, String, String, String, List<Term>, Attributes) - Constructor for class org.apache.cassandra.cql.DeleteStatement
-
- deleteStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DeleteStatement - Class in org.apache.cassandra.cql3.statements
-
A DELETE
parsed from a CQL query statement.
- DeleteStatement.Parsed - Class in org.apache.cassandra.cql3.statements
-
- deleteUser(String) - Static method in class org.apache.cassandra.auth.Auth
-
Deletes the user from AUTH_KS.USERS_CF.
- deleteWithConfirm(String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- deleteWithConfirm(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- 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
-
- delKeyspace() - Method in class org.apache.cassandra.cli.CliParser
-
- delKeyspace_return() - Constructor for class org.apache.cassandra.cli.CliParser.delKeyspace_return
-
- delStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- delStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.delStatement_return
-
- 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.RepairJob
-
- desc - Variable in class org.apache.cassandra.repair.StreamingRepairTask
-
Repair session ID that this streaming task belongs
- 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 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- DESCRIBE - Static variable in class org.apache.cassandra.cli.CliParser
-
- describe_cluster_name() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_keyspaces() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- describe_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() - Method in class org.apache.cassandra.cli.CliParser
-
- DescribeCluster() - Constructor for class org.apache.cassandra.tools.NodeTool.DescribeCluster
-
- describeCluster_return() - Constructor for class org.apache.cassandra.cli.CliParser.describeCluster_return
-
- 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.AbstractByteOrderedPartitioner
-
- describeOwnership(List<Token>) - Method in interface org.apache.cassandra.dht.IPartitioner
-
Calculate the deltas between tokens in the ring in order to compare
relative sizes.
- describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- describeRing(String) - Method in class org.apache.cassandra.service.StorageService
-
The TokenRange for a given keyspace.
- describeRing(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- 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.
- describeTable() - Method in class org.apache.cassandra.cli.CliParser
-
- describeTable_return() - Constructor for class org.apache.cassandra.cli.CliParser.describeTable_return
-
- 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(String, File, String, String, int, Descriptor.Type) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
-
- Descriptor(Descriptor.Version, File, String, String, int, Descriptor.Type) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
-
- descriptor - Variable in class org.apache.cassandra.io.sstable.SSTable
-
- Descriptor.Type - Enum in org.apache.cassandra.io.sstable
-
- Descriptor.Version - Class in org.apache.cassandra.io.sstable
-
- deserialize(DataInputStream, ColumnFamilyStore) - Method in interface org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
-
- deserialize(String) - Static method in enum org.apache.cassandra.config.ColumnDefinition.Kind
-
- 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, Descriptor.Version) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- deserialize(DataInput) - Method in class org.apache.cassandra.db.RowPosition.RowPositionSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
-
- deserialize(DataInput, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- deserialize(DataInput) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
-
- deserialize(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(Descriptor.Version, DataInput) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
-
- deserialize(Descriptor.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(Descriptor.Version, DataInput) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata.StatsMetadataSerializer
-
- deserialize(Descriptor.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.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.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(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, Descriptor.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
-
- deserializeColumnFamilies(Row) - Static method in class org.apache.cassandra.config.KSMetaData
-
Deserialize ColumnFamilies from low-level schema representation, all of them belong to the same keyspace
- 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, Descriptor.Version) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
-
- deserializeFromSSTable(DataInput, Descriptor.Version) - Method in class org.apache.cassandra.db.OnDiskAtom.Serializer
-
- deserializeFromSSTable(DataInput, ColumnSerializer.Flag, int, Descriptor.Version) - Method in class org.apache.cassandra.db.OnDiskAtom.Serializer
-
- deserializeFromSSTable(DataInput, Descriptor.Version) - Method in class org.apache.cassandra.db.RangeTombstone.Serializer
-
- deserializeFromSSTable(DataInput, Descriptor.Version) - Method in interface org.apache.cassandra.io.ISSTableSerializer
-
Deserialize into the specified DataInputStream instance in the format
suited for SSTables.
- deserializeIndex(FileDataInput, CType) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
-
Deserialize the index into a structure and return it
- 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
-
- dfa11 - Variable in class org.apache.cassandra.cql3.CqlLexer
-
- DFA11(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlLexer.DFA11
-
- dfa15 - Variable in class org.apache.cassandra.cli.CliLexer
-
- DFA15(BaseRecognizer) - Constructor for class org.apache.cassandra.cli.CliLexer.DFA15
-
- dfa15 - Variable in class org.apache.cassandra.cql.CqlLexer
-
- DFA15(BaseRecognizer) - Constructor for class org.apache.cassandra.cql.CqlLexer.DFA15
-
- dfa19 - Variable in class org.apache.cassandra.cql3.CqlLexer
-
- DFA19(BaseRecognizer) - Constructor for class org.apache.cassandra.cql3.CqlLexer.DFA19
-
- dfa7 - Variable in class org.apache.cassandra.cql.CqlLexer
-
- DFA7(BaseRecognizer) - Constructor for class org.apache.cassandra.cql.CqlLexer.DFA7
-
- dfile - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
-
- 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
-
- Differencer - Class in org.apache.cassandra.repair
-
Runs on the node that initiated a request to compare two trees, and launch repairs for disagreeing ranges.
- Differencer(RepairJobDesc, TreeResponse, TreeResponse) - Constructor for class org.apache.cassandra.repair.Differencer
-
- differences - Variable in class org.apache.cassandra.repair.Differencer
-
- 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
-
- differencingDone - Variable in class org.apache.cassandra.repair.RepairSession
-
- 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.cli.CliLexer
-
- Digit - Static variable in class org.apache.cassandra.cli.CliParser
-
- DIGIT - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- DIGIT - Static variable in class org.apache.cassandra.cql.CqlParser
-
- DIGIT - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- DIGIT - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- direction - Variable in 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
-
- 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() - Constructor for class org.apache.cassandra.tools.NodeTool.DisableAutoCompaction
-
- DisableBackup() - Constructor for class org.apache.cassandra.tools.NodeTool.DisableBackup
-
- DisableBinary() - Constructor for class org.apache.cassandra.tools.NodeTool.DisableBinary
-
- DisableGossip() - Constructor for class org.apache.cassandra.tools.NodeTool.DisableGossip
-
- DisableHandoff() - Constructor for class org.apache.cassandra.tools.NodeTool.DisableHandoff
-
- disableHintedHandoff() - Method in class org.apache.cassandra.tools.NodeProbe
-
- 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
-
- discardSSTables(long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Discard all SSTables that were created before given timestamp.
- disconnect() - Static method in class org.apache.cassandra.cli.CliMain
-
Disconnect thrift connection to cassandra instance
- disk_access_mode - Variable in class org.apache.cassandra.config.Config
-
- disk_failure_policy - Variable in class org.apache.cassandra.config.Config
-
- diskAtomFilterSerializer() - Method in class org.apache.cassandra.db.composites.AbstractCellNameType
-
- diskAtomFilterSerializer() - Method in interface org.apache.cassandra.db.composites.CellNameType
-
- DiskAwareRunnable - Class in org.apache.cassandra.io.util
-
- DiskAwareRunnable() - Constructor for class org.apache.cassandra.io.util.DiskAwareRunnable
-
- Dispatcher() - Constructor for class org.apache.cassandra.transport.Message.Dispatcher
-
- displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql.CqlLexer
-
- displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql.CqlParser
-
- displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql3.CqlLexer
-
- displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql3.CqlParser
-
- doAntiCompaction(UUID) - Method in class org.apache.cassandra.service.ActiveRepairService
-
Submit anti-compaction jobs to CompactionManager.
- doCallbackOnFailure() - Method in class org.apache.cassandra.net.MessageIn
-
- doneWithNonLocalSession(TraceState) - Method in class org.apache.cassandra.tracing.Tracing
-
- doRetry(FileMessageHeader, Throwable) - Method in class org.apache.cassandra.streaming.StreamSession
-
- doShadowRound() - Method in class org.apache.cassandra.gms.Gossiper
-
Do a single 'shadow' round of gossip, where we do not modify any state
Only used when replacing a node, to get and assume its states
- DoubleLiteral - Static variable in class org.apache.cassandra.cli.CliLexer
-
- DoubleLiteral - Static variable in class org.apache.cassandra.cli.CliParser
-
- 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(InputStream, long) - Method in class org.apache.cassandra.streaming.StreamReader
-
- drain() - Method in class org.apache.cassandra.tools.NodeProbe
-
- Drain() - Constructor for class org.apache.cassandra.tools.NodeTool.Drain
-
- drop(String) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- drop(String) - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Called during execution of DROP USER query.
- drop(String) - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- drop(String) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- DROP - Static variable in class org.apache.cassandra.cli.CliLexer
-
- DROP - Static variable in class org.apache.cassandra.cli.CliParser
-
- dropCf(UUID) - Method in class org.apache.cassandra.db.Keyspace
-
- dropColumnFamilyStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- dropFromSchema(long) - Method in class org.apache.cassandra.config.CFMetaData
-
Remove all CF attributes from schema
- dropFromSchema(long) - Method in class org.apache.cassandra.config.KSMetaData
-
- dropFromSchema(UserType, long) - Static method in class org.apache.cassandra.config.UTMetaData
-
- dropIndex() - Method in class org.apache.cassandra.cli.CliParser
-
- dropIndex_return() - Constructor for class org.apache.cassandra.cli.CliParser.dropIndex_return
-
- dropIndexStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- DropIndexStatement - Class in org.apache.cassandra.cql
-
- DropIndexStatement(String) - Constructor for class org.apache.cassandra.cql.DropIndexStatement
-
- dropIndexStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DropIndexStatement - Class in org.apache.cassandra.cql3.statements
-
- DropIndexStatement(IndexName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- dropKeyspaceStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- dropKeyspaceStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- DropKeyspaceStatement - Class in org.apache.cassandra.cql3.statements
-
- DropKeyspaceStatement(String, 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
-
- 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
-
- 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
-
- DropUserStatement - Class in org.apache.cassandra.cql3.statements
-
- DropUserStatement(String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropUserStatement
-
- 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
-
- 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
-
- F - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- F - Static variable in class org.apache.cassandra.cql.CqlParser
-
- F - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- F - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- factory(Function) - Static method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
Creates a trivial factory that always return the provided function.
- factory - Static variable in class org.apache.cassandra.cql3.functions.TokenFct
-
- factory - Static variable in class org.apache.cassandra.db.ArrayBackedSortedColumns
-
- factory - Static variable in class org.apache.cassandra.db.AtomicBTreeColumns
-
- Factory() - Constructor for class org.apache.cassandra.db.ColumnFamily.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.
- failed - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
Used to mark a repair as failed - if the coordinator thinks that the repair is still ongoing and sends a
request, we need to fail the coordinator as well.
- failedSnapshot() - Method in interface org.apache.cassandra.repair.IRepairJobEventListener
-
Signal that there was a failure during the snapshot creation process.
- failedSnapshot() - Method in class org.apache.cassandra.repair.RepairSession
-
- 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
-
- FailureDetectorMBean - Interface in org.apache.cassandra.gms
-
- FailureDetectorSourceFilter(IFailureDetector) - Constructor for class org.apache.cassandra.dht.RangeStreamer.FailureDetectorSourceFilter
-
- FAMILY - Static variable in class org.apache.cassandra.cli.CliLexer
-
- FAMILY - Static variable in class org.apache.cassandra.cli.CliParser
-
- FastByteArrayInputStream - Class in org.apache.cassandra.io.util
-
A specialized InputStream
for reading the contents of a byte array.
- FastByteArrayInputStream(byte[]) - Constructor for class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Constructs a new ByteArrayInputStream
on the byte array
buf
.
- FastByteArrayInputStream(byte[], int, int) - Constructor for class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Constructs a new ByteArrayInputStream
on the byte array
buf
with the initial position set to offset
and the
number of bytes available set to offset
+ length
.
- FastByteArrayOutputStream - Class in org.apache.cassandra.io.util
-
A specialized OutputStream
for class for writing content to an
(internal) byte array.
- FastByteArrayOutputStream() - Constructor for class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Constructs a new ByteArrayOutputStream with a default size of 32 bytes.
- FastByteArrayOutputStream(int) - Constructor for class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Constructs a new ByteArrayOutputStream
with a default size of
size
bytes.
- 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.statements.Selectable.WithFieldSelection
-
- fieldName(int) - Method in class org.apache.cassandra.db.marshal.UserType
-
- fieldNames() - Method in class org.apache.cassandra.db.marshal.UserType
-
- 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 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- FILE - Static variable in class org.apache.cassandra.cli.CliParser
-
- 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
-
- 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, long, List<Pair<Long, Long>>, CompressionInfo, long) - Constructor for class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- FileMessageHeader(UUID, int, String, long, List<Pair<Long, Long>>, CompressionMetadata, long) - Constructor for class org.apache.cassandra.streaming.messages.FileMessageHeader
-
- filename - Variable in class org.apache.cassandra.cli.CliSessionState
-
- 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
-
- files - Variable in class org.apache.cassandra.streaming.StreamSummary
-
Number of files to transfer.
- 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
-
- FileUtils() - Constructor for class org.apache.cassandra.io.util.FileUtils
-
- 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
-
- 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
-
- 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
- finalizeMetadata(String, double, long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- finalState - Variable in exception org.apache.cassandra.streaming.StreamException
-
- 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(SemanticVersion...) - Method in class org.apache.cassandra.utils.SemanticVersion
-
Returns a version that is backward compatible with this version amongst a list
of provided version, or null if none can be found.
- finish - Variable in class org.apache.cassandra.db.filter.ColumnSlice
-
- finish() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- finish() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
- finish(long) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
-
Finishes the new file(s)
Creates final files, adds the new files to the dataTracker (via replaceReader).
- finish(SSTableWriter.FinishType, long, long) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- finish(long, boolean) - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile.Builder.Boundaries
-
- finishAddingAtoms() - Method in class org.apache.cassandra.db.ColumnIndex.Builder
-
- finishBootstrapping() - Method in class org.apache.cassandra.service.StorageService
-
- finishCompaction(CompactionInfo.Holder) - Method in interface org.apache.cassandra.db.compaction.CompactionManager.CompactionExecutorStatsCollector
-
- finishCompaction(CompactionInfo.Holder) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.StatsCollector
-
- finishCompaction(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
- finishLocalSampling(String, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- finishLocalSampling(String, int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
- finishParentSession(UUID, Set<InetAddress>, boolean) - 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() - Method in class org.apache.cassandra.gms.Gossiper
-
- finishStartup() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- 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
- 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.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
-
- 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
-
- 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.cql.CqlLexer
-
- FLOAT - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FLOAT - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- FLOAT - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- floatingPoint(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
-
- 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.io.compress.CompressedSequentialWriter
-
- flush() - Method in class org.apache.cassandra.io.util.DataOutputStreamPlus
-
- flush() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
If buffer is dirty, flush it's contents to the operating system.
- 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
- 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
-
- flushRunnable() - Method in class org.apache.cassandra.db.Memtable
-
- 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_111_in_functionCall3985 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_112_in_functionCall3990 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_113_in_arrayConstruct3206 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_113_in_hashConstruct3254 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_114_in_dropIndex2678 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_114_in_host_name4132 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_115_in_connectStatement695 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_115_in_connectStatement741 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_116_in_hashElementPair3298 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_116_in_keyRangeExpr3454 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_119_in_keyValuePair3116 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_119_in_setStatement1960 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_119_in_setStatement1971 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_122_in_helpStatement1652 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_123_in_assumeStatement2325 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_123_in_consistencyLevelStatement2367 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_123_in_getStatement1729 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_124_in_helpStatement1045 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_124_in_showClusterName2407 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_125_in_describeCluster2872 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_125_in_helpStatement963 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_126_in_columnLimitExpr3539 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_127_in_reversedExpr3583 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_128_in_getStatement1789 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_129_in_arrayConstruct3201 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_129_in_columnFamilyExpr3337 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_129_in_columnFamilyExpr3354 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_129_in_columnFamilyExpr3376 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_129_in_keyRangeExpr3445 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_130_in_arrayConstruct3211 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_130_in_columnFamilyExpr3341 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_130_in_columnFamilyExpr3360 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_130_in_columnFamilyExpr3382 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_130_in_keyRangeExpr3464 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_131_in_hashConstruct3249 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_132_in_hashConstruct3260 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_141_in_relationType6907 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_cfamColumns2443 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_cfamDefinition2338 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_cfamProperty2560 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_createIndexStatement2805 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_createTypeStatement2687 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_function6078 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_function6112 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_indexIdent2904 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_indexIdent2922 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_insertStatement1431 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_insertStatement1475 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_pkDef2490 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_relation7090 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_relation7298 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_selectionFunctionArgs1199 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_selectionFunctionArgs1211 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_selectStatement777 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_singleColumnInValues7419 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_term6258 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_tupleLiteral5721 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_tupleOfIdentifiers7370 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_tupleOfMarkersForTuples7561 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_tupleOfTupleLiterals7475 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_unaliasedSelector1074 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_142_in_unaliasedSelector1114 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_cfamColumns2460 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_cfamDefinition2354 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_cfamProperty2573 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_createIndexStatement2811 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_createTypeStatement2703 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_function6080 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_function6118 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_indexIdent2910 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_indexIdent2928 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_insertStatement1453 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_insertStatement1496 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_pkDef2513 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_relation7092 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_relation7303 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_selectionFunctionArgs1201 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_selectionFunctionArgs1248 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_selectStatement783 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_singleColumnInValues7445 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_term6264 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_tupleLiteral5742 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_tupleOfIdentifiers7389 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_tupleOfMarkersForTuples7580 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_tupleOfTupleLiterals7494 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_unaliasedSelector1080 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_143_in_unaliasedSelector1120 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_144_in_normalColumnOperation6355 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_cfamColumns2449 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_cfamDefinition2345 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_cfamProperty2566 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_collection_type7985 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_collectionLiteral5544 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_createTypeStatement2694 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_deleteSelection1933 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_functionArgs6157 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_insertStatement1442 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_insertStatement1485 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_mapLiteral5367 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_pkDef2502 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_selectClause929 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_selectionFunctionArgs1231 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_selectStatement847 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_setOrMapLiteral5437 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_setOrMapLiteral5482 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_singleColumnInValues7432 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_tuple_type8097 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_tupleLiteral5731 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_tupleOfIdentifiers7379 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_tupleOfMarkersForTuples7570 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_tupleOfTupleLiterals7484 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_updateStatement1675 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_145_in_usertypeLiteral5667 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_146_in_constant5299 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_147_in_columnFamilyName4898 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_147_in_indexName4859 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_147_in_unaliasedSelector1167 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_147_in_userTypeName4929 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_148_in_inMarker7334 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_148_in_inMarkerForTuple7611 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_148_in_intValue5937 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_148_in_mapLiteral5357 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_148_in_mapLiteral5373 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_148_in_markerForTuple7525 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_148_in_setOrMapLiteral5417 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_148_in_setOrMapLiteral5443 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_148_in_usertypeLiteral5657 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_148_in_usertypeLiteral5673 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_148_in_value5855 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_149_in_batchStatement2114 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_149_in_query75 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_150_in_collection_type7979 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_150_in_collection_type8011 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_150_in_collection_type8038 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_150_in_comparatorType7698 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_150_in_relationType6865 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_150_in_tuple_type8077 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_151_in_relationType6876 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_152_in_columnOperationDifferentiator6312 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_152_in_property6762 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_152_in_property6780 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_152_in_relationType6854 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_152_in_specializedColumnOperation6442 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_153_in_collection_type7991 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_153_in_collection_type8017 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_153_in_collection_type8044 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_153_in_comparatorType7704 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_153_in_relationType6886 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_153_in_tuple_type8113 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_154_in_relationType6897 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_155_in_collectionLiteral5520 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_155_in_columnCondition6577 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_155_in_columnOperationDifferentiator6323 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_155_in_deleteOp1993 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_156_in_selectClause945 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_156_in_selectCountClause1271 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_157_in_collectionLiteral5564 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_157_in_columnCondition6583 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_157_in_columnOperationDifferentiator6329 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_157_in_deleteOp1999 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_158_in_collectionLiteral5574 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_158_in_collectionLiteral5605 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_158_in_mapLiteral5337 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_158_in_usertypeLiteral5651 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_159_in_collectionLiteral5587 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_159_in_collectionLiteral5607 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_159_in_mapLiteral5393 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_159_in_usertypeLiteral5684 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_81_in_createColumnFamilyStatement1897 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_81_in_createIndexStatement2177 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_81_in_deleteStatement1637 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_81_in_insertStatement841 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_81_in_insertStatement883 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_81_in_selectStatement339 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_81_in_updateStatement1424 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_81_in_whereClause713 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_82_in_createColumnFamilyStatement1912 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_82_in_createIndexStatement2183 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_82_in_deleteStatement1645 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_82_in_insertStatement861 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_82_in_insertStatement901 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_82_in_selectStatement345 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_82_in_updateStatement1432 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_82_in_whereClause751 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_83_in_termPairWithOperation3001 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_84_in_createColumnFamilyStatement1904 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_84_in_insertStatement849 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_84_in_insertStatement891 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_84_in_selectExpression579 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_84_in_termList2881 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_84_in_updateStatement1314 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_84_in_whereClause740 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_85_in_termPairWithOperation3042 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_86_in_deleteStatement1523 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_86_in_insertStatement811 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_86_in_selectStatement388 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_86_in_truncateStatement3185 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_86_in_updateStatement1260 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_87_in_batchStatement1123 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_87_in_batchStatement1134 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_87_in_endStmnt3224 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_90_in_alterTableStatement2586 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_90_in_alterTableStatement2623 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_90_in_createColumnFamilyStatement1937 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_90_in_createColumnFamilyStatement1969 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_90_in_createKeyspaceStatement1753 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_90_in_createKeyspaceStatement1799 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_90_in_deleteStatement1580 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_90_in_termPair2914 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_90_in_termPairWithOperation2967 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_90_in_updateStatement1340 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_93_in_selectExpression617 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_addColumnFamily_in_statement518 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_addKeyspace_in_statement510 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_alterKeyspaceStatement_in_cqlStatement425 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_alterTableStatement_in_cqlStatement405 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_alterTableStatement_in_query214 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_alterTypeStatement_in_cqlStatement646 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_alterUserStatement_in_cqlStatement526 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_AND_in_getStatement1794 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_AND_in_keyValuePairExpr3050 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_API_VERSION_in_helpStatement1134 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_API_VERSION_in_showVersion2717 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_arrayConstruct_in_attrValue3150 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_ASSUME_in_assumeStatement2317 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_ASSUME_in_helpStatement1579 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_assumeStatement_in_statement646 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_attr_name_in_keyValuePair3114 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_attrValue_in_keyValuePair3118 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_attrValueDouble_in_attrValue3182 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_attrValueInt_in_attrValue3174 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_attrValueString_in_attrValue3166 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_basic_unreserved_keyword_in_non_type_ident8221 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_basic_unreserved_keyword_in_unreserved_function_keyword8331 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_batchStatement_in_cqlStatement188 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_batchStatement_in_query105 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_batchStatementObjective_in_batchStatement1121 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_batchStatementObjective_in_batchStatement1132 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_batchStatementObjective_in_batchStatement2112 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_BOOLEAN_in_constant5240 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_BY_in_incrStatement2026 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_BY_in_incrStatement2069 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_cfamColumns_in_cfamDefinition2340 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cfamColumns_in_cfamDefinition2347 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cfamDefinition_in_createTableStatement2319 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cfamOrdering_in_cfamProperty2562 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cfamOrdering_in_cfamProperty2568 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cfamProperty_in_cfamDefinition2366 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cfamProperty_in_cfamDefinition2373 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cfName_in_columnFamilyName4902 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_alterTableStatement3186 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_alterTableStatement3214 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_alterTableStatement3246 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_alterTableStatement3376 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_alterTableStatement3382 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_alterTableStatement3407 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_alterTableStatement3413 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_columnCondition6479 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_columnOperation6291 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_createTriggerStatement2982 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_deleteOp1964 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_deleteOp1991 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_dropTriggerStatement3061 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_indexIdent2877 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_indexIdent2908 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_indexIdent2926 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_insertStatement1435 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_insertStatement1446 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_normalColumnOperation6359 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_normalColumnOperation6380 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_normalColumnOperation6412 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_orderByClause1366 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_relation6929 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_relation6979 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_relation7005 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_relation7031 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_tupleOfIdentifiers7374 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_tupleOfIdentifiers7383 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_unaliasedSelector1026 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_unaliasedSelector1078 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_unaliasedSelector1118 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_cident_in_unaliasedSelector1171 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_collection_type_in_comparatorType7656 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_collectionLiteral_in_value5787 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_COLUMN_in_addColumnFamily2478 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_COLUMN_in_delColumnFamily2632 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_COLUMN_in_helpStatement1219 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_COLUMN_in_helpStatement1250 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_COLUMN_in_helpStatement1309 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_COLUMN_in_updateColumnFamily2555 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnCondition_in_updateConditions1756 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_columnCondition_in_updateConditions1763 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_columnFamily_in_assumeStatement2319 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnFamily_in_columnFamilyExpr3335 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnFamily_in_delColumnFamily2636 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnFamily_in_dropIndex2676 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnFamily_in_getStatement1787 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnFamily_in_listStatement2231 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnFamily_in_truncateStatement2284 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnFamilyExpr_in_countStatement2118 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnFamilyExpr_in_delStatement2154 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnFamilyExpr_in_getStatement1726 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnFamilyExpr_in_incrStatement2023 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnFamilyExpr_in_incrStatement2066 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnFamilyExpr_in_setStatement1958 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnFamilyName_in_alterTableStatement3168 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_columnFamilyName_in_createIndexStatement2803 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_columnFamilyName_in_createTableStatement2309 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_columnFamilyName_in_createTriggerStatement2997 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_columnFamilyName_in_dataResource4346 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_columnFamilyName_in_deleteStatement1823 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_columnFamilyName_in_dropTableStatement3748 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_columnFamilyName_in_dropTriggerStatement3068 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_columnFamilyName_in_insertStatement1419 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_columnFamilyName_in_selectStatement811 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_columnFamilyName_in_truncateStatement3888 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_columnFamilyName_in_updateStatement1647 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_columnLimitExpr_in_listStatement2239 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnName_in_dropIndex2680 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnOperation_in_updateStatement1671 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_columnOperation_in_updateStatement1677 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_columnOperationDifferentiator_in_columnOperation6293 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_columnOrSuperColumn_in_columnFamilyExpr3358 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnOrSuperColumn_in_columnFamilyExpr3380 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_columnOrSuperColumn_in_getCondition1856 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_comparatorType_in_alterTableStatement2418 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_comparatorType_in_alterTableStatement2490 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_comparatorType_in_alterTableStatement3192 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_comparatorType_in_alterTableStatement3218 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_comparatorType_in_alterTypeStatement3489 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_comparatorType_in_alterTypeStatement3515 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_comparatorType_in_cfamColumns2403 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_comparatorType_in_collection_type7983 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_comparatorType_in_collection_type7989 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_comparatorType_in_collection_type8015 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_comparatorType_in_collection_type8042 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_comparatorType_in_comparatorType7702 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_comparatorType_in_createCfamColumnValidator2062 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_comparatorType_in_createCfamKeywordArgument2095 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_comparatorType_in_term6262 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_comparatorType_in_tuple_type8092 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_comparatorType_in_tuple_type8101 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_comparatorType_in_typeColumns2727 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_CONNECT_in_connectStatement691 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_CONNECT_in_connectStatement737 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_CONNECT_in_helpStatement821 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_connectStatement_in_statement470 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_CONSISTENCYLEVEL_in_consistencyLevelStatement2365 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_CONSISTENCYLEVEL_in_helpStatement1605 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_consistencyLevelStatement_in_statement654 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_constant_in_propertyValue6809 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_constant_in_value5765 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_COUNT_in_countStatement2116 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_COUNT_in_helpStatement1499 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_countStatement_in_statement486 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_cqlStatement_in_query72 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_CREATE_in_addColumnFamily2476 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_CREATE_in_addKeyspace2438 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_CREATE_in_helpStatement1160 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_CREATE_in_helpStatement1217 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_createCfamColumns_in_createColumnFamilyStatement1899 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_createCfamColumns_in_createColumnFamilyStatement1906 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_createCfamColumnValidator_in_createCfamColumns2019 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_createCfamColumnValidator_in_createCfamColumns2035 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_createCfamKeywordArgument_in_alterTableStatement2590 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_createCfamKeywordArgument_in_alterTableStatement2627 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_createCfamKeywordArgument_in_createColumnFamilyStatement1941 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_createCfamKeywordArgument_in_createColumnFamilyStatement1973 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_createColumnFamilyStatement_in_query162 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_createIndexStatement_in_cqlStatement326 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_createIndexStatement_in_query172 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_createKeyspaceStatement_in_cqlStatement290 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_createKeyspaceStatement_in_query152 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_createTableStatement_in_cqlStatement307 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_createTriggerStatement_in_cqlStatement590 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_createTypeStatement_in_cqlStatement626 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_createUserStatement_in_cqlStatement506 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_dataResource_in_resource4284 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_DECR_in_helpStatement1446 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_DECR_in_incrStatement2064 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_DEL_in_delStatement2152 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_DEL_in_helpStatement1472 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_delColumnFamily_in_statement542 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_deleteOp_in_deleteSelection1918 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_deleteOp_in_deleteSelection1937 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_deleteSelection_in_deleteStatement1806 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_deleteStatement_in_batchStatementObjective1209 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_deleteStatement_in_batchStatementObjective2187 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_deleteStatement_in_cqlStatement214 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_deleteStatement_in_query140 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_delKeyspace_in_statement550 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_delStatement_in_statement582 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_DESCRIBE_in_describeCluster2870 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_DESCRIBE_in_describeTable2825 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_DESCRIBE_in_helpStatement935 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_DESCRIBE_in_helpStatement961 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_describeCluster_in_statement502 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_describeTable_in_statement494 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_DoubleLiteral_in_attrValueDouble3694 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_DoubleLiteral_in_tracingProbability4254 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_DROP_in_delColumnFamily2630 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_DROP_in_delKeyspace2592 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_DROP_in_dropIndex2670 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_DROP_in_helpStatement1278 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_DROP_in_helpStatement1307 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_DROP_in_helpStatement1338 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_dropColumnFamilyStatement_in_query204 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_dropIndex_in_statement662 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_dropIndexStatement_in_cqlStatement384 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_dropIndexStatement_in_query182 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_dropKeyspaceStatement_in_cqlStatement345 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_dropKeyspaceStatement_in_query194 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_dropTableStatement_in_cqlStatement363 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_dropTriggerStatement_in_cqlStatement607 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_dropTypeStatement_in_cqlStatement667 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_dropUserStatement_in_cqlStatement547 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_endStmnt_in_alterTableStatement2640 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_endStmnt_in_batchStatement1152 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_endStmnt_in_createColumnFamilyStatement1995 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_endStmnt_in_createIndexStatement2185 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_endStmnt_in_createKeyspaceStatement1832 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_endStmnt_in_dropColumnFamilyStatement2691 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_endStmnt_in_dropIndexStatement2241 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_endStmnt_in_dropKeyspaceStatement2292 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_endStmnt_in_query142 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_endStmnt_in_query83 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_endStmnt_in_query95 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_endStmnt_in_selectStatement483 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_endStmnt_in_truncateStatement3207 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_endStmnt_in_useStatement258 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_entityName_in_assumeStatement2327 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_entityName_in_columnFamily3821 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_entityName_in_columnName3611 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_entityName_in_keyRangeExpr3451 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_entityName_in_keyRangeExpr3458 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_entityName_in_keyspace3710 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_entityName_in_keyspaceNewName3738 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_entityName_in_keyValuePairExpr3045 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_entityName_in_newColumnFamily3785 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_EOF_in_endStmnt3228 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_EOF_in_query79 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_EOF_in_root454 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_EXIT_in_exitStatement1701 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_EXIT_in_helpStatement989 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_exitStatement_in_statement478 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_FAMILY_in_addColumnFamily2480 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_FAMILY_in_delColumnFamily2634 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_FAMILY_in_helpStatement1221 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_FAMILY_in_helpStatement1252 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_FAMILY_in_helpStatement1311 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_FAMILY_in_updateColumnFamily2557 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_FLOAT_in_constant5219 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_FLOAT_in_term2818 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_function_in_term6226 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_functionArgs_in_function6116 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_functionArgument_in_functionCall3987 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_functionCall_in_columnOrSuperColumn4074 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_functionCall_in_rowKey3882 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_functionCall_in_rowValue3920 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_functionCall_in_value3962 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_functionName_in_function6076 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_functionName_in_function6110 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_functionName_in_unaliasedSelector1148 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_GET_in_getStatement1724 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_GET_in_getStatement1785 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_GET_in_helpStatement1366 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_getCondition_in_getStatement1791 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_getCondition_in_getStatement1796 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_getStatement_in_statement590 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_grantStatement_in_cqlStatement442 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_hashConstruct_in_arrayConstruct3204 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_hashConstruct_in_attrValue3158 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_hashConstruct_in_rowValue3924 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_hashElementPair_in_hashConstruct3251 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_hashElementPair_in_hashConstruct3256 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1014 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1041 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1069 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1098 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1130 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1158 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1187 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1215 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1246 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1276 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1305 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1336 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1364 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1391 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1418 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1444 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1470 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1497 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1524 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1551 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1577 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1603 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement1629 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement792 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement794 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement819 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement846 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement873 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement903 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement933 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement959 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HELP_in_helpStatement987 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_helpStatement_in_statement598 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_HEXNUMBER_in_constant5281 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_host_in_connectStatement693 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_host_name_in_host4096 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_ident_in_alterTypeStatement3483 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_alterTypeStatement3511 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_alterTypeStatement3576 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_alterTypeStatement3582 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_alterTypeStatement3609 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_alterTypeStatement3615 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_cfamColumns2399 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_cfamColumns2453 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_cfamOrdering2601 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_IDENT_in_cfName5033 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_IDENT_in_cident4675 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_IDENT_in_createIndexStatement2155 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_IDENT_in_functionName5985 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_IDENT_in_ident4745 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_IDENT_in_idxName5109 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_inMarker7338 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_inMarkerForTuple7615 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_intValue5941 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_IDENT_in_ksName4957 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_markerForTuple7529 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_IDENT_in_non_type_ident8165 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_pkDef2480 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_pkDef2496 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_pkDef2506 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_property6760 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_property6778 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_selector985 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_selectStatement792 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_IDENT_in_term2812 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_ident_in_typeColumns2723 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_usertypeLiteral5655 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_usertypeLiteral5671 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_userTypeName4927 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ident_in_value5859 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_Identifier_in_assumeStatement2323 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_Identifier_in_attr_name3625 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_Identifier_in_columnOrSuperColumn4058 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_Identifier_in_command3771 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_Identifier_in_consistencyLevelStatement2371 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_Identifier_in_functionCall3983 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_Identifier_in_host_name4129 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_Identifier_in_host_name4134 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_Identifier_in_rowKey3866 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_Identifier_in_rowValue3904 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_Identifier_in_traceSessionId4237 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_Identifier_in_username3794 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_Identifier_in_value3946 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_idxName_in_createIndexStatement2794 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_idxName_in_indexName4863 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_INCR_in_helpStatement1420 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_INCR_in_incrStatement2021 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_incrementValue_in_incrStatement2030 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_incrementValue_in_incrStatement2073 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_incrStatement_in_statement614 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_INDEX_in_dropIndex2672 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_INDEX_in_helpStatement1340 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_indexIdent_in_createIndexStatement2809 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_indexName_in_dropIndexStatement3848 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_inMarker_in_columnCondition6549 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_inMarker_in_columnCondition6669 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_inMarker_in_relation6985 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_inMarkerForTuple_in_relation7124 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_insertStatement_in_batchStatementObjective1183 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_insertStatement_in_batchStatementObjective2161 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_insertStatement_in_cqlStatement138 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_insertStatement_in_query81 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_INTEGER_in_constant5200 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_INTEGER_in_intTerm2943 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_INTEGER_in_intValue5923 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_INTEGER_in_normalColumnOperation6416 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_INTEGER_in_selectCountClause1293 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_INTEGER_in_selectExpression530 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_INTEGER_in_selectStatement466 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_INTEGER_in_term2800 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_INTEGER_in_usingClauseDeleteObjective1024 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_INTEGER_in_usingClauseObjective1057 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_IntegerNegativeLiteral_in_columnOrSuperColumn4066 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_IntegerNegativeLiteral_in_rowKey3878 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_IntegerNegativeLiteral_in_rowValue3916 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_IntegerNegativeLiteral_in_value3954 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_IntegerPositiveLiteral_in_columnLimitExpr3543 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_IntegerPositiveLiteral_in_columnOrSuperColumn4062 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_IntegerPositiveLiteral_in_getStatement1740 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_IntegerPositiveLiteral_in_getStatement1805 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_IntegerPositiveLiteral_in_port4195 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_IntegerPositiveLiteral_in_rowKey3874 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_IntegerPositiveLiteral_in_rowLimitExpr3505 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_IntegerPositiveLiteral_in_rowValue3912 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_IntegerPositiveLiteral_in_setStatement1975 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_IntegerPositiveLiteral_in_value3950 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_intTerm_in_termPairWithOperation3047 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_intValue_in_selectStatement870 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_intValue_in_usingClauseDelete2025 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_intValue_in_usingClauseObjective1595 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_intValue_in_usingClauseObjective1609 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ip_address_in_connectStatement739 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_IP_ADDRESS_in_ip_address4157 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_K_ADD_in_alterTableStatement2434 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_ADD_in_alterTableStatement3208 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ADD_in_alterTypeStatement3505 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ALL_in_dataResource4307 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ALL_in_permissionOrAll4227 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ALLOW_in_selectStatement885 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ALTER_in_alterKeyspaceStatement3108 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ALTER_in_alterTableStatement2326 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_ALTER_in_alterTableStatement2360 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_ALTER_in_alterTableStatement3162 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ALTER_in_alterTableStatement3182 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ALTER_in_alterTypeStatement3459 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ALTER_in_alterTypeStatement3479 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ALTER_in_alterUserStatement4478 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_AND_in_alterTableStatement2611 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_AND_in_alterTableStatement3403 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_AND_in_alterTypeStatement3605 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_AND_in_cfamDefinition2371 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_AND_in_createColumnFamilyStatement1957 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_AND_in_createKeyspaceStatement1785 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_AND_in_properties6735 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_AND_in_updateConditions1761 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_AND_in_usingClause1567 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_AND_in_usingClause950 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_AND_in_usingClauseDelete982 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_AND_in_whereClause1333 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_AND_in_whereClause676 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_APPLY_in_batchStatement1148 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_APPLY_in_batchStatement2128 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_AS_in_selector981 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_AS_in_selectStatement788 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ASC_in_cfamOrdering2604 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ASC_in_orderByClause1371 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ASCII_in_native_type7751 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_BATCH_in_batchStatement1099 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_BATCH_in_batchStatement1150 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_BATCH_in_batchStatement2088 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_BATCH_in_batchStatement2130 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_BEGIN_in_batchStatement1097 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_BEGIN_in_batchStatement2059 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_BIGINT_in_native_type7765 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_BLOB_in_native_type7778 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_BOOLEAN_in_native_type7793 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_BY_in_cfamProperty2558 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_BY_in_selectStatement840 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_CLUSTERING_in_cfamProperty2554 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_COLUMNFAMILY_in_alterTableStatement2328 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_COLUMNFAMILY_in_alterTableStatement3164 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_COLUMNFAMILY_in_createColumnFamilyStatement1869 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_COLUMNFAMILY_in_createTableStatement2287 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_COLUMNFAMILY_in_dataResource4337 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_COLUMNFAMILY_in_dropColumnFamilyStatement2673 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_COLUMNFAMILY_in_dropTableStatement3734 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_COLUMNFAMILY_in_truncateStatement3882 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_COMPACT_in_cfamProperty2542 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_CONSISTENCY_in_selectStatement422 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_CONSISTENCY_in_usingClauseDeleteObjective1007 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_CONTAINS_in_relation7033 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_COUNT_in_selectStatement337 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_COUNT_in_selectStatement775 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_COUNTER_in_batchStatement2075 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_COUNTER_in_native_type7805 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_CREATE_in_createColumnFamilyStatement1867 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_CREATE_in_createIndexStatement2148 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_CREATE_in_createIndexStatement2762 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_CREATE_in_createKeyspaceStatement1708 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_CREATE_in_createKeyspaceStatement2222 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_CREATE_in_createTableStatement2285 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_CREATE_in_createTriggerStatement2963 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_CREATE_in_createTypeStatement2647 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_CREATE_in_createUserStatement4386 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_CUSTOM_in_createIndexStatement2765 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_DECIMAL_in_native_type7817 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_DELETE_in_deleteStatement1474 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_DELETE_in_deleteStatement1800 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_DESC_in_cfamOrdering2608 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_DESC_in_orderByClause1375 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_DISTINCT_in_selectStatement746 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_DOUBLE_in_native_type7829 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_DROP_in_alterTableStatement2506 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_DROP_in_alterTableStatement3241 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_DROP_in_dropColumnFamilyStatement2671 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_DROP_in_dropIndexStatement2221 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_DROP_in_dropIndexStatement3832 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_DROP_in_dropKeyspaceStatement2272 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_DROP_in_dropKeyspaceStatement3682 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_DROP_in_dropTableStatement3732 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_DROP_in_dropTriggerStatement3044 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_DROP_in_dropTypeStatement3782 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_DROP_in_dropUserStatement4559 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_EXISTS_in_createIndexStatement2778 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_EXISTS_in_createKeyspaceStatement2231 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_EXISTS_in_createTableStatement2294 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_EXISTS_in_createTriggerStatement2972 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_EXISTS_in_createTypeStatement2656 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_EXISTS_in_createUserStatement4395 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_EXISTS_in_deleteStatement1863 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_EXISTS_in_dropIndexStatement3839 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_EXISTS_in_dropKeyspaceStatement3689 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_EXISTS_in_dropTableStatement3739 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_EXISTS_in_dropTriggerStatement3051 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_EXISTS_in_dropTypeStatement3789 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_EXISTS_in_dropUserStatement4566 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_EXISTS_in_insertStatement1513 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_EXISTS_in_updateStatement1706 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_FILTERING_in_selectStatement887 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_FIRST_in_selectExpression524 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_FLOAT_in_native_type7842 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_FROM_in_deleteStatement1506 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_FROM_in_deleteStatement1819 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_FROM_in_revokeStatement4036 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_FROM_in_selectStatement371 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_FROM_in_selectStatement807 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_FROZEN_in_comparatorType7696 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_FULL_in_indexIdent2920 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_GRANT_in_grantStatement3913 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IF_in_createIndexStatement2774 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IF_in_createKeyspaceStatement2227 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IF_in_createTableStatement2290 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IF_in_createTriggerStatement2968 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IF_in_createTypeStatement2652 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IF_in_createUserStatement4391 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IF_in_deleteStatement1859 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IF_in_dropIndexStatement3837 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IF_in_dropKeyspaceStatement3687 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IF_in_dropTableStatement3737 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IF_in_dropTriggerStatement3049 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IF_in_dropTypeStatement3787 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IF_in_dropUserStatement4564 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IF_in_insertStatement1509 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IF_in_updateStatement1702 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IN_in_columnCondition6511 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IN_in_columnCondition6623 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IN_in_deleteStatement1635 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_IN_in_relation6981 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IN_in_relation7007 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IN_in_relation7076 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_IN_in_updateStatement1422 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_IN_in_whereClause711 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_INDEX_in_createIndexStatement2150 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_INDEX_in_createIndexStatement2771 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_INDEX_in_dropIndexStatement2223 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_INDEX_in_dropIndexStatement3834 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_INET_in_native_type7856 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_INSERT_in_insertStatement1413 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_INSERT_in_insertStatement792 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_INT_in_native_type7871 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_INTO_in_insertStatement1415 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_INTO_in_insertStatement794 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_KEY_in_cfamColumns2427 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_KEY_in_cfamColumns2441 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_KEY_in_createCfamColumns2039 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_KEY_in_non_type_ident8233 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_KEY_in_relation7038 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_KEY_in_term2788 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_KEYS_in_indexIdent2902 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_KEYSPACE_in_alterKeyspaceStatement3110 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_KEYSPACE_in_createKeyspaceStatement1710 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_KEYSPACE_in_createKeyspaceStatement2224 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_KEYSPACE_in_dataResource4319 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_KEYSPACE_in_dropKeyspaceStatement2274 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_KEYSPACE_in_dropKeyspaceStatement3684 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_KEYSPACES_in_dataResource4309 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_LEVEL_in_selectStatement424 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_LEVEL_in_usingClauseDeleteObjective1009 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_LIMIT_in_selectStatement462 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_LIMIT_in_selectStatement866 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_LIST_in_collection_type8009 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_LIST_in_listPermissionsStatement4086 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_LIST_in_listUsersStatement4597 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_MAP_in_collection_type7976 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_NORECURSIVE_in_listPermissionsStatement4142 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_NOSUPERUSER_in_alterUserStatement4514 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_NOSUPERUSER_in_createUserStatement4433 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_NOT_in_createIndexStatement2776 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_NOT_in_createKeyspaceStatement2229 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_NOT_in_createTableStatement2292 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_NOT_in_createTriggerStatement2970 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_NOT_in_createTypeStatement2654 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_NOT_in_createUserStatement4393 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_NOT_in_insertStatement1511 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_NULL_in_value5831 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_OF_in_listPermissionsStatement4125 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ON_in_createIndexStatement2159 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_ON_in_createIndexStatement2799 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ON_in_createTriggerStatement2993 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ON_in_dropTriggerStatement3064 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ON_in_grantStatement3933 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ON_in_listPermissionsStatement4108 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ON_in_revokeStatement4016 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ORDER_in_cfamProperty2556 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_ORDER_in_selectStatement838 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_PASSWORD_in_userOption4640 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_PERMISSION_in_permissionOrAll4256 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_PERMISSIONS_in_permissionOrAll4231 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_PRIMARY_in_cfamColumns2425 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_PRIMARY_in_cfamColumns2439 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_PRIMARY_in_createCfamColumns2037 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_RENAME_in_alterTableStatement3322 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_RENAME_in_alterTypeStatement3538 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_REVERSED_in_selectExpression545 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_REVOKE_in_revokeStatement3996 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_SELECT_in_selectStatement289 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_SELECT_in_selectStatement740 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_SET_in_collection_type8035 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_SET_in_updateStatement1308 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_SET_in_updateStatement1669 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_STATIC_in_alterTableStatement3223 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_STATIC_in_cfamColumns2408 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_STORAGE_in_cfamProperty2544 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_SUPERUSER_in_alterUserStatement4508 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_SUPERUSER_in_createUserStatement4427 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TEXT_in_native_type7887 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TIMESTAMP_in_native_type7902 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TIMESTAMP_in_usingClauseDelete2021 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TIMESTAMP_in_usingClauseDeleteObjective1020 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_TIMESTAMP_in_usingClauseObjective1591 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TIMEUUID_in_native_type7952 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TO_in_alterTableStatement3378 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TO_in_alterTableStatement3409 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TO_in_alterTypeStatement3578 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TO_in_alterTypeStatement3611 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TO_in_grantStatement3953 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TOKEN_in_functionName6029 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TOKEN_in_relation6947 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TRIGGER_in_createTriggerStatement2965 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TRIGGER_in_dropTriggerStatement3046 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TRUNCATE_in_truncateStatement3166 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_TRUNCATE_in_truncateStatement3879 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TTL_in_unaliasedSelector1106 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TTL_in_usingClauseObjective1053 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_TTL_in_usingClauseObjective1605 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TUPLE_in_tuple_type8075 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TYPE_in_alterTableStatement2414 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_TYPE_in_alterTableStatement3188 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TYPE_in_alterTypeStatement3461 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TYPE_in_alterTypeStatement3485 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TYPE_in_createTypeStatement2649 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_TYPE_in_dropTypeStatement3784 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_UNLOGGED_in_batchStatement2069 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_UPDATE_in_updateStatement1243 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_UPDATE_in_updateStatement1643 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_USE_in_useStatement238 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_USE_in_useStatement702 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_USER_in_alterUserStatement4480 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_USER_in_createUserStatement4388 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_USER_in_dropUserStatement4561 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_USERS_in_listUsersStatement4599 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_USING_in_createIndexStatement2822 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_USING_in_createTriggerStatement2999 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_USING_in_selectStatement420 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_USING_in_usingClause1560 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_USING_in_usingClause943 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_USING_in_usingClauseDelete2019 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_USING_in_usingClauseDelete975 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_UUID_in_native_type7912 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_VALUES_in_insertStatement1463 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_VALUES_in_insertStatement871 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_VARCHAR_in_native_type7927 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_VARINT_in_native_type7939 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_WHERE_in_deleteStatement1573 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_WHERE_in_deleteStatement1845 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_WHERE_in_selectStatement443 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_WHERE_in_selectStatement821 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_WHERE_in_updateStatement1331 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_WHERE_in_updateStatement1688 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_WITH_in_alterKeyspaceStatement3124 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_WITH_in_alterTableStatement2557 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_WITH_in_alterTableStatement3286 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_WITH_in_alterUserStatement4492 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_WITH_in_cfamDefinition2364 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_WITH_in_createColumnFamilyStatement1925 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_WITH_in_createIndexStatement2841 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_WITH_in_createKeyspaceStatement1738 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_K_WITH_in_createKeyspaceStatement2248 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_WITH_in_createUserStatement4411 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_K_WRITETIME_in_unaliasedSelector1072 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_keyRangeExpr_in_listStatement2233 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_KEYSPACE_in_addKeyspace2440 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_KEYSPACE_in_delKeyspace2594 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_keyspace_in_delKeyspace2596 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_keyspace_in_describeTable2828 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_KEYSPACE_in_helpStatement1162 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_KEYSPACE_in_helpStatement1191 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_KEYSPACE_in_helpStatement1280 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_keyspace_in_showSchema2787 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_KEYSPACE_in_updateKeyspace2518 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_keyspace_in_useKeyspace2905 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_keyspaceName_in_alterKeyspaceStatement3114 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_keyspaceName_in_createKeyspaceStatement2240 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_keyspaceName_in_dataResource4325 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_keyspaceName_in_dropKeyspaceStatement3698 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_keyspaceName_in_useStatement706 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_KEYSPACES_in_helpStatement1073 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_KEYSPACES_in_showKeyspaces2750 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_keyValuePair_in_keyValuePairExpr3057 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_keyValuePairExpr_in_addColumnFamily2482 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_keyValuePairExpr_in_addKeyspace2442 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_keyValuePairExpr_in_updateColumnFamily2559 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_keyValuePairExpr_in_updateKeyspace2520 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_ksName_in_columnFamilyName4895 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ksName_in_indexName4856 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ksName_in_keyspaceName4822 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_LIMIT_in_getStatement1736 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_LIMIT_in_getStatement1801 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_LIMIT_in_rowLimitExpr3501 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_LIST_in_helpStatement1526 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_LIST_in_listStatement2229 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_listPermissionsStatement_in_cqlStatement491 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_listStatement_in_statement630 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_listUsersStatement_in_cqlStatement569 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_mapLiteral_in_property6784 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_markerForTuple_in_relation7268 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_markerForTuple_in_tupleOfMarkersForTuples7565 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_markerForTuple_in_tupleOfMarkersForTuples7574 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_native_type_in_comparatorType7640 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_native_type_in_unreserved_function_keyword8343 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_NEXT_in_helpStatement877 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_NEXT_in_traceNextQuery2973 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_non_type_ident_in_userTypeName4935 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_normalColumnOperation_in_columnOperationDifferentiator6314 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_ON_in_dropIndex2674 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_operator_in_getCondition1858 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_orderByClause_in_selectStatement842 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_orderByClause_in_selectStatement849 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_password_in_connectStatement702 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_password_in_connectStatement748 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_password_in_useKeyspace2916 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_permission_in_permissionOrAll4252 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_permissionOrAll_in_grantStatement3925 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_permissionOrAll_in_listPermissionsStatement4098 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_permissionOrAll_in_revokeStatement4008 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_pkDef_in_cfamColumns2445 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_port_in_connectStatement697 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_port_in_connectStatement743 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_PROBABILITY_in_helpStatement909 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_PROBABILITY_in_setTraceProbability3010 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_properties_in_alterKeyspaceStatement3126 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_properties_in_alterTableStatement3289 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_properties_in_createIndexStatement2843 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_properties_in_createKeyspaceStatement2250 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_property_in_cfamProperty2533 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_property_in_properties6731 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_property_in_properties6737 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_propertyValue_in_property6766 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_QMARK_in_cfName5087 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_QMARK_in_idxName5163 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_QMARK_in_inMarker7324 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_QMARK_in_inMarkerForTuple7601 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_QMARK_in_intValue5952 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_QMARK_in_ksName5011 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_QMARK_in_markerForTuple7515 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_QMARK_in_term2835 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_QMARK_in_value5877 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_QUERY_in_helpStatement879 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_QUERY_in_traceNextQuery2975 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_QUIT_in_exitStatement1687 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_QUIT_in_helpStatement1016 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_QUOTED_NAME_in_cfName5058 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_QUOTED_NAME_in_cident4700 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_QUOTED_NAME_in_ident4770 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_QUOTED_NAME_in_idxName5134 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_QUOTED_NAME_in_ksName4982 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_QUOTED_NAME_in_non_type_ident8196 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_RANGEOP_in_selectExpression601 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_relation_in_relation7300 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_relation_in_whereClause1329 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_relation_in_whereClause1335 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_relation_in_whereClause660 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_relation_in_whereClause680 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_relationType_in_columnCondition6493 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_relationType_in_columnCondition6601 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_relationType_in_relation6933 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_relationType_in_relation6955 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_relationType_in_relation7234 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_relationType_in_relation7264 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_resource_in_grantStatement3945 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_resource_in_listPermissionsStatement4110 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_resource_in_revokeStatement4028 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_reversedExpr_in_columnLimitExpr3545 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_revokeStatement_in_cqlStatement467 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_rowKey_in_columnFamilyExpr3339 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_rowKey_in_hashElementPair3296 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_rowLimitExpr_in_listStatement2236 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_rowValue_in_hashElementPair3300 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_SCHEMA_in_helpStatement1102 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_SCHEMA_in_showSchema2784 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_selectClause_in_selectStatement755 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_selectCountClause_in_selectStatement781 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_selectExpression_in_selectStatement305 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_selectExpression_in_selectStatement343 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_selectionFunctionArgs_in_unaliasedSelector1152 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_selector_in_selectClause924 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_selector_in_selectClause933 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_selectStatement_in_cqlStatement113 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_selectStatement_in_query69 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_SEMICOLON_in_root451 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_set_in_alterTableStatement2332 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_alterTableStatement2382 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_alterTableStatement2456 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_alterTableStatement2528 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_alterTableStatement2578 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_alterTableStatement2615 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_basic_unreserved_keyword8381 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_set_in_constant5308 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_set_in_createCfamKeywordArgument2107 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_createColumnFamilyStatement1873 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_createColumnFamilyStatement1929 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_createColumnFamilyStatement1961 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_createIndexStatement2163 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_createKeyspaceStatement1714 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_createKeyspaceStatement1743 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_createKeyspaceStatement1757 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_createKeyspaceStatement1789 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_createKeyspaceStatement1803 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_deleteStatement1511 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_deleteStatement1529 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_dropColumnFamilyStatement2677 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_dropIndexStatement2227 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_dropKeyspaceStatement2278 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_SET_in_helpStatement1393 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_SET_in_helpStatement905 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_set_in_insertStatement799 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_insertStatement817 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_normalColumnOperation6384 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_set_in_permission4178 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_set_in_relation3114 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_selectStatement376 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_selectStatement394 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_SET_in_setStatement1956 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_SET_in_setTraceProbability3006 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_set_in_truncateStatement3171 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_truncateStatement3191 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_unreserved_keyword8292 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_set_in_updateStatement1248 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_updateStatement1266 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_set_in_useStatement242 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_setOrMapLiteral_in_collectionLiteral5582 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_setStatement_in_statement606 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_setTraceProbability_in_statement574 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_SHOW_in_helpStatement1043 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_SHOW_in_helpStatement1071 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_SHOW_in_helpStatement1100 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_SHOW_in_helpStatement1132 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_SHOW_in_showClusterName2405 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_SHOW_in_showKeyspaces2748 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_SHOW_in_showSchema2782 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_SHOW_in_showVersion2715 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_showClusterName_in_showStatement2188 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_showKeyspaces_in_showStatement2204 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_showSchema_in_showStatement2212 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_showStatement_in_statement622 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_showVersion_in_showStatement2196 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_singleColumnInValues_in_columnCondition6529 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_singleColumnInValues_in_columnCondition6645 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_singleColumnInValues_in_relation7011 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_specializedColumnOperation_in_columnOperationDifferentiator6331 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_statement_in_root449 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_STRING_LITERAL_in_comparatorType7722 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_STRING_LITERAL_in_constant5188 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_STRING_LITERAL_in_createCfamColumnValidator2072 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_STRING_LITERAL_in_createIndexStatement2826 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_STRING_LITERAL_in_createTriggerStatement3003 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_STRING_LITERAL_in_term2794 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_STRING_LITERAL_in_userOption4644 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_StringLiteral_in_columnOrSuperColumn4070 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_StringLiteral_in_comparator3752 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_StringLiteral_in_password3806 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_StringLiteral_in_replica_placement_strategy3724 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_StringLiteral_in_rowKey3870 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_StringLiteral_in_rowValue3908 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_StringLiteral_in_value3958 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_term_in_collectionLiteral5538 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_collectionLiteral5548 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_collectionLiteral5578 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_columnCondition6497 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_columnCondition6581 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_columnCondition6605 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_columnOperationDifferentiator6327 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_createCfamColumns2015 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_createCfamColumns2031 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_createIndexStatement2181 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_deleteOp1997 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_deleteStatement1577 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_deleteStatement1584 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_functionArgs6151 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_functionArgs6161 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_insertStatement1479 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_insertStatement1489 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_insertStatement845 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_insertStatement853 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_insertStatement887 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_insertStatement895 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_mapLiteral5355 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_mapLiteral5361 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_mapLiteral5371 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_mapLiteral5377 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_normalColumnOperation6352 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_normalColumnOperation6394 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_relation3110 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_relation3136 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_relation6937 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_relation6959 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_relation7054 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_selectExpression562 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_selectExpression583 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_selectExpression599 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_selectExpression605 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_setOrMapLiteral5421 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_setOrMapLiteral5441 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_setOrMapLiteral5447 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_setOrMapLiteral5486 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_singleColumnInValues7427 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_singleColumnInValues7436 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_specializedColumnOperation6446 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_term6268 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_termList2876 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_termList2885 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_termPair2912 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_termPair2918 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_termPairWithOperation2965 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_termPairWithOperation2972 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_termPairWithOperation2997 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_termPairWithOperation3006 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_tupleLiteral5725 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_tupleLiteral5735 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_updateStatement1337 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_updateStatement1344 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_usertypeLiteral5661 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_usertypeLiteral5677 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_term_in_whereClause696 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_whereClause717 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_term_in_whereClause744 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_termList_in_deleteStatement1490 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_termList_in_deleteStatement1641 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_termList_in_updateStatement1428 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_termPairWithOperation_in_updateStatement1310 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_termPairWithOperation_in_updateStatement1316 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_TRACE_in_helpStatement875 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_TRACE_in_helpStatement907 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_TRACE_in_setTraceProbability3008 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_TRACE_in_traceNextQuery2971 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_traceNextQuery_in_statement566 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_tracingProbability_in_setTraceProbability3012 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_TRUNCATE_in_helpStatement1553 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_TRUNCATE_in_truncateStatement2282 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_truncateStatement_in_cqlStatement267 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_truncateStatement_in_query130 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_truncateStatement_in_statement638 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_TTL_in_setStatement1969 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_tuple_type_in_comparatorType7668 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_tupleLiteral_in_relation7238 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_tupleLiteral_in_tupleOfTupleLiterals7479 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_tupleLiteral_in_tupleOfTupleLiterals7488 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_tupleLiteral_in_value5815 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_tupleOfIdentifiers_in_relation6951 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_tupleOfIdentifiers_in_relation7066 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_tupleOfMarkersForTuples_in_relation7192 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_tupleOfTupleLiterals_in_relation7158 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_typeColumns_in_createTypeStatement2689 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_typeColumns_in_createTypeStatement2696 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_typeIdentifier_in_getStatement1731 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_unaliasedSelector_in_selectionFunctionArgs1215 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_unaliasedSelector_in_selectionFunctionArgs1235 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_unaliasedSelector_in_selector978 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_unreserved_function_keyword_in_functionName6019 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_unreserved_function_keyword_in_unreserved_keyword8276 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_unreserved_keyword_in_cfName5077 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_unreserved_keyword_in_cident4719 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_unreserved_keyword_in_ident4789 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_unreserved_keyword_in_idxName5153 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_unreserved_keyword_in_ksName5001 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_unreserved_keyword_in_propertyValue6831 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_UPDATE_in_helpStatement1189 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_UPDATE_in_helpStatement1248 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_UPDATE_in_updateColumnFamily2553 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_UPDATE_in_updateKeyspace2516 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_updateColumnFamily_in_statement534 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_updateConditions_in_deleteStatement1871 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_updateConditions_in_updateStatement1714 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_updateKeyspace_in_statement526 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_updateStatement_in_batchStatementObjective1196 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_updateStatement_in_batchStatementObjective2174 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_updateStatement_in_cqlStatement163 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_updateStatement_in_query93 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_USE_in_helpStatement848 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_USE_in_useKeyspace2903 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_useKeyspace_in_statement558 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_username_in_alterUserStatement4482 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_username_in_connectStatement700 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_username_in_connectStatement746 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_username_in_createUserStatement4401 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_username_in_dropUserStatement4572 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_username_in_grantStatement3965 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_username_in_listPermissionsStatement4127 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_username_in_revokeStatement4048 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_username_in_useKeyspace2909 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_userOption_in_userOptions4619 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_userOptions_in_alterUserStatement4494 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_userOptions_in_createUserStatement4413 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_usertypeLiteral_in_value5800 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_userTypeName_in_alterTypeStatement3465 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_userTypeName_in_comparatorType7684 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_userTypeName_in_createTypeStatement2674 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_userTypeName_in_dropTypeStatement3798 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_useStatement_in_cqlStatement239 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_useStatement_in_query115 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_usingClause_in_batchStatement1103 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_usingClause_in_batchStatement2092 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_usingClause_in_insertStatement1530 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_usingClause_in_insertStatement913 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_usingClause_in_updateStatement1292 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_usingClause_in_updateStatement1657 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_usingClauseDelete_in_deleteStatement1555 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_usingClauseDelete_in_deleteStatement1833 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_usingClauseDeleteObjective_in_usingClauseDelete977 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_usingClauseDeleteObjective_in_usingClauseDelete985 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_usingClauseDeleteObjective_in_usingClauseObjective1044 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_usingClauseObjective_in_usingClause1562 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_usingClauseObjective_in_usingClause1569 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_usingClauseObjective_in_usingClause945 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_usingClauseObjective_in_usingClause953 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_UUID_in_constant5259 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_UUID_in_term2806 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_value_in_getCondition1860 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_value_in_setStatement1964 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_value_in_term6189 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_whereClause_in_deleteStatement1849 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_whereClause_in_selectStatement445 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- FOLLOW_whereClause_in_selectStatement825 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_whereClause_in_updateStatement1692 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- FOLLOW_WITH_in_keyValuePairExpr3054 - Static variable in class org.apache.cassandra.cli.CliParser
-
- FOLLOW_WITH_in_setStatement1967 - Static variable in class org.apache.cassandra.cli.CliParser
-
- forceBatchlogReplay() - Method in class org.apache.cassandra.db.BatchlogManager
-
- forceBatchlogReplay() - Method in interface org.apache.cassandra.db.BatchlogManagerMBean
-
Forces batchlog replay.
- forceBlockingFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- forceBlockingFlush() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- forceBlockingFlush() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Forces this indexes' in memory data to disk
- forceBlockingFlush(String) - Static method in class org.apache.cassandra.db.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.SSTableReader
-
For testing purposes only.
- forceFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- 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(String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceKeyspaceCompaction(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Forces major compaction of a single keyspace
- forceKeyspaceCompaction(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() - 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
-
- forceRepairAsync(String, int, Collection<String>, Collection<String>, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceRepairAsync(String, boolean, Collection<String>, Collection<String>, Collection<Range<Token>>, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceRepairAsync(String, RepairParallelism, Collection<String>, Collection<String>, Collection<Range<Token>>, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceRepairAsync(String, boolean, boolean, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceRepairAsync(String, boolean, boolean, Collection<Range<Token>>, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceRepairAsync(String, RepairParallelism, boolean, Collection<Range<Token>>, boolean, String...) - 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
-
Invoke repair asynchronously.
- forceRepairAsync(String, int, Collection<String>, Collection<String>, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Invoke repair asynchronously.
- forceRepairAsync(String, boolean, boolean, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Invoke repair asynchronously.
- forceRepairAsync(PrintStream, String, boolean, Collection<String>, Collection<String>, boolean, boolean, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceRepairAsync(PrintStream, String, RepairParallelism, Collection<String>, Collection<String>, boolean, boolean, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceRepairRangeAsync(String, String, String, boolean, Collection<String>, Collection<String>, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceRepairRangeAsync(String, String, String, int, Collection<String>, Collection<String>, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceRepairRangeAsync(String, String, String, boolean, boolean, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
-
- forceRepairRangeAsync(String, String, String, boolean, Collection<String>, Collection<String>, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Same as forceRepairAsync, but handles a specified range
- forceRepairRangeAsync(String, String, String, int, Collection<String>, Collection<String>, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Same as forceRepairAsync, but handles a specified range
- forceRepairRangeAsync(String, String, String, boolean, boolean, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Same as forceRepairAsync, but handles a specified range
- forceRepairRangeAsync(PrintStream, String, boolean, Collection<String>, Collection<String>, String, String, boolean, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- forceRepairRangeAsync(PrintStream, String, RepairParallelism, Collection<String>, Collection<String>, String, String, boolean, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- 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() - Method in class org.apache.cassandra.repair.RepairSession
-
clear all RepairJobs and terminate this session.
- 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(List<ColumnDefinition>) - Static method in class org.apache.cassandra.cql3.statements.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<Token>) - Static method in class org.apache.cassandra.db.DataRange
-
- format - Static variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
-
- forProgress(long, long) - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- 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
-
- 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(long) - Method in interface org.apache.cassandra.io.util.IAllocator
-
- free(long) - Method in class org.apache.cassandra.io.util.JEMallocAllocator
-
- free(long) - Method in interface org.apache.cassandra.io.util.JEMallocAllocator.JEMLibrary
-
- free() - Method in class org.apache.cassandra.io.util.Memory
-
- free(long) - Method in class org.apache.cassandra.io.util.NativeAllocator
-
- free() - Method in class org.apache.cassandra.io.util.SafeMemory
-
- 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
-
- 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 "/-[tmp-][-]-",
- fromFilename(String) - 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 "--[tmp-][-]-"
- 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.
- fromJsonList(String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- fromJsonMap(String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- 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.
- 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
-
- fromSchema(UntypedResultSet.Row) - Static method in class org.apache.cassandra.config.CFMetaData
-
Deserialize CF metadata from low-level representation
- fromSchema(UntypedResultSet, String, String, AbstractType<?>, boolean) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
Deserialize columns from storage-level representation
- fromSchema(Row, Iterable<CFMetaData>, UTMetaData) - Static method in class org.apache.cassandra.config.KSMetaData
-
Deserialize only Keyspace attributes without nested ColumnFamilies
- fromSchema(Row, Row, Row) - Static method in class org.apache.cassandra.config.KSMetaData
-
Deserialize Keyspace with nested ColumnFamilies
- fromSchema(Row) - Static method in class org.apache.cassandra.config.TriggerDefinition
-
Deserialize triggers from storage-level representation.
- fromSchema(Row) - Static method in class org.apache.cassandra.config.UTMetaData
-
- 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.statements.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.CollectionType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.DateType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.DecimalType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.DoubleType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.EmptyType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.FloatType
-
- fromString(String) - Method in class org.apache.cassandra.db.marshal.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.TimestampType
-
- 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
-
- fromStringCQL2(String) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
for compatibility with TimeUUID in CQL2.
- fromStringCQL2(String) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
-
- fromThrift(String, String) - Static method in class org.apache.cassandra.cache.CachingOptions
-
- fromThrift(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
-
- fromThrift(String, String, AbstractType<?>, AbstractType<?>, ColumnDef) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- fromThrift(String, String, AbstractType<?>, AbstractType<?>, List<ColumnDef>) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- fromThrift(KsDef, CFMetaData...) - Static method in class org.apache.cassandra.config.KSMetaData
-
- fromThrift(TriggerDef) - Static method in class org.apache.cassandra.config.TriggerDefinition
-
- fromThrift(List<TriggerDef>) - Static method in class org.apache.cassandra.config.TriggerDefinition
-
- fromThrift(ConsistencyLevel) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- fromThrift(List<IndexExpression>) - Static method in class org.apache.cassandra.thrift.ThriftConversion
-
- fromThriftCqlRow(CqlRow, CqlResult) - Static method in class org.apache.cassandra.config.CFMetaData
-
Create CFMetaData from thrift CqlRow
that contains columns from schema_columnfamilies.
- fromThriftForUpdate(CfDef, CFMetaData) - Static method in class org.apache.cassandra.config.CFMetaData
-
- 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() - Method in class org.apache.cassandra.cql3.CqlParser
-
- Function - Interface in org.apache.cassandra.cql3.functions
-
- Function.Factory - Interface in org.apache.cassandra.cql3.functions
-
- FUNCTION_CALL - Static variable in class org.apache.cassandra.cli.CliLexer
-
- FUNCTION_CALL - Static variable in class org.apache.cassandra.cli.CliParser
-
- functionArgs() - Method in class org.apache.cassandra.cql3.CqlParser
-
- functionArgument() - Method in class org.apache.cassandra.cli.CliParser
-
- functionArgument_return() - Constructor for class org.apache.cassandra.cli.CliParser.functionArgument_return
-
- functionCall() - Method in class org.apache.cassandra.cli.CliParser
-
- FunctionCall - Class in org.apache.cassandra.cql3.functions
-
- FunctionCall.Raw - Class in org.apache.cassandra.cql3.functions
-
- functionCall_return() - Constructor for class org.apache.cassandra.cli.CliParser.functionCall_return
-
- functionName() - Method in class org.apache.cassandra.cql3.CqlParser
-
- functionName - Variable in class org.apache.cassandra.cql3.statements.Selectable.WithFunction
-
- Functions - Class in org.apache.cassandra.cql3.functions
-
- G - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- G - Static variable in class org.apache.cassandra.cql.CqlParser
-
- G - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- G - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- gatherTombstones(ColumnFamily, 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_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() - 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.SSTableReader.Operator
-
- generate() - Static method in class org.apache.cassandra.utils.CounterId
-
- generateCFMetadataUpdate() - Method in class org.apache.cassandra.cql.DropIndexStatement
-
- 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 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- GET - Static variable in class org.apache.cassandra.cli.CliParser
-
- get(QueryOptions) - Method in class org.apache.cassandra.cql3.Constants.Value
-
- get(String, String, List<? extends AssignementTestable>, ColumnSpecification) - Static method in class org.apache.cassandra.cql3.functions.Functions
-
- get(QueryOptions) - Method in class org.apache.cassandra.cql3.Lists.Value
-
- get(QueryOptions) - Method in class org.apache.cassandra.cql3.Maps.Value
-
- get(QueryOptions) - Method in class org.apache.cassandra.cql3.Sets.Value
-
- get(QueryOptions) - Method in class org.apache.cassandra.cql3.Term.Terminal
-
- get(QueryOptions) - Method in class org.apache.cassandra.cql3.Tuples.InValue
-
- get(QueryOptions) - 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(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(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() - 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.
- 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
-
- getActiveCount() - Method in interface org.apache.cassandra.concurrent.IExecutorMBean
-
Deprecated.
Get the current number of running tasks
- getActiveCount() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- getActiveRepairedSSTableRefsForAntiCompaction(UUID) - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
Gets the repairing sstables for anticompaction.
- 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.DataTracker.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.
- getAllSessionInfo() - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- 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.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.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.ISaslAwareAuthenticator.SaslAuthenticator
-
- getAuthenticator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getAuthenticator() - Method in class org.apache.cassandra.transport.ServerConnection
-
- getAuthorizer() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getAvailableProcessors() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- 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 interface org.apache.cassandra.io.sstable.ISSTableScanner
-
- getBackingFiles() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.EmptySSTableScanner
-
- getBackingFiles() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
-
- getBackupsDirectory(Descriptor) - Static method in class org.apache.cassandra.db.Directories
-
- getBadnessThreshold() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
-
- getBadnessThreshold() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
-
- 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
-
- 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.SSTableReader
-
- getBloomFilterDiskSpaceUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getBloomFilterDiskSpaceUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getBloomFilterFalsePositives() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getBloomFilterFalsePositives() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getBloomFilterFalseRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getBloomFilterFpChance() - Method in class org.apache.cassandra.config.CFMetaData
-
- getBloomFilterOffHeapMemoryUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getBloomFilterOffHeapMemoryUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getBloomFilterOffHeapSize() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Returns the amount of memory in bytes used off heap by the bloom filter.
- getBloomFilterSerializedSize() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getBoolean(String, Boolean) - Method in class org.apache.cassandra.cql3.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
-
May be used by custom QueryHandler implementations
- 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
-
- 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) - Static method in class org.apache.cassandra.io.util.SegmentedFile
-
- getBuiltIndexes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getBuiltIndexes() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Returns a list of the names of the built column indexes for current store
- getBuiltIndexes() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getByte(long) - Method in class org.apache.cassandra.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(AbstractType<?>, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.Term
-
Returns the typed value, serialized to a ByteBuffer according to a
comparator/validator.
- getByteBuffer() - Method in class org.apache.cassandra.cql.Term
-
Returns the typed value, serialized to a ByteBuffer.
- getByteBuffer(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
-
- 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.SSTableReader
-
- getCacheKey(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getCacheMetric(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
Retrieve cache metrics based on the cache type (KeyCache, RowCache, or CounterCache)
- getCachePath(String) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- getCacheServiceMBean() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCaching() - Method in class org.apache.cassandra.config.CFMetaData
-
- 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
-
- getCF(UUID) - Method in class org.apache.cassandra.config.Schema
-
- getCFDirectories() - Method in class org.apache.cassandra.db.Directories
-
- getCfInfo(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get the columnfamily definition for the signature
- getCfInfo(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
return the CfInfo for the column family
- getCFMetaData(String, String) - Method in class org.apache.cassandra.config.Schema
-
Given a keyspace name & column family name, get the column family
meta data.
- getCFMetaData(UUID) - Method in class org.apache.cassandra.config.Schema
-
Get ColumnFamily metadata by its identifier
- getCFMetaData(Descriptor) - Method in class org.apache.cassandra.config.Schema
-
- getCFMetaData(String) - Method in class org.apache.cassandra.cql.AlterTableStatement
-
- getCFMetaData(String, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
Returns a CFMetaData instance based on the parameters parsed from this
CREATE
statement, or defaults where applicable.
- getCFMetaData() - Method in class org.apache.cassandra.cql3.statements.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) - Method in class org.apache.cassandra.hadoop.AbstractBulkRecordWriter.ExternalClient
-
- getCFMetaData(String, String, Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get CFMetaData of a column family
- getCFMetaData() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
- getCFMetaData(String, String) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
Validate that keyspace
is an existing keyspace and cfName
one of its existing column family.
- getCFMetaData(String, String) - Method in class org.apache.cassandra.tools.BulkLoader.ExternalClient
-
- getCfName() - Method in class org.apache.cassandra.cql3.IndexName
-
- getCfNamesByKeySpace(KsDef) - Static method in class org.apache.cassandra.cli.CliUtils
-
Returns set of column family names in specified keySpace.
- getCfsProxy(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- getChannel() - Method in class org.apache.cassandra.io.util.DataOutputStreamAndChannel
-
- 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
-
- getClauseRelations() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getClauseRelations() - Method in class org.apache.cassandra.cql.WhereClause
-
- 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
-
- getClusteringColumn(int) - Method in interface org.apache.cassandra.cql3.CQL3Row
-
- 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
-
- getCollectionElementValue() - Method in class org.apache.cassandra.cql3.ColumnCondition.Bound
-
- getCollectionsParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getColumn(Tree, int) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- 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.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.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
-
- getColumnFamily() - Method in class org.apache.cassandra.auth.DataResource
-
- getColumnFamily(Tree, Iterable<CfDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- getColumnFamily(String, Iterable<CfDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- getColumnFamily() - Method in class org.apache.cassandra.cql.AbstractModification
-
- getColumnFamily() - Method in class org.apache.cassandra.cql.CreateIndexStatement
-
Column family namespace.
- getColumnFamily() - Method in class org.apache.cassandra.cql.DropIndexStatement
-
- getColumnFamily() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnFamily() - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getColumnFamily() - Method in class org.apache.cassandra.cql3.CFName
-
- getColumnFamily(DecoratedKey, 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.columniterator.SSTableNamesIterator
-
- getColumnFamily() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
- getColumnFamily() - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- getColumnFamily() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
- getColumnFamily(DecoratedKey) - Method in class org.apache.cassandra.db.Memtable
-
- getColumnFamily(UUID) - Method in class org.apache.cassandra.db.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
-
- getColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
- getColumnFamilyIds() - Method in class org.apache.cassandra.db.CounterMutation
-
- getColumnFamilyIds() - Method in interface org.apache.cassandra.db.IMutation
-
- getColumnFamilyIds() - Method in class org.apache.cassandra.db.Mutation
-
- getColumnFamilyInsertStatement(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- 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
-
- getColumnFamilySchema(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- 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
-
- getColumnFamilyType(String, String) - Method in class org.apache.cassandra.config.Schema
-
Get type of the ColumnFamily but it's keyspace/name
- getColumnFinish() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnIndex(ColumnDefinition) - Method in class org.apache.cassandra.cql3.statements.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.statements.Selection
-
- getColumnMeta(Cassandra.Client, boolean, boolean) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get column meta data
- getColumnMetadata(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get a list of columns
- getColumnMetadata(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
get a list of column for the column family
- getColumnMetadata(Cassandra.Client) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
include key columns
- getColumnName() - Method in class org.apache.cassandra.cql.CreateIndexStatement
-
Column name to index.
- getColumnNames() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnNames() - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getColumnNames() - Method in class org.apache.cassandra.db.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.
- getColumnRelations() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnRelations() - Method in class org.apache.cassandra.cql.WhereClause
-
- getColumns() - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
- getColumns() - Method in class org.apache.cassandra.cql.DeleteStatement
-
- getColumns() - Method in class org.apache.cassandra.cql.SelectExpression
-
- getColumns() - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getColumns() - Method in class org.apache.cassandra.cql3.statements.Selection
-
- getColumns() - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getColumnsLimit() - Method in class org.apache.cassandra.cql.SelectExpression
-
- getColumnsLimit() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnSpecifications() - Method in class org.apache.cassandra.cql3.statements.Selection
-
- getColumnSpecifications() - Method in class org.apache.cassandra.cql3.statements.SelectionColumnMapping
-
- getColumnSpecifications() - Method in interface org.apache.cassandra.cql3.statements.SelectionColumns
-
- getColumnsString(CellNameType, Iterable<Cell>) - Static method in class org.apache.cassandra.db.composites.CellNames
-
- getColumnStart() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getColumnStats() - Method in class org.apache.cassandra.db.ColumnFamily
-
- getColumnsWithConditions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getColumnValues() - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getCommandCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getCommandCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Completed tasks for Command(Mutations, Read etc) TCP Connections
- getCommandDroppedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getCommandDroppedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Dropped tasks for Command(Mutations, Read etc) TCP Connections
- getCommandPendingTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getCommandPendingTasks(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- getCommandPendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Pending tasks for Command(Mutations, Read etc) TCP Connections
- getComment() - Method in class org.apache.cassandra.config.CFMetaData
-
- getCommitFailurePolicy() - 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
- getCommitLogPeriodicQueueSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getCommitLogSegmentRecyclingEnabled() - 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
-
- getCompacting() - Method in class org.apache.cassandra.db.DataTracker
-
- 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(Collection<SSTableReader>, int, long) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getCompactionTask(Collection<SSTableReader>, int, long) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getCompactionTask(Collection<SSTableReader>, int, long) - Method in class org.apache.cassandra.db.compaction.WrappingCompactionStrategy
-
- GetCompactionThreshold() - Constructor for class org.apache.cassandra.tools.NodeTool.GetCompactionThreshold
-
- getCompactionThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
-
- 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.cql.CFPropDefs
-
- 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 interface org.apache.cassandra.concurrent.IExecutorMBean
-
Deprecated.
Get the number of completed tasks
- getCompletedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
Get the number of completed tasks
- getCompletedTasks() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- getCompletedTasks() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
-
- getCompletedTasks() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getCompletedTasks() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Deprecated.
- getCompletedTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCompletedTasks() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Deprecated.
- getComponent(int) - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- getComponentComparator(Integer, ColumnDefinition.Kind) - Method in class org.apache.cassandra.config.CFMetaData
-
- getComponentComparator(AbstractType<?>, Integer, ColumnDefinition.Kind) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- 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() - Static method in class org.apache.cassandra.io.util.SegmentedFile
-
- getCompressedBuilder(CompressedSequentialWriter) - Static method in class org.apache.cassandra.io.util.SegmentedFile
-
- getCompressionMetadata() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Returns the compression metadata for this sstable.
- getCompressionMetadataOffHeapMemoryUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getCompressionMetadataOffHeapMemoryUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getCompressionMetadataOffHeapSize() - Method in class org.apache.cassandra.io.sstable.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.db.ColumnFamilyStore
-
- getCompressionRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getCompressionRatio() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getCompressor() - Method in class org.apache.cassandra.transport.Connection
-
- getConcurrentCompactors() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- 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
-
- getCondition() - Method in class org.apache.cassandra.cli.CliParser
-
- getCondition_return() - Constructor for class org.apache.cassandra.cli.CliParser.getCondition_return
-
- 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.
- getConnectionFactory() - Method in class org.apache.cassandra.tools.BulkLoader.ExternalClient
-
- 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
-
- getConsistencyLevel() - Method in class org.apache.cassandra.cql.AbstractModification
-
- getConsistencyLevel() - Method in class org.apache.cassandra.cql.Attributes
-
- getConsistencyLevel() - Method in class org.apache.cassandra.cql.BatchStatement
-
- getConsistencyLevel() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getConsistencyLevel() - Method in class org.apache.cassandra.cql.UpdateStatement
-
Returns the consistency level of this UPDATE
statement, either
one parsed from the CQL statement, or the default level otherwise.
- 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.JMXEnabledSharedExecutorPool.JMXEnabledSEPExecutor
-
- getCoreThreads() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- getCoreThreads() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Deprecated.
Returns core pool size of thread pool.
- getCoreValidationThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getCoreValidationThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Returns core size of validation thread pool
- getCount() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- 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
-
- getCQL2KeyName() - Method in class org.apache.cassandra.config.CFMetaData
-
- getCQLQueryHandler() - Static method in class org.apache.cassandra.service.ClientState
-
- getCQLSupportedVersion() - Static method in class org.apache.cassandra.service.ClientState
-
- getCQLVersion() - Method in class org.apache.cassandra.service.ClientState
-
- 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.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
-
- getCurrentDescriptor() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
- getCurrentGenerationNumber(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getCurrentGenerationNumber(String) - Method in class org.apache.cassandra.gms.Gossiper
-
- getCurrentGenerationNumber(String) - Method in interface org.apache.cassandra.gms.GossiperMBean
-
- getCurrentGenerationNumber() - Method in class org.apache.cassandra.service.StorageService
-
- getCurrentGenerationNumber() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Return the generation value for this node.
- getCurrentGenerationNumber() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getCurrentKey() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- getCurrentKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- getCurrentlyBlockedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- getCurrentlyBlockedTasks() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Deprecated.
Get the number of tasks currently blocked, waiting to be accepted by
the executor (because all threads are busy and the backing queue is full).
- getCurrentlyBlockedTasks() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- getCurrentMemtable() - Method in class org.apache.cassandra.db.DataTracker.View
-
- getCurrentPosition() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
-
- getCurrentPosition() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.EmptySSTableScanner
-
- getCurrentPosition() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
-
- 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
-
- getCurrentValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- getCurrentVersion(SSTableReader) - Method in class org.apache.cassandra.db.DataTracker
-
- getData() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
Returns the current contents of the buffer.
- getData() - Method in interface org.apache.cassandra.service.IResponseResolver
-
returns the data response without comparing with any digests
- getData() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- getData() - Method in class org.apache.cassandra.service.RowDataResolver
-
- getData() - Method in class org.apache.cassandra.service.RowDigestResolver
-
Special case of resolve() so that CL.ONE reads never throw DigestMismatchException in the foreground
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
-
Return the data center for which an endpoint resides in
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.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(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Datacenter name depending on the respective snitch used, given the hostname/ip
- getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.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(InetAddress) - Method in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch
-
Returns the name of the data center for the endpoint, or UNKNOWN
if not known.
- getDataCenter() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getDatacenterEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
-
- getDatacenterRacks() - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
-
- getDatacenters() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
-
- getDataTracker() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Package protected for access from the CompactionManager.
- getDcLocalReadRepair() - Method in class org.apache.cassandra.config.CFMetaData
-
- getDefaultIndexName(String, ColumnIdentifier) - Static method in class org.apache.cassandra.config.CFMetaData
-
- getDefaultMarshallers(CfDef) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
construct a map to store the mashaller type to cassandra data type mapping
- 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.cli.CliLexer
-
- getDelegates() - Method in class org.apache.cassandra.cli.CliParser
-
- getDelegates() - Method in class org.apache.cassandra.cql.CqlLexer
-
- getDelegates() - Method in class org.apache.cassandra.cql.CqlParser
-
- 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.cli.CliLexer.DFA15
-
- getDescription() - Method in class org.apache.cassandra.cql.CqlLexer.DFA15
-
- getDescription() - Method in class org.apache.cassandra.cql.CqlLexer.DFA7
-
- getDescription() - Method in class org.apache.cassandra.cql3.CqlLexer.DFA11
-
- getDescription() - Method in class org.apache.cassandra.cql3.CqlLexer.DFA19
-
- getDirectories() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- getDirectories() - Method in class org.apache.cassandra.io.util.DiskAwareRunnable
-
Get sstable directories for the CF.
- getDirectoryForNewSSTables() - Method in class org.apache.cassandra.db.Directories
-
- 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)
- getDroppableTombstoneRatio() - Method in class org.apache.cassandra.db.DataTracker
-
- getDroppableTombstonesBefore(int) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- getDroppableTombstonesBefore(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- 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
-
- 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.IndexSummary
-
- getEffectiveIndexInterval() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- 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() - 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.cql.Relation
-
- 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.SSTableReader
-
- getEstimatedColumnCountHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getEstimatedColumnCountHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getEstimatedDroppableTombstoneRatio(int) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- getEstimatedDroppableTombstoneRatio(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- 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.SSTableReader
-
- getEstimatedRowSizeHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getEstimatedRowSizeHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getEstimatedTasks() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
-
- getExceptionCount() - Method in class org.apache.cassandra.service.StorageService
-
- getExceptionCount() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- getExceptionCount() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getExpectedCompactedFileSize(Iterable<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Calculate expected file size of SSTable after compaction.
- getExpectedWriteSize() - Method in class org.apache.cassandra.db.compaction.CompactionTask
-
- 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
-
- getFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getfd(FileDescriptor) - Static method in class org.apache.cassandra.utils.CLibrary
-
Get system file descriptor from FileDescriptor object.
- getfd(String) - Static method in class org.apache.cassandra.utils.CLibrary
-
- getFileCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getFileDataInput(long) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getFileMessages() - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
- getFilename() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getFilename() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getFilePointer() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- getFilePointer() - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- getFilePointer() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- getFilePointer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getFilePointer() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- 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
-
- getFinish() - Method in class org.apache.cassandra.cql.SelectExpression
-
- getFinishKey() - Method in class org.apache.cassandra.cql.WhereClause
-
- getFirstEmptyKey() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- getFlushWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- 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.AbstractCassandraStorage
-
get the full class name
- getFunctionNames() - Static method in enum org.apache.cassandra.cli.CliClient.Function
-
- getGcGraceSeconds() - Method in class org.apache.cassandra.config.CFMetaData
-
- getGCWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getGossipInfo() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getGrammarFileName() - Method in class org.apache.cassandra.cli.CliLexer
-
- getGrammarFileName() - Method in class org.apache.cassandra.cli.CliParser
-
- getGrammarFileName() - Method in class org.apache.cassandra.cql.CqlLexer
-
- getGrammarFileName() - Method in class org.apache.cassandra.cql.CqlParser
-
- getGrammarFileName() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- getGrammarFileName() - Method in class org.apache.cassandra.cql3.CqlParser
-
- getHashBuckets(ByteBuffer, int, long) - Method in class org.apache.cassandra.utils.BloomFilter
-
- getHeapMemoryUsage() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getHeapSizeOf(Token) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- getHeapSizeOf(Token) - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getHeapSizeOf(Token) - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getHeapSizeOf(Token) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getHeapSizeOf(Token) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getHeapSizeOf(Token) - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- 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
-
- getHostId(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- getHostId(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Return the unique host ID for an end-point.
- getHostIdMap() - Method in class org.apache.cassandra.service.StorageService
-
- getHostIdMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
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
- 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() - Method in enum org.apache.cassandra.transport.DataType
-
- getId() - 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
-
- getIgnoreHosts(Configuration) - Static method in class org.apache.cassandra.hadoop.AbstractBulkOutputFormat
-
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.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.AbstractCassandraStorage
-
get a list of columns with defined index
- getIndexesBackedByCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getIndexesByNames(Set<String>) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getIndexesNotBackedByCfs() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getIndexFilename() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- getIndexForColumn(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
- getIndexInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
Deprecated.
- 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.CompositesIndexOnCollectionValue
-
- getIndexKeyFor(ByteBuffer) - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- getIndexKeyFor(ByteBuffer) - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Returns the decoratedKey for a column value
- getIndexName() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- getIndexName() - Method in class org.apache.cassandra.cql.CreateIndexStatement
-
Index name (or null).
- getIndexName() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- getIndexName() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
- getIndexOperator(String) - Static method in class org.apache.cassandra.cli.CliUtils
-
Returns IndexOperator from string representation
- getIndexOperator(Bound) - Method in interface org.apache.cassandra.cql3.statements.Restriction.Slice
-
- getIndexOperator(Bound) - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Slice
-
- getIndexOptions() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- getIndexScanPosition(RowPosition) - Method in class org.apache.cassandra.io.sstable.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.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
- getIndexSummaryCapacityInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getIndexSummaryIndexFromBinarySearchResult(int) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getIndexSummaryKey(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Returns the key for the index summary entry at `index`.
- getIndexSummaryOffHeapMemoryUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getIndexSummaryOffHeapMemoryUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getIndexSummaryOffHeapSize() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getIndexSummaryResizeIntervalInMinutes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getIndexSummarySamplingLevel() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getIndexSummarySize() - Method in class org.apache.cassandra.io.sstable.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.AbstractCassandraStorage
-
get index type from string
- getInetAddress(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getInitialTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInMarker() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
-
For IN relations, returns the single marker for the IN values if there is one, otherwise null.
- 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.AbstractCassandraStorage
-
- getInputInitialAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputIsWide(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputKeyRange(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
may be null if unset
- getInputKeyspace(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputKeyspacePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputKeyspaceUserName(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getInputMaxConnections(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputMaxSimultReqPerConnections(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInputMinSimultReqPerConnections(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
-
- getInputStream(File) - Method in interface org.apache.cassandra.cache.AutoSavingCache.IStreamFactory
-
- getInputWhereClauses(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- getInstance(Map<ByteBuffer, CollectionType>) - Static method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.CompositeType
-
- getInstance(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() - 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
-
- getInternodeEncryption(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- getInternodeRecvBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInternodeSendBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getInValues() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
-
For IN relations, returns the list of Tuples.Literal instances or Tuples.Raw markers.
- getInValues() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
-
- 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.
- getJmxName() - Method in enum org.apache.cassandra.concurrent.Stage
-
- getJmxType() - Method in enum org.apache.cassandra.concurrent.Stage
-
- getJoiningNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getJoiningNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of nodes currently bootstrapping into the ring.
- getJoiningNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getKey(Tree) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- getKey() - Method in class org.apache.cassandra.db.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.columniterator.SSTableNamesIterator
-
- getKey() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
- 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
-
- getKeyAlias() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getKeyAlias() - Method in class org.apache.cassandra.cql.WhereClause
-
- getKeyAsBytes(String, Tree) - Method in class org.apache.cassandra.cli.CliClient
-
- getKeyBounds(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
May be used by custom QueryHandler implementations
- getKeyCache() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getKeyCacheCapacityInBytes() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheCapacityInBytes() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheCapacityInMB() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheCapacityInMB() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheEntries() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheEntries() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheHit() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getKeyCacheHits() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheHits() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getKeyCacheKeysToSave() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheKeysToSave() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getKeyCacheRecentHitRate() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheRecentHitRate() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheRequest() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getKeyCacheRequests() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheRequests() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getKeyCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getKeyCacheSize() - Method in class org.apache.cassandra.service.CacheService
-
- getKeyCacheSize() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getKeyCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getKeyFinish() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getKeyName() - Method in class org.apache.cassandra.cql.AbstractModification
-
- getKeys() - Method in class org.apache.cassandra.cql.DeleteStatement
-
- getKeys() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getKeys() - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getKeys() - Method in class org.apache.cassandra.cql.WhereClause
-
- getKeySamples(Range<Token>) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getKeySet() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- getKeyspace() - Method in class org.apache.cassandra.auth.DataResource
-
- getKeySpace() - Method in class org.apache.cassandra.cli.CliClient
-
- getKeySpace(Tree, List<KsDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- getKeySpace(String, List<KsDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
-
- getKeyspace() - Method in class org.apache.cassandra.cql.AbstractModification
-
- getKeyspace() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getKeyspace() - Method in class org.apache.cassandra.cql3.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
-
- getKeySpaceDef(String, List<KsDef>) - Static method in class org.apache.cassandra.cli.CliUtils
-
Parse the statement from cli and return KsDef
- 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
-
- getKeyStart() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getKeysType() - Method in class org.apache.cassandra.db.marshal.MapType
-
- getKeyType() - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
- getKeyType(String) - Method in class org.apache.cassandra.cql.UpdateStatement
-
- getKeyValidator() - Method in class org.apache.cassandra.config.CFMetaData
-
- 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.cli.CliClient
-
- getKSMetaData(String) - Method in class org.apache.cassandra.config.Schema
-
Get metadata about keyspace by its name
- getLargestBucketOffset() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- getLastFlushOffset() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- getLastReadableBoundary() - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
-
- getLeavingEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
-
caller should not modify leavingEndpoints
- getLeavingNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getLeavingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of nodes currently leaving the ring.
- getLeavingNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLength() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- getLength() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
Returns the length of the valid data currently in the buffer.
- getLengthInBytes() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
-
- getLengthInBytes() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.EmptySSTableScanner
-
- getLengthInBytes() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
-
- 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
-
- getLifetimeRangeLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getLifetimeRangeLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getLifetimeReadLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getLifetimeReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getLifetimeWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getLifetimeWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getLimit(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
-
- getList(String, AbstractType<T>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
-
- getListenAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getLiveCellsPerSlice() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getLiveCellsPerSlice() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- 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
-
- getLiveDiskSpaceUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getLiveDiskSpaceUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getLiveMembers() - Method in class org.apache.cassandra.gms.Gossiper
-
- getLiveNaturalEndpoints(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
-
- getLiveSSTableCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getLiveSSTableCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getLiveTokenOwners() - Method in class org.apache.cassandra.gms.Gossiper
-
- getLoad() - Method in class org.apache.cassandra.service.StorageService
-
raw load value
- getLoad() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- getLoadInfo() - Method in class org.apache.cassandra.service.LoadBroadcaster
-
- getLoadMap() - Method in class org.apache.cassandra.service.StorageService
-
- getLoadMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Human-readable load value.
- getLoadMap() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getLoadString() - Method in class org.apache.cassandra.service.StorageService
-
- getLoadString() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Human-readable load value
- getLoadString() - Method in class org.apache.cassandra.tools.NodeProbe
-
- 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
-
- 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() - Constructor for class org.apache.cassandra.tools.NodeTool.GetLoggingLevels
-
- 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
-
- getMappings() - Method in class org.apache.cassandra.cql3.statements.SelectionColumnMapping
-
- getMappings() - Method in interface org.apache.cassandra.cql3.statements.SelectionColumns
-
- getMaxCompactionThreshold() - Method in class org.apache.cassandra.config.CFMetaData
-
- getMaxDataAge(Collection<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
-
- getMaxHintsInProgress() - Method in class org.apache.cassandra.service.StorageProxy
-
- getMaxHintsInProgress() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getMaxHintsThread() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMaxHintWindow() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMaxHintWindow() - Method in class org.apache.cassandra.service.StorageProxy
-
- getMaxHintWindow() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getMaximalTask(int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
- getMaximalTask(int) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
-
- getMaximalTask(int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
-
- getMaximalTask(int) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
-
- getMaximalTask(int) - 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
-
Deprecated.
Returns maximum pool size of thread pool.
- getMaximumThreads() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- 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.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.
- getMaxRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMaxRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getMaxSizeFile(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- 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
-
- getMaxStreamingRetries() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMaxTimestamp() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getMeanColumns() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMeanColumns() - Method in class org.apache.cassandra.db.DataTracker
-
- getMeanRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMeanRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- 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
-
- getMemtableColumnsCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMemtableColumnsCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getMemtableDataSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMemtableDataSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getMemtableFlushPeriod() - Method in class org.apache.cassandra.config.CFMetaData
-
- getMemtableFor(OpOrder.Group, ReplayPosition) - Method in class org.apache.cassandra.db.DataTracker
-
- 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.
- getMemtablesPendingFlush() - Method in class org.apache.cassandra.db.DataTracker.View
-
- getMemtableSwitchCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMemtableSwitchCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getMergedRowCounts() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionIterable
-
- getMessage() - Method in exception org.apache.cassandra.exceptions.RepairException
-
- getMessage() - Method in interface org.apache.cassandra.exceptions.TransportException
-
The exception message.
- getMessages() - Method in class org.apache.cassandra.service.AbstractRowResolver
-
- getMessages() - Method in interface org.apache.cassandra.service.IResponseResolver
-
- getMessages() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- getMessageType() - Method in class org.apache.cassandra.net.MessageIn
-
- getMessagingVersion() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- getMetadata() - Method in class org.apache.cassandra.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
-
- getMetrics() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- getMinCompactionThreshold() - Method in class org.apache.cassandra.config.CFMetaData
-
- getMinimalKey(DecoratedKey) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
If the given @param key occupies only part of a larger buffer, allocate a new buffer that is only
as large as necessary.
- getMinimumCompactionThreshold() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMinimumCompactionThreshold() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Gets the minimum number of sstables in queue before compaction kicks off
- getMinimumToken() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- getMinimumToken() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getMinimumToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getMinIndexInterval() - Method in class org.apache.cassandra.config.CFMetaData
-
- getMinIndexInterval() - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getMinIndexInterval() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getMinRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getMinRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getMinRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getMinTimestamp() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getMovingEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Endpoints which are migrating to the new tokens
- getMovingNodes() - Method in class org.apache.cassandra.service.StorageService
-
- getMovingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve the list of nodes currently moving in the ring.
- getMovingNodes() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getMultiCellColumn(ColumnIdentifier) - Method in interface org.apache.cassandra.cql3.CQL3Row
-
- getMutation() - Method in class org.apache.cassandra.db.CounterMutation
-
- getMutations(String, ThriftClientState, List<ByteBuffer>) - Method in class org.apache.cassandra.cql.BatchStatement
-
- getName() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
- getName() - Method in class org.apache.cassandra.auth.DataResource
-
- getName() - Method in interface org.apache.cassandra.auth.IResource
-
- getName() - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
Name of the column family to create
- getName() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
-
- getName() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- 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
-
- 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.
- 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
-
- getNext() - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
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
-
read wide row
- getNodeProbe() - Method in class org.apache.cassandra.cli.CliSessionState
-
- 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
-
- 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
-
- getNumRecords() - Method in class org.apache.cassandra.cql.SelectStatement
-
- getNumTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getNumWords() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
Expert: gets the number of longs in the array that are in use
- getoffHeapMemoryAllocator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getOldestMemtable() - Method in class org.apache.cassandra.db.DataTracker.View
-
- getOnDiskDeserializer(DataInput, Descriptor.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.SSTableWriter
-
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
Return the current file pointer of the underlying on-disk file.
- getOnDiskIterator(DataInput, Descriptor.Version) - Method in class org.apache.cassandra.config.CFMetaData
-
- getOnDiskIterator(DataInput, ColumnSerializer.Flag, int, Descriptor.Version) - Method in class org.apache.cassandra.config.CFMetaData
-
- 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
-
- getOperations() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
-
Deprecated.
- getOptions() - Method in class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- getOptions() - Method in class org.apache.cassandra.cql3.UserOptions
-
- getOrCreateNextSession(InetAddress, InetAddress) - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- getOrCreateSessionById(InetAddress, int, InetAddress) - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- 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.
- 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
-
- getOutputColumnFamily(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.AbstractBulkOutputFormat
-
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyOutputFormat
-
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.AbstractCassandraStorage
-
output format
- getOutputInitialAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputKeyspace(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputKeyspacePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputKeyspaceUserName(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputLocalDCOnly(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputLocation() - Method in class org.apache.cassandra.hadoop.AbstractBulkRecordWriter
-
- getOutputPartitioner(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputRpcPort(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- getOutputStream(File) - Method in interface org.apache.cassandra.cache.AutoSavingCache.IStreamFactory
-
- getOverlappingSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getOwnership() - Method in class org.apache.cassandra.service.StorageService
-
- getOwnership() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
given a list of tokens (representing the nodes in the cluster), returns
a mapping from "token -> %age of cluster owned by that token"
- getOwnership() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getPage(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
-
- 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.
- getParent() - Method in class org.apache.cassandra.auth.DataResource
-
- getParent() - Method in interface org.apache.cassandra.auth.IResource
-
Gets next resource in the hierarchy.
- 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.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
- getPartitionKeys(String, Job) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
return partition keys
- getPartitionSample(String, String, int, int, int, List<ColumnFamilyMetrics.Sampler>) - Method in class org.apache.cassandra.tools.NodeProbe
-
- getPath() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- getPath() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- getPath() - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- getPath() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- getPath() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getPath() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- 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
-
- getPendingRangeToEndpointMap(String) - Method in class org.apache.cassandra.service.StorageService
-
- getPendingRangeToEndpointMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve a map of pending ranges to endpoints that describe the ring topology
- getPendingTasks() - Method in interface org.apache.cassandra.concurrent.IExecutorMBean
-
Deprecated.
Get the number of tasks waiting to be executed
- getPendingTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
Get the number of tasks waiting to be executed
- getPendingTasks() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- getPendingTasks() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getPendingTasks() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getPendingTasks() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
-
- getPendingTasks() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getPendingTasks() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Deprecated.
- getPendingTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getPendingTasks() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Deprecated.
- getPermissions(AuthenticatedUser, IResource) - Static method in class org.apache.cassandra.auth.Auth
-
- 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
-
- getPhiConvictThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getPhiConvictThreshold() - Method in class org.apache.cassandra.gms.FailureDetector
-
- getPhiConvictThreshold() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
- getPigType(AbstractType) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get pig type for the cassandra data type
- getPos() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- getPos() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- getPosition(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
-
- getPosition(RowPosition, SSTableReader.Operator) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Get position updating key cache and stats.
- getPosition(RowPosition, SSTableReader.Operator, boolean) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getPosition() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
- getPosition() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- getPosition() - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- getPosition() - Method in class org.apache.cassandra.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'.
- getPositionsForRanges(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Determine the minimal set of sections that can be extracted from this SSTable to cover the given ranges.
- 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) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- getPrepared(MD5Digest) - Method in interface org.apache.cassandra.cql3.QueryHandler
-
- getPrepared(MD5Digest) - Method in class org.apache.cassandra.cql3.QueryProcessor
-
- getPrepared() - Method in class org.apache.cassandra.thrift.ThriftClientState
-
- getPreparedForThrift(Integer) - Method in interface org.apache.cassandra.cql3.QueryHandler
-
- getPreparedForThrift(Integer) - Method in class org.apache.cassandra.cql3.QueryProcessor
-
- 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
-
- 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
-
- getProgress() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- getProgress() - Method in class org.apache.cassandra.hadoop.ReporterWrapper
-
- getProperty(String) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getPropertyBoolean(String, Boolean) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getPropertyDouble(String, Double) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getPropertyInt(String, Integer) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getPropertySet(String, Set<String>) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getPropertyString(String, String) - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getProtectedConstructor(Class, Class...) - Static method in class org.apache.cassandra.utils.Hex
-
Used to get access to protected/private constructor of the specified class
- getProtectedField(Class, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Used to get access to protected/private field of the specified class
- getProtocolVersion() - Method in class org.apache.cassandra.cql3.QueryOptions
-
The protocol version for the query.
- getProxyMetric(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
Retrieve Proxy metrics
- getQueryMap(String) - Static method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
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(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(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Rack name depending on the respective snitch used, given the host name/ip
- getRack(InetAddress) - Method in class org.apache.cassandra.locator.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(InetAddress) - Method in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch
-
Returns the name of the rack for the endpoint, or UNKNOWN
if not known.
- 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.AbstractByteOrderedPartitioner
-
- getRandomToken() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getRandomToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getRandomTokens(TokenMetadata, int) - Static method in class org.apache.cassandra.dht.BootStrapper
-
- getRange(ByteBuffer) - Method in class org.apache.cassandra.client.RingCache
-
- 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.
- getRangeCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRangeCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRangeOperations() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRangeOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRangeRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRangeRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRangeRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getRangeSlice(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.
- 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
-
- 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
-
- getReadCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getReadCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getReadExecutor(ReadCommand, ConsistencyLevel) - Static method in class org.apache.cassandra.service.AbstractReadExecutor
-
- getReadMeter() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getReadOperations() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getReadRepairAttempted() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadRepairAttempted() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getReadRepairAttempted() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getReadRepairChance() - Method in class org.apache.cassandra.config.CFMetaData
-
- getReadRepairRepairedBackground() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadRepairRepairedBackground() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getReadRepairRepairedBackground() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getReadRepairRepairedBlocking() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadRepairRepairedBlocking() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getReadRepairRepairedBlocking() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getReadRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReadRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getReadRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- getReceivedCount() - Method in class org.apache.cassandra.service.ReadCallback
-
- 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.SSTableReader
-
- getRecentBloomFilterFalsePositives() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentBloomFilterFalsePositives() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentBloomFilterFalseRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getRecentFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getRecentHitRate() - Method in class org.apache.cassandra.metrics.CacheMetrics
-
Deprecated.
- getRecentLatency() - Method in class org.apache.cassandra.metrics.LatencyMetrics
-
Deprecated.
- getRecentLatencyHistogramMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
-
Deprecated.
- getRecentLatencyMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
-
Deprecated.
- getRecentlyDropped() - Method in class org.apache.cassandra.metrics.DroppedMessageMetrics
-
Deprecated.
- getRecentlyDroppedMessages() - Method in class org.apache.cassandra.net.MessagingService
-
- getRecentlyDroppedMessages() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
dropped message counts since last called
- getRecentRangeLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentRangeLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentRangeLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentRangeLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecentRangeLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentRangeLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentRangeLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentRangeLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecentReadLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentReadLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecentReadLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentReadLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentReadLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentReadLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecentSSTablesPerReadHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentSSTablesPerReadHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentTimeout() - Method in class org.apache.cassandra.metrics.ConnectionMetrics
-
Deprecated.
- getRecentTimeouts() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- getRecentTimeoutsPerHost() - Method in class org.apache.cassandra.net.MessagingService
-
- getRecentTimeoutsPerHost() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Number of timeouts since last check per host.
- getRecentTotalTimeout() - Static method in class org.apache.cassandra.metrics.ConnectionMetrics
-
Deprecated.
- getRecentTotalTimouts() - Method in class org.apache.cassandra.net.MessagingService
-
- getRecentTotalTimouts() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Number of timeouts since last check.
- getRecentTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
-
- getRecentWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecentWriteLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getRecentWriteLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getRecentWriteLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getRecentWriteLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getRecognitionErrors() - Method in class org.apache.cassandra.cql.CqlLexer
-
- getRecognitionErrors() - Method in class org.apache.cassandra.cql.CqlParser
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
-
- 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
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
-
Deprecated.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
-
Get the RecordWriter
for the given task.
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.cql3.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.utils.MergeIterator.Reducer
-
- getRegisteredCallback(int) - Method in class org.apache.cassandra.net.MessagingService
-
- getRegisteredCallbackAge(int) - Method in class org.apache.cassandra.net.MessagingService
-
- getRelation(Bound, Bound) - Method in interface org.apache.cassandra.cql3.statements.Restriction.Slice
-
- getRelation(Bound, Bound) - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Slice
-
- 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
-
- getRepairedSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getReplaceAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReplaceNode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReplaceTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getReplayPosition(Iterable<? extends SSTableReader>) - Static method in class org.apache.cassandra.db.commitlog.ReplayPosition
-
Convenience method to compute the replay position for a group of SSTables.
- getReplayPosition() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- 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
-
- getResponseCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getResponseCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Completed tasks for Response(GOSSIP & RESPONSE) TCP Connections
- getResponseCount() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
-
- getResponsePendingTasks() - Method in class org.apache.cassandra.net.MessagingService
-
- getResponsePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Pending tasks for Response(GOSSIP & RESPONSE) TCP Connections
- 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.
- getResultMetadata() - Method in class org.apache.cassandra.cql3.statements.Selection
-
- getResultMetadata() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- getResultSetIndex(ColumnDefinition) - Method in class org.apache.cassandra.cql3.statements.Selection
-
Returns the index of the specified column within the resultset
- getReturnType(String, String, String) - Static method in class org.apache.cassandra.cql3.functions.Functions
-
- 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
-
- 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
-
- getRowCacheCapacityInBytes() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheCapacityInBytes() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheCapacityInMB() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheCapacityInMB() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheEntries() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheEntries() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheHits() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheHits() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRowCacheKeysToSave() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheKeysToSave() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getRowCacheRecentHitRate() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheRecentHitRate() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheRequests() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheRequests() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRowCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- getRowCacheSize() - Method in class org.apache.cassandra.service.CacheService
-
- getRowCacheSize() - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
Deprecated.
- getRowCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getRpcaddress(InetAddress) - Method in class org.apache.cassandra.service.StorageService
-
Return the rpc address associated with an endpoint as a string.
- getRpcKeepAlive() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- 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.
- 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) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getScanner() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
I/O SSTableScanner
- getScanner(RateLimiter) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getScanner(Range<Token>, RateLimiter) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Direct I/O SSTableScanner over a defined range of tokens.
- getScanner(Collection<Range<Token>>, RateLimiter) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
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.SSTableScanner
-
- getScanner(SSTableReader, Collection<Range<Token>>, RateLimiter) - Static method in class org.apache.cassandra.io.sstable.SSTableScanner
-
- 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, Set<String>) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- getSchema(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
define the schema
- getSchema(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
schema: (value, value, value) where keys are in the front.
- getSchemaKSKey(String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- 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
- 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) - 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.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
-
- 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.TimestampType
-
- 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.UTF8Type
-
- getSerializer() - Method in class org.apache.cassandra.db.marshal.UUIDType
-
- getServerCipherSuites(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- getServerEncryptionOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getServerKeystore(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- getServerKeystorePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- getServerSocket(EncryptionOptions, InetAddress, int) - Static method in class org.apache.cassandra.security.SSLFactory
-
- getServerTruststore(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- getServerTruststorePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- 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
-
- 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(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
-
- getShortName(AbstractType<?>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
- 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
-
- 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
-
- 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
-
- getSSLStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getSSLStoragePort(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- 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
-
- getSSTableLevel() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getSSTableMetadata() - Method in class org.apache.cassandra.io.sstable.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.DataTracker
-
- getSSTables(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- 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
-
- getSSTablesPerReadHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getSSTablesPerReadHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getStage(Stage) - Static method in class org.apache.cassandra.concurrent.StageManager
-
Retrieve a stage from the StageManager
- getStage() - Method in class org.apache.cassandra.net.MessageOut
-
- getStart() - Method in class org.apache.cassandra.cql.SelectExpression
-
- getStartKey() - Method in class org.apache.cassandra.cql.WhereClause
-
- getStartPoints(int, int) - Static method in class org.apache.cassandra.io.sstable.Downsampling
-
- getStartToken() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- getStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- 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
-
- getStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.getStatement_return
-
- getStatements() - Method in class org.apache.cassandra.cql.BatchStatement
-
- 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.AbstractCassandraStorage
-
- getStorageMetric(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
Retrieve Proxy metrics
- getStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getStoragePort(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- getStrategyClass() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
-
- getStrategyOptions() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
-
- 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() - 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
-
- 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
- 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
-
- getText() - Method in class org.apache.cassandra.cql.Term
-
Returns the text parsed to create this term.
- getThreadPoolMBeanProxies() - Method in class org.apache.cassandra.tools.NodeProbe
-
- 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(ThriftClientState) - Method in class org.apache.cassandra.cql.AbstractModification
-
- getTimestamp() - Method in class org.apache.cassandra.cql.Attributes
-
- getTimestamp() - Method in class org.apache.cassandra.cql.BatchStatement
-
- 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() - Method in class org.apache.cassandra.cql.AbstractModification
-
- getTimeToLive() - Method in class org.apache.cassandra.cql.Attributes
-
- getTimeToLive() - Method in class org.apache.cassandra.cql.BatchStatement
-
- getTimeToLive(QueryOptions) - 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) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Converts a milliseconds-since-epoch timestamp into the 16 byte representation
of a type 1 UUID (a time-based UUID).
- getTimeUUIDBytes(long, int) - Static method in class org.apache.cassandra.utils.UUIDGen
-
Converts a 100-nanoseconds precision timestamp into the 16 byte representation
of a type 1 UUID (a time-based UUID).
- 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.AbstractByteOrderedPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
-
- getToken(ByteBuffer) - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
Generate the token of a key.
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getToken() - Method in interface org.apache.cassandra.dht.RingPosition
-
- getToken() - Method in class org.apache.cassandra.dht.Token
-
- getToken() - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- getToken(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Deprecated.
- 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.AbstractByteOrderedPartitioner
-
- getTokenFactory() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getTokenFactory() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getTokenMetadata() - Method in class org.apache.cassandra.service.StorageService
-
- getTokenNames() - Method in class org.apache.cassandra.cli.CliParser
-
- getTokenNames() - Method in class org.apache.cassandra.cql.CqlParser
-
- getTokenNames() - Method in class org.apache.cassandra.cql3.CqlParser
-
- getTokens(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getTokens() - Method in class org.apache.cassandra.service.StorageService
-
- getTokens(String) - Method in class org.apache.cassandra.service.StorageService
-
- getTokens() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch string representations of the tokens for this node.
- getTokens(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch string representations of the tokens for a specified node.
- getTokens() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getTokens(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
- getTokenToEndpointMap() - Method in class org.apache.cassandra.service.StorageService
-
- getTokenToEndpointMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Retrieve a map of tokens to endpoints, including the bootstrapping
ones.
- getTokenToEndpointMap() - Method in class org.apache.cassandra.tools.NodeProbe
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- getTokenValidator() - Method in interface org.apache.cassandra.dht.IPartitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- getTokenValidator() - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- getTokenValue() - Method in class org.apache.cassandra.dht.BytesToken
-
- getTokenValue() - Method in class org.apache.cassandra.dht.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
- getTombstonesPerSlice() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTombstonesPerSlice() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- 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
-
- getTotalBatchesReplayed() - Method in class org.apache.cassandra.db.BatchlogManager
-
- getTotalBatchesReplayed() - Method in interface org.apache.cassandra.db.BatchlogManagerMBean
-
- getTotalBlockedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- getTotalBlockedTasks() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Deprecated.
Get the number of tasks that had blocked before being accepted (or
rejected).
- getTotalBlockedTasks() - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- getTotalBufferSize() - Method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
-
- getTotalBufferSize() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- getTotalBytes() - Method in class org.apache.cassandra.io.sstable.KeyIterator
-
- getTotalBytes() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
-
- getTotalBytes(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
-
- getTotalBytesCompacted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getTotalBytesCompacted() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Deprecated.
- getTotalCommitlogSize() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
- getTotalCommitlogSize() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Deprecated.
- getTotalCommitlogSpaceInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTotalCompactionsCompleted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- getTotalCompactionsCompleted() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Deprecated.
- getTotalCompressedBytesRead() - Method in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- getTotalDiskSpaceUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTotalDiskSpaceUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- 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
-
- getTotalLatencyHistogramMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
-
Deprecated.
- getTotalLatencyMicros() - Method in interface org.apache.cassandra.scheduler.WeightedQueueMBean
-
Deprecated.
- 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
-
- getTotalRangeLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalRangeLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getTotalRangeLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTotalRangeLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getTotalRangeLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalRangeLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getTotalReadLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getTotalReadLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTotalReadLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getTotalReadLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalReadLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- 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
-
- 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.SSTableReader
-
- getTotalWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getTotalWriteLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getTotalWriteLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getTotalWriteLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
-
- getTotalWriteLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getTracingId() - Method in class org.apache.cassandra.transport.Message.Response
-
- getTracingProbability() - Method in class org.apache.cassandra.service.StorageService
-
- getTracingProbability() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the configured tracing probability.
- getTracker() - Method in class org.apache.cassandra.transport.Connection
-
- getTransport() - Method in class org.apache.cassandra.thrift.CustomTNonBlockingServer.CustomFrameBuffer
-
- getTransportFactory() - Method in class org.apache.cassandra.thrift.ThriftServer
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.addColumnFamily_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.addKeyspace_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.arrayConstruct_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.assumeStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.attr_name_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.attrValue_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.attrValueDouble_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.attrValueInt_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.attrValueString_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.columnFamily_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.columnFamilyExpr_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.columnLimitExpr_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.columnName_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.columnOrSuperColumn_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.command_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.comparator_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.connectStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.consistencyLevelStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.countStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.delColumnFamily_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.delKeyspace_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.delStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.describeCluster_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.describeTable_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.dropIndex_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.entityName_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.exitStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.functionArgument_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.functionCall_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.getCondition_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.getStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.hashConstruct_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.hashElementPair_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.helpStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.host_name_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.host_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.incrementValue_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.incrStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.ip_address_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.keyRangeExpr_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.keyspace_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.keyspaceNewName_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.keyValuePair_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.keyValuePairExpr_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.listStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.newColumnFamily_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.operator_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.password_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.port_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.replica_placement_strategy_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.reversedExpr_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.root_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.rowKey_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.rowLimitExpr_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.rowValue_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.setStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.setTraceProbability_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.showClusterName_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.showKeyspaces_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.showSchema_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.showStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.showVersion_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.statement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.traceNextQuery_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.traceSessionId_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.tracingProbability_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.truncateStatement_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.typeIdentifier_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.updateColumnFamily_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.updateKeyspace_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.useKeyspace_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.username_return
-
- getTree() - Method in class org.apache.cassandra.cli.CliParser.value_return
-
- getTreeAdaptor() - Method in class org.apache.cassandra.cli.CliParser
-
- getTrickleFsync() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getTrickleFsyncIntervalInKb() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- 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
-
- getType(ByteBuffer) - Method in class org.apache.cassandra.config.UTMetaData
-
- getType() - Method in class org.apache.cassandra.cql.Term
-
Obtain the term's type.
- getType() - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
-
- getType() - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
-
- getType() - Method in interface org.apache.cassandra.cql3.CQL3Type
-
- getType() - Method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
- getType() - Method in class org.apache.cassandra.cql3.CQL3Type.Tuple
-
- getType() - Method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
-
- 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.serializers.AbstractTextSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- 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.TimestampSerializer
-
- getType() - Method in interface org.apache.cassandra.serializers.TypeSerializer
-
- getType() - Method in class org.apache.cassandra.serializers.UUIDSerializer
-
- getTypeByFunction(String) - Static method in class org.apache.cassandra.cli.CliClient
-
Get AbstractType by function name
- getTypeParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- getUncompactingSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getUncompactingSSTables() - Method in class org.apache.cassandra.db.DataTracker
-
- getUncompactingSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
-
- 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.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
-
- 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
-
- getUsername() - Method in class org.apache.cassandra.cli.CliClient
-
- 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
- getValidator() - Method in enum org.apache.cassandra.cli.CliClient.Function
-
- getValidator() - Method in class org.apache.cassandra.cql.CFPropDefs
-
- getValidatorMap(CfDef) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
get the validators
- getValidColumnFamilies(boolean, boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
- getValidity() - Method in class org.apache.cassandra.auth.PermissionsCache
-
- getValidity() - Method in interface org.apache.cassandra.auth.PermissionsCacheMBean
-
- getValue() - Method in class org.apache.cassandra.cql.Relation
-
- getValue() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
-
For non-IN relations, returns the Tuples.Literal or Tuples.Raw marker for a single tuple.
- getValue() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
-
- getValue() - Method in class org.apache.cassandra.utils.PureJavaCrc32
-
- getValues() - Method in class org.apache.cassandra.cql3.QueryOptions
-
- 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.
- getVersion() - Method in class org.apache.cassandra.config.Schema
-
- getVersion(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- getVersion(String) - Method in class org.apache.cassandra.net.MessagingService
-
- getVersion(String) - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
- GetVersion - Class in org.apache.cassandra.tools
-
- GetVersion() - Constructor for class org.apache.cassandra.tools.GetVersion
-
- getVersion() - Method in class org.apache.cassandra.transport.Connection
-
- getView() - Method in class org.apache.cassandra.db.DataTracker
-
- getWaiting() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
-
Return how many threads are waiting
- getWithProtocolVersion(int) - Method in class org.apache.cassandra.cql3.Lists.Value
-
- getWithProtocolVersion(int) - Method in class org.apache.cassandra.cql3.Maps.Value
-
- getWithProtocolVersion(int) - Method in class org.apache.cassandra.cql3.Sets.Value
-
- getWithProtocolVersion(int) - Method in interface org.apache.cassandra.cql3.Term.CollectionTerminal
-
Gets the value of the collection when serialized with the given protocol version format
- getWorkMap(Multimap<Range<Token>, InetAddress>, String) - 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
-
- getWriteCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- getWriteCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.
- getWriteDirectory(long) - Method in class org.apache.cassandra.io.util.DiskAwareRunnable
-
- getWriteEndpoints(Token, String, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- getWriteOperations() - Method in class org.apache.cassandra.service.StorageProxy
-
- getWriteOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.
- getWriter(int) - Method in class org.apache.cassandra.cache.AutoSavingCache
-
- getWriter() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- getWriteResponseHandler(Collection<InetAddress>, Collection<InetAddress>, ConsistencyLevel, Runnable, WriteType) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- getWriteRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- getWriteRpcTimeout() - Method in class org.apache.cassandra.service.StorageProxy
-
- getWriteRpcTimeout() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- GLOBAL_OPTIONS - Static variable in class org.apache.cassandra.io.compress.CompressionParameters
-
- globalCount() - Method in class org.apache.cassandra.utils.concurrent.Ref
-
A convenience method for reporting:
- globalRangeLatency - Static variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
- globalReadLatency - Static variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
- 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
-
- gossiperStarting() - Method in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch
-
Called in preparation for the initiation of the gossip loop.
- 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
-
- GossipShutdownVerbHandler - Class in org.apache.cassandra.gms
-
- GossipShutdownVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipShutdownVerbHandler
-
- gossipSnitchInfo() - Method in class org.apache.cassandra.service.StorageService
-
- grant(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- grant(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- grant(AuthenticatedUser, Set<Permission>, IResource, String) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Grants a set of permissions on a resource to a user.
- grant(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- grantStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- GrantStatement - Class in org.apache.cassandra.cql3.statements
-
- GrantStatement(Set<Permission>, IResource, String) - Constructor for class org.apache.cassandra.cql3.statements.GrantStatement
-
- group(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) - 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) - Constructor for class org.apache.cassandra.db.filter.ColumnCounter.GroupByPrefixReversed
-
- GT - Static variable in class org.apache.cassandra.io.sstable.SSTableReader.Operator
-
- guid() - Static method in class org.apache.cassandra.utils.GuidGenerator
-
- guidAsBytes() - Static method in class org.apache.cassandra.utils.GuidGenerator
-
- GuidGenerator - Class in org.apache.cassandra.utils
-
- GuidGenerator() - Constructor for class org.apache.cassandra.utils.GuidGenerator
-
- guidToString(byte[]) - Static method in class org.apache.cassandra.utils.GuidGenerator
-
- I - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- I - Static variable in class org.apache.cassandra.cql.CqlParser
-
- I - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- I - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- IAllocator - Interface in org.apache.cassandra.io.util
-
- 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.Option - Enum in org.apache.cassandra.auth
-
Supported CREATE USER/ALTER USER options.
- IAuthorizer - Interface in org.apache.cassandra.auth
-
Primary Cassandra authorization interface.
- IBitSet - Interface in org.apache.cassandra.utils.obs
-
- ICache<K,V> - Interface in org.apache.cassandra.cache
-
This is similar to the Map interface, but requires maintaining a given capacity
and does not require put or remove to return values, which lets SerializingCache
be more efficient by avoiding deserialize except on get.
- IColumnIteratorFactory - Interface in org.apache.cassandra.db.columniterator
-
- ICompressedFile - Interface in org.apache.cassandra.io.util
-
- ICompressor - Interface in org.apache.cassandra.io.compress
-
- ICompressor.WrappedArray - Class in org.apache.cassandra.io.compress
-
A simple wrapper of a byte array.
- id - Variable in class org.apache.cassandra.concurrent.NamedThreadFactory
-
- id - Variable in class org.apache.cassandra.cql3.statements.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.cql.CqlLexer
-
- IDENT - Static variable in class org.apache.cassandra.cql.CqlParser
-
- IDENT - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- IDENT - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- ident() - Method in class org.apache.cassandra.cql3.CqlParser
-
- Identifier - Static variable in class org.apache.cassandra.cli.CliLexer
-
- Identifier - Static variable in class org.apache.cassandra.cli.CliParser
-
- IdentityQueryFilter - Class in org.apache.cassandra.db.columniterator
-
- IdentityQueryFilter() - Constructor for class org.apache.cassandra.db.columniterator.IdentityQueryFilter
-
Will read entire CF into memory.
- 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.
- IExecutorMBean - Interface in org.apache.cassandra.concurrent
-
Deprecated.
- IFailureDetectionEventListener - Interface in org.apache.cassandra.gms
-
Implemented by the Gossiper to convict an endpoint
based on the PHI calculated by the Failure Detector on the inter-arrival
times of the heart beats.
- IFailureDetector - Interface in org.apache.cassandra.gms
-
An interface that provides an application with the ability
to query liveness information of a node in the cluster.
- ifExists - Variable in class org.apache.cassandra.cql3.statements.DropIndexStatement
-
- ifile - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
-
- IFilter - Interface in org.apache.cassandra.utils
-
- IGNORE_HOSTS - Static variable in class org.apache.cassandra.hadoop.AbstractBulkRecordWriter
-
- 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.
- ignoredSchemaRow(Row) - Static method in class org.apache.cassandra.config.Schema
-
- 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.AbstractBulkRecordWriter
-
- 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.sink
-
- 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 - Variable in class org.apache.cassandra.cli.CliSessionState
-
- includeBackups(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
-
- includeFinishKey() - Method in class org.apache.cassandra.cql.SelectStatement
-
- includeFinishKey() - Method in class org.apache.cassandra.cql.WhereClause
-
- includes(Comparator<Composite>, Composite) - Method in class org.apache.cassandra.db.filter.ColumnSlice
-
- includes(Comparator<Composite>, Composite) - Method in class org.apache.cassandra.db.RangeTombstone
-
- includeStartKey() - Method in class org.apache.cassandra.cql.SelectStatement
-
- includeStartKey() - Method in class org.apache.cassandra.cql.WhereClause
-
- 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
-
- INCR - Static variable in class org.apache.cassandra.cli.CliLexer
-
- INCR - Static variable in class org.apache.cassandra.cli.CliParser
-
- 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
-
- 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.SSTableReader
-
Increment the total row read count and read rate for this SSTable.
- incrementTimeout() - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- incrementValue() - Method in class org.apache.cassandra.cli.CliParser
-
- incrementValue_return() - Constructor for class org.apache.cassandra.cli.CliParser.incrementValue_return
-
- incrManualSeverity(double) - Method in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- incrPastWindow(InetAddress) - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
-
- incrStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- incrStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.incrStatement_return
-
- INDEX - Static variable in class org.apache.cassandra.cli.CliLexer
-
- INDEX - Static variable in class org.apache.cassandra.cli.CliParser
-
- index(ByteBuffer, ColumnFamily) - Method in class org.apache.cassandra.db.index.PerRowSecondaryIndex
-
Index the given row.
- INDEX_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- 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.
- IndexCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- 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
-
- indexes(CellName) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnClusteringKey
-
- indexes(CellName) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKey
-
- 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
-
- 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
-
- indexManager - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- indexManager - Variable in class org.apache.cassandra.db.index.SecondaryIndexSearcher
-
- indexName - Variable in class org.apache.cassandra.cql.DropIndexStatement
-
- indexName() - 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
-
- 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
-
- indexSerializer() - Method in class org.apache.cassandra.db.composites.AbstractCType
-
- indexSerializer() - Method in interface org.apache.cassandra.db.composites.CType
-
- indexSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Lists
-
- 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>, List<SSTableReader>, 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
-
- 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
-
- inFileMode() - Method in class org.apache.cassandra.cli.CliSessionState
-
- 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.hadoop.AbstractBulkRecordWriter.ExternalClient
-
- 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(String) - Method in class org.apache.cassandra.tools.BulkLoader.ExternalClient
-
- init() - Method in class org.apache.cassandra.utils.MerkleTree
-
Initializes this tree by splitting it until hashdepth is reached,
or until an additional level of splits would violate maxsize.
- initCf(UUID, String, boolean) - Method in class org.apache.cassandra.db.Keyspace
-
adds a cf to internal structures, ends up creating disk files).
- initClient() - Method in class org.apache.cassandra.service.StorageService
-
- initClient(int) - Method in class org.apache.cassandra.service.StorageService
-
- initHostAddress - Variable in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- 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
-
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
-
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
-
- 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) - Static method in class org.apache.cassandra.streaming.StreamResultFuture
-
- initSchema(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
Methods to get the column family schema from Cassandra
- initServer() - Method in class org.apache.cassandra.service.StorageService
-
- initServer(int) - Method in class org.apache.cassandra.service.StorageService
-
- injectApplicationState(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.Gossiper
-
- 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
-
- inOrderTester(boolean) - Method in class org.apache.cassandra.db.DeletionInfo
-
- 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.AbstractCassandraStorage
-
- 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.cql.CqlParser
-
- insertStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- insertUser(String, boolean) - Static method in class org.apache.cassandra.auth.Auth
-
Inserts the user into AUTH_KS.USERS_CF (or overwrites their superuser status as a result of an ALTER USER query).
- inspectCommitLogThrowable(Throwable) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
-
- 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.CounterColumnType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.DateType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.DecimalType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.DoubleType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.EmptyType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.FloatType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.InetAddressType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.Int32Type
-
- instance - Static variable in class org.apache.cassandra.db.marshal.IntegerType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.LexicalUUIDType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.LongType
-
- instance - Static variable in class org.apache.cassandra.db.marshal.TimestampType
-
- 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.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.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.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.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.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.memory.HeapAllocator
-
- InstrumentingCache<K,V> - Class in org.apache.cassandra.cache
-
Wraps an ICache in requests + hits tracking.
- InstrumentingCache(String, ICache<K, V>) - Constructor for class org.apache.cassandra.cache.InstrumentingCache
-
- 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 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- INTEGER - Static variable in class org.apache.cassandra.cql.CqlParser
-
- integer(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
-
- INTEGER - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- INTEGER - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- IntegerNegativeLiteral - Static variable in class org.apache.cassandra.cli.CliLexer
-
- IntegerNegativeLiteral - Static variable in class org.apache.cassandra.cli.CliParser
-
- IntegerPositiveLiteral - Static variable in class org.apache.cassandra.cli.CliLexer
-
- IntegerPositiveLiteral - Static variable in class org.apache.cassandra.cli.CliParser
-
- 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
-
- internalIP(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- 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.DataTracker.View
-
- IntervalTree<C,D,I extends Interval<C,D>> - Class in org.apache.cassandra.utils
-
- IntervalTree(Collection<I>, Comparator<C>) - Constructor for class org.apache.cassandra.utils.IntervalTree
-
- IntervalTree.Serializer<C,D,I extends Interval<C,D>> - Class in org.apache.cassandra.utils
-
- inTransportFactory - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- intTerm() - Method in class org.apache.cassandra.cql.CqlParser
-
- 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.db.ColumnFamilyStore
-
call when dropping or renaming a CF.
- invalidate() - Method in class org.apache.cassandra.db.index.AbstractSimplePerColumnSecondaryIndex
-
- invalidate() - Method in class org.apache.cassandra.db.index.SecondaryIndex
-
Remove the index and unregisters this index's mbean if one exists
- invalidate() - Method in class org.apache.cassandra.db.index.SecondaryIndexManager
-
Remove the index
- invalidate(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() - 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() - 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() - Constructor for class org.apache.cassandra.tools.NodeTool.InvalidateRowCache
-
- invalidateRowCacheForCf(Pair<String, String>) - Method in class org.apache.cassandra.service.CacheService
-
- InvalidRequestException - Exception in org.apache.cassandra.exceptions
-
- InvalidRequestException(String) - Constructor for exception org.apache.cassandra.exceptions.InvalidRequestException
-
- invalids() - Method in class org.apache.cassandra.utils.MerkleTree
-
Returns a lazy iterator of invalid TreeRanges that need to be filled
in order to make the given Range valid.
- invalidSchemaRow(Row) - Static method in class org.apache.cassandra.config.Schema
-
- 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.AbstractTracingAwareExecutorService
-
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.AbstractTracingAwareExecutorService
-
- invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.cassandra.concurrent.AbstractTracingAwareExecutorService
-
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.AbstractTracingAwareExecutorService
-
- InWithMarker(AbstractMarker) - Constructor for class org.apache.cassandra.cql3.statements.MultiColumnRestriction.InWithMarker
-
- InWithMarker(AbstractMarker) - Constructor for class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithMarker
-
- InWithValues(List<? extends Term>) - Constructor for class org.apache.cassandra.cql3.statements.MultiColumnRestriction.InWithValues
-
- InWithValues(List<? extends Term>) - Constructor for class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithValues
-
- IOWAIT_INDEX - Static variable in class org.apache.cassandra.utils.BackgroundActivityMonitor
-
- IP_ADDRESS - Static variable in class org.apache.cassandra.cli.CliLexer
-
- IP_ADDRESS - Static variable in class org.apache.cassandra.cli.CliParser
-
- ip_address() - Method in class org.apache.cassandra.cli.CliParser
-
- ip_address_return() - Constructor for class org.apache.cassandra.cli.CliParser.ip_address_return
-
- IPartitioner - Interface in org.apache.cassandra.dht
-
- IReadCommand - Interface in org.apache.cassandra.service
-
- IRepairJobEventListener - Interface in org.apache.cassandra.repair
-
Implemented by the RepairSession to accept callbacks from sequential snapshot creation failure.
- IRequestCoordinator<R> - Interface in org.apache.cassandra.repair
-
- IRequestProcessor<R> - Interface in org.apache.cassandra.repair
-
- IRequestScheduler - Interface in org.apache.cassandra.scheduler
-
Implementors of IRequestScheduler must provide a constructor taking a RequestSchedulerOptions object.
- IRequestSink - Interface in org.apache.cassandra.sink
-
- IResource - Interface in org.apache.cassandra.auth
-
The interface at the core of Cassandra authorization.
- IResponseResolver<TMessage,TResolved> - Interface in org.apache.cassandra.service
-
- IRowCacheEntry - Interface in org.apache.cassandra.cache
-
- 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
-
- isAlive() - Method in class org.apache.cassandra.gms.EndpointState
-
- isAlive(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
-
- isAlive(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
-
Failure Detector's knowledge of whether a node is up or
down.
- 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.
- ISaslAwareAuthenticator - Interface in org.apache.cassandra.auth
-
- ISaslAwareAuthenticator.SaslAuthenticator - Interface in org.apache.cassandra.auth
-
- isAssignableTo(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
-
- isAssignableTo(String, ColumnSpecification) - Method in interface org.apache.cassandra.cql3.AssignementTestable
-
- isAssignableTo(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Constants.Literal
-
- isAssignableTo(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
-
- isAssignableTo(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Lists.Literal
-
- isAssignableTo(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Maps.Literal
-
- isAssignableTo(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Sets.Literal
-
- isAssignableTo(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Tuples.Literal
-
- isAssignableTo(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.TypeCast
-
- isAssignableTo(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.UserTypes.Literal
-
- 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
-
- isBindMarker() - Method in class org.apache.cassandra.cql.Term
-
- 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
-
- 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.UTF8Type
-
- isCancelled() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
-
- isCapacitySetManually() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- isClean() - Method in class org.apache.cassandra.db.Memtable
-
- isCleanAfter(ReplayPosition) - 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
-
- isClientMode() - Method in class org.apache.cassandra.service.StorageService
-
- isCollection() - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
-
- isCollection() - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
-
- isCollection() - Method in interface org.apache.cassandra.cql3.CQL3Type
-
- isCollection() - Method in enum org.apache.cassandra.cql3.CQL3Type.Native
-
- isCollection() - Method in class org.apache.cassandra.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
-
- isCollectionKeys - Variable in class org.apache.cassandra.cql3.statements.IndexTarget
-
- isColumnFamilyLevel() - Method in class org.apache.cassandra.auth.DataResource
-
- isColumnList() - Method in class org.apache.cassandra.cql.SelectExpression
-
- isColumnRange() - Method in class org.apache.cassandra.cql.SelectExpression
-
- isColumnRange() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isColumnsReversed() - Method in class org.apache.cassandra.cql.SelectExpression
-
- isColumnsReversed() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isCompacting(Iterable<ColumnFamilyStore>) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- isCompactionManager - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
-
- isCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- isCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.Addition
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.Prepend
-
- isCompatibleWith(Operation.RawUpdate) - Method in interface org.apache.cassandra.cql3.Operation.RawUpdate
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.SetElement
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.SetValue
-
- isCompatibleWith(Operation.RawUpdate) - Method in class org.apache.cassandra.cql3.Operation.Substraction
-
- isCompatibleWith(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
-
- 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.ISaslAwareAuthenticator.SaslAuthenticator
-
- 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
-
- isConnected() - Static method in class org.apache.cassandra.cli.CliMain
-
Checks whether the thrift client is connected.
- isContains() - Method in interface org.apache.cassandra.cql3.statements.Restriction
-
- isContains() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Contains
-
- isContains() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.EQ
-
- isContains() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithMarker
-
- isContains() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithValues
-
- isContains() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Slice
-
- 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.db.IndexExpression
-
Checks if the operator of this IndexExpression
is a CONTAINS_KEY
operator.
- isCount - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
-
- 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
-
- isCountOperation() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isCQL3Table() - Method in class org.apache.cassandra.config.CFMetaData
-
- isCustom - Variable in class org.apache.cassandra.cql3.statements.IndexPropDefs
-
- 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
-
- isEmpty() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- isEmpty() - Method in class org.apache.cassandra.cache.SerializingCache
-
- isEmpty() - Method in class org.apache.cassandra.cql3.UntypedResultSet
-
- isEmpty() - Method in class org.apache.cassandra.cql3.UserOptions
-
- isEmpty() - Method in class org.apache.cassandra.db.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.composites.AbstractComposite
-
- isEmpty() - Method in interface org.apache.cassandra.db.composites.Composite
-
- 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.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
- 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
-
- isEOF() - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- isEOF() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- isEOF() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- isEQ() - Method in interface org.apache.cassandra.cql3.statements.Restriction
-
- isEQ() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Contains
-
- isEQ() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.EQ
-
- isEQ() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithMarker
-
- isEQ() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithValues
-
- isEQ() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Slice
-
- ISerializer<T> - Interface in org.apache.cassandra.io
-
- 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.
- isExistingUser(String) - Static method in class org.apache.cassandra.auth.Auth
-
Checks if the username is stored in AUTH_KS.USERS_CF.
- isExpired() - Method in class org.apache.cassandra.db.Memtable
-
- isFailed() - Method in class org.apache.cassandra.repair.RepairJob
-
- 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
-
- isFatClient(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
A fat client is a node that has not joined the ring, therefore acting as a coordinator only.
- isFilterFullyCoveredBy(IDiskAtomFilter, ColumnFamily, long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isFinal - Variable in enum org.apache.cassandra.io.sstable.SSTableWriter.FinishType
-
- isForOutgoing - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
-
- isFullCollection - Variable in class org.apache.cassandra.cql3.statements.IndexTarget
-
- isFullRowSlice(SliceQueryFilter) - Static method in class org.apache.cassandra.db.DataRange
-
- isFullWildcard() - Method in class org.apache.cassandra.cql.SelectStatement
-
- 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
-
- 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 interface org.apache.cassandra.cql3.statements.Restriction
-
- isIN() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Contains
-
- isIN() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.EQ
-
- isIN() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithMarker
-
- isIN() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithValues
-
- isIN() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Slice
-
- isInBounds(T, Iterable<Bounds<T>>) - Static method in class org.apache.cassandra.dht.Bounds
-
- isInclusive(Bound) - Method in interface org.apache.cassandra.cql3.statements.Restriction.Slice
-
Returns true if the start or end bound (depending on the argument) is inclusive, false otherwise
- isInclusive(Bound) - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Slice
-
Returns true if the start or end bound (depending on the argument) is inclusive, false otherwise
- 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
-
- 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
-
- 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
-
- isKeyCacheEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- isKeyRange() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isKeyRange() - Method in class org.apache.cassandra.cql.WhereClause
-
- isKeyspaceLevel() - Method in class org.apache.cassandra.auth.DataResource
-
- isKnownEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
- isLatencyForSnitch() - Method in 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 - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- isLeaving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- isLegacy(String) - Static method in class org.apache.cassandra.cache.CachingOptions
-
- 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.SSTableReader
-
- isMarkedForDelete() - Method in class org.apache.cassandra.db.ColumnFamily
-
- isMarkedSuspect() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- isMember(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- isMemoryLockable() - Method in interface org.apache.cassandra.service.NativeAccessMBean
-
- isMinimum(IPartitioner) - Method in class org.apache.cassandra.db.DecoratedKey
-
- isMinimum() - Method in class org.apache.cassandra.db.DecoratedKey
-
- isMinimum() - Method in interface org.apache.cassandra.db.RowPosition
-
- isMinimum(IPartitioner) - Method in interface org.apache.cassandra.dht.RingPosition
-
- isMinimum(IPartitioner) - Method in class org.apache.cassandra.dht.Token
-
- isMinimum() - Method in class org.apache.cassandra.dht.Token
-
- isMinimum(IPartitioner) - Method in class org.apache.cassandra.dht.Token.KeyBound
-
- 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
-
- isMultiColumn() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
-
- isMultiColumn() - Method in class org.apache.cassandra.cql3.statements.MultiColumnRestriction.EQ
-
- isMultiColumn() - Method in class org.apache.cassandra.cql3.statements.MultiColumnRestriction.InWithMarker
-
- isMultiColumn() - Method in class org.apache.cassandra.cql3.statements.MultiColumnRestriction.InWithValues
-
- isMultiColumn() - Method in class org.apache.cassandra.cql3.statements.MultiColumnRestriction.Slice
-
- isMultiColumn() - Method in interface org.apache.cassandra.cql3.statements.Restriction
-
- isMultiColumn() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction
-
- isMultiKey() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isMultiKey() - Method in class org.apache.cassandra.cql.WhereClause
-
- isNameValid(String) - Static method in class org.apache.cassandra.config.CFMetaData
-
- isNativeTransportRunning() - Method in class org.apache.cassandra.service.StorageService
-
- isNativeTransportRunning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- isNativeTransportRunning() - Method in class org.apache.cassandra.tools.NodeProbe
-
- isolateReferences() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- isOnAllComponents() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isOnToken() - Method in class org.apache.cassandra.cql3.Relation
-
- isOnToken() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
-
- isOnToken() - Method in interface org.apache.cassandra.cql3.statements.Restriction
-
- isOnToken() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Contains
-
- isOnToken() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.EQ
-
- isOnToken() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithMarker
-
- isOnToken() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithValues
-
- isOnToken() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Slice
-
- 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
-
- 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(ByteBuffer) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
-
- isPresent(ByteBuffer) - Method in class org.apache.cassandra.utils.BloomFilter
-
- isPresent(ByteBuffer) - Method in interface org.apache.cassandra.utils.IFilter
-
- isPrimaryKeyColumn() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- isPure() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- isPure() - Method in interface org.apache.cassandra.cql3.functions.Function
-
- isPurged() - Method in class org.apache.cassandra.config.CFMetaData
-
- isReadyForBootstrap() - Static method in class org.apache.cassandra.service.MigrationManager
-
- isReceiving() - Method in class org.apache.cassandra.streaming.StreamCoordinator
-
- isRemote() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
-
- isRepaired() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- isReplaced() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- isReplacing() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- isReversed() - Method in interface org.apache.cassandra.db.filter.IDiskAtomFilter
-
- isReversed() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
-
- isReversed() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- 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
-
- isRootLevel() - Method in class org.apache.cassandra.auth.DataResource
-
- isRowCacheEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- 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) - 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
-
- isSetConsistencyLevel() - Method in class org.apache.cassandra.cql.AbstractModification
-
True if an explicit consistency level was parsed from the statement.
- isSetConsistencyLevel() - Method in class org.apache.cassandra.cql.UpdateStatement
-
True if an explicit consistency level was parsed from the statement.
- isSetKeyspace() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isSetTimestamp() - Method in class org.apache.cassandra.cql.AbstractModification
-
- isSetTimestamp() - Method in class org.apache.cassandra.cql.BatchStatement
-
- 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
-
- isSlice() - Method in interface org.apache.cassandra.cql3.statements.Restriction
-
- isSlice() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Contains
-
- isSlice() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.EQ
-
- isSlice() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithMarker
-
- isSlice() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithValues
-
- isSlice() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.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.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
-
- 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
-
- 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() - Method in class org.apache.cassandra.config.CFMetaData
-
- isSuperuser(String) - Static method in class org.apache.cassandra.auth.Auth
-
Checks if the user is a known superuser.
- isSupportedBy(SemanticVersion) - Method in class org.apache.cassandra.utils.SemanticVersion
-
- 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
-
- 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
-
- isUnary() - Method in class org.apache.cassandra.cql.Operation
-
- isUnreadable(File) - Static method in class org.apache.cassandra.db.BlacklistedDirectories
-
Tells whether or not the directory is blacklisted for reads.
- isUnused() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
- isUnwritable(File) - Static method in class org.apache.cassandra.db.BlacklistedDirectories
-
Tells whether or not the directory is blacklisted for writes.
- isUserDefined - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- isValid(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
-
- 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.TimestampType
-
- 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.cql.SelectExpression
-
- isWildcard() - Method in class org.apache.cassandra.cql.SelectStatement
-
- isWildcard() - Method in class org.apache.cassandra.cql3.statements.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.statements.Selectable.WritetimeOrTTL
-
- 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 - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
-
- iterator(long) - Method in class org.apache.cassandra.io.util.SegmentedFile
-
- iterator() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- 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
-
- 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
-
- M - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- M - Static variable in class org.apache.cassandra.cql.CqlParser
-
- M - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- M - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- mA() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mA() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- main(String[]) - Static method in class org.apache.cassandra.cli.CliMain
-
- main(String[]) - Static method in class org.apache.cassandra.gms.FailureDetector
-
- main(String[]) - Static method in class org.apache.cassandra.service.CassandraDaemon
-
- main(String[]) - Static method in class org.apache.cassandra.tools.BulkLoader
-
- main(String[]) - Static method in class org.apache.cassandra.tools.GetVersion
-
- main(String...) - Static method in class org.apache.cassandra.tools.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.transport.Client
-
- major - Variable in class org.apache.cassandra.utils.SemanticVersion
-
- 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(ColumnSpecification, 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.
- makeColumn(CellName, ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- makeCounter(CellName, long) - Method in class org.apache.cassandra.cql3.UpdateParameters
-
- makeCountMetadata(String, String, ColumnIdentifier) - Static method in class org.apache.cassandra.cql3.ResultSet
-
- makeCountResult(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.ResultSet
-
- makeCountResult(String, String, long, ColumnIdentifier) - Static method in class org.apache.cassandra.cql3.ResultSet
-
- 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
-
- 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
-
- makeFilename(File, String, String) - Static method in class org.apache.cassandra.io.sstable.AbstractSSTableSimpleWriter
-
- makeFromBlobFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.BytesConversionFcts
-
- makeIndexColumnName(ByteBuffer, 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.CompositesIndexOnClusteringKey
-
- makeIndexColumnPrefix(ByteBuffer, Composite) - Method in class org.apache.cassandra.db.index.composites.CompositesIndexOnCollectionKey
-
- 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
-
- 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
-
- makeRowBounds(Token, Token, IPartitioner) - Static method in class org.apache.cassandra.dht.Bounds
-
Compute a bounds of keys corresponding to a given bounds of token.
- makeRowRange(Token, Token, IPartitioner) - Static method in class org.apache.cassandra.dht.Range
-
Compute a range of keys corresponding to a given range of token.
- 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.
- 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
-
- malloc(long) - Method in interface org.apache.cassandra.io.util.JEMallocAllocator.JEMLibrary
-
- mAlnum() - Method in class org.apache.cassandra.cli.CliLexer
-
- manages(String) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManager
-
- mAND() - Method in class org.apache.cassandra.cli.CliLexer
-
- 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
-
- mAPI_VERSION() - Method in class org.apache.cassandra.cli.CliLexer
-
- mapLiteral() - Method in class org.apache.cassandra.cql3.CqlParser
-
- MappedFileDataInput - Class in org.apache.cassandra.io.util
-
- MappedFileDataInput(MappedByteBuffer, String, long, int) - Constructor for class org.apache.cassandra.io.util.MappedFileDataInput
-
- MAPRED_TASK_ID - Static variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
-
- Maps - Class in org.apache.cassandra.cql3
-
Static helper methods and classes for maps.
- Maps.DelayedValue - Class in org.apache.cassandra.cql3
-
- Maps.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.SSTableWriter
-
- mark - Variable in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
The current mark position.
- mark(int) - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Sets a mark position in this ByteArrayInputStream.
- mark() - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- mark(int) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- mark() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- mark() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- mark() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- mark() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
-
- 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() - 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.
- markCompactedSSTablesReplaced(Collection<SSTableReader>, Collection<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.DataTracker
-
- markCompacting(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
-
- markCompacting(Collection<SSTableReader>, boolean, boolean) - Method in class org.apache.cassandra.db.DataTracker
-
- 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, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Lists.Marker
-
- Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Maps.Marker
-
- Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Sets.Marker
-
- marker - Variable in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithMarker
-
- 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.DataTracker
-
- 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(Collection<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.DataTracker
-
- markObsolete(DataTracker) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
Mark the sstable as obsolete, i.e., compacted into newer sstables.
- markSSTablesRepairing(UUID, UUID) - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
Marks all the unrepaired sstables as repairing unless we have already done so.
- markSupported() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Indicates whether this stream supports the mark()
and
reset()
methods.
- markSupported() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- markSupported() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- markSuspect() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- MarshalException - Exception in org.apache.cassandra.serializers
-
- MarshalException(String) - Constructor for exception org.apache.cassandra.serializers.MarshalException
-
- MarshalException(String, Throwable) - Constructor for exception org.apache.cassandra.serializers.MarshalException
-
- mASSUME() - Method in class org.apache.cassandra.cli.CliLexer
-
- max() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- max - Variable in class org.apache.cassandra.utils.Interval
-
- max() - Method in class org.apache.cassandra.utils.IntervalTree
-
- MAX_COLUMNS_DEFAULT - Static variable in class org.apache.cassandra.cql.SelectExpression
-
- MAX_ELEMENTS - Static variable in class org.apache.cassandra.db.marshal.CollectionType
-
- MAX_FAILED_HOSTS - Static variable in class org.apache.cassandra.hadoop.AbstractBulkRecordWriter
-
- max_hint_window_in_ms - Variable in class org.apache.cassandra.config.Config
-
- max_hints_delivery_threads - Variable in class org.apache.cassandra.config.Config
-
- MAX_NAME_LENGTH - Static variable in interface org.apache.cassandra.db.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
-
- 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
-
- 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
-
- 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.SSTableReader
-
maxDataAge is a timestamp in local server time (e.g.
- maxFailures - Variable in class org.apache.cassandra.hadoop.AbstractBulkRecordWriter
-
- MAXIMUM - Static variable in class org.apache.cassandra.dht.Murmur3Partitioner
-
- MAXIMUM - Static variable in class org.apache.cassandra.dht.RandomPartitioner
-
- maxIndexInterval(int) - Method in class org.apache.cassandra.config.CFMetaData
-
- MaxIntTracker(int) - Constructor for class org.apache.cassandra.io.sstable.ColumnStats.MaxIntTracker
-
- maxKeyBound(IPartitioner) - Method in class org.apache.cassandra.dht.Token
-
- 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
-
- 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
- maxPurgeableTimestamp(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.CompactionController
-
- maxPurgeableTimestamp(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplitController
-
- 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
- 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
-
- 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.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.TimeuuidFcts
-
- 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.
- 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(DataResource, ClientState) - Static method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
-
- maybeEscapeName(String) - Static method in class org.apache.cassandra.cli.CliUtils
-
- maybeExecuteImmediately(Runnable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
-
- maybeExecuteImmediately(Runnable) - Method in class org.apache.cassandra.concurrent.SEPExecutor
-
- maybeExecuteImmediately(Runnable) - Method in interface org.apache.cassandra.concurrent.TracingAwareExecutorService
-
- 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.DataTracker
-
- 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
-
- 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
-
- 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.cql.CqlLexer
-
- mB() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- MBEAN_NAME - Static variable in class org.apache.cassandra.db.BlacklistedDirectories
-
- MBEAN_NAME - Static variable in class org.apache.cassandra.db.HintedHandOffManager
-
- MBEAN_NAME - Static variable in class org.apache.cassandra.gms.FailureDetector
-
- MBEAN_NAME - Static variable in class org.apache.cassandra.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
-
- mBY() - Method in class org.apache.cassandra.cli.CliLexer
-
- mC() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mC() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mCharacterEscapeSequence() - Method in class org.apache.cassandra.cli.CliLexer
-
- mCOLUMN() - Method in class org.apache.cassandra.cli.CliLexer
-
- mCOMMENT() - Method in class org.apache.cassandra.cli.CliLexer
-
- mCOMMENT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mCOMMENT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mCOMPIDENT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mCONFIG() - Method in class org.apache.cassandra.cli.CliLexer
-
- mCONNECT() - Method in class org.apache.cassandra.cli.CliLexer
-
- mCONSISTENCYLEVEL() - Method in class org.apache.cassandra.cli.CliLexer
-
- mCOUNT() - Method in class org.apache.cassandra.cli.CliLexer
-
- mCREATE() - Method in class org.apache.cassandra.cli.CliLexer
-
- mD() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mD() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- MD5Digest - Class in org.apache.cassandra.utils
-
The result of the computation of an MD5 digest.
- mDecimalDigit() - Method in class org.apache.cassandra.cli.CliLexer
-
- mDECR() - Method in class org.apache.cassandra.cli.CliLexer
-
- mDEL() - Method in class org.apache.cassandra.cli.CliLexer
-
- mDESCRIBE() - Method in class org.apache.cassandra.cli.CliLexer
-
- mDigit() - Method in class org.apache.cassandra.cli.CliLexer
-
- mDIGIT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mDIGIT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mDoubleLiteral() - Method in class org.apache.cassandra.cli.CliLexer
-
- mDROP() - Method in class org.apache.cassandra.cli.CliLexer
-
- mE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mean() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
- 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
-
- MemoryInputStream - Class in org.apache.cassandra.io.util
-
- MemoryInputStream(Memory) - Constructor for class org.apache.cassandra.io.util.MemoryInputStream
-
- MemoryOutputStream - Class in org.apache.cassandra.io.util
-
This class provides a way to stream the writes into the
Memory
- MemoryOutputStream(Memory) - Constructor for class org.apache.cassandra.io.util.MemoryOutputStream
-
- 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(ColumnFamilyStore) - 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.
- mergeSchema(Collection<Mutation>) - Static method in class org.apache.cassandra.db.DefsTables
-
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)
- mergeSchemaInternal(Collection<Mutation>, boolean) - Static method in class org.apache.cassandra.db.DefsTables
-
- mergeTombstoneHistogram(StreamingHistogram) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- 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
-
- mEscapeCharacter() - Method in class org.apache.cassandra.cli.CliLexer
-
- mEscapeSequence() - Method in class org.apache.cassandra.cli.CliLexer
-
- Message - Class in org.apache.cassandra.transport
-
A message from the CQL binary protocol.
- Message(Message.Type) - Constructor for class org.apache.cassandra.transport.Message
-
- Message.Codec<M extends Message> - Interface in org.apache.cassandra.transport
-
- Message.Direction - Enum in org.apache.cassandra.transport
-
- Message.Dispatcher - Class in org.apache.cassandra.transport
-
- Message.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(List<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.ResultSet.Metadata
-
- 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, boolean) - 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 - Class in org.apache.cassandra.io.sstable.metadata
-
- MetadataCollector(CellNameType) - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- MetadataCollector(Collection<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.
- metric - Variable in class org.apache.cassandra.db.ColumnFamilyStore
-
- metric - Variable in class org.apache.cassandra.db.Keyspace
-
- MetricNameFactory - Interface in org.apache.cassandra.metrics
-
- metricPercentilesAsArray(long[]) - Method in class org.apache.cassandra.tools.NodeProbe
-
- metrics - Static variable in class org.apache.cassandra.cql3.QueryProcessor
-
- metrics - Variable in class org.apache.cassandra.db.HintedHandOffManager
-
- mEXIT() - Method in class org.apache.cassandra.cli.CliLexer
-
- mEXPONENT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mF() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mF() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mFAMILY() - Method in class org.apache.cassandra.cli.CliLexer
-
- mFILE() - Method in class org.apache.cassandra.cli.CliLexer
-
- mFLOAT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mFLOAT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mG() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mG() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mGET() - Method in class org.apache.cassandra.cli.CliLexer
-
- mH() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mH() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mHELP() - Method in class org.apache.cassandra.cli.CliLexer
-
- mHEX() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mHEX() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mHexDigit() - Method in class org.apache.cassandra.cli.CliLexer
-
- mHexEscapeSequence() - Method in class org.apache.cassandra.cli.CliLexer
-
- mHEXNUMBER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mI() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mI() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- microsTimestamp(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
-
- mIDENT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mIDENT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mIdentifier() - Method in class org.apache.cassandra.cli.CliLexer
-
- midpoint(Token, Token) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
-
- midpoint(Token, Token) - Method in interface org.apache.cassandra.dht.IPartitioner
-
Calculate a Token representing the approximate "middle" of the given
range.
- midpoint(Token, Token) - Method in class org.apache.cassandra.dht.LocalPartitioner
-
- midpoint(Token, Token) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
-
- midpoint(Token, Token) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- midpoint(Token, Token) - Method in class org.apache.cassandra.dht.RandomPartitioner
-
- midpoint(BigInteger, BigInteger, int) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Given two bit arrays represented as BigIntegers, containing the given
number of significant bits, calculate a midpoint.
- 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
-
- 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*.
- mINCR() - Method in class org.apache.cassandra.cli.CliLexer
-
- mINDEX() - Method in class org.apache.cassandra.cli.CliLexer
-
- 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.AbstractByteOrderedPartitioner
-
- MINIMUM - Static variable in class org.apache.cassandra.dht.Murmur3Partitioner
-
- MINIMUM - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
-
- MINIMUM - Static variable in class org.apache.cassandra.dht.RandomPartitioner
-
- minIndexInterval(int) - Method in class org.apache.cassandra.config.CFMetaData
-
- minKeyBound(IPartitioner) - Method in class org.apache.cassandra.dht.Token
-
- 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.SemanticVersion
-
- 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
-
- mINTEGER() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mINTEGER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mIntegerNegativeLiteral() - Method in class org.apache.cassandra.cli.CliLexer
-
- mIntegerPositiveLiteral() - Method in class org.apache.cassandra.cli.CliLexer
-
- minTimestamp() - Method in class org.apache.cassandra.db.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.TimeuuidFcts
-
- minValue(Class<R>) - Method in interface org.apache.cassandra.dht.IPartitioner
-
- mIP_ADDRESS() - Method in class org.apache.cassandra.cli.CliLexer
-
- mJ() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mJ() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_ADD() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_ADD() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_ALL() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_ALLOW() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_ALTER() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_ALTER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_AND() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_AND() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_APPLY() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_APPLY() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_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.cql.CqlLexer
-
- mK_BATCH() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_BEGIN() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_BEGIN() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_BIGINT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_BLOB() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_BOOLEAN() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_BY() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_CLUSTERING() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_COLUMNFAMILY() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_COLUMNFAMILY() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_COMPACT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_CONSISTENCY() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_CONTAINS() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_COUNT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_COUNT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_COUNTER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_CREATE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_CREATE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_CUSTOM() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_DECIMAL() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_DELETE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_DELETE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_DESC() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_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.cql.CqlLexer
-
- mK_DROP() - 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_FIRST() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_FLOAT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_FROM() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_FROM() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_FROZEN() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_FULL() - 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.cql.CqlLexer
-
- mK_IN() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_INDEX() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_INDEX() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_INET() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_INFINITY() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_INSERT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_INSERT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_INT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_INTO() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_INTO() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_KEY() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_KEY() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_KEYS() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_KEYSPACE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_KEYSPACE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_KEYSPACES() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_LEVEL() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_LIMIT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_LIMIT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_LIST() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_MAP() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_MODIFY() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_NAN() - 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.cql.CqlLexer
-
- mK_ON() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_ORDER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_PASSWORD() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_PERMISSION() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_PERMISSIONS() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_PRIMARY() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_PRIMARY() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_RENAME() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_REVERSED() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_REVOKE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_SELECT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_SELECT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_SET() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_SET() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_STATIC() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_STORAGE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_SUPERUSER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TEXT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TIMESTAMP() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_TIMESTAMP() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TIMEUUID() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TO() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TOKEN() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TRIGGER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TRUNCATE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_TRUNCATE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TTL() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_TTL() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TUPLE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_TYPE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_TYPE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_UNLOGGED() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_UPDATE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_UPDATE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_USE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_USE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_USER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_USERS() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_USING() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_USING() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_UUID() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_VALUES() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_VALUES() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_VARCHAR() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_VARINT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_WHERE() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_WHERE() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_WITH() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mK_WITH() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mK_WRITETIME() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mKEYSPACE() - Method in class org.apache.cassandra.cli.CliLexer
-
- mKEYSPACES() - Method in class org.apache.cassandra.cli.CliLexer
-
- mL() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mL() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mLetter() - Method in class org.apache.cassandra.cli.CliLexer
-
- mLETTER() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mLETTER() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mLIMIT() - Method in class org.apache.cassandra.cli.CliLexer
-
- mLIST() - Method in class org.apache.cassandra.cli.CliLexer
-
- mM() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mM() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- MmappedSegmentedFile - Class in org.apache.cassandra.io.util
-
- MmappedSegmentedFile(String, long, SegmentedFile.Segment[]) - Constructor for class org.apache.cassandra.io.util.MmappedSegmentedFile
-
- 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.cql.CqlLexer
-
- mMULTILINE_COMMENT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mN() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mN() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mNEXT() - Method in class org.apache.cassandra.cli.CliLexer
-
- mNonEscapeCharacter() - Method in class org.apache.cassandra.cli.CliLexer
-
- mO() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mO() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- 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
-
- mON() - Method in class org.apache.cassandra.cli.CliLexer
-
- 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() - 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.cql.CqlLexer
-
- mP() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mPROBABILITY() - Method in class org.apache.cassandra.cli.CliLexer
-
- mQ() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mQ() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mQMARK() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mQMARK() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mQUERY() - Method in class org.apache.cassandra.cli.CliLexer
-
- mQUIT() - Method in class org.apache.cassandra.cli.CliLexer
-
- mQUOTED_NAME() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mR() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mR() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mRANGEOP() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mS() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mS() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mSCHEMA() - Method in class org.apache.cassandra.cli.CliLexer
-
- mSEMICOLON() - Method in class org.apache.cassandra.cli.CliLexer
-
- mSET() - Method in class org.apache.cassandra.cli.CliLexer
-
- mSHOW() - Method in class org.apache.cassandra.cli.CliLexer
-
- mSingleEscapeCharacter() - Method in class org.apache.cassandra.cli.CliLexer
-
- mSingleStringCharacter() - Method in class org.apache.cassandra.cli.CliLexer
-
- msProxy - Variable in class org.apache.cassandra.tools.NodeProbe
-
- mSTRING_LITERAL() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mSTRING_LITERAL() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mStringLiteral() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__100() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__101() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__102() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__103() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__104() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__105() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__106() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__107() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__111() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__112() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__113() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__114() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__115() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__116() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__117() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__118() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__119() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__120() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__121() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__122() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__123() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__124() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__125() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__126() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__127() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__128() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__129() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__130() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__131() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__132() - Method in class org.apache.cassandra.cli.CliLexer
-
- mT__141() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__142() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__143() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__144() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__145() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__146() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__147() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__148() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__149() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__150() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__151() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__152() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__153() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__154() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__155() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__156() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__157() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__158() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__159() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mT__81() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__82() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__83() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__84() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__85() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__86() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__87() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__88() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__89() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__90() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__91() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__92() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__93() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__94() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__95() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__96() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__97() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__98() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mT__99() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mTokens() - Method in class org.apache.cassandra.cli.CliLexer
-
- mTokens() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mTokens() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mTRACE() - Method in class org.apache.cassandra.cli.CliLexer
-
- mTRUNCATE() - Method in class org.apache.cassandra.cli.CliLexer
-
- mTTL() - Method in class org.apache.cassandra.cli.CliLexer
-
- mU() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mU() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- MultiColumnRelation - Class in org.apache.cassandra.cql3
-
A relation using the tuple notation, which typically affects multiple columns.
- MultiColumnRestriction - Interface in org.apache.cassandra.cql3.statements
-
- MultiColumnRestriction.EQ - Class in org.apache.cassandra.cql3.statements
-
- MultiColumnRestriction.IN - Interface in org.apache.cassandra.cql3.statements
-
- MultiColumnRestriction.InWithMarker - Class in org.apache.cassandra.cql3.statements
-
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.statements
-
An IN restriction that has a set of terms for in values.
- MultiColumnRestriction.Slice - Class in org.apache.cassandra.cql3.statements
-
- 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.cql.CqlLexer
-
- MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql.CqlParser
-
- MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- mUnicodeEscapeSequence() - Method in class org.apache.cassandra.cli.CliLexer
-
- mUPDATE() - Method in class org.apache.cassandra.cli.CliLexer
-
- Murmur3BloomFilter - Class in org.apache.cassandra.utils
-
- Murmur3BloomFilter(int, IBitSet) - Constructor for class org.apache.cassandra.utils.Murmur3BloomFilter
-
- Murmur3BloomFilter(Murmur3BloomFilter) - Constructor for class org.apache.cassandra.utils.Murmur3BloomFilter
-
- Murmur3BloomFilter.Murmur3BloomFilterSerializer - Class in org.apache.cassandra.utils
-
- Murmur3BloomFilterSerializer() - Constructor for class org.apache.cassandra.utils.Murmur3BloomFilter.Murmur3BloomFilterSerializer
-
- Murmur3Partitioner - Class in org.apache.cassandra.dht
-
This class generates a BigIntegerToken using a Murmur3 hash.
- Murmur3Partitioner() - Constructor for class org.apache.cassandra.dht.Murmur3Partitioner
-
- MurmurHash - Class in org.apache.cassandra.utils
-
This is a very fast, non-cryptographic hash suitable for general hash-based
lookup.
- MurmurHash() - Constructor for class org.apache.cassandra.utils.MurmurHash
-
- mUSE() - Method in class org.apache.cassandra.cli.CliLexer
-
- mutate(Collection<? extends IMutation>, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
-
Use this method to have these Mutations applied
across all replicas.
- mutateAtomically(Collection<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
-
- 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
-
- mutationForKey(ByteBuffer, String, Long, ThriftClientState, List<ByteBuffer>, CFMetaData) - Method in class org.apache.cassandra.cql.DeleteStatement
-
- 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.cql.CqlLexer
-
- mUUID() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mV() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mV() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mW() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mW() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mWITH() - Method in class org.apache.cassandra.cli.CliLexer
-
- mWS() - Method in class org.apache.cassandra.cli.CliLexer
-
- mWS() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mWS() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mX() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mX() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- Mx4jTool - Class in org.apache.cassandra.utils
-
If mx4j-tools is in the classpath call maybeLoad to load the HTTP interface of mx4j.
- Mx4jTool() - Constructor for class org.apache.cassandra.utils.Mx4jTool
-
- mY() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mY() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- mZ() - Method in class org.apache.cassandra.cql.CqlLexer
-
- mZ() - Method in class org.apache.cassandra.cql3.CqlLexer
-
- R - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- R - Static variable in class org.apache.cassandra.cql.CqlParser
-
- R - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- R - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- r1 - Variable in class org.apache.cassandra.repair.Differencer
-
- r2 - Variable in class org.apache.cassandra.repair.Differencer
-
- rack(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- Rack() - Constructor for class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.Rack
-
- rack_name - Variable in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.Rack
-
- 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
-
- racks - Variable in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.Datacenter
-
- RandomAccessReader - Class in org.apache.cassandra.io.util
-
- RandomAccessReader(File, int, PoolingSegmentedFile) - Constructor for class org.apache.cassandra.io.util.RandomAccessReader
-
- RandomAccessReader(File, int, long, 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
-
- 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(T, T, IPartitioner) - 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.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_CF - 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() - 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.
- RANGEOP - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- RANGEOP - Static variable in class org.apache.cassandra.cql.CqlParser
-
- ranges - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
-
- ranges - Variable in class org.apache.cassandra.repair.messages.SyncRequest
-
- ranges - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
- ranges - Variable in class org.apache.cassandra.streaming.StreamRequest
-
- rangeSet(Range<T>...) - Static method in class org.apache.cassandra.dht.Range
-
- rangeSet(Range<T>) - Static method in class org.apache.cassandra.dht.Range
-
- RangeSliceCommand - Class in org.apache.cassandra.db
-
- RangeSliceCommand(String, String, 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) - Constructor for class org.apache.cassandra.dht.RangeStreamer
-
- RangeStreamer(TokenMetadata, InetAddress, String) - 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
-
- RangeXfersCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- 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(String, 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.statements.Selectable.WithFieldSelection.Raw
-
- Raw(String, List<Selectable.Raw>) - Constructor for class org.apache.cassandra.cql3.statements.Selectable.WithFunction.Raw
-
- Raw(ColumnIdentifier.Raw, boolean) - Constructor for class org.apache.cassandra.cql3.statements.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.
- rawAppend(ColumnFamily, long, DecoratedKey, DataOutputPlus) - Static method in class org.apache.cassandra.io.sstable.SSTableWriter
-
- rawColumnName - Variable in class org.apache.cassandra.cql3.statements.AlterTableStatement
-
- RawSelector - Class in org.apache.cassandra.cql3.statements
-
- RawSelector(Selectable.Raw, ColumnIdentifier) - Constructor for class org.apache.cassandra.cql3.statements.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.FastByteArrayInputStream
-
Reads a single byte from the source byte array and returns it as an
integer in the range from 0 to 255.
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Reads at most len
bytes from this stream and stores
them in byte array b
starting at offset
.
- read() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- read(byte[]) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- read() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- read() - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- read() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- read(byte[]) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- read(byte[], int, int) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- read(DataInput, int, 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.utils.BytesReadTracker
-
- readByte() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads an 8-bit byte from the current position in this file.
- readByte() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readBytes(int) - Method in interface org.apache.cassandra.io.util.FileDataInput
-
Read length bytes from current file position
- readBytes(int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
Does the same thing as readFully
do but without copying data (thread safe)
- readBytes(int) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- readBytes(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
-
- 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.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
-
- readConfig() - Method in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch
-
- 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.utils.BytesReadTracker
-
- readEnumValue(Class<T>, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- 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.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.MappedFileDataInput
-
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- readFully(byte[], int, int) - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readFully(byte[]) - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readInet(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.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.utils.BytesReadTracker
-
- readLong() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a 64-bit long from the current position in this file.
- readLong() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readLong() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- readLongString(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
- readNameAndValueList(ByteBuf) - 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.
- readNextChar() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
- 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
-
- readSchemaRow(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Fetches a subset of schema (table data, columns metadata or triggers) for the keyspace.
- readSchemaRow(String, String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Fetches a subset of schema (table data, columns metadata or triggers) for the keyspace+table pair.
- readShort() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a 16-bit short from the current position in this file.
- readShort() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readShort() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- readShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
- 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
-
- readTimeouts - Static variable in class org.apache.cassandra.metrics.ClientRequestMetrics
-
Deprecated.
- readTOC(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
Reads the list of components from the TOC component.
- readUnavailables - Static variable in class org.apache.cassandra.metrics.ClientRequestMetrics
-
Deprecated.
- readUnsignedByte() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads an unsigned 8-bit byte from the current position in this file and
returns it as an integer.
- readUnsignedByte() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readUnsignedShort() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads an unsigned 16-bit short from the current position in this file and
returns it as an integer.
- readUnsignedShort() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readUnsignedShort() - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- readUTF() - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
Reads a string that is encoded in modified UTF-8
from
this file.
- readUTF() - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- readUUID(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) - 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
-
- 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.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() - Constructor for class org.apache.cassandra.tools.NodeTool.Rebuild
-
- rebuildIndex(String, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- RebuildIndex() - Constructor for class org.apache.cassandra.tools.NodeTool.RebuildIndex
-
- 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.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
-
- 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
- recentLatencyHistogram - Variable in class org.apache.cassandra.metrics.LatencyMetrics
-
Deprecated.
- recentSSTablesPerRead - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Deprecated.
- 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) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
-
- 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(List<SSTableReader>, List<SSTableReader>, long) - 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(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.utils.MergeIterator
-
- Reducer() - Constructor for class org.apache.cassandra.utils.MergeIterator.Reducer
-
- reduceScopeForLimitedSpace() - 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.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() - 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() - 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(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(TimerContext) - 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.
- 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>>) - 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
-
- rejectedExecutionHandler - Static variable in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
-
- relation() - Method in class org.apache.cassandra.cql.CqlParser
-
- Relation - Class in org.apache.cassandra.cql
-
Relations encapsulate the relationship between an entity of some kind, and
a value (term).
- Relation(Term, String, Term) - Constructor for class org.apache.cassandra.cql.Relation
-
Creates a new relation.
- relation(List<Relation>) - Method in class org.apache.cassandra.cql3.CqlParser
-
- Relation - Class in org.apache.cassandra.cql3
-
- Relation() - Constructor for class org.apache.cassandra.cql3.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.AbstractCassandraStorage
-
- 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
-
- 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.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
- reloadAttributes() - Method in class org.apache.cassandra.config.KSMetaData
-
- 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.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() - Constructor for class org.apache.cassandra.tools.NodeTool.ReloadTriggers
-
- relToAbsPathForStoreLocation(String, Path) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- 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.CompoundCType.CompoundCBuilder
-
- remainingCount() - Method in class org.apache.cassandra.db.composites.SimpleCType.SimpleCBuilder
-
- remainingCount() - Method in class org.apache.cassandra.db.marshal.CompositeType.Builder
-
- 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() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
- 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.ReducingKeyIterator
-
- remove() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
- remove() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.EmptySSTableScanner
-
- remove() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
-
- remove(IMessageSink) - Static method in class org.apache.cassandra.sink.SinkManager
-
- remove(IRequestSink) - Static method in class org.apache.cassandra.sink.SinkManager
-
- 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
-
- removeFromActiveSessions(RepairSession) - Method in class org.apache.cassandra.service.ActiveRepairService
-
- removeFromMoving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Remove pair of token/address from moving endpoints
- removeIndex(ByteBuffer) - Method in class org.apache.cassandra.db.index.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() - 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
-
- removePostPreparationHook(PostPreparationHook) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- removePreExecutionHook(PreExecutionHook) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- 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
-
- RemoveToken() - Constructor for class org.apache.cassandra.tools.NodeTool.RemoveToken
-
Deprecated.
- 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 DataTracker 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 DataTracker's view.
- removeValue(V) - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- REMOVING_TOKEN - Static variable in class org.apache.cassandra.gms.VersionedValue
-
- removingNonlocal(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- rename(Descriptor, Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.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
-
- Repair() - Constructor for class org.apache.cassandra.tools.NodeTool.Repair
-
- repairedAt - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- repairedAt - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
-
used as fail time if failed is true
- 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
-
- RepairFuture - Class in org.apache.cassandra.repair
-
- RepairFuture(RepairSession) - Constructor for class org.apache.cassandra.repair.RepairFuture
-
- RepairJob - Class in org.apache.cassandra.repair
-
RepairJob runs repair on given ColumnFamily.
- RepairJob(IRepairJobEventListener, UUID, UUID, String, String, Range<Token>, RepairParallelism, 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
-
- 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
-
- 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.
- repairResults - Variable in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- repairResults - Variable in class org.apache.cassandra.service.RowDataResolver
-
- RepairSession - Class in org.apache.cassandra.repair
-
Coordinates the (active) repair of a token range.
- RepairSession(UUID, Range<Token>, String, RepairParallelism, Set<InetAddress>, String...) - Constructor for class org.apache.cassandra.repair.RepairSession
-
Create new repair session.
- RepairSession(UUID, UUID, Range<Token>, String, RepairParallelism, Set<InetAddress>, String[]) - Constructor for class org.apache.cassandra.repair.RepairSession
-
- 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
-
- replacedEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
-
Remove the Endpoint and evict immediately, to avoid gossiping about this node.
- replaceEarlyOpenedFiles(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
-
Adds the early opened files to the data tracker, but does not tell compaction strategies about it
note that we dont track the live size of these sstables
- 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.DataTracker
-
- 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
-
- replaceWithNewInstances(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
-
Replaces existing sstables with new instances, makes sure compaction strategies have the correct instance
- ReplayPosition - Class in org.apache.cassandra.db.commitlog
-
- ReplayPosition(long, int) - Constructor for class org.apache.cassandra.db.commitlog.ReplayPosition
-
- replayPosition - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- replayPosition(ReplayPosition) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
-
- replayPosition - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
- ReplayPosition.ReplayPositionSerializer - Class in org.apache.cassandra.db.commitlog
-
- ReplayPositionSerializer() - Constructor for class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
-
- replica_placement_strategy() - Method in class org.apache.cassandra.cli.CliParser
-
- replica_placement_strategy_return() - Constructor for class org.apache.cassandra.cli.CliParser.replica_placement_strategy_return
-
- replicasMissingMostRecentCommit(CFMetaData, long) - Method in class org.apache.cassandra.service.paxos.PrepareCallback
-
- replicatedSystemKeyspaceNames - Static variable in class org.apache.cassandra.config.Schema
-
- 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.
- reportError(RecognitionException) - Method in class org.apache.cassandra.cli.CliLexer
-
- reportError(RecognitionException) - Method in class org.apache.cassandra.cli.CliParser
-
- 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 - Variable in class org.apache.cassandra.repair.StreamingRepairTask
-
- 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
- requestInvoke(AbstractNonblockingServer.FrameBuffer) - Method in class org.apache.cassandra.thrift.CustomTNonBlockingServer
-
- requestNames() - Method in class org.apache.cassandra.cql3.ResultSet.Metadata
-
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
- 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
-
- require_client_auth - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- requireAuthentication() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- requireAuthentication() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Whether or not the authenticator requires explicit login.
- requireAuthentication() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- requireAuthentication() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- required - Variable in exception org.apache.cassandra.exceptions.UnavailableException
-
- 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_KEYSPACE - Static variable in enum org.apache.cassandra.cql.StatementType
-
Statement types that require a keyspace to be set
- 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
IndexExpression
s 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.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 class org.apache.cassandra.db.context.CounterContext.ContextState
-
- reset() - Method in class org.apache.cassandra.io.util.FastByteArrayInputStream
-
Resets this stream to the last marked location.
- reset() - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Resets this stream to the beginning of the underlying byte array.
- reset(FileMark) - Method in interface org.apache.cassandra.io.util.FileDataInput
-
- reset() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
-
- reset(FileMark) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- reset() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- reset(FileMark) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- reset(InetAddress) - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
reconnect to @param remoteEP (after the current message backlog is exhausted).
- reset(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() - 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.SSTableWriter
-
- resetAndTruncate(FileMark) - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- resetBuffer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- resetBuffer() - Method in class org.apache.cassandra.io.util.SequentialWriter
-
- resetCollection(String) - Method in class org.apache.cassandra.db.CFRowAdder
-
- resetEndpointStateMap() - Method in class org.apache.cassandra.gms.Gossiper
-
- 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() - Constructor for class org.apache.cassandra.tools.NodeTool.ResetLocalSchema
-
- resetToNewerVersion(int) - Method in class org.apache.cassandra.net.OutboundTcpConnectionPool
-
- resetUnsafe() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
FOR TESTING PURPOSES.
- resetUnsafe() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManager
-
Resets all the segments, for testing purposes.
- resetVersion(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- resolve() - Method in interface org.apache.cassandra.service.IResponseResolver
-
This Method resolves the responses that are passed in .
- resolve() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- resolve() - Method in class org.apache.cassandra.service.RowDataResolver
-
- resolve() - Method in class org.apache.cassandra.service.RowDigestResolver
-
- resolver - Variable in class org.apache.cassandra.service.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.PermissionAlteringStatement
-
- Resources - Class in org.apache.cassandra.auth
-
- Resources() - Constructor for class org.apache.cassandra.auth.Resources
-
- resourceToFile(String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- ResourceWatcher - Class in org.apache.cassandra.utils
-
- ResourceWatcher() - Constructor for class org.apache.cassandra.utils.ResourceWatcher
-
- ResourceWatcher.WatchedResource - Class in org.apache.cassandra.utils
-
- 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) - 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) - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
-
- response(MessageIn) - 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) - Method in class org.apache.cassandra.service.WriteResponseHandler
-
- Response(Message.Type) - Constructor for class org.apache.cassandra.transport.Message.Response
-
- responseCompletedTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Completed tasks for Response(GOSSIP & RESPONSE) TCP Connections
- responseHandler - Variable in class org.apache.cassandra.transport.SimpleClient
-
- responsePendingTasks - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Pending tasks for Response(GOSSIP & RESPONSE) TCP Connections
- responses - Variable in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- responses - Variable in class org.apache.cassandra.service.TruncateResponseHandler
-
- responses - Variable in class org.apache.cassandra.service.WriteResponseHandler
-
- ResponseVerbHandler - Class in org.apache.cassandra.net
-
- ResponseVerbHandler() - Constructor for class org.apache.cassandra.net.ResponseVerbHandler
-
- 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.statements
-
A restriction/clause on a column.
- Restriction.EQ - Interface in org.apache.cassandra.cql3.statements
-
- Restriction.IN - Interface in org.apache.cassandra.cql3.statements
-
- Restriction.Slice - Interface in org.apache.cassandra.cql3.statements
-
- result - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Rows
-
- resultify(Row) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- 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 - 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.Metadata, 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.Metadata - Class in org.apache.cassandra.cql3
-
- resultSetBuilder(long) - Method in class org.apache.cassandra.cql3.statements.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
- 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
-
- retry(UUID, int) - Method in class org.apache.cassandra.streaming.StreamSession
-
Call back on receiving StreamMessage.Type.RETRY
message.
- RetryMessage - Class in org.apache.cassandra.streaming.messages
-
- RetryMessage(UUID, int) - Constructor for class org.apache.cassandra.streaming.messages.RetryMessage
-
- returnType - Variable in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- returnType() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
- returnType() - Method in interface org.apache.cassandra.cql3.functions.Function
-
- reverse() - Method in class org.apache.cassandra.cql3.ResultSet
-
- reverse(Bound) - Static method in enum org.apache.cassandra.cql3.statements.Bound
-
- 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
-
- reversedExpr() - Method in class org.apache.cassandra.cli.CliParser
-
- reversedExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.reversedExpr_return
-
- 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, String) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- revoke(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- revoke(AuthenticatedUser, Set<Permission>, IResource, String) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Revokes a set of permissions on a resource from a user.
- revoke(AuthenticatedUser, Set<Permission>, IResource, String) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- revokeAll(String) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- revokeAll(IResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- revokeAll(String) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- revokeAll(IResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- revokeAll(String) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
This method is called before deleting a user with DROP USER query so that a new user with the same
name wouldn't inherit permissions of the deleted user in the future.
- revokeAll(IResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
This method is called after a resource is removed (i.e.
- revokeAll(String) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- revokeAll(IResource) - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- revokeStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- RevokeStatement - Class in org.apache.cassandra.cql3.statements
-
- RevokeStatement(Set<Permission>, IResource, String) - Constructor for class org.apache.cassandra.cql3.statements.RevokeStatement
-
- right - Variable in class org.apache.cassandra.dht.AbstractBounds
-
- right - Variable in class org.apache.cassandra.utils.Pair
-
- rightBoundary() - Method in class org.apache.cassandra.dht.AbstractBounds
-
- 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
-
- ringCache - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter
-
- ringIterator(ArrayList<Token>, Token, boolean) - Static method in class org.apache.cassandra.locator.TokenMetadata
-
iterator over the Tokens in the given ring, starting with the token for the node owning start
(which does not have to be a Token in the ring)
- RingPosition<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
-
- root() - Static method in class org.apache.cassandra.auth.DataResource
-
- ROOT - Static variable in class org.apache.cassandra.auth.Resources
-
Deprecated.
- root() - Method in class org.apache.cassandra.cli.CliParser
-
- root_return() - Constructor for class org.apache.cassandra.cli.CliParser.root_return
-
- 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_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>, 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
-
- RowDataResolver - Class in org.apache.cassandra.service
-
- RowDataResolver(String, ByteBuffer, IDiskAtomFilter, long) - Constructor for class org.apache.cassandra.service.RowDataResolver
-
- RowDigestResolver - Class in org.apache.cassandra.service
-
- RowDigestResolver(String, ByteBuffer) - Constructor for class org.apache.cassandra.service.RowDigestResolver
-
- rowFilter - Variable in class org.apache.cassandra.db.AbstractRangeCommand
-
- RowHash(Token, byte[], long) - Constructor for class org.apache.cassandra.utils.MerkleTree.RowHash
-
- RowIndexEntry - Class in org.apache.cassandra.db
-
- RowIndexEntry(long) - Constructor for class org.apache.cassandra.db.RowIndexEntry
-
- RowIndexEntry.Serializer - Class in org.apache.cassandra.db
-
- rowIndexEntrySerializer() - Method in class org.apache.cassandra.db.composites.AbstractCType
-
- rowIndexEntrySerializer() - Method in interface org.apache.cassandra.db.composites.CType
-
- RowIteratorFactory - Class in org.apache.cassandra.db
-
- RowIteratorFactory() - Constructor for class org.apache.cassandra.db.RowIteratorFactory
-
- rowKey() - Method in class org.apache.cassandra.cli.CliParser
-
- rowKey_return() - Constructor for class org.apache.cassandra.cli.CliParser.rowKey_return
-
- rowLimitExpr() - Method in class org.apache.cassandra.cli.CliParser
-
- rowLimitExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.rowLimitExpr_return
-
- 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
-
- rows - Variable in class org.apache.cassandra.cql3.ResultSet
-
- rows - Variable in class org.apache.cassandra.db.compaction.CompactionIterable.Reducer
-
- rows - Variable in class org.apache.cassandra.db.RangeSliceReply
-
- 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
-
- rowValue() - Method in class org.apache.cassandra.cli.CliParser
-
- rowValue_return() - Constructor for class org.apache.cassandra.cli.CliParser.rowValue_return
-
- 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.AbstractCassandraStorage
-
- run() - Method in class org.apache.cassandra.db.ColumnFamilyStore.FlushLargestColumnFamily
-
- run() - Method in class org.apache.cassandra.db.SizeEstimatesRecorder
-
- run - Variable in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
- run() - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
Loops collecting mutations from the queue and sending to Cassandra
- run() - Method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
-
- run() - Method in class org.apache.cassandra.net.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.Differencer
-
Compares our trees, and triggers repairs for any ranges that mismatch.
- 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.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.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.RepairSession
-
- runMayThrow() - Method in class org.apache.cassandra.utils.WrappedRunnable
-
- runPostFlush - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- runWithCompactionsDisabled(Callable<V>, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- S - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- S - Static variable in class org.apache.cassandra.cql.CqlParser
-
- S - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- S - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- 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.SSTableReader
-
Save index summary to Summary.db file.
- saveTask - Variable in class org.apache.cassandra.cache.AutoSavingCache
-
- saveTruncationRecord(ColumnFamilyStore, long, ReplayPosition) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- 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
-
- schedule() - Method in class org.apache.cassandra.io.sstable.SSTableDeletingTask
-
- 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 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- SCHEMA - Static variable in class org.apache.cassandra.cli.CliParser
-
- Schema - Class in org.apache.cassandra.config
-
- Schema() - Constructor for class org.apache.cassandra.config.Schema
-
Initialize empty schema object
- schema(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- SCHEMA_COLUMNFAMILIES_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SCHEMA_COLUMNS_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SCHEMA_KEYSPACES_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SCHEMA_TRIGGERS_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SCHEMA_USER_TYPES_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SchemaAlteringStatement - Class in org.apache.cassandra.cql3.statements
-
Abstract class for statements that alter the schema.
- SchemaAlteringStatement() - Constructor for class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
- SchemaAlteringStatement(CFName) - Constructor for class org.apache.cassandra.cql3.statements.SchemaAlteringStatement
-
- schemaCFS(String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- 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
-
- SchemaColumnFamiliesCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- SchemaColumnsCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- SchemaKeyspacesCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- SchemaTriggersCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- SchemaUserTypesCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- scName(Composite) - Static method in class org.apache.cassandra.db.SuperColumns
-
- scNameType(CellNameType) - Static method in class org.apache.cassandra.db.SuperColumns
-
- scrub(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, 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
-
- scrub(boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- scrub(PrintStream, boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
- Scrub() - Constructor for class org.apache.cassandra.tools.NodeTool.Scrub
-
- Scrubber - Class in org.apache.cassandra.db.compaction
-
- Scrubber(ColumnFamilyStore, SSTableReader, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
-
- Scrubber(ColumnFamilyStore, SSTableReader, boolean, OutputHandler, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
-
- 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
-
- 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
-
- SeedProviderDef - Class in org.apache.cassandra.config
-
- SeedProviderDef(LinkedHashMap<String, ?>) - Constructor for class org.apache.cassandra.config.SeedProviderDef
-
- 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.MappedFileDataInput
-
- seek(long) - Method in class org.apache.cassandra.io.util.RandomAccessReader
-
- seekInternal(int) - Method in class org.apache.cassandra.io.util.AbstractDataInput
-
- seekInternal(int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- seekInternal(int) - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- seekInternal(int) - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- 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, String, 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<DataTracker.View, List<SSTableReader>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- selectable - Variable in class org.apache.cassandra.cql3.statements.RawSelector
-
- Selectable - Interface in org.apache.cassandra.cql3.statements
-
- Selectable.Raw - Interface in org.apache.cassandra.cql3.statements
-
- Selectable.WithFieldSelection - Class in org.apache.cassandra.cql3.statements
-
- Selectable.WithFieldSelection.Raw - Class in org.apache.cassandra.cql3.statements
-
- Selectable.WithFunction - Class in org.apache.cassandra.cql3.statements
-
- Selectable.WithFunction.Raw - Class in org.apache.cassandra.cql3.statements
-
- Selectable.WritetimeOrTTL - Class in org.apache.cassandra.cql3.statements
-
- Selectable.WritetimeOrTTL.Raw - Class in org.apache.cassandra.cql3.statements
-
- selectAndReference(Function<DataTracker.View, List<SSTableReader>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- selectClause() - Method in class org.apache.cassandra.cql3.CqlParser
-
- selectCountClause() - Method in class org.apache.cassandra.cql3.CqlParser
-
- selected - Variable in class org.apache.cassandra.cql3.statements.Selectable.WithFieldSelection
-
- selectExpression() - Method in class org.apache.cassandra.cql.CqlParser
-
- SelectExpression - Class in org.apache.cassandra.cql
-
Select expressions are analogous to the projection in a SQL query.
- SelectExpression(Term, Term, int, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.cql.SelectExpression
-
Create a new SelectExpression for a range (slice) of columns.
- SelectExpression(Term, int, boolean, boolean) - Constructor for class org.apache.cassandra.cql.SelectExpression
-
Create a new SelectExpression for a list of columns.
- selectFullRow - Variable in class org.apache.cassandra.db.DataRange
-
- Selection - Class in org.apache.cassandra.cql3.statements
-
- Selection(List<ColumnDefinition>, SelectionColumnMapping, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.Selection
-
- Selection(List<ColumnDefinition>, SelectionColumnMapping, List<ColumnSpecification>, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.Selection
-
- Selection.ResultSetBuilder - Class in org.apache.cassandra.cql3.statements
-
- SelectionColumnMapping - Class in org.apache.cassandra.cql3.statements
-
- SelectionColumns - Interface in org.apache.cassandra.cql3.statements
-
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
-
- 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.cql.CqlParser
-
- SelectStatement - Class in org.apache.cassandra.cql
-
Encapsulates a completely parsed SELECT query, including the target
column family, expression, result count, and ordering clause.
- SelectStatement(SelectExpression, boolean, String, String, ConsistencyLevel, WhereClause, int) - Constructor for class org.apache.cassandra.cql.SelectStatement
-
- selectStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- SelectStatement - Class in org.apache.cassandra.cql3.statements
-
Encapsulates a completely parsed SELECT query, including the target
column family, expression, result count, and ordering clause.
- SelectStatement(CFMetaData, int, SelectStatement.Parameters, Selection, 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.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
-
- SemanticVersion - Class in org.apache.cassandra.utils
-
Implements semantic versioning as defined at http://semver.org/.
- SemanticVersion(String) - Constructor for class org.apache.cassandra.utils.SemanticVersion
-
Parse a semantic version from a string.
- SEMICOLON - Static variable in class org.apache.cassandra.cli.CliLexer
-
- SEMICOLON - Static variable in class org.apache.cassandra.cli.CliParser
-
- send(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.
- sendNotification(String, String, Object) - Method in class org.apache.cassandra.service.StorageService
-
Sends JMX notification to subscribers.
- sendOneWay(MessageOut, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
-
- sendOneWay(MessageOut, 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, 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.
- sendTreeRequests(Collection<InetAddress>) - Method in class org.apache.cassandra.repair.RepairJob
-
Send merkle tree request to every involved neighbor.
- 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
-
- SequentialRequestCoordinator<R> - Class in org.apache.cassandra.repair
-
- SequentialRequestCoordinator(IRequestProcessor<R>) - Constructor for class org.apache.cassandra.repair.SequentialRequestCoordinator
-
- SequentialWriter - Class in org.apache.cassandra.io.util
-
Adds buffering, mark, and fsyncing to OutputStream.
- SequentialWriter(File, int) - 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
- 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() - Method in enum org.apache.cassandra.config.ColumnDefinition.Kind
-
- 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, DataOutputPlus) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- serialize(RowPosition, DataOutputPlus) - 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<?>, 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(Token, DataOutputPlus) - 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, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
-
- serialize(T, DataOutputPlus) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataComponentSerializer
-
Serialize metadata component to given output.
- serialize(Map<MetadataType, MetadataComponent>, DataOutputPlus) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
-
Serialize given metadata components
- serialize(Map<MetadataType, MetadataComponent>, 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>, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
-
- serialize(StatsMetadata, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata.StatsMetadataSerializer
-
- serialize(ValidationMetadata, 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(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(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(DataOutputStreamAndChannel, int, StreamSession) - Method in class org.apache.cassandra.streaming.messages.OutgoingFileMessage
-
- serialize(StreamMessage, DataOutputStreamAndChannel, int, StreamSession) - Static method in class org.apache.cassandra.streaming.messages.StreamMessage
-
- serialize(V, DataOutputStreamAndChannel, 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(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
-
- serializedSchema() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- serializedSchema(String) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- 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) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
-
- serializedSize(RowPosition, TypeSizes) - 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<?>, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
-
- serializedSize(String, int) - Method in class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- serializedSize(Token, TypeSizes) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
-
- serializedSize(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) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
-
- serializedSize(T) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataComponentSerializer
-
Calculate and return serialized size.
- serializedSize(StatsMetadata) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata.StatsMetadataSerializer
-
- serializedSize(ValidationMetadata) - 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(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() - Method in class org.apache.cassandra.utils.Murmur3BloomFilter
-
- 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(CType) - 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.AbstractBounds
-
- 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
-
- 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.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.Murmur3BloomFilter
-
- serializer - Static variable in class org.apache.cassandra.utils.StreamingHistogram
-
- serializer - Static variable in class org.apache.cassandra.utils.UUIDSerializer
-
- serializeSchema() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- 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.repair.RepairFuture
-
- 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
-
- 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.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_CF - Static variable in class org.apache.cassandra.tracing.Tracing
-
- sessionState - Static variable in class org.apache.cassandra.cli.CliMain
-
- SET - Static variable in class org.apache.cassandra.cli.CliLexer
-
- SET - Static variable in class org.apache.cassandra.cli.CliParser
-
- set(CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
-
- 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
-
- setBootstrapState(SystemKeyspace.BootstrapState) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
- setBound(Operator, Term) - Method in interface org.apache.cassandra.cql3.statements.Restriction.Slice
-
- setBound(Restriction.Slice) - Method in interface org.apache.cassandra.cql3.statements.Restriction.Slice
-
- setBound(Operator, Term) - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Slice
-
- setBound(Restriction.Slice) - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Slice
-
- 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
-
- 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() - Constructor for class org.apache.cassandra.tools.NodeTool.SetCacheCapacity
-
- setCacheKeysToSave(int, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
-
- 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
-
- setColumnFamilyInsertStatement(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- setColumnFamilySchema(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- setColumnsLimit(int) - Method in class org.apache.cassandra.cql.SelectExpression
-
- setColumnsReversed(boolean) - Method in class org.apache.cassandra.cql.SelectExpression
-
- setCommitFailurePolicy(Config.CommitFailurePolicy) - 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() - 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() - 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.AbstractCassandraStorage
-
set hadoop cassandra connection settings
- setConnectionInformation() - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
set hadoop cassandra connection settings
- setConsistencyLevel(ConsistencyLevel) - Method in class org.apache.cassandra.cql.Attributes
-
- setCoreCompactorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setCoreCompactorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the compaction thread pool.
- setCorePoolSize(int) - Method in interface org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutorMBean
-
- setCoreThreads(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledSharedExecutorPool.JMXEnabledSEPExecutor
-
- setCoreThreads(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- setCoreThreads(int) - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Deprecated.
Allows user to resize core pool size of the thread pool.
- setCoreValidationThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setCoreValidationThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the compaction thread pool.
- 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
-
- setCQLVersion(String) - Method in class org.apache.cassandra.service.ClientState
-
- setCrcCheckChance(double) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- setCrcCheckChance(double) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Set new crc check chance
- setCrcCheckChance(double) - Method in class org.apache.cassandra.io.compress.CompressionParameters
-
- setCurrentSocket(SocketAddress) - Method in class org.apache.cassandra.thrift.ThriftSessionManager
-
- 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
-
- 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() - 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
- 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
-
- setErr(PrintStream) - Method in class org.apache.cassandra.cli.CliSessionState
-
- 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.Metadata
-
- 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() - Constructor for class org.apache.cassandra.tools.NodeTool.SetHintedHandoffThrottleInKB
-
- 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.AbstractBulkOutputFormat
-
Set the hosts to ignore as comma delimited values.
- setIgnoreHosts(Configuration, String...) - Static method in class org.apache.cassandra.hadoop.AbstractBulkOutputFormat
-
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
-
- 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
-
- setInputMinSimultReqPerConnections(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.
- 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() - 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
-
- setInternodeEncryption(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- setIsDigestQuery(boolean) - Method in class org.apache.cassandra.db.ReadCommand
-
- setKeyAlias(String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
- setKeyAlias(String) - Method in class org.apache.cassandra.cql.WhereClause
-
- setKeyCacheCapacityInMB(long) - Method in class org.apache.cassandra.service.CacheService
-
- setKeyCacheCapacityInMB(long) - Method in interface org.apache.cassandra.service.CacheServiceMBean
-
- 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.cli.CliClient
-
- setKeyspace(String) - Method in class org.apache.cassandra.cql.DropIndexStatement
-
- 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
- setKeyType(String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
-
- 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
-
set read configuration settings
- setLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
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() - 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
-
- 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.JMXEnabledSharedExecutorPool.JMXEnabledSEPExecutor
-
- setMaximumThreads(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
-
- setMaximumThreads(int) - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
-
Deprecated.
Allows user to resize maximum size of the thread pool.
- setMaximumValidatorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- setMaximumValidatorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
-
Allows user to resize maximum size of the validator thread pool.
- 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
- setMultiKey(boolean) - Method in class org.apache.cassandra.cql.WhereClause
-
- 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
-
- 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
-
- setOrMapLiteral(Term.Raw) - Method in class org.apache.cassandra.cql3.CqlParser
-
- setOut(PrintStream) - Method in class org.apache.cassandra.cli.CliSessionState
-
- setOutboundBindAny(boolean) - Static method in class org.apache.cassandra.config.Config
-
- setOutput(PrintStream) - Method in class org.apache.cassandra.tools.AbstractJmxClient
-
- setOutputColumnFamily(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the column family for the output of this job.
- setOutputColumnFamily(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the column family for the output of this job.
- setOutputCompressionChunkLength(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputCompressionClass(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputCql(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
-
Set the CQL prepared statement for the output of this job.
- setOutputInitialAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputKeyspace(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
Set the keyspace for the output of this job.
- setOutputKeyspacePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputKeyspaceUserName(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setOutputKeyspaceUserNameAndPassword(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- 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
-
set partition filter
- setPartitionFilter(Expression) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
- setPendingRanges(String, Multimap<Range<Token>, InetAddress>) - Method in class org.apache.cassandra.locator.TokenMetadata
-
- 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
-
- 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
-
- setReplacedBy(SSTableReader) - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- setResizeIntervalInMinutes(int) - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
-
- setResizeIntervalInMinutes(int) - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
-
- 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
-
- 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
-
- setServerCipherSuites(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- setServerKeystore(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- setServerKeystorePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- setServerTruststore(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- setServerTruststorePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- 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.Metadata
-
- setSourceFrame(Frame) - Method in class org.apache.cassandra.transport.Message
-
- setSources(List<InetAddress>) - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
-
- setSSLStoragePort(Configuration, int) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- setSSTablePreempiveOpenIntervalInMB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setStart(Composite) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
-
- setStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- setStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.setStatement_return
-
- 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
-
- setStoragePort(Configuration, int) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
-
- setStoreFuncUDFContextSignature(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
StoreFunc methods
- setStoreLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CassandraStorage
-
set store configuration settings
- setStoreLocation(String, Job) - Method in class org.apache.cassandra.hadoop.pig.CqlNativeStorage
-
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() - 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
-
- 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
- setTimestamp(Long) - Method in class org.apache.cassandra.cql.Attributes
-
- setTimeToLive(int) - Method in class org.apache.cassandra.cql.Attributes
-
- setTokens(Collection<Token>) - Method in class org.apache.cassandra.service.StorageService
-
This method updates the local token on disk
- 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() - Method in class org.apache.cassandra.cli.CliParser
-
- setTraceProbability(double) - Method in class org.apache.cassandra.service.StorageService
-
- setTraceProbability(double) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Enables/Disables tracing for the whole system.
- setTraceProbability(double) - Method in class org.apache.cassandra.tools.NodeProbe
-
- SetTraceProbability() - Constructor for class org.apache.cassandra.tools.NodeTool.SetTraceProbability
-
- setTraceProbability_return() - Constructor for class org.apache.cassandra.cli.CliParser.setTraceProbability_return
-
- setTracingId(UUID) - Method in class org.apache.cassandra.transport.Message.Response
-
- setTracingRequested() - Method in class org.apache.cassandra.transport.Message.Request
-
- setTreeAdaptor(TreeAdaptor) - Method in class org.apache.cassandra.cli.CliParser
-
- setTruncateRpcTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setTruncateRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setTruncateRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- setTupleValue(Tuple, int, Object) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
set the value to the position of the tuple
- SetType<T> - Class in org.apache.cassandra.db.marshal
-
- SetType(AbstractType<T>, boolean) - Constructor for class org.apache.cassandra.db.marshal.SetType
-
- setUDFContextSignature(String) - Method in class org.apache.cassandra.hadoop.pig.AbstractCassandraStorage
-
- setup() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
-
- setup() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
-
- setup() - Static method in class org.apache.cassandra.auth.Auth
-
Sets up Authenticator and Authorizer.
- setup() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
- setup() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Setup is called once upon system startup to initialize the IAuthenticator.
- setup() - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Setup is called once upon system startup to initialize the IAuthorizer.
- setup() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- setup() - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- setup() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- setup() - Method in class org.apache.cassandra.service.CassandraDaemon
-
This is a hook for concrete daemons to initialize themselves suitably.
- 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
-
- setupJob(JobContext) - Method in class org.apache.cassandra.hadoop.AbstractBulkOutputFormat.NullOutputCommitter
-
- setupKeyCache() - Method in class org.apache.cassandra.io.sstable.SSTableReader
-
- setupTable(String, String) - Static method in class org.apache.cassandra.auth.Auth
-
Set up table from given CREATE TABLE statement under system_auth keyspace, if not already done so.
- setupTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.AbstractBulkOutputFormat.NullOutputCommitter
-
- setUserDefined(boolean) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
- setUsername(String) - Method in class org.apache.cassandra.cli.CliClient
-
- 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
-
- SetValue(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.SetValue
-
- setVersion(InetAddress, int) - Method in class org.apache.cassandra.net.MessagingService
-
- setWriteConsistencyLevel(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
-
- setWriteRpcTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
- setWriteRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
-
- setWriteRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
- severity(double) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- shadowed - Variable in class org.apache.cassandra.db.DataTracker.View
-
- SHARED - Static variable in class org.apache.cassandra.concurrent.JMXEnabledSharedExecutorPool
-
- 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.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 interface org.apache.cassandra.utils.concurrent.SharedCloseable
-
- sharedCopy() - Method in interface org.apache.cassandra.utils.IFilter
-
- sharedCopy() - Method in class org.apache.cassandra.utils.Murmur3BloomFilter
-
- 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
-
- 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
-
- shouldLogAverage - Variable in class org.apache.cassandra.utils.CoalescingStrategies.CoalescingStrategy
-
- shouldPullSchemaFrom(InetAddress) - Static method in class org.apache.cassandra.service.MigrationManager
-
- SHOW - Static variable in class org.apache.cassandra.cli.CliLexer
-
- SHOW - Static variable in class org.apache.cassandra.cli.CliParser
-
- showClusterName() - Method in class org.apache.cassandra.cli.CliParser
-
- showClusterName_return() - Constructor for class org.apache.cassandra.cli.CliParser.showClusterName_return
-
- showKeyspaces() - Method in class org.apache.cassandra.cli.CliParser
-
- showKeyspaces_return() - Constructor for class org.apache.cassandra.cli.CliParser.showKeyspaces_return
-
- showSchema() - Method in class org.apache.cassandra.cli.CliParser
-
- showSchema_return() - Constructor for class org.apache.cassandra.cli.CliParser.showSchema_return
-
- showStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- showStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.showStatement_return
-
- showVersion() - Method in class org.apache.cassandra.cli.CliParser
-
- showVersion_return() - Constructor for class org.apache.cassandra.cli.CliParser.showVersion_return
-
- shutdown() - Method in class org.apache.cassandra.concurrent.JMXEnabledSharedExecutorPool.JMXEnabledSEPExecutor
-
- 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
-
- 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, EncryptionOptions.ClientEncryptionOptions) - Constructor for class org.apache.cassandra.transport.SimpleClient
-
- SimpleClient(String, int) - Constructor for class org.apache.cassandra.transport.SimpleClient
-
- 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
-
- 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
-
- 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.statements.SelectionColumnMapping
-
- SimpleSeedProvider - Class in org.apache.cassandra.locator
-
- SimpleSeedProvider(Map<String, String>) - Constructor for class org.apache.cassandra.locator.SimpleSeedProvider
-
- SimpleSnitch - Class in org.apache.cassandra.locator
-
A simple endpoint snitch implementation that treats Strategy order as proximity,
allowing non-read-repaired reads to prefer a single endpoint, which improves
cache locality.
- SimpleSnitch() - Constructor for class org.apache.cassandra.locator.SimpleSnitch
-
- 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
-
- 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, Operator, Term.Raw) - Constructor for class org.apache.cassandra.cql3.SingleColumnRelation
-
Creates a new relation.
- SingleColumnRelation(ColumnIdentifier.Raw, Operator, Term.Raw, boolean) - Constructor for class org.apache.cassandra.cql3.SingleColumnRelation
-
- SingleColumnRestriction - Class in org.apache.cassandra.cql3.statements
-
- SingleColumnRestriction() - Constructor for class org.apache.cassandra.cql3.statements.SingleColumnRestriction
-
- SingleColumnRestriction.Contains - Class in org.apache.cassandra.cql3.statements
-
- SingleColumnRestriction.EQ - Class in org.apache.cassandra.cql3.statements
-
- SingleColumnRestriction.InWithMarker - Class in org.apache.cassandra.cql3.statements
-
- SingleColumnRestriction.InWithValues - Class in org.apache.cassandra.cql3.statements
-
- SingleColumnRestriction.Slice - Class in org.apache.cassandra.cql3.statements
-
- SingleDatacenterFilter(IEndpointSnitch, String) - Constructor for class org.apache.cassandra.dht.RangeStreamer.SingleDatacenterFilter
-
- SingleEscapeCharacter - Static variable in class org.apache.cassandra.cli.CliLexer
-
- SingleEscapeCharacter - Static variable in class org.apache.cassandra.cli.CliParser
-
- SinglePartitionPager - Interface in org.apache.cassandra.service.pager
-
Common interface to single partition queries (by slice and by name).
- SingleStringCharacter - Static variable in class org.apache.cassandra.cli.CliLexer
-
- SingleStringCharacter - Static variable in class org.apache.cassandra.cli.CliParser
-
- singleton(T, Comparator<? super T>) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- SinkManager - Class in org.apache.cassandra.sink
-
- SinkManager() - Constructor for class org.apache.cassandra.sink.SinkManager
-
- size() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
-
- size() - Method in interface org.apache.cassandra.cache.ICache
-
- size() - Method in class org.apache.cassandra.cache.InstrumentingCache
-
- size() - Method in class org.apache.cassandra.cache.SerializingCache
-
- size() - Method in class org.apache.cassandra.cql3.ResultSet
-
- size() - Method in class org.apache.cassandra.cql3.UntypedResultSet
-
- size() - Method in class org.apache.cassandra.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.FastByteArrayOutputStream
-
Returns the total number of bytes written to this stream so far.
- 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 - 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.utils.BiMultiValMap
-
- size() - Method in class org.apache.cassandra.utils.btree.BTreeSet
-
- 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_CF - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
- SizeComparator() - Constructor for class org.apache.cassandra.io.sstable.SSTableReader.SizeComparator
-
- SizeEstimatesCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- 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
-
- 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
-
- 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
-
- skipBloomFilter(DataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
-
- skipBody(DataInput, Descriptor.Version) - Method in class org.apache.cassandra.db.RangeTombstone.Serializer
-
- skipBytes(int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- skipBytes(int) - Method in class org.apache.cassandra.io.util.MemoryInputStream
-
- skipBytes(int) - Method in class org.apache.cassandra.utils.BytesReadTracker
-
- skipBytes(int) - Method in class org.apache.cassandra.utils.vint.EncodedDataInputStream
-
- skipBytesFully(DataInput, int) - Static method in class org.apache.cassandra.io.util.FileUtils
-
- 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 (2MB by default) regions and then doles them out to threads that request
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(boolean) - Constructor for class org.apache.cassandra.cql3.statements.MultiColumnRestriction.Slice
-
- Slice(boolean) - Constructor for class org.apache.cassandra.cql3.statements.SingleColumnRestriction.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
-
- 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() - 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
-
- 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
-
- 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(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.AbstractCassandraStorage
-
- SplittingCompactionTask(ColumnFamilyStore, SSTableReader, int) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
-
- splitValues(QueryOptions) - Method in interface org.apache.cassandra.cql3.statements.MultiColumnRestriction.IN
-
- splitValues(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.MultiColumnRestriction.InWithMarker
-
- splitValues(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.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 - Class in org.apache.cassandra.io.sstable
-
This class is built on top of the SequenceFile.
- SSTable(Descriptor, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.SSTable
-
- SSTable(Descriptor, Set<Component>, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.SSTable
-
- sstable - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
-
- sstable - Variable in class org.apache.cassandra.notifications.SSTableRepairStatusChanged
-
- sstable - Variable in class org.apache.cassandra.streaming.messages.IncomingFileMessage
-
- sstable - Variable in class org.apache.cassandra.streaming.StreamWriter
-
- SSTABLE_ACTIVITY_CF - 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
-
- SSTableActivityCF - Static variable in class org.apache.cassandra.config.CFMetaData
-
- SSTableAddedNotification - Class in org.apache.cassandra.notifications
-
- SSTableAddedNotification(SSTableReader) - Constructor for class org.apache.cassandra.notifications.SSTableAddedNotification
-
- SSTableCompactingNotification - Class in org.apache.cassandra.notifications
-
- SSTableCompactingNotification(Iterable<SSTableReader>, boolean) - Constructor for class org.apache.cassandra.notifications.SSTableCompactingNotification
-
- sstableComparator - Static variable in class org.apache.cassandra.io.sstable.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
-
- SSTableIdentityIterator - Class in org.apache.cassandra.io.sstable
-
- SSTableIdentityIterator(SSTableReader, RandomAccessReader, DecoratedKey, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
-
Used to iterate through the columns of a row.
- SSTableIdentityIterator(SSTableReader, RandomAccessReader, DecoratedKey, long, 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
-
- 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
-
- 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
-
- SSTableMetadataViewer - Class in org.apache.cassandra.tools
-
Shows the contents of sstable metadata
- SSTableMetadataViewer() - Constructor for class org.apache.cassandra.tools.SSTableMetadataViewer
-
- SSTableNamesIterator - Class in org.apache.cassandra.db.columniterator
-
- SSTableNamesIterator(SSTableReader, DecoratedKey, SortedSet<CellName>) - Constructor for class org.apache.cassandra.db.columniterator.SSTableNamesIterator
-
- SSTableNamesIterator(SSTableReader, FileDataInput, DecoratedKey, SortedSet<CellName>, RowIndexEntry) - Constructor for class org.apache.cassandra.db.columniterator.SSTableNamesIterator
-
- 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.SSTableReader
-
- SSTableReader - Class in org.apache.cassandra.io.sstable
-
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.OpenReason - Enum in org.apache.cassandra.io.sstable
-
- SSTableReader.Operator - Class in org.apache.cassandra.io.sstable
-
TODO: Move someplace reusable
- SSTableReader.SizeComparator - Class in org.apache.cassandra.io.sstable
-
- 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, Set<SSTableReader>, long, boolean) - Constructor for class org.apache.cassandra.io.sstable.SSTableRewriter
-
- SSTableRewriter(ColumnFamilyStore, Set<SSTableReader>, long, boolean, boolean) - Constructor for class org.apache.cassandra.io.sstable.SSTableRewriter
-
- SSTableRewriter(ColumnFamilyStore, Set<SSTableReader>, 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.AbstractCompactionTask
-
- sstables - Variable in class org.apache.cassandra.db.compaction.LeveledManifest.CompactionCandidate
-
- sstables - Variable in class org.apache.cassandra.db.DataTracker.View
-
- sstables - Variable in class org.apache.cassandra.notifications.SSTableCompactingNotification
-
- sstables - Variable in class org.apache.cassandra.streaming.StreamReceiveTask
-
- SSTableScanner - Class in org.apache.cassandra.io.sstable
-
- SSTableScanner.EmptySSTableScanner - Class in org.apache.cassandra.io.sstable
-
- SSTableScanner.KeyScanningIterator - Class in org.apache.cassandra.io.sstable
-
- SSTableSimpleUnsortedWriter - Class in org.apache.cassandra.io.sstable
-
A SSTable writer that doesn't assume rows are in sorted order.
- SSTableSimpleUnsortedWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>, int, CompressionParameters) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
Create a new buffering writer.
- SSTableSimpleUnsortedWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>, int) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
- SSTableSimpleUnsortedWriter(File, CFMetaData, IPartitioner, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
- SSTableSimpleWriter - Class in org.apache.cassandra.io.sstable
-
A SSTable writer that assumes rows are in (partitioner) sorted order.
- SSTableSimpleWriter(File, IPartitioner, String, String, AbstractType<?>, AbstractType<?>) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
Create a new writer.
- SSTableSimpleWriter(File, CFMetaData, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.SSTableSimpleWriter
-
- sstablesInBounds(AbstractBounds<RowPosition>) - Method in class org.apache.cassandra.db.DataTracker.View
-
- sstablesInBounds(AbstractBounds<RowPosition>, DataTracker.SSTableIntervalTree, IPartitioner) - Static method in class org.apache.cassandra.db.DataTracker.View
-
- SSTableSliceIterator - Class in org.apache.cassandra.db.columniterator
-
A Cell Iterator over SSTable
- SSTableSliceIterator(SSTableReader, DecoratedKey, ColumnSlice[], boolean) - Constructor for class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
- SSTableSliceIterator(SSTableReader, FileDataInput, DecoratedKey, ColumnSlice[], boolean, RowIndexEntry) - Constructor for class org.apache.cassandra.db.columniterator.SSTableSliceIterator
-
An iterator for a slice within an SSTable
- sstablesMap - Variable in class org.apache.cassandra.db.DataTracker.View
-
- sstablesPerRead - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Deprecated.
- sstablesPerReadHistogram - Variable in class org.apache.cassandra.metrics.ColumnFamilyMetrics
-
Histogram of the number of sstable data files accessed per read
- 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, SSTableReader, 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 - Class in org.apache.cassandra.io.sstable
-
- SSTableWriter(String, long, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableWriter
-
- SSTableWriter(String, long, long, CFMetaData, IPartitioner, MetadataCollector) - Constructor for class org.apache.cassandra.io.sstable.SSTableWriter
-
- SSTableWriter.FinishType - Enum in org.apache.cassandra.io.sstable
-
- Stage - Enum in org.apache.cassandra.concurrent
-
- StageManager - Class in org.apache.cassandra.concurrent
-
This class manages executor services for Messages recieved: each Message requests
running on a specific "stage" for concurrency control; hence the Map approach,
even though stages (executors) are not created dynamically.
- StageManager() - Constructor for class org.apache.cassandra.concurrent.StageManager
-
- StandaloneScrubber - Class in org.apache.cassandra.tools
-
- StandaloneScrubber() - Constructor for class org.apache.cassandra.tools.StandaloneScrubber
-
- StandaloneSplitter - Class in org.apache.cassandra.tools
-
- StandaloneSplitter() - Constructor for class org.apache.cassandra.tools.StandaloneSplitter
-
- StandaloneUpgrader - Class in org.apache.cassandra.tools
-
- StandaloneUpgrader() - Constructor for class org.apache.cassandra.tools.StandaloneUpgrader
-
- start() - Method in class org.apache.cassandra.db.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() - Method in class org.apache.cassandra.repair.DatacenterAwareRequestCoordinator
-
- start() - Method in interface org.apache.cassandra.repair.IRequestCoordinator
-
- start() - Method in class org.apache.cassandra.repair.ParallelRequestCoordinator
-
- start() - Method in class org.apache.cassandra.repair.SequentialRequestCoordinator
-
- 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() - 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
-
- 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
-
- startThriftServer() - Method in class org.apache.cassandra.tools.NodeProbe
-
- 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
-
- 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
-
- 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
-
- statement() - Method in class org.apache.cassandra.cli.CliParser
-
- statement - Variable in class org.apache.cassandra.cql.CQLStatement
-
- statement - Variable in class org.apache.cassandra.cql.hooks.PreparationContext
-
- statement - Variable in class org.apache.cassandra.cql3.statements.ParsedStatement.Prepared
-
- statement_return() - Constructor for class org.apache.cassandra.cli.CliParser.statement_return
-
- statementId - Variable in class org.apache.cassandra.transport.messages.ExecuteMessage
-
- statementId - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- statements - Variable in class org.apache.cassandra.cql.BatchStatement
-
- StatementType - Enum in org.apache.cassandra.cql
-
- states() - Method in class org.apache.cassandra.gms.EndpointState
-
- 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
-
- StatsCollector() - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.StatsCollector
-
- StatsMetadata - Class in org.apache.cassandra.io.sstable.metadata
-
SSTable metadata that always stay on heap.
- StatsMetadata(EstimatedHistogram, EstimatedHistogram, 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() - 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_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() - Constructor for class org.apache.cassandra.tools.NodeTool.StatusBackup
-
- StatusBinary() - Constructor for class org.apache.cassandra.tools.NodeTool.StatusBinary
-
- statusCode - Variable in enum org.apache.cassandra.db.compaction.CompactionManager.AllSSTableOpStatus
-
- StatusGossip() - Constructor for class org.apache.cassandra.tools.NodeTool.StatusGossip
-
- 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() - 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() - Constructor for class org.apache.cassandra.tools.NodeTool.Stop
-
- stop() - Method in class org.apache.cassandra.transport.Server
-
- 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
.
- stopDaemon() - Method in class org.apache.cassandra.service.StorageService
-
- stopDaemon() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
- 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
-
- storage_port - Variable in class org.apache.cassandra.config.Config
-
- StorageMetrics - Class in org.apache.cassandra.metrics
-
Metrics related to Storage.
- StorageMetrics() - Constructor for class org.apache.cassandra.metrics.StorageMetrics
-
- StorageProxy - Class in org.apache.cassandra.service
-
- StorageProxy.WritePerformer - Interface in org.apache.cassandra.service
-
- StorageProxyMBean - Interface in org.apache.cassandra.service
-
- StorageService - Class in org.apache.cassandra.service
-
This abstraction contains the token/identifier of this node
on the identifier space.
- StorageService() - Constructor for class org.apache.cassandra.service.StorageService
-
- StorageServiceMBean - Interface in org.apache.cassandra.service
-
- store_type - Variable in class org.apache.cassandra.config.EncryptionOptions
-
- 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.AbstractCassandraStorage
-
- 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.AbstractBulkRecordWriter
-
- 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, 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
-
Task that make two nodes exchange (stream) some ranges (for a given table/cf).
- StreamingRepairTask(RepairJobDesc, SyncRequest) - 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) - 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
StreamResultFuture
s 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, long, int) - 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) - 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
-
- 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
-
- string(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
-
- string(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- string(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- string(ByteBuffer, int, int, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- string(ByteBuffer, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- STRING_LITERAL - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- STRING_LITERAL - Static variable in class org.apache.cassandra.cql.CqlParser
-
- STRING_LITERAL - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- STRING_LITERAL - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- stringifyAliasesParameters(Map<Byte, AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
-
Helper function to ease the writing of AbstractType.toString() methods.
- stringifyCollectionsParameters(Map<ByteBuffer, ? 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
-
- StringLiteral - Static variable in class org.apache.cassandra.cli.CliLexer
-
- StringLiteral - Static variable in class org.apache.cassandra.cli.CliParser
-
- StringSerializer() - Constructor for class org.apache.cassandra.dht.BootStrapper.StringSerializer
-
- StringToken - Class in org.apache.cassandra.dht
-
- StringToken(String) - Constructor for class org.apache.cassandra.dht.StringToken
-
- subcodec - Variable in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
-
- subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
- subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.Rows
-
- subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
-
- subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
-
- subcodec - Static variable in class org.apache.cassandra.transport.messages.ResultMessage.Void
-
- submit(Callable<T>) - Method in class org.apache.cassandra.concurrent.AbstractTracingAwareExecutorService
-
Task Submission / Creation / Objects
- submit(Runnable) - Method in class org.apache.cassandra.concurrent.AbstractTracingAwareExecutorService
-
- submit(Runnable, T) - Method in class org.apache.cassandra.concurrent.AbstractTracingAwareExecutorService
-
- submitAntiCompaction(ColumnFamilyStore, Collection<Range<Token>>, Refs<SSTableReader>, long) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- 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
-
- submitDifferencers() - Method in class org.apache.cassandra.repair.RepairJob
-
Submit differencers for running.
- submitHint(Mutation, InetAddress, AbstractWriteResponseHandler) - Static method in class org.apache.cassandra.service.StorageProxy
-
- submitIndexBuild(SecondaryIndexBuilder) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Is not scheduled, because it is performing disjoint work from sstable compaction.
- submitMaximal(ColumnFamilyStore, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
- submitRepairSession(UUID, Range<Token>, String, RepairParallelism, Set<InetAddress>, 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.DataTracker
-
- subscribers - Variable in class org.apache.cassandra.db.DataTracker
-
- 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
-
- 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
-
- 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
-
- 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.Auth
-
- 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.AllowAllAuthenticator
-
- supportedOptions() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Set of options supported by CREATE USER and ALTER USER queries.
- supportedOptions() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- supportedOptions() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- supportedOptions() - Method in class org.apache.cassandra.io.compress.DeflateCompressor
-
- supportedOptions() - Method in interface org.apache.cassandra.io.compress.ICompressor
-
- supportedOptions() - Method in class org.apache.cassandra.io.compress.LZ4Compressor
-
- supportedOptions() - Method in class org.apache.cassandra.io.compress.SnappyCompressor
-
- supportedOptions() - Method in interface org.apache.cassandra.thrift.ITransportFactory
-
- supportedOptions() - Method in class org.apache.cassandra.thrift.SSLTransportFactory
-
- supportedOptions() - Method in class org.apache.cassandra.thrift.TFramedTransportFactory
-
- 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) - Method in class org.apache.cassandra.db.DataTracker
-
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.compress.CompressedSequentialWriter
-
- sync() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleUnsortedWriter
-
- 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
-
- 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(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
-
- 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_KS - Static variable in class org.apache.cassandra.db.Keyspace
-
- system_update_column_family(CfDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
- system_update_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.CassandraServer
-
update an existing keyspace, but do not allow column family modifications.
- systemKeyspace() - Static method in class org.apache.cassandra.config.KSMetaData
-
- SystemKeyspace - Class in org.apache.cassandra.db
-
- SystemKeyspace() - Constructor for class org.apache.cassandra.db.SystemKeyspace
-
- SystemKeyspace.BootstrapState - Enum in org.apache.cassandra.db
-
- systemKeyspaceNames - Static variable in class org.apache.cassandra.config.Schema
-
- SystemOutput(boolean, boolean) - Constructor for class org.apache.cassandra.utils.OutputHandler.SystemOutput
-
- T - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- t - Variable in class org.apache.cassandra.cql3.Operation
-
- T__100 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__100 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__101 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__101 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__102 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__102 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__103 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__103 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__104 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__104 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__105 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__105 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__106 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__106 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__107 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__107 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__111 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__111 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__112 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__112 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__113 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__113 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__114 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__114 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__115 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__115 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__116 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__116 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__117 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__117 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__118 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__118 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__119 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__119 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__120 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__120 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__121 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__121 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__122 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__122 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__123 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__123 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__124 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__124 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__125 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__125 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__126 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__126 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__127 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__127 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__128 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__128 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__129 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__129 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__130 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__130 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__131 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__131 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__132 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- T__132 - Static variable in class org.apache.cassandra.cli.CliParser
-
- T__141 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__141 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__142 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__142 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__143 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__143 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__144 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__144 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__145 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__145 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__146 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__146 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__147 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__147 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__148 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__148 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__149 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__149 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__150 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__150 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__151 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__151 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__152 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__152 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__153 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__153 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__154 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__154 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__155 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__155 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__156 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__156 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__157 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__157 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__158 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__158 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__159 - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- T__159 - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- T__81 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__81 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__82 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__82 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__83 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__83 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__84 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__84 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__85 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__85 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__86 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__86 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__87 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__87 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__88 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__88 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__89 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__89 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__90 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__90 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__91 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__91 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__92 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__92 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__93 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__93 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__94 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__94 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__95 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__95 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__96 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__96 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__97 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__97 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__98 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__98 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- T__99 - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- T__99 - Static variable in class org.apache.cassandra.cql.CqlParser
-
- tableOrType - Variable in class org.apache.cassandra.transport.Event.SchemaChange
-
- 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.cql.CqlParser
-
- Term - Class in org.apache.cassandra.cql
-
A term parsed from a CQL statement.
- Term(String, TermType) - Constructor for class org.apache.cassandra.cql.Term
-
- Term(String, int) - Constructor for class org.apache.cassandra.cql.Term
-
Create new Term instance from a string, and an integer that corresponds
with the token ID from CQLParser.
- Term(long, TermType) - Constructor for class org.apache.cassandra.cql.Term
-
- Term() - Constructor for class org.apache.cassandra.cql.Term
-
- Term(String, int, int) - Constructor for class org.apache.cassandra.cql.Term
-
- term() - Method in class org.apache.cassandra.cql3.CqlParser
-
- Term - Interface in org.apache.cassandra.cql3
-
A CQL3 term, i.e.
- Term.CollectionTerminal - Interface in org.apache.cassandra.cql3
-
- 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
-
- termList() - Method in class org.apache.cassandra.cql.CqlParser
-
- termPair(Map<Term, Term>) - Method in class org.apache.cassandra.cql.CqlParser
-
- termPairWithOperation(Map<Term, Operation>) - Method in class org.apache.cassandra.cql.CqlParser
-
- testMetadata(String, Class<? extends AbstractReplicationStrategy>, Map<String, String>, CFMetaData...) - Static method in class org.apache.cassandra.config.KSMetaData
-
- testMetadataNotDurable(String, Class<? extends AbstractReplicationStrategy>, Map<String, String>, CFMetaData...) - Static method in class org.apache.cassandra.config.KSMetaData
-
- TFramedTransportFactory - Class in org.apache.cassandra.thrift
-
- TFramedTransportFactory() - Constructor for class org.apache.cassandra.thrift.TFramedTransportFactory
-
- threadLocalMD5Digest() - Static method in class org.apache.cassandra.utils.FBUtilities
-
- 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(SocketAddress) - 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
-
- thriftPort - Variable in class org.apache.cassandra.cli.CliSessionState
-
- thriftServer - Variable in class org.apache.cassandra.service.CassandraDaemon
-
- ThriftServer - Class in org.apache.cassandra.thrift
-
- ThriftServer(InetAddress, int, 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(File, 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
-
- throwLastRecognitionError() - Method in class org.apache.cassandra.cql.CqlLexer
-
- throwLastRecognitionError() - Method in class org.apache.cassandra.cql.CqlParser
-
- throwLastSyntaxError() - Method in class org.apache.cassandra.cql3.ErrorCollector
-
Throws the last 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 interface org.apache.cassandra.utils.concurrent.RefCounted.Tidy
-
- timeout - Variable in class org.apache.cassandra.utils.ExpiringMap.CacheableObject
-
- timeouts - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
-
- timeouts - Variable in class org.apache.cassandra.metrics.ConnectionMetrics
-
Number of timeouts for specific IP
- timestamp - Variable in class org.apache.cassandra.cql.AbstractModification
-
- timestamp - Variable in class org.apache.cassandra.cql.BatchStatement
-
- timestamp - Variable in class org.apache.cassandra.cql3.Attributes.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() - 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
-
- TimestampType - Class in org.apache.cassandra.db.marshal
-
Type for date-time values.
- timeToLive - Variable in class org.apache.cassandra.cql.AbstractModification
-
- timeToLive - Variable in class org.apache.cassandra.cql.BatchStatement
-
- timeToLive - Variable in class org.apache.cassandra.cql3.Attributes.Raw
-
- TimeuuidFcts - Class in org.apache.cassandra.cql3.functions
-
- TimeuuidFcts() - Constructor for class org.apache.cassandra.cql3.functions.TimeuuidFcts
-
- TimeUUIDSerializer - Class in org.apache.cassandra.serializers
-
- TimeUUIDSerializer() - Constructor for class org.apache.cassandra.serializers.TimeUUIDSerializer
-
- 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
-
- toByteArray() - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Returns the contents of this ByteArrayOutputStream as a byte array.
- 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
-
- 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
-
- 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
-
- 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
-
- 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.
- Token - Class in org.apache.cassandra.dht
-
- Token() - Constructor for class org.apache.cassandra.dht.Token
-
- token - Variable in class org.apache.cassandra.utils.MerkleTree.RowHash
-
- Token.KeyBound - Class in org.apache.cassandra.dht
-
- Token.TokenFactory - 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.cli.CliParser
-
- tokenNames - Static variable in class org.apache.cassandra.cql.CqlParser
-
- tokenNames - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- tokens - Variable in class org.apache.cassandra.dht.BootStrapper
-
- tokens(Collection<Token>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
-
- TokenSerializer() - 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_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() - Constructor for exception org.apache.cassandra.db.filter.TombstoneOverwhelmingException
-
- 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
- topology - Variable in class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.TopologyConfig
-
- TopologyConfig() - Constructor for class org.apache.cassandra.locator.YamlFileNetworkTopologySnitch.TopologyConfig
-
- TopPartitions() - Constructor for class org.apache.cassandra.tools.NodeTool.TopPartitions
-
- toRowBounds() - Method in class org.apache.cassandra.dht.AbstractBounds
-
Transform this abstract bounds to equivalent covering bounds of row positions.
- toRowBounds() - Method in class org.apache.cassandra.dht.Bounds
-
- toRowBounds() - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- toRowBounds() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- toRowBounds() - Method in class org.apache.cassandra.dht.Range
-
- toSchema(Mutation, long) - Method in class org.apache.cassandra.config.CFMetaData
-
- toSchema(long) - Method in class org.apache.cassandra.config.CFMetaData
-
Convert current metadata into schema mutation
- toSchema(Mutation, long) - Method in class org.apache.cassandra.config.ColumnDefinition
-
- toSchema(long) - Method in class org.apache.cassandra.config.KSMetaData
-
- toSchema(Mutation, String, long) - Method in class org.apache.cassandra.config.TriggerDefinition
-
Add specified trigger to the schema using given mutation.
- toSchema(UserType, long) - Static method in class org.apache.cassandra.config.UTMetaData
-
- toSchema(Mutation, UserType, long) - Static method in class org.apache.cassandra.config.UTMetaData
-
- toSchema(Mutation, long) - Method in class org.apache.cassandra.config.UTMetaData
-
- toSchemaUpdate(CFMetaData, long, boolean) - Method in class org.apache.cassandra.config.CFMetaData
-
Create schema mutations to update this metadata to provided new state.
- toSchemaUpdate(KSMetaData, long) - Method in class org.apache.cassandra.config.KSMetaData
-
- toString() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
- toString() - Method in class org.apache.cassandra.auth.DataResource
-
- toString() - Method in class org.apache.cassandra.auth.PermissionDetails
-
- toString(List<Object>) - Static method in class org.apache.cassandra.auth.Resources
-
Deprecated.
- toString() - Method in class org.apache.cassandra.cache.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.TriggerDefinition
-
- toString() - Method in class org.apache.cassandra.cql.AlterTableStatement
-
- toString() - Method in class org.apache.cassandra.cql.Attributes
-
- toString() - Method in class org.apache.cassandra.cql.BatchStatement
-
- toString() - Method in class org.apache.cassandra.cql.CFPropDefs
-
- toString() - Method in class org.apache.cassandra.cql.DeleteStatement
-
- toString() - Method in class org.apache.cassandra.cql.Operation
-
- toString() - Method in class org.apache.cassandra.cql.Relation
-
- toString() - Method in class org.apache.cassandra.cql.SelectExpression
-
- toString() - Method in class org.apache.cassandra.cql.SelectStatement
-
- toString() - Method in class org.apache.cassandra.cql.Term
-
- toString() - Method in class org.apache.cassandra.cql.UpdateStatement
-
- toString() - Method in class org.apache.cassandra.cql.WhereClause
-
- toString() - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
-
- toString() - Method in class org.apache.cassandra.cql3.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.FunctionCall.Raw
-
- 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.ResultSet.Metadata
-
- toString() - Method in class org.apache.cassandra.cql3.ResultSet
-
- toString() - Method in class org.apache.cassandra.cql3.Sets.Literal
-
- toString() - Method in class org.apache.cassandra.cql3.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 class org.apache.cassandra.cql3.statements.Selectable.WithFieldSelection
-
- toString() - Method in class org.apache.cassandra.cql3.statements.Selectable.WithFunction
-
- toString() - Method in class org.apache.cassandra.cql3.statements.Selectable.WritetimeOrTTL
-
- toString() - Method in class org.apache.cassandra.cql3.statements.SelectionColumnMapping
-
- toString() - Method in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
-
- toString() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Contains
-
- toString() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.EQ
-
- toString() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithMarker
-
- toString() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithValues
-
- toString() - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Slice
-
- 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.UserOptions
-
- 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.DataTracker.View
-
- 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(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.BytesToken
-
- toString() - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- toString() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- toString() - Method in class org.apache.cassandra.dht.LocalToken
-
- toString() - Method in class org.apache.cassandra.dht.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.AbstractColumnFamilyRecordWriter.AbstractRangeClient
-
- toString() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
-
- toString() - Method in class org.apache.cassandra.io.compress.CompressedRandomAccessReader
-
- toString() - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
-
- toString() - Method in error org.apache.cassandra.io.FSReadError
-
- toString() - Method in error org.apache.cassandra.io.FSWriteError
-
- toString() - Method in class org.apache.cassandra.io.sstable.Component
-
- toString() - Method in class org.apache.cassandra.io.sstable.Descriptor
-
- toString() - Method in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- toString() - Method in class org.apache.cassandra.io.sstable.SSTable
-
- toString() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
-
- toString() - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Returns the contents of this ByteArrayOutputStream as a string.
- toString(int) - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
- toString(String) - Method in class org.apache.cassandra.io.util.FastByteArrayOutputStream
-
Returns the contents of this ByteArrayOutputStream as a string converted
according to the encoding declared in enc
.
- toString() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
-
- toString() - Method in class org.apache.cassandra.io.util.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.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.notifications.SSTableCompactingNotification
-
- toString() - Method in class org.apache.cassandra.repair.Differencer
-
- toString() - Method in class org.apache.cassandra.repair.messages.PrepareMessage
-
- toString() - Method in class org.apache.cassandra.repair.RepairJobDesc
-
- toString(String) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
-
- toString(Boolean) - Method in class org.apache.cassandra.serializers.BooleanSerializer
-
- 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(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
-
- 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.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
-
- toString() - Method in class org.apache.cassandra.utils.SemanticVersion
-
- 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
- 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
- totalLatencyHistogram - Variable in class org.apache.cassandra.metrics.LatencyMetrics
-
Deprecated.
- 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
- toThrift() - Method in class org.apache.cassandra.config.CFMetaData
-
- toThrift(Map<ByteBuffer, ColumnDefinition>) - Static method in class org.apache.cassandra.config.ColumnDefinition
-
- toThrift() - Method in class org.apache.cassandra.config.ColumnDefinition
-
- toThrift() - Method in class org.apache.cassandra.config.KSMetaData
-
- toThrift() - Method in class org.apache.cassandra.config.TriggerDefinition
-
- toThrift(Map<String, TriggerDefinition>) - Static method in class org.apache.cassandra.config.TriggerDefinition
-
- 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
-
- 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
-
- toTokenBounds() - Method in class org.apache.cassandra.dht.AbstractBounds
-
Transform this abstract bounds to a token abstract bounds.
- toTokenBounds() - Method in class org.apache.cassandra.dht.Bounds
-
- toTokenBounds() - Method in class org.apache.cassandra.dht.ExcludingBounds
-
- toTokenBounds() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
-
- toTokenBounds() - Method in class org.apache.cassandra.dht.Range
-
- toType(Pair<DataType, Object>) - Static method in enum org.apache.cassandra.transport.DataType
-
- toWriteUTFBytes(String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
- tProtocolFactory - Variable in class org.apache.cassandra.thrift.TServerFactory.Args
-
- TpStats() - Constructor for class org.apache.cassandra.tools.NodeTool.TpStats
-
- TRACE - Static variable in class org.apache.cassandra.cli.CliLexer
-
- TRACE - Static variable in class org.apache.cassandra.cli.CliParser
-
- trace(String, Object) - Method in class org.apache.cassandra.tracing.TraceState
-
- trace(String, Object, Object) - Method in class org.apache.cassandra.tracing.TraceState
-
- trace(String, Object[]) - Method in class org.apache.cassandra.tracing.TraceState
-
- trace(String) - Method in class org.apache.cassandra.tracing.TraceState
-
- trace(ByteBuffer, String, int) - Static method in class org.apache.cassandra.tracing.TraceState
-
- trace(String) - Static method in class org.apache.cassandra.tracing.Tracing
-
- trace(String, Object) - Static method in class org.apache.cassandra.tracing.Tracing
-
- trace(String, Object, Object) - Static method in class org.apache.cassandra.tracing.Tracing
-
- trace(String, Object[]) - Static method in class org.apache.cassandra.tracing.Tracing
-
- TRACE_HEADER - Static variable in class org.apache.cassandra.tracing.Tracing
-
- TRACE_KS - Static variable in class org.apache.cassandra.tracing.Tracing
-
- trace_next_query() - Method in class org.apache.cassandra.thrift.CassandraServer
-
- TraceEventsCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- traceKeyspace() - Static method in class org.apache.cassandra.config.KSMetaData
-
- traceNextQuery() - Method in class org.apache.cassandra.cli.CliParser
-
- traceNextQuery() - Method in class org.apache.cassandra.service.QueryState
-
- traceNextQuery_return() - Constructor for class org.apache.cassandra.cli.CliParser.traceNextQuery_return
-
- traceSessionId() - Method in class org.apache.cassandra.cli.CliParser
-
- traceSessionId_return() - Constructor for class org.apache.cassandra.cli.CliParser.traceSessionId_return
-
- TraceSessionsCf - Static variable in class org.apache.cassandra.config.CFMetaData
-
- 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) - Constructor for class org.apache.cassandra.tracing.TraceState
-
- Tracing - Class in org.apache.cassandra.tracing
-
A trace session context.
- Tracing() - Constructor for class org.apache.cassandra.tracing.Tracing
-
- TracingAwareExecutorService - Interface in org.apache.cassandra.concurrent
-
- tracingId - Variable in class org.apache.cassandra.transport.Message.Response
-
- tracingProbability() - Method in class org.apache.cassandra.cli.CliParser
-
- tracingProbability_return() - Constructor for class org.apache.cassandra.cli.CliParser.tracingProbability_return
-
- tracingRequested - Variable in class org.apache.cassandra.transport.Message.Request
-
- 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 - Variable in class org.apache.cassandra.io.sstable.Descriptor.Version
-
- 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
.
- TransportException - Interface in org.apache.cassandra.exceptions
-
- transportFactory - Variable in class org.apache.cassandra.cli.CliSessionState
-
- 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
-
- 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
-
- TriggerExecutor - Class in org.apache.cassandra.triggers
-
- triggers(Map<String, TriggerDefinition>) - Method in class org.apache.cassandra.config.CFMetaData
-
- 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 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- TRUNCATE - Static variable in class org.apache.cassandra.cli.CliParser
-
- 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(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() - 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
-
- truncateStatement() - Method in class org.apache.cassandra.cli.CliParser
-
- truncateStatement() - Method in class org.apache.cassandra.cql.CqlParser
-
- truncateStatement() - Method in class org.apache.cassandra.cql3.CqlParser
-
- TruncateStatement - Class in org.apache.cassandra.cql3.statements
-
- TruncateStatement(CFName) - Constructor for class org.apache.cassandra.cql3.statements.TruncateStatement
-
- truncateStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.truncateStatement_return
-
- 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
-
- tryOpenDirectory(String) - Static method in class org.apache.cassandra.utils.CLibrary
-
- tryRef() - Method in class org.apache.cassandra.io.sstable.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
-
- 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 - Static variable in class org.apache.cassandra.cli.CliLexer
-
- TTL - Static variable in class org.apache.cassandra.cli.CliParser
-
- 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
-
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')).
- 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.
- 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.cql.CQLStatement
-
- type - Variable in class org.apache.cassandra.cql.Operation
-
- type - Variable in class org.apache.cassandra.cql3.ColumnSpecification
-
- type - Variable in class org.apache.cassandra.cql3.statements.BatchStatement
-
- 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 - Variable in class org.apache.cassandra.transport.messages.BatchMessage
-
- 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
-
- typeIdentifier() - Method in class org.apache.cassandra.cli.CliParser
-
- typeIdentifier_return() - Constructor for class org.apache.cassandra.cli.CliParser.typeIdentifier_return
-
- 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
-
- V - Static variable in class org.apache.cassandra.cql.CqlLexer
-
- V - Static variable in class org.apache.cassandra.cql.CqlParser
-
- V - Static variable in class org.apache.cassandra.cql3.CqlLexer
-
- V - Static variable in class org.apache.cassandra.cql3.CqlParser
-
- validate() - Method in class org.apache.cassandra.config.CFMetaData
-
- validate() - Method in class org.apache.cassandra.config.KSMetaData
-
- validate() - Method in class org.apache.cassandra.cql.CFPropDefs
-
- validate() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
-
The CqlParser
only goes as far as extracting the keyword arguments
from these statements, so this method is responsible for processing and
validating, and must be called prior to access.
- validate(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.AlterTableStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterTypeStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterUserStatement
-
- 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.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.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.CreateUserStatement
-
- 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.DropTableStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTriggerStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropTypeStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropUserStatement
-
- 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.ListUsersStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.PermissionAlteringStatement
-
- validate(Set<String>, Set<String>) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
-
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.UseStatement
-
- validate() - Method in class org.apache.cassandra.cql3.UserOptions
-
- validate(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
-
- 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(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TupleType
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UserType
-
- validate(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
-
- validate() - Method in class org.apache.cassandra.io.compress.CompressionParameters
-
- validate(byte[], int, int) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
- 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.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.TimestampSerializer
-
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimeUUIDSerializer
-
- validate(ByteBuffer) - Method in interface org.apache.cassandra.serializers.TypeSerializer
-
- 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
-
- validateCollectionMember(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
An alternative validation function used by CollectionsType in conjunction with CompositeType.
- validateCollectionMember(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ColumnToCollectionType
-
- validateColumn(CFMetaData, CellName, ByteBuffer) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- 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
-
- validateColumnName(CellName) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- 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
- validateColumns - Variable in class org.apache.cassandra.db.compaction.Scrubber
-
- 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 interface org.apache.cassandra.auth.IAuthenticator
-
Validates configuration of IAuthenticator implementation (if configurable).
- validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Validates configuration of IAuthorizer implementation (if configurable).
- validateConfiguration() - Method in interface org.apache.cassandra.auth.IInternodeAuthenticator
-
Validates configuration of IInternodeAuthenticator implementation (if configurable).
- validateConfiguration() - Method in class org.apache.cassandra.auth.LegacyAuthenticator
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.LegacyAuthorizer
-
- validateConfiguration() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
-
- validateConfiguration(Configuration) - Method in class org.apache.cassandra.hadoop.AbstractColumnFamilyInputFormat
-
- validateConfiguration(Configuration) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
-
- 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.cql.QueryProcessor
-
- validateKey(ByteBuffer) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
- validateKey(CFMetaData, ByteBuffer) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateKeyAlias(CFMetaData, String) - Static method in class org.apache.cassandra.cql.QueryProcessor
-
- validateKeyRange(CFMetaData, ByteBuffer, KeyRange) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- 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
-
- validateMinusSupplied(Object, Term, IntStream) - Method in class org.apache.cassandra.cql.CqlParser
-
- 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
-
- validatePredicate(CFMetaData, ColumnParent, SlicePredicate) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateRange(CFMetaData, ColumnParent, SliceRange) - Static method in class org.apache.cassandra.thrift.ThriftValidation
-
- validateReplicationFactor(String) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
- validateReplicationStrategy(String, 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
-
- validator - Variable in class org.apache.cassandra.cql.AlterTableStatement
-
- 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
-
- validBufferBytes - Variable in class org.apache.cassandra.io.util.RandomAccessReader
-
- validBufferBytes - Variable in class org.apache.cassandra.io.util.SequentialWriter
-
- validBufferBytes - Variable in class org.apache.cassandra.streaming.compress.CompressedInputStream
-
- value() - Method in class org.apache.cassandra.cli.CliParser
-
- value - Variable in class org.apache.cassandra.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(SortedSet<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Sets.Value
-
- value - Variable in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.EQ
-
- 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() - Method in class org.apache.cassandra.utils.DefaultInteger
-
- value - Variable in class org.apache.cassandra.utils.ExpiringMap.CacheableObject
-
- value_return() - Constructor for class org.apache.cassandra.cli.CliParser.value_return
-
- 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.Metadata
-
- valueFactory - Variable in class org.apache.cassandra.service.StorageService
-
- valueOf(String) - Static method in enum org.apache.cassandra.auth.IAuthenticator.Option
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.auth.Permission
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.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.cli.CliClient.ColumnFamilyArgument
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cli.CliClient.Function
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.concurrent.Stage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.CFMetaData.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.cql.AlterTableStatement.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql.Operation.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql.StatementType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.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.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.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.AbstractCassandraStorage.MarshallerType
-
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.metadata.MetadataType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.SSTableReader.OpenReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.SSTableWriter.FinishType
-
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
-
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.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.NoSpamLogger.Level
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.cassandra.auth.IAuthenticator.Option
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.auth.Permission
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.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.cli.CliClient.ColumnFamilyArgument
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cli.CliClient.Function
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.concurrent.Stage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.config.CFMetaData.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.cql.AlterTableStatement.OperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql.Operation.OperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql.StatementType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.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() - 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.ModificationStatement.StatementType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.MultiColumnRestriction.EQ
-
- values(QueryOptions) - Method in interface org.apache.cassandra.cql3.statements.Restriction.Slice
-
- values(QueryOptions) - Method in interface org.apache.cassandra.cql3.statements.Restriction
-
- values(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Contains
-
- values(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.EQ
-
- values(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithMarker
-
- values - Variable in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithValues
-
- values(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.InWithValues
-
- values(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SingleColumnRestriction.Slice
-
- 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.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.AbstractCassandraStorage.MarshallerType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.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.metadata.MetadataType
-
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.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.SSTableWriter.FinishType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- 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
-
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.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() - Method in class org.apache.cassandra.utils.BiMultiValMap
-
- 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.
- 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
-
- variables - Variable in class org.apache.cassandra.cql.hooks.ExecutionContext
-
- 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
-
- verbose - Variable in class org.apache.cassandra.cli.CliSessionState
-
- 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
-
- 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(String) - Constructor for class org.apache.cassandra.io.sstable.Descriptor.Version
-
- version - Variable in class org.apache.cassandra.net.MessageIn
-
- version - Variable in class org.apache.cassandra.streaming.messages.FileMessageHeader
-
SSTable version
- Version() - Constructor for class org.apache.cassandra.tools.NodeTool.Version
-
- version - Variable in class org.apache.cassandra.transport.Frame.Header
-
- VERSION_12 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- VERSION_12 - Static variable in class org.apache.cassandra.net.MessagingService
-
- VERSION_20 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- VERSION_20 - Static variable in class org.apache.cassandra.net.MessagingService
-
- VERSION_21 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
- VERSION_21 - Static variable in class org.apache.cassandra.net.MessagingService
-
- VERSION_3 - 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
-
- viewFilter(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
- viewFilter(AbstractBounds<RowPosition>) - 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
-
- Void() - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Void
-