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

A

AB_MAGIC - Static variable in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
abort() - Method in class org.apache.cassandra.auth.CassandraLoginModule
This method is called if the LoginContext's overall authentication failed.
abort(Throwable) - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
 
abort() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
 
abort() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
 
abort() - Method in class org.apache.cassandra.db.repair.PendingAntiCompaction.AcquireResult
 
abort() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReceiver
 
abort(Throwable) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableZeroCopyWriter
 
abort(Throwable) - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
 
abort(Throwable) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
abort() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
abort(Throwable) - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
 
abort(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter
 
abort() - Method in class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
 
abort(Predicate<ActiveRepairService.ParentRepairSession>, String) - Method in class org.apache.cassandra.service.ActiveRepairService
Remove any parent repair sessions matching predicate
abort() - Method in interface org.apache.cassandra.streaming.StreamReceiver
Called when something went wrong with a stream session.
abort() - Method in class org.apache.cassandra.streaming.StreamReceiveTask
Abort this task.
abort() - Method in class org.apache.cassandra.streaming.StreamTask
Abort the task.
abort() - Method in class org.apache.cassandra.streaming.StreamTransferTask
 
abort(Throwable) - Method in interface org.apache.cassandra.utils.concurrent.Transactional
 
abort(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
rollback any effects of this transaction object graph; delegates first to doCleanup, then to doAbort
abort() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
 
abortEarly() - Method in interface org.apache.cassandra.utils.btree.UpdateFunction
 
abortEarly() - Method in class org.apache.cassandra.utils.btree.UpdateFunction.Simple
 
abortOrDie(SSTableMultiWriter) - Static method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
 
abortRunnables(List<Memtable.FlushRunnable>, Throwable) - Method in class org.apache.cassandra.db.Memtable
 
abortTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
 
abs(long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
AbstractAllocator - Class in org.apache.cassandra.utils.memory
 
AbstractAllocator() - Constructor for class org.apache.cassandra.utils.memory.AbstractAllocator
 
AbstractAnalyzer - Class in org.apache.cassandra.index.sasi.analyzer
 
AbstractAnalyzer() - Constructor for class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
 
AbstractArrayClusteringPrefix - Class in org.apache.cassandra.db
 
AbstractArrayClusteringPrefix(ClusteringPrefix.Kind, byte[][]) - Constructor for class org.apache.cassandra.db.AbstractArrayClusteringPrefix
 
AbstractBounds<T extends RingPosition<T>> - Class in org.apache.cassandra.dht
 
AbstractBounds(T, T) - Constructor for class org.apache.cassandra.dht.AbstractBounds
 
AbstractBounds.AbstractBoundsSerializer<T extends RingPosition<T>> - Class in org.apache.cassandra.dht
 
AbstractBounds.Boundary<T extends RingPosition<T>> - Class in org.apache.cassandra.dht
 
AbstractBoundsSerializer(IPartitionerDependentSerializer<T>) - Constructor for class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
 
AbstractBTreePartition - Class in org.apache.cassandra.db.partitions
 
AbstractBTreePartition(DecoratedKey) - Constructor for class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
AbstractBTreePartition.Holder - Class in org.apache.cassandra.db.partitions
 
AbstractBufferClusteringPrefix - Class in org.apache.cassandra.db
 
AbstractBufferClusteringPrefix(ClusteringPrefix.Kind, ByteBuffer[]) - Constructor for class org.apache.cassandra.db.AbstractBufferClusteringPrefix
 
AbstractCell<V> - Class in org.apache.cassandra.db.rows
Base abstract class for Cell implementations.
AbstractCell(ColumnMetadata) - Constructor for class org.apache.cassandra.db.rows.AbstractCell
 
AbstractClusteringIndexFilter - Class in org.apache.cassandra.db.filter
 
AbstractClusteringIndexFilter(boolean) - Constructor for class org.apache.cassandra.db.filter.AbstractClusteringIndexFilter
 
AbstractCommitLogSegmentManager - Class in org.apache.cassandra.db.commitlog
Performs eager-creation of commit log segments in a background thread.
AbstractCommitLogService - Class in org.apache.cassandra.db.commitlog
 
AbstractCompactionController - Class in org.apache.cassandra.db
AbstractCompactionController allows custom implementations of the CompactionController for use in tooling, without being tied to the SSTableReader and local filesystem
AbstractCompactionController(ColumnFamilyStore, int, CompactionParams.TombstoneOption) - Constructor for class org.apache.cassandra.db.AbstractCompactionController
 
AbstractCompactionStrategy - Class in org.apache.cassandra.db.compaction
Pluggable compaction strategy determines how SSTables get merged.
AbstractCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
AbstractCompactionStrategy.ScannerList - Class in org.apache.cassandra.db.compaction
 
AbstractCompactionTask - Class in org.apache.cassandra.db.compaction
 
AbstractCompactionTask(ColumnFamilyStore, LifecycleTransaction) - Constructor for class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
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.ParsedComparator - Interface in org.apache.cassandra.db.marshal
 
AbstractDataSet(NavigableMap<DecoratedKey, AbstractVirtualTable.Partition>) - Constructor for class org.apache.cassandra.db.virtual.AbstractVirtualTable.AbstractDataSet
 
AbstractEndpointSnitch - Class in org.apache.cassandra.locator
 
AbstractEndpointSnitch() - Constructor for class org.apache.cassandra.locator.AbstractEndpointSnitch
 
AbstractFunction - Class in org.apache.cassandra.cql3.functions
Base class for our native/hardcoded functions.
AbstractFunction(FunctionName, List<AbstractType<?>>, AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.functions.AbstractFunction
 
AbstractGettableData - Class in org.apache.cassandra.cql3.functions.types
 
AbstractIterator<T> - Class in org.apache.cassandra.index.sasi.utils
 
AbstractIterator() - Constructor for class org.apache.cassandra.index.sasi.utils.AbstractIterator
Constructor for use by subclasses.
AbstractIterator<V> - Class in org.apache.cassandra.utils
 
AbstractIterator() - Constructor for class org.apache.cassandra.utils.AbstractIterator
 
AbstractIterator.State - Enum in org.apache.cassandra.index.sasi.utils
 
AbstractJmxClient - Class in org.apache.cassandra.tools
 
AbstractJmxClient(String, Integer, String, String) - Constructor for class org.apache.cassandra.tools.AbstractJmxClient
 
AbstractLocalAwareExecutorService - Class in org.apache.cassandra.concurrent
 
AbstractLocalAwareExecutorService() - Constructor for class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
AbstractMarker - Class in org.apache.cassandra.cql3
A single bind marker.
AbstractMarker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.AbstractMarker
 
AbstractMarker.INRaw - Class in org.apache.cassandra.cql3
A raw placeholder for multiple values of the same type for a single column.
AbstractMarker.MultiColumnRaw - Class in org.apache.cassandra.cql3
A MultiColumnRaw version of AbstractMarker.Raw
AbstractMarker.Raw - Class in org.apache.cassandra.cql3
A parsed, but non prepared, bind marker.
AbstractMessageHandler - Class in org.apache.cassandra.net
Core logic for handling inbound message deserialization and execution (in tandem with FrameDecoder).
AbstractMessageHandler(FrameDecoder, Channel, int, long, ResourceLimits.Limit, ResourceLimits.Limit, AbstractMessageHandler.WaitQueue, AbstractMessageHandler.WaitQueue, AbstractMessageHandler.OnHandlerClosed) - Constructor for class org.apache.cassandra.net.AbstractMessageHandler
 
AbstractMessageHandler.LargeMessage<H> - Class in org.apache.cassandra.net
 
AbstractMessageHandler.OnHandlerClosed - Interface in org.apache.cassandra.net
 
AbstractMessageHandler.WaitQueue - Class in org.apache.cassandra.net
A special-purpose wait queue to park inbound message handlers that failed to allocate reserve capacity for a message in.
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
 
AbstractOnHeapClusteringPrefix<V> - Class in org.apache.cassandra.db
 
AbstractOnHeapClusteringPrefix(ClusteringPrefix.Kind, V[]) - Constructor for class org.apache.cassandra.db.AbstractOnHeapClusteringPrefix
 
AbstractPaxosCallback<T> - Class in org.apache.cassandra.service.paxos
 
AbstractPaxosCallback(int, ConsistencyLevel, long) - Constructor for class org.apache.cassandra.service.paxos.AbstractPaxosCallback
 
AbstractRangeTombstoneMarker<B extends ClusteringBoundOrBoundary<?>> - Class in org.apache.cassandra.db.rows
 
AbstractRangeTombstoneMarker(B) - Constructor for class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
 
AbstractReadCommandBuilder - Class in org.apache.cassandra.db
 
AbstractReadCommandBuilder.PartitionRangeBuilder - Class in org.apache.cassandra.db
 
AbstractReadCommandBuilder.SinglePartitionBuilder - Class in org.apache.cassandra.db
 
AbstractReaderFileProxy - Class in org.apache.cassandra.io.util
 
AbstractReaderFileProxy(ChannelProxy, long) - Constructor for class org.apache.cassandra.io.util.AbstractReaderFileProxy
 
AbstractReadExecutor - Class in org.apache.cassandra.service.reads
Sends a read request to the replicas needed to satisfy a given ConsistencyLevel.
AbstractReadExecutor.NeverSpeculatingReadExecutor - Class in org.apache.cassandra.service.reads
 
AbstractReadRepair<E extends Endpoints<E>,P extends ReplicaPlan.ForRead<E>> - Class in org.apache.cassandra.service.reads.repair
 
AbstractReadRepair(ReadCommand, ReplicaPlan.Shared<E, P>, long) - Constructor for class org.apache.cassandra.service.reads.repair.AbstractReadRepair
 
AbstractReplicaCollection<C extends AbstractReplicaCollection<C>> - Class in org.apache.cassandra.locator
A collection like class for Replica objects.
AbstractReplicaCollection.ReplicaList - Class in org.apache.cassandra.locator
A simple list with no comodification checks and immutability by default (only append permitted, and only one initial copy) this permits us to reduce the amount of garbage generated, by not wrapping iterators or unnecessarily copying and reduces the amount of indirection necessary, as well as ensuring monomorphic callsites
AbstractReplicaCollection.ReplicaMap<K> - Class in org.apache.cassandra.locator
A simple map that ensures the underlying list's iteration order is maintained, and can be shared with subLists (either produced via subList, or via filter that naturally produced a subList).
AbstractReplicationStrategy - Class in org.apache.cassandra.locator
A abstract parent for all replication strategies.
AbstractReplicationStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.AbstractReplicationStrategy
 
AbstractRow - Class in org.apache.cassandra.db.rows
Base abstract class for Row implementations.
AbstractRow() - Constructor for class org.apache.cassandra.db.rows.AbstractRow
 
AbstractSignal() - Constructor for class org.apache.cassandra.utils.concurrent.WaitQueue.AbstractSignal
 
AbstractSSTableIterator - Class in org.apache.cassandra.db.columniterator
 
AbstractSSTableIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry, Slices, ColumnFilter, FileHandle) - Constructor for class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
AbstractSSTableIterator.IndexState - Class in org.apache.cassandra.db.columniterator
 
AbstractSSTableIterator.Reader - Class in org.apache.cassandra.db.columniterator
 
AbstractStrategyHolder - Class in org.apache.cassandra.db.compaction
Wrapper that's aware of how sstables are divided between separate strategies, and provides a standard interface to them not threadsafe, calls must be synchronized by caller
AbstractStrategyHolder.DestinationRouter - Interface in org.apache.cassandra.db.compaction
 
AbstractStrategyHolder.GroupedSSTableContainer - Class in org.apache.cassandra.db.compaction
Maps sstables to their token partition bucket
AbstractStrategyHolder.TaskSupplier - Class in org.apache.cassandra.db.compaction
 
AbstractTextSerializer - Class in org.apache.cassandra.serializers
 
AbstractTextSerializer(Charset) - Constructor for class org.apache.cassandra.serializers.AbstractTextSerializer
 
AbstractTokenTreeBuilder - Class in org.apache.cassandra.index.sasi.disk
 
AbstractTokenTreeBuilder() - Constructor for class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
 
AbstractTokenTreeBuilder.InteriorNode - Class in org.apache.cassandra.index.sasi.disk
 
AbstractTokenTreeBuilder.Leaf - Class in org.apache.cassandra.index.sasi.disk
 
AbstractTokenTreeBuilder.Leaf.LeafEntry - Class in org.apache.cassandra.index.sasi.disk
 
AbstractTokenTreeBuilder.Leaf.SimpleLeafEntry - Class in org.apache.cassandra.index.sasi.disk
 
AbstractTokenTreeBuilder.LevelIterator - Class in org.apache.cassandra.index.sasi.disk
 
AbstractTokenTreeBuilder.Node - Class in org.apache.cassandra.index.sasi.disk
 
AbstractTransactional() - Constructor for class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
 
AbstractType<T> - Class in org.apache.cassandra.db.marshal
Specifies a Comparator for a specific type of ByteBuffer.
AbstractType(AbstractType.ComparisonType) - Constructor for class org.apache.cassandra.db.marshal.AbstractType
 
AbstractType.ComparisonType - Enum in org.apache.cassandra.db.marshal
 
AbstractUnfilteredPartitionIterator - Class in org.apache.cassandra.db.partitions
 
AbstractUnfilteredPartitionIterator() - Constructor for class org.apache.cassandra.db.partitions.AbstractUnfilteredPartitionIterator
 
AbstractUnfilteredRowIterator - Class in org.apache.cassandra.db.rows
 
AbstractUnfilteredRowIterator(TableMetadata, DecoratedKey, DeletionTime, RegularAndStaticColumns, Row, boolean, EncodingStats) - Constructor for class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
 
AbstractVirtualTable - Class in org.apache.cassandra.db.virtual
An abstract virtual table implementation that builds the resultset on demand.
AbstractVirtualTable(TableMetadata) - Constructor for class org.apache.cassandra.db.virtual.AbstractVirtualTable
 
AbstractVirtualTable.AbstractDataSet - Class in org.apache.cassandra.db.virtual
An abstract, map-backed DataSet implementation.
AbstractVirtualTable.DataSet - Interface in org.apache.cassandra.db.virtual
 
AbstractVirtualTable.Partition - Interface in org.apache.cassandra.db.virtual
 
AbstractVirtualTable.SimpleTable - Class in org.apache.cassandra.db.virtual
 
AbstractWriteResponseHandler<T> - Class in org.apache.cassandra.service
 
AbstractWriteResponseHandler(ReplicaPlan.ForTokenWrite, Runnable, WriteType, long) - Constructor for class org.apache.cassandra.service.AbstractWriteResponseHandler
 
accept(long, TimeUnit) - Method in class org.apache.cassandra.metrics.MessagingMetrics.DCLatencyRecorder
 
accept(ByteBuffer) - Method in interface org.apache.cassandra.net.AsyncStreamingInputPlus.Consumer
 
accept(Message<?>) - Method in class org.apache.cassandra.net.InboundSink
 
accept(long, TimeUnit) - Method in interface org.apache.cassandra.net.LatencyConsumer
 
accept(Message<?>, InetAddressAndPort, ConnectionType) - Method in class org.apache.cassandra.net.OutboundSink
 
accept(Message<?>, InetAddressAndPort, ConnectionType) - Method in interface org.apache.cassandra.net.OutboundSink.Sink
 
accept(T) - Method in interface org.apache.cassandra.utils.FailingConsumer
 
accepted_protocols - Variable in class org.apache.cassandra.config.EncryptionOptions
 
acceptedProtocols() - Method in class org.apache.cassandra.config.EncryptionOptions
Combine the pre-4.0 protocol field with the accepted_protocols list, substituting a list of explicit protocols for the previous catchall default of "TLS"
acceptedProtocolsArray() - Method in class org.apache.cassandra.config.EncryptionOptions
 
acceptMessaging - Variable in class org.apache.cassandra.net.InboundConnectionSettings
 
accepts(Object) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractCollectionCodec
 
accepts(Object) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractMapCodec
 
accepts(DataType) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractTupleCodec
 
accepts(TypeToken<?>) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return true if this codec is capable of serializing the given javaType.
accepts(Class<?>) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return true if this codec is capable of serializing the given javaType.
accepts(DataType) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return true if this codec is capable of deserializing the given cqlType.
accepts(Object) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return true if this codec is capable of serializing the given object.
accepts(OpOrder.Group, CommitLogPosition) - Method in class org.apache.cassandra.db.Memtable
 
acceptsTransient() - Method in class org.apache.cassandra.db.ReadCommand
 
acceptStreaming - Variable in class org.apache.cassandra.net.InboundConnectionSettings
 
acceptVersions - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
acceptVersions(ConnectionCategory) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
accessor() - Method in class org.apache.cassandra.db.AbstractArrayClusteringPrefix
 
accessor() - Method in class org.apache.cassandra.db.AbstractBufferClusteringPrefix
 
accessor() - Method in interface org.apache.cassandra.db.ClusteringPrefix
 
accessor() - Method in class org.apache.cassandra.db.NativeClustering
 
accessor() - Method in class org.apache.cassandra.db.rows.ArrayCell
 
accessor() - Method in class org.apache.cassandra.db.rows.BufferCell
 
accessor() - Method in class org.apache.cassandra.db.rows.Cell
 
accessor() - Method in class org.apache.cassandra.db.rows.NativeCell
 
accumulate(LongAccumulator<ColumnData>, long) - Method in class org.apache.cassandra.db.rows.BTreeRow
 
accumulate(LongAccumulator<ColumnData>, Comparator<ColumnData>, ColumnData, long) - Method in class org.apache.cassandra.db.rows.BTreeRow
 
accumulate(BiLongAccumulator<A, ColumnData>, A, long) - Method in class org.apache.cassandra.db.rows.BTreeRow
 
accumulate(BiLongAccumulator<A, ColumnData>, A, Comparator<ColumnData>, ColumnData, long) - Method in class org.apache.cassandra.db.rows.BTreeRow
 
accumulate(LongAccumulator<Cell<?>>, long) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
accumulate(BiLongAccumulator<A, Cell<?>>, A, long) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
accumulate(LongAccumulator<ColumnData>, long) - Method in interface org.apache.cassandra.db.rows.Row
Apply an accumulation funtion to every column in a row
accumulate(LongAccumulator<ColumnData>, Comparator<ColumnData>, ColumnData, long) - Method in interface org.apache.cassandra.db.rows.Row
 
accumulate(BiLongAccumulator<A, ColumnData>, A, long) - Method in interface org.apache.cassandra.db.rows.Row
 
accumulate(BiLongAccumulator<A, ColumnData>, A, Comparator<ColumnData>, ColumnData, long) - Method in interface org.apache.cassandra.db.rows.Row
 
accumulate(Object[], BiLongAccumulator<A, V>, A, Comparator<V>, V, long) - Static method in class org.apache.cassandra.utils.btree.BTree
Walk the btree and accumulate a long value using the supplied accumulator function.
accumulate(Object[], LongAccumulator<V>, Comparator<V>, V, long) - Static method in class org.apache.cassandra.utils.btree.BTree
 
accumulate(Object[], LongAccumulator<V>, long) - Static method in class org.apache.cassandra.utils.btree.BTree
 
accumulate(Object[], BiLongAccumulator<A, V>, A, long) - Static method in class org.apache.cassandra.utils.btree.BTree
 
Accumulator<E> - Class in org.apache.cassandra.utils.concurrent
A simple append-only collection supporting an unbounded number of concurrent readers/writers, but a bounded number of items.
Accumulator(int) - Constructor for class org.apache.cassandra.utils.concurrent.Accumulator
 
ackCount() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
ackCount() - Method in class org.apache.cassandra.service.BatchlogResponseHandler
 
ackCount() - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
ackCount() - Method in class org.apache.cassandra.service.WriteResponseHandler
 
ackMutation() - Method in class org.apache.cassandra.service.BatchlogResponseHandler.BatchlogCleanup
 
acquire(int) - Method in class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
 
acquire(double) - Method in class org.apache.cassandra.utils.TestRateLimiter
Acquires a single unit at the given rate.
acquireCapacity(ResourceLimits.Limit, ResourceLimits.Limit, int, long, long) - Method in class org.apache.cassandra.net.AbstractMessageHandler
Try to acquire permits for the inbound message.
acquireCapacity(ResourceLimits.Limit, ResourceLimits.Limit, int) - Method in class org.apache.cassandra.net.AbstractMessageHandler
 
acquireLockFor(int) - Static method in class org.apache.cassandra.db.view.ViewManager
 
acquireReference() - Method in class org.apache.cassandra.tracing.TraceState
 
AcquisitionCallable(ColumnFamilyStore, Collection<Range<Token>>, UUID, int, int) - Constructor for class org.apache.cassandra.db.repair.PendingAntiCompaction.AcquisitionCallable
 
activate(FrameDecoder.FrameProcessor) - Method in class org.apache.cassandra.net.FrameDecoder
For use by InboundMessageHandler (or other upstream handlers) that want to start receiving frames.
activate() - Method in class org.apache.cassandra.service.CassandraDaemon
A convenience method to initialize and start the daemon in one shot.
active - Variable in class org.apache.cassandra.db.compaction.CompactionManager
 
ACTIVE_TASKS - Static variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
 
ActiveCompactions - Class in org.apache.cassandra.db.compaction
 
ActiveCompactions() - Constructor for class org.apache.cassandra.db.compaction.ActiveCompactions
 
ActiveCompactionsTracker - Interface in org.apache.cassandra.db.compaction
 
activeDeletion() - Method in class org.apache.cassandra.db.rows.RangeTombstoneMarker.Merger
 
ActiveRepairService - Class in org.apache.cassandra.service
ActiveRepairService is the starting point for manual "active" repairs.
ActiveRepairService(IFailureDetector, Gossiper) - Constructor for class org.apache.cassandra.service.ActiveRepairService
 
ActiveRepairService.ConsistentSessions - Class in org.apache.cassandra.service
 
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.ParentRepairStatus - Enum in org.apache.cassandra.service
 
ActiveRepairService.RepairCommandExecutorHandle - Class in org.apache.cassandra.service
 
ActiveRepairServiceMBean - Interface in org.apache.cassandra.service
 
activeStreamsOutbound - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
Deprecated.
activeTasks - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
Number of active tasks.
add(String) - Method in class org.apache.cassandra.auth.DCPermissions.Builder
 
add(ColumnCondition) - Method in class org.apache.cassandra.cql3.conditions.ColumnConditions.Builder
Adds the specified ColumnCondition to this set of conditions.
add(int, int) - Method in class org.apache.cassandra.cql3.functions.types.LocalDate
Return a new LocalDate with the specified (signed) amount of time added to (or subtracted from) the given Calendar field, based on the calendar's rules.
add(Operation) - Method in class org.apache.cassandra.cql3.Operations
Adds the specified Operation to this set of operations.
add(Restrictions) - Method in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
 
add(CustomIndexExpression) - Method in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
 
add(ByteBuffer) - Method in class org.apache.cassandra.cql3.selection.ResultSetBuilder
 
add(Cell<?>, int) - Method in class org.apache.cassandra.cql3.selection.ResultSetBuilder
 
add(ColumnIdentifier, CQL3Type.Raw, boolean) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
 
add(FieldIdentifier, CQL3Type.Raw) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTypeStatement.Raw
 
add(int, ColumnSpecification) - Method in class org.apache.cassandra.cql3.VariableSpecifications
 
add(Relation) - Method in class org.apache.cassandra.cql3.WhereClause.Builder
 
add(CustomIndexExpression) - Method in class org.apache.cassandra.cql3.WhereClause.Builder
 
add(ByteBuffer) - Method in class org.apache.cassandra.db.CBuilder
 
add(ClusteringPrefix<V>, int) - Method in class org.apache.cassandra.db.CBuilder
 
add(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.CBuilder
 
add(Object) - Method in class org.apache.cassandra.db.CBuilder
 
add(Mutation) - Method in class org.apache.cassandra.db.commitlog.CommitLog
Add a Mutation to the commit log.
add(T, T) - Method in class org.apache.cassandra.db.commitlog.IntervalSet.Builder
Add an interval to the set and perform normalization.
add(ColumnMetadata) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Builder
 
add(ColumnMetadata, Operator, ByteBuffer) - Method in class org.apache.cassandra.db.filter.RowFilter
 
add(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteType
 
add(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
add(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
add(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
add(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
 
add(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
add(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
add(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
 
add(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.NumberType
Adds the left argument to the right one.
add(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ShortType
 
add(DeletionTime) - Method in class org.apache.cassandra.db.MutableDeletionInfo
Potentially replaces the top-level tombstone with another, keeping whichever has the higher markedForDeleteAt timestamp.
add(RangeTombstone, ClusteringComparator) - Method in class org.apache.cassandra.db.MutableDeletionInfo
 
add(DeletionInfo) - Method in class org.apache.cassandra.db.MutableDeletionInfo
Combines another DeletionInfo with this one and returns the result.
add(RangeTombstoneMarker) - Method in class org.apache.cassandra.db.MutableDeletionInfo.Builder
 
add(PartitionUpdate) - Method in class org.apache.cassandra.db.Mutation.PartitionUpdateCollector
 
add(Row) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
Adds a row to this update.
add(RangeTombstone) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
 
add(RangeTombstone) - Method in class org.apache.cassandra.db.RangeTombstoneList
 
add(ClusteringBound<?>, ClusteringBound<?>, long, int) - Method in class org.apache.cassandra.db.RangeTombstoneList
Adds a new range tombstone.
add(ColumnMetadata) - Method in class org.apache.cassandra.db.RegularAndStaticColumns.Builder
 
add(int, RangeTombstoneMarker) - Method in class org.apache.cassandra.db.rows.RangeTombstoneMarker.Merger
 
add(int, Row) - Method in class org.apache.cassandra.db.rows.Row.Merger
 
add(String, Object) - Method in interface org.apache.cassandra.db.rows.Row.SimpleBuilder
Adds a value to a given column.
add(String, Object) - Method in class org.apache.cassandra.db.SimpleBuilders.RowBuilder
 
add(ClusteringBound<?>, ClusteringBound<?>) - Method in class org.apache.cassandra.db.Slices.Builder
 
add(Slice) - Method in class org.apache.cassandra.db.Slices.Builder
 
add(View) - Method in class org.apache.cassandra.db.view.TableViews
 
add(String, FilterPipelineTask<?, ?>) - Method in class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineBuilder
 
add(SSTableIndex) - Method in class org.apache.cassandra.index.sasi.conf.view.TermTree.Builder
 
add(TokenTreeBuilder) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
 
add(Long, AbstractTokenTreeBuilder.InteriorNode, AbstractTokenTreeBuilder.InteriorNode) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
 
add(AbstractTokenTreeBuilder.Leaf) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
 
add(Long, long) - Method in class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
 
add(Iterator<Pair<Long, LongSet>>) - Method in class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
 
add(SortedMap<Long, LongSet>) - Method in class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
 
add(ByteBuffer, DecoratedKey, long) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
 
add(ByteBuffer, DecoratedKey, long) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
 
add(Long, long) - Method in class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
 
add(SortedMap<Long, LongSet>) - Method in class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
 
add(Iterator<Pair<Long, LongSet>>) - Method in class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
 
add(Long, long) - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
add(SortedMap<Long, LongSet>) - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
add(Iterator<Pair<Long, LongSet>>) - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
add(TokenTreeBuilder) - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
add(DecoratedKey, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.memory.MemIndex
 
add(DecoratedKey, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.memory.SkipListMemIndex
 
add(DecoratedKey, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.memory.TrieMemIndex
 
add(Operator, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.plan.Expression
 
add(RowFilter.Expression) - Method in class org.apache.cassandra.index.sasi.plan.Operation.Builder
 
add(Collection<RowFilter.Expression>) - Method in class org.apache.cassandra.index.sasi.plan.Operation.Builder
 
add(ByteBuffer, TokenTreeBuilder) - Method in class org.apache.cassandra.index.sasi.sa.SA
 
add(RangeIterator<K, D>) - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
 
add(List<RangeIterator<K, D>>) - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
 
add(Replica) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
 
add(Replica, ReplicaCollection.Builder.Conflict) - Method in class org.apache.cassandra.locator.EndpointsForRange.Builder
 
add(Replica, ReplicaCollection.Builder.Conflict) - Method in class org.apache.cassandra.locator.EndpointsForToken.Builder
 
add(Replica) - Method in class org.apache.cassandra.locator.RangesAtEndpoint.Builder
 
add(Replica, ReplicaCollection.Builder.Conflict) - Method in class org.apache.cassandra.locator.RangesAtEndpoint.Builder
 
add(Replica, ReplicaCollection.Builder.Conflict) - Method in interface org.apache.cassandra.locator.ReplicaCollection.Builder
 
add(Replica) - Method in interface org.apache.cassandra.locator.ReplicaCollection.Builder
 
add(Predicate<Message<?>>) - Method in class org.apache.cassandra.net.InboundSink
 
add(InetAddressAndPort, long, TimeUnit) - Method in class org.apache.cassandra.net.LatencySubscribers
 
add(BiPredicate<Message<?>, InetAddressAndPort>) - Method in class org.apache.cassandra.net.OutboundSink
 
add(InetAddressAndPort, Collection<Range<Token>>) - Method in class org.apache.cassandra.repair.asymmetric.HostDifferences
Adds a set of differences between the node this instance is tracking and endpoint
add(InetAddressAndPort) - Method in class org.apache.cassandra.repair.asymmetric.StreamFromOptions
Add new node to the stream options If we have no difference between the new node and a currently tracked on, we know they are matching over the range we are tracking, then just add it to the set with the identical remote nodes.
add(CleanupSummary, CleanupSummary) - Static method in class org.apache.cassandra.repair.consistent.admin.CleanupSummary
 
add(Collection<Range<Token>>, long) - Method in class org.apache.cassandra.repair.consistent.RepairedState
 
add(UnfilteredRowIterator) - Method in class org.apache.cassandra.repair.Validator
Called (in order) for every row present in the CF.
add(Function) - Method in class org.apache.cassandra.schema.Functions.Builder
 
add(Function...) - Method in class org.apache.cassandra.schema.Functions.Builder
 
add(Iterable<? extends Function>) - Method in class org.apache.cassandra.schema.Functions.Builder
 
add(IndexMetadata) - Method in class org.apache.cassandra.schema.Indexes.Builder
 
add(IndexMetadata...) - Method in class org.apache.cassandra.schema.Indexes.Builder
 
add(Iterable<IndexMetadata>) - Method in class org.apache.cassandra.schema.Indexes.Builder
 
add(KeyspaceMetadata) - Method in class org.apache.cassandra.schema.Keyspaces.Builder
 
add(KeyspaceMetadata...) - Method in class org.apache.cassandra.schema.Keyspaces.Builder
 
add(Iterable<KeyspaceMetadata>) - Method in class org.apache.cassandra.schema.Keyspaces.Builder
 
add(TableMetadata) - Method in class org.apache.cassandra.schema.Tables.Builder
 
add(TableMetadata...) - Method in class org.apache.cassandra.schema.Tables.Builder
 
add(Iterable<TableMetadata>) - Method in class org.apache.cassandra.schema.Tables.Builder
 
add(TriggerMetadata) - Method in class org.apache.cassandra.schema.Triggers.Builder
 
add(TriggerMetadata...) - Method in class org.apache.cassandra.schema.Triggers.Builder
 
add(Iterable<TriggerMetadata>) - Method in class org.apache.cassandra.schema.Triggers.Builder
 
add(UserType) - Method in class org.apache.cassandra.schema.Types.Builder
 
add(UserType...) - Method in class org.apache.cassandra.schema.Types.Builder
 
add(Iterable<UserType>) - Method in class org.apache.cassandra.schema.Types.Builder
 
add(String, List<String>, List<String>) - Method in class org.apache.cassandra.schema.Types.RawBuilder
 
add(String...) - Method in class org.apache.cassandra.tools.nodetool.formatter.TableBuilder
 
add(String, String, Map<InetAddress, Float>) - Method in class org.apache.cassandra.tools.nodetool.SetHostStat
 
add(String, String, Map<String, Float>) - Method in class org.apache.cassandra.tools.nodetool.SetHostStatWithPort
 
add(ColumnFamilyStoreMBean) - Method in class org.apache.cassandra.tools.nodetool.stats.StatsKeyspace
 
add(IFilter.FilterKey) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
 
add(IFilter.FilterKey) - Method in class org.apache.cassandra.utils.BloomFilter
 
add(V) - Method in class org.apache.cassandra.utils.btree.BTree.Builder
 
add(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
add(int, V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
add(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet.Builder
 
add(E) - Method in class org.apache.cassandra.utils.concurrent.Accumulator
Adds an item to the collection.
add(Ref<?>) - Method in class org.apache.cassandra.utils.concurrent.Ref.IdentityCollection
 
add(SelfRefCounted<?>) - Method in class org.apache.cassandra.utils.concurrent.Ref.IdentityCollection
 
add(SharedCloseable) - Method in class org.apache.cassandra.utils.concurrent.Ref.IdentityCollection
 
add(SharedCloseableImpl) - Method in class org.apache.cassandra.utils.concurrent.Ref.IdentityCollection
 
add(Memory) - Method in class org.apache.cassandra.utils.concurrent.Ref.IdentityCollection
 
add(T) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
add(long) - Method in class org.apache.cassandra.utils.EstimatedHistogram
Increments the count of the bucket closest to n, rounding UP.
add(long, long) - Method in class org.apache.cassandra.utils.EstimatedHistogram
Increments the count of the bucket closest to n, rounding UP by delta
add(long) - Method in class org.apache.cassandra.utils.HistogramBuilder
 
add(IFilter.FilterKey) - Method in interface org.apache.cassandra.utils.IFilter
 
add(int, int) - Method in class org.apache.cassandra.utils.IntegerInterval.Set
Adds an interval to the set, performing the necessary normalization.
addAll(IntervalSet<T>) - Method in class org.apache.cassandra.db.commitlog.IntervalSet.Builder
 
addAll(Iterable<ColumnMetadata>) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Builder
 
addAll(RangeTombstoneList) - Method in class org.apache.cassandra.db.RangeTombstoneList
Adds all the range tombstones of tombstones to this RangeTombstoneList.
addAll(Iterable<ColumnMetadata>) - Method in class org.apache.cassandra.db.RegularAndStaticColumns.Builder
 
addAll(RegularAndStaticColumns) - Method in class org.apache.cassandra.db.RegularAndStaticColumns.Builder
 
addAll(Slices) - Method in class org.apache.cassandra.db.Slices.Builder
 
addAll(Iterable<Replica>, ReplicaCollection.Builder.Conflict) - Method in interface org.apache.cassandra.locator.ReplicaCollection.Builder
 
addAll(Iterable<Replica>) - Method in interface org.apache.cassandra.locator.ReplicaCollection.Builder
 
addAll(Collection<V>) - Method in class org.apache.cassandra.utils.btree.BTree.Builder
 
addAll(Collection<? extends V>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
addAll(int, Collection<? extends V>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
addAll(Collection<V>) - Method in class org.apache.cassandra.utils.btree.BTreeSet.Builder
 
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(Collection<? extends T>) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
addAll(Iterator<MerkleTree.RowHash>) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
addAllElementsToAll(List<List<ByteBuffer>>) - Method in class org.apache.cassandra.db.MultiCBuilder
Adds individually each of the specified list of elements to the end of all of the existing composites.
addAllWithSizeDelta(PartitionUpdate, OpOrder.Group, UpdateTransaction) - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
Adds a given update to this in-memtable partition.
addAndGetIndex(ColumnMetadata, List<ColumnMetadata>) - Method in interface org.apache.cassandra.cql3.selection.Selectable
 
addApplicationState(ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.EndpointState
 
addApplicationStates(Map<ApplicationState, VersionedValue>) - Method in class org.apache.cassandra.gms.EndpointState
 
addApplicationStates(Set<Map.Entry<ApplicationState, VersionedValue>>) - Method in class org.apache.cassandra.gms.EndpointState
 
addBaseTableUpdate(Row, Row) - Method in class org.apache.cassandra.db.view.ViewUpdateGenerator
Adds to this generator the updates to be made to the view given a base table row before and after an update.
addBootstrapToken(Token, InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
Deprecated.
addBootstrapTokens(Collection<Token>, InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
 
addCDCSize(long) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerCDC
For use after replay when replayer hard-links / adds tracking of replayed segments
addCell(ColumnMetadata, ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
addCell(ColumnMetadata, CellPath, ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
addCell(Cell<?>) - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
 
addCell(Cell<?>) - Method in class org.apache.cassandra.db.rows.ComplexColumnData.Builder
 
addCell(Cell<?>) - Method in interface org.apache.cassandra.db.rows.Row.Builder
Adds a cell to this builder.
addCellPerPartitionCount(long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
addClassPath(File) - Method in class org.apache.cassandra.triggers.CustomClassLoader
 
addClusteringColumn(String, AbstractType) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
addClusteringColumn(ColumnIdentifier, AbstractType) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
addCmdOption(String, String, boolean, String) - Static method in class org.apache.cassandra.tools.AbstractJmxClient
 
addColumn(ColumnIdentifier, CQL3Type.Raw, boolean) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
 
addColumn(ColumnMetadata) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
addColumnMapping(SelectionColumnMapping, ColumnSpecification) - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Record a mapping between the ColumnDefinitions that are used by the selector instances created by this factory and a column in the ResultSet.Metadata returned with a query.
addColumnMapping(SelectionColumnMapping, ColumnSpecification) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector.SimpleSelectorFactory
 
addColumns(Iterable<ColumnMetadata>) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
addColumnSpecifications(QueryOptions, List<ColumnSpecification>) - Static method in class org.apache.cassandra.cql3.QueryOptions
 
addColumnValue(ByteBuffer) - Method in class org.apache.cassandra.cql3.ResultSet
 
addComplexDeletion(ColumnMetadata, DeletionTime) - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
 
addComplexDeletion(DeletionTime) - Method in class org.apache.cassandra.db.rows.ComplexColumnData.Builder
 
addComplexDeletion(ColumnMetadata, DeletionTime) - Method in interface org.apache.cassandra.db.rows.Row.Builder
Adds a complex deletion.
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
addConditions(Clustering<?>, Collection<ColumnCondition>, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
 
addConditions(Clustering<?>, CQL3CasRequest, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
addConditionsTo(CQL3CasRequest, Clustering<?>, QueryOptions) - Method in class org.apache.cassandra.cql3.conditions.ColumnConditions
Adds the conditions to the specified CAS request.
addConditionsTo(CQL3CasRequest, Clustering<?>, QueryOptions) - Method in interface org.apache.cassandra.cql3.conditions.Conditions
Adds the conditions to the specified CAS request.
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(ColumnMetadata, long) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
addCustomIndexExpression(TableMetadata, IndexMetadata, ByteBuffer) - Method in class org.apache.cassandra.db.filter.RowFilter
 
addDisallowedClass(String) - Method in class org.apache.cassandra.cql3.functions.UDFByteCodeVerifier
 
addDisallowedMethodCall(String, String) - Method in class org.apache.cassandra.cql3.functions.UDFByteCodeVerifier
 
addDisallowedPackage(String) - Method in class org.apache.cassandra.cql3.functions.UDFByteCodeVerifier
 
addDuration(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TemporalType
Adds the duration to the specified value.
addDuration(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
addEachElementToAll(List<ByteBuffer>) - Method in class org.apache.cassandra.db.MultiCBuilder
Adds individually each of the specified elements to the end of all of the existing clusterings.
added - Variable in class org.apache.cassandra.notifications.InitialSSTableAddedNotification
true if the addition corresponds to the ColumnFamilyStore initialization, then the sstables are those loaded at startup.
added - Variable in class org.apache.cassandra.notifications.SSTableAddedNotification
The added SSTables
added - Variable in class org.apache.cassandra.notifications.SSTableListChangedNotification
 
addElementToAll(ByteBuffer) - Method in class org.apache.cassandra.db.MultiCBuilder
Adds the specified element to all the clusterings.
Adder(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Adder
 
Adder(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Adder
 
addEventListener(StreamEventHandler) - Method in class org.apache.cassandra.streaming.StreamResultFuture
 
addExclusion(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.plan.Expression
 
addExist(Clustering<?>) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
 
addExpireTimeForEndpoint(InetAddressAndPort, long) - Method in class org.apache.cassandra.gms.Gossiper
 
addExpireTimeIfFound(InetAddressAndPort, long) - Method in class org.apache.cassandra.service.StorageService
 
addFailedSnapshot(File) - Static method in class org.apache.cassandra.io.sstable.SnapshotDeletingTask
 
addFalsePositive() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
addFetchedColumns(ColumnFilter.Builder) - Method in class org.apache.cassandra.cql3.selection.Selector
Add to the provided builder the column (and potential subselections) to fetch for this selection.
addFetchedColumns(ColumnFilter.Builder) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
 
addFetchedColumns(ColumnFilter.Builder) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector.SimpleSelectorFactory
 
addFetchedColumns(ColumnFilter.Builder) - Method in class org.apache.cassandra.cql3.selection.TermSelector
 
addField(FieldIdentifier, CQL3Type.Raw) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTypeStatement.Raw
 
addFunctions(Iterable<Term>, List<Function>) - Static method in interface org.apache.cassandra.cql3.Terms
Adds all functions (native and user-defined) of the specified terms to the list.
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.AbstractMarker
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.Attributes
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.conditions.ColumnCondition
Adds functions for the bind variables of this operation.
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.conditions.ColumnConditions
 
addFunctionsTo(List<Function>) - Method in interface org.apache.cassandra.cql3.conditions.Conditions
Adds the functions used by the conditions to the specified list.
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
addFunctionsTo(List<Function>) - Method in interface org.apache.cassandra.cql3.functions.Function
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.functions.FunctionCall
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.Lists.DelayedValue
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.Maps.DelayedValue
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.Operation
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.Operations
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithMarker
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithValues
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.NotNullRestriction
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
 
addFunctionsTo(List<Function>) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Adds all functions (native and user-defined) used by any component of the restriction to the specified list.
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQRestriction
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithMarker
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithValues
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IsNotNullRestriction
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQRestriction
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.SliceRestriction
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.selection.Selection
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.Sets.DelayedValue
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
addFunctionsTo(List<Function>) - Method in interface org.apache.cassandra.cql3.Term
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.Term.Terminal
 
addFunctionsTo(List<Function>) - Method in interface org.apache.cassandra.cql3.Terms
Adds all functions (native and user-defined) used by any of the terms to the specified list.
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.Tuples.DelayedValue
 
addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.UserTypes.DelayedValue
 
addHash(MerkleTree.RowHash) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
addHistogram(long[], long[]) - Static method in class org.apache.cassandra.metrics.TableMetrics
 
addIncomingRangeFrom(Range<Token>, InetAddressAndPort) - Method in class org.apache.cassandra.repair.asymmetric.IncomingRepairStreamTracker
Adds a range to be streamed from streamFromNode First the currently tracked ranges are denormalized to make sure that no ranges overlap, then the streamFromNode is added to the StreamFromOptions for the range
addIndex(SSTableIndex) - Method in class org.apache.cassandra.index.sasi.conf.view.PrefixTermTree.Builder
 
addIndex(SSTableIndex) - Method in class org.apache.cassandra.index.sasi.conf.view.TermTree.Builder
 
addIndex(IndexMetadata, boolean) - Method in class org.apache.cassandra.index.SecondaryIndexManager
Adds and builds a index
addIndexClusteringColumns(TableMetadata.Builder, TableMetadata, ColumnMetadata) - Method in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
Add the clustering columns for a specific type of index table to the a TableMetadata.Builder (which is being used to construct the index table's TableMetadata.
addIndexClusteringColumns(TableMetadata.Builder, TableMetadataRef, ColumnMetadata) - Method in class org.apache.cassandra.index.internal.keys.KeysIndex
 
addInitialSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
addInitialSSTablesWithoutUpdatingSize(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
addInput(ProtocolVersion, List<ByteBuffer>) - Method in interface org.apache.cassandra.cql3.functions.AggregateFunction.Aggregate
Adds the specified input to this aggregate.
addInput(ProtocolVersion, ResultSetBuilder) - Method in class org.apache.cassandra.cql3.selection.Selector
Add the current value from the specified ResultSetBuilder.
addInput(ProtocolVersion, ResultSetBuilder) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
 
addInput(ProtocolVersion, ResultSetBuilder) - Method in class org.apache.cassandra.cql3.selection.TermSelector
 
addInputRow(ResultSetBuilder) - Method in interface org.apache.cassandra.cql3.selection.Selection.Selectors
Adds the current row of the specified ResultSetBuilder.
Addition(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.Addition
 
additionalHeaderParameters() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
Provide any additional header data that should be stored in the CommitLogDescriptor.
additionalHeaderParameters() - Method in class org.apache.cassandra.db.commitlog.EncryptedSegment
 
additionalWriteLatencyNanos - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
additionalWriteLatencyNanos - Variable in class org.apache.cassandra.metrics.TableMetrics
 
additionalWritePolicy(SpeculativeRetryPolicy) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
additionalWritePolicy - Variable in class org.apache.cassandra.schema.TableParams
 
additionalWritePolicy(SpeculativeRetryPolicy) - Method in class org.apache.cassandra.schema.TableParams.Builder
 
additionalWrites - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Needed to write to a transient replica to satisfy quorum
additionalWrites - Variable in class org.apache.cassandra.metrics.TableMetrics
 
addKey(ByteBuffer) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
addLeavingEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
 
addListener(GenericFutureListener<? extends Future<? super Void>>) - Method in class org.apache.cassandra.net.AsyncChannelPromise
 
addListener(GenericFutureListener<? extends Future<? super V>>) - Method in class org.apache.cassandra.net.AsyncPromise
 
addListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in class org.apache.cassandra.net.AsyncChannelPromise
 
addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class org.apache.cassandra.net.AsyncPromise
 
addLocalApplicationState(ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.Gossiper
 
addLocalApplicationStates(List<Pair<ApplicationState, VersionedValue>>) - Method in class org.apache.cassandra.gms.Gossiper
 
addMapEquality(ColumnMetadata, ByteBuffer, Operator, ByteBuffer) - Method in class org.apache.cassandra.db.filter.RowFilter
 
addMapping(ColumnSpecification, ColumnMetadata) - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
addMapping(ColumnSpecification, Iterable<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
addMerkleTree(int, Range<Token>) - Method in class org.apache.cassandra.utils.MerkleTrees
Add a MerkleTree with the defined size and range.
addMerkleTree(int, byte, Range<Token>) - Method in class org.apache.cassandra.utils.MerkleTrees
 
addMerkleTrees(int, Collection<Range<Token>>) - Method in class org.apache.cassandra.utils.MerkleTrees
Add merkle tree's with the defined maxsize and ranges.
addMovingEndpoint(Token, InetAddressAndPort) - 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
addNonSerializedColumns(Collection<? extends ColumnSpecification>) - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
Adds the specified columns which will not be serialized.
addNonShadowed(Cell<?>, Cell<?>, DeletionTime, Row.Builder) - Static method in class org.apache.cassandra.db.rows.Cells
Adds to the builder a representation of the given existing cell that, when merged/reconciled with the given update cell, produces the same result as merging the original with the update.
addNonShadowedComplex(ColumnMetadata, Iterator<Cell<?>>, Iterator<Cell<?>>, DeletionTime, Row.Builder) - Static method in class org.apache.cassandra.db.rows.Cells
Adds to the builder a representation of the given existing cell that, when merged/reconciled with the given update cell, produces the same result as merging the original with the update.
addNotExist(Clustering<?>) - 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
 
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
addOptionList(String, String, String, String) - Method in class org.apache.cassandra.tools.BulkLoader.CmdLineOptions
Add option with argument and argument name that accepts being defined multiple times as a list
addPartitionDeletion(DeletionTime) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
 
addPartitionKeyColumn(String, AbstractType) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
addPartitionKeyColumn(ColumnIdentifier, AbstractType) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
addPartitionSizeInBytes(long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
addPendingRange(Range<Token>, Replica) - Method in class org.apache.cassandra.locator.PendingRangeMaps
 
addPostShutdownHook(Runnable) - Method in class org.apache.cassandra.service.StorageService
Add a runnable which will be called after shutdown or drain.
addPreShutdownHook(Runnable) - Method in class org.apache.cassandra.service.StorageService
Add a runnable which will be called before shut down or drain.
addPrimaryKeyLivenessInfo() - Method in class org.apache.cassandra.cql3.UpdateParameters
 
addPrimaryKeyLivenessInfo(LivenessInfo) - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
 
addPrimaryKeyLivenessInfo(LivenessInfo) - Method in interface org.apache.cassandra.db.rows.Row.Builder
Adds the liveness information for the partition key columns of this row.
addProgressListener(ProgressListener) - Method in class org.apache.cassandra.repair.RepairRunnable
 
addProgressListener(ProgressListener) - Method in class org.apache.cassandra.tracing.TraceState
 
addProgressListener(ProgressListener) - Method in interface org.apache.cassandra.utils.progress.ProgressEventNotifier
Register progress listener to this publisher.
addProgressListener(ProgressListener) - Method in class org.apache.cassandra.utils.progress.ProgressEventNotifierSupport
 
addProperty(String, String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
addProperty(String, Map<String, String>) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
addRangeForEndpoint(Range<Token>, InetAddressAndPort) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
 
addRanges(String, ReplicaCollection<?>) - Method in class org.apache.cassandra.dht.RangeStreamer
Add ranges to be streamed for given keyspace.
addRangeTombstone() - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder
Adds a new range tombstone to this update, returning a builder for that range.
addRangeTombstone(RangeTombstone) - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder
Adds a new range tombstone to this update
addRangeTombstone() - Method in class org.apache.cassandra.db.SimpleBuilders.PartitionUpdateBuilder
 
addRangeTombstone(RangeTombstone) - Method in class org.apache.cassandra.db.SimpleBuilders.PartitionUpdateBuilder
 
addRegularColumn(String, AbstractType) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
addRegularColumn(ColumnIdentifier, AbstractType) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
addReplaceTokens(Collection<Token>, InetAddressAndPort, InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
 
address - Variable in class org.apache.cassandra.dht.BootStrapper
 
address - Variable in class org.apache.cassandra.locator.InetAddressAndPort
 
address - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
 
ADDRESS - Static variable in class org.apache.cassandra.transport.ConnectedClient
 
addressBytes - Variable in class org.apache.cassandra.locator.InetAddressAndPort
 
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.
addRowDeletion() - Method in class org.apache.cassandra.cql3.UpdateParameters
 
addRowDeletion(Row.Deletion) - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
 
addRowDeletion(Row.Deletion) - Method in interface org.apache.cassandra.db.rows.Row.Builder
Adds the deletion information for this row.
addRowFilterTo(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
 
addRowFilterTo(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.INRestriction
 
addRowFilterTo(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.NotNullRestriction
 
addRowFilterTo(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
 
addRowFilterTo(RowFilter, IndexRegistry, QueryOptions) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Adds to the specified row filter the expressions corresponding to this Restriction.
addRowFilterTo(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
 
addRowFilterTo(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQRestriction
 
addRowFilterTo(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.INRestriction
 
addRowFilterTo(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IsNotNullRestriction
 
addRowFilterTo(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
 
addRowFilterTo(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
 
addRowFilterTo(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
addSample(T, int) - Method in class org.apache.cassandra.metrics.Sampler
 
addSavedEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
Add an endpoint we knew about previously, but whose state is unknown
addSessionInfo(StreamSession) - Method in class org.apache.cassandra.streaming.messages.StreamMessageHeader
 
addSessionInfo(SessionInfo) - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
addSingleRange(InetAddressAndPort, Range<Token>) - Method in class org.apache.cassandra.repair.asymmetric.HostDifferences
 
addSourceFilter(RangeStreamer.SourceFilter) - 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
Adds sstable, note that implementations must handle duplicate notifications here (added already being in the compaction strategy)
addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
Deprecated.
 
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.TimeWindowCompactionStrategy
 
addSSTable(SSTableReader) - Method in class org.apache.cassandra.repair.consistent.admin.PendingStat.Builder
 
addSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
addSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
Adds sstables, note that implementations must handle duplicate notifications here (added already being in the compaction strategy)
addSSTables(AbstractStrategyHolder.GroupedSSTableContainer) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
 
addSSTables(AbstractStrategyHolder.GroupedSSTableContainer) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
addSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
addSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
addSSTables(AbstractStrategyHolder.GroupedSSTableContainer) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
addSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
addStat(PendingStat) - Method in class org.apache.cassandra.repair.consistent.admin.PendingStat.Builder
 
addStaticColumn(String, AbstractType) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
addStaticColumn(ColumnIdentifier, AbstractType) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
addStreamRequest(String, RangesAtEndpoint, RangesAtEndpoint, Collection<String>) - Method in class org.apache.cassandra.streaming.StreamSession
Request data fetch task to this session.
addTask(AbstractLocalAwareExecutorService.FutureTask<?>) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
addTask(AbstractLocalAwareExecutorService.FutureTask<?>) - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
addTo(long) - Method in class org.apache.cassandra.cql3.Duration
Adds this duration to the specified time in milliseconds.
addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.io.compress.CompressionMetadata
 
addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.io.util.FileHandle
 
addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.io.util.SafeMemory
 
addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
 
addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.utils.BloomFilter
 
addTo(Ref.IdentityCollection) - Method in interface org.apache.cassandra.utils.concurrent.SharedCloseable
 
addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
 
addTo(Ref.IdentityCollection) - Method in interface org.apache.cassandra.utils.obs.IBitSet
 
addTo(Ref.IdentityCollection) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
addToContacts(Replica) - Method in interface org.apache.cassandra.locator.ReplicaPlan.Shared
add the provided replica to this shared plan, by updating the internal reference
addToContacts(Replica) - Method in class org.apache.cassandra.locator.ReplicaPlan.SharedForRangeRead
 
addToContacts(Replica) - Method in class org.apache.cassandra.locator.ReplicaPlan.SharedForTokenRead
 
addToCountPerDc(ObjectIntHashMap<String>, Iterable<Replica>, int) - Static method in class org.apache.cassandra.locator.Replicas
increment each of the map's DC entries for each matching replica provided
addTombstone(ColumnMetadata) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
addTombstone(ColumnMetadata, CellPath) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
addToRawBuilder(Types.RawBuilder) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTypeStatement.Raw
 
addToRowFilter(RowFilter, TableMetadata, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.CustomIndexExpression
 
addToTotalBytesCompacted(long) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
 
addToVersion(int) - Method in enum org.apache.cassandra.transport.Message.Direction
 
addTraceHeaders(Map<ParamType, Object>) - Method in class org.apache.cassandra.tracing.Tracing
 
addTransferStream(OutgoingStream) - Method in class org.apache.cassandra.streaming.StreamTransferTask
 
addTrueNegative() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
addTruePositive() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
addUnit(Unit, int) - Method in class org.apache.cassandra.dht.tokenallocator.NoReplicationTokenAllocator
 
addUnit(Unit, int) - Method in interface org.apache.cassandra.dht.tokenallocator.TokenAllocator
 
addUpdateForKey(PartitionUpdate.Builder, Clustering<?>, UpdateParameters) - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
 
addUpdateForKey(PartitionUpdate.Builder, Slice, UpdateParameters) - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
 
addUpdateForKey(PartitionUpdate.Builder, Clustering<?>, UpdateParameters) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
addUpdateForKey(PartitionUpdate.Builder, Slice, UpdateParameters) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
addUpdateForKey(PartitionUpdate.Builder, Clustering<?>, UpdateParameters) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
 
addUpdateForKey(PartitionUpdate.Builder, Slice, UpdateParameters) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
 
addUserExpression(RowFilter.UserExpression) - Method in class org.apache.cassandra.db.filter.RowFilter
 
addView(ViewMetadata) - Method in class org.apache.cassandra.db.view.ViewManager
 
addWithExpiration(AbstractWriteResponseHandler<?>, Message<?>, Replica, ConsistencyLevel, boolean) - Method in class org.apache.cassandra.net.RequestCallbacks
 
adjust(long, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator.SubAllocator
Like allocate, but permits allocations to be negative.
adjustPoolSize() - Method in class org.apache.cassandra.db.compaction.CompactionManager.ValidationExecutor
 
adopt() - Method in class org.apache.cassandra.net.BufferPoolAllocator.Wrapped
 
advance() - Method in class org.apache.cassandra.utils.MergeIterator.Candidate
 
advertiseRemoving(InetAddressAndPort, 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(InetAddressAndPort, 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 class org.apache.cassandra.cql3.Operation.FieldDeletion
 
affectedColumn() - Method in interface org.apache.cassandra.cql3.Operation.RawDeletion
The name of the column affected by this delete operation.
after - Variable in class org.apache.cassandra.schema.Diff.Altered
 
after - Variable in class org.apache.cassandra.schema.KeyspaceMetadata.KeyspaceDiff
 
afterExecute(Runnable, Throwable) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
 
afterExecute(Runnable, Throwable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
aggregate(String, String) - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
Creates a DescribeStatement for DESCRIBE FUNCTION.
AGGREGATE_EVERYTHING - Static variable in class org.apache.cassandra.db.aggregation.AggregationSpecification
AggregationSpecification that group all the row together.
AggregateFcts - Class in org.apache.cassandra.cql3.functions
Factory methods for aggregate functions.
AggregateFcts() - Constructor for class org.apache.cassandra.cql3.functions.AggregateFcts
 
AggregateFunction - Interface in org.apache.cassandra.cql3.functions
Performs a calculation on a set of values and return a single value.
AggregateFunction.Aggregate - Interface in org.apache.cassandra.cql3.functions
An aggregation operation.
aggregatePkPrefix(ClusteringComparator, int) - Static method in class org.apache.cassandra.db.aggregation.AggregationSpecification
Creates a new AggregationSpecification instance that will build aggregates based on primary key columns.
aggregates() - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
Creates a DescribeStatement for DESCRIBE AGGREGATES.
AGGREGATES - Static variable in class org.apache.cassandra.schema.SchemaKeyspace
 
aggregatesUsingFunction(Function) - Method in class org.apache.cassandra.schema.Functions
 
AggregationPartitionIterator(int, ConsistencyLevel, ClientState, long) - Constructor for class org.apache.cassandra.service.pager.AggregationQueryPager.AggregationPartitionIterator
 
AggregationPartitionIterator(int, ReadExecutionController, long) - Constructor for class org.apache.cassandra.service.pager.AggregationQueryPager.AggregationPartitionIterator
 
AggregationQueryPager - Class in org.apache.cassandra.service.pager
QueryPager that takes care of fetching the pages for aggregation queries.
AggregationQueryPager(QueryPager, DataLimits) - Constructor for class org.apache.cassandra.service.pager.AggregationQueryPager
 
AggregationQueryPager.AggregationPartitionIterator - Class in org.apache.cassandra.service.pager
PartitionIterator for queries without Group By but with aggregates.
AggregationQueryPager.GroupByPartitionIterator - Class in org.apache.cassandra.service.pager
PartitionIterator that automatically fetch a new sub-page of data if needed when the current iterator is exhausted.
AggregationSpecification - Class in org.apache.cassandra.db.aggregation
Defines how rows should be grouped for creating aggregates.
AggregationSpecification.Kind - Enum in org.apache.cassandra.db.aggregation
The AggregationSpecification kinds.
AggregationSpecification.Serializer - Class in org.apache.cassandra.db.aggregation
 
algorithm - Variable in class org.apache.cassandra.config.EncryptionOptions
 
alias - Variable in class org.apache.cassandra.cql3.selection.RawSelector
 
aliasFactory - Variable in class org.apache.cassandra.metrics.LatencyMetrics
 
AlibabaCloudSnitch - Class in org.apache.cassandra.locator
A snitch that assumes an ECS region is a DC and an ECS availability_zone is a rack.
AlibabaCloudSnitch() - Constructor for class org.apache.cassandra.locator.AlibabaCloudSnitch
 
align(long, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
alignBuffer(ByteBuffer, int) - Static method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
 
Aligned(ChunkReader) - Constructor for class org.apache.cassandra.io.util.BufferManagingRebufferer.Aligned
 
alignToBlock(SequentialWriter) - Static method in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
 
alive - Variable in exception org.apache.cassandra.exceptions.UnavailableException
 
ALIVE_PREDICATE - Static variable in class org.apache.cassandra.dht.RangeStreamer
 
all() - Static method in class org.apache.cassandra.auth.DCPermissions
 
all() - Method in class org.apache.cassandra.auth.DCPermissions.Builder
 
ALL - Static variable in enum org.apache.cassandra.auth.Permission
 
all - Static variable in interface org.apache.cassandra.concurrent.ExecutorLocal
 
all() - Static method in class org.apache.cassandra.cql3.functions.AggregateFcts
 
all() - Static method in class org.apache.cassandra.cql3.functions.BytesConversionFcts
 
all() - Static method in class org.apache.cassandra.cql3.functions.CastFcts
 
all() - Static method in class org.apache.cassandra.cql3.functions.OperationFcts
 
all() - Static method in class org.apache.cassandra.cql3.functions.TimeFcts
 
all() - Static method in class org.apache.cassandra.cql3.functions.UuidFcts
 
all() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
all(TableMetadata) - Static method in class org.apache.cassandra.db.filter.ColumnFilter
A filter that includes all columns for the provided table.
all() - Static method in class org.apache.cassandra.db.Keyspace
 
ALL - Static variable in class org.apache.cassandra.db.Slice
The slice selecting all rows (of a given partition)
ALL - Static variable in class org.apache.cassandra.db.Slices
Slices selecting all the rows of a partition.
all() - Method in class org.apache.cassandra.locator.ReplicaLayout
All relevant owners of the ring position(s) for this operation, as implied by the current ring layout.
all() - Method in class org.apache.cassandra.locator.ReplicaLayout.ForWrite
 
all - Variable in class org.apache.cassandra.metrics.TableMetrics.TableHistogram
 
all - Variable in class org.apache.cassandra.metrics.TableMetrics.TableMeter
 
all - Variable in class org.apache.cassandra.metrics.TableMetrics.TableTimer
 
ALL - Static variable in class org.apache.cassandra.schema.SchemaKeyspace
The order in this list matters.
all(WaitQueue.Signal...) - Static method in class org.apache.cassandra.utils.concurrent.WaitQueue
 
ALL_MUTATIONS - Static variable in class org.apache.cassandra.db.commitlog.CommitLogReader
 
allChannels - Variable in class org.apache.cassandra.transport.Server.ConnectionTracker
 
allColumnsInCreateOrder() - Method in class org.apache.cassandra.schema.TableMetadata
Returns an iterator over all column definitions that respect the order of the CREATE statement.
allColumnsInCreateOrder() - Method in class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
 
allColumnsInSelectOrder() - Method in class org.apache.cassandra.schema.TableMetadata
 
allColumnsInSelectOrder() - Method in class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
 
allConnectedClients() - Method in class org.apache.cassandra.metrics.ClientMetrics
 
allData(IPartitioner) - Static method in class org.apache.cassandra.db.DataRange
Creates a DataRange to query all data (over the whole ring).
allData(IPartitioner, ClusteringIndexFilter) - Static method in class org.apache.cassandra.db.DataRange
Creates a DataRange to query all partitions of the ring using the provided clustering index filter.
allDataRead(TableMetadata, int) - Static method in class org.apache.cassandra.db.PartitionRangeReadCommand
Creates a new read command that query all the data in the table.
allExisting() - Static method in class org.apache.cassandra.db.Keyspace
 
allFetchedColumnsAreQueried() - Method in class org.apache.cassandra.db.filter.ColumnFilter
Whether _fetched_ == _queried_ for this filter, and so if the isQueried() methods can return false for some column/cell.
allFetchedColumnsAreQueried() - Method in class org.apache.cassandra.db.filter.ColumnFilter.SelectionColumnFilter
 
allFetchedColumnsAreQueried() - Method in class org.apache.cassandra.db.filter.ColumnFilter.WildCardColumnFilter
 
allInSameTable(Collection<ColumnSpecification>) - Static method in class org.apache.cassandra.cql3.ColumnSpecification
Returns true if all ColumnSpecifications are in the same table, false otherwise.
allKnownSSTables() - Method in class org.apache.cassandra.db.lifecycle.View
 
allLatency - Variable in class org.apache.cassandra.metrics.MessagingMetrics.DCLatencyRecorder
 
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
allMemtablesLiveDataSize - Variable in class org.apache.cassandra.metrics.TableMetrics
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.
allMemtablesOffHeapDataSize - Variable in class org.apache.cassandra.metrics.TableMetrics
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.
allMemtablesOnHeapDataSize - Variable in class org.apache.cassandra.metrics.TableMetrics
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.AbstractCommitLogSegmentManager
Allocate a segment within this CLSM.
allocate(Mutation, int) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerCDC
Reserve space in the current segment for the provided mutation or, if there isn't space available, create a new segment.
allocate(Mutation, int) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerStandard
Reserve space in the current segment for the provided mutation or, if there isn't space available, create a new segment.
allocate(int, int, int) - Static method in class org.apache.cassandra.db.context.CounterContext.ContextState
Allocate a new context big enough for globalCount + localCount + remoteCount elements and return the initial corresponding ContextState.
allocate(int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
allocate(int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
allocate(int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
Allocate and return a instance of bytes on the heap.
allocate(int, int, int[], OutputHandler, IPartitioner) - Static method in class org.apache.cassandra.dht.tokenallocator.OfflineTokenAllocator
 
allocate(int) - Method in enum org.apache.cassandra.io.compress.BufferType
 
allocate(long) - Static method in class org.apache.cassandra.io.util.Memory
 
allocate(boolean, int) - Method in interface org.apache.cassandra.net.FrameEncoder.PayloadAllocator
 
allocate(long) - Method in class org.apache.cassandra.net.ResourceLimits.Basic
 
allocate(long) - Method in class org.apache.cassandra.net.ResourceLimits.Concurrent
 
allocate(long) - Method in class org.apache.cassandra.net.ResourceLimits.EndpointAndGlobal
 
allocate(long) - Method in interface org.apache.cassandra.net.ResourceLimits.Limit
Allocates an amount independent of permits available from this limit.
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(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
allocate(long, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator.SubAllocator
 
allocate(int, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
 
allocate(int, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
 
allocate(int) - Method in class org.apache.cassandra.utils.memory.SlabAllocator
 
allocate(int, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.SlabAllocator
 
allocate_tokens_for_keyspace - Variable in class org.apache.cassandra.config.Config
Triggers automatic allocation of tokens if set, using the replication strategy of the referenced keyspace
allocate_tokens_for_local_replication_factor - Variable in class org.apache.cassandra.config.Config
Triggers automatic allocation of tokens if set, based on the provided replica count for a datacenter
allocateBuffer() - Method in class org.apache.cassandra.io.util.SequentialWriterOption
Allocate buffer using set buffer type and buffer size.
allocated(long) - Method in interface org.apache.cassandra.utils.btree.UpdateFunction
 
allocated(long) - Method in class org.apache.cassandra.utils.btree.UpdateFunction.Simple
 
allocateDirect(int) - Method in class org.apache.cassandra.net.BufferPoolAllocator.Wrapped
 
allocateTokens(TokenMetadata, AbstractReplicationStrategy, InetAddressAndPort, int) - Static method in class org.apache.cassandra.dht.tokenallocator.TokenAllocation
 
allocateTokens(TokenMetadata, int, InetAddressAndPort, int) - Static method in class org.apache.cassandra.dht.tokenallocator.TokenAllocation
 
allocatingOnHeap() - Method in class org.apache.cassandra.utils.memory.HeapAllocator
 
allocator - Variable in class org.apache.cassandra.net.FrameDecoder
 
allocator() - Method in class org.apache.cassandra.net.FrameEncoder
 
allocator() - Method in class org.apache.cassandra.net.FrameEncoderCrc
 
allocator - Variable in class org.apache.cassandra.net.OutboundConnectionInitiator.Result.MessagingSuccess
 
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
 
allOf(Collection<Future>) - Static method in class org.apache.cassandra.utils.FBUtilities
Returns a new Future wrapping the given list of futures and returning a list of their results.
allOperations() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
allow(Message<?>) - Method in class org.apache.cassandra.net.InboundSink
Deprecated.
ALLOW_TOOL_REINIT_FOR_TEST - Static variable in class org.apache.cassandra.tools.Util
 
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
 
AllowAllNetworkAuthorizer - Class in org.apache.cassandra.auth
 
AllowAllNetworkAuthorizer() - Constructor for class org.apache.cassandra.auth.AllowAllNetworkAuthorizer
 
allowClusteringColumnSlices() - Method in enum org.apache.cassandra.cql3.statements.StatementType
Checks this type of statement allow the where clause to contains clustering column slices.
allowedDCs() - Method in class org.apache.cassandra.auth.DCPermissions
 
AllowedSourcesFilter(Set<InetAddressAndPort>) - Constructor for class org.apache.cassandra.dht.RangeStreamer.AllowedSourcesFilter
 
allowFiltering - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
 
allowNonPrimaryKeyInWhereClause() - Method in enum org.apache.cassandra.cql3.statements.StatementType
Checks if this type of statement allow non primary key in the where clause.
allowPartitionKeyRanges() - Method in enum org.apache.cassandra.cql3.statements.StatementType
Checks this statement allow the where clause to contains missing partition key components or token relation.
allowUnlimitedConcurrentValidations - Static variable in class org.apache.cassandra.config.DatabaseDescriptor
 
allowUseOfSecondaryIndices() - Method in enum org.apache.cassandra.cql3.statements.StatementType
Checks if this type of statement allow the use of secondary indices.
allRegularColumnsBuilder(TableMetadata, boolean) - Static method in class org.apache.cassandra.db.filter.ColumnFilter
Returns a ColumnFilter builder that fetches all regular columns or all columns (and queries the columns added to the builder, or everything if no column is added).
allReplicas() - Method in class org.apache.cassandra.locator.Replicas.ReplicaCount
 
allReplicas - Variable in class org.apache.cassandra.locator.ReplicationFactor
 
allStrategies() - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
 
allStrategies() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
allStrategies() - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
allStreams() - Method in class org.apache.cassandra.repair.asymmetric.StreamFromOptions
 
allThreadPoolMetrics() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
allTypes() - Method in class org.apache.cassandra.db.marshal.TupleType
 
allViewsCfs() - Method in class org.apache.cassandra.db.view.TableViews
 
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(ColumnIdentifier, CQL3Type.Raw) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
 
alter(FieldIdentifier, CQL3Type.Raw) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTypeStatement.Raw
 
alterableOptions() - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
alterableOptions() - Method in interface org.apache.cassandra.auth.IRoleManager
Subset of supportedOptions that users are allowed to alter when performing ALTER ROLE [themselves].
altered - Variable in class org.apache.cassandra.schema.Diff
 
altered - Variable in class org.apache.cassandra.schema.Keyspaces.KeyspacesDiff
 
AlterKeyspaceStatement - Class in org.apache.cassandra.cql3.statements.schema
 
AlterKeyspaceStatement(String, KeyspaceAttributes) - Constructor for class org.apache.cassandra.cql3.statements.schema.AlterKeyspaceStatement
 
AlterKeyspaceStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
alterRole(AuthenticatedUser, RoleResource, RoleOptions) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
alterRole(AuthenticatedUser, RoleResource, RoleOptions) - Method in interface org.apache.cassandra.auth.IRoleManager
Called during execution of ALTER ROLE statement.
AlterRoleStatement - Class in org.apache.cassandra.cql3.statements
 
AlterRoleStatement(RoleName, RoleOptions) - Constructor for class org.apache.cassandra.cql3.statements.AlterRoleStatement
 
AlterRoleStatement(RoleName, RoleOptions, DCPermissions) - Constructor for class org.apache.cassandra.cql3.statements.AlterRoleStatement
 
AlterTableStatement - Class in org.apache.cassandra.cql3.statements.schema
 
AlterTableStatement(String, String) - Constructor for class org.apache.cassandra.cql3.statements.schema.AlterTableStatement
 
AlterTableStatement.AlterColumn - Class in org.apache.cassandra.cql3.statements.schema
ALTER TABLE ALTER TYPE ; No longer supported.
AlterTableStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
AlterTypeStatement - Class in org.apache.cassandra.cql3.statements.schema
 
AlterTypeStatement(String, String) - Constructor for class org.apache.cassandra.cql3.statements.schema.AlterTypeStatement
 
AlterTypeStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
AlterViewStatement - Class in org.apache.cassandra.cql3.statements.schema
 
AlterViewStatement(String, String, TableAttributes) - Constructor for class org.apache.cassandra.cql3.statements.schema.AlterViewStatement
 
AlterViewStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
alwaysLowerCaseTerms(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
 
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
 
AlwaysSpeculativeRetryPolicy - Class in org.apache.cassandra.service.reads
 
alwaysUpperCaseTerms(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
 
analyzeGroup(QueryController, Operation.OperationType, List<RowFilter.Expression>) - Static method in class org.apache.cassandra.index.sasi.plan.Operation
 
analyzer - Variable in class org.apache.cassandra.index.sasi.plan.Expression
 
analyzerClass - Variable in class org.apache.cassandra.index.sasi.conf.IndexMode
 
announce(Mutation) - Static method in class org.apache.cassandra.schema.MigrationManager
 
announce(Collection<Mutation>) - Static method in class org.apache.cassandra.schema.MigrationManager
 
announce(SchemaTransformation, boolean) - Static method in class org.apache.cassandra.schema.MigrationManager
 
announceNewKeyspace(KeyspaceMetadata) - Static method in class org.apache.cassandra.schema.MigrationManager
 
announceNewKeyspace(KeyspaceMetadata, boolean) - Static method in class org.apache.cassandra.schema.MigrationManager
 
announceNewKeyspace(KeyspaceMetadata, long, boolean) - Static method in class org.apache.cassandra.schema.MigrationManager
 
announceNewTable(TableMetadata) - Static method in class org.apache.cassandra.schema.MigrationManager
 
announceTableDrop(String, String, boolean) - Static method in class org.apache.cassandra.schema.MigrationManager
 
announceTableUpdate(TableMetadata) - Static method in class org.apache.cassandra.schema.MigrationManager
 
announceTableUpdate(TableMetadata, boolean) - Static method in class org.apache.cassandra.schema.MigrationManager
 
announceWithoutPush(Collection<Mutation>) - Static method in class org.apache.cassandra.schema.MigrationManager
 
ANONYMOUS_USER - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
 
ANONYMOUS_USERNAME - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
 
anticompactionTime - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Time spent anticompacting
anticompactionTime - Variable in class org.apache.cassandra.metrics.TableMetrics
time spent anticompacting data before participating in a consistent repair
any(WaitQueue.Signal...) - Static method in class org.apache.cassandra.utils.concurrent.WaitQueue
 
anyCauseMatches(Throwable, Predicate<Throwable>) - Static method in class org.apache.cassandra.utils.Throwables
 
append(String) - Method in class org.apache.cassandra.cql3.CqlBuilder
 
append(char) - Method in class org.apache.cassandra.cql3.CqlBuilder
 
append(boolean) - Method in class org.apache.cassandra.cql3.CqlBuilder
 
append(int) - Method in class org.apache.cassandra.cql3.CqlBuilder
 
append(long) - Method in class org.apache.cassandra.cql3.CqlBuilder
 
append(float) - Method in class org.apache.cassandra.cql3.CqlBuilder
 
append(double) - Method in class org.apache.cassandra.cql3.CqlBuilder
 
append(AbstractType<?>) - Method in class org.apache.cassandra.cql3.CqlBuilder
 
append(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.CqlBuilder
 
append(FunctionName) - Method in class org.apache.cassandra.cql3.CqlBuilder
 
append(Map<String, String>) - Method in class org.apache.cassandra.cql3.CqlBuilder
 
append(Map<String, String>, boolean) - Method in class org.apache.cassandra.cql3.CqlBuilder
 
append(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
Writes a partition in an implementation specific way
append(UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
Appends partition data to this writer.
append(UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableZeroCopyWriter
 
append(UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
 
append(UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
Appends partition data to this writer.
append(UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
 
append(UnfilteredRowIterator) - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
Writes a partition in an implementation specific way
append(UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
append(UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
 
append(File, String...) - Static method in class org.apache.cassandra.io.util.FileUtils
 
append(E, Replica) - Static method in class org.apache.cassandra.locator.Endpoints
 
append(ByteBuf) - Method in class org.apache.cassandra.net.AsyncStreamingInputPlus
Append a ByteBuf to the end of the einternal queue.
append(E) - Method in class org.apache.cassandra.utils.DynamicList
 
append(E, int) - Method in class org.apache.cassandra.utils.DynamicList
 
append(E, int) - Method in class org.apache.cassandra.utils.LockedDynamicList
 
appendAll(String, Object) - Method in interface org.apache.cassandra.db.rows.Row.SimpleBuilder
Appends new values to a given non-frozen collection column.
appendAll(String, Object) - Method in class org.apache.cassandra.db.SimpleBuilders.RowBuilder
 
appendAndSync(File, String...) - Static method in class org.apache.cassandra.io.util.FileUtils
 
appendBoundTo(MultiCBuilder, Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
 
appendBoundTo(MultiCBuilder, Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
 
appendBoundTo(MultiCBuilder, Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
 
appendBoundTo(MultiCBuilder, Bound, QueryOptions) - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
Appends the values of the SingleRestriction for the specified bound to the specified builder.
appendCqlTo(CqlBuilder) - Method in class org.apache.cassandra.cql3.functions.FunctionName
 
appendCqlTo(CqlBuilder) - Method in class org.apache.cassandra.schema.ColumnMetadata
 
appendCqlTo(CqlBuilder, TableMetadata, boolean) - Method in class org.apache.cassandra.schema.IndexMetadata
Appends to the specified builder the CQL used to create this index.
appendCqlTo(CqlBuilder) - Method in class org.apache.cassandra.schema.ReplicationParams
 
appendCqlTo(CqlBuilder, boolean, boolean, boolean) - Method in class org.apache.cassandra.schema.TableMetadata
 
appendCqlTo(CqlBuilder, boolean, boolean, boolean) - Method in class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
 
appendCqlTo(CqlBuilder) - Method in class org.apache.cassandra.schema.TableParams
 
appendCqlTo(CqlBuilder, boolean, boolean) - Method in class org.apache.cassandra.schema.ViewMetadata
 
appendCQLWhereClause(StringBuilder) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
appendCQLWhereClause(StringBuilder) - Method in class org.apache.cassandra.db.ReadCommand
 
appendCQLWhereClause(StringBuilder) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
appendCQLWhereClause(StringBuilder) - Method in class org.apache.cassandra.db.VirtualTablePartitionRangeReadQuery
 
appendCQLWhereClause(StringBuilder) - Method in class org.apache.cassandra.db.VirtualTableSinglePartitionReadQuery
 
appendDirect(ByteBuffer, boolean) - Method in class org.apache.cassandra.io.util.ChecksumWriter
 
Appender(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Lists.Appender
 
appendKeyString(StringBuilder, AbstractType<?>, ByteBuffer) - Static method in class org.apache.cassandra.db.DataRange
 
appendNameAndOrderTo(CqlBuilder) - Method in class org.apache.cassandra.schema.ColumnMetadata
 
appendOrderByToCQLString(TableMetadata, StringBuilder) - Method in class org.apache.cassandra.db.filter.AbstractClusteringIndexFilter
 
appendQuotingIfNeeded(String) - Method in class org.apache.cassandra.cql3.CqlBuilder
 
appendTo(CqlBuilder, T) - Method in interface org.apache.cassandra.cql3.CqlBuilder.Appender
 
appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
 
appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.INRestriction
Appends the values of this SingleRestriction to the specified builder.
appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.NotNullRestriction
 
appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
 
appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
 
appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQRestriction
 
appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.INRestriction
 
appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IsNotNullRestriction
 
appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
 
appendTo(MultiCBuilder, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
 
appendTo(MultiCBuilder, QueryOptions) - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
Appends the values of this SingleRestriction to the specified builder.
appendTOC(Descriptor, Collection<Component>) - Static method in class org.apache.cassandra.io.sstable.SSTable
Appends new component names to the TOC component.
appendToOperation(String) - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
 
appendWithSeparators(Iterable<T>, CqlBuilder.Appender<T>, String) - Method in class org.apache.cassandra.cql3.CqlBuilder
 
appendWithSeparators(Iterator<T>, CqlBuilder.Appender<T>, String) - Method in class org.apache.cassandra.cql3.CqlBuilder
 
appendWithSingleQuotes(String) - Method in class org.apache.cassandra.cql3.CqlBuilder
 
applicablePermissions() - Method in class org.apache.cassandra.auth.DataResource
 
applicablePermissions() - Method in class org.apache.cassandra.auth.FunctionResource
 
applicablePermissions() - Method in interface org.apache.cassandra.auth.IResource
Returns the set of Permissions that may be applied to this resource Certain permissions are not applicable to particular types of resources.
applicablePermissions() - Method in class org.apache.cassandra.auth.JMXResource
 
applicablePermissions() - Method in class org.apache.cassandra.auth.RoleResource
 
applicationReceiveQueueCapacityInBytes - Variable in class org.apache.cassandra.net.InboundConnectionSettings
 
applicationSendQueueCapacityInBytes - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
applicationSendQueueCapacityInBytes() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
applicationSendQueueReserveEndpointCapacityInBytes - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
applicationSendQueueReserveEndpointCapacityInBytes() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
applicationSendQueueReserveGlobalCapacityInBytes - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
applicationSendQueueReserveGlobalCapacityInBytes() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
ApplicationState - Enum in org.apache.cassandra.gms
The various "states" exchanged through Gossip.
appliesLocally(Mutation) - Method in class org.apache.cassandra.service.StorageProxy
 
appliesOnlyToStaticColumns(Operations, Conditions) - Static method in class org.apache.cassandra.cql3.statements.ModificationStatement
Checks that the specified operations and conditions only apply to static columns.
appliesTo(Row) - Method in class org.apache.cassandra.cql3.conditions.ColumnCondition.Bound
Validates whether this condition applies to current.
appliesTo(FilteredPartition) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
Checks whether the conditions represented by this object applies provided the current state of the partition on which those conditions are.
appliesTo(FilteredPartition) - 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.conditions.ColumnConditions
 
appliesToRegularColumns() - Method in interface org.apache.cassandra.cql3.conditions.Conditions
Checks if some of the conditions apply to regular columns.
appliesToRegularColumns() - Method in class org.apache.cassandra.cql3.Operations
Checks if some of the operations apply to regular columns.
appliesToStaticColumns() - Method in class org.apache.cassandra.cql3.conditions.ColumnConditions
 
appliesToStaticColumns() - Method in interface org.apache.cassandra.cql3.conditions.Conditions
Checks if some of the conditions apply to static columns.
appliesToStaticColumns() - Method in class org.apache.cassandra.cql3.Operations
Checks if some of the operations apply to static columns.
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.AlterKeyspaceStatement
 
apply(KeyspaceMetadata, TableMetadata) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.AlterColumn
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTypeStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.AlterViewStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.CreateAggregateStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.CreateFunctionStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.CreateKeyspaceStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTriggerStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTypeStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.CreateViewStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.DropAggregateStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.DropFunctionStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.DropIndexStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.DropKeyspaceStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.DropTableStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.DropTriggerStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.DropTypeStatement
 
apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.DropViewStatement
 
apply(PartitionUpdate, UpdateTransaction, OpOrder.Group, CommitLogPosition) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Insert/Update the column family for this key.
apply(Consumer<ColumnMetadata>) - Method in class org.apache.cassandra.db.Columns
Apply a function to each column definition in forwards or reversed order.
apply() - Method in class org.apache.cassandra.db.CounterMutation
 
apply() - Method in interface org.apache.cassandra.db.IMutation
 
apply(Mutation, boolean, boolean) - Method in class org.apache.cassandra.db.Keyspace
 
apply(Mutation, boolean) - Method in class org.apache.cassandra.db.Keyspace
 
apply(Mutation, boolean, boolean, boolean) - Method in class org.apache.cassandra.db.Keyspace
If apply is blocking, apply must not be deferred Otherwise there is a race condition where ALL mutation workers are beeing blocked ending in a complete deadlock of the mutation stage.
apply(boolean, boolean) - Method in class org.apache.cassandra.db.Mutation
 
apply(boolean) - Method in class org.apache.cassandra.db.Mutation
 
apply() - Method in class org.apache.cassandra.db.Mutation
 
apply(Consumer<ColumnData>) - Method in class org.apache.cassandra.db.rows.BTreeRow
 
apply(BiConsumer<A, ColumnData>, A) - Method in class org.apache.cassandra.db.rows.BTreeRow
 
apply(Consumer<ColumnData>) - Method in interface org.apache.cassandra.db.rows.Row
Apply a function to every column in a row
apply(BiConsumer<A, ColumnData>, A) - Method in interface org.apache.cassandra.db.rows.Row
Apply a function to every column in a row
apply(UnfilteredPartitionIterator, Transformation<? super UnfilteredRowIterator>) - Static method in class org.apache.cassandra.db.transform.Transformation
 
apply(PartitionIterator, Transformation<? super RowIterator>) - Static method in class org.apache.cassandra.db.transform.Transformation
 
apply(UnfilteredRowIterator, Transformation<?>) - Static method in class org.apache.cassandra.db.transform.Transformation
 
apply(RowIterator, Transformation<?>) - Static method in class org.apache.cassandra.db.transform.Transformation
 
apply(PartitionUpdate) - Method in class org.apache.cassandra.db.virtual.AbstractVirtualTable
 
apply() - Method in class org.apache.cassandra.db.virtual.VirtualMutation
 
apply(PartitionUpdate) - Method in interface org.apache.cassandra.db.virtual.VirtualTable
Applies the specified update.
apply(Replica) - Method in class org.apache.cassandra.dht.RangeStreamer.AllowedSourcesFilter
 
apply(Replica) - Method in class org.apache.cassandra.dht.RangeStreamer.ExcludeLocalNodeFilter
 
apply(Replica) - Method in class org.apache.cassandra.dht.RangeStreamer.FailureDetectorSourceFilter
 
apply(Replica) - Method in class org.apache.cassandra.dht.RangeStreamer.SingleDatacenterFilter
 
apply(Replica) - Method in interface org.apache.cassandra.dht.RangeStreamer.SourceFilter
 
apply(boolean, boolean) - Method in enum org.apache.cassandra.index.sasi.plan.Operation.OperationType
 
apply(int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Operator
 
apply(T) - Method in interface org.apache.cassandra.io.util.CheckedFunction
 
apply(InetAddressAndPort, Set<InetAddressAndPort>) - Method in interface org.apache.cassandra.repair.asymmetric.PreferedNodeFilter
 
apply(Keyspaces) - Method in interface org.apache.cassandra.schema.SchemaTransformation
Apply a statement transformation to a schema snapshot.
apply(IMutation, ReplicaPlan.ForTokenWrite, AbstractWriteResponseHandler<IMutation>, String) - Method in interface org.apache.cassandra.service.StorageProxy.WritePerformer
 
apply(T, A, long) - Method in interface org.apache.cassandra.utils.BiLongAccumulator
 
apply(Object[], BiConsumer<A, V>, A) - Static method in class org.apache.cassandra.utils.btree.BTree
Simple method to walk the btree forwards and apply a function till a stop condition is reached Private method
apply(Object[], Consumer<V>) - Static method in class org.apache.cassandra.utils.btree.BTree
Simple method to walk the btree forwards and apply a function till a stop condition is reached Private method
apply(V, K) - Method in interface org.apache.cassandra.utils.btree.UpdateFunction
 
apply(V) - Method in class org.apache.cassandra.utils.btree.UpdateFunction.Simple
 
apply(V, V) - Method in class org.apache.cassandra.utils.btree.UpdateFunction.Simple
 
apply(T, long) - Method in interface org.apache.cassandra.utils.LongAccumulator
 
applyAddressConfig() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
applyAddressConfig(Config) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
applyAuth() - Static method in class org.apache.cassandra.auth.AuthConfig
 
applyConfig() - Method in class org.apache.cassandra.config.EncryptionOptions
 
applyConfig() - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
applyConfig() - Method in class org.apache.cassandra.service.CassandraDaemon
 
applyConfigChanges() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
Update configuration from DatabaseDescriptor and estart the update-scheduler and reset-scheduler tasks if the configured rates for these tasks have changed.
applyCounterMutation() - Method in class org.apache.cassandra.db.CounterMutation
Applies the counter mutation, returns the result Mutation (for replication to other nodes).
applyCounterMutationOnCoordinator(CounterMutation, String, long) - Static method in class org.apache.cassandra.service.StorageProxy
 
applyCounterMutationOnLeader(CounterMutation, String, Runnable, long) - Static method in class org.apache.cassandra.service.StorageProxy
 
applyEncryptionContext() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
applyFuture(Mutation, boolean, boolean) - Method in class org.apache.cassandra.db.Keyspace
 
applyFuture(Mutation, boolean, boolean, boolean, boolean) - Method in class org.apache.cassandra.db.Keyspace
 
applyFuture() - Method in class org.apache.cassandra.db.Mutation
 
applyLeaf(Object[], BiConsumer<A, V>, A) - Static method in class org.apache.cassandra.utils.btree.BTree
 
applyOne(BaseRowIterator<?>, Transformation) - Method in class org.apache.cassandra.db.transform.BasePartitions
 
applyOne(Unfiltered, Transformation) - Method in class org.apache.cassandra.db.transform.BaseRows
 
applyPartitioner() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
applyPartitioner(Config) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
applySeedProvider() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
applySnitch() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
applySslContext() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
applyStateLocally(Map<InetAddressAndPort, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
 
applyTo(PartitionIterator) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
 
applyTo(UnfilteredPartitionIterator) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
 
applyTo(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
 
applyTo(RowIterator) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
 
applyToDeletion(DeletionTime) - Method in class org.apache.cassandra.db.partitions.PurgeFunction
 
applyToDeletion(DeletionTime) - Method in class org.apache.cassandra.db.transform.DuplicateRowChecker
 
applyToDeletion(DeletionTime) - Method in class org.apache.cassandra.db.transform.Transformation
Applied to the partition-level deletion of any rows iterator.
applyToDeletionInfo(DeletionInfo) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
 
applyTokensConfig() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
applyToMarker(RangeTombstoneMarker) - Method in class org.apache.cassandra.db.partitions.PurgeFunction
 
applyToMarker(RangeTombstoneMarker) - Method in class org.apache.cassandra.db.transform.DuplicateRowChecker
 
applyToMarker(RangeTombstoneMarker) - Method in class org.apache.cassandra.db.transform.Filter
 
applyToMarker(RangeTombstoneMarker) - Method in class org.apache.cassandra.db.transform.Transformation
Applied to any RTM we encounter in a rows/unfiltered iterator
applyToMarker(RangeTombstoneMarker) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
 
applyToPartition(BaseRowIterator<?>) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
 
applyToPartition(DecoratedKey, Row) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
 
applyToPartition(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.partitions.PurgeFunction
 
applyToPartition(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.ReadCommand.CheckForAbort
 
applyToPartition(BaseRowIterator) - Method in class org.apache.cassandra.db.transform.EmptyPartitionsDiscarder
 
applyToPartition(BaseRowIterator) - Method in class org.apache.cassandra.db.transform.Filter
 
applyToPartition(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.transform.RTBoundCloser
 
applyToPartition(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.transform.RTBoundValidator
 
applyToPartition(I) - Method in class org.apache.cassandra.db.transform.Transformation
Applied to any rows iterator (partition) we encounter in a partitions iterator
applyToPartition(UnfilteredRowIterator) - Method in class org.apache.cassandra.service.reads.ShortReadPartitionsProtection
 
applyToPartition(UnfilteredRowIterator) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
 
applyToPartition(SearchIterator<Clustering<?>, Row>) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
 
applyToPartition(Iterator<Row>) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
 
applyToPartitionColumns(RegularAndStaticColumns) - Method in class org.apache.cassandra.db.rows.WithOnlyQueriedData
 
applyToPartitionColumns(RegularAndStaticColumns) - Method in class org.apache.cassandra.db.transform.Transformation
Applied to the PartitionColumns of any rows iterator.
applyToPartitionKey(DecoratedKey) - Method in class org.apache.cassandra.db.transform.Transformation
Applied to the partition key of any rows/unfiltered iterator we are applied to
applyToPartitionKey(DecoratedKey) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
 
applyToRow(Row) - Method in class org.apache.cassandra.db.partitions.PurgeFunction
 
applyToRow(Row) - Method in class org.apache.cassandra.db.ReadCommand.CheckForAbort
 
applyToRow(Row) - Method in class org.apache.cassandra.db.rows.WithOnlyQueriedData
 
applyToRow(Row) - Method in class org.apache.cassandra.db.transform.DuplicateRowChecker
 
applyToRow(Row) - Method in class org.apache.cassandra.db.transform.Filter
 
applyToRow(Row) - Method in class org.apache.cassandra.db.transform.Transformation
Applied to any row we encounter in a rows iterator
applyToRow(Row) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
 
applyToStatic(Row) - Method in class org.apache.cassandra.db.partitions.PurgeFunction
 
applyToStatic(Row) - Method in class org.apache.cassandra.db.rows.WithOnlyQueriedData
 
applyToStatic(Row) - Method in class org.apache.cassandra.db.transform.DuplicateRowChecker
 
applyToStatic(Row) - Method in class org.apache.cassandra.db.transform.Filter
 
applyToStatic(Row) - Method in class org.apache.cassandra.db.transform.Transformation
Applied to the static row of any rows iterator.
applyToStatic(Row) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
 
applyUnsafe() - Method in class org.apache.cassandra.db.Mutation
 
ApproximateTime - Class in org.apache.cassandra.utils
This class provides approximate time utilities: - An imprecise nanoTime (monotonic) and currentTimeMillis (non-monotonic), that are faster than their regular counterparts They have a configured approximate precision (default of 10ms), which is the cadence they will be updated if the system is healthy - A mechanism for converting between nanoTime and currentTimeMillis measurements.
ApproximateTime() - Constructor for class org.apache.cassandra.utils.ApproximateTime
 
ApproximateTime.AlmostSameTime - Class in org.apache.cassandra.utils
 
ApproximateTime.Measurement - Enum in org.apache.cassandra.utils
 
approxTime - Static variable in interface org.apache.cassandra.utils.MonotonicClock
 
Architecture - Class in org.apache.cassandra.utils
 
archive_command - Variable in class org.apache.cassandra.utils.binlog.BinLogOptions
 
archiveCommand(String) - Method in class org.apache.cassandra.utils.binlog.BinLog.Builder
 
archivePending - Variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
archiver - Variable in class org.apache.cassandra.db.commitlog.CommitLog
 
areAllFetchedColumnsKnown() - Method in class org.apache.cassandra.cql3.selection.SimpleSelector.SimpleSelectorFactory
 
argCodecs - Variable in class org.apache.cassandra.cql3.functions.UDFunction
 
argNames - Variable in class org.apache.cassandra.cql3.functions.UDFunction
 
argNames() - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
args - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithFunction
 
args - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithToJSonFunction
 
argTypes - Variable in class org.apache.cassandra.cql3.functions.AbstractFunction
 
argTypes() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
argTypes() - Method in interface org.apache.cassandra.cql3.functions.Function
 
argTypes - Variable in exception org.apache.cassandra.exceptions.FunctionExecutionException
 
argTypes - Variable in class org.apache.cassandra.transport.Event.SchemaChange
 
argumentsList() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
array - Variable in class org.apache.cassandra.db.marshal.ValueComparators
 
ArrayCell - Class in org.apache.cassandra.db.rows
 
ArrayCell(ColumnMetadata, long, int, int, byte[], CellPath) - Constructor for class org.apache.cassandra.db.rows.ArrayCell
 
ArrayClustering - Class in org.apache.cassandra.db
 
ArrayClustering(byte[]...) - Constructor for class org.apache.cassandra.db.ArrayClustering
 
ArrayClusteringBound - Class in org.apache.cassandra.db
 
ArrayClusteringBound(ClusteringPrefix.Kind, byte[][]) - Constructor for class org.apache.cassandra.db.ArrayClusteringBound
 
ArrayClusteringBoundary - Class in org.apache.cassandra.db
 
ArrayClusteringBoundary(ClusteringPrefix.Kind, byte[][]) - Constructor for class org.apache.cassandra.db.ArrayClusteringBoundary
 
ArrayClusteringBoundOrBoundary - Class in org.apache.cassandra.db
 
ArrayClusteringBoundOrBoundary(ClusteringPrefix.Kind, byte[][]) - Constructor for class org.apache.cassandra.db.ArrayClusteringBoundOrBoundary
 
arsProxy - Variable in class org.apache.cassandra.tools.NodeProbe
 
asByteBuffer(long, int) - Method in class org.apache.cassandra.io.util.Memory
 
asByteBuffers(long, long) - Method in class org.apache.cassandra.io.util.Memory
 
asBytes(String, String, AbstractType) - Static method in interface org.apache.cassandra.cql3.Terms
 
asc(boolean) - Static method in enum org.apache.cassandra.utils.btree.BTree.Dir
 
ascii() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the ASCII type.
ascii() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type ascii.
AsciiSerializer - Class in org.apache.cassandra.serializers
 
AsciiType - Class in org.apache.cassandra.db.marshal
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.AsciiType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.BooleanType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.BytesType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.ByteType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.CollectionType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.DateType
Deprecated.
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.DecimalType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.DoubleType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.DurationType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.EmptyType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.FloatType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.InetAddressType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.Int32Type
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.IntegerType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.LongType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.ReversedType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.ShortType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.TimestampType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.TimeType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.TupleType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.UserType
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
asCQL3Type() - Method in class org.apache.cassandra.db.marshal.UUIDType
 
asCqlString() - Method in class org.apache.cassandra.cql3.statements.schema.IndexTarget
 
asCQLTypeStringList(List<AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.AbstractType
 
asFunctionParameterString() - Method in class org.apache.cassandra.cql3.functions.types.DataType
Returns a String representation of this data type suitable for inclusion as a parameter type in a function or aggregate signature.
asFunctionParameterString() - Method in class org.apache.cassandra.cql3.functions.types.DataType.CollectionType
 
asFunctionParameterString() - Method in class org.apache.cassandra.cql3.functions.types.TupleType
 
asFunctionParameterString() - Method in class org.apache.cassandra.cql3.functions.types.UserType
 
asInt() - Method in enum org.apache.cassandra.transport.ProtocolVersion
 
asJavaClass(TypeCodec<?>) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
 
ask() - Method in class org.apache.cassandra.utils.concurrent.Blocker
 
asList() - Method in class org.apache.cassandra.dht.Range
 
asMap() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
asMap() - Method in class org.apache.cassandra.locator.ReplicaMultimap
 
asMap() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
asMap() - Method in class org.apache.cassandra.schema.CachingParams
 
asMap() - Method in class org.apache.cassandra.schema.CompactionParams
 
asMap() - Method in class org.apache.cassandra.schema.CompressionParams
 
asMap() - Method in class org.apache.cassandra.schema.ReplicationParams
 
asMap() - Method in class org.apache.cassandra.transport.ClientStat
 
asMap() - Method in class org.apache.cassandra.transport.ConnectedClient
 
asNativeFunction() - Method in class org.apache.cassandra.cql3.functions.FunctionName
 
asNewBuffer() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
Assassinate - Class in org.apache.cassandra.tools.nodetool
 
Assassinate() - Constructor for class org.apache.cassandra.tools.nodetool.Assassinate
 
assassinateEndpoint(String) - Method in class org.apache.cassandra.gms.Gossiper
Do not call this method unless you know what you are doing.
assassinateEndpoint(String) - Method in interface org.apache.cassandra.gms.GossiperMBean
 
assassinateEndpoint(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
assertFull(Iterable<Replica>) - Static method in class org.apache.cassandra.locator.Replicas
For areas of the code that should never see a transient replica
assertNormalized(List<Range<T>>) - Static method in class org.apache.cassandra.dht.Range
 
assertUdfsEnabled(String) - Static method in class org.apache.cassandra.cql3.functions.UDFunction
 
AssignmentTestable - Interface in org.apache.cassandra.cql3
 
AssignmentTestable.TestResult - Enum in org.apache.cassandra.cql3
 
assumeLiveData - Variable in class org.apache.cassandra.db.filter.DataLimits.Counter
 
asUUID() - Method in class org.apache.cassandra.schema.TableId
 
asymmetric - Variable in class org.apache.cassandra.repair.messages.SyncRequest
 
asymmetricCellPathComparator() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
asymmetricColumnDataComparator - Static variable in class org.apache.cassandra.schema.ColumnMetadata
 
AsymmetricOrdering<T1,T2> - Class in org.apache.cassandra.utils
 
AsymmetricOrdering() - Constructor for class org.apache.cassandra.utils.AsymmetricOrdering
 
AsymmetricOrdering.Op - Enum in org.apache.cassandra.utils
 
AsymmetricRemoteSyncTask - Class in org.apache.cassandra.repair
AsymmetricRemoteSyncTask sends SyncRequest to target node to repair(stream) data with other target replica.
AsymmetricRemoteSyncTask(RepairJobDesc, InetAddressAndPort, InetAddressAndPort, List<Range<Token>>, PreviewKind) - Constructor for class org.apache.cassandra.repair.AsymmetricRemoteSyncTask
 
AsyncChannelOutputPlus - Class in org.apache.cassandra.net
A DataOutputStreamPlus that writes ASYNCHRONOUSLY to a Netty Channel.
AsyncChannelOutputPlus(Channel) - Constructor for class org.apache.cassandra.net.AsyncChannelOutputPlus
 
AsyncChannelOutputPlus.FlushException - Exception in org.apache.cassandra.net
 
AsyncChannelPromise - Class in org.apache.cassandra.net
See AsyncPromise and ChannelPromise This class is all boiler plate, just ensuring we return ourselves and invoke the correct Promise method.
AsyncChannelPromise(Channel) - Constructor for class org.apache.cassandra.net.AsyncChannelPromise
 
AsyncMessageOutputPlus - Class in org.apache.cassandra.net
A DataOutputStreamPlus that writes ASYNCHRONOUSLY to a Netty Channel.
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
 
AsyncPromise<V> - Class in org.apache.cassandra.net
Netty's DefaultPromise uses a mutex to coordinate notifiers AND waiters between the eventLoop and the other threads.
AsyncPromise(EventExecutor) - Constructor for class org.apache.cassandra.net.AsyncPromise
 
AsyncPromise(EventExecutor, GenericFutureListener<? extends Future<? super V>>) - Constructor for class org.apache.cassandra.net.AsyncPromise
 
AsyncStreamingInputPlus - Class in org.apache.cassandra.net
 
AsyncStreamingInputPlus(Channel) - Constructor for class org.apache.cassandra.net.AsyncStreamingInputPlus
 
AsyncStreamingInputPlus.Consumer - Interface in org.apache.cassandra.net
 
AsyncStreamingInputPlus.InputTimeoutException - Exception in org.apache.cassandra.net
 
AsyncStreamingOutputPlus - Class in org.apache.cassandra.net
A DataOutputStreamPlus that writes ASYNCHRONOUSLY to a Netty Channel.
AsyncStreamingOutputPlus(Channel) - Constructor for class org.apache.cassandra.net.AsyncStreamingOutputPlus
 
AsyncStreamingOutputPlus.BufferSupplier - Interface in org.apache.cassandra.net
 
AsyncStreamingOutputPlus.Write - Interface in org.apache.cassandra.net
 
atLimit() - Method in class org.apache.cassandra.io.util.SimpleCachedBufferPool
Checks if the number of used buffers has exceeded the maximum number of cached buffers.
AtomicBTreePartition - Class in org.apache.cassandra.db.partitions
A thread-safe and atomic Partition implementation.
AtomicBTreePartition(TableMetadataRef, DecoratedKey, MemtableAllocator) - Constructor for class org.apache.cassandra.db.partitions.AtomicBTreePartition
 
attach(AbstractCommitLogService, AbstractCommitLogSegmentManager) - Method in class org.apache.cassandra.metrics.CommitLogMetrics
 
attach(Connection) - Method in class org.apache.cassandra.transport.Message
 
attachInbound(Channel, boolean) - Method in class org.apache.cassandra.streaming.StreamSession
Attach a channel to this session upon receiving the first inbound message.
attachOutbound(Channel) - Method in class org.apache.cassandra.streaming.StreamSession
Attach a channel to this session upon sending the first outbound message.
attachTo(BasePartitions) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
 
attachTo(BaseRows) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
 
attachTo(BasePartitions) - Method in class org.apache.cassandra.db.transform.StoppingTransformation
 
attachTo(BaseRows) - Method in class org.apache.cassandra.db.transform.StoppingTransformation
 
attempted - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
Deprecated.
Attribute() - Constructor for class org.apache.cassandra.tools.JMXTool.Attribute
 
Attribute(String, String, String) - Constructor for class org.apache.cassandra.tools.JMXTool.Attribute
 
attributeNames() - Method in class org.apache.cassandra.tools.JMXTool.Info
 
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
 
attributeSet() - Method in class org.apache.cassandra.tools.JMXTool.Info
 
attrs - Variable in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
 
attrs() - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
 
attrs - Variable in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
 
attrs - Variable in class org.apache.cassandra.cql3.statements.schema.CreateViewStatement.Raw
 
audit_logging_options - Variable in class org.apache.cassandra.config.Config
 
audit_logs_dir - Variable in class org.apache.cassandra.audit.AuditLogOptions
AuditLogs directory can be configured using `cassandra.logdir.audit` or default is set to `cassandra.logdir` + /audit/
AuditEvent - Class in org.apache.cassandra.audit
wrapper to expose audit events as DiagnosticEvents.
AUDITLOG_MESSAGE - Static variable in class org.apache.cassandra.audit.BinAuditLogger
 
AUDITLOG_TYPE - Static variable in class org.apache.cassandra.audit.BinAuditLogger
 
AuditLogContext - Class in org.apache.cassandra.audit
 
AuditLogContext(AuditLogEntryType) - Constructor for class org.apache.cassandra.audit.AuditLogContext
 
AuditLogContext(AuditLogEntryType, String) - Constructor for class org.apache.cassandra.audit.AuditLogContext
 
AuditLogContext(AuditLogEntryType, String, String) - Constructor for class org.apache.cassandra.audit.AuditLogContext
 
AuditLogEntry - Class in org.apache.cassandra.audit
 
AuditLogEntry.Builder - Class in org.apache.cassandra.audit
 
AuditLogEntryCategory - Enum in org.apache.cassandra.audit
Enum to categorize AuditLogEntries
auditLogEntryType - Variable in class org.apache.cassandra.audit.AuditLogContext
 
AuditLogEntryType - Enum in org.apache.cassandra.audit
 
AuditLogFilter - Class in org.apache.cassandra.audit
 
AuditLogManager - Class in org.apache.cassandra.audit
Central location for managing the logging of client/user-initated actions (like queries, log in commands, and so on).
AuditLogOptions - Class in org.apache.cassandra.audit
 
AuditLogOptions() - Constructor for class org.apache.cassandra.audit.AuditLogOptions
 
AuditLogViewer - Class in org.apache.cassandra.tools
Tool to view the contenst of AuditLog files in human readable format.
AuditLogViewer() - Constructor for class org.apache.cassandra.tools.AuditLogViewer
 
augment(Partition) - Method in interface org.apache.cassandra.triggers.ITrigger
Called exactly once per CF update, returned mutations are atomically updated.
AUTH_KEYSPACE_NAME - Static variable in class org.apache.cassandra.schema.SchemaConstants
 
AUTH_PROVIDER_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
AuthCache<K,V> - Class in org.apache.cassandra.auth
 
AuthCache(String, IntConsumer, IntSupplier, IntConsumer, IntSupplier, IntConsumer, IntSupplier, Function<K, V>, BooleanSupplier) - Constructor for class org.apache.cassandra.auth.AuthCache
 
AuthCacheMBean - Interface in org.apache.cassandra.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
 
AuthConfig - Class in org.apache.cassandra.auth
Only purpose is to Initialize authentication/authorization via AuthConfig.applyAuth().
AuthConfig() - Constructor for class org.apache.cassandra.auth.AuthConfig
 
authenticate(InetAddress, int) - Method in class org.apache.cassandra.auth.AllowAllInternodeAuthenticator
 
authenticate(InetAddress, int) - Method in interface org.apache.cassandra.auth.IInternodeAuthenticator
Decides whether or not a peer is allowed to connect to this node.
authenticate(Object) - Method in class org.apache.cassandra.auth.jmx.AuthenticationProxy
Perform authentication of the client opening the MBeanServerConnection
authenticate(InetAddressAndPort) - Method in class org.apache.cassandra.net.InboundConnectionSettings
 
authenticate(InetAddress, int) - Method in class org.apache.cassandra.net.InboundConnectionSettings
 
authenticate() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
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
 
AuthenticationException(String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.AuthenticationException
 
AuthenticationProxy - Class in org.apache.cassandra.auth.jmx
An alternative to the JAAS based implementation of JMXAuthenticator provided by the JDK (JMXPluggableAuthenticator).
AuthenticationProxy(String) - Constructor for class org.apache.cassandra.auth.jmx.AuthenticationProxy
Creates an instance of JMXPluggableAuthenticator and initializes it with a LoginContext.
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.net.InboundConnectionSettings
 
authenticator - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
authenticator() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
authenticator - Variable in class org.apache.cassandra.transport.messages.AuthenticateMessage
 
AuthEvents - Class in org.apache.cassandra.auth
 
AuthEvents() - Constructor for class org.apache.cassandra.auth.AuthEvents
 
AuthEvents.Listener - Interface in org.apache.cassandra.auth
 
authFailure(QueryState, Exception) - Method in class org.apache.cassandra.audit.AuditLogManager
 
authFailure(QueryState, Exception) - Method in interface org.apache.cassandra.auth.AuthEvents.Listener
 
AuthKeyspace - Class in org.apache.cassandra.auth
 
AuthorizationProxy - Class in org.apache.cassandra.auth.jmx
Provides a proxy interface to the platform's MBeanServer instance to perform role-based authorization on method invocation.
AuthorizationProxy() - Constructor for class org.apache.cassandra.auth.jmx.AuthorizationProxy
 
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(RoleResource) - Method in class org.apache.cassandra.auth.AllowAllNetworkAuthorizer
 
authorize(AuthenticatedUser, IResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
authorize(RoleResource) - Method in class org.apache.cassandra.auth.CassandraNetworkAuthorizer
 
authorize(AuthenticatedUser, IResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
Returns a set of permissions of a user on a resource.
authorize(RoleResource) - Method in interface org.apache.cassandra.auth.INetworkAuthorizer
Returns the dc permissions associated with the given role
authorize(ClientState) - Method in interface org.apache.cassandra.cql3.CQLStatement
Perform any access verification necessary for the statement.
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterRoleStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateRoleStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.DescribeStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropRoleStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListRolesStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.RoleManagementStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.AlterKeyspaceStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTypeStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.AlterViewStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateAggregateStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateFunctionStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateKeyspaceStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTriggerStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTypeStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateViewStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.DropAggregateStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.DropFunctionStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.DropIndexStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.DropKeyspaceStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.DropTableStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.DropTriggerStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.DropTypeStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.DropViewStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
 
authorize(ClientState) - Method in class org.apache.cassandra.cql3.statements.UseStatement
 
authorizer - Variable in class org.apache.cassandra.config.Config
 
authProvider - Variable in class org.apache.cassandra.tools.LoaderOptions
 
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
 
AuthSchemaChangeListener - Class in org.apache.cassandra.auth
SchemaChangeListener implementation that cleans up permissions on dropped resources.
AuthSchemaChangeListener() - Constructor for class org.apache.cassandra.auth.AuthSchemaChangeListener
 
authSuccess(QueryState) - Method in class org.apache.cassandra.audit.AuditLogManager
 
authSuccess(QueryState) - Method in interface org.apache.cassandra.auth.AuthEvents.Listener
 
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(boolean) - Method in class org.apache.cassandra.utils.btree.BTree.Builder
 
auto_bootstrap - Variable in class org.apache.cassandra.config.Config
 
auto_optimise_full_repair_streams - Variable in class org.apache.cassandra.config.Config
 
auto_optimise_inc_repair_streams - Variable in class org.apache.cassandra.config.Config
 
auto_optimise_preview_repair_streams - Variable in class org.apache.cassandra.config.Config
 
auto_snapshot - Variable in class org.apache.cassandra.config.Config
 
autocompaction_on_startup_enabled - Variable in class org.apache.cassandra.config.Config
 
automatic_sstable_upgrade - Variable in class org.apache.cassandra.config.Config
 
automaticSSTableUpgrade() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
autoOptimiseFullRepairStreams() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
autoOptimiseFullRepairStreams() - Method in class org.apache.cassandra.service.StorageService
 
autoOptimiseFullRepairStreams() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
autoOptimiseIncRepairStreams() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
autoOptimiseIncRepairStreams() - Method in class org.apache.cassandra.service.StorageService
 
autoOptimiseIncRepairStreams() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
autoOptimisePreviewRepairStreams() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
autoOptimisePreviewRepairStreams() - Method in class org.apache.cassandra.service.StorageService
 
autoOptimisePreviewRepairStreams() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
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.DataInputBuffer
 
available() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
 
available() - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
available() - Method in class org.apache.cassandra.io.util.NIODataInputStream
 
available() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
available() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
AVAILABLE_RANGES_V2 - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
averageLiveCellsPerSliceLastFiveMinutes - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
averageTombstonesPerSliceLastFiveMinutes - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
aVeryLongTime - Static variable in class org.apache.cassandra.gms.Gossiper
 
avgFunctionForByte - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
AVG function for byte values (tinyint).
avgFunctionForCounter - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
AVG function for counter column values.
avgFunctionForDecimal - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The AVG function for decimal values.
avgFunctionForDouble - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
AVG function for double values.
avgFunctionForFloat - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
AVG function for float values.
avgFunctionForInt32 - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
AVG function for int32 values.
avgFunctionForLong - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
AVG function for long values.
avgFunctionForShort - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
AVG function for for short values (smallint).
avgFunctionForVarint - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The AVG function for varint values.
await() - Method in class org.apache.cassandra.net.AsyncChannelPromise
 
await() - Method in class org.apache.cassandra.net.AsyncPromise
 
await(long, TimeUnit) - Method in class org.apache.cassandra.net.AsyncPromise
 
await(long) - Method in class org.apache.cassandra.net.AsyncPromise
 
await() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
 
await(long, TimeUnit) - Method in class org.apache.cassandra.service.reads.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.OpOrder.Group
 
await() - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
 
await(long, TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
 
await() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue.AbstractSignal
 
await() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
Wait until signalled, or throw an InterruptedException if interrupted before this happens.
awaitCompletion() - Method in class org.apache.cassandra.tools.BootstrapMonitor
 
awaitManagementTasksCompletion() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogSegmentManager
To be used by tests only.
awaitNanos(long) - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
 
awaitNewBarrier() - Method in class org.apache.cassandra.utils.concurrent.OpOrder
 
awaitReadRepair() - Method in class org.apache.cassandra.service.reads.AbstractReadExecutor
 
awaitReads() - Method in class org.apache.cassandra.service.reads.repair.AbstractReadRepair
 
awaitReads() - Method in class org.apache.cassandra.service.reads.repair.NoopReadRepair
 
awaitReads() - Method in interface org.apache.cassandra.service.reads.repair.ReadRepair
awaitRepairsUntil(long, TimeUnit) - Method in class org.apache.cassandra.service.reads.repair.BlockingPartitionRepair
Wait for the repair to complete util a future time If the is a past time, the method returns immediately with the repair result.
awaitResponses() - Method in class org.apache.cassandra.service.reads.AbstractReadExecutor
Wait for the CL to be satisfied by responses
awaitResults() - Method in class org.apache.cassandra.service.reads.ReadCallback
 
awaitSchemaRequests(long) - Method in class org.apache.cassandra.schema.MigrationCoordinator
Wait until we've received schema responses for all versions we're aware of
awaitTermination(long, TimeUnit) - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
 
awaitTermination(long, TimeUnit) - Method in class org.apache.cassandra.concurrent.InfiniteLoopExecutor
 
awaitTermination(long, TimeUnit) - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
awaitTermination() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogSegmentManager
Returns when the management thread terminates.
awaitTermination() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
 
awaitTermination(long, TimeUnit, ExecutorService...) - Static method in class org.apache.cassandra.utils.ExecutorUtils
 
awaitTermination(long, TimeUnit, Collection<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
 
awaitTerminationUntil(long, Collection<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
 
awaitUninterruptibly() - Method in class org.apache.cassandra.net.AsyncChannelPromise
 
awaitUninterruptibly() - Method in class org.apache.cassandra.net.AsyncPromise
 
awaitUninterruptibly(long, TimeUnit) - Method in class org.apache.cassandra.net.AsyncPromise
 
awaitUninterruptibly(long) - Method in class org.apache.cassandra.net.AsyncPromise
 
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(long) - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
 
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.
awaitUntilUninterruptibly(long) - Method in class org.apache.cassandra.utils.concurrent.WaitQueue.AbstractSignal
 
awaitUntilUninterruptibly(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.
awaitWrites() - Method in class org.apache.cassandra.service.reads.repair.BlockingReadRepair
 
awaitWrites() - Method in class org.apache.cassandra.service.reads.repair.NoopReadRepair
 
awaitWrites() - Method in class org.apache.cassandra.service.reads.repair.ReadOnlyReadRepair
 
awaitWrites() - Method in interface org.apache.cassandra.service.reads.repair.ReadRepair

B

back_pressure_enabled - Variable in class org.apache.cassandra.config.Config
Deprecated.
back_pressure_strategy - Variable in class org.apache.cassandra.config.Config
Deprecated.
BACKUPS_SUBDIR - Static variable in class org.apache.cassandra.db.Directories
 
badPartitions - Variable in class org.apache.cassandra.db.compaction.Scrubber.ScrubResult
 
badUse(Exception) - Method in class org.apache.cassandra.tools.NodeTool
 
ballot - Variable in class org.apache.cassandra.service.paxos.Commit
 
bar(long, int, String, boolean) - Method in class org.apache.cassandra.tools.Util.TermHistogram
 
Barrier() - Constructor for class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
 
BASE_SAMPLING_LEVEL - Static variable in class org.apache.cassandra.io.sstable.Downsampling
The base (down)sampling level determines the granularity at which we can down/upsample.
BASE_TIME_KEY - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
baseCfs - Variable in class org.apache.cassandra.index.internal.CassandraIndex
 
baseCfs - Variable in class org.apache.cassandra.index.SecondaryIndexManager
The underlying column family containing the source data for these indexes
baseFilename() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
baseNonPKColumnsInViewPK - Variable in class org.apache.cassandra.db.view.View
 
BasePartitionIterator<I extends BaseRowIterator<?>> - Interface in org.apache.cassandra.db.partitions
 
BasePartitions<R extends BaseRowIterator<?>,I extends BasePartitionIterator<? extends BaseRowIterator<?>>> - Class in org.apache.cassandra.db.transform
 
BasePartitions(I) - Constructor for class org.apache.cassandra.db.transform.BasePartitions
 
BaseRowIterator<U extends Unfiltered> - Interface in org.apache.cassandra.db.rows
A common interface for Row and Unfiltered, that permits sharing of the (majority) common methods and functionality
BaseRows<R extends Unfiltered,I extends BaseRowIterator<? extends Unfiltered>> - Class in org.apache.cassandra.db.transform
 
BaseRows(I) - Constructor for class org.apache.cassandra.db.transform.BaseRows
 
baseTableId - Variable in class org.apache.cassandra.schema.ViewMetadata
 
baseTableMetadata() - Method in class org.apache.cassandra.schema.ViewMetadata
 
baseTableName - Variable in class org.apache.cassandra.schema.ViewMetadata
 
baseTime - Variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
baseType - Variable in class org.apache.cassandra.db.marshal.ReversedType
 
Basic(long) - Constructor for class org.apache.cassandra.net.ResourceLimits.Basic
 
BasicResultFilters - Class in org.apache.cassandra.index.sasi.analyzer.filter
Basic/General Token Filters
BasicResultFilters() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.BasicResultFilters
 
BasicResultFilters.LowerCase - Class in org.apache.cassandra.index.sasi.analyzer.filter
 
BasicResultFilters.NoOperation - Class in org.apache.cassandra.index.sasi.analyzer.filter
 
BasicResultFilters.UpperCase - Class in org.apache.cassandra.index.sasi.analyzer.filter
 
Batch - Class in org.apache.cassandra.batchlog
 
BATCH - Static variable in class org.apache.cassandra.fql.FullQueryLogger
 
Batch(BatchStatement.Type, List<String>, List<List<ByteBuffer>>, QueryOptions, QueryState, long) - Constructor for class org.apache.cassandra.fql.FullQueryLogger.Batch
 
Batch.Serializer - Class in org.apache.cassandra.batchlog
 
batch_size_fail_threshold_in_kb - Variable in class org.apache.cassandra.config.Config
 
batch_size_warn_threshold_in_kb - Variable in class org.apache.cassandra.config.Config
 
BATCH_THRESHOLD - Static variable in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
 
BATCH_TYPE - Static variable in class org.apache.cassandra.fql.FullQueryLogger
 
BATCHES - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
Batches - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
batchFailure(BatchStatement.Type, List<? extends CQLStatement>, List<String>, List<List<ByteBuffer>>, QueryOptions, QueryState, Exception) - Method in class org.apache.cassandra.audit.AuditLogManager
 
batchFailure(BatchStatement.Type, List<? extends CQLStatement>, List<String>, List<List<ByteBuffer>>, QueryOptions, QueryState, Exception) - Method in interface org.apache.cassandra.cql3.QueryEvents.Listener
 
batchlog_replay_throttle_in_kb - Variable in class org.apache.cassandra.config.Config
 
BATCHLOG_REPLAY_TIMEOUT - Static variable in class org.apache.cassandra.batchlog.BatchlogManager
 
BatchlogCleanup(int, BatchlogResponseHandler.BatchlogCleanupCallback) - Constructor for class org.apache.cassandra.service.BatchlogResponseHandler.BatchlogCleanup
 
BatchlogManager - Class in org.apache.cassandra.batchlog
 
BatchlogManager() - Constructor for class org.apache.cassandra.batchlog.BatchlogManager
 
BatchlogManagerMBean - Interface in org.apache.cassandra.batchlog
 
BatchlogResponseHandler<T> - Class in org.apache.cassandra.service
 
BatchlogResponseHandler(AbstractWriteResponseHandler<T>, int, BatchlogResponseHandler.BatchlogCleanup, long) - Constructor for class org.apache.cassandra.service.BatchlogResponseHandler
 
BatchlogResponseHandler.BatchlogCleanup - Class in org.apache.cassandra.service
 
BatchlogResponseHandler.BatchlogCleanupCallback - Interface in org.apache.cassandra.service
 
BatchMessage - Class in org.apache.cassandra.transport.messages
 
BatchMessage(BatchStatement.Type, List<Object>, List<List<ByteBuffer>>, QueryOptions) - Constructor for class org.apache.cassandra.transport.messages.BatchMessage
 
BatchMetrics - Class in org.apache.cassandra.metrics
 
BatchMetrics() - Constructor for class org.apache.cassandra.metrics.BatchMetrics
 
BatchQueryOptions - Class in org.apache.cassandra.cql3
 
BatchQueryOptions(QueryOptions, List<Object>) - Constructor for class org.apache.cassandra.cql3.BatchQueryOptions
 
BatchRemoveVerbHandler - Class in org.apache.cassandra.batchlog
 
BatchRemoveVerbHandler() - Constructor for class org.apache.cassandra.batchlog.BatchRemoveVerbHandler
 
BatchStatement - Class in org.apache.cassandra.cql3.statements
A BATCH statement parsed from a CQL query.
BatchStatement(BatchStatement.Type, VariableSpecifications, List<ModificationStatement>, Attributes) - Constructor for class org.apache.cassandra.cql3.statements.BatchStatement
Creates a new BatchStatement.
BatchStatement.Parsed - Class in org.apache.cassandra.cql3.statements
 
BatchStatement.Type - Enum in org.apache.cassandra.cql3.statements
 
BatchStoreVerbHandler - Class in org.apache.cassandra.batchlog
 
BatchStoreVerbHandler() - Constructor for class org.apache.cassandra.batchlog.BatchStoreVerbHandler
 
batchSuccess(BatchStatement.Type, List<? extends CQLStatement>, List<String>, List<List<ByteBuffer>>, QueryOptions, QueryState, long, Message.Response) - Method in class org.apache.cassandra.audit.AuditLogManager
 
batchSuccess(BatchStatement.Type, List<? extends CQLStatement>, List<String>, List<List<ByteBuffer>>, QueryOptions, QueryState, long, Message.Response) - Method in interface org.apache.cassandra.cql3.QueryEvents.Listener
 
batchSuccess(BatchStatement.Type, List<? extends CQLStatement>, List<String>, List<List<ByteBuffer>>, QueryOptions, QueryState, long, Message.Response) - Method in class org.apache.cassandra.fql.FullQueryLogger
Log an invocation of a batch of queries
batchType - Variable in class org.apache.cassandra.transport.messages.BatchMessage
 
before - Variable in class org.apache.cassandra.schema.Diff.Altered
 
before - Variable in class org.apache.cassandra.schema.KeyspaceMetadata.KeyspaceDiff
 
beforeAppend(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
Perform sanity checks on @param decoratedKey and @return the position in the data file before any data is written
beforeChange(InetAddressAndPort, EndpointState, ApplicationState, VersionedValue) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
beforeChange(InetAddressAndPort, EndpointState, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.locator.ReconnectableSnitchHelper
 
beforeChange(InetAddressAndPort, EndpointState, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.repair.RepairSession
 
beforeChange(InetAddressAndPort, EndpointState, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.ActiveRepairService
 
beforeChange(InetAddressAndPort, EndpointState, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
beforeChange(InetAddressAndPort, EndpointState, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.StorageService
 
beforeChange(InetAddressAndPort, EndpointState, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.streaming.StreamSession
 
beforeExecute(Thread, Runnable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
begin() - Method in interface org.apache.cassandra.index.Index.Indexer
Notification of the start of a partition update.
begin() - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
 
begin() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFlushObserver
Called before writing any data to the sstable.
begin(String, Map<String, String>) - Method in class org.apache.cassandra.tracing.Tracing
 
begin(String, InetAddress, Map<String, String>) - Method in class org.apache.cassandra.tracing.Tracing
 
beginCompaction(CompactionInfo.Holder) - Method in class org.apache.cassandra.db.compaction.ActiveCompactions
 
beginCompaction(CompactionInfo.Holder) - Method in interface org.apache.cassandra.db.compaction.ActiveCompactionsTracker
 
beginFlush(int, int, int) - Method in class org.apache.cassandra.net.AsyncChannelOutputPlus
Create a ChannelPromise for a flush of the given size.
beginLocalSampling(String, int, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
beginLocalSampling(String, int, int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
begin sampling for a specific sampler with a given capacity.
beginSampling(int, int) - Method in class org.apache.cassandra.metrics.FrequencySampler
Start to record samples
beginSampling(int, int) - Method in class org.apache.cassandra.metrics.MaxSampler
 
beginSampling(int, int) - Method in class org.apache.cassandra.metrics.Sampler
 
beginWrite(Mutation, boolean) - Method in class org.apache.cassandra.db.CassandraKeyspaceWriteHandler
 
beginWrite(Mutation, boolean) - Method in interface org.apache.cassandra.db.KeyspaceWriteHandler
 
BEST_COMPRESSION_LEVEL - Static variable in class org.apache.cassandra.io.compress.ZstdCompressor
 
BETA - Static variable in enum org.apache.cassandra.transport.ProtocolVersion
 
BetweenParenthesesOrWithTuple(List<Selectable>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.BetweenParenthesesOrWithTuple
 
bf - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
bf - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
bf(IFilter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
BigFormat - Class in org.apache.cassandra.io.sstable.format.big
Legacy bigtable format
bigint() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the BIGINT type.
bigint() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type bigint.
BigIntegerToken(BigInteger) - Constructor for class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
 
BigIntegerToken(String) - Constructor for class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
 
BigTableReader - Class in org.apache.cassandra.io.sstable.format.big
SSTableReaders are open()ed by Keyspace.onStart; after that they are created by SSTableWriter.renameAndOpen.
BigTableScanner - Class in org.apache.cassandra.io.sstable.format.big
 
BigTableScanner.EmptySSTableScanner - Class in org.apache.cassandra.io.sstable.format.big
 
BigTableScanner.KeyScanningIterator - Class in org.apache.cassandra.io.sstable.format.big
 
BigTableWriter - Class in org.apache.cassandra.io.sstable.format.big
 
BigTableWriter(Descriptor, long, long, UUID, boolean, TableMetadataRef, MetadataCollector, SerializationHeader, Collection<SSTableFlushObserver>, LifecycleNewTracker) - Constructor for class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
BigTableZeroCopyWriter - Class in org.apache.cassandra.io.sstable.format.big
 
BigTableZeroCopyWriter(Descriptor, TableMetadataRef, LifecycleNewTracker, Collection<Component>) - Constructor for class org.apache.cassandra.io.sstable.format.big.BigTableZeroCopyWriter
 
BiLongAccumulator<T,A> - Interface in org.apache.cassandra.utils
 
BiMultiValMap<K,V> - Class in org.apache.cassandra.utils
A variant of BiMap which does not enforce uniqueness of values.
BiMultiValMap() - Constructor for class org.apache.cassandra.utils.BiMultiValMap
 
BiMultiValMap(Map<K, V>, Multimap<V, K>) - Constructor for class org.apache.cassandra.utils.BiMultiValMap
 
BiMultiValMap(BiMultiValMap<K, V>) - Constructor for class org.apache.cassandra.utils.BiMultiValMap
 
binarySearch(PartitionPosition) - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
binarySearchAsymmetric(List<? extends T1>, T2, AsymmetricOrdering.Op) - Method in class org.apache.cassandra.utils.AsymmetricOrdering
 
BinAuditLogger - Class in org.apache.cassandra.audit
 
BinAuditLogger(Map<String, String>) - Constructor for class org.apache.cassandra.audit.BinAuditLogger
 
BinAuditLogger.Message - Class in org.apache.cassandra.audit
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.conditions.ColumnCondition
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Constants.Marker
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.functions.FunctionCall
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Lists.DelayedValue
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Lists.Marker
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Maps.DelayedValue
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Maps.Marker
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Sets.DelayedValue
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Sets.Marker
 
bind(QueryOptions) - Method in interface org.apache.cassandra.cql3.Term
Bind the values in this term to the values contained in values.
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Term.Terminal
 
bind(QueryOptions) - Method in interface org.apache.cassandra.cql3.Terms
Bind the values in these terms to the values contained in options.
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Tuples.DelayedValue
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Tuples.InMarker
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.Tuples.Marker
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.UserTypes.DelayedValue
 
bind(QueryOptions) - Method in class org.apache.cassandra.cql3.UserTypes.Marker
 
bind(InboundConnectionSettings, ChannelGroup, Consumer<ChannelPipeline>) - Static method in class org.apache.cassandra.net.InboundConnectionInitiator
 
bindAddress - Variable in class org.apache.cassandra.net.InboundConnectionSettings
 
bindAndGet(QueryOptions) - Method in class org.apache.cassandra.cql3.Constants.Marker
 
bindAndGet(QueryOptions) - Method in class org.apache.cassandra.cql3.Constants.Value
 
bindAndGet(QueryOptions) - Method in class org.apache.cassandra.cql3.functions.FunctionCall
 
bindAndGet(QueryOptions) - Method in interface org.apache.cassandra.cql3.Term
A shorter for bind(values).get().
bindAndGet(QueryOptions) - Method in class org.apache.cassandra.cql3.Term.NonTerminal
 
bindAndGet(QueryOptions) - Method in class org.apache.cassandra.cql3.Term.Terminal
 
bindAndGet(QueryOptions) - Method in interface org.apache.cassandra.cql3.Terms
 
bindAndGet(QueryOptions) - Method in class org.apache.cassandra.cql3.Tuples.DelayedValue
 
bindAndGet(QueryOptions) - Method in class org.apache.cassandra.cql3.UserTypes.DelayedValue
 
bindAndGetTerms(QueryOptions) - Method in class org.apache.cassandra.cql3.conditions.ColumnCondition
 
bindIndex - Variable in class org.apache.cassandra.cql3.AbstractMarker
 
bindIndex - Variable in class org.apache.cassandra.cql3.AbstractMarker.MultiColumnRaw
 
bindIndex - Variable in class org.apache.cassandra.cql3.AbstractMarker.Raw
 
bindIndex - Variable in class org.apache.cassandra.cql3.Json.Marker
 
bindTerms(QueryOptions) - Method in class org.apache.cassandra.cql3.conditions.ColumnCondition
 
bindVariables - Variable in class org.apache.cassandra.cql3.CQLStatement.Raw
 
bindVariables - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement
 
bindVariables - Variable in class org.apache.cassandra.cql3.statements.SelectStatement
 
BinLog - Class in org.apache.cassandra.utils.binlog
Bin log is a is quick and dirty binary log that is kind of a NIH version of binary logging with a traditional logging framework.
BinLog.Builder - Class in org.apache.cassandra.utils.binlog
 
BinLog.ReleaseableWriteMarshallable - Class in org.apache.cassandra.utils.binlog
 
BinLogArchiver - Interface in org.apache.cassandra.utils.binlog
 
BinLogOptions - Class in org.apache.cassandra.utils.binlog
 
BinLogOptions() - Constructor for class org.apache.cassandra.utils.binlog.BinLogOptions
 
bitIndex(K, K) - Method in interface org.apache.cassandra.index.sasi.utils.trie.KeyAnalyzer
Returns the index of the first bit that is different in the two keys.
bitset - Variable in class org.apache.cassandra.utils.BloomFilter
 
BLANK - Static variable in class org.apache.cassandra.db.ClockAndCount
 
blob() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the BLOB type.
blob() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type blob.
BlobAsVarcharFct - Static variable in class org.apache.cassandra.cql3.functions.BytesConversionFcts
 
block - Variable in class org.apache.cassandra.utils.binlog.BinLogOptions
Indicates if the BinLog should block if the it falls behind or should drop bin log records.
block(boolean) - Method in class org.apache.cassandra.utils.concurrent.Blocker
 
BLOCK_BYTES - Static variable in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
BLOCK_ENTRY_BYTES - Static variable in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
block_for_peers_in_remote_dcs - Variable in class org.apache.cassandra.config.Config
 
block_for_peers_timeout_in_secs - Variable in class org.apache.cassandra.config.Config
When a node first starts up it intially considers all other peers as DOWN and is disconnected from all of them.
BLOCK_HEADER_BYTES - Static variable in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
BLOCK_SIZE - Static variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
 
blockCount - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.Level
 
blockedOnAllocating - Variable in class org.apache.cassandra.utils.memory.MemtablePool
 
blockedTimerContext() - Method in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
 
Blocker - Class in org.apache.cassandra.utils.concurrent
 
Blocker() - Constructor for class org.apache.cassandra.utils.concurrent.Blocker
 
blockFor(AbstractReplicationStrategy) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
blockFor - Variable in exception org.apache.cassandra.exceptions.CasWriteUnknownResultException
 
blockFor - Variable in exception org.apache.cassandra.exceptions.RequestFailureException
 
blockFor - Variable in exception org.apache.cassandra.exceptions.RequestTimeoutException
 
blockFor() - Method in class org.apache.cassandra.locator.ReplicaPlan
 
blockFor() - Method in class org.apache.cassandra.locator.ReplicaPlan.ForRead
 
blockFor() - Method in class org.apache.cassandra.locator.ReplicaPlan.ForWrite
 
blockFor() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
blockFor() - Method in class org.apache.cassandra.service.BatchlogResponseHandler
 
blockFor() - Method in class org.apache.cassandra.service.reads.ReadCallback
 
blockForWrite(AbstractReplicationStrategy, Endpoints<?>) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
blockForWrites() - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
Flushes all keyspaces associated with this replayer in parallel, blocking until their flushes are complete.
blockIndex - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
 
blockIndexSize - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
 
blocking(boolean) - Method in class org.apache.cassandra.utils.binlog.BinLog.Builder
 
blockingExecutionHandler - Static variable in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
BlockingPartitionRepair - Class in org.apache.cassandra.service.reads.repair
 
BlockingPartitionRepair(DecoratedKey, Map<Replica, Mutation>, ReplicaPlan.ForTokenWrite) - Constructor for class org.apache.cassandra.service.reads.repair.BlockingPartitionRepair
 
BlockingPartitionRepair(DecoratedKey, Map<Replica, Mutation>, ReplicaPlan.ForTokenWrite, Predicate<InetAddressAndPort>) - Constructor for class org.apache.cassandra.service.reads.repair.BlockingPartitionRepair
 
BlockingReadRepair<E extends Endpoints<E>,P extends ReplicaPlan.ForRead<E>> - Class in org.apache.cassandra.service.reads.repair
'Classic' read repair.
BlockingReadRepairs - Class in org.apache.cassandra.service.reads.repair
 
BlockingReadRepairs() - Constructor for class org.apache.cassandra.service.reads.repair.BlockingReadRepairs
 
blockOffsets - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.Level
 
blocksCount() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
 
blockUntilFinished() - Method in class org.apache.cassandra.service.PendingRangeCalculatorService
 
BloomCalculations - Class in org.apache.cassandra.utils
The following calculations are taken from: http://www.cs.wisc.edu/~cao/papers/summary-cache/node8.html "Bloom Filters - the math" This class's static methods are meant to facilitate the use of the Bloom Filter class by helping to choose correct values of 'bits per element' and 'number of hash functions, k'.
BloomCalculations() - Constructor for class org.apache.cassandra.utils.BloomCalculations
 
BloomCalculations.BloomSpecification - Class in org.apache.cassandra.utils
A wrapper class that holds two key parameters for a Bloom Filter: the number of hash functions used, and the number of buckets per element used.
BloomFilter - Class in org.apache.cassandra.utils
 
bloomFilterDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Disk space used by bloom filter
bloomFilterDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.TableMetrics
Disk space used by bloom filter
bloomFilterFalsePositives - Variable in class org.apache.cassandra.metrics.TableMetrics
Number of false positives in bloom filter
bloomFilterFalsePositives - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
bloomFilterFalseRatio - Variable in class org.apache.cassandra.metrics.TableMetrics
False positive ratio of bloom filter
bloomFilterFalseRatio - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
bloomFilterFPChance - Variable in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
 
bloomFilterFpChance(double) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
bloomFilterFpChance - Variable in class org.apache.cassandra.schema.TableParams
 
bloomFilterFpChance(double) - Method in class org.apache.cassandra.schema.TableParams.Builder
 
bloomFilterOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Off heap memory used by bloom filter
bloomFilterOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.TableMetrics
Off heap memory used by bloom filter
bloomFilterOffHeapMemoryUsed - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
bloomFilterOffHeapUsed - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
BloomFilterSerializer - Class in org.apache.cassandra.utils
 
bloomFilterSpaceUsed - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
BloomFilterTracker - Class in org.apache.cassandra.io.sstable
 
BloomFilterTracker() - Constructor for class org.apache.cassandra.io.sstable.BloomFilterTracker
 
bloomFilterTracker - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
BloomSpecification(int, int) - Constructor for class org.apache.cassandra.utils.BloomCalculations.BloomSpecification
 
bmProxy - Variable in class org.apache.cassandra.tools.NodeProbe
 
body - Variable in class org.apache.cassandra.cql3.functions.UDFunction
 
body() - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
body - Variable in class org.apache.cassandra.transport.Envelope
 
BODY_LENGTH_SIZE - Static variable in class org.apache.cassandra.transport.Envelope.Header
 
bodySizeInBytes - Variable in class org.apache.cassandra.transport.Envelope.Header
 
bool(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
 
BOOL_SIZE - Static variable in class org.apache.cassandra.db.TypeSizes
 
BooleanSerializer - Class in org.apache.cassandra.serializers
 
BooleanSerializer() - Constructor for class org.apache.cassandra.serializers.BooleanSerializer
 
BooleanSerializer - Class in org.apache.cassandra.utils
 
BooleanSerializer() - Constructor for class org.apache.cassandra.utils.BooleanSerializer
 
BooleanType - Class in org.apache.cassandra.db.marshal
 
bootReplacing(InetAddress) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
Deprecated.
bootReplacingWithPort(InetAddressAndPort) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
bootstrap(StreamStateStore, boolean) - Method in class org.apache.cassandra.dht.BootStrapper
 
bootstrap(Collection<Token>, long) - Method in class org.apache.cassandra.service.StorageService
Bootstrap node by fetching data from other nodes.
bootstrap - Variable in class org.apache.cassandra.transport.SimpleClient
 
bootstrapComplete() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
bootstrapInProgress() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
BootstrapMonitor - Class in org.apache.cassandra.tools
 
BootstrapMonitor(PrintStream) - Constructor for class org.apache.cassandra.tools.BootstrapMonitor
 
BootStrapper - Class in org.apache.cassandra.dht
 
BootStrapper(InetAddressAndPort, Collection<Token>, TokenMetadata) - Constructor for class org.apache.cassandra.dht.BootStrapper
 
bootstrapping(Collection<Token>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
BootstrapResume - Class in org.apache.cassandra.tools.nodetool
 
BootstrapResume() - Constructor for class org.apache.cassandra.tools.nodetool.BootstrapResume
 
BOTTOM - Static variable in interface org.apache.cassandra.db.ClusteringBound
The smallest start bound, i.e.
BOTTOM - Static variable in class org.apache.cassandra.db.rows.CellPath
 
Bound(ColumnMetadata, Operator) - Constructor for class org.apache.cassandra.cql3.conditions.ColumnCondition.Bound
 
Bound - Enum in org.apache.cassandra.cql3.statements
 
bound(ClusteringPrefix.Kind, V...) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor.ObjectFactory
 
bound(ClusteringPrefix.Kind) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor.ObjectFactory
 
bound - Variable in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
 
Bound(ByteBuffer, boolean) - Constructor for class org.apache.cassandra.index.sasi.plan.Expression.Bound
 
boundary(ClusteringPrefix.Kind, V...) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor.ObjectFactory
 
Boundary(T, boolean) - Constructor for class org.apache.cassandra.dht.AbstractBounds.Boundary
 
boundary - Variable in class org.apache.cassandra.dht.AbstractBounds.Boundary
 
boundKind(boolean, boolean) - Static method in interface org.apache.cassandra.db.ClusteringBound
 
boundOrBoundary(ClusteringPrefix.Kind, V...) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor.ObjectFactory
 
bounds(Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQRestriction
 
bounds(Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.SliceRestriction
 
bounds(AbstractBounds.Boundary<T>, AbstractBounds.Boundary<T>) - Static method in class org.apache.cassandra.dht.AbstractBounds
 
bounds(T, boolean, T, boolean) - Static method in class org.apache.cassandra.dht.AbstractBounds
 
Bounds<T extends RingPosition<T>> - Class in org.apache.cassandra.dht
AbstractBounds containing both its endpoints: [left, right].
Bounds(T, T) - Constructor for class org.apache.cassandra.dht.Bounds
 
broadcast_address - Variable in class org.apache.cassandra.config.Config
 
broadcast_rpc_address - Variable in class org.apache.cassandra.config.Config
 
BTree - Class in org.apache.cassandra.utils.btree
 
BTree() - Constructor for class org.apache.cassandra.utils.btree.BTree
 
BTree.Builder<V> - Class in org.apache.cassandra.utils.btree
 
BTree.Builder.QuickResolver<V> - Interface in org.apache.cassandra.utils.btree
 
BTree.Builder.Resolver - Interface in org.apache.cassandra.utils.btree
 
BTree.Dir - Enum in org.apache.cassandra.utils.btree
 
BTreeRemoval - Class in org.apache.cassandra.utils.btree
 
BTreeRemoval() - Constructor for class org.apache.cassandra.utils.btree.BTreeRemoval
 
BTreeRow - Class in org.apache.cassandra.db.rows
Immutable implementation of a Row object.
BTreeRow.Builder - Class in org.apache.cassandra.db.rows
 
BTreeSearchIterator<K,V> - Interface in org.apache.cassandra.utils.btree
 
BTreeSet<V> - Class in org.apache.cassandra.utils.btree
 
BTreeSet(Object[], Comparator<? super V>) - Constructor for class org.apache.cassandra.utils.btree.BTreeSet
 
BTreeSet.BTreeDescRange<V> - Class in org.apache.cassandra.utils.btree
 
BTreeSet.BTreeRange<V> - Class in org.apache.cassandra.utils.btree
 
BTreeSet.Builder<V> - Class in org.apache.cassandra.utils.btree
 
BUCKET_HIGH_KEY - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
BUCKET_LOW_KEY - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
bucketHigh - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
bucketLow - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
buffer() - Method in class org.apache.cassandra.db.ColumnIndex
 
buffer - Variable in class org.apache.cassandra.db.marshal.ValueComparators
 
buffer() - Method in class org.apache.cassandra.db.rows.Cell
 
buffer - Variable in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
buffer - Variable in class org.apache.cassandra.io.util.BufferManagingRebufferer
 
buffer() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
 
buffer() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
buffer(boolean) - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
buffer() - Method in class org.apache.cassandra.io.util.LimitingRebufferer
 
buffer - Variable in class org.apache.cassandra.io.util.MmappedRegions.Region
 
buffer() - Method in class org.apache.cassandra.io.util.MmappedRegions.Region
 
buffer() - Method in interface org.apache.cassandra.io.util.Rebufferer.BufferHolder
Returns a useable buffer (i.e.
buffer - Variable in class org.apache.cassandra.io.util.RebufferingInputStream
 
buffer - Variable in class org.apache.cassandra.net.FrameEncoder.Payload
 
buffer_pool_use_heap_if_exhausted - Variable in class org.apache.cassandra.config.Config
Deprecated.
BUFFER_SIZE_IN_MB - Static variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
bufferAt(int) - Method in interface org.apache.cassandra.db.ClusteringPrefix
 
BufferCell - Class in org.apache.cassandra.db.rows
 
BufferCell(ColumnMetadata, long, int, int, ByteBuffer, CellPath) - Constructor for class org.apache.cassandra.db.rows.BufferCell
 
BufferClustering - Class in org.apache.cassandra.db
The clustering column values for a row.
BufferClustering(ByteBuffer...) - Constructor for class org.apache.cassandra.db.BufferClustering
 
BufferClusteringBound - Class in org.apache.cassandra.db
 
BufferClusteringBound(ClusteringPrefix.Kind, ByteBuffer[]) - Constructor for class org.apache.cassandra.db.BufferClusteringBound
 
BufferClusteringBoundary - Class in org.apache.cassandra.db
 
BufferClusteringBoundary(ClusteringPrefix.Kind, ByteBuffer[]) - Constructor for class org.apache.cassandra.db.BufferClusteringBoundary
 
BufferClusteringBoundOrBoundary - Class in org.apache.cassandra.db
 
BufferDecoratedKey - Class in org.apache.cassandra.db
 
BufferDecoratedKey(Token, ByteBuffer) - Constructor for class org.apache.cassandra.db.BufferDecoratedKey
 
BufferedDataOutputStreamPlus - Class in org.apache.cassandra.io.util
An implementation of the DataOutputStreamPlus interface using a ByteBuffer to stage writes before flushing them to an underlying channel.
BufferedDataOutputStreamPlus(RandomAccessFile) - Constructor for class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
BufferedDataOutputStreamPlus(RandomAccessFile, int) - Constructor for class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
BufferedDataOutputStreamPlus(FileOutputStream) - Constructor for class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
BufferedDataOutputStreamPlus(FileOutputStream, int) - Constructor for class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
BufferedDataOutputStreamPlus(WritableByteChannel) - Constructor for class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
BufferedDataOutputStreamPlus(WritableByteChannel, int) - Constructor for class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
BufferedDataOutputStreamPlus(WritableByteChannel, ByteBuffer) - Constructor for class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
BufferedDataOutputStreamPlus(ByteBuffer) - Constructor for class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
BufferedFileWriterMark(long) - Constructor for class org.apache.cassandra.io.util.SequentialWriter.BufferedFileWriterMark
 
BufferManagingRebufferer - Class in org.apache.cassandra.io.util
Buffer manager used for reading from a ChunkReader when cache is not in use.
BufferManagingRebufferer(ChunkReader) - Constructor for class org.apache.cassandra.io.util.BufferManagingRebufferer
 
BufferManagingRebufferer.Aligned - Class in org.apache.cassandra.io.util
 
BufferManagingRebufferer.Unaligned - Class in org.apache.cassandra.io.util
 
bufferOffset - Variable in class org.apache.cassandra.hints.ChecksummedDataInput
 
bufferOffset - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
bufferPool - Static variable in class org.apache.cassandra.net.FrameEncoder
 
BufferPool - Class in org.apache.cassandra.utils.memory
A pool of ByteBuffers that can be recycled to reduce system direct memory fragmentation and improve buffer allocation performance.
BufferPool(String, long, boolean) - Constructor for class org.apache.cassandra.utils.memory.BufferPool
 
BufferPool.LocalPool - Class in org.apache.cassandra.utils.memory
A thread local class that grabs chunks from the global pool for this thread allocations.
BufferPoolAllocator - Class in org.apache.cassandra.net
A trivial wrapper around BufferPool for integrating with Netty, but retaining ownership of pooling behaviour that is integrated into Cassandra's other pooling.
BufferPoolAllocator.Wrapped - Class in org.apache.cassandra.net
A simple extension to UnpooledUnsafeDirectByteBuf that returns buffers to BufferPool on deallocate, and permits extracting the buffer from it to take ownership and use directly.
BufferPoolMetrics - Class in org.apache.cassandra.metrics
 
BufferPoolMetrics(String, BufferPool) - Constructor for class org.apache.cassandra.metrics.BufferPoolMetrics
 
BufferPools - Class in org.apache.cassandra.utils.memory
 
BufferPools() - Constructor for class org.apache.cassandra.utils.memory.BufferPools
 
buffers - Variable in class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
 
bufferSize - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
bufferSize(long) - Method in interface org.apache.cassandra.io.util.DiskOptimizationStrategy
 
bufferSize(int) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
Set the buffer size to use (if appropriate).
bufferSize() - Method in class org.apache.cassandra.io.util.SequentialWriterOption
 
bufferSize(int) - Method in class org.apache.cassandra.io.util.SequentialWriterOption.Builder
 
bufferSize(long) - Method in class org.apache.cassandra.io.util.SpinningDiskOptimizationStrategy
For spinning disks always add one page.
bufferSize(long) - Method in class org.apache.cassandra.io.util.SsdDiskOptimizationStrategy
For solid state disks only add one page if the chance of crossing to the next page is more than a predifined value.
BufferType - Enum in org.apache.cassandra.io.compress
 
bufferType(BufferType) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
Set the buffer type (on heap or off heap) to use (if appropriate).
bufferType() - Method in class org.apache.cassandra.io.util.SequentialWriterOption
 
bufferType(BufferType) - Method in class org.apache.cassandra.io.util.SequentialWriterOption.Builder
 
build() - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
 
build() - Method in class org.apache.cassandra.auth.DCPermissions.Builder
 
build() - Method in class org.apache.cassandra.cql3.conditions.ColumnConditions.Builder
 
build() - Method in class org.apache.cassandra.cql3.selection.ResultSetBuilder
Builds the ResultSet
build() - Method in class org.apache.cassandra.cql3.WhereClause.Builder
 
build() - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
build() - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder.PartitionRangeBuilder
 
build() - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder.SinglePartitionBuilder
 
build() - Method in class org.apache.cassandra.db.CBuilder
 
build() - Method in class org.apache.cassandra.db.commitlog.IntervalSet.Builder
 
build() - Method in class org.apache.cassandra.db.compaction.Verifier.Options.Builder
 
build() - Method in class org.apache.cassandra.db.filter.ColumnFilter.Builder
 
build(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.lifecycle.SSTableIntervalTree
 
build(ValueAccessor<V>, V...) - Static method in class org.apache.cassandra.db.marshal.CompositeType
 
build(ValueAccessor<V>, boolean, V...) - Static method in class org.apache.cassandra.db.marshal.CompositeType
 
build() - Method in class org.apache.cassandra.db.MultiCBuilder
Builds the clusterings.
build() - Method in class org.apache.cassandra.db.MutableDeletionInfo.Builder
 
build() - Method in class org.apache.cassandra.db.Mutation.PartitionUpdateCollector
 
build() - Method in interface org.apache.cassandra.db.Mutation.SimpleBuilder
Build the mutation represented by this builder.
build(UnfilteredRowIterator, int) - Static method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
build(UnfilteredRowIterator, int, boolean) - Static method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
build(RowIterator, DeletionInfo, boolean, int) - Static method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
build() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
 
build() - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder
Build the update represented by this builder.
build() - Method in class org.apache.cassandra.db.RegularAndStaticColumns.Builder
 
build() - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
 
build() - Method in class org.apache.cassandra.db.rows.ComplexColumnData.Builder
 
build() - Method in interface org.apache.cassandra.db.rows.Row.Builder
Builds and return built row.
build() - Method in interface org.apache.cassandra.db.rows.Row.SimpleBuilder
Returns the built row.
build() - Method in class org.apache.cassandra.db.SimpleBuilders.MutationBuilder
 
build() - Method in class org.apache.cassandra.db.SimpleBuilders.PartitionUpdateBuilder
 
build() - Method in class org.apache.cassandra.db.SimpleBuilders.RowBuilder
 
build() - Method in class org.apache.cassandra.db.Slices.Builder
 
build() - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.Builder
 
build() - Method in class org.apache.cassandra.db.view.TableViews
 
build() - Method in class org.apache.cassandra.db.view.View
 
build() - Method in class org.apache.cassandra.index.internal.CollatedViewIndexBuilder
 
build() - Method in class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineBuilder
 
build() - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions.OptionsBuilder
 
build() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
 
build() - Method in class org.apache.cassandra.index.sasi.conf.view.PrefixTermTree.Builder
 
build() - Method in class org.apache.cassandra.index.sasi.conf.view.TermTree.Builder
 
build(Expression, Set<SSTableIndex>) - Static method in class org.apache.cassandra.index.sasi.TermIterator
 
build() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
 
build(List<RangeIterator<K, D>>) - Static method in class org.apache.cassandra.index.sasi.utils.RangeUnionIterator
 
build() - Method in class org.apache.cassandra.index.SecondaryIndexBuilder
 
build() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
 
build() - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
build() - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder.ForBatch
 
build() - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder.ForRead
 
build() - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder.ForWriter
 
build(IPartitioner) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
build(IPartitioner, IndexSummaryBuilder.ReadableBoundary) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
build() - Method in class org.apache.cassandra.io.sstable.SSTableHeaderFix.Builder
 
build() - Method in class org.apache.cassandra.io.util.SequentialWriterOption.Builder
 
build() - Method in class org.apache.cassandra.locator.EndpointsByRange.Builder
 
build() - Method in class org.apache.cassandra.locator.EndpointsByReplica.Builder
 
build() - Method in class org.apache.cassandra.locator.EndpointsForRange.Builder
 
build() - Method in class org.apache.cassandra.locator.EndpointsForToken.Builder
 
build() - Method in class org.apache.cassandra.locator.RangesAtEndpoint.Builder
 
build() - Method in class org.apache.cassandra.locator.RangesByEndpoint.Builder
 
build() - Method in interface org.apache.cassandra.locator.ReplicaCollection.Builder
 
build() - Method in class org.apache.cassandra.net.Message.Builder
 
build() - Method in class org.apache.cassandra.repair.consistent.admin.PendingStat.Builder
 
build() - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession.Builder
 
build() - Method in class org.apache.cassandra.repair.consistent.LocalSession.Builder
 
build() - Method in class org.apache.cassandra.schema.Functions.Builder
 
build() - Method in class org.apache.cassandra.schema.Indexes.Builder
 
build() - Method in class org.apache.cassandra.schema.Keyspaces.Builder
 
build() - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
build() - Method in class org.apache.cassandra.schema.TableParams.Builder
 
build() - Method in class org.apache.cassandra.schema.Tables.Builder
 
build() - Method in class org.apache.cassandra.schema.Triggers.Builder
 
build() - Method in class org.apache.cassandra.schema.Types.Builder
 
build() - Method in class org.apache.cassandra.schema.Types.RawBuilder
Build a Types instance from Raw definitions.
build() - Method in class org.apache.cassandra.schema.Views.Builder
 
build() - Method in class org.apache.cassandra.transport.Server.Builder
 
build() - Method in class org.apache.cassandra.transport.SimpleClient.Builder
 
build(boolean) - Method in class org.apache.cassandra.utils.binlog.BinLog.Builder
 
build(Collection<K>, UpdateFunction<K, V>) - Static method in class org.apache.cassandra.utils.btree.BTree
 
build(Iterable<K>, int, UpdateFunction<K, V>) - Static method in class org.apache.cassandra.utils.btree.BTree
Creates a BTree containing all of the objects in the provided collection
build(Object[], int, UpdateFunction<K, V>) - Static method in class org.apache.cassandra.utils.btree.BTree
 
build() - Method in class org.apache.cassandra.utils.btree.BTree.Builder
 
build() - Method in class org.apache.cassandra.utils.btree.BTreeSet.Builder
 
build(Collection<I>) - Static method in class org.apache.cassandra.utils.IntervalTree
 
build() - Method in class org.apache.cassandra.utils.streamhist.StreamingTombstoneHistogramBuilder
Creates a 'finished' snapshot of the current state of the histogram, but leaves this builder instance open for subsequent additions to the histograms.
buildAllViews() - Method in class org.apache.cassandra.db.view.ViewManager
 
buildAsMutation() - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder
As shortcut for new Mutation(build()).
buildAsMutation() - Method in class org.apache.cassandra.db.SimpleBuilders.PartitionUpdateBuilder
 
buildBound(boolean, boolean) - Method in class org.apache.cassandra.db.CBuilder
 
buildBound(boolean, boolean) - Method in class org.apache.cassandra.db.MultiCBuilder
Builds the ClusteringBounds
buildBoundForSlice(boolean, boolean, boolean, List<ColumnMetadata>) - Method in class org.apache.cassandra.db.MultiCBuilder
Builds the ClusteringBounds for slice restrictions.
buildBoundWith(List<ByteBuffer>, boolean, boolean) - Method in class org.apache.cassandra.db.CBuilder
 
buildCompactionCandidatesForAvailableDiskSpace(Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
buildComponentForTools(AbstractType<?>, List<AbstractType<?>>, Map<ByteBuffer, AbstractType<?>>, Map<ByteBuffer, AbstractType<?>>, EncodingStats) - Static method in class org.apache.cassandra.db.SerializationHeader.Component
Only exposed for SSTableHeaderFix.
Builder(QueryState) - Constructor for class org.apache.cassandra.audit.AuditLogEntry.Builder
 
Builder(AuditLogEntry) - Constructor for class org.apache.cassandra.audit.AuditLogEntry.Builder
 
Builder(AuditLogEntryType) - Constructor for class org.apache.cassandra.audit.AuditLogEntry.Builder
 
builder() - Static method in class org.apache.cassandra.auth.DCPermissions
 
Builder() - Constructor for class org.apache.cassandra.auth.DCPermissions.Builder
 
builder(Types) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement
 
Builder() - Constructor for class org.apache.cassandra.cql3.WhereClause.Builder
 
Builder() - Constructor for class org.apache.cassandra.db.commitlog.IntervalSet.Builder
 
Builder(T, T) - Constructor for class org.apache.cassandra.db.commitlog.IntervalSet.Builder
 
Builder() - Constructor for class org.apache.cassandra.db.compaction.Verifier.Options.Builder
 
builder(DeletionTime, ClusteringComparator, boolean) - Static method in class org.apache.cassandra.db.MutableDeletionInfo
 
Builder(TableMetadata, DecoratedKey, RegularAndStaticColumns, int, boolean) - Constructor for class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
 
Builder(TableMetadata, DecoratedKey, RegularAndStaticColumns, int) - Constructor for class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
 
Builder(PartitionUpdate, int) - Constructor for class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
 
Builder(TableMetadata, ByteBuffer, RegularAndStaticColumns, int) - Constructor for class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
 
builder() - Static method in class org.apache.cassandra.db.RegularAndStaticColumns
 
Builder() - Constructor for class org.apache.cassandra.db.RegularAndStaticColumns.Builder
 
Builder(boolean) - Constructor for class org.apache.cassandra.db.rows.BTreeRow.Builder
 
Builder(BTreeRow.Builder) - Constructor for class org.apache.cassandra.db.rows.BTreeRow.Builder
 
builder() - Static method in class org.apache.cassandra.db.rows.ComplexColumnData
 
Builder() - Constructor for class org.apache.cassandra.db.rows.ComplexColumnData.Builder
 
Builder(ClusteringComparator) - Constructor for class org.apache.cassandra.db.Slices.Builder
 
Builder(ClusteringComparator, int) - Constructor for class org.apache.cassandra.db.Slices.Builder
 
builder() - Static method in class org.apache.cassandra.db.streaming.CassandraStreamHeader
 
Builder() - Constructor for class org.apache.cassandra.db.streaming.CassandraStreamHeader.Builder
 
Builder(OnDiskIndexBuilder.Mode, AbstractType<?>) - Constructor for class org.apache.cassandra.index.sasi.conf.view.PrefixTermTree.Builder
 
Builder(OnDiskIndexBuilder.Mode, AbstractType<?>) - Constructor for class org.apache.cassandra.index.sasi.conf.view.TermTree.Builder
 
Builder(Operation.OperationType, QueryController, RowFilter.Expression...) - Constructor for class org.apache.cassandra.index.sasi.plan.Operation.Builder
 
builder() - Static method in class org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator
 
builder(RangeIntersectionIterator.Strategy) - Static method in class org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator
 
Builder(RangeIntersectionIterator.Strategy) - Constructor for class org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator.Builder
 
Builder(RangeIterator.Builder.IteratorType) - Constructor for class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
 
builder() - Static method in class org.apache.cassandra.index.sasi.utils.RangeUnionIterator
 
Builder() - Constructor for class org.apache.cassandra.index.sasi.utils.RangeUnionIterator.Builder
 
builder() - Static method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
Returns a new builder for a CQLSSTableWriter.
Builder() - Constructor for class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
 
builder() - Static method in class org.apache.cassandra.io.sstable.SSTableHeaderFix
 
Builder(String) - Constructor for class org.apache.cassandra.io.util.FileHandle.Builder
 
Builder(ChannelProxy) - Constructor for class org.apache.cassandra.io.util.FileHandle.Builder
 
Builder() - Constructor for class org.apache.cassandra.locator.EndpointsByRange.Builder
 
Builder() - Constructor for class org.apache.cassandra.locator.EndpointsByReplica.Builder
 
builder(Range<Token>) - Static method in class org.apache.cassandra.locator.EndpointsForRange
 
builder(Range<Token>, int) - Static method in class org.apache.cassandra.locator.EndpointsForRange
 
Builder(Range<Token>) - Constructor for class org.apache.cassandra.locator.EndpointsForRange.Builder
 
Builder(Range<Token>, int) - Constructor for class org.apache.cassandra.locator.EndpointsForRange.Builder
 
builder(Token) - Static method in class org.apache.cassandra.locator.EndpointsForToken
 
builder(Token, int) - Static method in class org.apache.cassandra.locator.EndpointsForToken
 
Builder(Token) - Constructor for class org.apache.cassandra.locator.EndpointsForToken.Builder
 
Builder(Token, int) - Constructor for class org.apache.cassandra.locator.EndpointsForToken.Builder
 
builder(InetAddressAndPort) - Static method in class org.apache.cassandra.locator.RangesAtEndpoint
 
builder(InetAddressAndPort, int) - Static method in class org.apache.cassandra.locator.RangesAtEndpoint
 
Builder(InetAddressAndPort) - Constructor for class org.apache.cassandra.locator.RangesAtEndpoint.Builder
 
Builder(InetAddressAndPort, int) - Constructor for class org.apache.cassandra.locator.RangesAtEndpoint.Builder
 
Builder() - Constructor for class org.apache.cassandra.locator.RangesByEndpoint.Builder
 
builder(Message<T>) - Static method in class org.apache.cassandra.net.Message
 
builder(Verb, T) - Static method in class org.apache.cassandra.net.Message
 
Builder() - Constructor for class org.apache.cassandra.repair.consistent.admin.PendingStat.Builder
 
builder() - Static method in class org.apache.cassandra.repair.consistent.CoordinatorSession
 
Builder() - Constructor for class org.apache.cassandra.repair.consistent.CoordinatorSession.Builder
 
builder() - Static method in class org.apache.cassandra.repair.consistent.LocalSession
 
Builder() - Constructor for class org.apache.cassandra.repair.consistent.LocalSession.Builder
 
builder() - Static method in class org.apache.cassandra.schema.Functions
 
builder() - Static method in class org.apache.cassandra.schema.Indexes
 
builder() - Static method in class org.apache.cassandra.schema.Keyspaces
 
builder(String, String) - Static method in class org.apache.cassandra.schema.TableMetadata
 
builder(String, String, TableId) - Static method in class org.apache.cassandra.schema.TableMetadata
 
builder() - Static method in class org.apache.cassandra.schema.TableParams
 
builder(TableParams) - Static method in class org.apache.cassandra.schema.TableParams
 
Builder() - Constructor for class org.apache.cassandra.schema.TableParams.Builder
 
builder() - Static method in class org.apache.cassandra.schema.Tables
 
builder() - Static method in class org.apache.cassandra.schema.Triggers
 
builder() - Static method in class org.apache.cassandra.schema.Types
 
builder() - Static method in class org.apache.cassandra.schema.Views
 
builder() - Static method in class org.apache.cassandra.tools.LoaderOptions
 
Builder() - Constructor for class org.apache.cassandra.transport.Server.Builder
 
builder(String, int) - Static method in class org.apache.cassandra.transport.SimpleClient
 
Builder() - Constructor for class org.apache.cassandra.utils.binlog.BinLog.Builder
 
builder(Comparator<? super V>) - Static method in class org.apache.cassandra.utils.btree.BTree
 
builder(Comparator<? super V>, int) - Static method in class org.apache.cassandra.utils.btree.BTree
 
Builder(Comparator<? super V>) - Constructor for class org.apache.cassandra.utils.btree.BTree.Builder
 
Builder(Comparator<? super V>, int) - Constructor for class org.apache.cassandra.utils.btree.BTree.Builder
 
Builder() - Constructor for class org.apache.cassandra.utils.btree.BTree.Builder
 
builder(Comparator<? super V>) - Static method in class org.apache.cassandra.utils.btree.BTreeSet
 
Builder(Comparator<? super V>) - Constructor for class org.apache.cassandra.utils.btree.BTreeSet.Builder
 
buildFromMap(Map<String, String>) - Static method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
 
buildFromMap(Map<String, String>) - Static method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
buildIndexClusteringPrefix(ByteBuffer, ClusteringPrefix<T>, CellPath) - Method in class org.apache.cassandra.index.internal.CassandraIndex
Used to construct an the clustering for an entry in the index table based on values from the base data.
buildIndexClusteringPrefix(ByteBuffer, ClusteringPrefix<T>, CellPath) - Method in class org.apache.cassandra.index.internal.composites.ClusteringColumnIndex
 
buildIndexClusteringPrefix(ByteBuffer, ClusteringPrefix<T>, CellPath) - Method in class org.apache.cassandra.index.internal.composites.CollectionKeyIndexBase
 
buildIndexClusteringPrefix(ByteBuffer, ClusteringPrefix<T>, CellPath) - Method in class org.apache.cassandra.index.internal.composites.CollectionValueIndex
 
buildIndexClusteringPrefix(ByteBuffer, ClusteringPrefix<T>, CellPath) - Method in class org.apache.cassandra.index.internal.composites.PartitionKeyIndex
 
buildIndexClusteringPrefix(ByteBuffer, ClusteringPrefix<T>, CellPath) - Method in class org.apache.cassandra.index.internal.composites.RegularColumnIndex
 
buildIndexClusteringPrefix(ByteBuffer, ClusteringPrefix<T>, CellPath) - Method in class org.apache.cassandra.index.internal.keys.KeysIndex
 
buildIntervals(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.lifecycle.SSTableIntervalTree
 
buildIterator() - Method in class org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator.Builder
 
buildIterator() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
 
buildIterator() - Method in class org.apache.cassandra.index.sasi.utils.RangeUnionIterator.Builder
 
buildPartitionKeyNames(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
buildRow() - Method in class org.apache.cassandra.cql3.UpdateParameters
 
buildRowIndex(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.ColumnIndex
 
buildSession(CoordinatorSession.Builder) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSessions
 
buildSession(LocalSession.Builder) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
buildValue(ValueAccessor<V>, V[]) - Static method in class org.apache.cassandra.db.marshal.TupleType
 
buildValue(ByteBuffer[]) - Static method in class org.apache.cassandra.db.marshal.TupleType
 
buildWith(List<ByteBuffer>) - Method in class org.apache.cassandra.db.CBuilder
 
buildWithStdevRangesAroundMean() - Method in class org.apache.cassandra.utils.HistogramBuilder
buildWithStdevRangesAroundMean(int) - Method in class org.apache.cassandra.utils.HistogramBuilder
Calculate the min, mean, max and standard deviation of the items in the builder, and generate an EstimatedHistogram with upto maxdev stdev size ranges either side of the mean, until min/max are hit; if either min/max are not reached a further range is inserted at the relevant ends.
built - Variable in class org.apache.cassandra.db.MultiCBuilder
true if the clusterings have been build, false otherwise.
BUILT_INDEXES - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
BUILT_VIEWS - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
bulkLoad(String) - Method in class org.apache.cassandra.service.StorageService
 
bulkLoad(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Starts a bulk load and blocks until it completes.
bulkLoadAsync(String) - Method in class org.apache.cassandra.service.StorageService
 
bulkLoadAsync(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Starts a bulk load asynchronously and returns the String representation of the planID for the new streaming session.
BulkLoadConnectionFactory - Class in org.apache.cassandra.tools
 
BulkLoadConnectionFactory(int, EncryptionOptions.ServerEncryptionOptions, boolean) - Constructor for class org.apache.cassandra.tools.BulkLoadConnectionFactory
 
BulkLoader - Class in org.apache.cassandra.tools
 
BulkLoader() - Constructor for class org.apache.cassandra.tools.BulkLoader
 
BulkLoader.CmdLineOptions - Class in org.apache.cassandra.tools
 
BulkLoadException - Exception in org.apache.cassandra.tools
 
BulkLoadException(Throwable) - Constructor for exception org.apache.cassandra.tools.BulkLoadException
 
byEndpoint() - Method in class org.apache.cassandra.locator.Endpoints
 
bypassConcurrentValidatorsLimit() - Method in class org.apache.cassandra.service.StorageService
 
bypassConcurrentValidatorsLimit() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
byRange() - Method in class org.apache.cassandra.locator.RangesAtEndpoint
 
BYTE_MASK - Static variable in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
BYTE_SIZE - Static variable in class org.apache.cassandra.db.TypeSizes
 
ByteArrayAccessor - Class in org.apache.cassandra.db.marshal
 
ByteArrayUtil - Class in org.apache.cassandra.utils
 
ByteArrayUtil() - Constructor for class org.apache.cassandra.utils.ByteArrayUtil
 
byteBuffer() - Method in class org.apache.cassandra.utils.MD5Digest
 
ByteBufferAccessor - Class in org.apache.cassandra.db.marshal
Accessor for ByteBuffer values.
ByteBufferUtil - Class in org.apache.cassandra.utils
Utility methods to make ByteBuffers less painful The following should illustrate the different ways byte buffers can be used public void testArrayOffet() { byte[] b = "test_slice_array".getBytes(); ByteBuffer bb = ByteBuffer.allocate(1024); assert bb.position() == 0; assert bb.limit() == 1024; assert bb.capacity() == 1024; bb.put(b); assert bb.position() == b.length; assert bb.remaining() == bb.limit() - bb.position(); ByteBuffer bb2 = bb.slice(); assert bb2.position() == 0; //slice should begin at other buffers current position assert bb2.arrayOffset() == bb.position(); //to match the position in the underlying array one needs to //track arrayOffset assert bb2.limit()+bb2.arrayOffset() == bb.limit(); assert bb2.remaining() == bb.remaining(); } }
ByteBufferUtil() - Constructor for class org.apache.cassandra.utils.ByteBufferUtil
 
ByteOrderedPartitioner - Class in org.apache.cassandra.dht
 
ByteOrderedPartitioner() - Constructor for class org.apache.cassandra.dht.ByteOrderedPartitioner
 
ByteOrderedPartitioner.BytesToken - Class in org.apache.cassandra.dht
 
bytes - Variable in class org.apache.cassandra.cql3.ColumnIdentifier
 
bytes - Variable in class org.apache.cassandra.cql3.Constants.Value
 
bytes - Variable in class org.apache.cassandra.cql3.FieldIdentifier
 
Bytes - Class in org.apache.cassandra.cql3.functions.types.utils
Simple utility methods to make working with bytes (blob) easier.
bytes(byte) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
bytes(int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
bytes(long) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
bytes(short) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
bytes(float) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
bytes(double) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
bytes(String) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
bytes(String, Charset) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
bytes(String) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Encode a String in a ByteBuffer using UTF_8.
bytes(String, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Encode a String in a ByteBuffer using the provided charset.
bytes(byte) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(short) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(long) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(float) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(double) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(InetAddress) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(UUID) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes() - Method in class org.apache.cassandra.utils.CounterId
 
bytes - Variable in class org.apache.cassandra.utils.MD5Digest
 
bytesAnticompacted - Variable in class org.apache.cassandra.metrics.TableMetrics
number of bytes read while doing anticompaction
bytesCompacted - Variable in class org.apache.cassandra.metrics.CompactionMetrics
Total number of bytes compacted since server [re]start
BytesConversionFcts - Class in org.apache.cassandra.cql3.functions
 
BytesConversionFcts() - Constructor for class org.apache.cassandra.cql3.functions.BytesConversionFcts
 
ByteSerializer - Class in org.apache.cassandra.serializers
 
ByteSerializer() - Constructor for class org.apache.cassandra.serializers.ByteSerializer
 
bytesFlushed - Variable in class org.apache.cassandra.metrics.TableMetrics
Total number of bytes flushed since server [re]start
byteSize(Token) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
bytesMutatedAnticompaction - Variable in class org.apache.cassandra.metrics.TableMetrics
number of bytes where the whole sstable was contained in a repairing range so that we only mutated the repair status
bytesOnDisk() - Method in class org.apache.cassandra.io.sstable.SSTable
 
bytesPastLimit() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
 
bytesPastMark(DataPosition) - Method in class org.apache.cassandra.db.commitlog.EncryptedFileSegmentInputStream
 
bytesPastMark(DataPosition) - Method in class org.apache.cassandra.io.util.FileSegmentInputStream
 
bytesPastMark() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
bytesPastMark(DataPosition) - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
bytesPastMark(DataPosition) - Method in interface org.apache.cassandra.io.util.RewindableDataInput
 
bytesPastMark(DataPosition) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
bytesPendingRepair - Variable in class org.apache.cassandra.metrics.TableMetrics
 
bytesPendingRepair - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
BytesReadTracker - Interface in org.apache.cassandra.io.util
 
bytesReceived - Static variable in class org.apache.cassandra.metrics.ClientMessageSizeMetrics
 
bytesReceivedPerRequest - Static variable in class org.apache.cassandra.metrics.ClientMessageSizeMetrics
 
bytesRemaining() - Method in class org.apache.cassandra.db.commitlog.EncryptedFileSegmentInputStream
 
bytesRemaining() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
bytesRemaining() - Method in class org.apache.cassandra.io.util.FileSegmentInputStream
 
bytesRemaining() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
bytesRepaired - Variable in class org.apache.cassandra.metrics.TableMetrics
Reports the size of sstables in repaired, unrepaired, and any ongoing repair buckets
bytesRepaired - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
bytesSent - Static variable in class org.apache.cassandra.metrics.ClientMessageSizeMetrics
 
bytesSentPerResponse - Static variable in class org.apache.cassandra.metrics.ClientMessageSizeMetrics
 
BytesSerializer - Class in org.apache.cassandra.serializers
 
BytesSerializer() - Constructor for class org.apache.cassandra.serializers.BytesSerializer
 
bytesToHex(byte[]) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
bytesToHex(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytesToHex(byte...) - Static method in class org.apache.cassandra.utils.Hex
 
bytesToHex(byte[], int, int) - Static method in class org.apache.cassandra.utils.Hex
 
BytesToken(ByteBuffer) - Constructor for class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
BytesToken(byte[]) - Constructor for class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
BytesType - Class in org.apache.cassandra.db.marshal
 
bytesUnrepaired - Variable in class org.apache.cassandra.metrics.TableMetrics
 
bytesUnrepaired - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
bytesValidated - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
histogram over the number of bytes we have validated
bytesValidated - Variable in class org.apache.cassandra.metrics.TableMetrics
approximate number of bytes read while creating merkle trees
ByteTerm - Class in org.apache.cassandra.index.sasi.sa
 
ByteTerm(int, ByteBuffer, TokenTreeBuilder) - Constructor for class org.apache.cassandra.index.sasi.sa.ByteTerm
 
ByteType - Class in org.apache.cassandra.db.marshal
 

C

cache - Variable in class org.apache.cassandra.auth.AuthCache
Underlying cache.
CACHE_EVERYTHING - Static variable in class org.apache.cassandra.schema.CachingParams
 
CACHE_KEYS - Static variable in class org.apache.cassandra.schema.CachingParams
 
CACHE_NOTHING - Static variable in class org.apache.cassandra.schema.CachingParams
 
cacheAllRows() - Method in class org.apache.cassandra.schema.CachingParams
 
cached_rows_fail_threshold - Variable in class org.apache.cassandra.config.ReplicaFilteringProtectionOptions
 
cached_rows_warn_threshold - Variable in class org.apache.cassandra.config.ReplicaFilteringProtectionOptions
 
CachedBTreePartition - Class in org.apache.cassandra.db.partitions
 
CachedHashDecoratedKey - Class in org.apache.cassandra.db
 
CachedHashDecoratedKey(Token, ByteBuffer) - Constructor for class org.apache.cassandra.db.CachedHashDecoratedKey
 
cachedLiveRows() - Method in class org.apache.cassandra.db.partitions.CachedBTreePartition
The number of rows that were live at the time the partition was cached.
cachedLiveRows() - Method in interface org.apache.cassandra.db.partitions.CachedPartition
The number of rows that were live at the time the partition was cached.
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.
CachedPartition - Interface in org.apache.cassandra.db.partitions
A partition stored in the partition cache.
CacheKey - Class in org.apache.cassandra.cache
 
CacheKey(TableId, String) - Constructor for class org.apache.cassandra.cache.CacheKey
 
CacheKey(TableMetadata) - Constructor for class org.apache.cassandra.cache.CacheKey
 
cacheKey(DecoratedKey, RowIndexEntry) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
cacheKeys() - Method in class org.apache.cassandra.schema.CachingParams
 
CacheMetrics - Class in org.apache.cassandra.metrics
Metrics for ICache.
CacheMetrics(String, CacheSize) - Constructor for class org.apache.cassandra.metrics.CacheMetrics
Create metrics for given cache.
CacheProvider<K,V> - Interface in org.apache.cassandra.cache
 
cacheRows() - Method in class org.apache.cassandra.schema.CachingParams
 
cacheSerializer - Static variable in interface org.apache.cassandra.db.partitions.CachedPartition
 
CacheService - Class in org.apache.cassandra.service
 
cacheService - Variable in class org.apache.cassandra.tools.NodeProbe
 
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
 
CacheSize - Interface in org.apache.cassandra.cache
 
cacheSize - Static variable in class org.apache.cassandra.cache.ChunkCache
 
cacheType - Variable in class org.apache.cassandra.cache.AutoSavingCache
 
cacheType() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
 
caching(CachingParams) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
caching(CachingParams) - Method in class org.apache.cassandra.schema.TableParams.Builder
 
caching - Variable in class org.apache.cassandra.schema.TableParams
 
CachingParams - Class in org.apache.cassandra.schema
 
CachingParams(boolean, int) - Constructor for class org.apache.cassandra.schema.CachingParams
 
CachingParams.Option - Enum in org.apache.cassandra.schema
 
CaffeineCache<K extends IMeasurableMemory,V extends IMeasurableMemory> - Class in org.apache.cassandra.cache
An adapter from a Caffeine cache to the ICache interface.
calculateIndexingPageSize() - Method in class org.apache.cassandra.index.SecondaryIndexManager
Return the page size used when indexing an entire partition
calculateNaturalReplicas(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
Calculate the natural endpoints for the given token.
calculateNaturalReplicas(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.LocalStrategy
 
calculateNaturalReplicas(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.
calculateNaturalReplicas(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.SimpleStrategy
 
calculatePendingRanges(AbstractReplicationStrategy, String) - Method in class org.apache.cassandra.locator.TokenMetadata
Calculate pending ranges according to bootsrapping and leaving nodes.
calculatePendingRanges(AbstractReplicationStrategy, String) - Static method in class org.apache.cassandra.service.PendingRangeCalculatorService
 
calculateRangesToFetchWithPreferredEndpoints(BiFunction<InetAddressAndPort, EndpointsForRange, EndpointsForRange>, AbstractReplicationStrategy, ReplicaCollection<?>, boolean, TokenMetadata, TokenMetadata, String, Collection<RangeStreamer.SourceFilter>) - Static method in class org.apache.cassandra.dht.RangeStreamer
Get a map of all ranges and the source that will be cleaned up once this bootstrapped node is added for the given ranges.
calculateRangesToStreamWithEndpoints(RangesAtEndpoint, AbstractReplicationStrategy, TokenMetadata, TokenMetadata) - Static method in class org.apache.cassandra.service.RangeRelocator
calculating endpoints to stream current ranges to if needed in some situations node will handle current ranges as part of the new ranges
calculateSize() - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader
 
calculateStreamAndFetchRanges(RangesAtEndpoint, RangesAtEndpoint) - Static method in class org.apache.cassandra.service.RangeRelocator
Calculate pair of ranges to stream/fetch for given two range collections (current ranges for keyspace and ranges after move to new token) With transient replication the added wrinkle is that if a range transitions from full to transient then we need to stream the range despite the fact that we are retaining it as transient.
calculateThreshold(Snapshot, long) - Method in class org.apache.cassandra.service.reads.AlwaysSpeculativeRetryPolicy
 
calculateThreshold(Snapshot, long) - Method in class org.apache.cassandra.service.reads.FixedSpeculativeRetryPolicy
 
calculateThreshold(Snapshot, long) - Method in class org.apache.cassandra.service.reads.HybridSpeculativeRetryPolicy
 
calculateThreshold(Snapshot, long) - Method in class org.apache.cassandra.service.reads.NeverSpeculativeRetryPolicy
 
calculateThreshold(Snapshot, long) - Method in class org.apache.cassandra.service.reads.PercentileSpeculativeRetryPolicy
 
calculateThreshold(Snapshot, long) - Method in interface org.apache.cassandra.service.reads.SpeculativeRetryPolicy
 
calculateToFromStreams() - Method in class org.apache.cassandra.service.RangeRelocator
 
call() - Method in class org.apache.cassandra.db.repair.PendingAntiCompaction.AcquisitionCallable
 
call() - Method in class org.apache.cassandra.db.view.ViewBuilderTask
 
call(AbstractMessageHandler) - Method in interface org.apache.cassandra.net.AbstractMessageHandler.OnHandlerClosed
 
call() - Method in class org.apache.cassandra.tools.JMXTool.Diff
 
call() - Method in class org.apache.cassandra.tools.JMXTool.Dump
 
callback - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
callbacks - Variable in class org.apache.cassandra.net.MessagingService
 
callbacks - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
callbacks() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
callClose(int) - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
 
callClose(int) - Method in class org.apache.cassandra.utils.NativeLibraryLinux
 
callClose(int) - Method in class org.apache.cassandra.utils.NativeLibraryWindows
 
calledOnNullInput - Variable in class org.apache.cassandra.cql3.functions.UDFunction
 
callFcntl(int, int, long) - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
 
callFcntl(int, int, long) - Method in class org.apache.cassandra.utils.NativeLibraryLinux
 
callFcntl(int, int, long) - Method in class org.apache.cassandra.utils.NativeLibraryWindows
 
callFsync(int) - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
 
callFsync(int) - Method in class org.apache.cassandra.utils.NativeLibraryLinux
 
callFsync(int) - Method in class org.apache.cassandra.utils.NativeLibraryWindows
 
callGetpid() - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
 
callGetpid() - Method in class org.apache.cassandra.utils.NativeLibraryLinux
 
callGetpid() - Method in class org.apache.cassandra.utils.NativeLibraryWindows
 
callMlockall(int) - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
 
callMlockall(int) - Method in class org.apache.cassandra.utils.NativeLibraryLinux
 
callMlockall(int) - Method in class org.apache.cassandra.utils.NativeLibraryWindows
 
callMunlockall() - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
 
callMunlockall() - Method in class org.apache.cassandra.utils.NativeLibraryLinux
 
callMunlockall() - Method in class org.apache.cassandra.utils.NativeLibraryWindows
 
callOpen(String, int) - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
 
callOpen(String, int) - Method in class org.apache.cassandra.utils.NativeLibraryLinux
 
callOpen(String, int) - Method in class org.apache.cassandra.utils.NativeLibraryWindows
 
callPosixFadvise(int, long, int, int) - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
 
callPosixFadvise(int, long, int, int) - Method in class org.apache.cassandra.utils.NativeLibraryLinux
 
callPosixFadvise(int, long, int, int) - Method in class org.apache.cassandra.utils.NativeLibraryWindows
 
callStrerror(int) - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
 
callStrerror(int) - Method in class org.apache.cassandra.utils.NativeLibraryLinux
 
callStrerror(int) - Method in class org.apache.cassandra.utils.NativeLibraryWindows
 
canAccess(String) - Method in class org.apache.cassandra.auth.DCPermissions
returns true if the user can access the given dc
canBeConvertedToMultiColumnRestriction() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
 
cancel(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
remove the reader from the set we're modifying
cancel(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
remove the readers from the set we're modifying
cancel(boolean) - Method in class org.apache.cassandra.net.AsyncPromise
 
cancel() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
Should only be called by the owning thread.
CancelCmd() - Constructor for class org.apache.cassandra.tools.nodetool.RepairAdmin.CancelCmd
 
cancelSession(UUID, boolean) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
hook for operators to cancel sessions, cancelling from a non-coordinator is an error, unless force is set to true.
Candidate(int, Iterator<? extends In>, Comparator<? super In>) - Constructor for class org.apache.cassandra.utils.MergeIterator.Candidate
 
candidateReplicaCount() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
TODO: this method is brittle for its purpose of deciding when we should fail a query; this needs to be CL aware, and of which nodes are live/down
candidateReplicaCount() - Method in class org.apache.cassandra.service.BatchlogResponseHandler
 
candidates() - Method in class org.apache.cassandra.locator.ReplicaPlan.ForRead
 
canHaveShadowedData() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
canHaveShadowedData() - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
 
canHaveShadowedData() - Method in class org.apache.cassandra.db.partitions.ImmutableBTreePartition
 
canHaveShadowedData() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
 
canLogin() - Method in class org.apache.cassandra.auth.AuthenticatedUser
Check whether this user has login privileges.
canLogin(RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
canLogin(RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
Return true if there exists a Role with the given name which has login privileges.
canLogin - Variable in class org.apache.cassandra.auth.Role
 
canLogin(RoleResource) - Static method in class org.apache.cassandra.auth.Roles
Returns true if the supplied role has the login privilege.
canMemoize() - Method in class org.apache.cassandra.utils.ExpiringMemoizingSupplier.Memoized
 
canMemoize() - Method in class org.apache.cassandra.utils.ExpiringMemoizingSupplier.NotMemoized
 
canMinimize(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
canMinimize(ByteBuffer[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
canRecyclePartially() - Method in class org.apache.cassandra.utils.memory.BufferPool.LocalPool
 
canSkipValue(ColumnMetadata) - Method in class org.apache.cassandra.db.rows.DeserializationHelper
 
canSkipValue(CellPath) - Method in class org.apache.cassandra.db.rows.DeserializationHelper
 
canTransitionTo(ConsistentSession.State) - Method in enum org.apache.cassandra.repair.consistent.ConsistentSession.State
 
capacity() - Method in interface org.apache.cassandra.cache.CacheSize
 
capacity() - Method in class org.apache.cassandra.cache.CaffeineCache
 
capacity() - Method in class org.apache.cassandra.cache.ChunkCache
 
capacity() - Method in class org.apache.cassandra.cache.SerializingCache
 
capacity() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
capacity() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
capacity - Variable in class org.apache.cassandra.metrics.CacheMetrics
Cache capacity in bytes
capacity(int) - Method in class org.apache.cassandra.net.BufferPoolAllocator.Wrapped
 
capacity() - Method in class org.apache.cassandra.utils.concurrent.Accumulator
 
capacity() - Method in interface org.apache.cassandra.utils.obs.IBitSet
 
capacity() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
captureWarnings() - Method in class org.apache.cassandra.service.ClientWarn
 
cardinality - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
Default cardinality estimation method is to use HyperLogLog++.
cardinalityEstimator - Variable in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
 
cas(String, String, DecoratedKey, CASRequest, ConsistencyLevel, ConsistencyLevel, ClientState, int, long) - 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_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
 
CASClientWriteRequestMetrics - Class in org.apache.cassandra.metrics
Metrics for tracking information about CAS write requests.
CASClientWriteRequestMetrics(String) - Constructor for class org.apache.cassandra.metrics.CASClientWriteRequestMetrics
 
casCommit - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
CAS Commit metrics
casCommit - Variable in class org.apache.cassandra.metrics.TableMetrics
CAS Commit metrics
CASE_SENSITIVE - Static variable in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
 
caseSensitive(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions.OptionsBuilder
 
caseSensitive(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
 
casPrepare - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
CAS Prepare metric
casPrepare - Variable in class org.apache.cassandra.metrics.TableMetrics
CAS Prepare metrics
casPropose - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
CAS Propose metrics
casPropose - Variable in class org.apache.cassandra.metrics.TableMetrics
CAS Propose metrics
CASRequest - Interface in org.apache.cassandra.service
Abstract the conditions and updates for a CAS operation.
CASSANDRA_3_4 - Static variable in class org.apache.cassandra.utils.CassandraVersion
 
CASSANDRA_4_0 - Static variable in class org.apache.cassandra.utils.CassandraVersion
 
CASSANDRA_4_0_RC2 - Static variable in class org.apache.cassandra.utils.CassandraVersion
 
CassandraAuthorizer - Class in org.apache.cassandra.auth
CassandraAuthorizer is an IAuthorizer implementation that keeps user permissions internally in C* using the system_auth.role_permissions table.
CassandraAuthorizer() - Constructor for class org.apache.cassandra.auth.CassandraAuthorizer
 
CassandraCompressedStreamReader - Class in org.apache.cassandra.db.streaming
CassandraStreamReader that reads from streamed compressed SSTable
CassandraCompressedStreamReader(StreamMessageHeader, CassandraStreamHeader, StreamSession) - Constructor for class org.apache.cassandra.db.streaming.CassandraCompressedStreamReader
 
CassandraCompressedStreamWriter - Class in org.apache.cassandra.db.streaming
CassandraStreamWriter for compressed SSTable.
CassandraCompressedStreamWriter(SSTableReader, CassandraStreamHeader, StreamSession) - Constructor for class org.apache.cassandra.db.streaming.CassandraCompressedStreamWriter
 
CassandraDaemon - Class in org.apache.cassandra.service
The CassandraDaemon is an abstraction for a Cassandra daemon service, which defines not only a way to activate and deactivate it, but also hooks into its lifecycle methods (see CassandraDaemon.setup(), CassandraDaemon.start(), CassandraDaemon.stop() and CassandraDaemon.setup()).
CassandraDaemon() - Constructor for class org.apache.cassandra.service.CassandraDaemon
 
CassandraDaemon(boolean) - Constructor for class org.apache.cassandra.service.CassandraDaemon
 
CassandraDaemon.Server - Interface in org.apache.cassandra.service
 
CassandraEntireSSTableStreamReader - Class in org.apache.cassandra.db.streaming
CassandraEntireSSTableStreamReader reads SSTable off the wire and writes it to disk.
CassandraEntireSSTableStreamReader(StreamMessageHeader, CassandraStreamHeader, StreamSession) - Constructor for class org.apache.cassandra.db.streaming.CassandraEntireSSTableStreamReader
 
CassandraEntireSSTableStreamWriter - Class in org.apache.cassandra.db.streaming
CassandraEntireSSTableStreamWriter streams the entire SSTable to given channel.
CassandraEntireSSTableStreamWriter(SSTableReader, StreamSession, ComponentContext) - Constructor for class org.apache.cassandra.db.streaming.CassandraEntireSSTableStreamWriter
 
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
 
CassandraIncomingFile - Class in org.apache.cassandra.db.streaming
used to receive the part(or whole) of a SSTable data file.
CassandraIncomingFile(ColumnFamilyStore, StreamSession, StreamMessageHeader) - Constructor for class org.apache.cassandra.db.streaming.CassandraIncomingFile
 
CassandraIndex - Class in org.apache.cassandra.index.internal
Index implementation which indexes the values for a single column in the base table and which stores its index data in a local, hidden table.
CassandraIndex(ColumnFamilyStore, IndexMetadata) - Constructor for class org.apache.cassandra.index.internal.CassandraIndex
 
CassandraIndexFunctions - Interface in org.apache.cassandra.index.internal
 
CassandraIndexSearcher - Class in org.apache.cassandra.index.internal
 
CassandraIndexSearcher(ReadCommand, RowFilter.Expression, CassandraIndex) - Constructor for class org.apache.cassandra.index.internal.CassandraIndexSearcher
 
CassandraKeyspaceRepairManager - Class in org.apache.cassandra.db.repair
 
CassandraKeyspaceRepairManager(Keyspace) - Constructor for class org.apache.cassandra.db.repair.CassandraKeyspaceRepairManager
 
CassandraKeyspaceWriteHandler - Class in org.apache.cassandra.db
 
CassandraKeyspaceWriteHandler(Keyspace) - Constructor for class org.apache.cassandra.db.CassandraKeyspaceWriteHandler
 
CassandraLoginModule - Class in org.apache.cassandra.auth
LoginModule which authenticates a user towards the Cassandra database using the internal authentication mechanism.
CassandraLoginModule() - Constructor for class org.apache.cassandra.auth.CassandraLoginModule
 
CassandraMetricsRegistry - Class in org.apache.cassandra.metrics
Makes integrating 3.0 metrics API with 2.0.
CassandraMetricsRegistry.JmxCounterMBean - Interface in org.apache.cassandra.metrics
 
CassandraMetricsRegistry.JmxGaugeMBean - Interface in org.apache.cassandra.metrics
 
CassandraMetricsRegistry.JmxHistogramMBean - Interface in org.apache.cassandra.metrics
 
CassandraMetricsRegistry.JmxMeterMBean - Interface in org.apache.cassandra.metrics
 
CassandraMetricsRegistry.JmxTimerMBean - Interface in org.apache.cassandra.metrics
 
CassandraMetricsRegistry.MetricMBean - Interface in org.apache.cassandra.metrics
 
CassandraMetricsRegistry.MetricName - Class in org.apache.cassandra.metrics
A value class encapsulating a metric's owning class and name.
CassandraNetworkAuthorizer - Class in org.apache.cassandra.auth
 
CassandraNetworkAuthorizer() - Constructor for class org.apache.cassandra.auth.CassandraNetworkAuthorizer
 
CassandraOutgoingFile - Class in org.apache.cassandra.db.streaming
used to transfer the part(or whole) of a SSTable data file
CassandraOutgoingFile(StreamOperation, Ref<SSTableReader>, List<SSTableReader.PartitionPositionBounds>, List<Range<Token>>, long) - Constructor for class org.apache.cassandra.db.streaming.CassandraOutgoingFile
 
CassandraPrincipal - Class in org.apache.cassandra.auth
This class implements the Principal interface and represents a user.
CassandraPrincipal(String) - Constructor for class org.apache.cassandra.auth.CassandraPrincipal
Create a CassPrincipal with a username.
CassandraRelevantEnv - Enum in org.apache.cassandra.config
 
CassandraRelevantProperties - Enum in org.apache.cassandra.config
A class that extracts system properties for the cassandra node it runs within.
CassandraRoleManager - Class in org.apache.cassandra.auth
Responsible for the creation, maintenance and deletion of roles for the purposes of authentication and authorization.
CassandraRoleManager() - Constructor for class org.apache.cassandra.auth.CassandraRoleManager
 
CassandraStreamHeader - Class in org.apache.cassandra.db.streaming
 
CassandraStreamHeader.Builder - Class in org.apache.cassandra.db.streaming
 
CassandraStreamHeader.CassandraStreamHeaderSerializer - Class in org.apache.cassandra.db.streaming
 
CassandraStreamHeaderSerializer() - Constructor for class org.apache.cassandra.db.streaming.CassandraStreamHeader.CassandraStreamHeaderSerializer
 
CassandraStreamManager - Class in org.apache.cassandra.db.streaming
Implements the streaming interface for the native cassandra storage engine.
CassandraStreamManager(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.streaming.CassandraStreamManager
 
CassandraStreamReader - Class in org.apache.cassandra.db.streaming
CassandraStreamReader reads from stream and writes to SSTable.
CassandraStreamReader(StreamMessageHeader, CassandraStreamHeader, StreamSession) - Constructor for class org.apache.cassandra.db.streaming.CassandraStreamReader
 
CassandraStreamReader.StreamDeserializer - Class in org.apache.cassandra.db.streaming
 
CassandraStreamReceiver - Class in org.apache.cassandra.db.streaming
 
CassandraStreamReceiver(ColumnFamilyStore, StreamSession, int) - Constructor for class org.apache.cassandra.db.streaming.CassandraStreamReceiver
 
CassandraStreamWriter - Class in org.apache.cassandra.db.streaming
CassandraStreamWriter writes given section of the SSTable to given channel.
CassandraStreamWriter(SSTableReader, CassandraStreamHeader, StreamSession) - Constructor for class org.apache.cassandra.db.streaming.CassandraStreamWriter
 
CassandraTableRepairManager - Class in org.apache.cassandra.db.repair
 
CassandraTableRepairManager(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.repair.CassandraTableRepairManager
 
CassandraTableWriteHandler - Class in org.apache.cassandra.db
 
CassandraTableWriteHandler(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.CassandraTableWriteHandler
 
cassandraTriggerDir() - Static method in class org.apache.cassandra.utils.FBUtilities
 
CassandraValidationIterator - Class in org.apache.cassandra.db.repair
 
CassandraValidationIterator(ColumnFamilyStore, Collection<Range<Token>>, UUID, UUID, boolean, int) - Constructor for class org.apache.cassandra.db.repair.CassandraValidationIterator
 
CassandraVersion - Class in org.apache.cassandra.utils
Implements versioning used in Cassandra and CQL.
CassandraVersion(String) - Constructor for class org.apache.cassandra.utils.CassandraVersion
Parse a version from a string.
CassandraWriteContext - Class in org.apache.cassandra.db
 
CassandraWriteContext(OpOrder.Group, CommitLogPosition) - Constructor for class org.apache.cassandra.db.CassandraWriteContext
 
CassHelp() - Constructor for class org.apache.cassandra.tools.NodeTool.CassHelp
 
cast(MappedBuffer) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
 
cast(MappedBuffer) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataBlock
 
cast(MappedBuffer) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataLevel
 
cast(MappedBuffer) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.Level
 
cast(MappedBuffer) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.PointerBlock
 
cast(MappedBuffer) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.PointerLevel
 
CastFcts - Class in org.apache.cassandra.cql3.functions
Casting functions
CasWriteTimeoutException - Exception in org.apache.cassandra.exceptions
 
CasWriteTimeoutException(WriteType, ConsistencyLevel, int, int, int) - Constructor for exception org.apache.cassandra.exceptions.CasWriteTimeoutException
 
CasWriteUnknownResultException - Exception in org.apache.cassandra.exceptions
 
CasWriteUnknownResultException(ConsistencyLevel, int, int) - Constructor for exception org.apache.cassandra.exceptions.CasWriteUnknownResultException
 
category() - Method in enum org.apache.cassandra.net.ConnectionType
 
cause() - Method in class org.apache.cassandra.net.AsyncPromise
 
CBCodec<T> - Interface in org.apache.cassandra.transport
 
cboolean() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the BOOLEAN type.
cboolean() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type boolean.
CBuilder - Class in org.apache.cassandra.db
Allows to build ClusteringPrefixes, either Clustering or ClusteringBound.
CBuilder() - Constructor for class org.apache.cassandra.db.CBuilder
 
CBUtil - Class in org.apache.cassandra.transport
ByteBuf utility methods.
cdc(boolean) - Method in class org.apache.cassandra.schema.TableParams.Builder
 
cdc - Variable in class org.apache.cassandra.schema.TableParams
 
cdc_enabled - Variable in class org.apache.cassandra.config.Config
 
cdc_free_space_check_interval_ms - Variable in class org.apache.cassandra.config.Config
 
cdc_raw_directory - Variable in class org.apache.cassandra.config.Config
 
cdc_total_space_in_mb - Variable in class org.apache.cassandra.config.Config
 
cdcIndexFileName() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
CDCWriteException - Exception in org.apache.cassandra.exceptions
 
CDCWriteException(String) - Constructor for exception org.apache.cassandra.exceptions.CDCWriteException
 
cdouble() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the DOUBLE type.
cdouble() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type double.
ceil(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
 
ceilIndex(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
 
ceiling(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
 
ceiling(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
ceiling(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
cell(ColumnMetadata, long, int, int, V, CellPath) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor.ObjectFactory
 
Cell<V> - Class in org.apache.cassandra.db.rows
A cell is our atomic unit for a single value of a single column.
Cell(ColumnMetadata) - Constructor for class org.apache.cassandra.db.rows.Cell
 
Cell.Factory<V> - Interface in org.apache.cassandra.db.rows
 
cellComparator() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
CellPath - Class in org.apache.cassandra.db.rows
A path for a cell belonging to a complex column type (non-frozen collection or UDT).
CellPath() - Constructor for class org.apache.cassandra.db.rows.CellPath
 
CellPath.Serializer - Interface in org.apache.cassandra.db.rows
 
cellPathComparator() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
cellPathForField(FieldIdentifier) - Method in class org.apache.cassandra.db.marshal.UserType
 
cellPathSerializer - Static variable in class org.apache.cassandra.db.marshal.CollectionType
 
cellPathSerializer() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
cells() - Method in class org.apache.cassandra.db.rows.BTreeRow
 
Cells - Class in org.apache.cassandra.db.rows
Static methods to work on cells.
cells() - Method in interface org.apache.cassandra.db.rows.Row
An iterable over the cells of this row.
cellsCount() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
cellsInLegacyOrder(TableMetadata, boolean) - Method in class org.apache.cassandra.db.rows.BTreeRow
 
cellsInLegacyOrder(TableMetadata, boolean) - Method in interface org.apache.cassandra.db.rows.Row
An iterable over the cells of this row that return cells in "legacy order".
cellValueType() - Method in class org.apache.cassandra.schema.ColumnMetadata
The type of the cell values for cell belonging to this column.
cf - Variable in class org.apache.cassandra.metrics.TableMetrics.TableHistogram
 
cf - Variable in class org.apache.cassandra.metrics.TableMetrics.TableTimer
 
CfHistograms - Class in org.apache.cassandra.tools.nodetool
Deprecated.
use TableHistograms
CfHistograms() - Constructor for class org.apache.cassandra.tools.nodetool.CfHistograms
Deprecated.
 
cfloat() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the FLOAT type.
cfloat() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type float.
cfName - Variable in class org.apache.cassandra.cql3.ColumnSpecification
 
cfName - Variable in exception org.apache.cassandra.exceptions.AlreadyExistsException
 
cfname - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
cfs - Variable in class org.apache.cassandra.db.AbstractCompactionController
 
cfs - Variable in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
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.AbstractStrategyHolder
 
cfs - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
cfs - Variable in class org.apache.cassandra.db.Memtable
 
cfs - Variable in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
 
cfs - Variable in class org.apache.cassandra.service.reads.AbstractReadExecutor
 
cfs - Variable in class org.apache.cassandra.service.reads.repair.AbstractReadRepair
 
CfStats - Class in org.apache.cassandra.tools.nodetool
Deprecated.
use TableStats
CfStats() - Constructor for class org.apache.cassandra.tools.nodetool.CfStats
Deprecated.
 
cfstore - Variable in class org.apache.cassandra.db.lifecycle.Tracker
 
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
 
channel(Descriptor, Component, long) - Method in class org.apache.cassandra.db.streaming.ComponentContext
 
channel - Variable in class org.apache.cassandra.hints.ChecksummedDataInput
 
channel - Variable in class org.apache.cassandra.io.util.AbstractReaderFileProxy
 
channel() - Method in class org.apache.cassandra.io.util.AbstractReaderFileProxy
 
channel() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
 
channel - Variable in class org.apache.cassandra.io.util.DataOutputStreamPlus
 
channel - Variable in class org.apache.cassandra.io.util.FileHandle
 
channel() - Method in class org.apache.cassandra.io.util.LimitingRebufferer
 
channel - Variable in class org.apache.cassandra.io.util.NIODataInputStream
 
channel() - Method in interface org.apache.cassandra.io.util.ReaderFileProxy
 
channel - Variable in class org.apache.cassandra.net.AbstractMessageHandler
 
channel() - Method in class org.apache.cassandra.net.AsyncChannelPromise
 
channel - Variable in class org.apache.cassandra.net.OutboundConnectionInitiator.Result.Success
 
channel() - Method in class org.apache.cassandra.transport.Connection
 
channel - Variable in class org.apache.cassandra.transport.SimpleClient
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.cassandra.net.AbstractMessageHandler
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.cassandra.net.FrameDecoder
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.cassandra.streaming.async.StreamingInboundHandler
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.cassandra.transport.PreV5Handlers.LegacyDispatchHandler
 
channelManagers - Variable in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
ChannelProxy - Class in org.apache.cassandra.io.util
A proxy of a FileChannel that: - implements reference counting - exports only thread safe FileChannel operations - wraps IO exceptions into runtime exceptions Tested by RandomAccessReaderTest.
ChannelProxy(String) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
 
ChannelProxy(File) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
 
ChannelProxy(String, FileChannel) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
 
ChannelProxy(ChannelProxy) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
 
ChannelProxyReadChannel(ChannelProxy, long) - Constructor for class org.apache.cassandra.security.EncryptionUtils.ChannelProxyReadChannel
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.cassandra.net.AbstractMessageHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.cassandra.net.FrameDecoder
Called by Netty pipeline when a new message arrives; we anticipate in normal operation this will receive messages of type BufferPoolAllocator.Wrapped or BufferPoolAllocator.Wrapped.
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.cassandra.streaming.async.StreamingInboundHandler
 
channelRead0(ChannelHandlerContext, Message.Request) - Method in class org.apache.cassandra.transport.PreV5Handlers.LegacyDispatchHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class org.apache.cassandra.net.FrameDecoder
 
CHAR_MASK - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
charCount - Variable in class org.apache.cassandra.index.sasi.sa.SA
 
CHARSET - Static variable in class org.apache.cassandra.io.util.FileUtils
 
CharTerm - Class in org.apache.cassandra.index.sasi.sa
 
CharTerm(int, CharBuffer, TokenTreeBuilder) - Constructor for class org.apache.cassandra.index.sasi.sa.CharTerm
 
check(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.Verifier.RangeOwnHelper
check if the given key is contained in any of the given ranges Must be called in sorted order - key should be increasing
check_for_duplicate_rows_during_compaction - Variable in class org.apache.cassandra.config.Config
 
check_for_duplicate_rows_during_reads - Variable in class org.apache.cassandra.config.Config
If these are enabled duplicate keys will get logged, and if snapshot_on_duplicate_row_detection is enabled, the table will get snapshotted for offline investigation
checkAccess(Thread) - Method in class org.apache.cassandra.security.ThreadAwareSecurityManager
 
checkAccess(ThreadGroup) - Method in class org.apache.cassandra.security.ThreadAwareSecurityManager
 
checkAndClear() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
atomically: cancels the Signal if !isSet(), or returns true if isSignalled()
checkBindValueSet(ByteBuffer, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified bind marker value is set to a meaningful value.
checkBounds(long, long) - Method in class org.apache.cassandra.io.util.Memory
 
checkBounds(long, long) - Method in class org.apache.cassandra.io.util.SafeMemory
 
checkCertFilesForHotReloading(EncryptionOptions.ServerEncryptionOptions, EncryptionOptions) - Static method in class org.apache.cassandra.security.SSLFactory
Performs a lightweight check whether the certificate files have been refreshed.
checkComparable() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
checkContainsNoDuplicates(List<?>, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified list does not contains duplicates.
checkContainsOnly(List<E>, List<E>, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified list contains only the specified elements.
checkCrc() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
 
checkDatacenter - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkDataDirs - Static variable in class org.apache.cassandra.service.StartupChecks
 
CheckedFunction<T,R,E extends java.lang.Exception> - Interface in org.apache.cassandra.io.util
 
checkFalse(boolean, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified expression is false.
checkFalse(boolean, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified expression is false.
CheckForAbort() - Constructor for class org.apache.cassandra.db.ReadCommand.CheckForAbort
 
checkForDuplicateRowsDuringCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
checkForDuplicateRowsDuringReads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
checkForEndpointCollision(UUID, Set<InetAddressAndPort>) - Method in class org.apache.cassandra.service.StorageService
 
checkForExceptions() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader.StreamDeserializer
 
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.
checkIfTupleType(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.Tuples
 
checkJemalloc - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkJMXPorts - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkJMXProperties - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkLegacyAuthTables - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkLimit(int) - Method in class org.apache.cassandra.hints.ChecksummedDataInput
 
checkLz4Native - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkMaxMapCount - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkNativeLibraryInitialization - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkNotEmpty(T, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified collections is NOT empty.
checkNotNull(T, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified object is NOT null.
checkNull(T, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified object is null.
checkNull(T, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified object is null.
checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
Deprecated.
checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
Check for validity of the output-specification for the job.
checkOutputSpecs(Configuration) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
Deprecated.
checkOwnsTokens(boolean) - Method in class org.apache.cassandra.db.compaction.Verifier.Options.Builder
 
checkOwnsTokens - Variable in class org.apache.cassandra.db.compaction.Verifier.Options
 
checkPackageAccess(String) - Method in class org.apache.cassandra.security.ThreadAwareSecurityManager
 
checkPermission(ClientState, Permission, RoleResource) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
 
checkPermission(Permission) - Method in class org.apache.cassandra.security.ThreadAwareSecurityManager
 
checkPermission(Permission, Object) - Method in class org.apache.cassandra.security.ThreadAwareSecurityManager
 
checkpoint() - Method in interface org.apache.cassandra.db.lifecycle.ILifecycleTransaction
 
checkpoint() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
call when a consistent batch of changes is ready to be made atomically visible these will be exposed in the Tracker atomically, or an exception will be thrown; in this case the transaction should be rolled back
checkpoint() - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
 
checkpoint() - Method in class org.apache.cassandra.index.sasi.plan.Expression
 
checkpoint() - Method in class org.apache.cassandra.index.sasi.plan.QueryController
 
checkpw(String, String) - Static method in class org.apache.cassandra.auth.PasswordAuthenticator
 
checkRack - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkSSTablesFormat - Static variable in class org.apache.cassandra.service.StartupChecks
 
ChecksummedDataInput - Class in org.apache.cassandra.hints
A RandomAccessReader wrapper that calculates the CRC in place.
ChecksummedRandomAccessReader - Class in org.apache.cassandra.io.util
 
ChecksummedRandomAccessReader() - Constructor for class org.apache.cassandra.io.util.ChecksummedRandomAccessReader
 
ChecksummedSequentialWriter - Class in org.apache.cassandra.io.util
 
ChecksummedSequentialWriter(File, File, File, SequentialWriterOption) - Constructor for class org.apache.cassandra.io.util.ChecksummedSequentialWriter
 
ChecksummedSequentialWriter.TransactionalProxy - Class in org.apache.cassandra.io.util
 
ChecksumMismatchException - Exception in org.apache.cassandra.exceptions
 
ChecksumMismatchException() - Constructor for exception org.apache.cassandra.exceptions.ChecksumMismatchException
 
ChecksumMismatchException(String) - Constructor for exception org.apache.cassandra.exceptions.ChecksumMismatchException
 
ChecksumType - Enum in org.apache.cassandra.utils
 
checksumValidator(Descriptor) - Static method in class org.apache.cassandra.io.util.DataIntegrityMetadata
 
ChecksumValidator(Descriptor) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
 
ChecksumValidator(ChecksumType, RandomAccessReader, String) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
 
ChecksumValidator(ChecksumType, RandomAccessReader, int) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
 
ChecksumWriter - Class in org.apache.cassandra.io.util
 
ChecksumWriter(DataOutput) - Constructor for class org.apache.cassandra.io.util.ChecksumWriter
 
checkSystemKeyspaceState - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkTrue(boolean, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified expression is true.
checkTrue(boolean, String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Checks that the specified expression is true.
checkUpdateable() - Method in class org.apache.cassandra.db.MultiCBuilder
 
checkValidLaunchDate - Static variable in class org.apache.cassandra.service.StartupChecks
 
checkVersion(boolean) - Method in class org.apache.cassandra.db.compaction.Verifier.Options.Builder
 
checkVersion - Variable in class org.apache.cassandra.db.compaction.Verifier.Options
 
childCount() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
 
childCount() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf
 
childCount() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
 
children - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
 
chooseGroup(String, Class<?>) - Static method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
If the group is empty, use the package name of the given class.
chooseName(String, Method) - Static method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
If name is empty, use the name of the given method.
chooseType(String, Class<?>) - Static method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
If the type is empty, use the simple name of the given class.
Chunk(long, int) - Constructor for class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
 
CHUNK_LENGTH_IN_KB - Static variable in class org.apache.cassandra.schema.CompressionParams
 
chunk_length_kb - Variable in class org.apache.cassandra.config.TransparentDataEncryptionOptions
 
CHUNK_LENGTH_KB - Static variable in class org.apache.cassandra.schema.CompressionParams
Deprecated.
ChunkCache - Class in org.apache.cassandra.cache
 
ChunkCacheMetrics - Class in org.apache.cassandra.metrics
Metrics for ICache.
ChunkCacheMetrics(ChunkCache) - Constructor for class org.apache.cassandra.metrics.ChunkCacheMetrics
Create metrics for the provided chunk cache.
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.schema.CompressionParams
 
chunkLengthInKB() - Method in class org.apache.cassandra.schema.CompressionParams
 
chunkOffsetBy(int) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
Get a chunk offset by it's index.
ChunkReader - Interface in org.apache.cassandra.io.util
RandomFileReader component that reads data from a file into a provided buffer and may have requirements over the size and alignment of reads.
chunks() - Method in class org.apache.cassandra.db.streaming.CompressionInfo
Returns the offset and length of the file chunks.
chunkSize() - Method in interface org.apache.cassandra.io.util.ChunkReader
Buffer size required for this rebufferer.
chunkSize() - Method in class org.apache.cassandra.io.util.CompressedChunkReader
 
chunkSize - Variable in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
 
chunkStart(long) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
 
cint() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the INT type.
cint() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type int.
cipher - Variable in class org.apache.cassandra.config.TransparentDataEncryptionOptions
 
CIPHER - Static variable in class org.apache.cassandra.transport.ConnectedClient
 
cipher_suites - Variable in class org.apache.cassandra.config.EncryptionOptions
 
CipherFactory - Class in org.apache.cassandra.security
A factory for loading encryption keys from KeyProvider instances.
CipherFactory(TransparentDataEncryptionOptions) - Constructor for class org.apache.cassandra.security.CipherFactory
 
cipherSuitesArray() - Method in class org.apache.cassandra.config.EncryptionOptions
 
CLASS - Static variable in class org.apache.cassandra.schema.CompressionParams
 
CLASS - Static variable in class org.apache.cassandra.schema.ReplicationParams
 
CLASS - Static variable in class org.apache.cassandra.schema.TriggerMetadata
 
CLASS_NAME - Static variable in class org.apache.cassandra.config.ParameterizedClass
 
class_name - Variable in class org.apache.cassandra.config.ParameterizedClass
 
classForName(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
classFromName(String) - Static method in class org.apache.cassandra.schema.CompactionParams
 
classOption - Variable in class org.apache.cassandra.schema.TriggerMetadata
 
clean(ByteBuffer) - Static method in class org.apache.cassandra.io.util.FileUtils
 
clean() - Method in interface org.apache.cassandra.utils.memory.MemtableCleaner
This is a function that schedules a cleaning task, normally flushing of the largest sstable.
cleanDirectory(File, Throwable) - Static method in class org.apache.cassandra.utils.binlog.BinLog
 
cleaned(Throwable) - Static method in class org.apache.cassandra.utils.Throwables
A shortcut for unchecked(unwrapped(t)).
cleanThreshold - Variable in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
 
cleanup() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReceiver
 
cleanup() - Method in class org.apache.cassandra.diag.DiagnosticEventService
Removes all active subscribers.
cleanup(TableId, Collection<Range<Token>>, boolean) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
cleanup() - Method in class org.apache.cassandra.repair.consistent.LocalSessions
Auto fails and auto deletes timed out and old sessions Compaction will clean up the sstables still owned by a deleted session
cleanUp(UUID, Set<InetAddressAndPort>) - Method in class org.apache.cassandra.service.ActiveRepairService
Send Verb.CLEANUP_MSG to the given endpoints.
cleanup() - Method in interface org.apache.cassandra.streaming.StreamReceiver
Called after finished has returned and we've sent any messages to other nodes.
Cleanup - Class in org.apache.cassandra.tools.nodetool
 
Cleanup() - Constructor for class org.apache.cassandra.tools.nodetool.Cleanup
 
CLEANUP_INTERVAL - Static variable in class org.apache.cassandra.repair.consistent.LocalSessions
How often LocalSessions.cleanup is run
cleanupCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
CleanupDataCmd() - Constructor for class org.apache.cassandra.tools.nodetool.RepairAdmin.CleanupDataCmd
 
cleanupJob(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
 
CleanupMessage - Class in org.apache.cassandra.repair.messages
Message to cleanup repair resources on replica nodes.
CleanupMessage(UUID) - Constructor for class org.apache.cassandra.repair.messages.CleanupMessage
 
cleanupPending(List<String>, String, boolean) - Method in class org.apache.cassandra.service.ActiveRepairService
 
cleanupPending(List<String>, String, boolean) - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
 
cleanupSizeEstimates() - Method in class org.apache.cassandra.service.StorageService
 
cleanupSizeEstimates() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Removes extraneous entries in system.size_estimates.
CleanupSummary - Class in org.apache.cassandra.repair.consistent.admin
 
CleanupSummary(String, String, Set<UUID>, Set<UUID>) - Constructor for class org.apache.cassandra.repair.consistent.admin.CleanupSummary
 
CleanupSummary(ColumnFamilyStore, Set<UUID>, Set<UUID>) - Constructor for class org.apache.cassandra.repair.consistent.admin.CleanupSummary
 
CleanupTransaction - Interface in org.apache.cassandra.index.transactions
Performs garbage collection of index entries during a cleanup.
clear() - Method in class org.apache.cassandra.cache.CaffeineCache
 
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(String) - Static method in class org.apache.cassandra.db.Keyspace
 
clear(String, Schema) - Static method in class org.apache.cassandra.db.Keyspace
 
clear() - Method in class org.apache.cassandra.db.rows.RangeTombstoneMarker.Merger
 
clear() - Method in class org.apache.cassandra.db.rows.Row.Merger
 
clear() - Method in class org.apache.cassandra.db.view.ViewUpdateGenerator
Clears the current state so that the generator may be reused.
clear() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
clear() - Method in class org.apache.cassandra.io.util.DataOutputBufferFixed
 
clear() - Method in class org.apache.cassandra.metrics.ClearableHistogram
 
clear() - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
clear() - Method in class org.apache.cassandra.net.InboundSink
 
clear() - Method in class org.apache.cassandra.net.OutboundSink
 
clear() - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
 
clear() - Method in class org.apache.cassandra.schema.Schema
Clear all KS/CF metadata and reset version.
clear() - Method in class org.apache.cassandra.transport.ProtocolVersionTracker
 
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.concurrent.WeightedQueue
 
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_snapshot - Variable in class org.apache.cassandra.db.SnapshotCommand
 
ClearableHistogram - Class in org.apache.cassandra.metrics
Adds ability to reset a histogram
ClearableHistogram(DecayingEstimatedHistogramReservoir) - Constructor for class org.apache.cassandra.metrics.ClearableHistogram
Creates a new Histogram with the given reservoir.
clearAllEstimates() - Static method in class org.apache.cassandra.db.SystemKeyspace
truncates size_estimates and table_estimates tables
clearAllLocal(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.context.CounterContext
 
clearCache() - Static method in class org.apache.cassandra.auth.Roles
 
clearConnectionHistory() - Method in class org.apache.cassandra.service.CassandraDaemon
 
clearConnectionHistory() - Method in interface org.apache.cassandra.service.CassandraDaemon.Server
 
clearConnectionHistory() - Method in class org.apache.cassandra.service.NativeTransportService
 
clearConnectionHistory() - Method in class org.apache.cassandra.service.StorageService
 
clearConnectionHistory() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Clears the history of clients that have connected in the past
clearConnectionHistory() - Method in class org.apache.cassandra.tools.NodeProbe
 
clearConnectionHistory() - Method in class org.apache.cassandra.transport.Server
 
clearEphemeralSnapshots(Directories) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
clearEstimates(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
Clears size estimates for a table (on table drop)
clearInternalStatementsCache() - Static method in class org.apache.cassandra.cql3.QueryProcessor
Clear our internal statmeent cache for test purposes.
clearOverflow() - Method in class org.apache.cassandra.utils.EstimatedHistogram
Resets the count in the overflow bucket to zero.
clearPreparedStatements(boolean) - Static method in class org.apache.cassandra.cql3.QueryProcessor
Clears the prepared statement cache.
clearSnapshot(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Clear all the snapshots for a given column family.
clearSnapshot(String, List<File>, RateLimiter) - Static method in class org.apache.cassandra.db.Directories
 
clearSnapshot(String, String) - Static method in class org.apache.cassandra.db.Keyspace
Clear all the snapshots for a given keyspace.
clearSnapshot(String, String...) - Method in class org.apache.cassandra.service.StorageService
Remove the snapshot with the given name from the given keyspaces.
clearSnapshot(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Remove the snapshot with the given name from the given keyspaces.
clearSnapshot(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
Remove all the existing snapshots.
ClearSnapshot - Class in org.apache.cassandra.tools.nodetool
 
ClearSnapshot() - Constructor for class org.apache.cassandra.tools.nodetool.ClearSnapshot
 
clearSSTableReadMeter(String, String, int) - Static method in class org.apache.cassandra.db.SystemKeyspace
Clears persisted read rates from system.sstable_activity for SSTables that have been deleted.
clearState() - Method in class org.apache.cassandra.db.UnfilteredDeserializer
Clears any state in this deserializer.
clearUnsafe() - Method in class org.apache.cassandra.db.ColumnFamilyStore
For testing.
clearUnsafe() - Method in class org.apache.cassandra.gms.Gossiper
 
clearUnsafe() - Method in class org.apache.cassandra.locator.TokenMetadata
used by tests
clearUnsafe(int) - Method in class org.apache.cassandra.utils.concurrent.Accumulator
Removes element at the speficied index from this accumulator.
clearUnwritableUnsafe() - Static method in class org.apache.cassandra.db.DisallowedDirectories
Testing only! Clear the set of unwritable directories.
Client() - Constructor for class org.apache.cassandra.io.sstable.SSTableLoader.Client
 
Client - Class in org.apache.cassandra.transport
 
Client(String, int, ProtocolVersion, EncryptionOptions) - Constructor for class org.apache.cassandra.transport.Client
 
client_encryption_options - Variable in class org.apache.cassandra.config.Config
 
clientEncOptions - Variable in class org.apache.cassandra.tools.LoaderOptions
 
clientInitialization() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
clientInitialization(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
Initializes this class as a client, which means that just an empty configuration will be used.
ClientMessageSizeMetrics - Class in org.apache.cassandra.metrics
Metrics to track the size of incoming and outgoing bytes at Cassandra server.
ClientMessageSizeMetrics() - Constructor for class org.apache.cassandra.metrics.ClientMessageSizeMetrics
 
ClientMetrics - Class in org.apache.cassandra.metrics
 
ClientRequestMetrics - Class in org.apache.cassandra.metrics
 
ClientRequestMetrics(String) - Constructor for class org.apache.cassandra.metrics.ClientRequestMetrics
 
ClientResourceLimits - Class in org.apache.cassandra.transport
 
ClientResourceLimits() - Constructor for class org.apache.cassandra.transport.ClientResourceLimits
 
ClientStat - Class in org.apache.cassandra.transport
 
ClientState - Class in org.apache.cassandra.service
State related to a client connection.
ClientState(InetSocketAddress) - Constructor for class org.apache.cassandra.service.ClientState
 
ClientState(ClientState) - Constructor for class org.apache.cassandra.service.ClientState
 
ClientStats - Class in org.apache.cassandra.tools.nodetool
 
ClientStats() - Constructor for class org.apache.cassandra.tools.nodetool.ClientStats
 
ClientWarn - Class in org.apache.cassandra.service
 
ClientWarn.State - Class in org.apache.cassandra.service
 
clientWarnings(Keyspaces.KeyspacesDiff) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement
 
clientWarnState - Variable in class org.apache.cassandra.concurrent.ExecutorLocals
 
ClientWriteRequestMetrics - Class in org.apache.cassandra.metrics
Metrics for tracking information about write requests.
ClientWriteRequestMetrics(String) - Constructor for class org.apache.cassandra.metrics.ClientWriteRequestMetrics
 
CliPattern(String) - Constructor for class org.apache.cassandra.tools.JMXTool.CliPattern
 
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.CommitLogPosition
 
clone() - Method in class org.apache.cassandra.transport.Envelope
 
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(byte[]) - Method in class org.apache.cassandra.utils.memory.AbstractAllocator
Allocate a slice of the given length.
clone(V, ValueAccessor<V>) - Method in class org.apache.cassandra.utils.memory.AbstractAllocator
 
clone(ByteBuffer) - Method in class org.apache.cassandra.utils.memory.ContextAllocator
 
clone(DecoratedKey, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
 
clone(DecoratedKey, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
 
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.
cloneAndReplace(IFilter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Clone this reader with the new values and set the clone as replacement.
cloneOnlyTokenMap() - Method in class org.apache.cassandra.locator.TokenMetadata
Create a copy of TokenMetadata with only tokenToEndpointMap.
cloneWithHigherVersion(VersionedValue) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
cloneWithKeyspaceIfSet(String) - Method in class org.apache.cassandra.service.ClientState
Clone this ClientState object, but use the provided keyspace instead of the keyspace in this ClientState object.
cloneWithNewPartitioner(IPartitioner) - Method in class org.apache.cassandra.locator.TokenMetadata
cloneWithNewStart(DecoratedKey, Runnable) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
cloneWithNewSummarySamplingLevel(ColumnFamilyStore, int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Returns a new SSTableReader with the same properties as this SSTableReader except that a new IndexSummary will be built at the target samplingLevel.
cloneWithRestoredStart(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
cloningBTreeRowBuilder() - Method in class org.apache.cassandra.utils.memory.AbstractAllocator
 
close() - Method in class org.apache.cassandra.cache.ChunkCache
 
close() - Method in class org.apache.cassandra.cache.RefCountedMemory
 
close() - Method in class org.apache.cassandra.db.CassandraWriteContext
 
close() - Method in class org.apache.cassandra.db.ColumnFamilyStore.RefViewFragment
 
close() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
close() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
 
close() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
 
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.CompactionIterator
 
close() - Method in interface org.apache.cassandra.db.compaction.CompactionManager.CompactionPauser
 
close() - Method in class org.apache.cassandra.db.compaction.CompactionTasks
 
close() - Method in class org.apache.cassandra.db.compaction.Scrubber
 
close() - Method in class org.apache.cassandra.db.compaction.Verifier
 
close() - Method in class org.apache.cassandra.db.lifecycle.LogReplicaSet
 
close() - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
 
close() - Method in class org.apache.cassandra.db.partitions.AbstractUnfilteredPartitionIterator
 
close() - Method in interface org.apache.cassandra.db.partitions.BasePartitionIterator
 
close() - Method in class org.apache.cassandra.db.partitions.SingletonUnfilteredPartitionIterator
 
close() - Method in interface org.apache.cassandra.db.partitions.UnfilteredPartitionIterators.MergeListener
 
close() - Method in class org.apache.cassandra.db.ReadExecutionController
 
close() - Method in class org.apache.cassandra.db.repair.CassandraValidationIterator
 
close() - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexInfoRetriever
 
close() - Method in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
 
close() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
 
close() - Method in class org.apache.cassandra.db.rows.ThrottledUnfilteredIterator
 
close() - Method in interface org.apache.cassandra.db.rows.UnfilteredRowIterators.MergeListener
 
close() - Method in class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
 
close(boolean) - Method in class org.apache.cassandra.db.Slice
 
close() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader.StreamDeserializer
 
close() - Method in class org.apache.cassandra.db.streaming.ComponentContext
 
close() - Method in class org.apache.cassandra.db.streaming.CompressedInputStream
 
close(UnfilteredPartitionIterator) - Static method in class org.apache.cassandra.db.transform.RTBoundCloser
 
close(UnfilteredRowIterator) - Static method in class org.apache.cassandra.db.transform.RTBoundCloser
 
close() - Method in interface org.apache.cassandra.db.WriteContext
 
close(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
close(Reporter) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
Deprecated.
close() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
close() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
 
close() - Method in class org.apache.cassandra.hints.CompressedChecksummedDataInput
 
close() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
close() - Method in class org.apache.cassandra.index.sasi.disk.TokenTree.TokenTreeIterator
 
close() - Method in class org.apache.cassandra.index.sasi.memory.KeyRangeIterator
 
close() - Method in class org.apache.cassandra.index.sasi.plan.Operation
 
close() - Method in class org.apache.cassandra.index.sasi.TermIterator
 
close() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
close() - Method in class org.apache.cassandra.index.sasi.utils.OnDiskIndexIterator
 
close() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.EmptyRangeIterator
 
close() - Method in class org.apache.cassandra.index.sasi.utils.RangeUnionIterator
 
close() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
 
close() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
Close this writer.
close() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
close() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableZeroCopyWriter
 
close() - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
 
close() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
close() - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
close(Throwable) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
close() - Method in class org.apache.cassandra.io.sstable.KeyIterator
 
close() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
close() - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
 
close() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
close() - Method in class org.apache.cassandra.io.util.AbstractReaderFileProxy
 
close() - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
close() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
 
close() - Method in class org.apache.cassandra.io.util.CompressedChunkReader.Mmap
 
close() - Method in class org.apache.cassandra.io.util.DataInputBuffer
 
close() - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
 
close() - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.FileDigestValidator
 
close() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
close(Throwable) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
 
close() - Method in class org.apache.cassandra.io.util.FileHandle.Builder
 
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.LimitingRebufferer
 
close() - Method in class org.apache.cassandra.io.util.Memory
 
close() - Method in class org.apache.cassandra.io.util.NIODataInputStream
 
close() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
close() - Method in interface org.apache.cassandra.io.util.ReaderFileProxy
 
close() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
close(boolean) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
close() - Method in class org.apache.cassandra.io.util.SafeMemory
 
close(Throwable) - Method in class org.apache.cassandra.io.util.SafeMemory
 
close() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
close(Throwable) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
close() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
close() - Method in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
 
close() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
close() - Method in class org.apache.cassandra.metrics.TableMetrics.TableTimer.Context
 
close() - Method in class org.apache.cassandra.net.AsyncChannelOutputPlus
Flush any remaining writes, and release any buffers.
close() - Method in class org.apache.cassandra.net.AsyncMessageOutputPlus
 
close() - Method in class org.apache.cassandra.net.AsyncStreamingInputPlus
Note: This should invoked on the consuming thread.
close(boolean) - Method in class org.apache.cassandra.net.OutboundConnection
Permanently close this connection.
close() - Method in class org.apache.cassandra.security.EncryptionUtils.ChannelProxyReadChannel
 
close() - Method in class org.apache.cassandra.service.pager.AggregationQueryPager.GroupByPartitionIterator
 
close() - Method in class org.apache.cassandra.service.reads.repair.PartitionIteratorMergeListener
 
close() - Method in class org.apache.cassandra.service.reads.repair.RowIteratorMergeListener
 
close() - Method in class org.apache.cassandra.streaming.async.NettyStreamingMessageSender
 
close() - Method in class org.apache.cassandra.streaming.compress.StreamCompressionInputStream
Close resources except StreamCompressionInputStream.dataInputPlus as that needs to remain open for other streaming activity.
close() - Method in interface org.apache.cassandra.streaming.StreamingMessageSender
 
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.AbstractIterator
 
close() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
 
close(Throwable) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
 
close() - Method in interface org.apache.cassandra.utils.CloseableIterator
 
close() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
To be called exactly once for each register() call this object is returned for, indicating the operation is complete
close() - Method in class org.apache.cassandra.utils.concurrent.Ref
 
close() - Method in class org.apache.cassandra.utils.concurrent.Refs
close(Throwable) - Method in interface org.apache.cassandra.utils.concurrent.SharedCloseable
 
close() - Method in class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
 
close(Throwable) - Method in class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
 
close() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
 
close() - Method in interface org.apache.cassandra.utils.concurrent.Transactional
 
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(Throwable, Iterable<? extends AutoCloseable>) - Static method in class org.apache.cassandra.utils.Throwables
 
CloseableIterator<T> - Interface in org.apache.cassandra.utils
 
closeableIterator(Iterator<T>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
closeAll(Collection<? extends AutoCloseable>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
closeAllAndPropagate(Collection<ISSTableScanner>, Throwable) - Static method in interface org.apache.cassandra.io.sstable.ISSTableScanner
 
closeBound(boolean) - Method in class org.apache.cassandra.db.ArrayClusteringBoundary
 
closeBound(boolean) - Method in class org.apache.cassandra.db.BufferClusteringBoundary
 
closeBound(boolean) - Method in interface org.apache.cassandra.db.ClusteringBoundary
 
closeBound(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
closeBound(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
closeBound(boolean) - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
 
closeBoundOfBoundary(boolean) - Method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
 
closeDeletionTime(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
closeDeletionTime(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
closeDeletionTime(boolean) - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
 
closeIsInclusive(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
closeIsInclusive(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
closeIsInclusive(boolean) - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
 
closeOutbound(InetAddressAndPort) - Method in class org.apache.cassandra.net.MessagingService
Only to be invoked once we believe the endpoint will never be contacted again.
closeQuietly(Closeable) - Static method in class org.apache.cassandra.io.util.FileUtils
 
closeQuietly(AutoCloseable) - Static method in class org.apache.cassandra.io.util.FileUtils
 
closeQuietly(Iterable<? extends AutoCloseable>) - Static method in class org.apache.cassandra.io.util.FileUtils
 
closeQuietly() - Method in class org.apache.cassandra.io.util.MmappedRegions
 
closeReader() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
 
closeReader() - Method in class org.apache.cassandra.io.util.LimitingRebufferer
 
closeReader() - Method in interface org.apache.cassandra.io.util.Rebufferer
Called when a reader is closed.
CloudstackSnitch - Class in org.apache.cassandra.locator
A snitch that assumes a Cloudstack Zone follows the typical convention <country>-<location>-<availability zone> and uses the country/location tuple as a datacenter and the availability zone as a rack
CloudstackSnitch() - Constructor for class org.apache.cassandra.locator.CloudstackSnitch
 
cluster() - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
Creates a DescribeStatement for DESCRIBE CLUSTER.
cluster_name - Variable in class org.apache.cassandra.config.Config
 
Clusterable<T> - Interface in org.apache.cassandra.db
Common class for objects that are identified by a clustering prefix, and can be thus sorted by a ClusteringComparator.
clustering() - Method in class org.apache.cassandra.db.AbstractOnHeapClusteringPrefix
 
clustering() - Method in class org.apache.cassandra.db.aggregation.GroupingState
Returns the last row clustering or null if either no rows has been processed yet or the last row was a static row.
clustering() - Method in interface org.apache.cassandra.db.Clusterable
 
Clustering<V> - Interface in org.apache.cassandra.db
 
clustering(V...) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor.ObjectFactory
 
clustering() - Method in interface org.apache.cassandra.db.marshal.ValueAccessor.ObjectFactory
 
clustering() - Method in class org.apache.cassandra.db.NativeClustering
 
clustering() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.CounterMark
 
clustering() - Method in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
 
clustering - Variable in class org.apache.cassandra.db.rows.BTreeRow.Builder
 
clustering() - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
 
clustering() - Method in class org.apache.cassandra.db.rows.BTreeRow
 
clustering() - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
 
clustering() - Method in interface org.apache.cassandra.db.rows.Row.Builder
The clustering for the row that is currently being built.
clustering() - Method in interface org.apache.cassandra.db.rows.Row
The clustering values for this row.
clustering() - Method in interface org.apache.cassandra.db.rows.Unfiltered
 
clustering(TableMetadata) - Method in class org.apache.cassandra.service.pager.PagingState.RowMark
 
Clustering.Serializer - Class in org.apache.cassandra.db
Serializer for Clustering object.
CLUSTERING_COLUMN_INDEX_FUNCTIONS - Static variable in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
 
ClusteringBound<V> - Interface in org.apache.cassandra.db
The start or end of a range of clusterings, either inclusive or exclusive.
ClusteringBoundary<V> - Interface in org.apache.cassandra.db
The threshold between two different ranges, i.e.
ClusteringBoundOrBoundary<V> - Interface in org.apache.cassandra.db
This class defines a threshold between ranges of clusterings.
ClusteringBoundOrBoundary.Serializer - Class in org.apache.cassandra.db
 
clusteringColumn(TableMetadata, ByteBuffer, AbstractType<?>, int) - Static method in class org.apache.cassandra.schema.ColumnMetadata
 
clusteringColumn(String, String, String, AbstractType<?>, int) - Static method in class org.apache.cassandra.schema.ColumnMetadata
 
ClusteringColumnIndex - Class in org.apache.cassandra.index.internal.composites
Index on a CLUSTERING_COLUMN column definition.
ClusteringColumnIndex(ColumnFamilyStore, IndexMetadata) - Constructor for class org.apache.cassandra.index.internal.composites.ClusteringColumnIndex
 
clusteringColumns - Variable in class org.apache.cassandra.schema.TableMetadata
 
clusteringColumns() - Method in class org.apache.cassandra.schema.TableMetadata
 
ClusteringComparator - Class in org.apache.cassandra.db
A comparator of clustering prefixes (or more generally of Clusterable}.
ClusteringComparator(AbstractType<?>...) - Constructor for class org.apache.cassandra.db.ClusteringComparator
 
ClusteringComparator(Iterable<AbstractType<?>>) - Constructor for class org.apache.cassandra.db.ClusteringComparator
 
clusteringIndexFilter - Variable in class org.apache.cassandra.db.DataRange
 
clusteringIndexFilter(DecoratedKey) - Method in class org.apache.cassandra.db.DataRange
The clustering index filter to use for the provided key.
clusteringIndexFilter(DecoratedKey) - Method in class org.apache.cassandra.db.DataRange.Paging
 
ClusteringIndexFilter - Interface in org.apache.cassandra.db.filter
A filter that selects a subset of the rows of a given partition by using the "clustering index".
clusteringIndexFilter(DecoratedKey) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
clusteringIndexFilter(DecoratedKey) - Method in class org.apache.cassandra.db.ReadCommand
The clustering index filter this command to use for the provided key.
clusteringIndexFilter() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
clusteringIndexFilter(DecoratedKey) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
clusteringIndexFilter() - Method in interface org.apache.cassandra.db.SinglePartitionReadQuery
 
clusteringIndexFilter() - Method in class org.apache.cassandra.db.VirtualTableSinglePartitionReadQuery
 
ClusteringIndexFilter.InternalDeserializer - Interface in org.apache.cassandra.db.filter
 
ClusteringIndexFilter.Kind - Enum in org.apache.cassandra.db.filter
 
ClusteringIndexFilter.Serializer - Interface in org.apache.cassandra.db.filter
 
clusteringIndexFilterAsSlices() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
Returns the slices fetched by this SELECT, assuming an internal call (no bound values in particular).
ClusteringIndexNamesFilter - Class in org.apache.cassandra.db.filter
A filter selecting rows given their clustering value.
ClusteringIndexNamesFilter(NavigableSet<Clustering<?>>, boolean) - Constructor for class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
 
ClusteringIndexSliceFilter - Class in org.apache.cassandra.db.filter
A filter over a single partition.
ClusteringIndexSliceFilter(Slices, boolean) - Constructor for class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
 
clusteringKeyRestrictionsAreSatisfiedBy(Clustering<?>) - Method in class org.apache.cassandra.db.filter.RowFilter
Returns true if all of the expressions within this filter that apply to the clustering key are satisfied by the given Clustering, false otherwise.
clusteringKeyRestrictionsHasIN() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if restrictions on the clustering key have IN restrictions.
clusteringOrder() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
ClusteringPrefix<V> - Interface in org.apache.cassandra.db
A clustering prefix is the unit of what a ClusteringComparator can compare.
ClusteringPrefix.Deserializer - Class in org.apache.cassandra.db
Helper class that makes the deserialization of clustering prefixes faster.
ClusteringPrefix.Kind - Enum in org.apache.cassandra.db
The kind of clustering prefix this actually is.
ClusteringPrefix.Serializer - Class in org.apache.cassandra.db
 
clusteringTypes() - Method in class org.apache.cassandra.db.SerializationHeader
 
CmdLineOptions() - Constructor for class org.apache.cassandra.tools.BulkLoader.CmdLineOptions
 
cmp - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskBlock.SearchResult
 
code - Variable in enum org.apache.cassandra.db.ConsistencyLevel
 
code() - Method in exception org.apache.cassandra.exceptions.CassandraException
 
code - Variable in enum org.apache.cassandra.exceptions.RequestFailureReason
 
code() - Method in interface org.apache.cassandra.exceptions.TransportException
The exception code.
code - Variable in enum org.apache.cassandra.streaming.ProgressInfo.Direction
 
code() - Method in exception org.apache.cassandra.transport.ProtocolException
 
code() - Method in exception org.apache.cassandra.transport.ServerError
 
codec - Static variable in class org.apache.cassandra.cql3.QueryOptions
 
codec - Static variable in class org.apache.cassandra.cql3.ResultSet
 
Codec() - Constructor for class org.apache.cassandra.cql3.ResultSet.Codec
 
codec - Static variable in class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
 
codec - Static variable in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
codec - Static variable in enum org.apache.cassandra.transport.DataType
 
Codec() - Constructor for class org.apache.cassandra.transport.DataType.Codec
 
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.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
 
codecFor(T) - Method in class org.apache.cassandra.cql3.functions.types.CodecRegistry
Returns a codec that accepts the given value.
codecFor(DataType) - Method in class org.apache.cassandra.cql3.functions.types.CodecRegistry
Returns a codec that accepts the given CQL type.
codecFor(DataType, Class<T>) - Method in class org.apache.cassandra.cql3.functions.types.CodecRegistry
Returns a codec that accepts the given CQL type and the given Java class.
codecFor(DataType, TypeToken<T>) - Method in class org.apache.cassandra.cql3.functions.types.CodecRegistry
Returns a codec that accepts the given CQL type and the given Java type.
codecFor(DataType, T) - Method in class org.apache.cassandra.cql3.functions.types.CodecRegistry
Returns a codec that accepts the given CQL type and the given value.
codecFor(DataType) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
 
CodecNotFoundException - Exception in org.apache.cassandra.cql3.functions.types.exceptions
Thrown when a suitable TypeCodec cannot be found by CodecRegistry instances.
CodecNotFoundException(String) - Constructor for exception org.apache.cassandra.cql3.functions.types.exceptions.CodecNotFoundException
 
CodecNotFoundException(Throwable) - Constructor for exception org.apache.cassandra.cql3.functions.types.exceptions.CodecNotFoundException
 
CodecRegistry - Class in org.apache.cassandra.cql3.functions.types
A registry for TypeCodecs.
CodecRegistry() - Constructor for class org.apache.cassandra.cql3.functions.types.CodecRegistry
Creates a new instance initialized with built-in codecs for all the base CQL types.
CodecUtils - Class in org.apache.cassandra.cql3.functions.types
A set of utility methods to deal with type conversion and serialization.
CollatedViewIndexBuilder - Class in org.apache.cassandra.index.internal
Manages building an entire index from column family data.
CollatedViewIndexBuilder(ColumnFamilyStore, Set<Index>, ReducingKeyIterator, Collection<SSTableReader>) - Constructor for class org.apache.cassandra.index.internal.CollatedViewIndexBuilder
 
CollatedViewIndexBuildingSupport() - Constructor for class org.apache.cassandra.index.Index.CollatedViewIndexBuildingSupport
 
collect(Row, Iterator<Row>, DeletionInfo) - Static method in class org.apache.cassandra.db.rows.EncodingStats.Collector
 
collectCounterMarks() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
For an update on a counter table, returns a list containing a CounterMark for every counter contained in the update.
Collection(CollectionType) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Collection
 
COLLECTION_ENTRY_INDEX_FUNCTIONS - Static variable in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
 
COLLECTION_KEY_INDEX_FUNCTIONS - Static variable in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
 
COLLECTION_VALUE_INDEX_FUNCTIONS - Static variable in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
 
collectionCondition(Term.Raw, Term.Raw, Operator) - Static method in class org.apache.cassandra.cql3.conditions.ColumnCondition.Raw
A condition on a collection element.
CollectionEntryIndex - Class in org.apache.cassandra.index.internal.composites
Index on the element and value of cells participating in a collection.
CollectionEntryIndex(ColumnFamilyStore, IndexMetadata) - Constructor for class org.apache.cassandra.index.internal.composites.CollectionEntryIndex
 
collectionInCondition(Term.Raw, List<Term.Raw>) - Static method in class org.apache.cassandra.cql3.conditions.ColumnCondition.Raw
An IN condition on a collection element.
collectionInCondition(Term.Raw, AbstractMarker.INRaw) - Static method in class org.apache.cassandra.cql3.conditions.ColumnCondition.Raw
An IN condition on a collection element with a single marker.
CollectionKeyIndex - Class in org.apache.cassandra.index.internal.composites
Index on the collection element of the cell name of a collection.
CollectionKeyIndex(ColumnFamilyStore, IndexMetadata) - Constructor for class org.apache.cassandra.index.internal.composites.CollectionKeyIndex
 
CollectionKeyIndexBase - Class in org.apache.cassandra.index.internal.composites
Common superclass for indexes that capture collection keys, including indexes on such keys themselves.
CollectionKeyIndexBase(ColumnFamilyStore, IndexMetadata) - Constructor for class org.apache.cassandra.index.internal.composites.CollectionKeyIndexBase
 
CollectionSerializer<T> - Class in org.apache.cassandra.serializers
 
CollectionSerializer() - Constructor for class org.apache.cassandra.serializers.CollectionSerializer
 
collectionSize(List<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.CollectionType
 
collectionSize(List<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.MapType
 
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(AbstractType.ComparisonType, CollectionType.Kind) - Constructor for class org.apache.cassandra.db.marshal.CollectionType
 
CollectionType.Kind - Enum in org.apache.cassandra.db.marshal
 
CollectionValueIndex - Class in org.apache.cassandra.index.internal.composites
Index the value of a collection cell.
CollectionValueIndex(ColumnFamilyStore, IndexMetadata) - Constructor for class org.apache.cassandra.index.internal.composites.CollectionValueIndex
 
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.conditions.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 interface org.apache.cassandra.cql3.Terms
Collects the column specifications for the bind variables in the terms.
collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Tuples.DelayedValue
 
collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.UserTypes.DelayedValue
 
Collector() - Constructor for class org.apache.cassandra.db.rows.EncodingStats.Collector
 
collector(Set<Collector.Characteristics>, Supplier<B>) - Static method in class org.apache.cassandra.locator.AbstractReplicaCollection
 
collector(InetAddressAndPort) - Static method in class org.apache.cassandra.locator.RangesAtEndpoint
 
Collectors3 - Class in org.apache.cassandra.utils
Some extra Collector implementations.
Collectors3() - Constructor for class org.apache.cassandra.utils.Collectors3
 
collectStats(EncodingStats.Collector) - Method in interface org.apache.cassandra.db.DeletionInfo
 
collectStats(EncodingStats.Collector) - Method in class org.apache.cassandra.db.MutableDeletionInfo
 
collectStats(EncodingStats.Collector) - Method in class org.apache.cassandra.db.RangeTombstoneList
 
collectStats(Cell<?>, PartitionStatisticsCollector) - Static method in class org.apache.cassandra.db.rows.Cells
Collect statistics ont a given cell.
collectStats(Row, PartitionStatisticsCollector) - Static method in class org.apache.cassandra.db.rows.Rows
Collect statistics on a given row.
collectTimestamps() - Method in interface org.apache.cassandra.cql3.selection.Selection.Selectors
Checks if one of the selectors collect timestamps.
collectTTLs() - Method in interface org.apache.cassandra.cql3.selection.Selection.Selectors
Checks if one of the selectors collect TTLs.
column - Variable in class org.apache.cassandra.cql3.conditions.ColumnCondition.Bound
 
column - Variable in class org.apache.cassandra.cql3.conditions.ColumnCondition
 
column - Variable in class org.apache.cassandra.cql3.Operation
 
column - Variable in class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL
 
column - Variable in class org.apache.cassandra.cql3.selection.SimpleSelector
 
column - Variable in class org.apache.cassandra.cql3.statements.schema.IndexTarget
 
column - Variable in class org.apache.cassandra.db.filter.ColumnSubselection
 
column() - Method in class org.apache.cassandra.db.filter.ColumnSubselection
 
column - Variable in class org.apache.cassandra.db.filter.RowFilter.Expression
 
column() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
 
column() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.CounterMark
 
column - Variable in class org.apache.cassandra.db.rows.ColumnData
 
column() - Method in class org.apache.cassandra.db.rows.ColumnData
The column this is data for.
column(String, Object) - Method in class org.apache.cassandra.db.virtual.SimpleDataSet
 
column - Variable in class org.apache.cassandra.schema.DroppedColumn
 
column_family - Variable in class org.apache.cassandra.db.SnapshotCommand
 
column_index_cache_size_in_kb - Variable in class org.apache.cassandra.config.Config
 
column_index_size_in_kb - Variable in class org.apache.cassandra.config.Config
 
ColumnCondition - Class in org.apache.cassandra.cql3.conditions
A CQL3 condition on the value of a column or collection element.
ColumnCondition.Bound - Class in org.apache.cassandra.cql3.conditions
 
ColumnCondition.Raw - Class in org.apache.cassandra.cql3.conditions
 
ColumnConditions - Class in org.apache.cassandra.cql3.conditions
A set of ColumnConditions.
ColumnConditions.Builder - Class in org.apache.cassandra.cql3.conditions
A Builder for ColumnConditions.
columnCount() - Method in class org.apache.cassandra.db.rows.BTreeRow
 
columnCount() - Method in interface org.apache.cassandra.db.rows.Row
The number of columns for which data (incl.
columnData() - Method in class org.apache.cassandra.db.rows.BTreeRow
 
ColumnData - Class in org.apache.cassandra.db.rows
Generic interface for the data of a given column (inside a row).
ColumnData(ColumnMetadata) - Constructor for class org.apache.cassandra.db.rows.ColumnData
 
columnData() - Method in interface org.apache.cassandra.db.rows.Row
A collection of the ColumnData representation of this row, for columns with some data (possibly not live) present
columnDef - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
The definition of the column to which apply the restriction.
columnDefinitionNameComparator(ColumnMetadata.Kind) - Method in class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
 
columnDefs - Variable in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
The columns to which the restriction apply.
columnDefs - Variable in class org.apache.cassandra.cql3.restrictions.TokenRestriction
The definition of the columns to which apply the token restriction.
ColumnDeletion(ColumnIdentifier) - Constructor for class org.apache.cassandra.cql3.Operation.ColumnDeletion
 
columnFamilies - Variable in class org.apache.cassandra.streaming.StreamRequest
 
COLUMNFAMILIES_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
columnFamily() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
columnFamily() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
COLUMNFAMILY - Static variable in class org.apache.cassandra.db.compaction.CompactionInfo
 
columnFamily - Variable in class org.apache.cassandra.db.TruncateResponse
 
columnFamily - Variable in class org.apache.cassandra.repair.RepairJobDesc
 
ColumnFamilySplit - Class in org.apache.cassandra.hadoop
 
ColumnFamilySplit(String, String, String[]) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
Deprecated.
ColumnFamilySplit(String, String, long, String[]) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
 
ColumnFamilySplit() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
 
ColumnFamilyStore - Class in org.apache.cassandra.db
 
ColumnFamilyStore(Keyspace, String, int, TableMetadataRef, Directories, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore
 
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
ColumnFilter - Class in org.apache.cassandra.db.filter
Represents which (non-PK) columns (and optionally which sub-part of a column for complex columns) are selected by a query.
ColumnFilter() - Constructor for class org.apache.cassandra.db.filter.ColumnFilter
 
columnFilter() - Method in interface org.apache.cassandra.db.ReadQuery
A filter on which (non-PK) columns must be returned by the query.
columnFilter() - Method in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
 
ColumnFilter.Builder - Class in org.apache.cassandra.db.filter
A builder for a ColumnFilter object.
ColumnFilter.SelectionColumnFilter - Class in org.apache.cassandra.db.filter
ColumnFilter sub-class for queries with selected columns.
ColumnFilter.Serializer - Class in org.apache.cassandra.db.filter
 
ColumnFilter.Tester - Class in org.apache.cassandra.db.filter
 
ColumnFilter.WildCardColumnFilter - Class in org.apache.cassandra.db.filter
ColumnFilter sub-class for wildcard queries.
columnFilterFactory - Variable in class org.apache.cassandra.cql3.selection.Selection
 
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
 
ColumnIndex - Class in org.apache.cassandra.db
Column index builder used by BigTableWriter.
ColumnIndex(SerializationHeader, SequentialWriter, Version, Collection<SSTableFlushObserver>, ISerializer<IndexInfo>) - Constructor for class org.apache.cassandra.db.ColumnIndex
 
ColumnIndex - Class in org.apache.cassandra.index.sasi.conf
 
ColumnIndex(AbstractType<?>, ColumnMetadata, IndexMetadata) - Constructor for class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
columnIndex - Variable in class org.apache.cassandra.index.sasi.memory.MemIndex
 
columnIndexCount - Variable in class org.apache.cassandra.db.ColumnIndex
 
ColumnMetadata - Class in org.apache.cassandra.schema
 
ColumnMetadata(TableMetadata, ByteBuffer, AbstractType<?>, int, ColumnMetadata.Kind) - Constructor for class org.apache.cassandra.schema.ColumnMetadata
 
ColumnMetadata(String, String, ColumnIdentifier, AbstractType<?>, int, ColumnMetadata.Kind) - Constructor for class org.apache.cassandra.schema.ColumnMetadata
 
ColumnMetadata.ClusteringOrder - Enum in org.apache.cassandra.schema
 
ColumnMetadata.Kind - Enum in org.apache.cassandra.schema
The type of CQL3 column this definition represents.
columnName(List<String>) - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
columnName(List<String>) - Method in interface org.apache.cassandra.cql3.functions.Function
Returns the name of the function to use within a ResultSet.
columnNames() - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
columns - Variable in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
columns(String...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
columns - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
columns() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
Columns - Class in org.apache.cassandra.db
An immutable and sorted list of (non-PK) columns for a given table.
columns() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
columns() - Method in interface org.apache.cassandra.db.partitions.Partition
 
columns() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
 
columns() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
 
columns(boolean) - Method in class org.apache.cassandra.db.RegularAndStaticColumns
 
columns - Variable in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
 
columns() - Method in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
 
columns() - Method in interface org.apache.cassandra.db.rows.BaseRowIterator
A subset of the columns for the (static and regular) rows returned by this iterator.
columns() - Method in class org.apache.cassandra.db.rows.BTreeRow
 
columns() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
 
columns() - Method in interface org.apache.cassandra.db.rows.Row
An in-natural-order collection of the columns for which data (incl.
columns() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
 
columns() - Method in class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
 
columns() - Method in class org.apache.cassandra.db.SerializationHeader
 
columns(boolean) - Method in class org.apache.cassandra.db.SerializationHeader
 
columns() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader.StreamDeserializer
 
columns() - Method in class org.apache.cassandra.db.transform.BaseRows
 
columns() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
COLUMNS - Static variable in class org.apache.cassandra.schema.SchemaKeyspace
 
columns() - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
columns() - Method in class org.apache.cassandra.schema.TableMetadata
 
columns(List<UnfilteredRowIterator>) - Method in class org.apache.cassandra.service.reads.repair.PartitionIteratorMergeListener
 
Columns.Serializer - Class in org.apache.cassandra.db
 
columnsIndex(int) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexInfoRetriever
 
columnsIndexCount() - Method in class org.apache.cassandra.db.RowIndexEntry
 
ColumnSpecification - Class in org.apache.cassandra.cql3
 
ColumnSpecification(String, String, ColumnIdentifier, AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.ColumnSpecification
 
ColumnSubselection - Class in org.apache.cassandra.db.filter
Handles the selection of a subpart of a column.
ColumnSubselection(ColumnMetadata) - Constructor for class org.apache.cassandra.db.filter.ColumnSubselection
 
ColumnSubselection.Serializer - Class in org.apache.cassandra.db.filter
 
colUpdateTimeDeltaHistogram - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Column update time delta on this Keyspace
colUpdateTimeDeltaHistogram - Variable in class org.apache.cassandra.metrics.TableMetrics
Column update time delta on this CF
combinedIndex - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
 
CombinedTerm - Class in org.apache.cassandra.index.sasi.utils
 
CombinedTerm(AbstractType<?>, OnDiskIndex.DataTerm) - Constructor for class org.apache.cassandra.index.sasi.utils.CombinedTerm
 
CombinedTermIterator - Class in org.apache.cassandra.index.sasi.utils
 
CombinedTermIterator(OnDiskIndex...) - Constructor for class org.apache.cassandra.index.sasi.utils.CombinedTermIterator
 
CombinedTermIterator(Descriptor, OnDiskIndex...) - Constructor for class org.apache.cassandra.index.sasi.utils.CombinedTermIterator
 
CombinedValue<V> - Interface in org.apache.cassandra.index.sasi.utils
 
command - Variable in class org.apache.cassandra.index.internal.CassandraIndexSearcher
 
command - Variable in class org.apache.cassandra.service.reads.AbstractReadExecutor
 
command - Variable in class org.apache.cassandra.service.reads.repair.AbstractReadRepair
 
command - Variable in class org.apache.cassandra.service.reads.repair.RepairedDataVerifier.SimpleVerifier
 
command - Variable in class org.apache.cassandra.service.reads.ResponseResolver
 
comment(String) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
comment(String) - Method in class org.apache.cassandra.schema.TableParams.Builder
 
comment - Variable in class org.apache.cassandra.schema.TableParams
 
commit() - Method in class org.apache.cassandra.auth.CassandraLoginModule
This method is called if the LoginContext's overall authentication succeeded (the relevant REQUIRED, REQUISITE, SUFFICIENT and OPTIONAL LoginModules succeeded).
commit(Throwable) - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
 
commit() - Method in interface org.apache.cassandra.index.transactions.IndexTransaction
 
commit(Throwable) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableZeroCopyWriter
 
commit(Throwable) - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
 
commit(Throwable) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
commit(Throwable) - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
 
commit(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter
 
Commit - Class in org.apache.cassandra.service.paxos
 
Commit(UUID, PartitionUpdate) - Constructor for class org.apache.cassandra.service.paxos.Commit
 
commit(Commit) - Static method in class org.apache.cassandra.service.paxos.PaxosState
 
commit(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
commit any effects of this transaction object graph, then cleanup; delegates first to doCommit, then to doCleanup
commit() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
 
commit(Throwable) - Method in interface org.apache.cassandra.utils.concurrent.Transactional
 
Commit.CommitSerializer - Class in org.apache.cassandra.service.paxos
 
commit_failure_policy - Variable in class org.apache.cassandra.config.Config
 
commitLog - Variable in class org.apache.cassandra.db.commitlog.AbstractCommitLogSegmentManager
 
CommitLog - Class in org.apache.cassandra.db.commitlog
 
CommitLog.Configuration - Class in org.apache.cassandra.db.commitlog
 
commitlog_compression - Variable in class org.apache.cassandra.config.Config
 
commitlog_directory - Variable in class org.apache.cassandra.config.Config
 
commitlog_max_compression_buffers_in_pool - Variable in class org.apache.cassandra.config.Config
 
commitlog_periodic_queue_size - Variable in class org.apache.cassandra.config.Config
Deprecated.
commitlog_segment_size_in_mb - Variable in class org.apache.cassandra.config.Config
 
commitlog_sync - Variable in class org.apache.cassandra.config.Config
 
commitlog_sync_batch_window_in_ms - Variable in class org.apache.cassandra.config.Config
Deprecated.
since 4.0 This value was near useless, and we're not using it anymore
commitlog_sync_group_window_in_ms - Variable in class org.apache.cassandra.config.Config
 
commitlog_sync_period_in_ms - Variable in class org.apache.cassandra.config.Config
 
commitlog_total_space_in_mb - Variable in class org.apache.cassandra.config.Config
 
CommitLogArchiver - Class in org.apache.cassandra.db.commitlog
 
CommitLogArchiver(String, String, String, long, TimeUnit) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
CommitLogDescriptor - Class in org.apache.cassandra.db.commitlog
 
CommitLogDescriptor(int, long, ParameterizedClass, EncryptionContext) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
CommitLogDescriptor(long, ParameterizedClass, EncryptionContext) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
commitLogIntervals - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
commitLogIntervals(IntervalSet<CommitLogPosition>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
commitLogIntervals - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
CommitLogMBean - Interface in org.apache.cassandra.db.commitlog
 
CommitLogMetrics - Class in org.apache.cassandra.metrics
Metrics for commit log
CommitLogMetrics() - Constructor for class org.apache.cassandra.metrics.CommitLogMetrics
 
CommitLogPosition - Class in org.apache.cassandra.db.commitlog
Contains a segment id and a position for CommitLogSegment identification.
CommitLogPosition(long, int) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogPosition
 
CommitLogPosition.CommitLogPositionSerializer - Class in org.apache.cassandra.db.commitlog
 
CommitLogPositionSerializer() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogPosition.CommitLogPositionSerializer
 
commitLogPositionSetSerializer - Static variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
CommitLogReader - Class in org.apache.cassandra.db.commitlog
 
CommitLogReader() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogReader
 
commitLogReader - Variable in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
CommitLogReadHandler - Interface in org.apache.cassandra.db.commitlog
 
CommitLogReadHandler.CommitLogReadErrorReason - Enum in org.apache.cassandra.db.commitlog
 
CommitLogReadHandler.CommitLogReadException - Exception in org.apache.cassandra.db.commitlog
 
CommitLogReplayer - Class in org.apache.cassandra.db.commitlog
 
CommitLogReplayer.CommitLogReplayException - Exception in org.apache.cassandra.db.commitlog
 
CommitLogReplayer.MutationInitiator - Class in org.apache.cassandra.db.commitlog
 
CommitLogReplayException(String, Throwable) - Constructor for exception org.apache.cassandra.db.commitlog.CommitLogReplayer.CommitLogReplayException
 
CommitLogReplayException(String) - Constructor for exception org.apache.cassandra.db.commitlog.CommitLogReplayer.CommitLogReplayException
 
CommitLogSegment - Class in org.apache.cassandra.db.commitlog
 
CommitLogSegment.Allocation - Class in org.apache.cassandra.db.commitlog
A simple class for tracking information about the portion of a segment that has been allocated to a log write.
CommitLogSegment.CDCState - Enum 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
 
CommitLogSegmentManagerCDC - Class in org.apache.cassandra.db.commitlog
 
CommitLogSegmentManagerCDC(CommitLog, String) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerCDC
 
CommitLogSegmentManagerStandard - Class in org.apache.cassandra.db.commitlog
 
CommitLogSegmentManagerStandard(CommitLog, String) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerStandard
 
CommitLogSegmentReader - Class in org.apache.cassandra.db.commitlog
Read each sync section of a commit log, iteratively.
CommitLogSegmentReader(CommitLogReadHandler, CommitLogDescriptor, RandomAccessReader, boolean) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegmentReader
 
CommitLogSegmentReader.SegmentIterator - Class in org.apache.cassandra.db.commitlog
 
CommitLogSegmentReader.SegmentReadException - Exception in org.apache.cassandra.db.commitlog
 
CommitLogSegmentReader.SyncSegment - Class in org.apache.cassandra.db.commitlog
 
CommitSerializer() - Constructor for class org.apache.cassandra.service.paxos.Commit.CommitSerializer
 
commitTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
 
CommitVerbHandler - Class in org.apache.cassandra.service.paxos
 
CommitVerbHandler() - Constructor for class org.apache.cassandra.service.paxos.CommitVerbHandler
 
CommonRange - Class in org.apache.cassandra.repair
Groups ranges with identical endpoints/transient endpoints
CommonRange(Set<InetAddressAndPort>, Set<InetAddressAndPort>, Collection<Range<Token>>) - Constructor for class org.apache.cassandra.repair.CommonRange
 
CommonRange(Set<InetAddressAndPort>, Set<InetAddressAndPort>, Collection<Range<Token>>, boolean) - Constructor for class org.apache.cassandra.repair.CommonRange
 
commonRange - Variable in class org.apache.cassandra.repair.RepairSession
Range to repair
Compact - Class in org.apache.cassandra.tools.nodetool
 
Compact() - Constructor for class org.apache.cassandra.tools.nodetool.Compact
 
compactedPartitionMaximumBytes - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
compactedPartitionMeanBytes - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
compactedPartitionMinimumBytes - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
compactingRepaired() - Method in class org.apache.cassandra.db.AbstractCompactionController
 
compactingRepaired() - Method in class org.apache.cassandra.db.compaction.CompactionController
 
compaction(long, Collection<SSTableReader>, long, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionLogger
 
compaction(CompactionParams) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
compaction(CompactionParams) - Method in class org.apache.cassandra.schema.TableParams.Builder
 
compaction - Variable in class org.apache.cassandra.schema.TableParams
 
COMPACTION_ENABLED - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
COMPACTION_HISTORY - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
COMPACTION_ID - Static variable in class org.apache.cassandra.db.compaction.CompactionInfo
 
compaction_large_partition_warning_threshold_mb - Variable in class org.apache.cassandra.config.Config
 
compaction_throughput_mb_per_sec - Variable in class org.apache.cassandra.config.Config
 
COMPACTION_WINDOW_SIZE_KEY - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
COMPACTION_WINDOW_UNIT_KEY - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
CompactionAwareWriter - Class in org.apache.cassandra.db.compaction.writers
Class that abstracts away the actual writing of files to make it possible to use CompactionTask for more use cases.
CompactionAwareWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, boolean) - Constructor for class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
compactionBytesWritten - Variable in class org.apache.cassandra.metrics.TableMetrics
Total number of bytes written by compaction since server [re]start
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
 
CompactionController(ColumnFamilyStore, Set<SSTableReader>, int, RateLimiter, CompactionParams.TombstoneOption) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
 
compactionDiskSpaceCheck(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
compactionDiskSpaceCheck(boolean) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
CompactionHistory - Class in org.apache.cassandra.tools.nodetool
 
CompactionHistory() - Constructor for class org.apache.cassandra.tools.nodetool.CompactionHistory
 
CompactionHistoryHolder - Class in org.apache.cassandra.tools.nodetool.stats
 
CompactionHistoryHolder(NodeProbe) - Constructor for class org.apache.cassandra.tools.nodetool.stats.CompactionHistoryHolder
 
CompactionHistoryPrinter - Class in org.apache.cassandra.tools.nodetool.stats
 
CompactionHistoryPrinter() - Constructor for class org.apache.cassandra.tools.nodetool.stats.CompactionHistoryPrinter
 
CompactionHistoryPrinter.DefaultPrinter - Class in org.apache.cassandra.tools.nodetool.stats
 
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
 
CompactionInfo(TableMetadata, OperationType, long, long, UUID, Collection<SSTableReader>) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
 
CompactionInfo.Holder - Class in org.apache.cassandra.db.compaction
 
CompactionInfo.Unit - Enum 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
 
CompactionIterator - Class in org.apache.cassandra.db.compaction
Merge multiple iterators over the content of sstable into a "compacted" iterator.
CompactionIterator(OperationType, List<ISSTableScanner>, AbstractCompactionController, int, UUID) - Constructor for class org.apache.cassandra.db.compaction.CompactionIterator
 
CompactionIterator(OperationType, List<ISSTableScanner>, AbstractCompactionController, int, UUID, ActiveCompactionsTracker) - Constructor for class org.apache.cassandra.db.compaction.CompactionIterator
 
CompactionLogger - Class in org.apache.cassandra.db.compaction
 
CompactionLogger(ColumnFamilyStore, CompactionStrategyManager) - Constructor for class org.apache.cassandra.db.compaction.CompactionLogger
 
compactionLogger - Variable in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
CompactionLogger.Strategy - Interface in org.apache.cassandra.db.compaction
 
CompactionLogger.StrategySummary - Interface in org.apache.cassandra.db.compaction
This will produce the compaction strategy's starting information.
CompactionLogger.Writer - Interface in org.apache.cassandra.db.compaction
This is an interface to allow writing to a different interface.
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.CompactionPauser - Interface in org.apache.cassandra.db.compaction
 
CompactionManager.ValidationExecutor - Class 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(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
 
CompactionParams - Class in org.apache.cassandra.schema
 
CompactionParams.Option - Enum in org.apache.cassandra.schema
 
CompactionParams.TombstoneOption - Enum in org.apache.cassandra.schema
 
compactionProxy - Variable in class org.apache.cassandra.tools.NodeProbe
 
compactionsAborted - Variable in class org.apache.cassandra.metrics.CompactionMetrics
Total number of compactions which have outright failed due to lack of disk space
compactionsReduced - Variable in class org.apache.cassandra.metrics.CompactionMetrics
Total number of compactions that have had sstables drop out of them
CompactionStats - Class in org.apache.cassandra.tools.nodetool
 
CompactionStats() - Constructor for class org.apache.cassandra.tools.nodetool.CompactionStats
 
CompactionStrategyHolder - Class in org.apache.cassandra.db.compaction
 
CompactionStrategyHolder(ColumnFamilyStore, AbstractStrategyHolder.DestinationRouter, boolean) - Constructor for class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
CompactionStrategyManager - Class in org.apache.cassandra.db.compaction
Manages the compaction strategies.
CompactionStrategyManager(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
CompactionStrategyManager(ColumnFamilyStore, Supplier<DiskBoundaries>, boolean) - Constructor for class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
CompactionTask - Class in org.apache.cassandra.db.compaction
 
CompactionTask(ColumnFamilyStore, LifecycleTransaction, int) - Constructor for class org.apache.cassandra.db.compaction.CompactionTask
 
CompactionTask(ColumnFamilyStore, LifecycleTransaction, int, boolean) - Constructor for class org.apache.cassandra.db.compaction.CompactionTask
 
CompactionTasks - Class in org.apache.cassandra.db.compaction
 
CompactionTransaction - Interface in org.apache.cassandra.index.transactions
Performs garbage collection of stale index entries during a regular compaction.
compactionType - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
compactionType - Variable in class org.apache.cassandra.notifications.SSTableListChangedNotification
 
CompactTableMetadata(TableMetadata.Builder) - Constructor for class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
 
compactValueColumn - Variable in class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
 
comparator() - Method in class org.apache.cassandra.db.CBuilder
 
comparator - Static variable in class org.apache.cassandra.db.commitlog.CommitLogPosition
 
comparator - Static variable in class org.apache.cassandra.db.DecoratedKey
 
comparator - Variable in class org.apache.cassandra.db.MultiCBuilder
The table comparator.
comparator() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
comparator - Static variable in class org.apache.cassandra.db.rows.Cell
 
comparator - Static variable in class org.apache.cassandra.db.rows.ColumnData
 
comparator - Variable in class org.apache.cassandra.index.sasi.conf.view.RangeTermTree
 
comparator - Variable in class org.apache.cassandra.index.sasi.conf.view.TermTree.Builder
 
comparator - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
comparator - Variable in class org.apache.cassandra.index.sasi.sa.SA
 
comparator() - Method in class org.apache.cassandra.index.sasi.utils.trie.PatriciaTrie
 
comparator - Variable in class org.apache.cassandra.schema.TableMetadata
 
comparator() - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
 
comparator - Variable in class org.apache.cassandra.utils.btree.BTreeSet
 
comparator() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
comparatorSet - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
compare(Function) - Method in interface org.apache.cassandra.cql3.functions.Function
 
compare(Function) - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
compare(Function) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
compare(Clusterable, Clusterable) - Method in class org.apache.cassandra.db.ClusteringComparator
 
compare(ClusteringPrefix<V1>, ClusteringPrefix<V2>) - Method in class org.apache.cassandra.db.ClusteringComparator
 
compare(Clustering<V1>, Clustering<V2>) - Method in class org.apache.cassandra.db.ClusteringComparator
 
compare(Clustering<V1>, Clustering<V2>, int) - Method in class org.apache.cassandra.db.ClusteringComparator
Compares the specified part of the specified clusterings.
compare(ClusteringPrefix.Kind, ClusteringPrefix.Kind) - Static method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
Compares the 2 provided kind.
compare(File, File) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogSegmentFileComparator
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
compare(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
compare(byte[], V2, ValueAccessor<V2>) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
compare(ByteBuffer, V2, ValueAccessor<V2>) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
compare(UserType) - Method in class org.apache.cassandra.db.marshal.UserType
 
compare(V, VR, ValueAccessor<VR>) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
lexicographically compare to
compare(L, ValueAccessor<L>, R, ValueAccessor<R>) - Static method in interface org.apache.cassandra.db.marshal.ValueAccessor
lexicographically compare to
compare(StatsTable, StatsTable) - Method in class org.apache.cassandra.tools.nodetool.stats.StatsTableComparator
Compare StatsTable instances based on this instance's sortKey.
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(ByteBuffer, int, int, byte[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
compare(byte[], ByteBuffer, int, int) - 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, int, int, 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, 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, int, int, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
compare(long, long) - Method in interface org.apache.cassandra.utils.LongTimSort.LongComparator
 
compareAsymmetric(T1, T2) - Method in class org.apache.cassandra.utils.AsymmetricOrdering
 
compareByteArrayTo(byte[], byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
compareByteArrayTo(byte[], ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
compareByteArrayTo(byte[], V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
compare a byte array on the left with a on the right}
compareByteBufferTo(ByteBuffer, byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
compareByteBufferTo(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
compareByteBufferTo(ByteBuffer, V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
compare a byte buffer on the left with a on the right}
compareCollectionMembers(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>, VL) - Method in class org.apache.cassandra.db.marshal.AbstractType
An alternative comparison function used by CollectionsType in conjunction with CompositeType.
compareComponent(int, V1, ValueAccessor<V1>, V2, ValueAccessor<V2>) - Method in class org.apache.cassandra.db.ClusteringComparator
 
compareComponent(int, ClusteringPrefix<V1>, ClusteringPrefix<V2>) - Method in class org.apache.cassandra.db.ClusteringComparator
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.AbstractType
Implement IFF ComparisonType is CUSTOM Compares the byte representation of two instances of this class, for types where this cannot be done by simple in-order comparison of the unsigned bytes Standard Java compare semantics
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.BooleanType
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.ByteType
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.EmptyType
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.FloatType
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.ListType
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.LongType
 
compareCustom(RL, ValueAccessor<RL>, TR, ValueAccessor<TR>) - Method in class org.apache.cassandra.db.marshal.MapType
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.SetType
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.ShortType
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.TimestampType
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.TupleType
 
compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
comparedToClustering - Variable in enum org.apache.cassandra.db.ClusteringPrefix.Kind
Return the comparison of this kind to CLUSTERING.
compareEndpoints(InetAddressAndPort, Replica, Replica) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
 
compareEndpoints(InetAddressAndPort, Replica, Replica) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
 
compareEndpoints(InetAddressAndPort, Replica, Replica) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
compareEndpoints(InetAddressAndPort, Replica, Replica) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
compares two endpoints in relation to the target endpoint, returning as Comparator.compare would
compareEndpoints(InetAddressAndPort, Replica, Replica) - Method in class org.apache.cassandra.locator.SimpleSnitch
 
compareEndpointStartup(InetAddressAndPort, InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
determine which endpoint started up earlier
compareForCQL(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
Same as compare except that this ignore ReversedType.
compareForCQL(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
compareIdTo(CounterContext.ContextState) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
compareInclusionOf(CellPath) - Method in class org.apache.cassandra.db.filter.ColumnSubselection
Given a path, return -1 if the path is before anything selected by this subselection, 0 if it is selected by this subselection and 1 if the path is after anything selected by this subselection.
compareIntegers(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Static method in class org.apache.cassandra.db.marshal.IntegerType
 
compareLongs(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Static method in class org.apache.cassandra.db.marshal.LongType
 
compareMaps(AbstractType<?>, AbstractType<?>, TL, ValueAccessor<TL>, TR, ValueAccessor<TR>) - Static method in class org.apache.cassandra.db.marshal.MapType
 
compareNextTo(ClusteringBoundOrBoundary<T>) - Method in class org.apache.cassandra.db.ClusteringPrefix.Deserializer
 
compareNextTo(ClusteringBound<?>) - Method in class org.apache.cassandra.db.UnfilteredDeserializer
Compare the provided bound to the next atom to read on disk.
comparePageTo(long, int, AbstractType<?>, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
compareSubArrays(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Compare two ByteBuffer at specified offsets for length.
compareTo(FunctionResource) - Method in class org.apache.cassandra.auth.FunctionResource
 
compareTo(PermissionDetails) - Method in class org.apache.cassandra.auth.PermissionDetails
 
compareTo(RoleResource) - Method in class org.apache.cassandra.auth.RoleResource
 
compareTo(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
compareTo(ClusteringComparator, List<ByteBuffer>) - Method in interface org.apache.cassandra.db.ClusteringBound
 
compareTo(CommitLogPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogPosition
 
compareTo(AbstractStrategyHolder.TaskSupplier) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder.TaskSupplier
 
compareTo(PartitionPosition) - Method in class org.apache.cassandra.db.DecoratedKey
 
compareTo(IPartitioner, ByteBuffer, PartitionPosition) - Static method in class org.apache.cassandra.db.DecoratedKey
 
compareTo(DeletionTime) - Method in class org.apache.cassandra.db.DeletionTime
 
compareTo(ColumnSubselection) - Method in class org.apache.cassandra.db.filter.ColumnSubselection
 
compareTo(Memtable) - Method in class org.apache.cassandra.db.Memtable
 
compareTo(Token) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
compareTo(Token) - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
 
compareTo(Token) - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
compareTo(Range<T>) - Method in class org.apache.cassandra.dht.Range
Note: this class has a natural ordering that is inconsistent with equals
compareTo(PartitionPosition) - 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(RangeTermTree.Term) - Method in class org.apache.cassandra.index.sasi.conf.view.RangeTermTree.Term
 
compareTo(OnDiskIndex.DataTerm) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataTerm
 
compareTo(CombinedValue<Long>) - Method in class org.apache.cassandra.index.sasi.disk.Token
 
compareTo(AbstractType<?>, Term) - Method in class org.apache.cassandra.index.sasi.sa.ByteTerm
 
compareTo(AbstractType<?>, Term) - Method in class org.apache.cassandra.index.sasi.sa.CharTerm
 
compareTo(AbstractType<?>, Term) - Method in class org.apache.cassandra.index.sasi.sa.Term
 
compareTo(AbstractType<?>, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.Term
 
compareTo(AbstractType<?>, ByteBuffer, boolean) - Method in class org.apache.cassandra.index.sasi.Term
 
compareTo(CombinedValue<OnDiskIndex.DataTerm>) - Method in class org.apache.cassandra.index.sasi.utils.CombinedTerm
 
compareTo(MetadataComponent) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataComponent
 
compareTo(SSTableIdentityIterator) - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
compareTo(InetAddressAndPort) - Method in class org.apache.cassandra.locator.InetAddressAndPort
 
compareTo(Replica) - Method in class org.apache.cassandra.locator.Replica
 
compareTo(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
 
compareTo(ColumnMetadata) - Method in class org.apache.cassandra.schema.ColumnMetadata
 
compareTo(JMXTool.Attribute) - Method in class org.apache.cassandra.tools.JMXTool.Attribute
 
compareTo(JMXTool.Operation) - Method in class org.apache.cassandra.tools.JMXTool.Operation
 
compareTo(CassandraVersion) - Method in class org.apache.cassandra.utils.CassandraVersion
 
compareTo(OpOrder.Group) - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
 
compareTo(CounterId) - Method in class org.apache.cassandra.utils.CounterId
 
compareTo(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
compareTo(Object, long, int, ByteBuffer) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
compareTo(Object, long, int, Object, long, int) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
Lexicographically compare two arrays.
compareTo(MergeIterator.Candidate<In>) - Method in class org.apache.cassandra.utils.MergeIterator.Candidate
 
compareUnsigned(byte[], byte[]) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
compareUnsigned(byte[], int, byte[], int, int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
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, int, int, byte[], int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
 
compareUnsigned(byte[], int, int, ByteBuffer, int, int) - 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) - Static method in class org.apache.cassandra.cql3.conditions.ColumnCondition.Bound
Returns true if the operator is satisfied (i.e.
comparisonOperator - Variable in class org.apache.cassandra.cql3.conditions.ColumnCondition.Bound
 
comparisonPath() - Method in class org.apache.cassandra.db.filter.ColumnSubselection
 
comparisonType - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
CompletableRemoteSyncTask - Interface in org.apache.cassandra.repair
 
complete() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
 
complete() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
 
complete() - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
 
complete(CountDownLatch) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
 
complete() - Method in class org.apache.cassandra.index.sasi.plan.Operation.Builder
 
complete() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFlushObserver
Called when all data is written to the file and it's ready to be finished up.
complete() - Method in class org.apache.cassandra.io.util.FileHandle.Builder
Complete building FileHandle without overriding file length.
complete(long) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
Complete building FileHandle with the given length, which overrides the file length.
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.OutgoingStreamMessage
 
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 stream at sequenceNumber.
complete() - Method in class org.apache.cassandra.tools.nodetool.formatter.TableBuilder.SharedTable
 
COMPLETED - Static variable in class org.apache.cassandra.db.compaction.CompactionInfo
 
COMPLETED_TASKS - Static variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
 
completedTasks - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
Number of completed tasks
completedTasks - Variable in class org.apache.cassandra.metrics.CompactionMetrics
Number of completed compactions since server [re]start
completedTasks - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
Number of completed tasks.
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
 
complexColumnCount() - Method in class org.apache.cassandra.db.Columns
The number of complex columns (non-frozen collections, udts, ...) in this object.
ComplexColumnData - Class in org.apache.cassandra.db.rows
The data for a complex column, that is it's cells and potential complex deletion time.
ComplexColumnData.Builder - Class in org.apache.cassandra.db.rows
 
complexColumns() - Method in class org.apache.cassandra.db.Columns
Iterator over the complex columns of this object.
complexDeletion() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
The complex deletion time of the complex column.
complexIdx(ColumnMetadata) - Method in class org.apache.cassandra.db.Columns
The index of the provided complex column in this object (if it contains the provided column).
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
WARNING: Be careful while changing the names or string representation of the enum members.
ComponentContext - Class in org.apache.cassandra.db.streaming
Mutable SSTable components and their hardlinks to avoid concurrent sstable component modification during entire-sstable-streaming.
componentManifest - Variable in class org.apache.cassandra.db.streaming.CassandraStreamHeader
 
ComponentManifest - Class in org.apache.cassandra.db.streaming
SSTable components and their sizes to be tranfered via entire-sstable-streaming
ComponentManifest(Map<Component, Long>) - Constructor for class org.apache.cassandra.db.streaming.ComponentManifest
 
components() - Method in class org.apache.cassandra.db.streaming.ComponentManifest
 
components - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
components - Variable in class org.apache.cassandra.io.sstable.SSTable
 
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(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
 
compose(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
Used by UDF implementations (both Java code generated by JavaBasedUDFunction and script executor ScriptBasedUDFunction) to convert the C* serialized representation to the Java object representation.
compose(TypeCodec<Object>[], ProtocolVersion, int, ByteBuffer) - Static method in class org.apache.cassandra.cql3.functions.UDFunction
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
compose(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
compose(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
compose(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
 
compose_boolean(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
 
compose_byte(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
 
compose_double(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
 
compose_float(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
 
compose_int(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
 
compose_long(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
 
compose_short(ProtocolVersion, int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
 
composeValue(Cell<V>, AbstractType<T>) - Static method in class org.apache.cassandra.db.rows.Cells
 
COMPOSITE_TYPE - Static variable in class org.apache.cassandra.fql.FullQueryLoggerOptionsCompositeData
 
COMPOSITE_TYPE - Static variable in class org.apache.cassandra.repair.consistent.admin.PendingStat
 
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
 
CompositesSearcher - Class in org.apache.cassandra.index.internal.composites
 
CompositesSearcher(ReadCommand, RowFilter.Expression, CassandraIndex) - Constructor for class org.apache.cassandra.index.internal.composites.CompositesSearcher
 
CompositeType - Class in org.apache.cassandra.db.marshal
 
CompositeType(List<AbstractType<?>>) - Constructor for class org.apache.cassandra.db.marshal.CompositeType
 
compress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
compress(ByteBuffer, ByteBuffer) - Method in interface org.apache.cassandra.io.compress.ICompressor
Compression for ByteBuffers.
compress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
 
compress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.NoopCompressor
 
compress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
 
compress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.ZstdCompressor
Compress using ByteBuffers
compress(ByteBuffer, ByteBuffer, boolean, ICompressor) - Static method in class org.apache.cassandra.security.EncryptionUtils
Compress the raw data, as well as manage sizing of the outputBuffer; if the buffer is not big enough, deallocate current, and allocate a large enough buffer.
compress(Envelope) - Method in interface org.apache.cassandra.transport.Compressor
 
compress(Envelope) - Method in class org.apache.cassandra.transport.Compressor.LZ4Compressor
 
compress(Envelope) - Method in class org.apache.cassandra.transport.Compressor.SnappyCompressor
 
compressArray(byte[], int, int, byte[], int, int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
compressBuffer(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
compressed(boolean) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
 
COMPRESSED_BLOCK_HEADER_SIZE - Static variable in class org.apache.cassandra.security.EncryptionUtils
 
CompressedChecksummedDataInput - Class in org.apache.cassandra.hints
 
CompressedChecksummedDataInput(ChannelProxy, ICompressor, long) - Constructor for class org.apache.cassandra.hints.CompressedChecksummedDataInput
 
CompressedChunkReader - Class in org.apache.cassandra.io.util
 
CompressedChunkReader(ChannelProxy, CompressionMetadata) - Constructor for class org.apache.cassandra.io.util.CompressedChunkReader
 
CompressedChunkReader.Mmap - Class in org.apache.cassandra.io.util
 
CompressedChunkReader.Standard - Class in org.apache.cassandra.io.util
 
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
 
CompressedHintsWriter - Class in org.apache.cassandra.hints
 
CompressedHintsWriter(File, HintsDescriptor, File, FileChannel, int, CRC32) - Constructor for class org.apache.cassandra.hints.CompressedHintsWriter
 
CompressedInputStream - Class in org.apache.cassandra.db.streaming
InputStream which reads compressed chunks from the underlying input stream and deals with decompression and position tracking.
CompressedInputStream(DataInputPlus, CompressionInfo, ChecksumType, DoubleSupplier) - Constructor for class org.apache.cassandra.db.streaming.CompressedInputStream
 
CompressedSegment - Class in org.apache.cassandra.db.commitlog
Compressed commit log segment.
CompressedSequentialWriter - Class in org.apache.cassandra.io.compress
 
CompressedSequentialWriter(File, String, File, SequentialWriterOption, CompressionParams, MetadataCollector) - Constructor for class org.apache.cassandra.io.compress.CompressedSequentialWriter
Create CompressedSequentialWriter without digest file.
CompressedSequentialWriter.CompressedFileWriterMark - Class in org.apache.cassandra.io.compress
Class to hold a mark to the position of the file
CompressedSequentialWriter.TransactionalProxy - Class in org.apache.cassandra.io.compress
 
compression - Variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
compression - Variable in class org.apache.cassandra.io.sstable.SSTable
 
compression(CompressionParams) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
compression(CompressionParams) - Method in class org.apache.cassandra.schema.TableParams.Builder
 
compression - Variable in class org.apache.cassandra.schema.TableParams
 
COMPRESSION - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
 
compression - Variable in class org.apache.cassandra.transport.SimpleClient
 
COMPRESSION_INFO - Static variable in class org.apache.cassandra.io.sstable.Component
 
COMPRESSION_LEVEL_OPTION_NAME - Static variable in class org.apache.cassandra.io.compress.ZstdCompressor
 
compressionInfo - Variable in class org.apache.cassandra.db.streaming.CassandraCompressedStreamReader
 
compressionInfo - Variable in class org.apache.cassandra.db.streaming.CassandraStreamHeader
 
CompressionInfo - Class in org.apache.cassandra.db.streaming
Container that carries compression parameters and chunks to decompress data from stream.
CompressionInfo() - Constructor for class org.apache.cassandra.db.streaming.CompressionInfo
 
CompressionMetadata - Class in org.apache.cassandra.io.compress
Holds metadata about compressed file
CompressionMetadata(Descriptor, long) - Constructor for class org.apache.cassandra.io.compress.CompressionMetadata
 
CompressionMetadata(String, long, boolean) - Constructor for class org.apache.cassandra.io.compress.CompressionMetadata
 
CompressionMetadata(String, CompressionParams, Memory, long, long, long) - Constructor for class org.apache.cassandra.io.compress.CompressionMetadata
 
compressionMetadata() - Method in class org.apache.cassandra.io.util.FileHandle
 
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.KeyspaceMetrics
Off heap memory used by compression meta data
compressionMetadataOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.TableMetrics
Off heap memory used by compression meta data
compressionMetadataOffHeapMemoryUsed - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
compressionMetadataOffHeapUsed - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
CompressionParams - Class in org.apache.cassandra.schema
 
CompressionParams(String, Map<String, String>, int, double) - Constructor for class org.apache.cassandra.schema.CompressionParams
 
CompressionParams(String, int, int, Map<String, String>) - Constructor for class org.apache.cassandra.schema.CompressionParams
 
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.TableMetrics
Current compression ratio for all SSTables
compressor() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
 
Compressor - Interface in org.apache.cassandra.transport
 
Compressor.LZ4Compressor - Class in org.apache.cassandra.transport
 
Compressor.SnappyCompressor - Class in org.apache.cassandra.transport
 
compute(ProtocolVersion) - Method in interface org.apache.cassandra.cql3.functions.AggregateFunction.Aggregate
Computes and returns the aggregate current value.
compute(byte[]) - Static method in class org.apache.cassandra.utils.MD5Digest
 
compute(String) - Static method in class org.apache.cassandra.utils.MD5Digest
 
computeBloomSpec(int) - Static method in class org.apache.cassandra.utils.BloomCalculations
Given the number of buckets that can be used per element, return a specification that minimizes the false positive rate.
computeBloomSpec(int, double) - Static method in class org.apache.cassandra.utils.BloomCalculations
Given a maximum tolerable false positive probability, compute a Bloom specification which will give less than the specified false positive rate, but minimize the number of buckets per element and the number of hash functions used.
computedCRC - Variable in class org.apache.cassandra.net.FrameDecoder.CorruptFrame
 
computeExpireTime() - Static method in class org.apache.cassandra.gms.Gossiper
 
computeLocalExpirationTime(int, int) - Static method in class org.apache.cassandra.db.ExpirationDateOverflowHandling
This method computes the Cell.localDeletionTime(), maybe capping to the maximum representable value which is Cell.MAX_DELETION_TIME.
computeNext() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SegmentIterator
 
computeNext() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
 
computeNext() - Method in class org.apache.cassandra.db.rows.RowAndDeletionMergeIterator
 
computeNext() - Method in class org.apache.cassandra.db.rows.ThrottledUnfilteredIterator
 
computeNext() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
 
computeNext() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.LevelIterator
 
computeNext() - Method in class org.apache.cassandra.index.sasi.disk.TokenTree.TokenTreeIterator
 
computeNext() - Method in class org.apache.cassandra.index.sasi.memory.KeyRangeIterator
 
computeNext() - Method in class org.apache.cassandra.index.sasi.plan.Operation
 
computeNext() - Method in class org.apache.cassandra.index.sasi.TermIterator
 
computeNext() - Method in class org.apache.cassandra.index.sasi.utils.AbstractIterator
Returns the next element.
computeNext() - Method in class org.apache.cassandra.index.sasi.utils.CombinedTermIterator
 
computeNext() - Method in class org.apache.cassandra.index.sasi.utils.OnDiskIndexIterator
 
computeNext() - Method in class org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator.BounceIntersectionIterator
 
computeNext() - Method in class org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator.LookupIntersectionIterator
 
computeNext() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.EmptyRangeIterator
 
computeNext() - Method in class org.apache.cassandra.index.sasi.utils.RangeUnionIterator
 
computeNext() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.KeyScanningIterator
 
computeNext() - Method in class org.apache.cassandra.io.sstable.KeyIterator
 
computeNext() - Method in class org.apache.cassandra.utils.AbstractIterator
 
computeNext() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRangeIterator
Find the next TreeRange.
computeNext() - Method in class org.apache.cassandra.utils.MerkleTrees.TreeRangeIterator
 
computeShouldStreamEntireSSTables() - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
 
computeSubPageSize(int, int) - Method in class org.apache.cassandra.service.pager.AggregationQueryPager.AggregationPartitionIterator
 
computeSubPageSize(int, int) - Method in class org.apache.cassandra.service.pager.AggregationQueryPager.GroupByPartitionIterator
Computes the size of the next sub-page to retrieve.
computeUnsignedVIntSize(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
Computes size of an unsigned vint that starts at readerIndex of the provided ByteBuf.
computeUnsignedVIntSize(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
 
computeUnsignedVIntSize(long) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
Compute the number of bytes that would be needed to encode an unsigned varint.
computeVIntSize(long) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
Compute the number of bytes that would be needed to encode a varint.
concat(List<PartitionIterator>) - Static method in class org.apache.cassandra.db.partitions.PartitionIterators
 
concat(List<UnfilteredPartitionIterator>) - Static method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators
 
concat(UnfilteredRowIterator, UnfilteredRowIterator) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
Returns an iterator that concatenate two atom iterators.
concat(Unfiltered, UnfilteredRowIterator) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
Returns an iterator that concatenate the specified atom with the iterator.
concat(E, E) - Static method in class org.apache.cassandra.locator.Endpoints
Care must be taken to ensure no conflicting ranges occur in pending and natural.
concat(RangesAtEndpoint, RangesAtEndpoint) - Static method in class org.apache.cassandra.locator.RangesAtEndpoint
 
concatAndBlockOnRepair(List<PartitionIterator>, List<ReadRepair<?, ?>>) - Static method in class org.apache.cassandra.service.StorageProxy
 
concatWithIndexes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
Concurrent(long) - Constructor for class org.apache.cassandra.net.ResourceLimits.Concurrent
 
concurrent_compactors - Variable in class org.apache.cassandra.config.Config
 
concurrent_counter_writes - Variable in class org.apache.cassandra.config.Config
 
concurrent_materialized_view_builders - Variable in class org.apache.cassandra.config.Config
 
concurrent_materialized_view_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_validations - Variable in class org.apache.cassandra.config.Config
 
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
 
condition(ColumnMetadata, Operator, Terms) - Static method in class org.apache.cassandra.cql3.conditions.ColumnCondition
A regular column, simple condition.
condition(ColumnMetadata, Term, Operator, Terms) - Static method in class org.apache.cassandra.cql3.conditions.ColumnCondition
A collection column, simple condition.
condition(ColumnMetadata, FieldIdentifier, Operator, Terms) - Static method in class org.apache.cassandra.cql3.conditions.ColumnCondition
A UDT column, simple condition.
condition - Variable in class org.apache.cassandra.service.TruncateResponseHandler
 
conditionColumns() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
conditionNotMet - Variable in class org.apache.cassandra.metrics.CASClientWriteRequestMetrics
 
Conditions - Interface in org.apache.cassandra.cql3.conditions
Conditions that can be applied to a mutation statement.
conf - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
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.CorruptedTombstoneStrategy - Enum in org.apache.cassandra.config
 
Config.DiskAccessMode - Enum in org.apache.cassandra.config
 
Config.DiskFailurePolicy - Enum in org.apache.cassandra.config
 
Config.DiskOptimizationStrategy - Enum in org.apache.cassandra.config
 
Config.FlushCompression - Enum in org.apache.cassandra.config
 
Config.InternodeCompression - Enum in org.apache.cassandra.config
 
Config.MemtableAllocationType - Enum in org.apache.cassandra.config
 
Config.RepairCommandPoolFullStrategy - Enum in org.apache.cassandra.config
 
Config.UserFunctionTimeoutPolicy - Enum in org.apache.cassandra.config
 
CONFIG_PATH - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
ConfigHelper - Class in org.apache.cassandra.hadoop
 
ConfigHelper() - Constructor for class org.apache.cassandra.hadoop.ConfigHelper
 
configOptions - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
Configuration(ParameterizedClass, EncryptionContext) - Constructor for class org.apache.cassandra.db.commitlog.CommitLog.Configuration
 
ConfigurationException - Exception in org.apache.cassandra.exceptions
 
ConfigurationException(String) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
 
ConfigurationException(String, boolean) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
 
ConfigurationException(String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
 
ConfigurationException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.ConfigurationException
 
ConfigurationLoader - Interface in org.apache.cassandra.config
 
configureInitialPipeline(Channel, Connection.Factory) - Method in class org.apache.cassandra.transport.PipelineConfigurator
 
configureLegacyPipeline(ChannelHandlerContext, ClientResourceLimits.Allocator) - Method in class org.apache.cassandra.transport.PipelineConfigurator
 
configureModernPipeline(ChannelHandlerContext, ClientResourceLimits.Allocator, ProtocolVersion, Map<String, String>) - Method in class org.apache.cassandra.transport.PipelineConfigurator
 
confirmedRepairedInconsistencies - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Incremented where an inconsistency is detected and there are no pending repair sessions affecting the data being read, indicating a genuine mismatch between replicas' repaired data sets.
confirmedRepairedInconsistencies - Variable in class org.apache.cassandra.metrics.TableMetrics
Metrics for inconsistencies detected between repaired data sets across replicas.
confirmReplication(InetAddressAndPort) - Method in class org.apache.cassandra.service.StorageService
 
connect(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
connect() - Method in class org.apache.cassandra.tools.NodeProbe
Create a connection to the JMX agent and setup the M[X]Bean proxies.
connect(boolean) - Method in class org.apache.cassandra.transport.SimpleClient
 
connect(boolean, boolean) - Method in class org.apache.cassandra.transport.SimpleClient
 
connected() - Method in class org.apache.cassandra.streaming.async.NettyStreamingMessageSender
 
connected() - Method in interface org.apache.cassandra.streaming.StreamingMessageSender
 
ConnectedClient - Class in org.apache.cassandra.transport
 
connecting - Variable in class org.apache.cassandra.streaming.SessionInfo
 
Connection - Class in org.apache.cassandra.transport
 
Connection(Channel, ProtocolVersion, 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
 
connectionAttempts() - Method in class org.apache.cassandra.net.OutboundConnection
 
ConnectionCategory - Enum in org.apache.cassandra.net
 
connectionFactory(StreamConnectionFactory) - Method in class org.apache.cassandra.streaming.StreamPlan
Set custom StreamConnectionFactory to be used for establishing connection
CONNECTIONS_PER_HOST - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
connectionsPerHost - Variable in class org.apache.cassandra.tools.LoaderOptions
 
ConnectionStage - Enum in org.apache.cassandra.transport
 
ConnectionTracker() - Constructor for class org.apache.cassandra.transport.Server.ConnectionTracker
 
ConnectionType - Enum in org.apache.cassandra.net
 
connectTo - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
connectTo() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
connectToId() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
consecutive_message_errors_threshold - Variable in class org.apache.cassandra.config.Config
 
consistency() - Method in class org.apache.cassandra.db.CounterMutation
 
consistency - Variable in exception org.apache.cassandra.exceptions.CasWriteUnknownResultException
 
consistency - Variable in exception org.apache.cassandra.exceptions.RequestFailureException
 
consistency - Variable in exception org.apache.cassandra.exceptions.RequestTimeoutException
 
consistency - Variable in exception org.apache.cassandra.exceptions.UnavailableException
 
consistencyForRole(String) - Static method in class org.apache.cassandra.auth.CassandraRoleManager
 
ConsistencyLevel - Enum in org.apache.cassandra.db
 
consistencyLevel - Variable in class org.apache.cassandra.locator.ReplicaPlan
 
consistencyLevel() - Method in class org.apache.cassandra.locator.ReplicaPlan
 
consistencyLevel() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
consistent - Variable in class org.apache.cassandra.service.ActiveRepairService
 
ConsistentSession - Class in org.apache.cassandra.repair.consistent
Base class for consistent Local and Coordinator sessions

There are 4 stages to a consistent incremental repair.

ConsistentSession.State - Enum in org.apache.cassandra.repair.consistent
The possible states of a ConsistentSession.
ConsistentSessions() - Constructor for class org.apache.cassandra.service.ActiveRepairService.ConsistentSessions
 
CONSOLE - Static variable in class org.apache.cassandra.tools.Output
 
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() - Static method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
construct(CommitLog, UUID) - Static method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
construct(ColumnFamilyStore, ILifecycleTransaction, boolean, long) - Static method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
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.
constructKeepingOriginals(ILifecycleTransaction, boolean, long) - Static method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
constructTree() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
 
constructTree() - Method in class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
 
constructTree() - Method in class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
 
constructWithoutEarlyOpening(ILifecycleTransaction, boolean, long) - Static method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
consume(PartitionIterator) - Static method in class org.apache.cassandra.db.partitions.PartitionIterators
 
consume(AsyncStreamingInputPlus.Consumer, long) - Method in class org.apache.cassandra.net.AsyncStreamingInputPlus
Consumes bytes in the stream until the given length
consume() - Method in class org.apache.cassandra.net.FrameDecoder.IntactFrame
 
consume(MergeIterator.Reducer) - Method in class org.apache.cassandra.utils.MergeIterator.Candidate
 
consume(int, int) - Method in interface org.apache.cassandra.utils.streamhist.HistogramDataConsumer
 
consumeNext(PartitionIterator) - Static method in class org.apache.cassandra.db.partitions.PartitionIterators
Consumes all rows in the next partition of the provided partition iterator.
consumeRepairResult(RepairResult) - Method in class org.apache.cassandra.repair.consistent.SyncStatSummary
 
consumeSessionResults(List<RepairSessionResult>) - Method in class org.apache.cassandra.repair.consistent.SyncStatSummary
 
contacts() - Method in class org.apache.cassandra.locator.ReplicaPlan
 
contacts(Replica) - Method in class org.apache.cassandra.locator.ReplicaPlan
 
contained(List<SSTableReader.PartitionPositionBounds>, SSTableReader) - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
 
contains(TupleType) - Method in class org.apache.cassandra.cql3.functions.types.TupleType
Return true if this tuple type contains the given tuple type, and false otherwise.
contains(String) - Method in class org.apache.cassandra.cql3.functions.types.UserType
Returns whether this UDT contains a given field.
contains(ColumnMetadata) - Method in class org.apache.cassandra.db.Columns
Whether the provided column is contained by this object.
contains(CommitLogPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
Check to see if a certain CommitLogPosition is contained by this segment file.
contains(T) - Method in class org.apache.cassandra.db.commitlog.IntervalSet
 
contains(PartitionPosition) - Method in class org.apache.cassandra.db.DataRange
Whether the provided ring position is covered by this DataRange.
contains(ColumnMetadata) - Method in class org.apache.cassandra.db.RegularAndStaticColumns
 
contains(String) - Method in class org.apache.cassandra.db.view.TableViews
 
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(Replica) - Method in class org.apache.cassandra.locator.Endpoints
 
contains(Replica) - Method in class org.apache.cassandra.locator.RangesAtEndpoint
 
contains(Range<Token>, boolean) - Method in class org.apache.cassandra.locator.RangesAtEndpoint
 
contains(Range<Token>) - Method in class org.apache.cassandra.locator.Replica
 
contains(Replica) - Method in interface org.apache.cassandra.locator.ReplicaCollection
 
contains(String) - Method in class org.apache.cassandra.locator.SnitchProperties
 
contains(Object) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
contains(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Check is the given buffer contains a given sub-buffer.
contains(Object) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
containsAll(Collection<?>) - Method in class org.apache.cassandra.db.Columns
Whether this object is a superset of the provided other Columns object.
containsAll(Collection<?>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
containsAll(Collection<?>) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
containsApplicationState(ApplicationState) - Method in class org.apache.cassandra.gms.EndpointState
 
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
 
containsCachedParition(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
containsCustomExpressions() - Method in class org.apache.cassandra.cql3.WhereClause
 
containsKey(K) - Method in class org.apache.cassandra.cache.CaffeineCache
 
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.locator.AbstractReplicaCollection.ReplicaMap
 
containsKey(Object) - Method in class org.apache.cassandra.locator.ReplicaMultimap
 
containsKey(Object) - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
 
containsKey(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
 
containsKey(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
containsKeyspace(String) - Method in class org.apache.cassandra.schema.Keyspaces
 
containsNull - Variable in class org.apache.cassandra.db.MultiCBuilder
true if the clusterings contains some null elements.
containsNull() - Method in class org.apache.cassandra.db.MultiCBuilder
Checks if the clusterings contains null elements.
ContainsRestriction(ColumnMetadata, Term, boolean) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
 
ContainsRestriction(ColumnMetadata, Term, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
 
containsSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
 
containsSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
containsSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
containsSstableCompressionClass(Map<String, String>) - Static method in class org.apache.cassandra.schema.CompressionParams
Returns true if the specified options contains the name of the compression class to be used, false otherwise.
containsStaticColumns() - Method in class org.apache.cassandra.cql3.selection.Selection
Checks if this selection contains static columns.
containsTokenRelations() - Method in class org.apache.cassandra.cql3.WhereClause
Checks if the where clause contains some token relations.
containsUnset - Variable in class org.apache.cassandra.db.MultiCBuilder
true if the composites contains some unset elements.
containsUnset() - Method in class org.apache.cassandra.db.MultiCBuilder
Checks if the clusterings contains unset elements.
containsValue(Object) - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
 
containsValue(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
 
containsValue(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
content - Variable in class org.apache.cassandra.index.sasi.Term
 
contention - Variable in class org.apache.cassandra.metrics.CASClientRequestMetrics
 
contentions - Variable in exception org.apache.cassandra.exceptions.CasWriteTimeoutException
 
contents - Variable in class org.apache.cassandra.net.FrameDecoder.IntactFrame
 
contentSize() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
context - Variable in class org.apache.cassandra.db.context.CounterContext.ContextState
 
context - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
ContextAllocator - Class in org.apache.cassandra.utils.memory
Wraps calls to a PoolAllocator with the provided writeOp.
ContextAllocator(OpOrder.Group, MemtableBufferAllocator) - Constructor for class org.apache.cassandra.utils.memory.ContextAllocator
 
convert(V2, ValueAccessor<V2>) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
convert(V2, ValueAccessor<V2>) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
convert(V2, ValueAccessor<V2>) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
Convert the data in to and the returned value may share a common byte array instance, so caller should assume that modifying the returned value will also modify the contents of
convert2Map() - Method in class org.apache.cassandra.tools.nodetool.stats.CompactionHistoryHolder
 
convert2Map() - Method in interface org.apache.cassandra.tools.nodetool.stats.StatsHolder
 
convert2Map() - Method in class org.apache.cassandra.tools.nodetool.stats.TableStatsHolder
 
convert2Map() - Method in class org.apache.cassandra.tools.nodetool.stats.TpStatsHolder
 
convertPreferredEndpointsToWorkMap(EndpointsByReplica) - Static method in class org.apache.cassandra.dht.RangeStreamer
The preferred endpoint list is the wrong format because it is keyed by Replica (this node) rather than the source endpoint we will fetch from which streaming wants.
convertSections(List<RepairedState.Section>) - Static method in class org.apache.cassandra.repair.consistent.admin.RepairStats
 
convict(InetAddressAndPort, double) - Method in class org.apache.cassandra.gms.Gossiper
This method is part of IFailureDetectionEventListener interface.
convict(InetAddressAndPort, double) - Method in interface org.apache.cassandra.gms.IFailureDetectionEventListener
Convict the specified endpoint.
convict(InetAddressAndPort, double) - Method in class org.apache.cassandra.repair.RepairSession
 
convict(InetAddressAndPort, 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.
coordinated - Variable in class org.apache.cassandra.service.ActiveRepairService.ConsistentSessions
 
coordinator - Variable in class org.apache.cassandra.repair.consistent.ConsistentSession
 
COORDINATOR - Static variable in class org.apache.cassandra.repair.consistent.LocalSessionInfo
 
coordinator - Variable in class org.apache.cassandra.repair.messages.PrepareConsistentRequest
 
coordinator - Variable in class org.apache.cassandra.repair.SyncNodePair
 
coordinator - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
coordinator - Variable in class org.apache.cassandra.streaming.SessionSummary
 
coordinator - Variable in class org.apache.cassandra.tracing.TraceState
 
coordinatorReadLatency - Variable in class org.apache.cassandra.metrics.TableMetrics
 
coordinatorScanLatency - Variable in class org.apache.cassandra.metrics.TableMetrics
 
CoordinatorSession - Class in org.apache.cassandra.repair.consistent
Coordinator side logic and state of a consistent repair session.
CoordinatorSession(CoordinatorSession.Builder) - Constructor for class org.apache.cassandra.repair.consistent.CoordinatorSession
 
CoordinatorSession.Builder - Class in org.apache.cassandra.repair.consistent
 
CoordinatorSessions - Class in org.apache.cassandra.repair.consistent
Container for all consistent repair sessions a node is coordinating
CoordinatorSessions() - Constructor for class org.apache.cassandra.repair.consistent.CoordinatorSessions
 
coordinatorWriteLatency - Variable in class org.apache.cassandra.metrics.TableMetrics
 
copy(long) - Method in class org.apache.cassandra.cache.RefCountedMemory
 
copy(boolean) - Method in class org.apache.cassandra.cql3.functions.types.UserType
 
copy() - Method in class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
 
copy() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
copy(AbstractAllocator) - Method in class org.apache.cassandra.db.ArrayClusteringBound
 
copy(AbstractAllocator) - Method in class org.apache.cassandra.db.BufferClusteringBound
 
copy(AbstractAllocator) - Method in class org.apache.cassandra.db.BufferClusteringBoundary
 
copy(AbstractAllocator) - Method in interface org.apache.cassandra.db.Clustering
 
copy(AbstractAllocator) - Method in interface org.apache.cassandra.db.ClusteringBound
 
copy(AbstractAllocator) - Method in interface org.apache.cassandra.db.ClusteringBoundOrBoundary
 
copy(AbstractAllocator) - Method in interface org.apache.cassandra.db.DeletionInfo
 
copy(AbstractAllocator) - Method in class org.apache.cassandra.db.MutableDeletionInfo
 
copy() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
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
Returns a copy of this command.
copy(AbstractAllocator) - Method in class org.apache.cassandra.db.rows.AbstractCell
 
copy(AbstractAllocator) - Method in class org.apache.cassandra.db.rows.ArrayCell
 
copy() - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
 
copy(AbstractAllocator) - Method in class org.apache.cassandra.db.rows.BufferCell
 
copy(AbstractAllocator) - Method in class org.apache.cassandra.db.rows.Cell
 
copy(AbstractAllocator) - Method in class org.apache.cassandra.db.rows.CellPath
 
copy(AbstractAllocator) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
copy(AbstractAllocator) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
copy(AbstractAllocator) - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
 
copy() - Method in interface org.apache.cassandra.db.rows.Row.Builder
Creates a copy of this Builder.
copy(Row, Row.Builder) - Static method in class org.apache.cassandra.db.rows.Rows
 
copy() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
copy(Descriptor, Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
copy(long) - Method in class org.apache.cassandra.io.util.Memory
 
copy(long) - Method in class org.apache.cassandra.io.util.SafeMemory
 
copy(Range<Token>) - Method in class org.apache.cassandra.repair.asymmetric.StreamFromOptions
 
copy() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
copy() - Method in class org.apache.cassandra.schema.CompressionParams
 
copy(TableMetadata) - Method in class org.apache.cassandra.schema.ViewMetadata
 
copy() - Method in class org.apache.cassandra.utils.btree.BTree.Builder
Creates a copy of this Builder.
copy(byte[], int, byte[], int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
 
copy(ByteBuffer, int, byte[], int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
 
copy(byte[], int, ByteBuffer, 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(byte[], int, byte[], int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
 
copy(ByteBuffer, int, byte[], int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
 
copy(byte[], int, ByteBuffer, 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(byte[], int, byte[], 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.PureJavaOperations
 
copy(byte[], int, ByteBuffer, 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(byte[], int, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
copy(ByteBuffer, int, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
copy(byte[], int, ByteBuffer, 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
 
copyAsDigestQuery() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
copyAsDigestQuery(Replica) - Method in class org.apache.cassandra.db.ReadCommand
Returns a copy of this command with isDigestQuery set to true.
copyAsDigestQuery(Iterable<Replica>) - Method in class org.apache.cassandra.db.ReadCommand
Returns a copy of this command with isDigestQuery set to true.
copyAsDigestQuery() - Method in class org.apache.cassandra.db.ReadCommand
 
copyAsDigestQuery() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
copyAsNewCollection(ByteBuffer, int, int, int, ProtocolVersion) - Method in class org.apache.cassandra.serializers.CollectionSerializer
Creates a new serialized map composed from the data from input between startPos (inclusive) and endPos (exclusive), assuming that data holds count elements.
copyAsTransientQuery() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
copyAsTransientQuery(Replica) - Method in class org.apache.cassandra.db.ReadCommand
Returns a copy of this command with acceptsTransient set to true.
copyAsTransientQuery(Iterable<Replica>) - Method in class org.apache.cassandra.db.ReadCommand
Returns a copy of this command with acceptsTransient set to true.
copyAsTransientQuery() - Method in class org.apache.cassandra.db.ReadCommand
 
copyAsTransientQuery() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
copyByteArrayTo(byte[], int, byte[], int, int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
copyByteArrayTo(byte[], int, ByteBuffer, int, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
copyByteArrayTo(byte[], int, V, int, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
copies a byte array into this accessors value.
copyByteBufferTo(ByteBuffer, int, byte[], int, int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
copyByteBufferTo(ByteBuffer, int, ByteBuffer, int, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
copyByteBufferTo(ByteBuffer, int, V, int, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
copies a byte buffer into this accessors value.
copyBytes(byte[], int, byte[], int, int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
copyBytes(byte[], int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
copyBytes(ByteBuffer, int, byte[], int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
copyBytes(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Transfer bytes from one ByteBuffer to another.
copyOf(Collection<Replica>) - Static method in class org.apache.cassandra.locator.EndpointsForRange
 
copyOf(Token, Collection<Replica>) - Static method in class org.apache.cassandra.locator.EndpointsForToken
 
copyOf(List<Replica>) - Static method in class org.apache.cassandra.locator.RangesAtEndpoint
 
copyTo(CounterContext.ContextState) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
copyTo(byte[], int, V2, ValueAccessor<V2>, int, int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
copyTo(ByteBuffer, int, V2, ValueAccessor<V2>, int, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
copyTo(V, int, V2, ValueAccessor<V2>, int, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
copy the bytes from the value, starting at the offset into the value, starting at the offset , using the accessor
copyTo(DataInput, OutputStream, int) - Static method in class org.apache.cassandra.io.util.FileUtils
 
copyWithConfirm(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
copyWithConfirm(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
copyWithOutConfirm(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
corePoolSize - Variable in class org.apache.cassandra.service.StorageServiceMBean.StageConcurrency
 
correspondingMessagingVersion() - Method in class org.apache.cassandra.io.sstable.format.Version
 
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
 
corrupted_tombstone_strategy - Variable in class org.apache.cassandra.config.Config
 
CorruptFileException - Exception in org.apache.cassandra.io.util
 
CorruptFileException(Exception, String) - Constructor for exception org.apache.cassandra.io.util.CorruptFileException
 
corruptFramesRecovered - Variable in class org.apache.cassandra.net.AbstractMessageHandler
 
corruptFramesRecovered() - Method in class org.apache.cassandra.net.InboundMessageHandlers
 
corruptFramesUnrecovered - Variable in class org.apache.cassandra.net.AbstractMessageHandler
 
corruptFramesUnrecovered() - Method in class org.apache.cassandra.net.InboundMessageHandlers
 
CorruptSSTableException - Exception in org.apache.cassandra.io.sstable
 
CorruptSSTableException(Throwable, File) - Constructor for exception org.apache.cassandra.io.sstable.CorruptSSTableException
 
CorruptSSTableException(Throwable, String) - Constructor for exception org.apache.cassandra.io.sstable.CorruptSSTableException
 
count() - Method in class org.apache.cassandra.db.CBuilder
 
count - Variable in class org.apache.cassandra.db.ClockAndCount
 
count() - Method in class org.apache.cassandra.db.filter.DataLimits
The max number of results this limits enforces.
count(Predicate<Replica>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
count(Predicate<Replica>) - Method in interface org.apache.cassandra.locator.ReplicaCollection
 
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 - Variable in class org.apache.cassandra.metrics.Sampler.Sample
 
count() - Method in class org.apache.cassandra.net.InboundMessageHandlers
 
count() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
countAllBatches() - Method in class org.apache.cassandra.batchlog.BatchlogManager
 
countAllBatches() - Method in interface org.apache.cassandra.batchlog.BatchlogManagerMBean
Counts all batches currently in the batchlog.
countANSI(String) - Static method in class org.apache.cassandra.tools.Util
 
countConnectedClients() - Method in class org.apache.cassandra.transport.Server
 
countConnectedClientsByUser() - Method in class org.apache.cassandra.transport.Server
 
counted() - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
The number of results counted.
countedInCurrentPartition() - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
 
counter() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the COUNTER type.
counter() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type counter.
Counter(int, boolean, boolean) - Constructor for class org.apache.cassandra.db.filter.DataLimits.Counter
 
counter(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
counter(CassandraMetricsRegistry.MetricName, CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
counter_cache_keys_to_save - Variable in class org.apache.cassandra.config.Config
 
counter_cache_save_period - Variable in class org.apache.cassandra.config.Config
 
counter_cache_size_in_mb - Variable in class org.apache.cassandra.config.Config
 
counter_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
 
CounterCells - Class in org.apache.cassandra.db.rows
 
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 - 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
 
countFull(ReplicaCollection<?>) - Static method in class org.apache.cassandra.locator.Replicas
 
countInOurDc(ReplicaCollection<?>) - Static method in class org.apache.cassandra.locator.Replicas
 
countPerDc(Collection<String>, Iterable<Replica>) - Static method in class org.apache.cassandra.locator.Replicas
count the number of full and transient replicas, separately, for each DC
countRowsFunction - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The function used to count the number of rows of a result set.
coverInMap(ConcurrentMap<K, IntegerInterval>, K, int) - Static method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
covers(IntegerInterval) - Method in class org.apache.cassandra.utils.IntegerInterval.Set
Returns true if the set completely covers the given interval.
covers(int, int) - Method in class org.apache.cassandra.utils.IntegerInterval.Set
Returns true if the set completely covers the given interval.
CQL3CasRequest - Class in org.apache.cassandra.cql3.statements
Processed CAS conditions and update on potentially multiple rows of the same partition.
CQL3CasRequest(TableMetadata, DecoratedKey, RegularAndStaticColumns, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CQL3CasRequest
 
CQL3Type - Interface in org.apache.cassandra.cql3
 
CQL3Type.Collection - Class in org.apache.cassandra.cql3
 
CQL3Type.Custom - Class in org.apache.cassandra.cql3
 
CQL3Type.Native - Enum in org.apache.cassandra.cql3
 
CQL3Type.Raw - Class in org.apache.cassandra.cql3
 
CQL3Type.Tuple - Class in org.apache.cassandra.cql3
 
CQL3Type.UserDefined - Class in org.apache.cassandra.cql3
 
CQL_VERSION - Static variable in class org.apache.cassandra.cql3.QueryProcessor
 
CQL_VERSION - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
 
CqlBuilder - Class in org.apache.cassandra.cql3
Utility class to facilitate the creation of the CQL representation of SchemaElements.
CqlBuilder() - Constructor for class org.apache.cassandra.cql3.CqlBuilder
 
CqlBuilder(int) - Constructor for class org.apache.cassandra.cql3.CqlBuilder
 
CqlBuilder.Appender<T> - Interface in org.apache.cassandra.cql3
 
CqlBulkOutputFormat - Class in org.apache.cassandra.hadoop.cql3
The CqlBulkOutputFormat acts as a Hadoop-specific OutputFormat that allows reduce tasks to store keys (and corresponding bound variable values) as CQL rows (and respective columns) in a given table.
CqlBulkOutputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
CqlBulkOutputFormat.NullOutputCommitter - Class in org.apache.cassandra.hadoop.cql3
 
CqlBulkRecordWriter - Class in org.apache.cassandra.hadoop.cql3
The CqlBulkRecordWriter maps the output <key, value> pairs to a Cassandra column family.
CqlBulkRecordWriter.ExternalClient - Class in org.apache.cassandra.hadoop.cql3
 
CqlBulkRecordWriter.NullOutputHandler - Class in org.apache.cassandra.hadoop.cql3
 
CqlClientHelper - Class in org.apache.cassandra.hadoop.cql3
 
CqlConfigHelper - Class in org.apache.cassandra.hadoop.cql3
 
CqlConfigHelper() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
CQLFragmentParser - Class in org.apache.cassandra.cql3
Helper class to encapsulate common code that calls one of the generated methods in CqlParser.
CQLFragmentParser() - Constructor for class org.apache.cassandra.cql3.CQLFragmentParser
 
CQLFragmentParser.CQLParserFunction<R> - Interface in org.apache.cassandra.cql3
 
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
 
cqlLimits(int) - Static method in class org.apache.cassandra.db.filter.DataLimits
 
cqlLimits(int, int) - Static method in class org.apache.cassandra.db.filter.DataLimits
 
CQLMessageHandler<M extends Message> - Class in org.apache.cassandra.transport
Implementation of AbstractMessageHandler for processing CQL messages which comprise a Message wrapped in an Envelope.
CQLMetrics - Class in org.apache.cassandra.metrics
 
CQLMetrics() - Constructor for class org.apache.cassandra.metrics.CQLMetrics
 
CqlOutputFormat - Class in org.apache.cassandra.hadoop.cql3
The CqlOutputFormat acts as a Hadoop-specific OutputFormat that allows reduce tasks to store keys (and corresponding bound variable values) as CQL rows (and respective columns) in a given table.
CqlOutputFormat() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
 
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 - Interface in org.apache.cassandra.cql3
 
CQLStatement.Raw - Class in org.apache.cassandra.cql3
 
CQLTypeParser - Class in org.apache.cassandra.schema
 
CQLTypeParser() - Constructor for class org.apache.cassandra.schema.CQLTypeParser
 
CRC - Static variable in class org.apache.cassandra.io.sstable.Component
 
Crc - Class in org.apache.cassandra.net
 
Crc() - Constructor for class org.apache.cassandra.net.Crc
 
Crc.InvalidCrc - Exception in org.apache.cassandra.net
 
CRC_CHECK_CHANCE - Static variable in class org.apache.cassandra.schema.CompressionParams
Deprecated.
crcCheckChance(double) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
crcCheckChance(double) - Method in class org.apache.cassandra.schema.TableParams.Builder
 
crcCheckChance - Variable in class org.apache.cassandra.schema.TableParams
 
create(AuditLogOptions) - Static method in class org.apache.cassandra.audit.AuditLogFilter
(Re-)Loads filters from config.
create() - Method in interface org.apache.cassandra.cache.CacheProvider
 
create(long, Weigher<K, V>) - Static method in class org.apache.cassandra.cache.CaffeineCache
Initialize a cache with initial capacity with weightedCapacity
create(long) - Static method in class org.apache.cassandra.cache.CaffeineCache
 
create(TableMetadata, ByteBuffer, Clustering<?>, ColumnMetadata, CellPath) - Static method in class org.apache.cassandra.cache.CounterCacheKey
 
create() - Method in class org.apache.cassandra.cache.NopCacheProvider
 
create() - Method in class org.apache.cassandra.cache.OHCProvider
 
create(long, Weigher<K, RefCountedMemory>, ISerializer<V>) - Static method in class org.apache.cassandra.cache.SerializingCache
 
create(long, ISerializer<V>) - Static method in class org.apache.cassandra.cache.SerializingCache
 
create() - Method in class org.apache.cassandra.cache.SerializingCacheProvider
 
create() - Static method in class org.apache.cassandra.concurrent.ExecutorLocals
This creates a new ExecutorLocals object based on what is already set.
create(TraceState) - Static method in class org.apache.cassandra.concurrent.ExecutorLocals
 
create(TupleType) - Static method in class org.apache.cassandra.cql3.CQL3Type.Tuple
 
create(UserType) - Static method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
 
create(Collection<UDFunction>, FunctionName, List<AbstractType<?>>, AbstractType<?>, FunctionName, FunctionName, AbstractType<?>, ByteBuffer) - Static method in class org.apache.cassandra.cql3.functions.UDAggregate
 
create(FunctionName, List<ColumnIdentifier>, List<AbstractType<?>>, AbstractType<?>, boolean, String, String) - Static method in class org.apache.cassandra.cql3.functions.UDFunction
 
create(ConsistencyLevel, List<ByteBuffer>, boolean, int, PagingState, ConsistencyLevel, ProtocolVersion, String) - Static method in class org.apache.cassandra.cql3.QueryOptions
 
create(ConsistencyLevel, List<ByteBuffer>, boolean, int, PagingState, ConsistencyLevel, ProtocolVersion, String, long, int) - 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(SelectStatement, ConsistencyLevel, ClientState, QueryPager, int) - Static method in class org.apache.cassandra.cql3.UntypedResultSet
This method is intended for testing purposes, since it executes query on cluster and not on the local node only.
create(ClusteringPrefix.Kind, byte[][]) - Static method in class org.apache.cassandra.db.ArrayClusteringBound
 
create(ClusteringPrefix.Kind, byte[][]) - Static method in class org.apache.cassandra.db.ArrayClusteringBoundary
 
create(ClusteringPrefix.Kind, byte[][]) - Static method in class org.apache.cassandra.db.ArrayClusteringBoundOrBoundary
 
create(ClusteringPrefix.Kind, ByteBuffer[]) - Static method in class org.apache.cassandra.db.BufferClusteringBound
 
create(ClusteringPrefix.Kind, ByteBuffer[]) - Static method in class org.apache.cassandra.db.BufferClusteringBoundary
 
create(ClusteringComparator) - Static method in class org.apache.cassandra.db.CBuilder
 
create(long, long) - Static method in class org.apache.cassandra.db.ClockAndCount
 
create(ClusteringPrefix.Kind, ClusteringPrefix<V>) - Static method in interface org.apache.cassandra.db.ClusteringBound
 
create(ClusteringComparator, boolean, boolean, Object...) - Static method in interface org.apache.cassandra.db.ClusteringBound
 
create(ClusteringPrefix.Kind, ClusteringPrefix<V>) - Static method in interface org.apache.cassandra.db.ClusteringBoundary
 
create(Collection<AbstractCompactionTask>) - Static method in class org.apache.cassandra.db.compaction.CompactionTasks
 
create(ColumnFamilyStore, int, int, List<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
 
create(ColumnFamilyStore, int, int, Iterable<SSTableReader>, SizeTieredCompactionStrategyOptions) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
 
create() - Static method in class org.apache.cassandra.db.filter.RowFilter
 
create(int) - Static method in class org.apache.cassandra.db.filter.RowFilter
 
create(long, int) - Static method in class org.apache.cassandra.db.LivenessInfo
 
create(long, int, int) - Static method in class org.apache.cassandra.db.LivenessInfo
 
create(ClusteringComparator, boolean) - Static method in class org.apache.cassandra.db.MultiCBuilder
Creates a new empty MultiCBuilder.
create(TableMetadata, int, ColumnFilter, RowFilter, DataLimits, DataRange) - Static method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
create(TableMetadata, int, ColumnFilter, RowFilter, DataLimits, DataRange) - Static method in interface org.apache.cassandra.db.PartitionRangeReadQuery
 
create(UnfilteredRowIterator, int) - Static method in class org.apache.cassandra.db.partitions.CachedBTreePartition
Creates an ArrayBackedCachedPartition holding all the data of the provided iterator.
create(UnfilteredRowIterator, int, int) - Static method in class org.apache.cassandra.db.partitions.CachedBTreePartition
Creates an ArrayBackedCachedPartition holding all the data of the provided iterator.
create(RowIterator) - Static method in class org.apache.cassandra.db.partitions.FilteredPartition
Create a FilteredPartition holding all the rows of the provided iterator.
create(UnfilteredRowIterator) - Static method in class org.apache.cassandra.db.partitions.ImmutableBTreePartition
Creates an ImmutableBTreePartition holding all the data of the provided iterator.
create(UnfilteredRowIterator, boolean) - Static method in class org.apache.cassandra.db.partitions.ImmutableBTreePartition
Creates an ImmutableBTreePartition holding all the data of the provided iterator.
create(UnfilteredRowIterator, int) - Static method in class org.apache.cassandra.db.partitions.ImmutableBTreePartition
Creates an ImmutableBTreePartition holding all the data of the provided iterator.
create(UnfilteredRowIterator, int, boolean) - Static method in class org.apache.cassandra.db.partitions.ImmutableBTreePartition
Creates an ImmutableBTreePartition holding all the data of the provided iterator.
create(long, long, DeletionTime, long, int, int, List<IndexInfo>, int[], ISerializer<IndexInfo>) - Static method in class org.apache.cassandra.db.RowIndexEntry
 
create(Clustering<?>, LivenessInfo, Row.Deletion, Object[]) - Static method in class org.apache.cassandra.db.rows.BTreeRow
 
create(Clustering<?>, LivenessInfo, Row.Deletion, Object[], int) - Static method in class org.apache.cassandra.db.rows.BTreeRow
 
create(ColumnMetadata, long, int, int, V, CellPath) - Method in interface org.apache.cassandra.db.rows.Cell.Factory
 
create(ByteBuffer) - Static method in class org.apache.cassandra.db.rows.CellPath
 
create(TableMetadata, int, ColumnFilter, RowFilter, DataLimits, DecoratedKey, ClusteringIndexFilter, IndexMetadata) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
Creates a new read command on a single partition.
create(TableMetadata, int, ColumnFilter, RowFilter, DataLimits, DecoratedKey, ClusteringIndexFilter) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
Creates a new read command on a single partition.
create(TableMetadata, int, DecoratedKey, ColumnFilter, ClusteringIndexFilter) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
Creates a new read command on a single partition.
create(TableMetadata, int, DecoratedKey, Slice) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
Creates a new single partition slice command for the provided single slice.
create(TableMetadata, int, DecoratedKey, Slices) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
Creates a new single partition slice command for the provided slices.
create(TableMetadata, int, ByteBuffer, Slices) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
Creates a new single partition slice command for the provided slices.
create(TableMetadata, int, DecoratedKey, NavigableSet<Clustering<?>>) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
Creates a new single partition name command for the provided rows.
create(TableMetadata, int, DecoratedKey, Clustering<?>) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
Creates a new single partition name command for the provided row.
create(TableMetadata, int, ColumnFilter, RowFilter, DataLimits, List<DecoratedKey>, ClusteringIndexFilter) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand.Group
 
create(TableMetadata, int, DecoratedKey, ColumnFilter, ClusteringIndexFilter) - Static method in interface org.apache.cassandra.db.SinglePartitionReadQuery
Creates a new read query on a single partition.
create(TableMetadata, int, ColumnFilter, RowFilter, DataLimits, DecoratedKey, ClusteringIndexFilter) - Static method in interface org.apache.cassandra.db.SinglePartitionReadQuery
Creates a new read query on a single partition.
create(Descriptor) - Static method in class org.apache.cassandra.db.streaming.ComponentContext
 
create(Descriptor) - Static method in class org.apache.cassandra.db.streaming.ComponentManifest
 
create(TableMetadata, DataInputPlus, SerializationHeader, DeserializationHelper) - Static method in class org.apache.cassandra.db.UnfilteredDeserializer
 
create(TableMetadata, int, ColumnFilter, RowFilter, DataLimits, DataRange) - Static method in class org.apache.cassandra.db.VirtualTablePartitionRangeReadQuery
 
create(TableMetadata, int, ColumnFilter, RowFilter, DataLimits, DecoratedKey, ClusteringIndexFilter) - Static method in class org.apache.cassandra.db.VirtualTableSinglePartitionReadQuery
 
create(TableMetadata, int, ColumnFilter, RowFilter, DataLimits, List<DecoratedKey>, ClusteringIndexFilter) - Static method in class org.apache.cassandra.db.VirtualTableSinglePartitionReadQuery.Group
 
create(Function, Throwable) - Static method in exception org.apache.cassandra.exceptions.FunctionExecutionException
 
create(char, List<AbstractType<?>>, Exception) - Static method in exception org.apache.cassandra.exceptions.OperationExecutionException
Creates a new OperationExecutionException for the specified operation.
create(ConsistencyLevel, int, int) - Static method in exception org.apache.cassandra.exceptions.UnavailableException
 
create(ConsistencyLevel, int, int, int, int) - Static method in exception org.apache.cassandra.exceptions.UnavailableException
 
create(ConsistencyLevel, String, int, int, int, int) - Static method in exception org.apache.cassandra.exceptions.UnavailableException
 
create(Mutation, long) - Static method in class org.apache.cassandra.hints.Hint
 
create(Mutation, long, int) - Static method in class org.apache.cassandra.hints.Hint
 
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<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.NoopCompressor
 
create(Map<String, String>) - Static method in class org.apache.cassandra.io.compress.SnappyCompressor
 
create(Map<String, String>) - Static method in class org.apache.cassandra.io.compress.ZstdCompressor
Create a Zstd compressor with the given options
create(Descriptor, Long, Long, UUID, boolean, TableMetadataRef, MetadataCollector, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
create(Descriptor, long, long, UUID, boolean, int, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
create(TableMetadataRef, Descriptor, long, long, UUID, boolean, int, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
create(Descriptor, long, long, UUID, boolean, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
create(Descriptor, long, long, UUID, boolean, TableMetadataRef, MetadataCollector, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Static method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
 
create(SSTableReader, RandomAccessReader, DecoratedKey) - Static method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
create(SSTableReader, FileDataInput, RowIndexEntry<?>, DecoratedKey, boolean) - Static method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
create(TableMetadata, DataInputPlus, SerializationHeader, DeserializationHelper, DeletionTime) - Static method in class org.apache.cassandra.io.sstable.SSTableSimpleIterator
 
create(ColumnFamilyStore, Descriptor, long, long, UUID, boolean, int, SerializationHeader) - Static method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
 
create(TableMetadataRef, Descriptor, long, long, UUID, boolean, int, SerializationHeader, Collection<Index>) - Static method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
 
create(ColumnFamilyStore, Descriptor, long, long, UUID, boolean, SerializationHeader) - Static method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
 
create() - Static method in class org.apache.cassandra.locator.EndpointSnitchInfo
 
create(BufferPoolAllocator) - Static method in class org.apache.cassandra.net.FrameDecoderCrc
 
create(long, boolean) - Static method in class org.apache.cassandra.net.StartupClusterConnectivityChecker
 
create(Class<? extends AbstractCompactionStrategy>, Map<String, String>) - Static method in class org.apache.cassandra.schema.CompactionParams
 
create(String, KeyspaceParams) - Static method in class org.apache.cassandra.schema.KeyspaceMetadata
 
create(String, KeyspaceParams, Tables) - Static method in class org.apache.cassandra.schema.KeyspaceMetadata
 
create(String, KeyspaceParams, Tables, Views, Types, Functions) - Static method in class org.apache.cassandra.schema.KeyspaceMetadata
 
create(boolean, Map<String, String>) - Static method in class org.apache.cassandra.schema.KeyspaceParams
 
create(String, String) - Static method in class org.apache.cassandra.schema.TriggerMetadata
 
create(TableMetadata, Row, ProtocolVersion) - Static method in class org.apache.cassandra.service.pager.PagingState.RowMark
 
create(ReadCommand, ReplicaPlan.Shared<E, P>, long) - Static method in interface org.apache.cassandra.service.reads.repair.ReadRepair
 
create(ReadCommand, ReplicaPlan.Shared<E, P>, long) - Method in interface org.apache.cassandra.service.reads.repair.ReadRepair.Factory
 
create(Token.TokenFactory, Range<Token>, List<InetAddressAndPort>, boolean) - Static method in class org.apache.cassandra.service.TokenRange
 
create(String, int) - Method in interface org.apache.cassandra.tools.INodeProbeFactory
 
create(String, int, String, String) - Method in interface org.apache.cassandra.tools.INodeProbeFactory
 
create(Message.Type, int, ProtocolVersion, EnumSet<Envelope.Header.Flag>, ByteBuf) - Static method in class org.apache.cassandra.transport.Envelope
 
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() - Static method in interface org.apache.cassandra.utils.MBeanWrapper
 
create(String, MBeanWrapper.OnException) - Static method in interface org.apache.cassandra.utils.MBeanWrapper
 
create() - Method in class org.apache.cassandra.utils.memory.BufferPool
 
create(X, Y) - Static method in class org.apache.cassandra.utils.Pair
 
create() - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
 
create(BiMultiValMap<K, V>) - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
 
create(V) - Static method in class org.apache.cassandra.utils.Wrapped
 
CreateAggregateStatement - Class in org.apache.cassandra.cql3.statements.schema
 
CreateAggregateStatement(String, String, List<CQL3Type.Raw>, CQL3Type.Raw, FunctionName, FunctionName, Term.Raw, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateAggregateStatement
 
CreateAggregateStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
createAllDirectories() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
Creates all storage-related directories.
createArray(int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
createArray(int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
createArray(int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
allocate an instance of the accessors backing type
createBrokenFunction(FunctionName, List<ColumnIdentifier>, List<AbstractType<?>>, AbstractType<?>, boolean, String, String, InvalidRequestException) - Static method in class org.apache.cassandra.cql3.functions.UDFunction
It can happen that a function has been declared (is listed in the scheam) but cannot be loaded (maybe only on some nodes).
createBuffer() - Method in class org.apache.cassandra.io.util.SimpleCachedBufferPool
 
createCachedThreadpoolWithMaxSize(String) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
Creates a thread pool that creates new threads as needed, but will reuse previously constructed threads when they are available.
createClustering(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
createColumnFamilyStore(Keyspace, TableMetadataRef, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
createColumnFamilyStore(Keyspace, String, TableMetadataRef, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
createColumnFamilyStore(Keyspace, String, TableMetadataRef, Directories, boolean, boolean, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
This is only directly used by offline tools
createCompactionStrategyInstance(CompactionParams) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
createCompressor(ParameterizedClass) - Static method in class org.apache.cassandra.schema.CompressionParams
 
createConnection(OutboundConnectionSettings, int) - Method in class org.apache.cassandra.streaming.DefaultConnectionFactory
 
createConnection(OutboundConnectionSettings, int) - Method in interface org.apache.cassandra.streaming.StreamConnectionFactory
 
createConnection(OutboundConnectionSettings, int) - Method in class org.apache.cassandra.tools.BulkLoadConnectionFactory
 
createContextForIndexing() - Method in class org.apache.cassandra.db.CassandraKeyspaceWriteHandler
 
createContextForIndexing() - Method in interface org.apache.cassandra.db.KeyspaceWriteHandler
 
createContextForRead() - Method in class org.apache.cassandra.db.CassandraKeyspaceWriteHandler
 
createContextForRead() - Method in interface org.apache.cassandra.db.KeyspaceWriteHandler
 
createCorrespondingCloseMarker(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
createCorrespondingOpenMarker(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
created - Variable in class org.apache.cassandra.schema.Diff
 
created - Variable in class org.apache.cassandra.schema.Keyspaces.KeyspacesDiff
 
createDataResponse(UnfilteredPartitionIterator, ReadCommand, RepairedDataInfo) - Static method in class org.apache.cassandra.db.ReadResponse
 
createdAtNanos() - Method in class org.apache.cassandra.net.Message
Creation time of the message.
createdAtNanos - Variable in class org.apache.cassandra.net.Message.Header
 
createDefault() - Static method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram
 
createDefaultMBeanName(String, String, String) - Static method in class org.apache.cassandra.metrics.DefaultNameFactory
 
createDeletableTempFile(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createDigestResponse(UnfilteredPartitionIterator, ReadCommand) - Static method in class org.apache.cassandra.db.ReadResponse
 
createDirectory(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createDirectory(File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createEndpointSnitch(boolean, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
createEntry(long, LongSet) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf
 
createExecutor() - Method in class org.apache.cassandra.repair.RepairSession
 
createFollower(int, UUID, StreamOperation, InetAddressAndPort, Channel, UUID, PreviewKind) - Static method in class org.apache.cassandra.streaming.StreamResultFuture
 
createFromMap(Map<?, ?>, EncryptionContext) - Static method in class org.apache.cassandra.security.EncryptionContext
If encryption headers are found in the parameters, those headers are merged with the application-wide encryptionContext.
CreateFunctionStatement - Class in org.apache.cassandra.cql3.statements.schema
 
CreateFunctionStatement(String, String, List<ColumnIdentifier>, List<CQL3Type.Raw>, CQL3Type.Raw, boolean, String, String, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateFunctionStatement
 
CreateFunctionStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
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).
createGroup(TableMetadata, int, ColumnFilter, RowFilter, DataLimits, List<DecoratedKey>, ClusteringIndexFilter) - Static method in interface org.apache.cassandra.db.SinglePartitionReadQuery
 
createGroupedSSTableContainer() - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
 
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
 
createHardLinkWithConfirm(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createHardLinkWithConfirm(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createHardLinkWithoutConfirm(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createHook() - Static method in interface org.apache.cassandra.db.StorageHook
 
createHook() - Static method in interface org.apache.cassandra.streaming.StreamHook
 
CreateIndexStatement - Class in org.apache.cassandra.cql3.statements.schema
 
CreateIndexStatement(String, String, String, List<IndexTarget.Raw>, IndexAttributes, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
 
CreateIndexStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
createInitiator(UUID, StreamOperation, Collection<StreamEventHandler>, StreamCoordinator) - Static method in class org.apache.cassandra.streaming.StreamResultFuture
 
createInRelation(List<ColumnIdentifier>, 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, List<Term.Raw>) - Static method in class org.apache.cassandra.cql3.SingleColumnRelation
 
createJMXServer(int, String, boolean) - Static method in class org.apache.cassandra.utils.JMXServerUtils
Creates a server programmatically.
createJMXServer(int, boolean) - Static method in class org.apache.cassandra.utils.JMXServerUtils
 
createKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
createKeyspaceCounter(String) - Method in class org.apache.cassandra.metrics.KeyspaceMetrics
 
createKeyspaceHistogram(String, boolean) - Method in class org.apache.cassandra.metrics.KeyspaceMetrics
 
createKeyspaceMeter(String) - Method in class org.apache.cassandra.metrics.KeyspaceMetrics
 
CreateKeyspaceStatement - Class in org.apache.cassandra.cql3.statements.schema
 
CreateKeyspaceStatement(String, KeyspaceAttributes, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateKeyspaceStatement
 
CreateKeyspaceStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
createKeyspaceTimer(String) - Method in class org.apache.cassandra.metrics.KeyspaceMetrics
 
createLifecycleNewTracker() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReceiver
 
createLinks(String) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
createLinks(Descriptor, Set<Component>, String) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
createLocal(UUID, long, Collection<Mutation>) - Static method in class org.apache.cassandra.batchlog.Batch
Creates a 'local' batch - with all enclosed mutations in decoded form (as Mutation instances)
createLocal(long) - Method in class org.apache.cassandra.db.context.CounterContext
Creates a counter context with a single local shard.
createMessage(boolean) - Method in class org.apache.cassandra.db.ReadCommand
Creates a message for this command.
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>, Operator, Term.MultiColumnRaw) - Static method in class org.apache.cassandra.cql3.MultiColumnRelation
Creates a multi-column EQ, LT, LTE, GT, or GTE relation.
createNotification(String) - Static method in class org.apache.cassandra.utils.progress.ProgressEvent
 
createOutgoingStreams(StreamSession, RangesAtEndpoint, UUID, PreviewKind) - Method in class org.apache.cassandra.db.streaming.CassandraStreamManager
 
createOutgoingStreams(StreamSession, RangesAtEndpoint, UUID, PreviewKind) - Method in interface org.apache.cassandra.streaming.TableStreamManager
Returns a collection of OutgoingStreams that contains the data selected by the given replicas, pendingRepair, and preview.
createRangeAware(TableMetadataRef, long, long, UUID, boolean, SSTableFormat.Type, int, SerializationHeader) - Static method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
 
createReader() - Method in class org.apache.cassandra.io.util.FileHandle
Create RandomAccessReader with configured method of reading content of the file.
createReader(RateLimiter) - Method in class org.apache.cassandra.io.util.FileHandle
Create RandomAccessReader with configured method of reading content of the file.
createReader(long) - Method in class org.apache.cassandra.io.util.FileHandle
 
createReaderInternal(RowIndexEntry, FileDataInput, boolean) - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
createReaderInternal(RowIndexEntry, FileDataInput, boolean) - Method in class org.apache.cassandra.db.columniterator.SSTableIterator
 
createReaderInternal(RowIndexEntry, FileDataInput, boolean) - Method in class org.apache.cassandra.db.columniterator.SSTableReversedIterator
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlInputFormat
 
createRemote(UUID, long, Collection<ByteBuffer>) - Static method in class org.apache.cassandra.batchlog.Batch
Creates a 'remote' batch - with all enclosed mutations in encoded form (as ByteBuffer instances) The mutations will always be encoded using the current messaging version.
createRemote(CounterId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext
Creates a counter context with a single remote shard.
createRemoteDataResponse(UnfilteredPartitionIterator, ByteBuffer, boolean, ReadCommand, int) - Static method in class org.apache.cassandra.db.ReadResponse
 
createRepairMutation(PartitionUpdate, ConsistencyLevel, InetAddressAndPort, boolean) - Static method in class org.apache.cassandra.service.reads.repair.BlockingReadRepairs
Create a read repair mutation from the given update, if the mutation is not larger than the maximum mutation size, otherwise return null.
createReplicationStrategy(String, Class<? extends AbstractReplicationStrategy>, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
createReplicationStrategy() - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
createResponse(UnfilteredPartitionIterator, RepairedDataInfo) - Method in class org.apache.cassandra.db.ReadCommand
 
createRole(AuthenticatedUser, RoleResource, RoleOptions) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
createRole(AuthenticatedUser, RoleResource, RoleOptions) - Method in interface org.apache.cassandra.auth.IRoleManager
Called during execution of a CREATE ROLE statement.
CreateRoleStatement - Class in org.apache.cassandra.cql3.statements
 
CreateRoleStatement(RoleName, RoleOptions, DCPermissions, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateRoleStatement
 
createSegment() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerCDC
On segment creation, flag whether the segment should accept CDC mutations or not based on the total currently allocated unflushed CDC segments and the contents of cdc_raw
createSegment() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerStandard
 
createServerSocket(int) - Method in class org.apache.cassandra.utils.RMIServerSocketFactoryImpl
 
createSingleMarkerInRelation(List<ColumnIdentifier>, 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
Create a JSSE SSLContext.
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
Deprecated.
 
createSSTableMultiWriter(Descriptor, long, long, UUID, boolean, int, SerializationHeader, LifecycleNewTracker) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
createSSTableMultiWriter(Descriptor, long, long, UUID, boolean, MetadataCollector, SerializationHeader, LifecycleNewTracker) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
createSSTableMultiWriter(Descriptor, long, long, UUID, boolean, MetadataCollector, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
createSSTableMultiWriter(Descriptor, long, long, UUID, boolean, MetadataCollector, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
 
createSSTableMultiWriter(Descriptor, long, long, UUID, boolean, MetadataCollector, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
createSSTableMultiWriter(Descriptor, long, long, UUID, boolean, MetadataCollector, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
createSSTableMultiWriter(Descriptor, long, long, UUID, boolean, MetadataCollector, SerializationHeader, Collection<Index>, LifecycleNewTracker) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
createStatementClusteringColumns() - Method in class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
 
createStreamReceiver(StreamSession, int) - Method in class org.apache.cassandra.db.streaming.CassandraStreamManager
 
createStreamReceiver(StreamSession, int) - Method in interface org.apache.cassandra.streaming.TableStreamManager
Creates a StreamReceiver for the given session, expecting the given number of streams
createSummaries() - Method in class org.apache.cassandra.streaming.StreamState
 
createSummary() - Method in class org.apache.cassandra.streaming.SessionInfo
 
createTableCounter(String) - Method in class org.apache.cassandra.metrics.TableMetrics
Creates a counter that will also have a global counter thats the sum of all counters across different column families
createTableCounter(String, String) - Method in class org.apache.cassandra.metrics.TableMetrics
 
createTableGauge(String, Gauge<T>) - Method in class org.apache.cassandra.metrics.TableMetrics
Create a gauge that will be part of a merged version of all column families.
createTableGauge(String, Gauge<T>, Gauge<G>) - Method in class org.apache.cassandra.metrics.TableMetrics
Create a gauge that will be part of a merged version of all column families.
createTableGauge(String, String, Gauge<T>, Gauge<G>) - Method in class org.apache.cassandra.metrics.TableMetrics
 
createTableGaugeWithDeprecation(String, String, Gauge<T>, Gauge<G>) - Method in class org.apache.cassandra.metrics.TableMetrics
Same as TableMetrics.createTableGauge(String, Gauge, Gauge) but accepts a deprecated name for a table Gauge.
createTableHistogram(String, Histogram, boolean) - Method in class org.apache.cassandra.metrics.TableMetrics
Create a histogram-like interface that will register both a CF, keyspace and global level histogram and forward any updates to both
createTableHistogram(String, String, Histogram, boolean) - Method in class org.apache.cassandra.metrics.TableMetrics
 
createTableHistogram(String, boolean) - Method in class org.apache.cassandra.metrics.TableMetrics
 
createTableHistogram(String, String, boolean) - Method in class org.apache.cassandra.metrics.TableMetrics
 
createTableMeter(String, Meter) - Method in class org.apache.cassandra.metrics.TableMetrics
 
createTableMeter(String, String, Meter) - Method in class org.apache.cassandra.metrics.TableMetrics
 
CreateTableStatement - Class in org.apache.cassandra.cql3.statements.schema
 
CreateTableStatement(String, String, Map<ColumnIdentifier, CQL3Type.Raw>, Set<ColumnIdentifier>, List<ColumnIdentifier>, List<ColumnIdentifier>, LinkedHashMap<ColumnIdentifier, Boolean>, TableAttributes, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateTableStatement
 
CreateTableStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
createTableTimer(String, Timer) - Method in class org.apache.cassandra.metrics.TableMetrics
 
createTableTimer(String) - Method in class org.apache.cassandra.metrics.TableMetrics
 
createTempFile(String, String, File) - Static method in class org.apache.cassandra.io.util.FileUtils
Pretty much like File.createTempFile(String, String, File), but with the guarantee that the "random" part of the generated file name between prefix and suffix is a positive, increasing long value.
createTempFile(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createThread(Runnable) - Static method in class org.apache.cassandra.concurrent.NamedThreadFactory
 
createThread(Runnable, String) - Static method in class org.apache.cassandra.concurrent.NamedThreadFactory
 
createThread(Runnable, String, boolean) - Static method in class org.apache.cassandra.concurrent.NamedThreadFactory
 
createThread(ThreadGroup, Runnable, String) - Static method in class org.apache.cassandra.concurrent.NamedThreadFactory
 
createThread(ThreadGroup, Runnable, String, boolean) - Static method in class org.apache.cassandra.concurrent.NamedThreadFactory
 
createTokenAllocator(NavigableMap<Token, InetAddressAndPort>, ReplicationStrategy<InetAddressAndPort>, IPartitioner) - Static method in class org.apache.cassandra.dht.tokenallocator.TokenAllocatorFactory
 
createTokenInfos() - Method in class org.apache.cassandra.dht.tokenallocator.NoReplicationTokenAllocator
Used in tests.
createTombstoneOnly(TableMetadata, DataInputPlus, SerializationHeader, DeserializationHelper, DeletionTime) - Static method in class org.apache.cassandra.io.sstable.SSTableSimpleIterator
 
CreateTriggerStatement - Class in org.apache.cassandra.cql3.statements.schema
 
CreateTriggerStatement(String, String, String, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateTriggerStatement
 
CreateTriggerStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
CreateTypeStatement - Class in org.apache.cassandra.cql3.statements.schema
 
CreateTypeStatement(String, String, List<FieldIdentifier>, List<CQL3Type.Raw>, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateTypeStatement
 
CreateTypeStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
createUnitInfos(Map<Object, TokenAllocatorBase.GroupInfo>) - Method in class org.apache.cassandra.dht.tokenallocator.TokenAllocatorBase
 
createUpdate(long) - Method in class org.apache.cassandra.db.context.CounterContext
Creates a counter context with a single local shard with clock id of UPDATE_CLOCK_ID.
createValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
CreateViewStatement - Class in org.apache.cassandra.cql3.statements.schema
 
CreateViewStatement(String, String, String, List<RawSelector>, List<ColumnIdentifier>, List<ColumnIdentifier>, WhereClause, LinkedHashMap<ColumnIdentifier, Boolean>, TableAttributes, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateViewStatement
 
CreateViewStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
createWithFixedPoolSize(String, int) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
Returns a ThreadPoolExecutor with a fixed number of threads.
createWithLength(String, long) - Static method in class org.apache.cassandra.io.compress.CompressionMetadata
 
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, UUID, boolean, SSTableReader, LifecycleTransaction) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
 
createWriter(ColumnFamilyStore, long, Collection<Component>) - Method in class org.apache.cassandra.db.streaming.CassandraEntireSSTableStreamReader
 
createWriter(ColumnFamilyStore, long, long, UUID, SSTableFormat.Type) - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader
 
createWriterForAntiCompaction(ColumnFamilyStore, File, int, long, UUID, boolean, Collection<SSTableReader>, ILifecycleTransaction) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
 
creationTime - Variable in class org.apache.cassandra.batchlog.Batch
 
creationTimeMillis() - Method in class org.apache.cassandra.net.Message
 
creationTimeNanos() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
 
creationTimeNanos() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
 
credentials_cache_max_entries - Variable in class org.apache.cassandra.config.Config
 
credentials_update_interval_in_ms - Variable in class org.apache.cassandra.config.Config
 
credentials_validity_in_ms - Variable in class org.apache.cassandra.config.Config
 
cross_node_timeout - Variable in class org.apache.cassandra.config.Config
 
crossNodeDroppedLatency - Variable in class org.apache.cassandra.metrics.DroppedMessageMetrics
The cross node dropped latency
CSLM_OVERHEAD - Static variable in class org.apache.cassandra.index.sasi.memory.SkipListMemIndex
 
csZoneDc - Variable in class org.apache.cassandra.locator.CloudstackSnitch
 
csZoneRack - Variable in class org.apache.cassandra.locator.CloudstackSnitch
 
CTOR_SIG - Static variable in class org.apache.cassandra.cql3.functions.UDFByteCodeVerifier
 
current(SSTableReader) - Method in interface org.apache.cassandra.db.lifecycle.ILifecycleTransaction
 
current() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
returns the currently visible readers managed by this transaction
current(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
return the current version of the provided reader, whether or not it is visible or staged; i.e.
current(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
 
CURRENT - Static variable in class org.apache.cassandra.index.sasi.disk.Descriptor
 
current() - Static method in enum org.apache.cassandra.io.sstable.format.SSTableFormat.Type
 
current() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
current() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
CURRENT - Static variable in enum org.apache.cassandra.transport.ProtocolVersion
The preferred versions
current() - Method in class org.apache.cassandra.utils.btree.FullBTreeSearchIterator
 
current() - Method in class org.apache.cassandra.utils.btree.LeafBTreeSearchIterator
 
current() - Method in interface org.apache.cassandra.utils.IndexedSearchIterator
 
CURRENT_VERSION - Static variable in class org.apache.cassandra.audit.BinAuditLogger
 
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.db.SystemKeyspace
 
CURRENT_VERSION - Static variable in class org.apache.cassandra.fql.FullQueryLogger
 
CURRENT_VERSION - Static variable in class org.apache.cassandra.index.sasi.disk.Descriptor
 
current_version - Static variable in class org.apache.cassandra.net.MessagingService
 
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).
currentBlockIdx() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
 
currentBuffer() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
currentBytes - Variable in class org.apache.cassandra.streaming.ProgressInfo
 
currentClustering() - Method in class org.apache.cassandra.cql3.UpdateParameters
 
currentIndex() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
 
CURRENTLY_BLOCKED_TASKS - Static variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
 
currentlyBackgroundUpgrading - Variable in class org.apache.cassandra.db.compaction.CompactionManager
 
currentTimeMillis() - Static method in class org.apache.cassandra.utils.ApproximateTime
no guarantees about relationship to nanoTime; non-monotonic (tracks currentTimeMillis as closely as possible)
currentTimeMillis() - Method in class org.apache.cassandra.utils.SystemTimeSource
 
currentTimeMillis() - Method in interface org.apache.cassandra.utils.TimeSource
 
currentTimeoutNanos() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
currentWriter() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
Cursor<K,V> - Interface in org.apache.cassandra.index.sasi.utils.trie
A Cursor can be used to traverse a Trie, visit each node step by step and make Cursor.Decisions on each step how to continue with traversing the Trie.
Cursor.Decision - Enum in org.apache.cassandra.index.sasi.utils.trie
The Cursor.Decision tells the Cursor what to do on each step while traversing the Trie.
Custom(AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Custom
 
Custom(String) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Custom
 
custom(String) - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns a Custom type.
custom(DataType.CustomType) - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return a newly-created codec for the given CQL custom type.
CUSTOM_EXPRESSION_NOT_SUPPORTED - Static variable in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
 
CUSTOM_EXPRESSIONS_NOT_ALLOWED - Static variable in class org.apache.cassandra.cql3.statements.ModificationStatement
 
CUSTOM_INDEX_OPTION_NAME - Static variable in class org.apache.cassandra.cql3.statements.schema.IndexTarget
 
customClass - Variable in class org.apache.cassandra.cql3.statements.schema.IndexAttributes
 
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
 
CustomExpression(TableMetadata, IndexMetadata, ByteBuffer) - Constructor for class org.apache.cassandra.db.filter.RowFilter.CustomExpression
 
customExpressionValueType() - Method in interface org.apache.cassandra.index.Index
If the index supports custom search expressions using the SELECT * FROM table WHERE expr(index_name, expression) syntax, this method should return the expected type of the expression argument.
customExpressionValueType() - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
customExpressionValueType() - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
CustomIndexExpression - Class in org.apache.cassandra.cql3.restrictions
 
CustomIndexExpression(QualifiedName, Term.Raw) - Constructor for class org.apache.cassandra.cql3.restrictions.CustomIndexExpression
 
CustomPayloadMirroringQueryHandler - Class in org.apache.cassandra.cql3
Custom QueryHandler that sends custom request payloads back with the result.
CustomPayloadMirroringQueryHandler() - Constructor for class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
 

D

daemonInitialization() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
daemonInitialization(Supplier<Config>) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
data() - Method in class org.apache.cassandra.db.virtual.AbstractVirtualTable
Provide a AbstractVirtualTable.DataSet that is contains all of the virtual table's data.
data(DecoratedKey) - Method in class org.apache.cassandra.db.virtual.AbstractVirtualTable
Provide a AbstractVirtualTable.DataSet that is potentially restricted to the provided partition - but is allowed to contain other partitions.
data() - Method in class org.apache.cassandra.db.virtual.AbstractVirtualTable.SimpleTable
 
data(DecoratedKey) - Method in class org.apache.cassandra.db.virtual.InternodeInboundTable
 
data() - Method in class org.apache.cassandra.db.virtual.InternodeInboundTable
 
data(DecoratedKey) - Method in class org.apache.cassandra.db.virtual.InternodeOutboundTable
 
data() - Method in class org.apache.cassandra.db.virtual.InternodeOutboundTable
 
DATA - Static variable in class org.apache.cassandra.io.sstable.Component
 
data - Variable in class org.apache.cassandra.utils.Interval
 
DATA_CENTER_NAME - Static variable in class org.apache.cassandra.locator.SimpleSnitch
 
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
 
DataBlock(MappedBuffer) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataBlock
 
datacenter(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
datacenter - Variable in class org.apache.cassandra.service.TokenRange.EndpointDetails
 
Datacenters - Class in org.apache.cassandra.dht
 
Datacenters() - Constructor for class org.apache.cassandra.dht.Datacenters
 
DATACENTERS_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
DatacenterSyncWriteResponseHandler<T> - Class in org.apache.cassandra.service
This class blocks for a quorum of responses _in all datacenters_ (CL.EACH_QUORUM).
DatacenterSyncWriteResponseHandler(ReplicaPlan.ForTokenWrite, Runnable, WriteType, long) - Constructor for class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
DatacenterWriteResponseHandler<T> - Class in org.apache.cassandra.service
This class blocks for a quorum of responses _in the local datacenter only_ (CL.LOCAL_QUORUM).
DatacenterWriteResponseHandler(ReplicaPlan.ForTokenWrite, Runnable, WriteType, long) - Constructor for class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
dataDirectories - Static variable in class org.apache.cassandra.db.Directories
The directories used to store keyspaces data.
DataDirectories(String[], String[]) - Constructor for class org.apache.cassandra.db.Directories.DataDirectories
 
DataDirectory(String) - Constructor for class org.apache.cassandra.db.Directories.DataDirectory
 
DataDirectory(File) - Constructor for class org.apache.cassandra.db.Directories.DataDirectory
 
dataFile - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
DataInputBuffer - Class in org.apache.cassandra.io.util
Input stream around a single ByteBuffer.
DataInputBuffer(ByteBuffer, boolean) - Constructor for class org.apache.cassandra.io.util.DataInputBuffer
 
DataInputBuffer(byte[], int, int) - Constructor for class org.apache.cassandra.io.util.DataInputBuffer
 
DataInputBuffer(byte[]) - Constructor for class org.apache.cassandra.io.util.DataInputBuffer
 
DataInputPlus - Interface in org.apache.cassandra.io.util
Extension to DataInput that provides support for reading varints
DataInputPlus.DataInputStreamPlus - Class in org.apache.cassandra.io.util
Wrapper around an InputStream that provides no buffering but can decode varints
DataInputStreamPlus(InputStream) - Constructor for class org.apache.cassandra.io.util.DataInputPlus.DataInputStreamPlus
 
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.FileDigestValidator - Class in org.apache.cassandra.io.util
 
dataLength - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
 
dataLength - Variable in class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
 
dataLength() - Method in class org.apache.cassandra.io.util.FileHandle
 
dataLevel - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
DataLevel(long, int) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataLevel
 
DataLimits - Class in org.apache.cassandra.db.filter
Object in charge of tracking if we have fetch enough data for a given query.
DataLimits() - Constructor for class org.apache.cassandra.db.filter.DataLimits
 
DataLimits.Counter - Class in org.apache.cassandra.db.filter
 
DataLimits.Kind - Enum in org.apache.cassandra.db.filter
 
DataLimits.Serializer - Class in org.apache.cassandra.db.filter
 
DataOutputBuffer - Class in org.apache.cassandra.io.util
An implementation of the DataOutputStream interface using a FastByteArrayOutputStream and exposing its buffer so copies can be avoided.
DataOutputBuffer() - Constructor for class org.apache.cassandra.io.util.DataOutputBuffer
 
DataOutputBuffer(int) - Constructor for class org.apache.cassandra.io.util.DataOutputBuffer
 
DataOutputBuffer(ByteBuffer) - Constructor for class org.apache.cassandra.io.util.DataOutputBuffer
 
DataOutputBufferFixed - Class in org.apache.cassandra.io.util
An implementation of the DataOutputStream interface using a FastByteArrayOutputStream and exposing its buffer so copies can be avoided.
DataOutputBufferFixed() - Constructor for class org.apache.cassandra.io.util.DataOutputBufferFixed
 
DataOutputBufferFixed(int) - Constructor for class org.apache.cassandra.io.util.DataOutputBufferFixed
 
DataOutputBufferFixed(ByteBuffer) - Constructor for class org.apache.cassandra.io.util.DataOutputBufferFixed
 
DataOutputPlus - Interface in org.apache.cassandra.io.util
Extension to DataOutput that provides for writing ByteBuffer and Memory, potentially with an efficient implementation that is zero copy or at least has reduced bounds checking overhead.
DataOutputStreamPlus - Class in org.apache.cassandra.io.util
Abstract base class for DataOutputStreams that accept writes from ByteBuffer or Memory and also provide access to the underlying WritableByteChannel associated with their output stream.
DataOutputStreamPlus() - Constructor for class org.apache.cassandra.io.util.DataOutputStreamPlus
 
DataOutputStreamPlus(WritableByteChannel) - Constructor for class org.apache.cassandra.io.util.DataOutputStreamPlus
 
DataPosition - Interface in org.apache.cassandra.io.util
 
dataPresent - Variable in exception org.apache.cassandra.exceptions.ReadFailureException
 
dataPresent - Variable in exception org.apache.cassandra.exceptions.ReadTimeoutException
 
DataRange - Class in org.apache.cassandra.db
Groups both the range of partitions to query, and the clustering index filter to apply for each partition (for a (partition) range query).
DataRange(AbstractBounds<PartitionPosition>, ClusteringIndexFilter) - Constructor for class org.apache.cassandra.db.DataRange
Creates a DataRange given a range of partition keys and a clustering index filter.
dataRange() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
dataRange() - Method in interface org.apache.cassandra.db.PartitionRangeReadQuery
 
dataRange() - Method in class org.apache.cassandra.db.VirtualTablePartitionRangeReadQuery
 
dataRange() - Method in class org.apache.cassandra.index.sasi.plan.QueryController
 
DataRange.Paging - Class in org.apache.cassandra.db
Specialized DataRange used for the paging case.
DataRange.Serializer - Class in org.apache.cassandra.db
 
DataResolver<E extends Endpoints<E>,P extends ReplicaPlan.ForRead<E>> - Class in org.apache.cassandra.service.reads
 
DataResolver(ReadCommand, ReplicaPlan.Shared<E, P>, ReadRepair<E, P>, long) - Constructor for class org.apache.cassandra.service.reads.DataResolver
 
DataResolver(ReadCommand, ReplicaPlan.Shared<E, P>, ReadRepair<E, P>, long, boolean) - Constructor for class org.apache.cassandra.service.reads.DataResolver
 
DataResource - Class in org.apache.cassandra.auth
The primary type of resource in Cassandra.
dataSize() - Method in interface org.apache.cassandra.db.ClusteringPrefix
The size of the data hold by this prefix.
dataSize() - Method in interface org.apache.cassandra.db.DeletionInfo
 
dataSize() - Method in class org.apache.cassandra.db.DeletionTime
 
dataSize(Collection<? extends IMutation>) - Static method in interface org.apache.cassandra.db.IMutation
Computes the total data size of the specified mutations.
dataSize() - Method in class org.apache.cassandra.db.LivenessInfo
The size of the (useful) data this liveness information contains.
dataSize() - Method in class org.apache.cassandra.db.MutableDeletionInfo
 
dataSize() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
The size of the data contained in this update.
dataSize() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
dataSize() - Method in class org.apache.cassandra.db.rows.AbstractCell
 
dataSize() - Method in class org.apache.cassandra.db.rows.BTreeRow
 
dataSize() - Method in class org.apache.cassandra.db.rows.CellPath
 
dataSize() - Method in class org.apache.cassandra.db.rows.ColumnData
The size of the data hold by this ColumnData.
dataSize() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
dataSize() - Method in interface org.apache.cassandra.db.rows.Row
 
dataSize() - Method in class org.apache.cassandra.db.rows.Row.Deletion
 
dataSize - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStat.Builder
 
dataSize - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStat
 
DataTerm(MappedBuffer, OnDiskIndexBuilder.TermSize, TokenTree) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataTerm
 
DataTracker - Class in org.apache.cassandra.index.sasi.conf
a pared-down version of DataTracker and DT.View.
DataTracker(AbstractType<?>, ColumnIndex) - Constructor for class org.apache.cassandra.index.sasi.conf.DataTracker
 
DataType - Class in org.apache.cassandra.cql3.functions.types
Data types supported by cassandra.
DataType(DataType.Name) - Constructor for class org.apache.cassandra.cql3.functions.types.DataType
 
DataType - Enum in org.apache.cassandra.transport
 
DataType.Codec - Class in org.apache.cassandra.transport
 
DataType.CollectionType - Class in org.apache.cassandra.cql3.functions.types
Instances of this class represent collection types, that is, lists, sets or maps.
DataType.CustomType - Class in org.apache.cassandra.cql3.functions.types
A "custom" type is a type that cannot be expressed as a CQL type.
DataType.Name - Enum in org.apache.cassandra.cql3.functions.types
The CQL type name.
DataType.NativeType - Class in org.apache.cassandra.cql3.functions.types
Instances of this class represent CQL native types, also known as CQL primitive types.
DataTypeClassNameParser - Class in org.apache.cassandra.cql3.functions.types
 
DataTypeClassNameParser() - Constructor for class org.apache.cassandra.cql3.functions.types.DataTypeClassNameParser
 
date() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the DATE type.
date() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type date.
dateOfFct - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
Deprecated.
Replaced by the #timeUuidToTimestamp function
dateStringToDays(String) - Static method in class org.apache.cassandra.serializers.SimpleDateSerializer
 
dateStringToTimestamp(String) - Static method in class org.apache.cassandra.serializers.TimestampSerializer
 
DateTieredCompactionStrategy - Class in org.apache.cassandra.db.compaction
Deprecated.
DateTieredCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
Deprecated.
 
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
Deprecated.
DAYS_PER_WEEK - Static variable in class org.apache.cassandra.cql3.Duration
 
dayToTimeInMillis(int) - Static method in class org.apache.cassandra.serializers.SimpleDateSerializer
 
dcLatency - Variable in class org.apache.cassandra.metrics.MessagingMetrics
 
dcLatency - Variable in class org.apache.cassandra.metrics.MessagingMetrics.DCLatencyRecorder
 
DCPermissions - Class in org.apache.cassandra.auth
 
DCPermissions() - Constructor for class org.apache.cassandra.auth.DCPermissions
 
DCPermissions.Builder - Class in org.apache.cassandra.auth
 
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.net.BufferPoolAllocator.Wrapped
 
deallocate() - Method in class org.apache.cassandra.net.SharedDefaultFileRegion
 
debug(String) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter.NullOutputHandler
 
debug - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
debug() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
debug - Variable in class org.apache.cassandra.tools.LoaderOptions
 
debug(BufferPool.Debug) - Method in class org.apache.cassandra.utils.memory.BufferPool
 
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
 
debugString() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
debugString() - Method in class org.apache.cassandra.transport.Message
 
DecayingEstimatedHistogramReservoir - Class in org.apache.cassandra.metrics
A decaying histogram reservoir where values collected during each minute will be twice as significant as the values collected in the previous minute.
DecayingEstimatedHistogramReservoir() - Constructor for class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
Construct a decaying histogram with default number of buckets and without considering zeroes.
DecayingEstimatedHistogramReservoir(boolean) - Constructor for class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
Construct a decaying histogram with default number of buckets.
DecayingEstimatedHistogramReservoir(boolean, int, int) - Constructor for class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
Construct a decaying histogram.
DecayingEstimatedHistogramReservoir(Clock) - Constructor for class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
decimal() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the DECIMAL type.
decimal() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type decimal.
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, ProtocolVersion) - Method in class org.apache.cassandra.cql3.ResultSet.Codec
 
decode(ByteBuf, ProtocolVersion) - Method in interface org.apache.cassandra.transport.CBCodec
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.cassandra.transport.Envelope.Decoder
 
decode(ChannelHandlerContext, Envelope, List<Object>) - Method in class org.apache.cassandra.transport.Envelope.Decompressor
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.cassandra.transport.InitialConnectionHandler
 
decode(ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.transport.messages.UnsupportedMessageCodec
 
decode(ChannelHandlerContext, Envelope, List) - Method in class org.apache.cassandra.transport.PreV5Handlers.ProtocolDecoder
 
decode(int, boolean) - Static method in enum org.apache.cassandra.transport.ProtocolVersion
 
decodeEntry(DecoratedKey, Row) - Method in class org.apache.cassandra.index.internal.CassandraIndex
Used at search time to convert a row in the index table into a simple struct containing the values required to retrieve the corresponding row from the base table.
decodeEntry(DecoratedKey, Row) - Method in class org.apache.cassandra.index.internal.composites.ClusteringColumnIndex
 
decodeEntry(DecoratedKey, Row) - Method in class org.apache.cassandra.index.internal.composites.CollectionKeyIndexBase
 
decodeEntry(DecoratedKey, Row) - Method in class org.apache.cassandra.index.internal.composites.CollectionValueIndex
 
decodeEntry(DecoratedKey, Row) - Method in class org.apache.cassandra.index.internal.composites.PartitionKeyIndex
 
decodeEntry(DecoratedKey, Row) - Method in class org.apache.cassandra.index.internal.composites.RegularColumnIndex
 
decodeEntry(DecoratedKey, Row) - Method in class org.apache.cassandra.index.internal.keys.KeysIndex
 
decodeJson(String) - Static method in class org.apache.cassandra.cql3.Json
 
decodeOne(ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.transport.DataType.Codec
 
decoder - Variable in class org.apache.cassandra.net.AbstractMessageHandler
 
Decoder() - Constructor for class org.apache.cassandra.transport.Envelope.Decoder
 
decodeZigZag64(long) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
Decode a ZigZag-encoded 64-bit value.
decommission(boolean) - Method in class org.apache.cassandra.service.StorageService
 
decommission(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
transfer this node's data to other machines and remove it from service.
decommission(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
 
Decommission - Class in org.apache.cassandra.tools.nodetool
 
Decommission() - Constructor for class org.apache.cassandra.tools.nodetool.Decommission
 
decompose(ProtocolVersion, Object) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
 
decompose(ProtocolVersion, Object) - Method in class org.apache.cassandra.cql3.functions.UDFunction
Used by UDF implementations (both Java code generated by JavaBasedUDFunction and script executor ScriptBasedUDFunction) to convert the Java object representation for the return value to the C* serialized representation.
decompose(TypeCodec<Object>, ProtocolVersion, Object) - Static method in class org.apache.cassandra.cql3.functions.UDFunction
 
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.PartitionerDefinedOrder
 
decompose(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
decomposes a uuid into raw bytes.
decompress(Envelope) - Method in interface org.apache.cassandra.transport.Compressor
 
decompress(Envelope) - Method in class org.apache.cassandra.transport.Compressor.LZ4Compressor
 
decompress(Envelope) - Method in class org.apache.cassandra.transport.Compressor.SnappyCompressor
 
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.db.ColumnFamilyStore
 
decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
decorateKey(ByteBuffer) - Method in interface org.apache.cassandra.dht.IPartitioner
Transform key to object representation of the on-disk format.
decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
 
decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
decorateKey(ByteBuffer) - Method in class org.apache.cassandra.io.sstable.SSTable
 
decorateKey(ByteBuffer) - Method in class org.apache.cassandra.locator.TokenMetadata
 
decorateSubrange(Range<Token>) - Method in class org.apache.cassandra.locator.Replica
 
decreaseIndent() - Method in class org.apache.cassandra.cql3.CqlBuilder
 
decrypt(ReadableByteChannel, ByteBuffer, boolean, Cipher) - Static method in class org.apache.cassandra.security.EncryptionUtils
Decrypt the input data, as well as manage sizing of the outputBuffer; if the buffer is not big enough, deallocate current, and allocate a large enough buffer.
decrypt(FileDataInput, ByteBuffer, boolean, Cipher) - Static method in class org.apache.cassandra.security.EncryptionUtils
 
DEFAULT - Static variable in class org.apache.cassandra.cql3.BatchQueryOptions
 
DEFAULT - Static variable in class org.apache.cassandra.cql3.QueryOptions
 
DEFAULT - Static variable in class org.apache.cassandra.io.util.SequentialWriterOption
Default write option.
DEFAULT - Static variable in class org.apache.cassandra.schema.CachingParams
 
DEFAULT - Static variable in class org.apache.cassandra.schema.CompactionParams
 
DEFAULT - Static variable in class org.apache.cassandra.schema.CompressionParams
 
DEFAULT_BASE_TIME_SECONDS - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
DEFAULT_BUCKET_COUNT - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
The default number of decayingBuckets.
DEFAULT_BUCKET_HIGH - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
DEFAULT_BUCKET_LOW - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
DEFAULT_BUFFER_SIZE - Static variable in class org.apache.cassandra.io.util.RandomAccessReader
 
DEFAULT_CHUNK_LENGTH - Static variable in class org.apache.cassandra.schema.CompressionParams
 
DEFAULT_COMPACTION_WINDOW_SIZE - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
DEFAULT_COMPACTION_WINDOW_UNIT - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
DEFAULT_COMPRESSION_LEVEL - Static variable in class org.apache.cassandra.io.compress.ZstdCompressor
 
DEFAULT_DURABLE_WRITES - Static variable in class org.apache.cassandra.schema.KeyspaceParams
 
DEFAULT_ENABLED - Static variable in class org.apache.cassandra.schema.CompactionParams
 
DEFAULT_EXPIRED_SSTABLE_CHECK_FREQUENCY_SECONDS - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
DEFAULT_EXPIRED_SSTABLE_CHECK_FREQUENCY_SECONDS - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
DEFAULT_FAIL_THRESHOLD - Static variable in class org.apache.cassandra.config.ReplicaFilteringProtectionOptions
 
DEFAULT_HOST - Static variable in class org.apache.cassandra.tools.AbstractJmxClient
 
DEFAULT_HOT_RELOAD_INITIAL_DELAY_SEC - Static variable in class org.apache.cassandra.security.SSLFactory
Default initial delay for hot reloading
DEFAULT_HOT_RELOAD_PERIOD_SEC - Static variable in class org.apache.cassandra.security.SSLFactory
Default periodic check delay for hot reloading
DEFAULT_JMX_PORT - Static variable in class org.apache.cassandra.tools.AbstractJmxClient
 
DEFAULT_LEVEL_FANOUT_SIZE - Static variable in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
DEFAULT_LOCAL_DURABLE_WRITES - Static variable in class org.apache.cassandra.schema.KeyspaceParams
This determines durable writes for the SchemaConstants.SCHEMA_KEYSPACE_NAME and SchemaConstants.SYSTEM_KEYSPACE_NAME keyspaces, the only reason it is not final is for commitlog unit tests.
DEFAULT_LOG_ALL_OPTION - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
DEFAULT_MAX_SSTABLE_AGE_DAYS - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
Deprecated.
DEFAULT_MAX_THRESHOLD - Static variable in class org.apache.cassandra.schema.CompactionParams
 
DEFAULT_MAX_TOKEN_LENGTH - Static variable in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
DEFAULT_MAX_WINDOW_SIZE_SECONDS - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
DEFAULT_MIN_COMPRESS_RATIO - Static variable in class org.apache.cassandra.schema.CompressionParams
 
DEFAULT_MIN_SSTABLE_SIZE - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
DEFAULT_MIN_THRESHOLD - Static variable in class org.apache.cassandra.schema.CompactionParams
 
DEFAULT_MIN_TOKEN_LENGTH - Static variable in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
DEFAULT_PAGE_SIZE - Static variable in class org.apache.cassandra.cql3.statements.SelectStatement
 
DEFAULT_PAGE_SIZE - Static variable in class org.apache.cassandra.index.SecondaryIndexManager
 
DEFAULT_PROVIDE_OVERLAPPING_TOMBSTONES - Static variable in class org.apache.cassandra.schema.CompactionParams
 
DEFAULT_SMALLEST_SSTABLE_BYTES - Static variable in class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
 
DEFAULT_SSTABLE_SIZE - Static variable in class org.apache.cassandra.tools.StandaloneSplitter
 
DEFAULT_STRIPE_COUNT - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
DEFAULT_THRESHOLDS - Static variable in class org.apache.cassandra.schema.CompactionParams
 
DEFAULT_TIMESTAMP_RESOLUTION - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
DEFAULT_TIMESTAMP_RESOLUTION - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
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_UNSAFE_AGGRESSIVE_SSTABLE_EXPIRATION - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
DEFAULT_WARN_THRESHOLD - Static variable in class org.apache.cassandra.config.ReplicaFilteringProtectionOptions
 
DEFAULT_WITH_ZERO_BUCKET_OFFSETS - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
DEFAULT_WITHOUT_ZERO_BUCKET_OFFSETS - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
DEFAULT_ZERO_CONSIDERATION - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
DefaultCompactionWriter - Class in org.apache.cassandra.db.compaction.writers
The default compaction writer - creates one output file in L0
DefaultCompactionWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>) - Constructor for class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
 
DefaultCompactionWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, boolean, boolean, int) - Constructor for class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
Deprecated.
DefaultCompactionWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, boolean, int) - Constructor for class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
 
DefaultConnectionFactory - Class in org.apache.cassandra.streaming
 
DefaultConnectionFactory() - Constructor for class org.apache.cassandra.streaming.DefaultConnectionFactory
 
DefaultFSErrorHandler - Class in org.apache.cassandra.service
 
DefaultFSErrorHandler() - Constructor for class org.apache.cassandra.service.DefaultFSErrorHandler
 
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
 
DefaultPrinter() - Constructor for class org.apache.cassandra.tools.nodetool.stats.CompactionHistoryPrinter.DefaultPrinter
 
DefaultPrinter() - Constructor for class org.apache.cassandra.tools.nodetool.stats.TpStatsPrinter.DefaultPrinter
 
Defaults() - Constructor for class org.apache.cassandra.utils.MonotonicClock.Defaults
 
defaultStatsMetadata() - Static method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
DefaultStemmingFilter(Locale) - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.StemmingFilters.DefaultStemmingFilter
 
DefaultStopWordFilter(Locale) - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.StopWordFilters.DefaultStopWordFilter
 
defaultTimeToLive(int) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
defaultTimeToLive(int) - Method in class org.apache.cassandra.schema.TableParams.Builder
 
defaultTimeToLive - Variable in class org.apache.cassandra.schema.TableParams
 
DefaultValue<T> - Class in org.apache.cassandra.utils
 
DefaultValue(T) - Constructor for class org.apache.cassandra.utils.DefaultValue
 
definition - Variable in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractTupleCodec
 
definition - Variable in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractUDTCodec
 
deflate() - Static method in class org.apache.cassandra.schema.CompressionParams
 
deflate(int) - Static method in class org.apache.cassandra.schema.CompressionParams
 
DeflateCompressor - Class in org.apache.cassandra.io.compress
 
DelayedValue(List<Term>) - Constructor for class org.apache.cassandra.cql3.Lists.DelayedValue
 
DelayedValue(Comparator<ByteBuffer>, Map<Term, Term>) - Constructor for class org.apache.cassandra.cql3.Maps.DelayedValue
 
DelayedValue(Comparator<ByteBuffer>, Set<Term>) - Constructor for class org.apache.cassandra.cql3.Sets.DelayedValue
 
DelayedValue(TupleType, List<Term>) - Constructor for class org.apache.cassandra.cql3.Tuples.DelayedValue
 
DelayedValue(UserType, List<Term>) - Constructor for class org.apache.cassandra.cql3.UserTypes.DelayedValue
 
delete() - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder
Deletes the partition identified by this builder (using a partition level deletion).
delete() - Method in interface org.apache.cassandra.db.rows.Row.SimpleBuilder
Deletes the whole row.
delete(String) - Method in interface org.apache.cassandra.db.rows.Row.SimpleBuilder
Removes the value for a given column (creating a tombstone).
delete() - Method in class org.apache.cassandra.db.SimpleBuilders.PartitionUpdateBuilder
 
delete() - Method in class org.apache.cassandra.db.SimpleBuilders.RowBuilder
 
delete(String) - Method in class org.apache.cassandra.db.SimpleBuilders.RowBuilder
 
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
 
deleteAllHints() - Method in class org.apache.cassandra.hints.HintsService
Deletes all hints for all destinations.
deleteAllHints() - Method in interface org.apache.cassandra.hints.HintsServiceMBean
Irrevocably deletes all the stored hints files (with the exception of those that are being dispatched right now, or being written to).
deleteAllHintsForEndpoint(String) - Method in class org.apache.cassandra.hints.HintsService
Deletes all hints for the provided destination.
deleteAllHintsForEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.hints.HintsService
Deletes all hints for the provided destination.
deleteAllHintsForEndpoint(String) - Method in interface org.apache.cassandra.hints.HintsServiceMBean
Irrevocably deletes all the stored hints files for the target address (with the exception of those that are being dispatched right now, or being written to).
deleteAsync(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
deleteChildrenRecursive(File) - Static method in class org.apache.cassandra.io.util.FileUtils
Deletes all files and subdirectories under "dir".
deleteDirectoryIfEmpty(Path) - Static method in class org.apache.cassandra.io.util.FileUtils
Deletes the specified directory if it is empty
deletedSlice() - Method in class org.apache.cassandra.db.RangeTombstone
The slice of rows that is deleted by this range tombstone.
deleteOldSnapshots() - Static method in class org.apache.cassandra.db.WindowsFailedSnapshotTracker
 
deletePartition(UnfilteredRowIterator, int) - Method in class org.apache.cassandra.index.SecondaryIndexManager
Delete all data from all indexes for this partition.
Deleter(ColumnMetadata) - Constructor for class org.apache.cassandra.cql3.Constants.Deleter
 
DeleterByField(ColumnMetadata, FieldIdentifier) - Constructor for class org.apache.cassandra.cql3.UserTypes.DeleterByField
 
deleteRecursive(File) - Static method in class org.apache.cassandra.io.util.FileUtils
Deletes the specified directory after having deleted its content.
deleteRecursiveOnExit(File) - Static method in class org.apache.cassandra.io.util.FileUtils
Schedules deletion of all file and subdirectories under "dir" on JVM shutdown.
deleteRecursiveWithThrottle(File, RateLimiter) - Static method in class org.apache.cassandra.io.util.FileUtils
Deletes all files and subdirectories under "dir".
deletes(LivenessInfo) - Method in class org.apache.cassandra.db.DeletionTime
 
deletes(Cell<?>) - Method in class org.apache.cassandra.db.DeletionTime
 
deletes(long) - Method in class org.apache.cassandra.db.DeletionTime
 
deletes(LivenessInfo) - Method in class org.apache.cassandra.db.rows.Row.Deletion
 
deletes(Cell<?>) - Method in class org.apache.cassandra.db.rows.Row.Deletion
 
deleteSession(UUID) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
deleteStaleEntry(DecoratedKey, Clustering<?>, DeletionTime, WriteContext) - Method in class org.apache.cassandra.index.internal.CassandraIndex
Specific to internal indexes, this is called by a searcher when it encounters a stale entry in the index
DeleteStatement - Class in org.apache.cassandra.cql3.statements
A DELETE parsed from a CQL query statement.
DeleteStatement.Parsed - Class in org.apache.cassandra.cql3.statements
 
deleteWithConfirm(String, Throwable) - Static method in class org.apache.cassandra.io.util.FileUtils
 
deleteWithConfirm(File, Throwable) - Static method in class org.apache.cassandra.io.util.FileUtils
 
deleteWithConfirm(File, Throwable, RateLimiter) - Static method in class org.apache.cassandra.io.util.FileUtils
 
deleteWithConfirm(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
deleteWithConfirm(File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
deleteWithConfirmWithThrottle(File, RateLimiter) - Static method in class org.apache.cassandra.io.util.FileUtils
 
deleting - Variable in class org.apache.cassandra.notifications.SSTableDeletingNotification
 
DeletingArchiver - Class in org.apache.cassandra.utils.binlog
 
DeletingArchiver(long) - Constructor for class org.apache.cassandra.utils.binlog.DeletingArchiver
 
deletion - Variable in class org.apache.cassandra.db.rows.BTreeRow.Builder
 
deletion() - Method in class org.apache.cassandra.db.rows.BTreeRow
 
deletion() - Method in interface org.apache.cassandra.db.rows.Row
The row deletion.
Deletion(DeletionTime, boolean) - Constructor for class org.apache.cassandra.db.rows.Row.Deletion
 
deletion(long) - Static method in class org.apache.cassandra.tools.SSTableMetadataViewer
 
DeletionInfo - Interface in org.apache.cassandra.db
A combination of a top-level (partition) tombstone and range tombstones describing the deletions within a partition.
deletionInfo() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
deletionInfo() - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
 
deletionInfo() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
 
DeletionPurger - Interface in org.apache.cassandra.db
 
deletionTime() - Method in class org.apache.cassandra.cql3.UpdateParameters
 
DeletionTime - Class in org.apache.cassandra.db
Information on deletion of a storage engine object.
DeletionTime(long, int) - Constructor for class org.apache.cassandra.db.DeletionTime
 
deletionTime() - Method in class org.apache.cassandra.db.RangeTombstone
The deletion time for this (range) tombstone.
deletionTime() - Method in class org.apache.cassandra.db.RowIndexEntry
 
deletionTime() - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
The deletion time for the range tombstone this is a bound of.
DeletionTime.Serializer - Class in org.apache.cassandra.db
 
deletionTimeSerializedSize(DeletionTime) - Method in class org.apache.cassandra.db.SerializationHeader
 
DELIMITER - Static variable in class org.apache.cassandra.gms.VersionedValue
 
DELIMITER - Static variable in class org.apache.cassandra.index.sasi.analyzer.DelimiterTokenizingOptions
 
DELIMITER_STR - Static variable in class org.apache.cassandra.gms.VersionedValue
 
DelimiterAnalyzer - Class in org.apache.cassandra.index.sasi.analyzer
 
DelimiterAnalyzer() - Constructor for class org.apache.cassandra.index.sasi.analyzer.DelimiterAnalyzer
 
DelimiterTokenizingOptions - Class in org.apache.cassandra.index.sasi.analyzer
Simple tokenizer based on a specified delimiter (rather than whitespace).
deliverHints(String) - Method in class org.apache.cassandra.service.StorageService
 
deliverHints(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
denormalize(Range<Token>, RangeMap<StreamFromOptions>) - Static method in class org.apache.cassandra.repair.asymmetric.RangeDenormalizer
"Denormalizes" (kind of the opposite of what Range.normalize does) the ranges in the keys of {{incoming}} It makes sure that if there is an intersection between {{range}} and some of the ranges in {{incoming.keySet()}} we know that all intersections are keys in the updated {{incoming}}
dependsOn(ColumnMetadata) - Method in interface org.apache.cassandra.index.Index
Called to determine whether this index targets a specific column.
dependsOn(ColumnMetadata) - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
dependsOn(ColumnMetadata) - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
DEPRECATED_MBEAN_NAME - Static variable in class org.apache.cassandra.db.DisallowedDirectories
 
depth(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
 
depth - Variable in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
desc - Variable in class org.apache.cassandra.cache.KeyCacheKey
 
desc - Variable in exception org.apache.cassandra.exceptions.RepairException
 
desc - Variable in class org.apache.cassandra.repair.messages.RepairMessage
 
desc - Variable in class org.apache.cassandra.repair.RepairResult
 
desc - Variable in class org.apache.cassandra.repair.SyncTask
 
desc - Variable in class org.apache.cassandra.repair.Validator
 
desc(boolean) - Static method in enum org.apache.cassandra.utils.btree.BTree.Dir
 
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(ClientState, Keyspaces) - Method in class org.apache.cassandra.cql3.statements.DescribeStatement
Returns the schema elements that must be part of the output.
describe(ClientState, Keyspaces) - Method in class org.apache.cassandra.cql3.statements.DescribeStatement.Element
 
describe(ClientState, Keyspaces) - Method in class org.apache.cassandra.cql3.statements.DescribeStatement.Listing
 
DescribeCluster - Class in org.apache.cassandra.tools.nodetool
 
DescribeCluster() - Constructor for class org.apache.cassandra.tools.nodetool.DescribeCluster
 
describeLocalRing(String) - Method in class org.apache.cassandra.service.StorageService
The same as describeRing(String) but considers only the part of the ring formed by nodes in the local DC.
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
describeOwnership(List<Token>) - Method in interface org.apache.cassandra.dht.IPartitioner
Calculate the deltas between tokens in the ring in order to compare relative sizes.
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
 
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
describeRing(String) - Method in class org.apache.cassandra.service.StorageService
The TokenRange for a given keyspace.
describeRing(String, boolean) - Method in class org.apache.cassandra.tools.NodeProbe
 
DescribeRing - Class in org.apache.cassandra.tools.nodetool
 
DescribeRing() - Constructor for class org.apache.cassandra.tools.nodetool.DescribeRing
 
describeRingJMX(String) - Method in class org.apache.cassandra.service.StorageService
 
describeRingJMX(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
describeRingWithPortJMX(String) - Method in class org.apache.cassandra.service.StorageService
 
describeRingWithPortJMX(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
describeSchemaVersions(boolean) - 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.
DescribeStatement<T> - Class in org.apache.cassandra.cql3.statements
The differents DESCRIBE statements parsed from a CQL statement.
DescribeStatement() - Constructor for class org.apache.cassandra.cql3.statements.DescribeStatement
 
DescribeStatement.Element - Class in org.apache.cassandra.cql3.statements
DescribeStatement implementation used for describe queries for a single schema element.
DescribeStatement.Listing - Class in org.apache.cassandra.cql3.statements
DescribeStatement implementation used for describe queries that only list elements names.
description() - Method in enum org.apache.cassandra.config.EncryptionOptions.TlsEncryptionPolicy
 
descriptor - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
Descriptor - Class in org.apache.cassandra.index.sasi.disk
Object descriptor for SASIIndex files.
Descriptor(String) - Constructor for class org.apache.cassandra.index.sasi.disk.Descriptor
 
descriptor - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
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) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
A descriptor that assumes CURRENT_VERSION.
Descriptor(File, String, String, int, SSTableFormat.Type) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
Constructor for sstable writers only.
Descriptor(String, File, String, String, int, SSTableFormat.Type) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
 
Descriptor(Version, File, String, String, int, SSTableFormat.Type) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
 
descriptor - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
descriptor - Variable in class org.apache.cassandra.io.sstable.SSTable
 
Descriptor.Version - Class in org.apache.cassandra.index.sasi.disk
 
DeserializationHelper - Class in org.apache.cassandra.db.rows
 
DeserializationHelper(TableMetadata, int, DeserializationHelper.Flag, ColumnFilter) - Constructor for class org.apache.cassandra.db.rows.DeserializationHelper
 
DeserializationHelper(TableMetadata, int, DeserializationHelper.Flag) - Constructor for class org.apache.cassandra.db.rows.DeserializationHelper
 
DeserializationHelper.Flag - Enum in org.apache.cassandra.db.rows
Flag affecting deserialization behavior (this only affect counters in practice).
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.batchlog.Batch.Serializer
 
deserialize(DataInputPlus, ColumnFamilyStore) - Method in interface org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
 
deserialize(DataInputPlus) - Method in class org.apache.cassandra.cache.SerializingCacheProvider.RowCacheSerializer
 
deserialize(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractCollectionCodec
 
deserialize(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractMapCodec
 
deserialize(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractTupleCodec
 
deserialize(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractUDTCodec
 
deserialize(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Deserialize the given ByteBuffer instance according to the CQL type handled by this codec.
deserialize(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveBooleanCodec
 
deserialize(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveByteCodec
 
deserialize(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveDoubleCodec
 
deserialize(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveFloatCodec
 
deserialize(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveIntCodec
 
deserialize(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveLongCodec
 
deserialize(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveShortCodec
 
deserialize(TypeCodec<?>, ProtocolVersion, ByteBuffer) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
 
deserialize(int) - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
 
deserialize(DataInputPlus, int, ClusteringComparator) - Method in class org.apache.cassandra.db.aggregation.AggregationSpecification.Serializer
 
deserialize(DataInputPlus, int, ClusteringComparator) - Method in class org.apache.cassandra.db.aggregation.GroupingState.Serializer
 
deserialize(DataInputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Clustering.Serializer
 
deserialize(ByteBuffer, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Clustering.Serializer
 
deserialize(DataInputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.ClusteringBoundOrBoundary.Serializer
 
deserialize(DataInputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.ClusteringPrefix.Serializer
 
deserialize(DataInputPlus, TableMetadata) - Method in class org.apache.cassandra.db.Columns.Serializer
 
deserialize(DataInputPlus) - Method in class org.apache.cassandra.db.commitlog.CommitLogPosition.CommitLogPositionSerializer
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.db.CounterMutation.CounterMutationSerializer
 
deserialize(DataInputPlus, int, TableMetadata) - Method in class org.apache.cassandra.db.DataRange.Serializer
 
deserialize(DataInputPlus) - Method in class org.apache.cassandra.db.DeletionTime.Serializer
 
deserialize(DataInputPlus, int, TableMetadata, boolean) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter.InternalDeserializer
 
deserialize(DataInputPlus, int, TableMetadata) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter.Serializer
 
deserialize(DataInputPlus, int, TableMetadata) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Serializer
 
deserialize(DataInputPlus, int, TableMetadata) - Method in class org.apache.cassandra.db.filter.ColumnSubselection.Serializer
 
deserialize(DataInputPlus, int, ClusteringComparator) - Method in class org.apache.cassandra.db.filter.DataLimits.Serializer
 
deserialize(DataInputPlus, int, TableMetadata) - Method in class org.apache.cassandra.db.filter.RowFilter.Serializer
 
deserialize(DataInputPlus, int, TableMetadata) - Method in class org.apache.cassandra.db.filter.RowFilter.UserExpression.Deserializer
 
deserialize(DataInputPlus, int, DeserializationHelper.Flag) - Method in class org.apache.cassandra.db.Mutation.MutationSerializer
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.db.Mutation.MutationSerializer
 
deserialize(DataInput, IPartitioner, int) - Method in class org.apache.cassandra.db.PartitionPosition.RowPositionSerializer
 
deserialize(DataInputPlus, int, DeserializationHelper.Flag) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.PartitionUpdateSerializer
 
deserialize(DataInputPlus, int, TableMetadata, ColumnFilter, DeserializationHelper.Flag) - Method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators.Serializer
 
deserialize(DataInputPlus, int, boolean, int, boolean, TableMetadata, int, ColumnFilter, RowFilter, DataLimits, IndexMetadata) - Method in class org.apache.cassandra.db.ReadCommand.SelectionDeserializer
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.db.ReadCommand.Serializer
 
deserialize(DataInputPlus, long) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
 
deserialize(RandomAccessReader) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
 
deserialize(FileDataInput) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
 
deserialize(DataInputPlus, long) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
 
deserialize(DataInputPlus) - Method in interface org.apache.cassandra.db.rows.CellPath.Serializer
 
deserialize(DataInputPlus) - Method in class org.apache.cassandra.db.rows.EncodingStats.Serializer
 
deserialize(DataInputPlus, int, TableMetadata, DeserializationHelper.Flag, UnfilteredRowIteratorSerializer.Header) - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
 
deserialize(DataInputPlus, int, TableMetadata, ColumnFilter, DeserializationHelper.Flag) - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
 
deserialize(DataInputPlus, SerializationHeader, DeserializationHelper, Row.Builder) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
Deserialize an Unfiltered from the provided input.
deserialize(Version, DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader.Serializer
 
deserialize(DataInputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Slice.Serializer
 
deserialize(DataInputPlus, int, TableMetadata) - Method in class org.apache.cassandra.db.Slices.Serializer
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.CassandraStreamHeaderSerializer
 
deserialize(DataInputPlus, int, Function<TableId, IPartitioner>) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.CassandraStreamHeaderSerializer
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
 
deserialize(DataInput, IPartitioner, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
 
deserialize(DataInput, IPartitioner, int) - Method in interface org.apache.cassandra.dht.IPartitionerDependentSerializer
Deserialize into the specified DataInputStream instance.
deserialize(DataInput, IPartitioner, int) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.exceptions.RequestFailureReason.Serializer
 
deserialize(IPartitioner, DataInput) - Static method in class org.apache.cassandra.gms.TokenSerializer
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.hints.HintMessage.Serializer
 
deserialize(DataInputPlus) - Method in interface org.apache.cassandra.io.ISerializer
Deserialize from the specified DataInput instance.
deserialize(DataInputPlus, int) - Method in interface org.apache.cassandra.io.IVersionedAsymmetricSerializer
Deserialize into the specified DataInputStream instance.
deserialize(DataInputPlus) - Method in class org.apache.cassandra.io.sstable.IndexInfo.Serializer
 
deserialize(DataInputStream, IPartitioner, int, int) - Method in class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
 
deserialize(Version, DataInputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
 
deserialize(Version, DataInputPlus) - 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.MetadataSerializer
 
deserialize(Descriptor, MetadataType) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
 
deserialize(Descriptor, FileDataInput, EnumSet<MetadataType>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
 
deserialize(Version, DataInputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata.StatsMetadataSerializer
 
deserialize(Version, DataInputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata.ValidationMetadataSerializer
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.locator.InetAddressAndPort.FwdFrmSerializer
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.locator.InetAddressAndPort.Serializer
 
deserialize(DataInputPlus, InetAddressAndPort, int) - Method in class org.apache.cassandra.net.Message.Serializer
 
deserialize(DataInputPlus, Message.Header, int) - Method in class org.apache.cassandra.net.Message.Serializer
A partial variant of deserialize, taking in a previously deserialized Message.Header as an argument.
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.repair.SyncNodePair.NodePairSerializer
 
deserialize(DataInputPlus, int, TableMetadata) - Method in class org.apache.cassandra.schema.IndexMetadata.Serializer
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.schema.MigrationManager.MigrationsSerializer
 
deserialize(DataInput) - Static method in class org.apache.cassandra.schema.TableId
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.BooleanSerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.ByteSerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.BytesSerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.CollectionSerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.DecimalSerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.DoubleSerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.DurationSerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.EmptySerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.FloatSerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.Int32Serializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.IntegerSerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.LongSerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.ShortSerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.TimeSerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.TimestampSerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.TypeSerializer
 
deserialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.TypeSerializer
 
deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.UUIDSerializer
 
deserialize(DataInputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.CounterCacheSerializer
 
deserialize(DataInputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.KeyCacheSerializer
 
deserialize(DataInputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.RowCacheSerializer
 
deserialize(ByteBuffer, ProtocolVersion) - Static method in class org.apache.cassandra.service.pager.PagingState
It's possible to receive a V3 paging state on a V4 client session, and vice versa - so we cannot blindly rely on the protocol version provided.
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.paxos.Commit.CommitSerializer
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
 
deserialize(LZ4SafeDecompressor, DataInputPlus, int) - Method in class org.apache.cassandra.streaming.async.StreamCompressionSerializer
 
deserialize(DataInputPlus, int) - Static method in class org.apache.cassandra.streaming.messages.StreamMessage
 
deserialize(DataInputPlus, int) - Method in interface org.apache.cassandra.streaming.messages.StreamMessage.Serializer
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.streaming.messages.StreamMessageHeader.FileMessageHeaderSerializer
 
deserialize(int) - Static method in enum org.apache.cassandra.streaming.PreviewKind
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
 
deserialize(byte) - Static method in enum org.apache.cassandra.tracing.Tracing.TraceType
 
deserialize(int) - Static method in enum org.apache.cassandra.transport.Envelope.Header.Flag
 
deserialize(ByteBuf, ProtocolVersion) - Static method in class org.apache.cassandra.transport.Event
 
deserialize(DataInputStream, boolean) - Static method in class org.apache.cassandra.utils.BloomFilterSerializer
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.BooleanSerializer
 
deserialize(DataInputPlus) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
Deserialize an IntervalTree whose keys use the natural ordering.
deserialize(DataInputPlus, int, Comparator<C>) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
 
deserialize(DataInputPlus, int) - Static method in class org.apache.cassandra.utils.MerkleTree
 
deserialize(DataInputPlus, boolean, int) - Static method in class org.apache.cassandra.utils.MerkleTree
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.MerkleTrees.MerkleTreesSerializer
 
deserialize(DataInputStream, boolean) - Static method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
deserialize(DataInputPlus) - Method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram.HistogramSerializer
 
deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
 
deserializeAndSetField(ByteBuffer, T, int, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractTupleCodec
Deserialize an individual field and set it on an object, as part of deserializing the whole object from a CQL tuple (see TypeCodec.AbstractTupleCodec.deserialize(ByteBuffer, ProtocolVersion)).
deserializeAndSetField(ByteBuffer, T, String, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractUDTCodec
Deserialize an individual field and set it on an object, as part of deserializing the whole object from a CQL UDT (see TypeCodec.AbstractUDTCodec.deserialize(ByteBuffer, ProtocolVersion)).
deserializeEvent(ByteBuf, ProtocolVersion) - Static method in class org.apache.cassandra.transport.Event.SchemaChange
 
deserializeFirstLastKey(DataInputStream, IPartitioner) - Method in class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
Deserializes the first and last key stored in the summary Only for use by offline tools like SSTableMetadataViewer, otherwise SSTable.first/last should be used.
deserializeForCache(DataInputPlus) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
 
deserializeForCache(DataInputPlus) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
 
deserializeForMessaging(DataInputPlus, TableMetadata, ColumnFilter, boolean) - Method in class org.apache.cassandra.db.SerializationHeader.Serializer
 
deserializeForNativeProtocol(V, ValueAccessor<V>, ProtocolVersion) - Method in class org.apache.cassandra.serializers.CollectionSerializer
 
deserializeForNativeProtocol(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.serializers.CollectionSerializer
 
deserializeForNativeProtocol(V, ValueAccessor<V>, ProtocolVersion) - Method in class org.apache.cassandra.serializers.ListSerializer
 
deserializeForNativeProtocol(I, ValueAccessor<I>, ProtocolVersion) - Method in class org.apache.cassandra.serializers.MapSerializer
 
deserializeForNativeProtocol(V, ValueAccessor<V>, ProtocolVersion) - Method in class org.apache.cassandra.serializers.SetSerializer
 
deserializeHeader(TableMetadata, ColumnFilter, DataInputPlus, int, DeserializationHelper.Flag) - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
 
deserializeMarkerBody(DataInputPlus, SerializationHeader, ClusteringBoundOrBoundary<?>) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
deserializeNextBound() - Method in class org.apache.cassandra.db.ClusteringPrefix.Deserializer
 
deserializeNextClustering() - Method in class org.apache.cassandra.db.ClusteringPrefix.Deserializer
 
deserializeNoBoxing(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveBooleanCodec
 
deserializeNoBoxing(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveByteCodec
 
deserializeNoBoxing(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveDoubleCodec
 
deserializeNoBoxing(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveFloatCodec
 
deserializeNoBoxing(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveIntCodec
 
deserializeNoBoxing(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveLongCodec
 
deserializeNoBoxing(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveShortCodec
 
deserializePositionAndSkip(DataInputPlus) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
 
deserializePositionAndSkip(DataInputPlus) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
 
Deserializer(ClusteringComparator, DataInputPlus, SerializationHeader) - Constructor for class org.apache.cassandra.db.ClusteringPrefix.Deserializer
 
deserializer - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
 
deserializer - Variable in enum org.apache.cassandra.db.filter.ClusteringIndexFilter.Kind
 
Deserializer() - Constructor for class org.apache.cassandra.db.filter.RowFilter.UserExpression.Deserializer
 
deserializeRowBody(DataInputPlus, SerializationHeader, DeserializationHelper, int, int, Row.Builder) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
deserializeSize(DataInput) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
 
deserializeStaticRow(DataInputPlus, SerializationHeader, DeserializationHelper) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
deserializeSubset(Columns, DataInputPlus) - Method in class org.apache.cassandra.db.Columns.Serializer
 
deserializeTombstonesOnly(FileDataInput, SerializationHeader, DeserializationHelper) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
deserializeValues(DataInputPlus, ClusteringPrefix.Kind, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.ClusteringBoundOrBoundary.Serializer
 
destroy() - Method in class org.apache.cassandra.service.CassandraDaemon
Clean up all resources obtained during the lifetime of the daemon.
destroy() - Method in class org.apache.cassandra.service.NativeTransportService
Ultimately stops servers and closes all resources.
destroyClientTransports() - Method in class org.apache.cassandra.service.CassandraDaemon
 
detail - Variable in exception org.apache.cassandra.exceptions.FunctionExecutionException
 
dfile - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
dfile - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
dfile - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
dfile(FileHandle) - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
diagnostic_events_enabled - Variable in class org.apache.cassandra.config.Config
 
DiagnosticEvent - Class in org.apache.cassandra.diag
Base class for internally emitted events used for diagnostics and testing.
DiagnosticEvent() - Constructor for class org.apache.cassandra.diag.DiagnosticEvent
 
DiagnosticEventAuditLogger - Class in org.apache.cassandra.audit
 
DiagnosticEventAuditLogger(Map<String, String>) - Constructor for class org.apache.cassandra.audit.DiagnosticEventAuditLogger
 
DiagnosticEventMemoryStore - Class in org.apache.cassandra.diag.store
Simple on-heap memory store that allows to buffer and retrieve a fixed number of events.
DiagnosticEventMemoryStore() - Constructor for class org.apache.cassandra.diag.store.DiagnosticEventMemoryStore
 
DiagnosticEventPersistence - Class in org.apache.cassandra.diag
Manages storing and retrieving events based on enabled DiagnosticEventStore implementation.
DiagnosticEventPersistence() - Constructor for class org.apache.cassandra.diag.DiagnosticEventPersistence
 
diagnosticEventsEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
DiagnosticEventService - Class in org.apache.cassandra.diag
Service for publishing and consuming DiagnosticEvents.
DiagnosticEventServiceMBean - Interface in org.apache.cassandra.diag
Provides JMX enabled attributes and operations implemented by DiagnosticEventService.
DiagnosticEventStore<T extends java.lang.Comparable<T>> - Interface in org.apache.cassandra.diag.store
Enables storing and retrieving DiagnosticEvents.
DiagnosticSnapshotService - Class in org.apache.cassandra.utils
Provides a means to take snapshots when triggered by anomalous events or when the breaking of invariants is detected.
diff(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Determine the count relationship between two contexts.
diff(RowDiffListener, Row, Row...) - Static method in class org.apache.cassandra.db.rows.Rows
Given the result (merged) of merging multiple inputs, signals the difference between each input and merged to diffListener.
Diff<T extends java.lang.Iterable,S> - Class in org.apache.cassandra.schema
 
diff - Variable in class org.apache.cassandra.schema.Schema.TransformationResult
 
Diff() - Constructor for class org.apache.cassandra.tools.JMXTool.Diff
 
Diff.Altered<T> - Class in org.apache.cassandra.schema
 
difference() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
 
Difference - Enum in org.apache.cassandra.schema
 
difference(MerkleTree, MerkleTree) - Static method in class org.apache.cassandra.utils.MerkleTree
 
difference(MerkleTrees, MerkleTrees) - Static method in class org.apache.cassandra.utils.MerkleTrees
Get the differences between the two sets of MerkleTrees.
DifferenceHolder - Class in org.apache.cassandra.repair.asymmetric
Just holds all differences between the hosts involved in a repair
DifferenceHolder(List<TreeResponse>) - Constructor for class org.apache.cassandra.repair.asymmetric.DifferenceHolder
 
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(InetAddressAndPort) - Constructor for class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
 
digest(Digest) - Method in interface org.apache.cassandra.db.ClusteringPrefix
Adds the data of this clustering prefix to the provided Digest instance.
digest(Digest) - Method in class org.apache.cassandra.db.Columns
 
digest(Digest) - Method in class org.apache.cassandra.db.DeletionTime
 
Digest - Class in org.apache.cassandra.db
 
digest() - Method in class org.apache.cassandra.db.Digest
 
digest(Digest) - Method in class org.apache.cassandra.db.LivenessInfo
Adds this liveness information to the provided digest.
digest(byte[], int, int, Digest) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
digest(ByteBuffer, int, int, Digest) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
digest(V, int, int, Digest) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
updates with bytes from the contents of starting at offset
digest(V, Digest) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
updates with te contents of
digest(UnfilteredPartitionIterator, Digest, int) - Static method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators
Digests the the provided iterator.
digest(ReadCommand) - Method in class org.apache.cassandra.db.ReadResponse
 
digest(Digest) - Method in class org.apache.cassandra.db.rows.AbstractCell
 
digest(Digest) - Method in class org.apache.cassandra.db.rows.AbstractRow
 
digest(Digest) - Method in class org.apache.cassandra.db.rows.CellPath
 
digest(Digest) - Method in class org.apache.cassandra.db.rows.ColumnData
Adds the data to the provided digest.
digest(Digest, ColumnData) - Static method in class org.apache.cassandra.db.rows.ColumnData
 
digest(Digest) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
digest(Digest) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
digest(Digest) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
digest(Digest) - Method in class org.apache.cassandra.db.rows.Row.Deletion
 
digest(RowIterator, Digest) - Static method in class org.apache.cassandra.db.rows.RowIterators
 
digest(Digest) - Method in interface org.apache.cassandra.db.rows.Unfiltered
Digest the atom using the provided Digest.
digest(UnfilteredRowIterator, Digest, int) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
Digests the partition represented by the provided iterator.
DIGEST - Static variable in class org.apache.cassandra.io.sstable.Component
 
digestHex - Variable in class org.apache.cassandra.service.reads.DigestResolver.DigestResolverDebugResult
 
digestResolver - Variable in class org.apache.cassandra.service.reads.AbstractReadExecutor
 
DigestResolver<E extends Endpoints<E>,P extends ReplicaPlan.ForRead<E>> - Class in org.apache.cassandra.service.reads
 
DigestResolver(ReadCommand, ReplicaPlan.Shared<E, P>, long) - Constructor for class org.apache.cassandra.service.reads.DigestResolver
 
DigestResolver.DigestResolverDebugResult - Class in org.apache.cassandra.service.reads
 
digests - Variable in class org.apache.cassandra.service.reads.repair.RepairedDataTracker
 
digestVersion() - Method in class org.apache.cassandra.db.ReadCommand
If the query is a digest one, the requested digest version.
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.compaction.writers.CompactionAwareWriter
 
Directories - Class in org.apache.cassandra.db
Encapsulate handling of paths to the data files.
Directories(TableMetadata) - Constructor for class org.apache.cassandra.db.Directories
 
Directories(TableMetadata, Collection<Directories.DataDirectory>) - Constructor for class org.apache.cassandra.db.Directories
 
Directories(TableMetadata, Directories.DataDirectory[]) - Constructor for class org.apache.cassandra.db.Directories
Create Directories of given ColumnFamily.
directories - Variable in class org.apache.cassandra.db.DiskBoundaries
 
Directories.DataDirectories - Class in org.apache.cassandra.db
Data directories used to store keyspace data.
Directories.DataDirectory - Class in org.apache.cassandra.db
 
Directories.FileAction - Enum in org.apache.cassandra.db
 
Directories.FileType - Enum in org.apache.cassandra.db
The type of files that can be listed by SSTableLister, we never return txn logs, use LifecycleTransaction.getFiles() if you need txn logs.
Directories.OnTxnErr - Enum in org.apache.cassandra.db
How to handle a failure to read a txn log file.
Directories.SnapshotSizeDetails - Class in org.apache.cassandra.db
 
Directories.SSTableLister - Class in org.apache.cassandra.db
 
directory - Variable in class org.apache.cassandra.io.sstable.Descriptor
canonicalized path to the directory where SSTable resides
directory - Variable in class org.apache.cassandra.tools.LoaderOptions
 
DirectorySizeCalculator - Class in org.apache.cassandra.utils
Walks directory recursively, summing up total contents of files within.
DirectorySizeCalculator(File) - Constructor for class org.apache.cassandra.utils.DirectorySizeCalculator
 
dirtyString() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
disable() - Method in class org.apache.cassandra.db.compaction.CompactionLogger
 
disable() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
DISABLE_THREAD_VALIDATION - Static variable in class org.apache.cassandra.gms.Gossiper.Props
 
disableAuditLog() - Method in class org.apache.cassandra.audit.AuditLogManager
Disables AuditLog, designed to be invoked only via JMX/ Nodetool, not from anywhere else in the codepath.
disableAuditLog() - Method in class org.apache.cassandra.service.StorageService
 
disableAuditLog() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
disableAuditLog() - Method in class org.apache.cassandra.tools.NodeProbe
 
DisableAuditLog - Class in org.apache.cassandra.tools.nodetool
 
DisableAuditLog() - Constructor for class org.apache.cassandra.tools.nodetool.DisableAuditLog
 
disableAutoCompaction() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
disableAutoCompaction() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
disableAutoCompaction(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
disableAutoCompaction(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
disableAutoCompaction(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
DisableAutoCompaction - Class in org.apache.cassandra.tools.nodetool
 
DisableAutoCompaction() - Constructor for class org.apache.cassandra.tools.nodetool.DisableAutoCompaction
 
DisableBackup - Class in org.apache.cassandra.tools.nodetool
 
DisableBackup() - Constructor for class org.apache.cassandra.tools.nodetool.DisableBackup
 
DisableBinary - Class in org.apache.cassandra.tools.nodetool
 
DisableBinary() - Constructor for class org.apache.cassandra.tools.nodetool.DisableBinary
 
disableCheckForDuplicateRowsDuringCompaction() - Method in class org.apache.cassandra.service.StorageProxy
 
disableCheckForDuplicateRowsDuringCompaction() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
disableCheckForDuplicateRowsDuringReads() - Method in class org.apache.cassandra.service.StorageProxy
 
disableCheckForDuplicateRowsDuringReads() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
disabled() - Static method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
disableDiagnostics() - Method in class org.apache.cassandra.diag.DiagnosticEventService
 
disableDiagnostics() - Method in interface org.apache.cassandra.diag.DiagnosticEventServiceMBean
Kill switch for disabling all events immediately, without restarting the node.
disableEarlyOpeningForTests - Static variable in class org.apache.cassandra.io.sstable.SSTableRewriter
 
disableEventPersistence(String) - Method in class org.apache.cassandra.diag.DiagnosticEventPersistence
 
disableEventPersistence(String) - Method in class org.apache.cassandra.diag.DiagnosticEventService
 
disableEventPersistence(String) - Method in interface org.apache.cassandra.diag.DiagnosticEventServiceMBean
Stop storing events.
DisableFullQueryLog - Class in org.apache.cassandra.tools.nodetool
 
DisableFullQueryLog() - Constructor for class org.apache.cassandra.tools.nodetool.DisableFullQueryLog
 
DisableGossip - Class in org.apache.cassandra.tools.nodetool
 
DisableGossip() - Constructor for class org.apache.cassandra.tools.nodetool.DisableGossip
 
DisableHandoff - Class in org.apache.cassandra.tools.nodetool
 
DisableHandoff() - Constructor for class org.apache.cassandra.tools.nodetool.DisableHandoff
 
disableHintedHandoff() - Method in class org.apache.cassandra.tools.NodeProbe
 
disableHintsForDC(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
disableHintsForDC(String) - Method in class org.apache.cassandra.service.StorageProxy
 
disableHintsForDC(String) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
disableHintsForDC(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
DisableHintsForDC - Class in org.apache.cassandra.tools.nodetool
 
DisableHintsForDC() - Constructor for class org.apache.cassandra.tools.nodetool.DisableHintsForDC
 
disableNativeTransportOldProtocolVersions() - Method in class org.apache.cassandra.service.StorageService
 
disableNativeTransportOldProtocolVersions() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
disableOldProtocolVersions() - Method in class org.apache.cassandra.tools.NodeProbe
 
DisableOldProtocolVersions - Class in org.apache.cassandra.tools.nodetool
 
DisableOldProtocolVersions() - Constructor for class org.apache.cassandra.tools.nodetool.DisableOldProtocolVersions
 
disableRepairedDataTrackingForPartitionReads() - Method in class org.apache.cassandra.service.StorageProxy
 
disableRepairedDataTrackingForPartitionReads() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
disableRepairedDataTrackingForRangeReads() - Method in class org.apache.cassandra.service.StorageProxy
 
disableRepairedDataTrackingForRangeReads() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
disableReportingUnconfirmedRepairedDataMismatches() - Method in class org.apache.cassandra.service.StorageProxy
 
disableReportingUnconfirmedRepairedDataMismatches() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
disableSnapshotOnDuplicateRowDetection() - Method in class org.apache.cassandra.service.StorageProxy
 
disableSnapshotOnDuplicateRowDetection() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
disableSnapshotOnRepairedDataMismatch() - Method in class org.apache.cassandra.service.StorageProxy
 
disableSnapshotOnRepairedDataMismatch() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
disableTombstoneCompactions - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
DisallowedDirectories - Class in org.apache.cassandra.db
 
DisallowedDirectoriesMBean - Interface in org.apache.cassandra.db
 
discard(CommitLogSegment, boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerCDC
 
discard(CommitLogSegment, boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerStandard
 
discard() - Method in class org.apache.cassandra.net.AsyncChannelOutputPlus
Discard any buffered data, and the buffers that contain it.
discard() - Method in class org.apache.cassandra.net.AsyncMessageOutputPlus
Discard any buffered data, and the buffers that contain it.
discard() - Method in class org.apache.cassandra.net.AsyncStreamingOutputPlus
Discard any buffered data, and the buffers that contain it.
discard() - Method in class org.apache.cassandra.net.FrameDecoder
For use by InboundMessageHandler (or other upstream handlers) that want to permanently stop receiving frames, e.g.
discardCompletedSegments(TableId, CommitLogPosition, CommitLogPosition) - 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(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Lists.Discarder
 
Discarder(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Discarder
 
DiscarderByIndex(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Lists.DiscarderByIndex
 
DiscarderByKey(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Maps.DiscarderByKey
 
discardMemtable(Memtable) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
discardSSTables(long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Discard all SSTables that were created before given timestamp.
discardStream(IncomingStream) - Method in class org.apache.cassandra.db.streaming.CassandraStreamReceiver
 
discardStream(IncomingStream) - Method in interface org.apache.cassandra.streaming.StreamReceiver
This is called when we've received stream data we can't add to the received set for some reason, usually when we've received data for a session which has been closed.
discoverComponentsFor(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTable
 
disk_access_mode - Variable in class org.apache.cassandra.config.Config
 
disk_failure_policy - Variable in class org.apache.cassandra.config.Config
 
disk_optimization_estimate_percentile - Variable in class org.apache.cassandra.config.Config
 
disk_optimization_page_cross_chance - Variable in class org.apache.cassandra.config.Config
 
disk_optimization_strategy - Variable in class org.apache.cassandra.config.Config
 
DiskBoundaries - Class in org.apache.cassandra.db
 
DiskBoundaries(ColumnFamilyStore, Directories.DataDirectory[], int) - Constructor for class org.apache.cassandra.db.DiskBoundaries
 
DiskBoundaries(ColumnFamilyStore, Directories.DataDirectory[], List<PartitionPosition>, long, int) - Constructor for class org.apache.cassandra.db.DiskBoundaries
 
DiskBoundaryManager - Class in org.apache.cassandra.db
 
DiskBoundaryManager() - Constructor for class org.apache.cassandra.db.DiskBoundaryManager
 
diskHeadAvailable - Variable in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
DiskOptimizationStrategy - Interface in org.apache.cassandra.io.util
 
diskTailAvailable - Variable in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
dispatch(Channel, Message.Request, Dispatcher.FlushItemConverter) - Method in class org.apache.cassandra.transport.Dispatcher
 
Dispatcher - Class in org.apache.cassandra.transport
 
Dispatcher(boolean) - Constructor for class org.apache.cassandra.transport.Dispatcher
 
dispatcher(boolean) - Method in class org.apache.cassandra.transport.PipelineConfigurator
 
DISTINCT_NONE - Static variable in class org.apache.cassandra.db.filter.DataLimits
 
distinctLimits(int) - Static method in class org.apache.cassandra.db.filter.DataLimits
 
DISTRIBUTED_KEYSPACE_NAME - Static variable in class org.apache.cassandra.schema.SchemaConstants
 
divide(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteType
 
divide(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
divide(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
divide(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
divide(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
 
divide(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
divide(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
divide(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
 
divide(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.NumberType
Divides the left argument by the right one.
divide(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ShortType
 
doAbort(Throwable) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
doAbort(Throwable) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
undo all of the changes made by this transaction, resetting the state to its original form
doAbort(Throwable) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter.TransactionalProxy
 
doAbort(Throwable) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
doAbort(Throwable) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
doAbort(Throwable) - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
 
doAbort(Throwable) - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter.TransactionalProxy
 
doAbort(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter.TransactionalProxy
 
doAbort(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
 
doAccept(T) - Method in interface org.apache.cassandra.utils.FailingConsumer
 
doCommit(Throwable) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
doCommit(Throwable) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
point of no return: commit all changes, but leave all readers marked as compacting
doCommit(Throwable) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter.TransactionalProxy
 
doCommit(Throwable) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
doCommit(Throwable) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
doCommit(Throwable) - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
 
doCommit(Throwable) - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter.TransactionalProxy
 
doCommit(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter.TransactionalProxy
 
doCommit(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
 
doCompute() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
doFlush(int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
doFlush(int) - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
doFlush(int) - Method in class org.apache.cassandra.io.util.DataOutputBufferFixed
 
doFlush(int) - Method in class org.apache.cassandra.io.util.SequentialWriter
 
doFlush(int) - Method in class org.apache.cassandra.net.AsyncChannelOutputPlus
 
doFlush(int) - Method in class org.apache.cassandra.net.AsyncMessageOutputPlus
 
doFlush(int) - Method in class org.apache.cassandra.net.AsyncStreamingOutputPlus
 
doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
 
doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
 
doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.INRestriction
 
doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.NotNullRestriction
 
doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
 
doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
 
doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
 
doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQRestriction
 
doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.INRestriction
 
doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IsNotNullRestriction
 
doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
 
doMergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
 
doMergeWith(TokenRestriction) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
Merges this restriction with the specified TokenRestriction.
doMergeWith(TokenRestriction) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQRestriction
 
doMergeWith(TokenRestriction) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.SliceRestriction
 
doneWithNonLocalSession(TraceState) - Method in class org.apache.cassandra.tracing.Tracing
 
doOnClose(PartitionIterator, Runnable) - Static method in class org.apache.cassandra.db.partitions.PartitionIterators
Wraps the provided iterator to run a specified action on close.
doPostCleanup(Throwable) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
doPostCleanup(Throwable) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
doPostCleanup(Throwable) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
doPostCleanup(Throwable) - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
 
doPostCleanup(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
perform an exception-safe post-abort cleanup
doPreCleanup(Throwable) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter.TransactionalProxy
 
doPreCleanup(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter.TransactionalProxy
 
doPreCleanup(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
perform an exception-safe pre-abort/commit cleanup; this will be run after prepareToCommit (so before commit), and before abort
doPrepare() - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
doPrepare() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
doPrepare() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter.TransactionalProxy
 
doPrepare() - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
doPrepare() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
doPrepare() - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
 
doPrepare() - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter.TransactionalProxy
 
doPrepare() - Method in class org.apache.cassandra.io.util.SequentialWriter.TransactionalProxy
 
doPrepare(Commit) - Static method in class org.apache.cassandra.service.paxos.PrepareVerbHandler
 
doPrepare() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
Do any preparatory work prior to commit.
doPropose(Commit) - Static method in class org.apache.cassandra.service.paxos.ProposeVerbHandler
 
doShadowRound() - Method in class org.apache.cassandra.gms.Gossiper
 
doShadowRound(Set<InetAddressAndPort>) - Method in class org.apache.cassandra.gms.Gossiper
Do a single 'shadow' round of gossip by retrieving endpoint states that will be stored exclusively in the map return value, instead of endpointStateMap.
DOUBLE_SIZE - Static variable in class org.apache.cassandra.db.TypeSizes
 
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(Message<UUID>) - Method in class org.apache.cassandra.batchlog.BatchRemoveVerbHandler
 
doVerb(Message<Batch>) - Method in class org.apache.cassandra.batchlog.BatchStoreVerbHandler
 
doVerb(Message<CounterMutation>) - Method in class org.apache.cassandra.db.CounterMutationVerbHandler
 
doVerb(Message<Mutation>) - Method in class org.apache.cassandra.db.MutationVerbHandler
 
doVerb(Message<ReadCommand>) - Method in class org.apache.cassandra.db.ReadCommandVerbHandler
 
doVerb(Message<Mutation>) - Method in class org.apache.cassandra.db.ReadRepairVerbHandler
 
doVerb(Message<TruncateRequest>) - Method in class org.apache.cassandra.db.TruncateVerbHandler
 
doVerb(Message<GossipDigestAck2>) - Method in class org.apache.cassandra.gms.GossipDigestAck2VerbHandler
 
doVerb(Message<GossipDigestAck>) - Method in class org.apache.cassandra.gms.GossipDigestAckVerbHandler
 
doVerb(Message<GossipDigestSyn>) - Method in class org.apache.cassandra.gms.GossipDigestSynVerbHandler
 
doVerb(Message) - Method in class org.apache.cassandra.gms.GossipShutdownVerbHandler
 
doVerb(Message<T>) - Method in class org.apache.cassandra.gms.GossipVerbHandler
 
doVerb(Message<HintMessage>) - Method in class org.apache.cassandra.hints.HintVerbHandler
 
doVerb(Message<T>) - Method in interface org.apache.cassandra.net.IVerbHandler
This method delivers a message to the implementing class (if the implementing class was registered by a call to MessagingService.registerVerbHandlers).
doVerb(Message<RepairMessage>) - Method in class org.apache.cassandra.repair.RepairMessageVerbHandler
 
doVerb(Message<NoPayload>) - Method in class org.apache.cassandra.schema.SchemaPullVerbHandler
 
doVerb(Message<Collection<Mutation>>) - Method in class org.apache.cassandra.schema.SchemaPushVerbHandler
 
doVerb(Message<NoPayload>) - Method in class org.apache.cassandra.schema.SchemaVersionVerbHandler
 
doVerb(Message<NoPayload>) - Method in class org.apache.cassandra.service.EchoVerbHandler
 
doVerb(Message<Commit>) - Method in class org.apache.cassandra.service.paxos.CommitVerbHandler
 
doVerb(Message<Commit>) - Method in class org.apache.cassandra.service.paxos.PrepareVerbHandler
 
doVerb(Message<Commit>) - Method in class org.apache.cassandra.service.paxos.ProposeVerbHandler
 
doVerb(Message<SnapshotCommand>) - Method in class org.apache.cassandra.service.SnapshotVerbHandler
 
doVerb(Message) - Method in class org.apache.cassandra.streaming.ReplicationDoneVerbHandler
 
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(boolean) - Method in class org.apache.cassandra.service.StorageService
 
drain() - Method in interface org.apache.cassandra.service.StorageServiceMBean
makes node unavailable for writes, flushes memtables and replays commitlog.
drain() - Method in class org.apache.cassandra.tools.NodeProbe
 
Drain - Class in org.apache.cassandra.tools.nodetool
 
Drain() - Constructor for class org.apache.cassandra.tools.nodetool.Drain
 
drainTo(Collection<? super T>) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
drainTo(Collection<? super T>, int) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
DRIVER_NAME - Static variable in class org.apache.cassandra.transport.ConnectedClient
 
DRIVER_NAME - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
 
DRIVER_VERSION - Static variable in class org.apache.cassandra.transport.ConnectedClient
 
DRIVER_VERSION - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
 
DriverException - Exception in org.apache.cassandra.cql3.functions.types.exceptions
Top level class for exceptions thrown by the driver.
DriverInternalError - Exception in org.apache.cassandra.cql3.functions.types.exceptions
An unexpected error happened internally.
DriverInternalError(String) - Constructor for exception org.apache.cassandra.cql3.functions.types.exceptions.DriverInternalError
 
DriverInternalError(String, Throwable) - Constructor for exception org.apache.cassandra.cql3.functions.types.exceptions.DriverInternalError
 
driverName() - Method in class org.apache.cassandra.transport.ConnectedClient
 
driverType(AbstractType) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
Returns the DataType for the C* internal type.
driverTypeFromAbstractType(String) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
 
driverTypes(List<AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
Construct an array containing the DataTypes for the C* internal types.
driverVersion() - Method in class org.apache.cassandra.transport.ConnectedClient
 
drop(RoleResource) - Method in class org.apache.cassandra.auth.AllowAllNetworkAuthorizer
 
drop(RoleResource) - Method in class org.apache.cassandra.auth.CassandraNetworkAuthorizer
 
drop(RoleResource) - Method in interface org.apache.cassandra.auth.INetworkAuthorizer
Called when a role is deleted, so any corresponding network auth data can also be cleaned up
drop(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
 
DropAggregateStatement - Class in org.apache.cassandra.cql3.statements.schema
 
DropAggregateStatement(String, String, List<CQL3Type.Raw>, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropAggregateStatement
 
DropAggregateStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
dropAllIndexes() - Method in class org.apache.cassandra.index.SecondaryIndexManager
Remove all indexes
dropCf(TableId) - Method in class org.apache.cassandra.db.Keyspace
 
dropCompactStorage() - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
 
dropData(Collection<SSTableReader>) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
dropData(long) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
dropData(Collection<SSTableReader>) - Method in class org.apache.cassandra.index.sasi.conf.DataTracker
 
dropData(long) - Method in class org.apache.cassandra.index.sasi.conf.DataTracker
 
DropFunctionStatement - Class in org.apache.cassandra.cql3.statements.schema
 
DropFunctionStatement(String, String, Collection<CQL3Type.Raw>, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropFunctionStatement
 
DropFunctionStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
DropIndexStatement - Class in org.apache.cassandra.cql3.statements.schema
 
DropIndexStatement(String, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropIndexStatement
 
DropIndexStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
DropKeyspaceStatement - Class in org.apache.cassandra.cql3.statements.schema
 
DropKeyspaceStatement(String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropKeyspaceStatement
 
DropKeyspaceStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
dropPageCache(long) - Method in class org.apache.cassandra.io.util.FileHandle
Drop page cache from start to given before.
dropped - Variable in class org.apache.cassandra.metrics.DroppedMessageMetrics
Number of dropped messages
dropped() - Method in class org.apache.cassandra.net.OutboundConnection
 
dropped - Variable in class org.apache.cassandra.schema.Diff
 
dropped - Variable in class org.apache.cassandra.schema.Keyspaces.KeyspacesDiff
 
DROPPED_COLUMNS - Static variable in class org.apache.cassandra.schema.SchemaKeyspace
 
DroppedColumn - Class in org.apache.cassandra.schema
 
DroppedColumn(ColumnMetadata, long) - Constructor for class org.apache.cassandra.schema.DroppedColumn
 
droppedColumns(Map<ByteBuffer, DroppedColumn>) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
droppedColumns - Variable in class org.apache.cassandra.schema.TableMetadata
 
DroppedMessageMetrics - Class in org.apache.cassandra.metrics
Metrics for dropped messages by verb.
DroppedMessageMetrics(Verb) - Constructor for class org.apache.cassandra.metrics.DroppedMessageMetrics
 
droppedMutations - Variable in class org.apache.cassandra.metrics.TableMetrics
Deprecated.
droppedMutations - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
droppedTime - Variable in class org.apache.cassandra.schema.DroppedColumn
 
dropRole(AuthenticatedUser, RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
dropRole(AuthenticatedUser, RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
Called during execution of DROP ROLE statement, as well we removing any main record of the role from the system this implies that we want to revoke this role from all other roles that it has been granted to.
DropRoleStatement - Class in org.apache.cassandra.cql3.statements
 
DropRoleStatement(RoleName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropRoleStatement
 
dropSSTables() - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
dropSSTables(Throwable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
dropSSTables(Predicate<SSTableReader>, OperationType, Throwable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
removes all sstables that are not busy compacting.
dropSSTablesIfInvalid(Throwable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
DropTableStatement - Class in org.apache.cassandra.cql3.statements.schema
 
DropTableStatement(String, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropTableStatement
 
DropTableStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
DropTriggerStatement - Class in org.apache.cassandra.cql3.statements.schema
 
DropTriggerStatement(String, String, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropTriggerStatement
 
DropTriggerStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
DropTypeStatement - Class in org.apache.cassandra.cql3.statements.schema
 
DropTypeStatement(String, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropTypeStatement
 
DropTypeStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
dropView(String) - Method in class org.apache.cassandra.db.view.ViewManager
Stops the building of the specified view, no-op if it isn't building.
DropViewStatement - Class in org.apache.cassandra.cql3.statements.schema
 
DropViewStatement(String, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropViewStatement
 
DropViewStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
dryRun() - Method in class org.apache.cassandra.io.sstable.SSTableHeaderFix.Builder
Only validate and prepare fix, but do not write updated (fixed) sstable serialization-headers.
dryRun - Variable in class org.apache.cassandra.io.sstable.SSTableHeaderFix
 
dst - Variable in class org.apache.cassandra.repair.messages.SyncRequest
 
Dump() - Constructor for class org.apache.cassandra.tools.JMXTool.Dump
 
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
 
dumpMemtable() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Drops current memtable without flushing to disk.
dumpMemtables() - Method in class org.apache.cassandra.db.view.TableViews
 
dumpTimings(String) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
dumpTimings(String) - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
duplicate() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
DUPLICATE_ROWS_DETECTED_SNAPSHOT_PREFIX - Static variable in class org.apache.cassandra.utils.DiagnosticSnapshotService
 
duplicateDirectByteBuffer(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
DuplicateRowChecker - Class in org.apache.cassandra.db.transform
 
duplicateRows(TableMetadata, Iterable<InetAddressAndPort>) - Static method in class org.apache.cassandra.utils.DiagnosticSnapshotService
 
durableWrites - Variable in class org.apache.cassandra.schema.KeyspaceParams
 
duration(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
 
Duration - Class in org.apache.cassandra.cql3
Represents a duration.
duration() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the Duration type, introduced in Cassandra 3.10.
Duration - Class in org.apache.cassandra.cql3.functions.types
Represents a duration.
duration() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Returns the default codec for the Duration type.
DurationSerializer - Class in org.apache.cassandra.serializers
 
DurationSerializer() - Constructor for class org.apache.cassandra.serializers.DurationSerializer
 
DurationType - Class in org.apache.cassandra.db.marshal
Represents a duration.
duringCompaction(UnfilteredPartitionIterator, OperationType) - Static method in class org.apache.cassandra.db.transform.DuplicateRowChecker
 
duringRead(PartitionIterator, List<InetAddressAndPort>) - Static method in class org.apache.cassandra.db.transform.DuplicateRowChecker
 
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
 
DynamicList<E> - Class in org.apache.cassandra.utils
 
DynamicList(int) - Constructor for class org.apache.cassandra.utils.DynamicList
 
DynamicList.Node<E> - Class in org.apache.cassandra.utils
 
DynamicTokenTreeBuilder - Class in org.apache.cassandra.index.sasi.disk
 
DynamicTokenTreeBuilder() - Constructor for class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
 
DynamicTokenTreeBuilder(TokenTreeBuilder) - Constructor for class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
 
DynamicTokenTreeBuilder(SortedMap<Long, LongSet>) - Constructor for class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
 

E

eachQuorumForRead(AbstractReplicationStrategy) - Static method in enum org.apache.cassandra.db.ConsistencyLevel
 
eachQuorumForWrite(AbstractReplicationStrategy, Endpoints<?>) - Static method in enum org.apache.cassandra.db.ConsistencyLevel
 
Ec2MultiRegionSnitch - Class in org.apache.cassandra.locator
1) Snitch will automatically set the public IP by querying the AWS API 2) Snitch will set the private IP as a Gossip application state.
Ec2MultiRegionSnitch() - Constructor for class org.apache.cassandra.locator.Ec2MultiRegionSnitch
 
Ec2Snitch - Class in org.apache.cassandra.locator
A snitch that assumes an EC2 region is a DC and an EC2 availability_zone is a rack.
Ec2Snitch() - Constructor for class org.apache.cassandra.locator.Ec2Snitch
 
Ec2Snitch(SnitchProperties) - Constructor for class org.apache.cassandra.locator.Ec2Snitch
 
EchoVerbHandler - Class in org.apache.cassandra.service
 
EchoVerbHandler() - Constructor for class org.apache.cassandra.service.EchoVerbHandler
 
ecsRegion - Variable in class org.apache.cassandra.locator.AlibabaCloudSnitch
 
ecsZone - Variable in class org.apache.cassandra.locator.AlibabaCloudSnitch
 
effectiveOwnership(String) - Method in class org.apache.cassandra.service.StorageService
 
effectiveOwnership(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
effectiveOwnership(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
effectiveOwnershipWithPort(String) - Method in class org.apache.cassandra.service.StorageService
 
effectiveOwnershipWithPort(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
effectiveOwnershipWithPort(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
elapsed() - Method in class org.apache.cassandra.tracing.TraceState
 
elapsedSinceCreated(TimeUnit) - Method in class org.apache.cassandra.net.Message
For how long the message has lived.
elapsedTokens(Token, Range<Token>) - Method in class org.apache.cassandra.dht.Splitter
Computes the number of elapsed tokens from the range start until this token
element - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithElementSelection
 
Element(String, String, BiFunction<KeyspaceMetadata, String, Stream<? extends SchemaElement>>) - Constructor for class org.apache.cassandra.cql3.statements.DescribeStatement.Element
 
element(ColumnMetadata, CellPath) - Static method in class org.apache.cassandra.db.filter.ColumnSubselection
 
element() - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
ElementDeletion(ColumnIdentifier, Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.ElementDeletion
 
ElementDiscarder(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Sets.ElementDiscarder
 
elementKeyspace() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
elementKeyspace() - Method in interface org.apache.cassandra.cql3.SchemaElement
Returns the CQL name of the keyspace to which this schema element belong.
elementKeyspace() - Method in class org.apache.cassandra.db.marshal.UserType
 
elementKeyspace() - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
elementKeyspace() - Method in class org.apache.cassandra.schema.TableMetadata
 
elementKeyspace() - Method in class org.apache.cassandra.schema.ViewMetadata
 
elementKeyspaceQuotedIfNeeded() - Method in interface org.apache.cassandra.cql3.SchemaElement
 
elementName() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
elementName() - Method in interface org.apache.cassandra.cql3.SchemaElement
Returns the CQL name of this schema element.
elementName() - Method in class org.apache.cassandra.db.marshal.UserType
 
elementName() - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
elementName() - Method in class org.apache.cassandra.schema.TableMetadata
 
elementName() - Method in class org.apache.cassandra.schema.ViewMetadata
 
elementNameQuotedIfNeeded() - Method in interface org.apache.cassandra.cql3.SchemaElement
 
elements - Variable in class org.apache.cassandra.cql3.Lists.Value
 
elements - Variable in class org.apache.cassandra.cql3.Sets.Value
 
elements - Variable in class org.apache.cassandra.cql3.Tuples.DelayedValue
 
elements - Variable in class org.apache.cassandra.cql3.Tuples.Value
 
elements - Variable in class org.apache.cassandra.cql3.UserTypes.Value
 
elements - Variable in class org.apache.cassandra.serializers.ListSerializer
 
elements - Variable in class org.apache.cassandra.serializers.SetSerializer
 
elementType() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
elementType() - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
elementType() - Method in interface org.apache.cassandra.cql3.SchemaElement
Return the schema element type
elementType() - Method in class org.apache.cassandra.db.marshal.UserType
 
elementType() - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
elementType() - Method in class org.apache.cassandra.schema.TableMetadata
 
elementType() - Method in class org.apache.cassandra.schema.ViewMetadata
 
EmbeddedCassandraService - Class in org.apache.cassandra.service
An embedded, in-memory cassandra storage service.
EmbeddedCassandraService() - Constructor for class org.apache.cassandra.service.EmbeddedCassandraService
 
empty(StatementType, TableMetadata) - Static method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Creates a new empty StatementRestrictions.
EMPTY - Static variable in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
empty() - Static method in class org.apache.cassandra.cql3.VariableSpecifications
Returns an empty instance of VariableSpecifications.
empty() - Static method in class org.apache.cassandra.cql3.WhereClause
 
EMPTY - Static variable in interface org.apache.cassandra.db.Clustering
Empty clustering for tables having no clustering columns.
empty() - Static method in class org.apache.cassandra.db.commitlog.IntervalSet
 
empty() - Static method in class org.apache.cassandra.db.compaction.CompactionTasks
 
empty() - Static method in class org.apache.cassandra.db.lifecycle.SSTableIntervalTree
 
EMPTY - Static variable in class org.apache.cassandra.db.LivenessInfo
 
empty() - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
empty() - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
empty() - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
return a value with a length of 0
EMPTY - Static variable in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
empty() - Static method in class org.apache.cassandra.db.ReadExecutionController
 
empty(TableMetadata) - Static method in interface org.apache.cassandra.db.ReadQuery
 
empty() - Static method in class org.apache.cassandra.gms.HeartBeatState
 
EMPTY - Static variable in interface org.apache.cassandra.index.IndexRegistry
An empty IndexRegistry
empty(ChannelProxy) - Static method in class org.apache.cassandra.io.util.MmappedRegions
 
EMPTY - Static variable in interface org.apache.cassandra.io.util.Rebufferer
 
empty(Range<Token>) - Static method in class org.apache.cassandra.locator.EndpointsForRange
 
empty(Token) - Static method in class org.apache.cassandra.locator.EndpointsForToken
 
empty(InetAddressAndPort) - Static method in class org.apache.cassandra.locator.RangesAtEndpoint
 
EMPTY - Static variable in class org.apache.cassandra.metrics.TableMetrics
 
EMPTY - Static variable in class org.apache.cassandra.repair.consistent.RepairedState.Stats
 
EMPTY - Static variable in interface org.apache.cassandra.service.pager.QueryPager
 
empty() - Static method in class org.apache.cassandra.utils.btree.BTree
 
empty(Comparator<? super V>) - Static method in class org.apache.cassandra.utils.btree.BTreeSet
 
EMPTY_ARRAY - Static variable in class org.apache.cassandra.utils.ByteBufferUtil
 
EMPTY_BYTE_ARRAY - Static variable in class org.apache.cassandra.utils.ByteArrayUtil
 
EMPTY_BYTE_BUFFER - Static variable in class org.apache.cassandra.utils.ByteBufferUtil
 
EMPTY_CONDITION - Static variable in interface org.apache.cassandra.cql3.conditions.Conditions
An EMPTY condition
EMPTY_LIST - Static variable in class org.apache.cassandra.locator.AbstractReplicaCollection
 
EMPTY_LONG_ARRAY - Static variable in class org.apache.cassandra.utils.HistogramBuilder
 
EMPTY_PARSER - Static variable in class org.apache.cassandra.db.marshal.TypeParser
 
EMPTY_SIZE - Static variable in class org.apache.cassandra.db.partitions.AtomicBTreePartition
 
EMPTY_STATE - Static variable in class org.apache.cassandra.db.aggregation.GroupingState
 
EMPTY_STATIC_ROW - Static variable in class org.apache.cassandra.db.rows.Rows
 
EMPTY_VALUES_ARRAY - Static variable in class org.apache.cassandra.db.AbstractArrayClusteringPrefix
 
EMPTY_VALUES_ARRAY - Static variable in class org.apache.cassandra.db.AbstractBufferClusteringPrefix
 
EMPTY_VERSION - Static variable in class org.apache.cassandra.gms.HeartBeatState
 
emptyBufferPool() - Method in class org.apache.cassandra.io.util.SimpleCachedBufferPool
Empties the buffer pool.
emptyCommit(DecoratedKey, TableMetadata) - Static method in class org.apache.cassandra.service.paxos.Commit
 
emptyDeletedRow(Clustering<?>, Row.Deletion) - Static method in class org.apache.cassandra.db.rows.BTreeRow
 
EmptyIterators - Class in org.apache.cassandra.db
 
EmptyIterators() - Constructor for class org.apache.cassandra.db.EmptyIterators
 
emptyPartitions - Variable in class org.apache.cassandra.db.compaction.Scrubber.ScrubResult
 
EmptyPartitionsDiscarder - Class in org.apache.cassandra.db.transform
 
EmptyPartitionsDiscarder() - Constructor for class org.apache.cassandra.db.transform.EmptyPartitionsDiscarder
 
emptyResponse() - Method in class org.apache.cassandra.net.Message
Builds a response Message with no payload, and all the right fields inferred from request Message
emptyRow(Clustering<?>) - Static method in class org.apache.cassandra.db.rows.BTreeRow
 
EmptySerializer - Class in org.apache.cassandra.serializers
 
EmptySerializer() - Constructor for class org.apache.cassandra.serializers.EmptySerializer
 
emptySortedSet(Comparator<? super T>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
EmptySSTableScanner(SSTableReader) - Constructor for class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
 
emptyTree() - Static method in class org.apache.cassandra.utils.IntervalTree
 
EmptyType - Class in org.apache.cassandra.db.marshal
A type that only accept empty data.
emptyUpdate(TableMetadata, DecoratedKey) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
Creates a empty immutable partition update.
emptyVersion - Static variable in class org.apache.cassandra.schema.SchemaConstants
 
enable(AuditLogOptions) - Method in class org.apache.cassandra.audit.AuditLogManager
Enables AuditLog, designed to be invoked only via JMX/ Nodetool, not from anywhere else in the codepath.
enable(boolean) - Method in class org.apache.cassandra.cache.ChunkCache
 
enable() - Method in class org.apache.cassandra.db.compaction.CompactionLogger
 
enable() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
enable(Path, String, boolean, int, long, String, int) - Method in class org.apache.cassandra.fql.FullQueryLogger
 
enable_drop_compact_storage - Variable in class org.apache.cassandra.config.Config
 
enable_legacy_ssl_storage_port - Variable in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
enable_materialized_views - Variable in class org.apache.cassandra.config.Config
 
enable_sasi_indexes - Variable in class org.apache.cassandra.config.Config
 
enable_scripted_user_defined_functions - Variable in class org.apache.cassandra.config.Config
 
enable_transient_replication - Variable in class org.apache.cassandra.config.Config
 
enable_user_defined_functions - Variable in class org.apache.cassandra.config.Config
 
enable_user_defined_functions_threads - Variable in class org.apache.cassandra.config.Config
Optionally disable asynchronous UDF execution.
enableActivityNotification(String) - Method in class org.apache.cassandra.tracing.TraceState
Activate notification with provided tag name.
enableAuditLog(String, String, String, String, String, String, String) - Method in class org.apache.cassandra.service.StorageService
 
enableAuditLog(String, Map<String, String>, String, String, String, String, String, String) - Method in class org.apache.cassandra.service.StorageService
 
enableAuditLog(String, Map<String, String>, String, String, String, String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
enableAuditLog(String, String, String, String, String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
enableAuditLog(String, Map<String, String>, String, String, String, String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
enableAuditLog(String, String, String, String, String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
EnableAuditLog - Class in org.apache.cassandra.tools.nodetool
 
EnableAuditLog() - Constructor for class org.apache.cassandra.tools.nodetool.EnableAuditLog
 
enableAutoCompaction() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
enableAutoCompaction(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
used for tests - to be able to check things after a minor compaction
enableAutoCompaction(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
enableAutoCompaction(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
enableAutoCompaction(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
EnableAutoCompaction - Class in org.apache.cassandra.tools.nodetool
 
EnableAutoCompaction() - Constructor for class org.apache.cassandra.tools.nodetool.EnableAutoCompaction
 
EnableBackup - Class in org.apache.cassandra.tools.nodetool
 
EnableBackup() - Constructor for class org.apache.cassandra.tools.nodetool.EnableBackup
 
EnableBinary - Class in org.apache.cassandra.tools.nodetool
 
EnableBinary() - Constructor for class org.apache.cassandra.tools.nodetool.EnableBinary
 
enableCheckForDuplicateRowsDuringCompaction() - Method in class org.apache.cassandra.service.StorageProxy
 
enableCheckForDuplicateRowsDuringCompaction() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
enableCheckForDuplicateRowsDuringReads() - Method in class org.apache.cassandra.service.StorageProxy
 
enableCheckForDuplicateRowsDuringReads() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
enabled - Variable in class org.apache.cassandra.audit.AuditLogOptions
 
enabled - Variable in class org.apache.cassandra.config.EncryptionOptions
 
enabled - Variable in class org.apache.cassandra.config.TransparentDataEncryptionOptions
 
ENABLED - Static variable in class org.apache.cassandra.schema.CompressionParams
 
enableDropCompactStorage() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
enableEventPersistence(String) - Method in class org.apache.cassandra.diag.DiagnosticEventPersistence
 
enableEventPersistence(String) - Method in class org.apache.cassandra.diag.DiagnosticEventService
 
enableEventPersistence(String) - Method in interface org.apache.cassandra.diag.DiagnosticEventServiceMBean
Start storing events to make them available via DiagnosticEventServiceMBean.readEvents(String, Long, int).
EnableFullQueryLog - Class in org.apache.cassandra.tools.nodetool
 
EnableFullQueryLog() - Constructor for class org.apache.cassandra.tools.nodetool.EnableFullQueryLog
 
enableFullQueryLogger(String, String, Boolean, int, long, String, int) - Method in class org.apache.cassandra.service.StorageService
 
enableFullQueryLogger(String, String, Boolean, int, long, String, int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Start the fully query logger.
enableFullQueryLogger(String, String, Boolean, int, long, String, int) - Method in class org.apache.cassandra.tools.NodeProbe
 
EnableGossip - Class in org.apache.cassandra.tools.nodetool
 
EnableGossip() - Constructor for class org.apache.cassandra.tools.nodetool.EnableGossip
 
EnableHandoff - Class in org.apache.cassandra.tools.nodetool
 
EnableHandoff() - Constructor for class org.apache.cassandra.tools.nodetool.EnableHandoff
 
enableHintedHandoff() - Method in class org.apache.cassandra.tools.NodeProbe
 
enableHintsForDC(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
enableHintsForDC(String) - Method in class org.apache.cassandra.service.StorageProxy
 
enableHintsForDC(String) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
enableHintsForDC(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
EnableHintsForDC - Class in org.apache.cassandra.tools.nodetool
 
EnableHintsForDC() - Constructor for class org.apache.cassandra.tools.nodetool.EnableHintsForDC
 
enableNativeTransportOldProtocolVersions() - Method in class org.apache.cassandra.service.StorageService
 
enableNativeTransportOldProtocolVersions() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
enableOldProtocolVersions() - Method in class org.apache.cassandra.tools.NodeProbe
 
EnableOldProtocolVersions - Class in org.apache.cassandra.tools.nodetool
 
EnableOldProtocolVersions() - Constructor for class org.apache.cassandra.tools.nodetool.EnableOldProtocolVersions
 
enableRepairedDataTrackingForPartitionReads() - Method in class org.apache.cassandra.service.StorageProxy
 
enableRepairedDataTrackingForPartitionReads() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
enableRepairedDataTrackingForRangeReads() - Method in class org.apache.cassandra.service.StorageProxy
 
enableRepairedDataTrackingForRangeReads() - Method in interface org.apache.cassandra.service.StorageProxyMBean
Tracking and reporting of variances in the repaired data set across replicas at read time
enableReportingUnconfirmedRepairedDataMismatches() - Method in class org.apache.cassandra.service.StorageProxy
 
enableReportingUnconfirmedRepairedDataMismatches() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
enableScriptedUserDefinedFunctions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
enableScriptedUserDefinedFunctions(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
enableSnapshotOnDuplicateRowDetection() - Method in class org.apache.cassandra.service.StorageProxy
 
enableSnapshotOnDuplicateRowDetection() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
enableSnapshotOnRepairedDataMismatch() - Method in class org.apache.cassandra.service.StorageProxy
 
enableSnapshotOnRepairedDataMismatch() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
enableSSTableDevelopmentTestMode - Static variable in interface org.apache.cassandra.io.sstable.format.SSTableFormat
 
enableUserDefinedFunctions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
enableUserDefinedFunctionsThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
encode(ResultSet, ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.cql3.ResultSet.Codec
 
encode(boolean, ByteBuffer) - Method in class org.apache.cassandra.net.FrameEncoderLZ4
 
encode(T, ByteBuf, ProtocolVersion) - Method in interface org.apache.cassandra.transport.CBCodec
 
encode(ChannelHandlerContext, Envelope, List<Object>) - Method in class org.apache.cassandra.transport.Envelope.Compressor
 
encode(ChannelHandlerContext, Envelope, List<Object>) - Method in class org.apache.cassandra.transport.Envelope.Encoder
 
encode(ProtocolVersion) - Method in class org.apache.cassandra.transport.Message
 
encode(T, ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.transport.messages.UnsupportedMessageCodec
 
encode(ChannelHandlerContext, Message, List) - Method in class org.apache.cassandra.transport.PreV5Handlers.ProtocolEncoder
 
encodedSize(ResultSet, ProtocolVersion) - Method in class org.apache.cassandra.cql3.ResultSet.Codec
 
encodedSize(T, ProtocolVersion) - Method in interface org.apache.cassandra.transport.CBCodec
 
encodedSize(T, ProtocolVersion) - Method in class org.apache.cassandra.transport.messages.UnsupportedMessageCodec
 
encodedUTF8Length(String) - Static method in class org.apache.cassandra.db.TypeSizes
 
encodeExtraBytesToRead(int) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
 
encodeHeader() - Method in class org.apache.cassandra.transport.Envelope
 
encodeHeaderInto(ByteBuffer) - Method in class org.apache.cassandra.transport.Envelope
 
encodeInto(ByteBuffer) - Method in class org.apache.cassandra.transport.Envelope
 
encodeZigZag64(long) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
Encode a ZigZag-encoded 64-bit value.
encodingBuffer - Static variable in class org.apache.cassandra.utils.vint.VIntCoding
 
EncodingStats - Class in org.apache.cassandra.db.rows
Stats used for the encoding of the rows and tombstones of a given source.
EncodingStats(long, int, int) - Constructor for class org.apache.cassandra.db.rows.EncodingStats
 
encodingStats - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
EncodingStats.Collector - Class in org.apache.cassandra.db.rows
 
EncodingStats.Serializer - Class in org.apache.cassandra.db.rows
 
encrypt(ByteBuffer, ByteBuffer, boolean, Cipher) - Static method in class org.apache.cassandra.security.EncryptionUtils
 
encryptAndWrite(ByteBuffer, WritableByteChannel, boolean, Cipher) - Static method in class org.apache.cassandra.security.EncryptionUtils
Encrypt the input data, and writes out to the same input buffer; if the buffer is not big enough, deallocate current, and allocate a large enough buffer.
ENCRYPTED_BLOCK_HEADER_SIZE - Static variable in class org.apache.cassandra.security.EncryptionUtils
 
EncryptedChecksummedDataInput - Class in org.apache.cassandra.hints
 
EncryptedChecksummedDataInput(ChannelProxy, Cipher, ICompressor, long) - Constructor for class org.apache.cassandra.hints.EncryptedChecksummedDataInput
 
EncryptedFileSegmentInputStream - Class in org.apache.cassandra.db.commitlog
Each segment of an encrypted file may contain many encrypted chunks, and each chunk needs to be individually decrypted to reconstruct the full segment.
EncryptedFileSegmentInputStream(String, long, int, int, EncryptedFileSegmentInputStream.ChunkProvider) - Constructor for class org.apache.cassandra.db.commitlog.EncryptedFileSegmentInputStream
 
EncryptedFileSegmentInputStream.ChunkProvider - Interface in org.apache.cassandra.db.commitlog
 
EncryptedHintsWriter - Class in org.apache.cassandra.hints
 
EncryptedHintsWriter(File, HintsDescriptor, File, FileChannel, int, CRC32) - Constructor for class org.apache.cassandra.hints.EncryptedHintsWriter
 
EncryptedSegment - Class in org.apache.cassandra.db.commitlog
Writes encrypted segments to disk.
EncryptedSegment(CommitLog, AbstractCommitLogSegmentManager) - Constructor for class org.apache.cassandra.db.commitlog.EncryptedSegment
 
encryption - Variable in class org.apache.cassandra.net.InboundConnectionSettings
 
encryption - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
encryption() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
encryption(EncryptionOptions) - Method in class org.apache.cassandra.transport.SimpleClient.Builder
 
ENCRYPTION_CIPHER - Static variable in class org.apache.cassandra.security.EncryptionContext
 
ENCRYPTION_IV - Static variable in class org.apache.cassandra.security.EncryptionContext
 
ENCRYPTION_KEY_ALIAS - Static variable in class org.apache.cassandra.security.EncryptionContext
 
encryptionConfig() - Method in class org.apache.cassandra.transport.PipelineConfigurator
 
EncryptionContext - Class in org.apache.cassandra.security
A (largely) immutable wrapper for the application-wide file-level encryption settings.
EncryptionContext() - Constructor for class org.apache.cassandra.security.EncryptionContext
 
EncryptionContext(TransparentDataEncryptionOptions) - Constructor for class org.apache.cassandra.security.EncryptionContext
 
EncryptionContext(TransparentDataEncryptionOptions, byte[], boolean) - Constructor for class org.apache.cassandra.security.EncryptionContext
 
EncryptionOptions - Class in org.apache.cassandra.config
 
EncryptionOptions() - Constructor for class org.apache.cassandra.config.EncryptionOptions
 
EncryptionOptions(String, String, String, String, List<String>, String, List<String>, String, String, boolean, boolean, Boolean, Boolean) - Constructor for class org.apache.cassandra.config.EncryptionOptions
 
EncryptionOptions(EncryptionOptions) - Constructor for class org.apache.cassandra.config.EncryptionOptions
 
EncryptionOptions.ServerEncryptionOptions - Class in org.apache.cassandra.config
 
EncryptionOptions.ServerEncryptionOptions.InternodeEncryption - Enum in org.apache.cassandra.config
 
EncryptionOptions.TlsEncryptionPolicy - Enum in org.apache.cassandra.config
 
EncryptionUtils - Class in org.apache.cassandra.security
Encryption and decryption functions specific to the commit log.
EncryptionUtils() - Constructor for class org.apache.cassandra.security.EncryptionUtils
 
EncryptionUtils.ChannelProxyReadChannel - Class in org.apache.cassandra.security
 
end - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegmentReader
ending position of the current sync section.
end(Object...) - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder.RangeTombstoneBuilder
Sets the end for the built range using the provided values.
end() - Method in class org.apache.cassandra.db.Slice
 
end() - Method in class org.apache.cassandra.io.util.MmappedRegions.Region
 
end - Variable in class org.apache.cassandra.repair.consistent.admin.RepairStats.Section
 
endDeletionTime() - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
The deletion time for the range tombstone this boundary ends (in clustering order).
endOfComplexColumn() - Method in class org.apache.cassandra.db.rows.DeserializationHelper
 
endOfData() - Method in class org.apache.cassandra.index.sasi.utils.AbstractIterator
Implementations of AbstractIterator.computeNext() must invoke this method when there are no elements left in the iteration.
endOfData() - Method in class org.apache.cassandra.utils.AbstractIterator
 
endOpenMarker - Variable in class org.apache.cassandra.io.sstable.IndexInfo
 
endpoint() - Method in class org.apache.cassandra.locator.RangesAtEndpoint
 
endpoint() - Method in class org.apache.cassandra.locator.Replica
 
endpoint(ResourceLimits.Limit) - Static method in class org.apache.cassandra.net.AbstractMessageHandler.WaitQueue
 
endpoint() - Method in class org.apache.cassandra.net.ResourceLimits.EndpointAndGlobal
 
endpoint - Variable in class org.apache.cassandra.repair.TreeResponse
 
endpoint - Variable in class org.apache.cassandra.tools.nodetool.HostStat
 
endpoint_snitch - Variable in class org.apache.cassandra.config.Config
 
EndpointAndGlobal(ResourceLimits.Limit, ResourceLimits.Limit) - Constructor for class org.apache.cassandra.net.ResourceLimits.EndpointAndGlobal
 
endpointList() - Method in class org.apache.cassandra.locator.Endpoints
 
EndpointMessagingVersions - Class in org.apache.cassandra.net
Map of hosts to their known current messaging versions.
EndpointMessagingVersions() - Constructor for class org.apache.cassandra.net.EndpointMessagingVersions
 
endpointReserveCapacity - Variable in class org.apache.cassandra.net.AbstractMessageHandler
 
Endpoints<E extends Endpoints<E>> - Class in org.apache.cassandra.locator
A collection of Endpoints for a given ring position.
endpoints() - Method in class org.apache.cassandra.locator.Endpoints
 
endpoints() - Static method in class org.apache.cassandra.locator.InOurDcTester
 
endpoints() - Method in class org.apache.cassandra.locator.RangesAtEndpoint
 
endpoints() - Method in interface org.apache.cassandra.locator.ReplicaCollection
 
endpoints - Variable in class org.apache.cassandra.repair.CommonRange
 
endpoints() - Method in class org.apache.cassandra.repair.RepairSession
 
endpoints - Variable in class org.apache.cassandra.service.TokenRange
 
EndpointsByRange - Class in org.apache.cassandra.locator
 
EndpointsByRange(Map<Range<Token>, EndpointsForRange>) - Constructor for class org.apache.cassandra.locator.EndpointsByRange
 
EndpointsByRange.Builder - Class in org.apache.cassandra.locator
 
EndpointsByReplica - Class in org.apache.cassandra.locator
 
EndpointsByReplica(Map<Replica, EndpointsForRange>) - Constructor for class org.apache.cassandra.locator.EndpointsByReplica
 
EndpointsByReplica.Builder - Class in org.apache.cassandra.locator
 
EndpointsForRange - Class in org.apache.cassandra.locator
A ReplicaCollection where all Replica are required to cover a range that fully contains the range() defined in the builder().
EndpointsForRange.Builder - Class in org.apache.cassandra.locator
 
EndpointsForToken - Class in org.apache.cassandra.locator
A ReplicaCollection where all Replica are required to cover a range that fully contains the token() defined in the builder().
EndpointsForToken.Builder - Class in org.apache.cassandra.locator
 
EndpointSnitchInfo - Class in org.apache.cassandra.locator
 
EndpointSnitchInfo() - Constructor for class org.apache.cassandra.locator.EndpointSnitchInfo
 
EndpointSnitchInfoMBean - Interface in org.apache.cassandra.locator
MBean exposing standard Snitch info
EndpointState - Class in org.apache.cassandra.gms
This abstraction represents both the HeartBeatState and the ApplicationState in an EndpointState instance.
EndpointState(HeartBeatState) - Constructor for class org.apache.cassandra.gms.EndpointState
 
EndpointState(EndpointState) - Constructor for class org.apache.cassandra.gms.EndpointState
 
endpointToVersion - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
endpointToVersion() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
endpointWaitQueue - Variable in class org.apache.cassandra.net.AbstractMessageHandler
 
endpointWithPort - Variable in class org.apache.cassandra.tools.nodetool.HostStatWithPort
 
endPosition - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SyncSegment
the logical ending position of the buffer
ends() - Method in class org.apache.cassandra.db.commitlog.IntervalSet
 
endsWith(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
endTimerPeriod(int) - Static method in class org.apache.cassandra.utils.WindowsTimer
 
enforceConcurrentValidatorsLimit() - Method in class org.apache.cassandra.service.StorageService
 
enforceConcurrentValidatorsLimit() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
enforceLimits - Variable in class org.apache.cassandra.db.filter.DataLimits.Counter
 
enforceStrictLiveness() - Method in class org.apache.cassandra.db.view.View
When views contains a primary key column that is not part of the base table primary key, we use that column liveness info as the view PK, to ensure that whenever that column is not live in the base, the row is not live in the view.
enforceStrictLiveness() - Method in class org.apache.cassandra.schema.TableMetadata
A table with strict liveness filters/ignores rows without PK liveness info, effectively tying the row liveness to its primary key liveness.
enqueue(Message) - Method in class org.apache.cassandra.net.OutboundConnection
This is the main entry point for enqueuing a message to be sent to the remote peer.
enqueue(Message, ConnectionType) - Method in class org.apache.cassandra.net.OutboundConnections
Select the appropriate connection for the provided message and use it to send the message.
enqueue(Envelope) - Method in class org.apache.cassandra.transport.SimpleClient.SimpleFlusher
 
ensureAllKeyspacesPermission(Permission) - Method in class org.apache.cassandra.service.ClientState
 
ensureCapacity(ByteBuffer, int, boolean) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Ensure buf is large enough for outputLength.
ensureCapacity(ByteBuffer, int, boolean, BufferType) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Ensure buf is large enough for outputLength.
ensureIsSuperuser(String) - Method in class org.apache.cassandra.service.ClientState
 
ensureKeyspacePermission(String, Permission) - Method in class org.apache.cassandra.service.ClientState
 
ensureNotAnonymous() - Method in class org.apache.cassandra.service.ClientState
 
EnsureOnHeap - Class in org.apache.cassandra.utils.memory
 
EnsureOnHeap() - Constructor for class org.apache.cassandra.utils.memory.EnsureOnHeap
 
ensureOnHeap() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
 
ensureOnHeap() - Method in class org.apache.cassandra.utils.memory.NativeAllocator
 
ensureOnHeap() - Method in class org.apache.cassandra.utils.memory.SlabAllocator
 
ensurePermission(Permission, IResource) - Method in class org.apache.cassandra.service.ClientState
 
ensurePermission(Permission, Function) - Method in class org.apache.cassandra.service.ClientState
 
ensureReleased(Throwable) - Method in class org.apache.cassandra.utils.concurrent.Ref
 
ensureReleased() - Method in class org.apache.cassandra.utils.concurrent.Ref
 
ensureTablePermission(String, String, Permission) - Method in class org.apache.cassandra.service.ClientState
 
ensureTablePermission(TableMetadataRef, Permission) - Method in class org.apache.cassandra.service.ClientState
 
ensureTablePermission(TableMetadata, Permission) - Method in class org.apache.cassandra.service.ClientState
 
entries - Variable in class org.apache.cassandra.cql3.Maps.Literal
 
entries - Variable in class org.apache.cassandra.cql3.UserTypes.Literal
 
entries - Variable in class org.apache.cassandra.metrics.CacheMetrics
Total number of cache entries
entriesLength - Variable in class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
 
ENTRY_OVERHEAD_SIZE - Static variable in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
ENTRY_TYPE_MASK - Static variable in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
entrySet() - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaMap
 
entrySet() - Method in class org.apache.cassandra.locator.ReplicaMultimap
 
entrySet() - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
 
entrySet() - Method in class org.apache.cassandra.utils.BiMultiValMap
 
entrySet() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
Envelope - Class in org.apache.cassandra.transport
 
Envelope(Envelope.Header, ByteBuf) - Constructor for class org.apache.cassandra.transport.Envelope
An on-wire message envelope consists of a header and a body.
Envelope.Compressor - Class in org.apache.cassandra.transport
 
Envelope.Decoder - Class in org.apache.cassandra.transport
 
Envelope.Decoder.HeaderExtractionResult - Class in org.apache.cassandra.transport
 
Envelope.Decompressor - Class in org.apache.cassandra.transport
 
Envelope.Encoder - Class in org.apache.cassandra.transport
 
Envelope.Header - Class in org.apache.cassandra.transport
 
Envelope.Header.Flag - Enum in org.apache.cassandra.transport
 
EQ - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader.Operator
 
EQRestriction(List<ColumnMetadata>, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
 
EQRestriction(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQRestriction
 
EQRestriction(TableMetadata, List<ColumnMetadata>, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQRestriction
 
EQUAL_BIT_KEY - Static variable in interface org.apache.cassandra.index.sasi.utils.trie.KeyAnalyzer
Returned by KeyAnalyzer.bitIndex(Object, Object) if a the bits of two keys were all equal.
equals(Object) - Method in class org.apache.cassandra.auth.AuthenticatedUser
 
equals(Object) - Method in class org.apache.cassandra.auth.CassandraPrincipal
Compares the specified Object with this CassPrincipal for equality.
equals(Object) - Method in class org.apache.cassandra.auth.DataResource
 
equals(Object) - Method in class org.apache.cassandra.auth.FunctionResource
 
equals(Object) - Method in class org.apache.cassandra.auth.JMXResource
 
equals(Object) - Method in class org.apache.cassandra.auth.PermissionDetails
 
equals(Object) - Method in class org.apache.cassandra.auth.Role
 
equals(Object) - Method in class org.apache.cassandra.auth.RoleResource
 
equals(Object) - Method in class org.apache.cassandra.cache.CounterCacheKey
 
equals(Object) - Method in class org.apache.cassandra.cache.KeyCacheKey
 
equals(Object) - Method in class org.apache.cassandra.cache.RowCacheKey
 
equals(Object) - Method in class org.apache.cassandra.cache.RowCacheSentinel
 
equals(Object) - Method in class org.apache.cassandra.config.EncryptionOptions
The method is being mainly used to cache SslContexts therefore, we only consider fields that would make a difference when the TrustStore or KeyStore files are updated
equals(Object) - Method in class org.apache.cassandra.config.ParameterizedClass
 
equals(ParameterizedClass) - Method in class org.apache.cassandra.config.ParameterizedClass
 
equals(Object) - Method in class org.apache.cassandra.config.TransparentDataEncryptionOptions
 
equals(TransparentDataEncryptionOptions) - Method in class org.apache.cassandra.config.TransparentDataEncryptionOptions
 
equals(Object) - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
equals(Object) - Method in class org.apache.cassandra.cql3.ColumnSpecification
 
equals(Object) - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
 
equals(Object) - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
 
equals(Object) - Method in class org.apache.cassandra.cql3.CQL3Type.Tuple
 
equals(Object) - Method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
 
equals(Object) - Method in class org.apache.cassandra.cql3.Duration
 
equals(Object) - Method in class org.apache.cassandra.cql3.FieldIdentifier
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.FunctionName
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.types.DataType.CollectionType
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.types.DataType.CustomType
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.types.DataType.NativeType
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.types.Duration
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.types.LocalDate
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.types.TupleType
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.types.TupleValue
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.types.UDTValue
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.types.UserType
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.types.UserType.Field
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
equals(Object) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
equals(ListType, Lists.Value) - Method in class org.apache.cassandra.cql3.Lists.Value
 
equals(MapType, Maps.Value) - Method in class org.apache.cassandra.cql3.Maps.Value
 
equals(Object) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
equals(Object) - Method in class org.apache.cassandra.cql3.QualifiedName
 
equals(Object) - Method in class org.apache.cassandra.cql3.restrictions.CustomIndexExpression
 
equals(Object) - Method in class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
 
equals(Object) - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
equals(Object) - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
equals(SetType, Sets.Value) - Method in class org.apache.cassandra.cql3.Sets.Value
 
equals(Object) - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
equals(Object) - Method in class org.apache.cassandra.cql3.Term.Raw
 
equals(Object) - Method in class org.apache.cassandra.cql3.TokenRelation
 
equals(UserType, UserTypes.Value) - Method in class org.apache.cassandra.cql3.UserTypes.Value
 
equals(Object) - Method in class org.apache.cassandra.cql3.WhereClause
 
equals(Object) - Method in class org.apache.cassandra.db.AbstractOnHeapClusteringPrefix
 
equals(Object) - Method in class org.apache.cassandra.db.ClockAndCount
 
equals(Object) - Method in class org.apache.cassandra.db.ClusteringComparator
 
equals(ClusteringPrefix<V1>, ClusteringPrefix<V2>) - Static method in interface org.apache.cassandra.db.ClusteringPrefix
 
equals(ClusteringPrefix<?>, Object) - Static method in interface org.apache.cassandra.db.ClusteringPrefix
 
equals(Object) - Method in class org.apache.cassandra.db.Columns
 
equals(Object) - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
equals(CommitLogDescriptor) - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
equals(Object) - Method in class org.apache.cassandra.db.commitlog.CommitLogPosition
 
equals(Object) - Method in class org.apache.cassandra.db.commitlog.IntervalSet
 
equals(Object) - Method in class org.apache.cassandra.db.DecoratedKey
 
equals(Object) - Method in class org.apache.cassandra.db.DeletionTime
 
equals(Object) - Method in class org.apache.cassandra.db.Directories.DataDirectories
 
equals(Object) - Method in class org.apache.cassandra.db.Directories.DataDirectory
 
equals(Object) - Method in class org.apache.cassandra.db.Directories.SnapshotSizeDetails
 
equals(Object) - Method in class org.apache.cassandra.db.DiskBoundaries
 
equals(Object) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
 
equals(Object) - Method in class org.apache.cassandra.db.filter.ColumnFilter.SelectionColumnFilter
 
equals(Object) - Method in class org.apache.cassandra.db.filter.ColumnFilter.WildCardColumnFilter
 
equals(Object) - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
 
equals(Object) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState
 
equals(LifecycleTransaction.ReaderState) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState
 
equals(Object) - Method in class org.apache.cassandra.db.LivenessInfo
 
equals(Object) - Method in class org.apache.cassandra.db.marshal.CollectionType
 
equals(Object) - Method in class org.apache.cassandra.db.marshal.TupleType
 
equals(Object) - Method in class org.apache.cassandra.db.marshal.UserType
 
equals(L, ValueAccessor<L>, R, ValueAccessor<R>) - Static method in interface org.apache.cassandra.db.marshal.ValueAccessor
 
equals(Object) - Method in class org.apache.cassandra.db.MutableDeletionInfo
 
equals(Object) - Method in class org.apache.cassandra.db.NativeClustering
 
equals(Object) - Method in class org.apache.cassandra.db.RangeTombstone
 
equals(Object) - Method in class org.apache.cassandra.db.RangeTombstoneList
 
equals(Object) - Method in class org.apache.cassandra.db.RegularAndStaticColumns
 
equals(Cell<V1>, Cell<V2>) - Static method in class org.apache.cassandra.db.rows.AbstractCell
 
equals(Object) - Method in class org.apache.cassandra.db.rows.AbstractCell
 
equals(Object) - Method in class org.apache.cassandra.db.rows.AbstractRow
 
equals(Object) - Method in class org.apache.cassandra.db.rows.CellPath
 
equals(Object) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
equals(Object) - Method in class org.apache.cassandra.db.rows.EncodingStats
 
equals(Object) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
equals(Object) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
equals(Object) - Method in class org.apache.cassandra.db.rows.Row.Deletion
 
equals(Object) - Method in class org.apache.cassandra.db.SerializationHeader.Component
 
equals(Object) - Method in class org.apache.cassandra.db.Slice
 
equals(Object) - Method in class org.apache.cassandra.db.streaming.CassandraIncomingFile
 
equals(Object) - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
 
equals(Object) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader
 
equals(Object) - Method in class org.apache.cassandra.db.streaming.ComponentManifest
 
equals(Object) - Method in class org.apache.cassandra.db.streaming.CompressionInfo
 
equals(Object) - Method in class org.apache.cassandra.dht.Bounds
 
equals(Object) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
equals(Object) - Method in class org.apache.cassandra.dht.ExcludingBounds
 
equals(Object) - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
equals(Object) - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
 
equals(Object) - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
equals(Object) - Method in class org.apache.cassandra.dht.Range
 
equals(Object) - Method in class org.apache.cassandra.dht.RangeStreamer.FetchReplica
 
equals(Object) - Method in class org.apache.cassandra.dht.Splitter.WeightedRange
 
equals(Object) - Method in class org.apache.cassandra.dht.Token.KeyBound
 
equals(Object) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
 
equals(Object) - Method in class org.apache.cassandra.index.sasi.plan.Expression.Bound
 
equals(Object) - Method in class org.apache.cassandra.index.sasi.plan.Expression
 
equals(Object) - Method in class org.apache.cassandra.index.sasi.SSTableIndex
 
equals(Object) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.Component
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.IndexesBounds
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.PartitionPositionBounds
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.format.Version
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.format.VersionAndType
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
 
equals(Object) - Method in class org.apache.cassandra.io.util.Memory
 
equals(Object) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
It's not clear whether AbstractReplicaCollection should implement the order sensitive equals of List or the order oblivious equals of Set.
equals(Object) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
 
equals(Object) - Method in class org.apache.cassandra.locator.InetAddressAndPort
 
equals(Object) - Method in class org.apache.cassandra.locator.Replica
 
equals(Object) - Method in interface org.apache.cassandra.locator.ReplicaCollection
 
equals(Object) - Method in class org.apache.cassandra.locator.ReplicaMultimap
 
equals(Object) - Method in class org.apache.cassandra.locator.ReplicationFactor
 
equals(Object) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
 
equals(Object) - Method in class org.apache.cassandra.repair.CommonRange
 
equals(Object) - Method in class org.apache.cassandra.repair.consistent.ConsistentSession
 
equals(Object) - Method in class org.apache.cassandra.repair.consistent.LocalSession
 
equals(Object) - Method in class org.apache.cassandra.repair.consistent.RepairedState.Section
 
equals(Object) - Method in class org.apache.cassandra.repair.messages.CleanupMessage
 
equals(Object) - Method in class org.apache.cassandra.repair.messages.FailSession
 
equals(Object) - Method in class org.apache.cassandra.repair.messages.FinalizeCommit
 
equals(Object) - Method in class org.apache.cassandra.repair.messages.FinalizePromise
 
equals(Object) - Method in class org.apache.cassandra.repair.messages.FinalizePropose
 
equals(Object) - Method in class org.apache.cassandra.repair.messages.PrepareConsistentRequest
 
equals(Object) - Method in class org.apache.cassandra.repair.messages.PrepareConsistentResponse
 
equals(Object) - Method in class org.apache.cassandra.repair.messages.PrepareMessage
 
equals(Object) - Method in class org.apache.cassandra.repair.messages.SnapshotMessage
 
equals(Object) - Method in class org.apache.cassandra.repair.messages.StatusRequest
 
equals(Object) - Method in class org.apache.cassandra.repair.messages.StatusResponse
 
equals(Object) - Method in class org.apache.cassandra.repair.messages.SyncRequest
 
equals(Object) - Method in class org.apache.cassandra.repair.messages.SyncResponse
 
equals(Object) - Method in class org.apache.cassandra.repair.messages.ValidationRequest
 
equals(Object) - Method in class org.apache.cassandra.repair.messages.ValidationResponse
 
equals(Object) - Method in class org.apache.cassandra.repair.RepairJobDesc
 
equals(Object) - Method in class org.apache.cassandra.repair.SyncNodePair
 
equals(Object) - Method in class org.apache.cassandra.schema.CachingParams
 
equals(Object) - Method in class org.apache.cassandra.schema.ColumnMetadata
 
equals(Object) - Method in class org.apache.cassandra.schema.CompactionParams
 
equals(Object) - Method in class org.apache.cassandra.schema.CompressionParams
 
equals(Object) - Method in class org.apache.cassandra.schema.DroppedColumn
 
equals(Object) - Method in class org.apache.cassandra.schema.Functions
 
equals(Object) - Method in class org.apache.cassandra.schema.Indexes
 
equals(Object) - Method in class org.apache.cassandra.schema.IndexMetadata
 
equals(Object) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
equals(Object) - Method in class org.apache.cassandra.schema.KeyspaceParams
 
equals(Object) - Method in class org.apache.cassandra.schema.Keyspaces
 
equals(Object) - Method in class org.apache.cassandra.schema.ReplicationParams
 
equals(Object) - Method in class org.apache.cassandra.schema.TableId
 
equals(Object) - Method in class org.apache.cassandra.schema.TableMetadata
 
equals(Object) - Method in class org.apache.cassandra.schema.TableParams
 
equals(Object) - Method in class org.apache.cassandra.schema.Tables
 
equals(Object) - Method in class org.apache.cassandra.schema.TriggerMetadata
 
equals(Object) - Method in class org.apache.cassandra.schema.Triggers
 
equals(Object) - Method in class org.apache.cassandra.schema.Types
 
equals(Object) - Method in class org.apache.cassandra.schema.ViewMetadata
 
equals(Object) - Method in class org.apache.cassandra.schema.Views
 
equals(Object) - Method in class org.apache.cassandra.security.EncryptionContext
 
equals(EncryptionContext) - Method in class org.apache.cassandra.security.EncryptionContext
 
equals(Object) - Method in class org.apache.cassandra.service.pager.PagingState
 
equals(Object) - Method in class org.apache.cassandra.service.pager.PagingState.RowMark
 
equals(Object) - Method in class org.apache.cassandra.service.paxos.Commit
 
equals(Object) - Method in class org.apache.cassandra.service.reads.AlwaysSpeculativeRetryPolicy
 
equals(Object) - Method in class org.apache.cassandra.service.reads.FixedSpeculativeRetryPolicy
 
equals(Object) - Method in class org.apache.cassandra.service.reads.HybridSpeculativeRetryPolicy
 
equals(Object) - Method in class org.apache.cassandra.service.reads.NeverSpeculativeRetryPolicy
 
equals(Object) - Method in class org.apache.cassandra.service.reads.PercentileSpeculativeRetryPolicy
 
equals(Object) - Method in class org.apache.cassandra.service.reads.repair.RepairedDataTracker
 
equals(Object) - Method in class org.apache.cassandra.streaming.messages.IncomingStreamMessage
 
equals(Object) - Method in class org.apache.cassandra.streaming.messages.StreamMessageHeader
 
equals(Object) - Method in class org.apache.cassandra.streaming.ProgressInfo
ProgressInfo is considered to be equal only when all attributes except currentBytes are equal.
equals(Object) - Method in class org.apache.cassandra.streaming.SessionSummary
 
equals(Object) - Method in class org.apache.cassandra.streaming.StreamResultFuture
 
equals(Object) - Method in class org.apache.cassandra.streaming.StreamSummary
 
equals(Object) - Method in class org.apache.cassandra.tools.JMXTool.Attribute
 
equals(Object) - Method in class org.apache.cassandra.tools.JMXTool.Info
 
equals(Object) - Method in class org.apache.cassandra.tools.JMXTool.Operation
 
equals(Object) - Method in class org.apache.cassandra.tools.JMXTool.Parameter
 
equals(Object) - Method in class org.apache.cassandra.transport.Event.SchemaChange
 
equals(Object) - Method in class org.apache.cassandra.transport.Event.StatusChange
 
equals(Object) - Method in class org.apache.cassandra.transport.Event.TopologyChange
 
equals(Object[], Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
 
equals(Object) - Method in class org.apache.cassandra.utils.CassandraVersion
 
equals(Object) - Method in class org.apache.cassandra.utils.CounterId
 
equals(Object) - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
equals(Object) - Method in class org.apache.cassandra.utils.IntegerInterval
 
equals(Object) - Method in class org.apache.cassandra.utils.IntegerInterval.Set
 
equals(Object) - Method in class org.apache.cassandra.utils.Interval
 
equals(Object) - Method in class org.apache.cassandra.utils.IntervalTree
 
equals(Object) - Method in class org.apache.cassandra.utils.MD5Digest
 
equals(Object) - Method in class org.apache.cassandra.utils.MerkleTree
 
equals(Object) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
equals(Object) - Method in class org.apache.cassandra.utils.Pair
 
equals(Object) - Method in class org.apache.cassandra.utils.RMIServerSocketFactoryImpl
 
equals(Object) - Method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram
 
equalsIgnoringCompression(CommitLogDescriptor) - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
equalsNativeFunction(FunctionName) - Method in class org.apache.cassandra.cql3.functions.FunctionName
 
equalsWithoutName(IndexMetadata) - Method in class org.apache.cassandra.schema.IndexMetadata
 
err(Throwable) - Method in class org.apache.cassandra.tools.NodeTool
 
err - Variable in class org.apache.cassandra.tools.Output
 
ERR_OUTDATED_SCHEMA - Static variable in exception org.apache.cassandra.exceptions.StartupException
 
ERR_WRONG_CONFIG - Static variable in exception org.apache.cassandra.exceptions.StartupException
 
ERR_WRONG_DISK_STATE - Static variable in exception org.apache.cassandra.exceptions.StartupException
 
ERR_WRONG_MACHINE_STATE - Static variable in exception org.apache.cassandra.exceptions.StartupException
 
error(Consumer<String>) - Method in class org.apache.cassandra.io.sstable.SSTableHeaderFix.Builder
 
error - Variable in class org.apache.cassandra.io.sstable.SSTableHeaderFix
 
error - Variable in class org.apache.cassandra.metrics.Sampler.Sample
 
error - Variable in class org.apache.cassandra.transport.messages.ErrorMessage
 
error() - Method in interface org.apache.cassandra.utils.MonotonicClock
 
error() - Method in class org.apache.cassandra.utils.MonotonicClock.SampledClock
 
error() - Method in class org.apache.cassandra.utils.MonotonicClock.SystemClock
 
error() - Method in interface org.apache.cassandra.utils.MonotonicClockTranslation
Nanoseconds of probable error in the translation
error(long, String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
error(String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
error(long, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
 
error(Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
 
errorBytes() - Method in class org.apache.cassandra.net.InboundMessageHandlers
 
errorBytes() - Method in class org.apache.cassandra.net.OutboundConnection
 
ErrorCollector - Class in org.apache.cassandra.cql3
ErrorListener that collect and enhance the errors send by the CQL lexer and parser.
ErrorCollector(String) - Constructor for class org.apache.cassandra.cql3.ErrorCollector
Creates a new ErrorCollector instance to collect the syntax errors associated to the specified CQL query.
errorCount() - Method in class org.apache.cassandra.net.InboundMessageHandlers
 
errorCount() - Method in class org.apache.cassandra.net.OutboundConnection
 
ErrorListener - Interface in org.apache.cassandra.cql3
Listener used to collect the syntax errors emitted by the Lexer and Parser.
ErrorMessage - Class in org.apache.cassandra.transport.messages
Message to indicate an error to the client.
ErrorMessage.WrappedException - Exception in org.apache.cassandra.transport.messages
 
escape(String) - Static method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
estimateCompactionGain(Set<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
Estimates how much of the keys we would keep if the sstables were compacted together
estimatedCellPerPartitionCount - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
estimatedCellPerPartitionCount - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
estimatedColumnCountHistogram - Variable in class org.apache.cassandra.metrics.TableMetrics
Histogram of estimated number of columns.
EstimatedHistogram - Class in org.apache.cassandra.utils
 
EstimatedHistogram() - Constructor for class org.apache.cassandra.utils.EstimatedHistogram
 
EstimatedHistogram(int) - Constructor for class org.apache.cassandra.utils.EstimatedHistogram
 
EstimatedHistogram(int, boolean) - Constructor for class org.apache.cassandra.utils.EstimatedHistogram
 
EstimatedHistogram(long[]) - Constructor for class org.apache.cassandra.utils.EstimatedHistogram
Create EstimatedHistogram from only bucket data.
EstimatedHistogram(long[], long[]) - Constructor for class org.apache.cassandra.utils.EstimatedHistogram
 
EstimatedHistogram.EstimatedHistogramSerializer - Class in org.apache.cassandra.utils
 
EstimatedHistogramSerializer() - Constructor for class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
estimatedKeys() - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
estimated number of keys we should write
estimatedKeys() - Method in class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
 
estimatedKeys - Variable in class org.apache.cassandra.db.streaming.CassandraStreamHeader
 
estimatedKeys - Variable in class org.apache.cassandra.db.streaming.CassandraStreamReader
 
estimatedKeys() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
estimatedKeysForRange(Range<Token>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
estimatedKeysForRanges(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
estimatedMaxDepthForBytes(IPartitioner, long, int) - Static method in class org.apache.cassandra.utils.MerkleTree
Estimate the allowable depth while keeping the resulting heap usage of this tree under the provided number of bytes.
estimatedMemoryUse() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
 
estimatedPartitionCount - Variable in class org.apache.cassandra.metrics.TableMetrics
Approximate number of keys in table.
estimatedPartitions() - Method in class org.apache.cassandra.db.repair.CassandraValidationIterator
 
estimatedPartitions() - Method in class org.apache.cassandra.repair.ValidationPartitionIterator
 
estimatedPartitionSize - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
estimatedPartitionSize - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
estimatedPartitionSizeHistogram - Variable in class org.apache.cassandra.metrics.TableMetrics
Histogram of estimated partition size (in bytes).
estimatedRemainingTasks - Variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
Deprecated.
 
estimatedRemainingTasks - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
estimatedRemainingTasks - Variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
 
estimatedTombstoneDropTime - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
estimatedTombstoneDropTime - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
estimatedTotalKeys - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
estimateKeys() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
estimateKeys() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
estimateRowsFromIndex(RandomAccessReader, Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTable
 
estimateTotalResults(ColumnFamilyStore) - Method in class org.apache.cassandra.db.filter.DataLimits
Estimate the number of results that a full scan of the provided cfs would yield.
evaluateComparisonWithOperator(int, Operator) - Static method in class org.apache.cassandra.cql3.conditions.ColumnCondition
 
evaluateResponse(byte[]) - Method in interface org.apache.cassandra.auth.IAuthenticator.SaslNegotiator
Evaluates the client response data and generates a byte[] response which may be a further challenge or purely informational in the case that the negotiation is completed on this round.
Event - Class in org.apache.cassandra.transport
 
event - Variable in class org.apache.cassandra.transport.messages.EventMessage
 
Event.NodeEvent - Class in org.apache.cassandra.transport
 
Event.SchemaChange - Class in org.apache.cassandra.transport
 
Event.SchemaChange.Change - Enum in org.apache.cassandra.transport
 
Event.SchemaChange.Target - Enum in org.apache.cassandra.transport
 
Event.StatusChange - Class in org.apache.cassandra.transport
 
Event.StatusChange.Status - Enum in org.apache.cassandra.transport
 
Event.TopologyChange - Class in org.apache.cassandra.transport
 
Event.TopologyChange.Change - Enum in org.apache.cassandra.transport
 
Event.Type - Enum in org.apache.cassandra.transport
 
EventMessage - Class in org.apache.cassandra.transport.messages
 
EventMessage(Event) - Constructor for class org.apache.cassandra.transport.messages.EventMessage
 
EventNotifier() - Constructor for class org.apache.cassandra.transport.Server.EventNotifier
 
EVENTS - Static variable in class org.apache.cassandra.tracing.TraceKeyspace
 
eventSerializedSize(ProtocolVersion) - Method in class org.apache.cassandra.transport.Event
 
eventSerializedSize(ProtocolVersion) - Method in class org.apache.cassandra.transport.Event.SchemaChange
 
eventSerializedSize(ProtocolVersion) - Method in class org.apache.cassandra.transport.Event.StatusChange
 
eventSerializedSize(ProtocolVersion) - Method in class org.apache.cassandra.transport.Event.TopologyChange
 
eventType - Variable in class org.apache.cassandra.streaming.StreamEvent
 
eventTypes - Variable in class org.apache.cassandra.transport.messages.RegisterMessage
 
evolveSystemKeyspace(KeyspaceMetadata, long) - Static method in class org.apache.cassandra.schema.MigrationManager
We have a set of non-local, distributed system keyspaces, e.g.
except(String, Object...) - Method in class org.apache.cassandra.schema.TableMetadata
 
exception - Variable in class org.apache.cassandra.schema.Schema.TransformationResult
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.cassandra.net.InboundMessageHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.cassandra.streaming.async.StreamingInboundHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.cassandra.transport.PreV5Handlers.ExceptionHandler
 
ExceptionCode - Enum in org.apache.cassandra.exceptions
Exceptions code, as defined by the binary protocol.
ExceptionHandlers - Class in org.apache.cassandra.transport
 
ExceptionHandlers() - Constructor for class org.apache.cassandra.transport.ExceptionHandlers
 
excise(UUID) - Method in class org.apache.cassandra.hints.HintsService
Cleans up hints-related state after a node with id = hostId left.
exclEnd() - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder.RangeTombstoneBuilder
Sets the end of this range as exclusive.
exclStart() - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder.RangeTombstoneBuilder
Sets the start of this range as exclusive.
excluded_categories - Variable in class org.apache.cassandra.audit.AuditLogOptions
 
excluded_keyspaces - Variable in class org.apache.cassandra.audit.AuditLogOptions
 
excluded_users - Variable in class org.apache.cassandra.audit.AuditLogOptions
 
ExcludeLocalNodeFilter() - Constructor for class org.apache.cassandra.dht.RangeStreamer.ExcludeLocalNodeFilter
 
ExcludingBounds<T extends RingPosition<T>> - Class in org.apache.cassandra.dht
AbstractBounds containing neither of its endpoints: (left, right).
ExcludingBounds(T, T) - Constructor for class org.apache.cassandra.dht.ExcludingBounds
 
exclusions - Variable in class org.apache.cassandra.index.sasi.plan.Expression
 
exclusiveClose(boolean, V[]) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor.ObjectFactory
 
exclusiveClose(boolean, V[], ValueAccessor<V>, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
exclusiveClose(boolean, ClusteringPrefix<V>, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
exclusiveCloseInclusiveOpen(boolean, V[]) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor.ObjectFactory
 
exclusiveCloseInclusiveOpen(boolean, V[], ValueAccessor<V>, DeletionTime, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
exclusiveCloseInclusiveOpen(boolean, ClusteringPrefix<V>, DeletionTime, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
exclusiveEndOf(ByteBuffer...) - Static method in class org.apache.cassandra.db.BufferClusteringBound
 
exclusiveEndOf(ClusteringPrefix<?>) - Static method in interface org.apache.cassandra.db.ClusteringBound
 
exclusiveOpen(boolean, V[]) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor.ObjectFactory
 
exclusiveOpen(boolean, V[], ValueAccessor<V>, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
exclusiveOpen(boolean, ClusteringPrefix<V>, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
exclusiveStartOf(ByteBuffer...) - Static method in class org.apache.cassandra.db.BufferClusteringBound
 
exclusiveStartOf(ClusteringPrefix<?>) - Static method in interface org.apache.cassandra.db.ClusteringBound
 
exec(ProcessBuilder) - Static method in class org.apache.cassandra.utils.FBUtilities
Starts and waits for the given @param pb to finish.
execute(Runnable) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
execute(Runnable, ExecutorLocals) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
execute(Runnable, ExecutorLocals) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
execute(Runnable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
execute(Runnable, ExecutorLocals) - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
 
execute(Runnable) - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
 
execute(Runnable, ExecutorLocals) - Method in interface org.apache.cassandra.concurrent.LocalAwareExecutorService
 
execute(Runnable) - Method in enum org.apache.cassandra.concurrent.Stage
 
execute(Runnable, ExecutorLocals) - Method in enum org.apache.cassandra.concurrent.Stage
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Constants.Adder
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Constants.Deleter
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Constants.Setter
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Constants.Substracter
 
execute(QueryState, QueryOptions, long) - Method in interface org.apache.cassandra.cql3.CQLStatement
Execute the statement and return the resulting result or null if there is no result.
execute(ProtocolVersion, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.FromJsonFct
 
execute(ProtocolVersion, List<ByteBuffer>) - Method in interface org.apache.cassandra.cql3.functions.ScalarFunction
Applies this function to the specified parameter.
execute(ProtocolVersion, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.ToJsonFct
 
execute(ProtocolVersion, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.TokenFct
 
execute(ProtocolVersion, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.Appender
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.Discarder
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.DiscarderByIndex
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.Prepender
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.Setter
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Lists.SetterByIndex
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Maps.DiscarderByKey
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Maps.Putter
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Maps.Setter
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Maps.SetterByKey
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Operation
Execute the operation.
execute(String, ConsistencyLevel, Object...) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
execute(String, ConsistencyLevel, QueryState, Object...) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Sets.Adder
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Sets.Discarder
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Sets.ElementDiscarder
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.Sets.Setter
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterRoleStatement
 
execute(QueryState, QueryOptions, long) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
 
execute(QueryState, QueryOptions, long) - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
execute(QueryState, QueryOptions, long) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
execute(QueryState, BatchQueryOptions, long) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateRoleStatement
 
execute(QueryState, QueryOptions, long) - Method in class org.apache.cassandra.cql3.statements.DescribeStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropRoleStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.GrantPermissionsStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.GrantRoleStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListRolesStatement
 
execute(QueryState, QueryOptions, long) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.RevokePermissionsStatement
 
execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.RevokeRoleStatement
 
execute(QueryState, QueryOptions, long) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
execute(QueryState, QueryOptions, long) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
 
execute(QueryState, QueryOptions, long) - Method in class org.apache.cassandra.cql3.statements.UseStatement
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.UserTypes.DeleterByField
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.UserTypes.Setter
 
execute(DecoratedKey, UpdateParameters) - Method in class org.apache.cassandra.cql3.UserTypes.SetterByField
 
execute(ActiveCompactionsTracker) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
executes the task and unmarks sstables compacting
execute(ConsistencyLevel, ClientState, long) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
execute(ConsistencyLevel, ClientState, long) - Method in interface org.apache.cassandra.db.ReadQuery
Executes the query at the provided consistency level.
execute(ConsistencyLevel, ClientState, long) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
execute(ConsistencyLevel, ClientState, long) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand.Group
 
execute(ConsistencyLevel, ClientState, long) - Method in class org.apache.cassandra.db.VirtualTableReadQuery
 
execute(ConsistencyLevel, ClientState, long) - Method in class org.apache.cassandra.db.VirtualTableSinglePartitionReadQuery.Group
 
execute(FilterPipelineTask<F, T>, T) - Static method in class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineExecutor
 
execute(ReadExecutionController) - Method in class org.apache.cassandra.index.sasi.plan.QueryPlan
 
execute() - Method in class org.apache.cassandra.io.sstable.SSTableHeaderFix
 
execute(Set<InetAddressAndPort>, Function<InetAddressAndPort, String>) - Method in class org.apache.cassandra.net.StartupClusterConnectivityChecker
 
execute(Supplier<ListenableFuture<List<RepairSessionResult>>>, AtomicBoolean) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
Runs the asynchronous consistent repair session.
execute() - Method in interface org.apache.cassandra.service.StartupCheck
Run some test to determine whether the system is safe to be started In the case where a test determines it is not safe to proceed, the test should log a message regarding the reason for the failure and ideally the steps required to remedy the problem.
execute() - Method in class org.apache.cassandra.streaming.StreamPlan
Execute this StreamPlan asynchronously.
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Assassinate
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.BootstrapResume
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Cleanup
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ClearSnapshot
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ClientStats
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Compact
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.CompactionHistory
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.CompactionStats
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Decommission
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DescribeCluster
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DescribeRing
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DisableAuditLog
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DisableAutoCompaction
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DisableBackup
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DisableBinary
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DisableFullQueryLog
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DisableGossip
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DisableHandoff
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DisableHintsForDC
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.DisableOldProtocolVersions
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Drain
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.EnableAuditLog
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.EnableAutoCompaction
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.EnableBackup
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.EnableBinary
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.EnableFullQueryLog
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.EnableGossip
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.EnableHandoff
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.EnableHintsForDC
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.EnableOldProtocolVersions
 
execute(String...) - Method in class org.apache.cassandra.tools.NodeTool
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.FailureDetectorInfo
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Flush
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GarbageCollect
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GcStats
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetBatchlogReplayTrottle
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetCompactionThreshold
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetCompactionThroughput
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetConcurrency
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetConcurrentCompactors
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetConcurrentViewBuilders
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetEndpoints
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetFullQueryLog
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetInterDCStreamThroughput
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetLoggingLevels
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetMaxHintWindow
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetSeeds
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetSnapshotThrottle
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetSSTables
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetStreamThroughput
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetTimeout
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetTraceProbability
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GossipInfo
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Import
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Info
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.InvalidateCounterCache
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.InvalidateKeyCache
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.InvalidateRowCache
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Join
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ListSnapshots
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Move
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.NetStats
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.PauseHandoff
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ProfileLoad
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ProxyHistograms
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.RangeKeySample
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Rebuild
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.RebuildIndex
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Refresh
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.RefreshSizeEstimates
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ReloadLocalSchema
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ReloadSeeds
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ReloadTriggers
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.RelocateSSTables
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.RemoveNode
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Repair
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.RepairAdmin.CancelCmd
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.RepairAdmin.CleanupDataCmd
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.RepairAdmin.ListCmd
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.RepairAdmin.SummarizePendingCmd
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.RepairAdmin.SummarizeRepairedCmd
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ReplayBatchlog
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ResetFullQueryLog
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ResetLocalSchema
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ResumeHandoff
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Ring
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Scrub
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetBatchlogReplayThrottle
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetCacheCapacity
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetCacheKeysToSave
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetCompactionThreshold
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetCompactionThroughput
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetConcurrency
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetConcurrentCompactors
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetConcurrentViewBuilders
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetHintedHandoffThrottleInKB
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetInterDCStreamThroughput
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetLoggingLevel
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetMaxHintWindow
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetSnapshotThrottle
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetStreamThroughput
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetTimeout
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.SetTraceProbability
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Sjk
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Snapshot
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Status
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.StatusAutoCompaction
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.StatusBackup
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.StatusBinary
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.StatusGossip
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.StatusHandoff
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Stop
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.StopDaemon
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.TableHistograms
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.TableStats
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.TpStats
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.TruncateHints
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.UpgradeSSTable
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Verify
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Version
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.ViewBuildStatus
 
execute(NodeProbe) - Method in class org.apache.cassandra.tools.ReloadSslCertificates
 
execute(QueryState, long, boolean) - Method in class org.apache.cassandra.transport.Message.Request
 
execute(QueryState, long) - Method in class org.apache.cassandra.transport.Message.Request
 
execute(QueryState, long, boolean) - Method in class org.apache.cassandra.transport.messages.AuthResponse
 
execute(QueryState, long, boolean) - Method in class org.apache.cassandra.transport.messages.BatchMessage
 
execute(QueryState, long, boolean) - Method in class org.apache.cassandra.transport.messages.ExecuteMessage
 
execute(QueryState, long, boolean) - Method in class org.apache.cassandra.transport.messages.OptionsMessage
 
execute(QueryState, long, boolean) - Method in class org.apache.cassandra.transport.messages.PrepareMessage
 
execute(QueryState, long, boolean) - Method in class org.apache.cassandra.transport.messages.QueryMessage
 
execute(QueryState, long, boolean) - Method in class org.apache.cassandra.transport.messages.RegisterMessage
 
execute(QueryState, long, boolean) - Method in class org.apache.cassandra.transport.messages.StartupMessage
 
execute(String, ConsistencyLevel) - Method in class org.apache.cassandra.transport.SimpleClient
 
execute(String, List<ByteBuffer>, ConsistencyLevel) - Method in class org.apache.cassandra.transport.SimpleClient
 
execute(Message.Request) - Method in class org.apache.cassandra.transport.SimpleClient
 
execute(Message.Request, boolean) - Method in class org.apache.cassandra.transport.SimpleClient
 
execute(List<Message.Request>) - Method in class org.apache.cassandra.transport.SimpleClient
 
execute(PartitionUpdate) - Method in class org.apache.cassandra.triggers.TriggerExecutor
Augment a partition update by executing triggers to generate an intermediate set of mutations, then merging the update from each mutation with those supplied.
execute(Collection<? extends IMutation>) - Method in class org.apache.cassandra.triggers.TriggerExecutor
Takes a collection of mutations and possibly augments it by adding extra mutations generated by configured triggers.
execute(Throwable) - Method in interface org.apache.cassandra.utils.JVMStabilityInspector.OnKillHook
 
executeAggregateImpl(ProtocolVersion, Object, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
 
executeAggregateUserDefined(ProtocolVersion, Object, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.JavaBasedUDFunction
 
executeAggregateUserDefined(ProtocolVersion, Object, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
executeAsync() - Method in class org.apache.cassandra.service.reads.AbstractReadExecutor
send the initial set of requests
executeFailure(CQLStatement, String, QueryOptions, QueryState, Exception) - Method in class org.apache.cassandra.audit.AuditLogManager
 
executeFailure(CQLStatement, String, QueryOptions, QueryState, Exception) - Method in interface org.apache.cassandra.cql3.QueryEvents.Listener
 
executeForAggregate(ProtocolVersion, Object, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.UDFunction
Like ScalarFunction.execute(ProtocolVersion, List) but the first parameter is already in non-serialized form.
executeImpl(ProtocolVersion, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
 
executeInternal(String, Object...) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
executeInternal(QueryState, QueryOptions, int, long) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
executeInternal(ActiveCompactionsTracker) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
executeInternal(ActiveCompactionsTracker) - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
executeInternal(ActiveCompactionsTracker) - Method in class org.apache.cassandra.db.compaction.SingleSSTableLCSTask
 
executeInternal(ReadExecutionController) - Method in interface org.apache.cassandra.db.ReadQuery
Execute the query for internal queries (that is, it basically executes the query locally).
executeInternal(ReadExecutionController) - Method in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
 
executeInternalWithCondition(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
executeInternalWithNow(int, long, String, Object...) - Static method in class org.apache.cassandra.cql3.QueryProcessor
A special version of executeLocally that takes the time used as "now" for the query in argument.
executeInternalWithoutCondition(QueryState, QueryOptions, long) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
executeInternalWithPaging(String, int, Object...) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
executeLocally(QueryState, QueryOptions) - Method in interface org.apache.cassandra.cql3.CQLStatement
Variant of execute used for internal query against the system tables, and thus only query the local node.
executeLocally(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
 
executeLocally(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
executeLocally(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
executeLocally(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.DescribeStatement
 
executeLocally(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
executeLocally(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
executeLocally(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
 
executeLocally(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.UseStatement
 
executeLocally(ReadExecutionController) - Method in class org.apache.cassandra.db.ReadCommand
Executes this command on the local host.
executeLocally(ReadExecutionController) - Method in interface org.apache.cassandra.db.ReadQuery
Execute the query locally.
executeLocally(ReadExecutionController) - Method in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
 
executeLocally(ReadExecutionController) - Method in class org.apache.cassandra.db.VirtualTableReadQuery
 
ExecuteMessage - Class in org.apache.cassandra.transport.messages
 
ExecuteMessage(MD5Digest, MD5Digest, QueryOptions) - Constructor for class org.apache.cassandra.transport.messages.ExecuteMessage
 
executeOnceInternal(String, Object...) - Static method in class org.apache.cassandra.cql3.QueryProcessor
Same than executeLocally, but to use for queries we know are only executed once so that the created statement object is not cached.
executeOnceInternalWithNowAndTimestamp(int, long, String, Object...) - Static method in class org.apache.cassandra.cql3.QueryProcessor
Execute an internal query with the provided nowInSec and timestamp for the QueryState.
executePreJoinTasksBlocking(boolean) - Method in class org.apache.cassandra.index.SecondaryIndexManager
Performs a blocking execution of pre-join tasks of all indexes
executePrepared(ResultMessage.Prepared, List<ByteBuffer>, ConsistencyLevel) - Method in class org.apache.cassandra.transport.SimpleClient
 
executeSuccess(CQLStatement, String, QueryOptions, QueryState, long, Message.Response) - Method in class org.apache.cassandra.audit.AuditLogManager
 
executeSuccess(CQLStatement, String, QueryOptions, QueryState, long, Message.Response) - Method in interface org.apache.cassandra.cql3.QueryEvents.Listener
 
executeSuccess(CQLStatement, String, QueryOptions, QueryState, long, Message.Response) - Method in class org.apache.cassandra.fql.FullQueryLogger
 
executeUserDefined(ProtocolVersion, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.JavaBasedUDFunction
 
executeUserDefined(ProtocolVersion, List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
executionController(boolean) - Method in class org.apache.cassandra.db.ReadCommand
 
executionController() - Method in class org.apache.cassandra.db.ReadCommand
 
executionController() - Method in interface org.apache.cassandra.db.ReadQuery
Starts a new read operation.
executionController() - Method in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
 
executionController() - Method in class org.apache.cassandra.db.VirtualTableReadQuery
 
executionController() - Method in class org.apache.cassandra.service.pager.AggregationQueryPager
 
executionController() - Method in class org.apache.cassandra.service.pager.MultiPartitionPager
 
executionController() - Method in interface org.apache.cassandra.service.pager.QueryPager
Starts a new read operation.
executor() - Method in enum org.apache.cassandra.concurrent.Stage
 
executor() - Method in class org.apache.cassandra.cql3.functions.JavaBasedUDFunction
 
executor() - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
executor - Static variable in class org.apache.cassandra.utils.progress.jmx.JMXBroadcastExecutor
 
ExecutorLocal<T> - Interface in org.apache.cassandra.concurrent
 
ExecutorLocals - Class in org.apache.cassandra.concurrent
 
executors - Variable in class org.apache.cassandra.concurrent.SharedExecutorPool
 
ExecutorUtils - Class in org.apache.cassandra.utils
 
ExecutorUtils() - Constructor for class org.apache.cassandra.utils.ExecutorUtils
 
exists() - Method in class org.apache.cassandra.auth.DataResource
 
exists() - Method in class org.apache.cassandra.auth.FunctionResource
 
exists() - Method in interface org.apache.cassandra.auth.IResource
 
exists() - Method in class org.apache.cassandra.auth.JMXResource
 
exists() - Method in class org.apache.cassandra.auth.RoleResource
 
expandToCover(int) - Method in class org.apache.cassandra.utils.IntegerInterval
Expands the interval to cover the given value by extending one of its sides if necessary.
expandToFit(long) - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
expandToFit(long) - Method in class org.apache.cassandra.io.util.DataOutputBufferFixed
 
expandToFit(long) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
expandUserTypes() - Method in class org.apache.cassandra.db.marshal.AbstractType
Replace any instances of UserType with equivalent TupleType-s.
expandUserTypes() - Method in class org.apache.cassandra.db.marshal.CompositeType
 
expandUserTypes() - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
expandUserTypes() - Method in class org.apache.cassandra.db.marshal.ListType
 
expandUserTypes() - Method in class org.apache.cassandra.db.marshal.MapType
 
expandUserTypes() - Method in class org.apache.cassandra.db.marshal.ReversedType
 
expandUserTypes() - Method in class org.apache.cassandra.db.marshal.SetType
 
expandUserTypes() - Method in class org.apache.cassandra.db.marshal.TupleType
 
ExpirationDateOverflowHandling - Class in org.apache.cassandra.db
 
ExpirationDateOverflowHandling() - Constructor for class org.apache.cassandra.db.ExpirationDateOverflowHandling
 
ExpirationDateOverflowHandling.ExpirationDateOverflowPolicy - Enum in org.apache.cassandra.db
 
expire() - Method in class org.apache.cassandra.utils.ExpiringMemoizingSupplier
 
expired() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
EXPIRED_LIVENESS_TTL - Static variable in class org.apache.cassandra.db.LivenessInfo
Used as flag for representing an expired liveness.
EXPIRED_SSTABLE_CHECK_FREQUENCY_SECONDS_KEY - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
EXPIRED_SSTABLE_CHECK_FREQUENCY_SECONDS_KEY - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
expiredBytes() - Method in class org.apache.cassandra.net.InboundMessageHandlers
 
expiredBytes() - Method in class org.apache.cassandra.net.OutboundConnection
 
expiredCallbacks - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Number of timeouts for specific IP
expiredCount() - Method in class org.apache.cassandra.net.InboundMessageHandlers
 
expiredCount() - Method in class org.apache.cassandra.net.OutboundConnection
 
expiredSSTableCheckFrequency - Variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
expiredSSTableCheckFrequency - Variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
expiresAfterNanos() - Method in enum org.apache.cassandra.net.Verb
 
expiresAtNanos - Variable in class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
 
expiresAtNanos() - Method in class org.apache.cassandra.net.Message
 
expiresAtNanos - Variable in class org.apache.cassandra.net.Message.Header
 
expiresAtNanos(long) - Method in enum org.apache.cassandra.net.Verb
 
expireUpgradeFromVersion() - Method in class org.apache.cassandra.gms.Gossiper
 
expiring(long, int, int) - Static method in class org.apache.cassandra.db.LivenessInfo
 
expiring(ColumnMetadata, long, int, int, ByteBuffer) - Static method in class org.apache.cassandra.db.rows.BufferCell
 
expiring(ColumnMetadata, long, int, int, ByteBuffer, CellPath) - Static method in class org.apache.cassandra.db.rows.BufferCell
 
ExpiringMemoizingSupplier<T> - Class in org.apache.cassandra.utils
An implementation similar to Guava's Suppliers.memoizeWithExpiration(Supplier) but allowing for memoization to be skipped.
ExpiringMemoizingSupplier.Memoized<T> - Class in org.apache.cassandra.utils
 
ExpiringMemoizingSupplier.NotMemoized<T> - Class in org.apache.cassandra.utils
 
ExpiringMemoizingSupplier.ReturnValue<T> - Class in org.apache.cassandra.utils
 
Expression(ColumnMetadata, Operator, ByteBuffer) - Constructor for class org.apache.cassandra.db.filter.RowFilter.Expression
 
Expression - Class in org.apache.cassandra.index.sasi.plan
 
Expression(Expression) - Constructor for class org.apache.cassandra.index.sasi.plan.Expression
 
Expression(QueryController, ColumnIndex) - Constructor for class org.apache.cassandra.index.sasi.plan.Expression
 
Expression(String, AbstractType<?>) - Constructor for class org.apache.cassandra.index.sasi.plan.Expression
 
Expression.Bound - Class in org.apache.cassandra.index.sasi.plan
 
Expression.Op - Enum in org.apache.cassandra.index.sasi.plan
 
expressions - Variable in class org.apache.cassandra.cql3.WhereClause
 
expressions - Variable in class org.apache.cassandra.db.filter.RowFilter
 
expressions - Variable in class org.apache.cassandra.index.sasi.plan.Operation.Builder
 
expressions - Variable in class org.apache.cassandra.index.sasi.plan.Operation
 
extend(UnfilteredPartitionIterator, MorePartitions<? super UnfilteredPartitionIterator>) - Static method in interface org.apache.cassandra.db.transform.MorePartitions
 
extend(PartitionIterator, MorePartitions<? super PartitionIterator>) - Static method in interface org.apache.cassandra.db.transform.MorePartitions
 
extend(UnfilteredRowIterator, MoreRows<? super UnfilteredRowIterator>) - Static method in interface org.apache.cassandra.db.transform.MoreRows
 
extend(UnfilteredRowIterator, MoreRows<? super UnfilteredRowIterator>, RegularAndStaticColumns) - Static method in interface org.apache.cassandra.db.transform.MoreRows
 
extend(RowIterator, MoreRows<? super RowIterator>) - Static method in interface org.apache.cassandra.db.transform.MoreRows
 
extend(long) - Method in class org.apache.cassandra.io.util.MmappedRegions
 
extend(Replica, Runnable, UnfilteredPartitionIterator, ReadCommand, DataLimits.Counter, long, boolean) - Static method in class org.apache.cassandra.service.reads.ShortReadProtection
 
extendClusteringOrder(ColumnIdentifier, boolean) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
 
extendClusteringOrder(ColumnIdentifier, boolean) - Method in class org.apache.cassandra.cql3.statements.schema.CreateViewStatement.Raw
 
extendedVerification(boolean) - Method in class org.apache.cassandra.db.compaction.Verifier.Options.Builder
 
extendedVerification - Variable in class org.apache.cassandra.db.compaction.Verifier.Options
 
extensions(Map<String, ByteBuffer>) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
extensions(Map<String, ByteBuffer>) - Method in class org.apache.cassandra.schema.TableParams.Builder
 
extensions - Variable in class org.apache.cassandra.schema.TableParams
 
ExternalArchiver - Class in org.apache.cassandra.utils.binlog
Archives binary log files immediately when they are rolled using a configure archive command.
ExternalArchiver(String, Path, int) - Constructor for class org.apache.cassandra.utils.binlog.ExternalArchiver
 
ExternalClient(Configuration) - Constructor for class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter.ExternalClient
 
extract(ByteBuffer, int) - Method in class org.apache.cassandra.locator.InetAddressAndPort.Serializer
Extract InetAddressAndPort from the provided ByteBuffer without altering its state.
extractComponent(ByteBuffer, int) - Static method in class org.apache.cassandra.db.marshal.CompositeType
 
extractExpireTime(String[]) - Method in class org.apache.cassandra.service.StorageService
 
extractFromVersion(int) - Static method in enum org.apache.cassandra.transport.Message.Direction
 
extractIOExceptionCause(Throwable) - Static method in class org.apache.cassandra.utils.Throwables
 
extractThrowable(Runnable) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 

F

Factory() - Constructor for class org.apache.cassandra.cql3.selection.Selector.Factory
 
factory - Static variable in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
factory() - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
factory() - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
factory() - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
returns the ValueAccessor.ObjectFactory for the backing type
Factory() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader.Factory
 
Factory() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableWriter.Factory
 
factory - Variable in class org.apache.cassandra.metrics.CacheMetrics
 
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
 
fail(Message.Header, Throwable) - Method in interface org.apache.cassandra.net.InboundMessageHandlers.MessageConsumer
 
fail(Message.Header, Throwable) - Method in class org.apache.cassandra.net.InboundSink
 
fail() - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
 
fail() - Method in class org.apache.cassandra.repair.Validator
Called when some error during the validation happened.
failed - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStats
 
failed() - Method in class org.apache.cassandra.tools.NodeProbe
 
failedRepairJob(UUID, String, String, Throwable) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
failIfCanCast(Throwable, Class<T>) - Static method in class org.apache.cassandra.utils.Throwables
 
FailingConsumer<T> - Interface in org.apache.cassandra.utils
 
failParentRepair(UUID, Throwable) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
failRepairs(UUID, String, String[], Throwable) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
failSession(UUID) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
failSession(UUID, boolean) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
failSession(LocalSession, boolean) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
FailSession - Class in org.apache.cassandra.repair.messages
 
FailSession(UUID) - Constructor for class org.apache.cassandra.repair.messages.FailSession
 
failSession(String, boolean) - Method in class org.apache.cassandra.service.ActiveRepairService
 
failSession(String, boolean) - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
 
FailureDetector - Class in org.apache.cassandra.gms
This FailureDetector is an implementation of the paper titled "The Phi Accrual Failure Detector" by Hayashibara.
FailureDetector() - Constructor for class org.apache.cassandra.gms.FailureDetector
 
FailureDetectorInfo - Class in org.apache.cassandra.tools.nodetool
 
FailureDetectorInfo() - Constructor for class org.apache.cassandra.tools.nodetool.FailureDetectorInfo
 
FailureDetectorMBean - Interface in org.apache.cassandra.gms
 
FailureDetectorSourceFilter(IFailureDetector) - Constructor for class org.apache.cassandra.dht.RangeStreamer.FailureDetectorSourceFilter
 
failureReasonByEndpoint - Variable in exception org.apache.cassandra.exceptions.RequestFailureException
 
failureResponse(RequestFailureReason) - Method in class org.apache.cassandra.net.Message
Builds a failure response Message with an explicit reason, and fields inferred from request Message
failures - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
 
FakeNode(InetAddressAndPort, Integer, Collection<Token>) - Constructor for class org.apache.cassandra.dht.tokenallocator.OfflineTokenAllocator.FakeNode
 
familyLowerBound - Variable in class org.apache.cassandra.utils.CassandraVersion
 
fast(BufferPoolAllocator) - Static method in class org.apache.cassandra.net.FrameDecoderLZ4
 
FAST_COMPRESSION_LEVEL - Static variable in class org.apache.cassandra.io.compress.ZstdCompressor
 
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
 
fastInstance - Static variable in class org.apache.cassandra.net.FrameEncoderLZ4
 
fastLog12(long) - Static method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
fatalExceptionCaught(Throwable) - Method in class org.apache.cassandra.net.AbstractMessageHandler
 
fatalExceptionCaught(Throwable) - Method in class org.apache.cassandra.net.InboundMessageHandler
 
fatalExceptionCaught(Throwable) - Method in class org.apache.cassandra.transport.CQLMessageHandler
 
FBUtilities - Class in org.apache.cassandra.utils
 
FBUtilities() - Constructor for class org.apache.cassandra.utils.FBUtilities
 
fchannel - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
fdProxy - Variable in class org.apache.cassandra.tools.NodeProbe
 
fetchAsync() - Method in class org.apache.cassandra.dht.RangeStreamer
 
fetchedCellIsQueried(ColumnMetadata, CellPath) - Method in class org.apache.cassandra.db.filter.ColumnFilter
Whether the provided complex cell (identified by its column and path), which is assumed to be _fetched_ by this filter, is also _queried_ by the user.
fetchedCellIsQueried(ColumnMetadata, CellPath) - Method in class org.apache.cassandra.db.filter.ColumnFilter.SelectionColumnFilter
 
fetchedCellIsQueried(CellPath) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Tester
Must only be called if fetches(path) == true.
fetchedCellIsQueried(ColumnMetadata, CellPath) - Method in class org.apache.cassandra.db.filter.ColumnFilter.WildCardColumnFilter
 
fetchedColumnIsQueried(ColumnMetadata) - Method in class org.apache.cassandra.db.filter.ColumnFilter
Whether the provided column, which is assumed to be _fetched_ by this filter (so the caller must guarantee that fetches(column) == true, is also _queried_ by the user.
fetchedColumnIsQueried(ColumnMetadata) - Method in class org.apache.cassandra.db.filter.ColumnFilter.SelectionColumnFilter
Whether the provided complex cell (identified by its column and path), which is assumed to be _fetched_ by this filter, is also _queried_ by the user.
fetchedColumnIsQueried(ColumnMetadata) - Method in class org.apache.cassandra.db.filter.ColumnFilter.WildCardColumnFilter
 
fetchedColumns() - Method in class org.apache.cassandra.db.filter.ColumnFilter
The columns that needs to be fetched internally for this filter.
fetchedColumns() - Method in class org.apache.cassandra.db.filter.ColumnFilter.SelectionColumnFilter
 
fetchedColumns() - Method in class org.apache.cassandra.db.filter.ColumnFilter.WildCardColumnFilter
 
fetches(ColumnMetadata) - Method in class org.apache.cassandra.db.filter.ColumnFilter
Whether the provided column is fetched by this filter.
fetches(ColumnMetadata) - Method in class org.apache.cassandra.db.filter.ColumnFilter.SelectionColumnFilter
 
fetches(CellPath) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Tester
 
fetches(ColumnMetadata) - Method in class org.apache.cassandra.db.filter.ColumnFilter.WildCardColumnFilter
 
fetchesAllColumns(boolean) - Method in class org.apache.cassandra.db.filter.ColumnFilter
Whether all the (regular or static) columns are fetched by this filter.
fetchesAllColumns(boolean) - Method in class org.apache.cassandra.db.filter.ColumnFilter.SelectionColumnFilter
 
fetchesAllColumns(boolean) - Method in class org.apache.cassandra.db.filter.ColumnFilter.WildCardColumnFilter
 
fetchingStrategy - Variable in class org.apache.cassandra.db.filter.ColumnFilter.SelectionColumnFilter
 
fetchPage(int, ConsistencyLevel, ClientState, long) - Method in class org.apache.cassandra.service.pager.AggregationQueryPager
 
fetchPage(int, ConsistencyLevel, ClientState, long) - Method in class org.apache.cassandra.service.pager.MultiPartitionPager
 
fetchPage(int, ConsistencyLevel, ClientState, long) - Method in interface org.apache.cassandra.service.pager.QueryPager
Fetches the next page.
fetchPageInternal(int, ReadExecutionController) - Method in class org.apache.cassandra.service.pager.AggregationQueryPager
 
fetchPageInternal(int, ReadExecutionController) - Method in class org.apache.cassandra.service.pager.MultiPartitionPager
 
fetchPageInternal(int, ReadExecutionController) - Method in interface org.apache.cassandra.service.pager.QueryPager
Fetches the next page internally (in other, this does a local query).
FetchReplica(Replica, Replica) - Constructor for class org.apache.cassandra.dht.RangeStreamer.FetchReplica
 
field - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection
 
FieldDeletion(ColumnIdentifier, FieldIdentifier) - Constructor for class org.apache.cassandra.cql3.Operation.FieldDeletion
 
FieldIdentifier - Class in org.apache.cassandra.cql3
Identifies a field in a UDT.
FieldIdentifier(ByteBuffer) - Constructor for class org.apache.cassandra.cql3.FieldIdentifier
 
fieldName(int) - Method in class org.apache.cassandra.db.marshal.UserType
 
fieldNameAsString(int) - Method in class org.apache.cassandra.db.marshal.UserType
 
fieldNames() - Method in class org.apache.cassandra.db.marshal.UserType
 
fieldPosition(FieldIdentifier) - Method in class org.apache.cassandra.db.marshal.UserType
 
fields - Variable in class org.apache.cassandra.serializers.TupleSerializer
 
fields - Variable in class org.apache.cassandra.serializers.UserTypeSerializer
 
fieldSpecOf(ColumnSpecification, int) - Static method in class org.apache.cassandra.cql3.UserTypes
 
fieldType(int) - Method in class org.apache.cassandra.db.marshal.UserType
 
fieldTypes() - Method in class org.apache.cassandra.db.marshal.UserType
 
fifteenMinuteHitRate - Variable in class org.apache.cassandra.metrics.CacheMetrics
15m hit rate
fifteenMinuteRate() - Method in class org.apache.cassandra.metrics.RestorableMeter
Returns the 15-minute rate in terms of events per second.
file - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
 
file_cache_enabled - Variable in class org.apache.cassandra.config.Config
 
file_cache_round_up - Variable in class org.apache.cassandra.config.Config
Because of the current BufferPool slab sizes of 64 kb, we store in the file cache buffers that divide 64 kb, so we need to round the buffer sizes to powers of two.
file_cache_size_in_mb - Variable in class org.apache.cassandra.config.Config
 
FileAuditLogger - Class in org.apache.cassandra.audit
Synchronous, file-based audit logger; just uses the standard logging mechansim.
FileAuditLogger(Map<String, String>) - Constructor for class org.apache.cassandra.audit.FileAuditLogger
 
FileDataInput - Interface in org.apache.cassandra.io.util
 
fileDigestValidator(Descriptor) - Static method in class org.apache.cassandra.io.util.DataIntegrityMetadata
 
FileDigestValidator(Descriptor) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.FileDigestValidator
 
FileDirectSegment - Class in org.apache.cassandra.db.commitlog
Writes to the backing commit log file only on sync, allowing transformations of the mutations, such as compression or encryption, before writing out to disk.
fileEndPosition - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SyncSegment
offset in file where this section ends.
FileHandle - Class in org.apache.cassandra.io.util
FileHandle provides access to a file for reading, including the ones written by various SequentialWriter instances, and it is typically used by SSTableReader.
FileHandle.Builder - Class in org.apache.cassandra.io.util
Configures how the file will be read (compressed, mmapped, use cache etc.)
fileLength - Variable in class org.apache.cassandra.io.util.AbstractReaderFileProxy
 
fileLength() - Method in class org.apache.cassandra.io.util.AbstractReaderFileProxy
 
fileLength() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
 
fileLength() - Method in class org.apache.cassandra.io.util.LimitingRebufferer
 
fileLength() - Method in interface org.apache.cassandra.io.util.ReaderFileProxy
 
FileMessageHeaderSerializer() - Constructor for class org.apache.cassandra.streaming.messages.StreamMessageHeader.FileMessageHeaderSerializer
 
fileName() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
fileName - Variable in enum org.apache.cassandra.db.compaction.OperationType
 
filename(boolean) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
 
fileName - Variable in class org.apache.cassandra.streaming.ProgressInfo
 
filenameFor(Component) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
filePath() - Method in class org.apache.cassandra.io.util.ChannelProxy
 
filePath - Variable in exception org.apache.cassandra.io.util.CorruptFileException
 
files - Variable in class org.apache.cassandra.streaming.StreamSummary
Number of files to transfer.
FileSegmentInputStream - Class in org.apache.cassandra.io.util
This is the same as DataInputBuffer, i.e.
FileSegmentInputStream(ByteBuffer, String, long) - Constructor for class org.apache.cassandra.io.util.FileSegmentInputStream
 
fileSeqNum - Variable in class org.apache.cassandra.db.streaming.CassandraStreamReader
 
fileStartPosition - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SyncSegment
offset in file where this section begins.
FileUtils - Class in org.apache.cassandra.io.util
 
filter - Variable in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
filter(UnfilteredPartitionIterator, int, boolean) - Method in class org.apache.cassandra.db.filter.DataLimits
 
filter(UnfilteredRowIterator, int, boolean) - Method in class org.apache.cassandra.db.filter.DataLimits
 
filter(PartitionIterator, int, boolean, boolean) - Method in class org.apache.cassandra.db.filter.DataLimits
 
filter(TableMetadata, int) - Method in class org.apache.cassandra.db.filter.RowFilter
 
filter(UnfilteredPartitionIterator, int) - Method in class org.apache.cassandra.db.filter.RowFilter
Filters the provided iterator so that only the row satisfying the expression of this filter are included in the resulting iterator.
filter(PartitionIterator, TableMetadata, int) - Method in class org.apache.cassandra.db.filter.RowFilter
Filters the provided iterator so that only the row satisfying the expression of this filter are included in the resulting iterator.
filter(UnfilteredPartitionIterator, int) - Static method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators
 
filter(ColumnFilter, TableMetadata) - Method in class org.apache.cassandra.db.rows.BTreeRow
 
filter(ColumnFilter, DeletionTime, boolean, TableMetadata) - Method in class org.apache.cassandra.db.rows.BTreeRow
 
filter(ColumnFilter, DeletionTime, DroppedColumn, LivenessInfo) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
filter(ColumnFilter, TableMetadata) - Method in interface org.apache.cassandra.db.rows.Row
Returns a copy of this row that: 1) only includes the data for the column included by filter.
filter(ColumnFilter, DeletionTime, boolean, TableMetadata) - Method in interface org.apache.cassandra.db.rows.Row
Returns a copy of this row that: 1) only includes the data for the column included by filter.
filter(UnfilteredRowIterator, int) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
Returns a iterator that only returns rows with only live content.
Filter - Class in org.apache.cassandra.db.transform
 
Filter(int, boolean) - Constructor for class org.apache.cassandra.db.transform.Filter
 
filter(UnfilteredPartitionIterator, int) - Static method in class org.apache.cassandra.db.transform.FilteredPartitions
Filter any RangeTombstoneMarker from the iterator's iterators, transforming it into a PartitionIterator.
filter(UnfilteredPartitionIterator, Filter) - Static method in class org.apache.cassandra.db.transform.FilteredPartitions
 
filter(UnfilteredRowIterator, int) - Static method in class org.apache.cassandra.db.transform.FilteredRows
Filter any RangeTombstoneMarker from the iterator, transforming it into a RowIterator.
FILTER - Static variable in class org.apache.cassandra.io.sstable.Component
 
filter(Predicate<Replica>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
filter(Predicate<Replica>, int) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
filter(Predicate<Replica>) - Method in interface org.apache.cassandra.locator.ReplicaCollection
 
filter(Predicate<Replica>, int) - Method in interface org.apache.cassandra.locator.ReplicaCollection
 
filter(Predicate<Replica>) - Method in class org.apache.cassandra.locator.ReplicaLayout.ForRangeRead
 
filter(Predicate<Replica>) - Method in class org.apache.cassandra.locator.ReplicaLayout.ForTokenRead
 
filter(Predicate<Replica>) - Method in class org.apache.cassandra.locator.ReplicaLayout.ForTokenWrite
 
filter(Predicate<Function>) - Method in class org.apache.cassandra.schema.Functions
 
filter(Predicate<KeyspaceMetadata>) - Method in class org.apache.cassandra.schema.Keyspaces
 
filter(Predicate<TableMetadata>) - Method in class org.apache.cassandra.schema.Tables
 
filterBatchlogEndpoints(String, Multimap<String, InetAddressAndPort>, Consumer<List<?>>, Predicate<InetAddressAndPort>, Function<Integer, Integer>) - Static method in class org.apache.cassandra.locator.ReplicaPlans
 
filterCipherSuites(Iterable<String>, List<String>, Set<String>) - Method in class org.apache.cassandra.security.SSLFactory.LoggingCipherSuiteFilter
 
FilteredPartition - Class in org.apache.cassandra.db.partitions
 
FilteredPartition(RowIterator) - Constructor for class org.apache.cassandra.db.partitions.FilteredPartition
 
FilteredPartitions - Class in org.apache.cassandra.db.transform
 
FilteredRows - Class in org.apache.cassandra.db.transform
 
FilterFactory - Class in org.apache.cassandra.utils
 
FilterFactory() - Constructor for class org.apache.cassandra.utils.FilterFactory
 
filterHash(long[]) - Method in class org.apache.cassandra.db.CachedHashDecoratedKey
 
filterHash(long[]) - Method in class org.apache.cassandra.db.DecoratedKey
 
filterHash(long[]) - Method in class org.apache.cassandra.db.PreHashedDecoratedKey
 
filterHash(long[]) - Method in interface org.apache.cassandra.utils.IFilter.FilterKey
Places the murmur3 hash of the key in the given long array of size at least two.
filterLazily(Predicate<Replica>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
filterLazily(Predicate<Replica>, int) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
filterLazily(Predicate<Replica>) - Method in interface org.apache.cassandra.locator.ReplicaCollection
 
filterLazily(Predicate<Replica>, int) - Method in interface org.apache.cassandra.locator.ReplicaCollection
 
filterNotIndexed(ColumnFilter, UnfilteredRowIterator) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
Returns an iterator that only returns the rows of the provided iterator that this filter selects.
filterNotIndexed(ColumnFilter, UnfilteredRowIterator) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
 
filterNotIndexed(ColumnFilter, UnfilteredRowIterator) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
 
filterOn(String, Operator, Object) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
FilterPipelineBuilder - Class in org.apache.cassandra.index.sasi.analyzer.filter
Creates a Pipeline object for applying n pieces of logic from the provided methods to the builder in a guaranteed order
FilterPipelineBuilder(FilterPipelineTask<?, ?>) - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineBuilder
 
FilterPipelineExecutor - Class in org.apache.cassandra.index.sasi.analyzer.filter
Executes all linked Pipeline Tasks serially and returns output (if exists) from the executed logic
FilterPipelineExecutor() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineExecutor
 
FilterPipelineTask<F,T> - Class in org.apache.cassandra.index.sasi.analyzer.filter
A single task or set of work to process an input and return a single output.
FilterPipelineTask() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineTask
 
filterSuspectSSTables(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
Filters SSTables that are to be excluded from the given collection
finalFunction() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
finalize() - Method in class org.apache.cassandra.utils.binlog.BinLog
There is a race where we might not release a buffer, going to let finalization catch it since it shouldn't happen to a lot of buffers.
finalizeCommit() - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
 
FinalizeCommit - Class in org.apache.cassandra.repair.messages
 
FinalizeCommit(UUID) - Constructor for class org.apache.cassandra.repair.messages.FinalizeCommit
 
finalized - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStats
 
finalizeLength(long, int) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
finalizeMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
finalizeMetadata(String, double, long, UUID, boolean, SerializationHeader) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
FinalizePromise - Class in org.apache.cassandra.repair.messages
 
FinalizePromise(UUID, InetAddressAndPort, boolean) - Constructor for class org.apache.cassandra.repair.messages.FinalizePromise
 
finalizePropose() - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
 
FinalizePropose - Class in org.apache.cassandra.repair.messages
 
FinalizePropose(UUID) - Constructor for class org.apache.cassandra.repair.messages.FinalizePropose
 
finalReader - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter.TransactionalProxy
 
finalState - Variable in exception org.apache.cassandra.streaming.StreamException
 
find(String) - Method in class org.apache.cassandra.db.Directories
 
find(FunctionName, List<AbstractType<?>>) - Method in class org.apache.cassandra.schema.Functions
 
find(FunctionName, List<AbstractType<?>>, Functions.Filter) - Method in class org.apache.cassandra.schema.Functions
Find the function with the specified name
find(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
 
findAll(String, String) - Static method in class org.apache.cassandra.db.view.View
 
findAvailableIndexName(String) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
findBaseTable(String, String) - Static method in class org.apache.cassandra.db.view.View
 
findBlockIndex(ClusteringBound<?>, int) - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
 
findByIndex(Object[], int) - Static method in class org.apache.cassandra.utils.btree.BTree
 
findCorrectRange(Token) - Method in class org.apache.cassandra.repair.Validator
 
findFunction(FunctionName, List<AbstractType<?>>) - Method in class org.apache.cassandra.schema.Schema
Find the function with the specified name
findIndex(long[], long) - Static method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
findIndex(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
Honours result semantics of Arrays.binarySearch(long[], long), as though it were performed on the tree flattened into an array
findIndexedTable(String) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
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).
findSession(InetAddressAndPort, UUID, int, boolean) - Method in class org.apache.cassandra.streaming.StreamManager
 
finish() - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
we are done, return the finished sstables so that the caller can mark the old ones as compacted
finish() - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
 
finish() - Method in interface org.apache.cassandra.index.Index.Indexer
Notification of the end of the partition update.
finish() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
 
finish(Pair<ByteBuffer, ByteBuffer>, File, TermIterator) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
 
finish(File) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
Finishes up index building process by creating/populating index file.
finish(Descriptor, File) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
 
finish(Descriptor, Pair<ByteBuffer, ByteBuffer>, File, TermIterator) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
 
finish() - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
finish() - Method in class org.apache.cassandra.index.sasi.plan.QueryController
 
finish() - Method in class org.apache.cassandra.index.sasi.sa.IntegralSA
 
finish() - Method in class org.apache.cassandra.index.sasi.sa.SA
 
finish() - Method in class org.apache.cassandra.index.sasi.sa.SuffixSA
 
finish(long, long, boolean) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableZeroCopyWriter
 
finish(boolean) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableZeroCopyWriter
 
finish(long, long, boolean) - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
 
finish(boolean) - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
 
finish(long, long, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
finish(boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
finish(long, long, boolean) - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
 
finish(boolean) - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
 
finish(long, long, boolean) - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
 
finish(boolean) - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
 
finish() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
Finishes the new file(s) Creates final files, adds the new files to the Tracker (via replaceReader).
finish(boolean) - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
 
finish() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
finish() - Method in class org.apache.cassandra.net.FrameEncoder.Payload
 
finish() - Method in interface org.apache.cassandra.streaming.OutgoingStream
Release any resources held by the stream
finish() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
convenience method to both prepareToCommit() and commit() in one operation; only of use to outer-most transactional object of an object graph
finishCompaction(CompactionInfo.Holder) - Method in class org.apache.cassandra.db.compaction.ActiveCompactions
 
finishCompaction(CompactionInfo.Holder) - Method in interface org.apache.cassandra.db.compaction.ActiveCompactionsTracker
 
finishCompactionsAndShutdown(long, TimeUnit) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
finished() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReceiver
 
finished() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableZeroCopyWriter
 
finished() - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
 
finished() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
Open the resultant SSTableReader once it has been fully written, and all related state is ready to be finalised including other sstables being written involved in the same operation
finished() - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
 
finished() - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
 
finished() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
finished() - Method in class org.apache.cassandra.repair.SyncTask
 
finished() - Method in interface org.apache.cassandra.streaming.StreamReceiver
Called when a stream session has succesfully completed.
finishJoiningRing(boolean, Collection<Token>) - Method in class org.apache.cassandra.service.StorageService
 
finishLocalSampling(String, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
finishLocalSampling(String, int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
finishOnClose(boolean) - Method in class org.apache.cassandra.io.util.SequentialWriterOption.Builder
 
finishOnClose() - Method in class org.apache.cassandra.io.util.SequentialWriterOption
 
finishSampling(int) - Method in class org.apache.cassandra.metrics.FrequencySampler
Call to stop collecting samples, and gather the results
finishSampling(int) - Method in class org.apache.cassandra.metrics.MaxSampler
 
finishSampling(int) - Method in class org.apache.cassandra.metrics.Sampler
 
finishStartup() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
finishTransaction() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReceiver
 
finishTransfer() - Method in class org.apache.cassandra.streaming.messages.OutgoingStreamMessage
 
finishViewBuildStatus(String, String) - 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
fireProgressEvent(ProgressEvent) - Method in class org.apache.cassandra.repair.RepairRunnable
 
fireProgressEvent(String, ProgressEvent) - Method in class org.apache.cassandra.utils.progress.ProgressEventNotifierSupport
 
first() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
first - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
first - Variable in class org.apache.cassandra.io.sstable.SSTable
 
first() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
FIRST_COMPLEX_REGULAR - Static variable in class org.apache.cassandra.db.Columns
 
FIRST_COMPLEX_STATIC - Static variable in class org.apache.cassandra.db.Columns
 
firstByteValueMask(int) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
 
firstIteration - Variable in class org.apache.cassandra.index.sasi.disk.TokenTree.TokenTreeIterator
 
firstKey - Variable in class org.apache.cassandra.db.streaming.CassandraStreamHeader
 
firstKey() - Method in class org.apache.cassandra.index.sasi.utils.trie.PatriciaTrie
 
firstKeyBeyond(PartitionPosition) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Finds and returns the first key beyond a given token in this SSTable or null if no such key exists.
firstName - Variable in class org.apache.cassandra.io.sstable.IndexInfo
 
firstNotCovered(Collection<IntervalSet<CommitLogPosition>>) - Static method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
Find the earliest commit log position that is not covered by the known flushed ranges for some table.
firstToken(ArrayList<Token>, Token) - Static method in class org.apache.cassandra.locator.TokenMetadata
 
firstTokenIndex(ArrayList<Token>, Token, boolean) - Static method in class org.apache.cassandra.locator.TokenMetadata
 
firstUncontactedCandidate(Predicate<Replica>) - Method in class org.apache.cassandra.locator.ReplicaPlan.ForRead
 
fiveMinuteHitRate - Variable in class org.apache.cassandra.metrics.CacheMetrics
5m hit rate
fixedRows - Variable in class org.apache.cassandra.db.compaction.Scrubber.NegativeLocalDeletionInfoMetrics
 
FixedSpeculativeRetryPolicy - Class in org.apache.cassandra.service.reads
 
fixNonFrozenUDTIfUpgradeFrom30() - Static method in class org.apache.cassandra.io.sstable.SSTableHeaderFix
 
flags(Set<TableMetadata.Flag>) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
flags - Variable in class org.apache.cassandra.schema.TableMetadata
 
flags - Variable in class org.apache.cassandra.transport.Envelope.Header
 
flattenEntries() - Method in class org.apache.cassandra.locator.ReplicaMultimap
 
flattenValues() - Method in class org.apache.cassandra.locator.ReplicaMultimap
 
FLOAT_SIZE - Static variable in class org.apache.cassandra.db.TypeSizes
 
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(long) - Method in class org.apache.cassandra.io.util.MmappedRegions
 
floor(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
 
floor(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
 
floor(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
floor(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
floorIndex(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
 
flush(int, int) - Method in class org.apache.cassandra.db.commitlog.FileDirectSegment
 
flush(int, int) - Method in class org.apache.cassandra.db.commitlog.MemoryMappedSegment
 
flush(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionLogger
 
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.BufferedDataOutputStreamPlus
 
flush() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
flush() - Method in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
 
flush() - Method in class org.apache.cassandra.net.AsyncChannelOutputPlus
Perform an asynchronous flush, then waits until all outstanding flushes have completed
Flush - Class in org.apache.cassandra.tools.nodetool
 
Flush() - Constructor for class org.apache.cassandra.tools.nodetool.Flush
 
flush_compression - Variable in class org.apache.cassandra.config.Config
 
flushAllIndexesBlocking() - Method in class org.apache.cassandra.index.SecondaryIndexManager
Perform a blocking flush all indexes
flushAllNonCFSBackedIndexesBlocking() - Method in class org.apache.cassandra.index.SecondaryIndexManager
Performs a blocking flush of all custom indexes
flushAndFsyncBlockingly(Iterable<UUID>) - Method in class org.apache.cassandra.hints.HintsService
Flush the buffer pool for the selected target nodes, then fsync their writers.
flushBeforeTransfer(boolean) - Method in class org.apache.cassandra.streaming.StreamPlan
Set flushBeforeTransfer option.
flushBuffer(ByteBuffer, DataOutputPlus, boolean) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
 
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()
flushed() - Method in class org.apache.cassandra.net.AsyncChannelOutputPlus
 
flushedToNetwork() - Method in class org.apache.cassandra.net.AsyncChannelOutputPlus
 
FlushException(String) - Constructor for exception org.apache.cassandra.net.AsyncChannelOutputPlus.FlushException
 
FlushException(String, Throwable) - Constructor for exception org.apache.cassandra.net.AsyncChannelOutputPlus.FlushException
 
flushHighWaterMark - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
flushHistogram() - Method in class org.apache.cassandra.utils.streamhist.StreamingTombstoneHistogramBuilder
Drain the temporary spool into the final bins
flushIndexesBlocking(Set<Index>) - Method in class org.apache.cassandra.index.SecondaryIndexManager
Perform a blocking flush of selected indexes
flushingMemtables - Variable in class org.apache.cassandra.db.lifecycle.View
contains all memtables that are no longer referenced for writing and are queued for / in the process of being flushed.
flushInProgress - Static variable in class org.apache.cassandra.cache.AutoSavingCache
True if a cache flush is currently executing: only one may execute at a time.
flushLargestMemtable() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
Finds the largest memtable, as a percentage of *either* on- or off-heap memory limits, and immediately queues it for flushing.
flushLowWaterMark - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
flushRunnables(LifecycleTransaction) - 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
forAggregate(Event.SchemaChange.Change, UDAggregate) - Static method in class org.apache.cassandra.transport.Event.SchemaChange
 
ForBatch(Descriptor, TableMetadataRef, Set<Component>, StatsMetadata, SerializationHeader) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder.ForBatch
 
forBatchlogWrite(boolean) - Static method in class org.apache.cassandra.locator.ReplicaPlans
Requires that the provided endpoints are alive.
force(MappedByteBuffer) - Static method in class org.apache.cassandra.utils.SyncUtil
 
force(FileChannel, boolean) - Static method in class org.apache.cassandra.utils.SyncUtil
 
FORCE_REPAIR_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
forceBatchlogReplay() - Method in class org.apache.cassandra.batchlog.BatchlogManager
 
forceBatchlogReplay() - Method in interface org.apache.cassandra.batchlog.BatchlogManagerMBean
Forces batchlog replay.
forceBlockingFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceBlockingFlush(String...) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
forceBlockingFlush() - Method in class org.apache.cassandra.db.view.TableViews
 
forceBlockingFlush(String) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
forceCleanup(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceCompactionForTokenRange(Collection<Range<Token>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceCompactionForTokenRange(Collection<Range<Token>>) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
force a major compaction of specified key range in this column family
forceCompactionForTokenRange(ColumnFamilyStore, Collection<Range<Token>>) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
forceConviction(InetAddressAndPort) - Method in class org.apache.cassandra.gms.FailureDetector
 
forceConviction(InetAddressAndPort) - Method in interface org.apache.cassandra.gms.IFailureDetector
force conviction of endpoint in the failure detector
forcedProtocolVersion - Variable in class org.apache.cassandra.transport.Message
 
forceFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Flush if there is unflushed data in the memtables
forceFlush(CommitLogPosition) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Flush if there is unflushed data that was written to the CommitLog before @param flushIfDirtyBefore (inclusive).
forceKeyspaceCleanup(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceKeyspaceCleanup(int, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceKeyspaceCleanup(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
forceKeyspaceCleanup(int, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
forceKeyspaceCleanup(int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceKeyspaceCleanup(PrintStream, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceKeyspaceCompaction(boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceKeyspaceCompaction(boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Forces major compaction of a single keyspace
forceKeyspaceCompaction(boolean, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceKeyspaceCompactionForTokenRange(String, String, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceKeyspaceCompactionForTokenRange(String, String, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Forces major compaction of specified token range in a single keyspace
forceKeyspaceCompactionForTokenRange(String, String, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceKeyspaceFlush(String, String...) - Method in class org.apache.cassandra.service.StorageService
Flush all memtables for a keyspace and column families.
forceKeyspaceFlush(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Flush all memtables for the given column families, or all columnfamilies for the given keyspace if none are explicitly listed.
forceKeyspaceFlush(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceMajorCompaction() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceMajorCompaction(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceMajorCompaction(boolean) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
force a major compaction of this column family
forceNewerGeneration() - Method in class org.apache.cassandra.gms.Gossiper
 
forceRecycleAllSegments(Iterable<TableId>) - 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
 
forceShutdown() - Method in class org.apache.cassandra.db.compaction.CompactionManager
Shutdowns both compaction and validation executors, cancels running compaction / validation, and waits for tasks to complete if tasks were not cancelable.
forceShutdown(Throwable) - Method in class org.apache.cassandra.repair.RepairSession
clear all RepairJobs and terminate this session.
forceTerminateAllRepairSessions() - Method in class org.apache.cassandra.service.StorageService
 
forceTerminateAllRepairSessions() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
forceUserDefinedCleanup(String) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
forceUserDefinedCleanup(String) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Triggers the cleanup of user specified sstables.
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.
forceUserDefinedCompaction(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
forChunkCache() - Static method in class org.apache.cassandra.utils.memory.BufferPools
Long-lived buffers used for chunk cache and other disk access
forColumn(AbstractType<?>, ColumnIndex) - Static method in class org.apache.cassandra.index.sasi.memory.MemIndex
 
forColumns(TableMetadata, List<ColumnMetadata>, boolean) - Static method in class org.apache.cassandra.cql3.selection.Selection
 
forEach(BiConsumer<Long, InetAddressAndPort>) - Method in class org.apache.cassandra.net.ForwardingInfo
Apply the provided consumer to all (host, message_id) pairs.
forEach(HistogramDataConsumer<E>) - Method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram
 
forException(Throwable) - Static method in enum org.apache.cassandra.exceptions.RequestFailureReason
 
forExternalCalls(SocketAddress) - Static method in class org.apache.cassandra.service.ClientState
 
forForwardingCounterWrite(Keyspace, Token, Replica) - Static method in class org.apache.cassandra.locator.ReplicaPlans
A forwarding counter write is always sent to a single owning coordinator for the range, by the original coordinator (if it is not itself an owner)
forFunction(Event.SchemaChange.Change, UDFunction) - Static method in class org.apache.cassandra.transport.Event.SchemaChange
 
forGroupByInternalPaging(GroupingState) - Method in class org.apache.cassandra.db.filter.DataLimits
Creates a DataLimits instance to be used for paginating internally GROUP BY queries.
forId(int) - Static method in enum org.apache.cassandra.net.OutboundConnectionSettings.Framing
 
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(String) - Static method in class org.apache.cassandra.service.ClientState
 
forInternalCalls() - Static method in class org.apache.cassandra.service.QueryState
 
forInternalString(String) - Static method in class org.apache.cassandra.cql3.FieldIdentifier
Creates a FieldIdentifier from an internal string.
ForKey() - Constructor for class org.apache.cassandra.db.PartitionPosition.ForKey
 
forKeyRange(Range<PartitionPosition>) - Static method in class org.apache.cassandra.db.DataRange
Creates a DataRange to query all rows over the provided key range.
forLocalBatchlogWrite() - Static method in class org.apache.cassandra.locator.ReplicaPlans
 
format(C) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractCollectionCodec
 
format(Map<K, V>) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractMapCodec
 
format(T) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractTupleCodec
 
format(T) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractUDTCodec
 
format(T) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Format the given value as a valid CQL literal according to the CQL type handled by this codec.
format - Static variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
format - Variable in class org.apache.cassandra.db.streaming.CassandraStreamHeader
SSTable format
format - Variable in class org.apache.cassandra.db.streaming.CassandraStreamReader
 
format - Variable in class org.apache.cassandra.io.sstable.format.Version
 
formatField(T, int) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractTupleCodec
Format an individual field in an object as a CQL literal, as part of formatting the whole object (see TypeCodec.AbstractTupleCodec.format(Object)).
formatField(T, String) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractUDTCodec
Format an individual field in an object as a CQL literal, as part of formatting the whole object (see TypeCodec.AbstractUDTCodec.format(Object)).
formatResults(List<RoleResource>) - Method in class org.apache.cassandra.cql3.statements.ListRolesStatement
 
formatResults(List<RoleResource>) - Method in class org.apache.cassandra.cql3.statements.ListUsersStatement
 
formatType - Variable in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
 
formatType - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
formatType() - Method in class org.apache.cassandra.io.sstable.format.VersionAndType
 
forName(String) - Static method in enum org.apache.cassandra.schema.CompactionParams.TombstoneOption
 
forNetworking() - Static method in class org.apache.cassandra.utils.memory.BufferPools
Short-lived buffers used for internode messaging or client-server connections.
forOfflineTools(TableMetadata) - Static method in class org.apache.cassandra.schema.TableMetadataRef
Create a new ref to the passed TableMetadata for use by offline tools only.
forPaging(AbstractBounds<PartitionPosition>, ClusteringComparator, Clustering<?>, boolean) - Method in class org.apache.cassandra.db.DataRange
Returns a new DataRange for use when paging this range.
forPaging(ClusteringComparator, Clustering<?>, boolean) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
Returns a filter for continuing the paging of this filter given the last returned clustering prefix.
forPaging(ClusteringComparator, Clustering<?>, boolean) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
 
forPaging(ClusteringComparator, Clustering<?>, boolean) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
 
forPaging(int) - Method in class org.apache.cassandra.db.filter.DataLimits
 
forPaging(int, ByteBuffer, int) - Method in class org.apache.cassandra.db.filter.DataLimits
 
forPaging(Clustering<?>, DataLimits) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
forPaging(Clustering<?>, DataLimits) - Method in interface org.apache.cassandra.db.SinglePartitionReadQuery
Returns a new SinglePartitionReadQuery suitable to paging from the last returned row.
forPaging(ClusteringComparator, Clustering<?>, boolean, boolean) - Method in class org.apache.cassandra.db.Slice
Returns a slice for continuing paging from the last returned clustering prefix.
forPaging(ClusteringComparator, Clustering<?>, boolean, boolean) - Method in class org.apache.cassandra.db.Slices
Returns slices for continuing the paging of those slices given the last returned clustering prefix.
forPaging(Clustering<?>, DataLimits) - Method in class org.apache.cassandra.db.VirtualTableSinglePartitionReadQuery
 
forPaxos(Keyspace, DecoratedKey, ConsistencyLevel) - Static method in class org.apache.cassandra.locator.ReplicaPlans
Construct the plan for a paxos round - NOT the write or read consistency level for either the write or comparison, but for the paxos linearisation agreement.
forProgress(long, long) - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
forProtocolVersion(ProtocolVersion) - Static method in class org.apache.cassandra.cql3.QueryOptions
 
forQuoted(String) - Static method in class org.apache.cassandra.cql3.FieldIdentifier
Creates a FieldIdentifier from a quoted identifier string.
forQuoted(String) - Static method in class org.apache.cassandra.cql3.selection.Selectable.RawIdentifier
Creates a RawIdentifier from a quoted identifier string.
ForRangeRead(AbstractReplicationStrategy, AbstractBounds<PartitionPosition>, EndpointsForRange) - Constructor for class org.apache.cassandra.locator.ReplicaLayout.ForRangeRead
 
ForRangeRead(Keyspace, AbstractReplicationStrategy, ConsistencyLevel, AbstractBounds<PartitionPosition>, EndpointsForRange, EndpointsForRange, int) - Constructor for class org.apache.cassandra.locator.ReplicaPlan.ForRangeRead
 
forRangeRead(Keyspace, ConsistencyLevel, AbstractBounds<PartitionPosition>, int) - Static method in class org.apache.cassandra.locator.ReplicaPlans
Construct a plan for reading the provided range at the provided consistency level.
ForRead(Descriptor, TableMetadataRef, ValidationMetadata, boolean, Set<Component>, StatsMetadata, SerializationHeader) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder.ForRead
 
forRead(Keyspace, Token, ConsistencyLevel, SpeculativeRetryPolicy) - Static method in class org.apache.cassandra.locator.ReplicaPlans
Construct a plan for reading the provided token at the provided consistency level.
forReadRepair(Token, ReplicaPlan.ForRead<?>) - Static method in class org.apache.cassandra.locator.ReplicaPlans
 
forReadResponse() - Static method in class org.apache.cassandra.db.Digest
 
forRepairedDataTracking() - Static method in class org.apache.cassandra.db.Digest
 
forSchema() - Static method in class org.apache.cassandra.db.Digest
 
forShortReadRetry(int) - Method in class org.apache.cassandra.db.filter.DataLimits
 
forSingleReplicaRead(Keyspace, Token, Replica) - Static method in class org.apache.cassandra.locator.ReplicaPlans
Construct a plan for reading from a single node - this permits no speculation or read-repair
forSingleReplicaRead(Keyspace, AbstractBounds<PartitionPosition>, Replica, int) - Static method in class org.apache.cassandra.locator.ReplicaPlans
Construct a plan for reading from a single node - this permits no speculation or read-repair
forSingleReplicaWrite(Keyspace, Token, Replica) - Static method in class org.apache.cassandra.locator.ReplicaPlans
Construct a ReplicaPlan for writing to exactly one node, with CL.ONE.
forStatement(int) - Method in class org.apache.cassandra.cql3.BatchQueryOptions
 
forSubRange(AbstractBounds<PartitionPosition>) - Method in class org.apache.cassandra.db.DataRange
Returns a new DataRange equivalent to this one but restricted to the provided sub-range.
forSubRange(AbstractBounds<PartitionPosition>) - Method in class org.apache.cassandra.db.DataRange.Paging
 
forSubRange(AbstractBounds<PartitionPosition>, boolean) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
Returns an equivalent command but that only queries data within the provided range.
forSystemTable(String, String) - Static method in class org.apache.cassandra.schema.TableId
Creates the UUID of a system table.
forTable(TableId) - Method in class org.apache.cassandra.db.view.ViewManager
 
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.
forTable(TableId) - Method in class org.apache.cassandra.schema.Views
 
forToken(Token) - Method in class org.apache.cassandra.locator.EndpointsForRange
 
forTokenRange(Range<Token>) - Static method in class org.apache.cassandra.db.DataRange
Creates a DataRange to query all rows over the provided token range.
ForTokenRead(AbstractReplicationStrategy, EndpointsForToken) - Constructor for class org.apache.cassandra.locator.ReplicaLayout.ForTokenRead
 
ForTokenRead(Keyspace, AbstractReplicationStrategy, ConsistencyLevel, EndpointsForToken, EndpointsForToken) - Constructor for class org.apache.cassandra.locator.ReplicaPlan.ForTokenRead
 
forTokenWrite(AbstractReplicationStrategy, EndpointsForToken, EndpointsForToken) - Static method in class org.apache.cassandra.locator.ReplicaLayout
 
ForTokenWrite(AbstractReplicationStrategy, EndpointsForToken, EndpointsForToken) - Constructor for class org.apache.cassandra.locator.ReplicaLayout.ForTokenWrite
 
ForTokenWrite(AbstractReplicationStrategy, EndpointsForToken, EndpointsForToken, EndpointsForToken) - Constructor for class org.apache.cassandra.locator.ReplicaLayout.ForTokenWrite
 
ForTokenWrite(Keyspace, AbstractReplicationStrategy, ConsistencyLevel, EndpointsForToken, EndpointsForToken, EndpointsForToken, EndpointsForToken) - Constructor for class org.apache.cassandra.locator.ReplicaPlan.ForTokenWrite
 
forTokenWriteLiveAndDown(Keyspace, Token) - Static method in class org.apache.cassandra.locator.ReplicaLayout
Gets the 'natural' and 'pending' replicas that own a given token, with no filtering or processing.
forUnquoted(String) - Static method in class org.apache.cassandra.cql3.FieldIdentifier
Creates a FieldIdentifier from an unquoted identifier string.
forUnquoted(String) - Static method in class org.apache.cassandra.cql3.selection.Selectable.RawIdentifier
Creates a RawIdentifier from an unquoted identifier string.
forValidator() - Static method in class org.apache.cassandra.db.Digest
 
ForwardingInfo - Class in org.apache.cassandra.net
A container used to store a node -> message_id map for inter-DC write forwarding.
ForwardingInfo(List<InetAddressAndPort>, long[]) - Constructor for class org.apache.cassandra.net.ForwardingInfo
 
forwardMap - Variable in class org.apache.cassandra.utils.BiMultiValMap
 
forwardMap - Variable in class org.apache.cassandra.utils.ConcurrentBiMap
 
forwardTo() - Method in class org.apache.cassandra.net.Message
Used for cross-DC write optimisation - pick one node in the DC and have it relay the write to its local peers
forWrite(Keyspace, ConsistencyLevel, Token, ReplicaPlans.Selector) - Static method in class org.apache.cassandra.locator.ReplicaPlans
 
forWrite(Keyspace, ConsistencyLevel, EndpointsForToken, EndpointsForToken, Predicate<Replica>, ReplicaPlans.Selector) - Static method in class org.apache.cassandra.locator.ReplicaPlans
 
forWrite(Keyspace, ConsistencyLevel, ReplicaLayout.ForTokenWrite, ReplicaPlans.Selector) - Static method in class org.apache.cassandra.locator.ReplicaPlans
 
forWrite(Keyspace, ConsistencyLevel, ReplicaLayout.ForTokenWrite, ReplicaLayout.ForTokenWrite, ReplicaPlans.Selector) - Static method in class org.apache.cassandra.locator.ReplicaPlans
 
ForWriter(Descriptor, TableMetadataRef, long, Set<Component>, StatsMetadata, SSTableReader.OpenReason, SerializationHeader) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder.ForWriter
 
FrameDecoder - Class in org.apache.cassandra.net
A Netty inbound handler that decodes incoming frames and passes them forward to InboundMessageHandler for processing.
frameDecoder(String, BufferPoolAllocator) - Method in class org.apache.cassandra.transport.PipelineConfigurator
 
FrameDecoder.CorruptFrame - Class in org.apache.cassandra.net
A corrupted frame was encountered; this represents the knowledge we have about this frame, and whether or not the stream is recoverable.
FrameDecoder.Frame - Class in org.apache.cassandra.net
 
FrameDecoder.FrameProcessor - Interface in org.apache.cassandra.net
 
FrameDecoder.IntactFrame - Class in org.apache.cassandra.net
The payload bytes of a complete frame, i.e.
FrameDecoderCrc - Class in org.apache.cassandra.net
Framing format that protects integrity of data in movement with CRCs (of both header and payload).
FrameDecoderCrc(BufferPoolAllocator) - Constructor for class org.apache.cassandra.net.FrameDecoderCrc
 
FrameDecoderLZ4 - Class in org.apache.cassandra.net
Framing format that compresses payloads with LZ4, and protects integrity of data in movement with CRCs (of both header and payload).
FrameEncoder - Class in org.apache.cassandra.net
 
FrameEncoder() - Constructor for class org.apache.cassandra.net.FrameEncoder
 
frameEncoder(String) - Method in class org.apache.cassandra.transport.PipelineConfigurator
 
FrameEncoder.Payload - Class in org.apache.cassandra.net
An abstraction useful for transparently allocating buffers that can be written to upstream of the FrameEncoder without knowledge of the encoder's frame layout, while ensuring enough space to write the remainder of the frame's contents is reserved.
FrameEncoder.PayloadAllocator - Interface in org.apache.cassandra.net
 
FrameEncoderCrc - Class in org.apache.cassandra.net
Please see FrameDecoderCrc for description of the framing produced by this encoder.
FrameEncoderCrc() - Constructor for class org.apache.cassandra.net.FrameEncoderCrc
 
FrameEncoderLZ4 - Class in org.apache.cassandra.net
Please see FrameDecoderLZ4 for description of the framing produced by this encoder.
frameSize - Variable in class org.apache.cassandra.net.FrameDecoder.Frame
 
framing - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
framing(ConnectionCategory) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
free() - Method in class org.apache.cassandra.cache.RefCountedMemory
 
free() - Method in class org.apache.cassandra.io.util.Memory
 
free() - Method in class org.apache.cassandra.io.util.SafeMemory
 
free(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
freeDirect(ByteBuffer) - Method in class org.apache.cassandra.net.BufferPoolAllocator.Wrapped
 
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
 
freeze() - Method in class org.apache.cassandra.db.marshal.UserType
 
freezeNestedMulticellTypes() - Method in class org.apache.cassandra.db.marshal.AbstractType
Returns an AbstractType instance that is equivalent to this one, but with all nested UDTs and collections explicitly frozen.
freezeNestedMulticellTypes() - Method in class org.apache.cassandra.db.marshal.ListType
 
freezeNestedMulticellTypes() - Method in class org.apache.cassandra.db.marshal.MapType
 
freezeNestedMulticellTypes() - Method in class org.apache.cassandra.db.marshal.SetType
 
freezeNestedMulticellTypes() - Method in class org.apache.cassandra.db.marshal.UserType
 
FrequencySampler<T> - Class in org.apache.cassandra.metrics
Find the most frequent sample.
FrequencySampler() - Constructor for class org.apache.cassandra.metrics.FrequencySampler
 
from(CQL3Type) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
from(String) - Static method in class org.apache.cassandra.cql3.Duration
Converts a String into a duration.
from(String) - Static method in class org.apache.cassandra.cql3.functions.types.Duration
Converts a String into a duration.
from - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithSliceSelection
 
from(Collection<ColumnMetadata>) - Static method in class org.apache.cassandra.db.Columns
Returns a new Columns object holing the same columns than the provided set.
from(UntypedResultSet) - Static method in class org.apache.cassandra.db.compaction.CompactionHistoryTabularData
 
from(String, String, String, Map.Entry<String, Directories.SnapshotSizeDetails>, TabularDataSupport) - Static method in class org.apache.cassandra.db.SnapshotDetailsTabularData
 
from(InetAddressAndPort) - Method in class org.apache.cassandra.net.Message.Builder
 
from() - Method in class org.apache.cassandra.net.Message
Sender of the message.
from - Variable in class org.apache.cassandra.net.Message.Header
 
from - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
from() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
from - Variable in class org.apache.cassandra.service.reads.DigestResolver.DigestResolverDebugResult
 
from - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
 
from(String) - Static method in class org.apache.cassandra.tools.nodetool.stats.CompactionHistoryPrinter
 
from(String, boolean) - Static method in class org.apache.cassandra.tools.nodetool.stats.TableStatsPrinter
 
from(String) - Static method in class org.apache.cassandra.tools.nodetool.stats.TpStatsPrinter
 
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, int, int) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
fromBytes(ByteBuffer, int) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
Deserialize a partition update from a provided byte buffer.
fromCode(int) - Static method in enum org.apache.cassandra.db.ConsistencyLevel
 
fromCode(int) - Static method in enum org.apache.cassandra.exceptions.RequestFailureReason
 
fromComposite(CompositeData) - Static method in class org.apache.cassandra.repair.consistent.admin.CleanupSummary
 
fromComposite(CompositeData) - Static method in class org.apache.cassandra.repair.consistent.admin.PendingStat
 
fromComposite(CompositeData) - Static method in class org.apache.cassandra.repair.consistent.admin.PendingStats
 
fromComposite(CompositeData) - Static method in class org.apache.cassandra.repair.consistent.admin.RepairStats
 
fromCompositeData(CompositeData) - Static method in class org.apache.cassandra.fql.FullQueryLoggerOptionsCompositeData
 
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
 
fromContext(WriteContext) - Static method in class org.apache.cassandra.db.CassandraWriteContext
 
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
 
fromExcl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
fromFileName(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
fromFileName(String) - Static method in enum org.apache.cassandra.db.compaction.OperationType
 
fromFilename(String) - Static method in class org.apache.cassandra.io.sstable.Descriptor
Parse a sstable filename into a Descriptor.
fromFilename(File) - Static method in class org.apache.cassandra.io.sstable.Descriptor
Parse a sstable filename into a Descriptor.
fromFilenameWithComponent(File) - Static method in class org.apache.cassandra.io.sstable.Descriptor
Parse a sstable filename, extracting both the Descriptor and Component part.
fromHeader(File, EncryptionContext) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
fromHexString(String) - Static method in class org.apache.cassandra.cql3.functions.types.utils.Bytes
Parse an hex string representing a CQL blob.
fromId(int) - Static method in enum org.apache.cassandra.net.ConnectionType
 
fromId(int) - Static method in enum org.apache.cassandra.net.Verb
 
fromId(int) - Static method in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
 
fromIncl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
fromIndexTargets(List<IndexTarget>, String, IndexMetadata.Kind, Map<String, String>) - Static method in class org.apache.cassandra.schema.IndexMetadata
 
fromInt(int) - Static method in class org.apache.cassandra.utils.CounterId
Pack an int in a valid CounterId so that the resulting ids respects the numerical ordering.
fromInternalRow(TableMetadata, DecoratedKey, Row) - Static method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
fromIterator(UnfilteredRowIterator, ColumnFilter) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
Turns the given iterator into an update.
fromIterator(RowIterator, ColumnFilter) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
Turns the given iterator into an update.
FromJsonFct - Class in org.apache.cassandra.cql3.functions
 
fromJsonList(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
fromJsonMap(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.AbstractType
Given a parsed JSON string, return a byte representation of the object.
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.BooleanType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.BytesType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ByteType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.DateType
Deprecated.
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.DurationType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.EmptyType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.FloatType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.FrozenType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.InetAddressType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ListType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.LongType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.MapType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.SetType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.ShortType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.TimestampType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.TimeType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.TupleType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.UserType
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
fromKeyExcl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder.PartitionRangeBuilder
 
fromKeyIncl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder.PartitionRangeBuilder
 
fromMap(Map<String, Object>, Class<T>) - Static method in class org.apache.cassandra.config.YamlConfigurationLoader
 
fromMap(Map<String, Object>, boolean, Class<T>) - Static method in class org.apache.cassandra.config.YamlConfigurationLoader
 
fromMap(Map<String, String>) - Static method in class org.apache.cassandra.schema.CachingParams
 
fromMap(Map<String, String>) - Static method in class org.apache.cassandra.schema.CompactionParams
 
fromMap(Map<String, String>) - Static method in class org.apache.cassandra.schema.CompressionParams
 
fromMap(Map<String, String>) - Static method in class org.apache.cassandra.schema.ReplicationParams
 
fromMapWithDefaults(Map<String, String>, Map<String, String>) - Static method in class org.apache.cassandra.schema.ReplicationParams
 
fromMillisSinceEpoch(long) - Method in interface org.apache.cassandra.utils.MonotonicClockTranslation
accepts millis since epoch, returns nanoTime in the related clock
fromName(String) - Static method in class org.apache.cassandra.auth.DataResource
Parses a data resource name into a DataResource instance.
fromName(String) - Static method in class org.apache.cassandra.auth.FunctionResource
Parses a resource name into a FunctionResource instance.
fromName(String) - Static method in class org.apache.cassandra.auth.JMXResource
Parses a role resource name into a RoleResource instance.
fromName(String) - Static method in class org.apache.cassandra.auth.Resources
Creates an IResource instance from its external name.
fromName(String) - Static method in class org.apache.cassandra.auth.RoleResource
Parses a role resource name into a RoleResource instance.
fromName(String) - Static method in enum org.apache.cassandra.repair.RepairParallelism
Return RepairParallelism that match given name.
fromOpcode(int, Message.Direction) - Static method in enum org.apache.cassandra.transport.Message.Type
 
fromPoolName(String) - Static method in enum org.apache.cassandra.concurrent.Stage
 
fromPrepared(CQLStatement) - Static method in class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
 
fromPrepared(CQLStatement) - Static method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
fromReceiver(StreamReceiver) - Static method in class org.apache.cassandra.db.streaming.CassandraStreamReceiver
 
fromRepairState(String, String, RepairedState.Stats) - Static method in class org.apache.cassandra.repair.consistent.admin.RepairStats
 
fromRoleResource(RoleResource, IRoleManager) - Static method in class org.apache.cassandra.auth.Roles
Constructs a Role object from a RoleResource, using the methods of the supplied IRoleManager.
fromSchemaMetadata(String, IndexMetadata.Kind, Map<String, String>) - Static method in class org.apache.cassandra.schema.IndexMetadata
 
fromSelectors(TableMetadata, List<Selectable>, VariableSpecifications, Set<ColumnMetadata>, Set<ColumnMetadata>, boolean, boolean, boolean) - Static method in class org.apache.cassandra.cql3.selection.Selection
 
fromSerialized(ByteBuffer, ListType, ProtocolVersion) - Static method in class org.apache.cassandra.cql3.Lists.Value
 
fromSerialized(ByteBuffer, MapType, ProtocolVersion) - Static method in class org.apache.cassandra.cql3.Maps.Value
 
fromSerialized(ByteBuffer, SetType, ProtocolVersion) - 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
 
fromSerialized(ByteBuffer, UserType) - Static method in class org.apache.cassandra.cql3.UserTypes.Value
 
fromStream(OutgoingStream) - Static method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
 
fromString(String) - Static method in enum org.apache.cassandra.cql3.statements.schema.IndexTarget.Type
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.AbstractType
get a byte representation of the given string.
fromString(String) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.BooleanType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.BytesType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.ByteType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.CollectionType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.DateType
Deprecated.
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.DurationType
 
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.LongType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.ShortType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.TimestampType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.TimeType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.TupleType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
fromString(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
fromString(String) - Static method in class org.apache.cassandra.io.sstable.format.VersionAndType
 
fromString(String) - Static method in class org.apache.cassandra.locator.ReplicationFactor
 
fromString(String) - Static method in class org.apache.cassandra.schema.TableId
 
fromString(String) - Static method in enum org.apache.cassandra.service.reads.repair.ReadRepairStrategy
 
fromString(String) - Static method in interface org.apache.cassandra.service.reads.SpeculativeRetryPolicy
 
fromString(String) - Static method in enum org.apache.cassandra.streaming.StreamOperation
 
fromStringSet(Set<String>) - Static method in enum org.apache.cassandra.schema.TableMetadata.Flag
 
fromTimeInMillis(long) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
fromTimeInMillis(long) - Method in class org.apache.cassandra.db.marshal.TemporalType
Returns the temporal value corresponding to the specified UNIX timestamp.
fromTimeInMillis(long) - Method in class org.apache.cassandra.db.marshal.TimestampType
 
fromType(AbstractType, ProtocolVersion) - Static method in enum org.apache.cassandra.transport.DataType
 
fromUUID(UUID) - Static method in class org.apache.cassandra.schema.TableId
 
fromValue(int) - Static method in enum org.apache.cassandra.exceptions.ExceptionCode
 
fromValue(int) - Static method in enum org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer.TokenType
 
frozen - Variable 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
 
FSDiskFullWriteError - Error in org.apache.cassandra.io
 
FSDiskFullWriteError(String, long) - Constructor for error org.apache.cassandra.io.FSDiskFullWriteError
 
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.
FSNoDiskAvailableForWriteError - Error in org.apache.cassandra.io
Thrown when all the disks used by a given keyspace have been marked as unwriteable.
FSNoDiskAvailableForWriteError(String) - Constructor for error org.apache.cassandra.io.FSNoDiskAvailableForWriteError
 
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
 
FSWriteError(Throwable) - Constructor for error org.apache.cassandra.io.FSWriteError
 
full - Variable in class org.apache.cassandra.db.SystemKeyspace.AvailableRanges
 
full - Variable in class org.apache.cassandra.streaming.StreamRequest
 
full_query_logging_options - Variable in class org.apache.cassandra.config.Config
 
FULL_RANGE - Static variable in class org.apache.cassandra.locator.SystemReplicas
 
FullBTreeSearchIterator<K,V> - Class in org.apache.cassandra.utils.btree
 
FullBTreeSearchIterator(Object[], Comparator<? super K>, BTree.Dir) - Constructor for class org.apache.cassandra.utils.btree.FullBTreeSearchIterator
 
fullCollection(ColumnIdentifier) - Static method in class org.apache.cassandra.cql3.statements.schema.IndexTarget.Raw
 
fullName - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
fullOnly(int) - Static method in class org.apache.cassandra.locator.ReplicationFactor
 
fullPartitionDelete(TableMetadata, DecoratedKey, long, int) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
Creates an immutable partition update that entirely deletes a given partition.
fullPartitionDelete(TableMetadata, ByteBuffer, long, int) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
Creates a partition update that entirely deletes a given partition.
fullPartitionRead(TableMetadata, int, DecoratedKey) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
Creates a new read command that queries a single partition in its entirety.
fullPartitionRead(TableMetadata, int, ByteBuffer) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
Creates a new read command that queries a single partition in its entirety.
FullQueryLogger - Class in org.apache.cassandra.fql
A logger that logs entire query contents after the query finishes (or times out).
FullQueryLogger() - Constructor for class org.apache.cassandra.fql.FullQueryLogger
 
FullQueryLogger.Batch - Class in org.apache.cassandra.fql
 
FullQueryLogger.Query - Class in org.apache.cassandra.fql
 
FullQueryLoggerOptions - Class in org.apache.cassandra.fql
 
FullQueryLoggerOptions() - Constructor for class org.apache.cassandra.fql.FullQueryLoggerOptions
 
FullQueryLoggerOptionsCompositeData - Class in org.apache.cassandra.fql
 
FullQueryLoggerOptionsCompositeData() - Constructor for class org.apache.cassandra.fql.FullQueryLoggerOptionsCompositeData
 
fullReplica(InetAddressAndPort, Range<Token>) - Static method in class org.apache.cassandra.locator.Replica
 
fullReplica(InetAddressAndPort, Token, Token) - Static method in class org.apache.cassandra.locator.Replica
 
fullReplicas() - Method in class org.apache.cassandra.locator.Replicas.ReplicaCount
 
fullReplicas - Variable in class org.apache.cassandra.locator.ReplicationFactor
 
function(String, String, List<AbstractType<?>>) - Static method in class org.apache.cassandra.auth.FunctionResource
Creates a FunctionResource representing a specific, keyspace-scoped function.
function(Function) - Static method in class org.apache.cassandra.auth.FunctionResource
 
Function - Interface in org.apache.cassandra.cql3.functions
 
function - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithFunction
 
function(String, String) - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
Creates a DescribeStatement for DESCRIBE FUNCTION.
FunctionCall - Class in org.apache.cassandra.cql3.functions
 
FunctionCall.Raw - Class in org.apache.cassandra.cql3.functions
 
FunctionExecutionException - Exception in org.apache.cassandra.exceptions
 
FunctionExecutionException(FunctionName, List<String>, String) - Constructor for exception org.apache.cassandra.exceptions.FunctionExecutionException
 
functionFromCql(String, String, List<CQL3Type.Raw>) - Static method in class org.apache.cassandra.auth.FunctionResource
Creates a FunctionResource representing a specific, keyspace-scoped function.
functionFromCql(FunctionName, List<CQL3Type.Raw>) - Static method in class org.apache.cassandra.auth.FunctionResource
 
FunctionName - Class in org.apache.cassandra.cql3.functions
 
FunctionName(String, String) - Constructor for class org.apache.cassandra.cql3.functions.FunctionName
 
functionName - Variable in exception org.apache.cassandra.exceptions.FunctionExecutionException
 
FunctionResolver - Class in org.apache.cassandra.cql3.functions
 
FunctionResource - Class in org.apache.cassandra.auth
IResource implementation representing functions.
functions() - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
Creates a DescribeStatement for DESCRIBE FUNCTIONS.
functions - Variable in class org.apache.cassandra.index.internal.CassandraIndex
 
Functions - Class in org.apache.cassandra.schema
An immutable container for a keyspace's UDAs and UDFs (and, in case of SystemKeyspace, native functions and aggregates).
functions - Variable in class org.apache.cassandra.schema.KeyspaceMetadata
 
FUNCTIONS - Static variable in class org.apache.cassandra.schema.SchemaKeyspace
 
Functions.Builder - Class in org.apache.cassandra.schema
 
Functions.Filter - Enum in org.apache.cassandra.schema
 
Functions.FunctionsDiff<T extends Function> - Class in org.apache.cassandra.schema
 
fwdFrmSerializer - Static variable in class org.apache.cassandra.locator.InetAddressAndPort.FwdFrmSerializer
 

G

garbageCollect(CompactionParams.TombstoneOption, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
garbageCollect(String, int, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
garbageCollect(String, int, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Rewrites all sstables from the given tables to remove deleted data.
garbageCollect(String, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
garbageCollect(PrintStream, String, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
GarbageCollect - Class in org.apache.cassandra.tools.nodetool
 
GarbageCollect() - Constructor for class org.apache.cassandra.tools.nodetool.GarbageCollect
 
GC_ALL - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
 
gc_log_threshold_in_ms - Variable in class org.apache.cassandra.config.Config
 
gc_warn_threshold_in_ms - Variable in class org.apache.cassandra.config.Config
 
gcBefore - Variable in class org.apache.cassandra.db.AbstractCompactionController
 
gcBefore(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
gcBefore - Variable in class org.apache.cassandra.db.compaction.CompactionTask
 
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.schema.TableMetadata.Builder
 
gcGraceSeconds(int) - Method in class org.apache.cassandra.schema.TableParams.Builder
 
gcGraceSeconds - Variable in class org.apache.cassandra.schema.TableParams
 
GCInspector - Class in org.apache.cassandra.service
 
GCInspector() - Constructor for class org.apache.cassandra.service.GCInspector
 
GCInspectorMXBean - Interface in org.apache.cassandra.service
 
gcProxy - Variable in class org.apache.cassandra.tools.NodeProbe
 
GcStats - Class in org.apache.cassandra.tools.nodetool
 
GcStats() - Constructor for class org.apache.cassandra.tools.nodetool.GcStats
 
GE - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader.Operator
 
generate() - Static method in class org.apache.cassandra.schema.TableId
 
generate() - Static method in class org.apache.cassandra.utils.CounterId
 
GENERATED_NOW_IN_SECONDS - Static variable in class org.apache.cassandra.fql.FullQueryLogger
 
GENERATED_TIMESTAMP - Static variable in class org.apache.cassandra.fql.FullQueryLogger
 
generateDefaultIndexName(String, ColumnIdentifier) - Static method in class org.apache.cassandra.schema.IndexMetadata
 
generateDefaultIndexName(String) - Static method in class org.apache.cassandra.schema.IndexMetadata
 
generatedNowInSeconds() - Method in class org.apache.cassandra.service.QueryState
 
generatedTimestamp() - Method in class org.apache.cassandra.service.QueryState
 
GenerateTokens - Class in org.apache.cassandra.tools
 
GenerateTokens() - Constructor for class org.apache.cassandra.tools.GenerateTokens
 
generateViewUpdates(Collection<View>, UnfilteredRowIterator, UnfilteredRowIterator, int, boolean) - Method in class org.apache.cassandra.db.view.TableViews
Given some updates on the base table of this object and the existing values for the rows affected by that update, generates the mutation to be applied to the provided views.
generateViewUpdates() - Method in class org.apache.cassandra.db.view.ViewUpdateGenerator
Returns the updates that needs to be done to the view given the base table updates passed to ViewUpdateGenerator.addBaseTableUpdate(org.apache.cassandra.db.rows.Row, org.apache.cassandra.db.rows.Row).
GENERATION - Static variable in class org.apache.cassandra.auth.AuthKeyspace
Generation is used as a timestamp for automatic table creation on startup.
generation - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
GENERATION - Static variable in class org.apache.cassandra.repair.SystemDistributedKeyspace
Generation is used as a timestamp for automatic table creation on startup.
GENERATION - Static variable in class org.apache.cassandra.tracing.TraceKeyspace
Generation is used as a timestamp for automatic table creation on startup.
generationReverseComparator - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
generic(String, String) - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
Creates a DescribeStatement for the generic DESCRIBE ....
get(K) - Method in class org.apache.cassandra.auth.AuthCache
Retrieve a value from the cache.
get(K) - Method in class org.apache.cassandra.cache.CaffeineCache
 
get(K) - Method in interface org.apache.cassandra.cache.ICache
 
get(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
get(K) - Method in class org.apache.cassandra.cache.SerializingCache
 
get() - Method in interface org.apache.cassandra.concurrent.ExecutorLocal
This is called when scheduling the task, and also before calling ExecutorLocal.set(Object) when running on a executor thread.
get(String) - Method in class org.apache.cassandra.config.TransparentDataEncryptionOptions
 
get(ProtocolVersion) - Method in class org.apache.cassandra.cql3.Constants.Value
 
get(String, FunctionName, List<? extends AssignmentTestable>, String, String, AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.FunctionResolver
 
get(String, Class<T>) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name converted to the given Java type.
get(String, TypeToken<T>) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name converted to the given Java type.
get(String, TypeCodec<T>) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name converted using the given TypeCodec.
get(int, Class<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value converted to the given Java type.
get(int, TypeToken<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value converted to the given Java type.
get(int, TypeCodec<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value converted using the given TypeCodec.
get(String, Class<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name converted to the given Java type.
get(String, TypeToken<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name converted to the given Java type.
get(String, TypeCodec<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name converted using the given TypeCodec.
get(ProtocolVersion) - Method in class org.apache.cassandra.cql3.Lists.Value
 
get(ProtocolVersion) - Method in class org.apache.cassandra.cql3.Maps.Value
 
get(ProtocolVersion) - Method in class org.apache.cassandra.cql3.Sets.Value
 
get(ProtocolVersion) - Method in class org.apache.cassandra.cql3.Term.Terminal
 
get(ProtocolVersion) - Method in class org.apache.cassandra.cql3.Tuples.InValue
 
get(ProtocolVersion) - Method in class org.apache.cassandra.cql3.Tuples.Value
 
get(ProtocolVersion) - Method in class org.apache.cassandra.cql3.UserTypes.Value
 
get(int) - Method in class org.apache.cassandra.db.AbstractOnHeapClusteringPrefix
 
get(int) - Method in interface org.apache.cassandra.db.ClusteringPrefix
Retrieves the ith value of this prefix.
get(boolean, boolean) - Static method in enum org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState.Action
 
get(int) - Method in class org.apache.cassandra.db.NativeClustering
 
get(ByteBuffer, IPartitioner) - Static method in class org.apache.cassandra.db.PartitionPosition.ForKey
 
get(int) - Method in class org.apache.cassandra.db.rows.CellPath
 
get() - Method in class org.apache.cassandra.db.rows.EncodingStats.Collector
 
get(int) - Method in class org.apache.cassandra.db.Slices
Returns the ith slice of this Slices object.
get() - Method in class org.apache.cassandra.index.sasi.disk.Token
 
get(long, Function<Long, DecoratedKey>) - Method in class org.apache.cassandra.index.sasi.disk.TokenTree
 
get(String) - Method in class org.apache.cassandra.index.sasi.memory.TrieMemIndex.ConcurrentPrefixTrie
 
get(String) - Method in class org.apache.cassandra.index.sasi.memory.TrieMemIndex.ConcurrentSuffixTrie
 
get() - Method in class org.apache.cassandra.index.sasi.utils.CombinedTerm
 
get() - Method in interface org.apache.cassandra.index.sasi.utils.CombinedValue
 
get() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
get(long) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
get(int) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
 
get(int) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
 
get(Object) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaMap
 
get(Range<Token>) - Method in class org.apache.cassandra.locator.EndpointsByRange
 
get(Replica) - Method in class org.apache.cassandra.locator.EndpointsByReplica
 
get(InetAddressAndPort) - Method in class org.apache.cassandra.locator.RangesByEndpoint
 
get(int) - Method in interface org.apache.cassandra.locator.ReplicaCollection
 
get(K) - Method in class org.apache.cassandra.locator.ReplicaMultimap.Builder
 
get(K) - Method in class org.apache.cassandra.locator.ReplicaMultimap
 
get() - Method in interface org.apache.cassandra.locator.ReplicaPlan.Shared
get the shared replica plan, non-volatile (so maybe stale) but no risk of partially initialised
get() - Method in class org.apache.cassandra.locator.ReplicaPlan.SharedForRangeRead
 
get() - Method in class org.apache.cassandra.locator.ReplicaPlan.SharedForTokenRead
 
get(String, String) - Method in class org.apache.cassandra.locator.SnitchProperties
Get a snitch property value or return defaultValue if not defined.
get(InetAddressAndPort) - Static method in class org.apache.cassandra.metrics.StreamingMetrics
 
get() - Method in class org.apache.cassandra.net.AsyncPromise
 
get(long, TimeUnit) - Method in class org.apache.cassandra.net.AsyncPromise
 
get(int) - Method in interface org.apache.cassandra.net.AsyncStreamingOutputPlus.BufferSupplier
Request a buffer with at least the given capacity.
get(InetAddressAndPort) - Method in class org.apache.cassandra.net.EndpointMessagingVersions
Returns the messaging-version as announced by the given node but capped to the min of the version as announced by the node and MessagingService.current_version.
get(String) - Method in class org.apache.cassandra.net.EndpointMessagingVersions
 
get(ConnectionType) - Static method in class org.apache.cassandra.net.PingRequest
 
get() - Method in class org.apache.cassandra.net.ShareableBytes
 
get(InetAddressAndPort) - Method in class org.apache.cassandra.repair.asymmetric.DifferenceHolder
 
get(InetAddressAndPort) - Method in class org.apache.cassandra.repair.asymmetric.HostDifferences
 
get(Object) - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
 
get(FunctionName) - Method in class org.apache.cassandra.schema.Functions
Get all function overloads with the specified name
get(String) - Method in class org.apache.cassandra.schema.Indexes
Get the index with the specified name
get(UUID) - Method in class org.apache.cassandra.schema.Indexes
Get the index with the specified id
get(String) - Method in class org.apache.cassandra.schema.Keyspaces
Get the keyspace with the specified name
get() - Method in class org.apache.cassandra.schema.TableMetadataRef
 
get(String) - Method in class org.apache.cassandra.schema.Tables
Get the table with the specified name
get(String) - Method in class org.apache.cassandra.schema.Triggers
Get the trigger with the specified name
get(ByteBuffer) - Method in class org.apache.cassandra.schema.Types
Get the type with the specified name
get(String) - Method in class org.apache.cassandra.schema.Views.Builder
 
get(String) - Method in class org.apache.cassandra.schema.Views
Get the materialized view with the specified name
get() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
get() - Method in class org.apache.cassandra.service.BatchlogResponseHandler
 
get() - Method in class org.apache.cassandra.service.ClientWarn
 
get() - Method in class org.apache.cassandra.service.TruncateResponseHandler
 
get() - Method in class org.apache.cassandra.tracing.Tracing
 
get(UUID) - Method in class org.apache.cassandra.tracing.Tracing
 
get(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
 
get(int) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
 
get(int) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
get(int) - Method in class org.apache.cassandra.utils.btree.BTreeSet
The converse of indexOf: provided an index between 0 and size, returns the i'th item, in set order.
get(int) - Method in class org.apache.cassandra.utils.concurrent.Accumulator
 
get() - Method in class org.apache.cassandra.utils.concurrent.Ref
 
get(T) - Method in class org.apache.cassandra.utils.concurrent.Refs
 
get(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
get(int) - Method in class org.apache.cassandra.utils.DynamicList
 
get() - Method in class org.apache.cassandra.utils.ExpiringMemoizingSupplier
 
get(int) - Method in class org.apache.cassandra.utils.LockedDynamicList
 
get(int, BufferType) - Method in class org.apache.cassandra.utils.memory.BufferPool
 
get(int) - Method in class org.apache.cassandra.utils.memory.BufferPool.LocalPool
 
get(List<? extends Iterator<In>>, Comparator<? super 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(Token) - Method in class org.apache.cassandra.utils.MerkleTrees
Get the MerkleTree.Range responsible for the given token.
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(long, TimeUnit) - Method in class org.apache.cassandra.utils.SlidingTimeRate
Gets the current rate in the given time unit from the beginning of the time window to the provided point in time ago.
get(TimeUnit) - Method in class org.apache.cassandra.utils.SlidingTimeRate
Gets the current rate in the given time unit.
get() - Method in class org.apache.cassandra.utils.Wrapped
 
get() - Method in class org.apache.cassandra.utils.WrappedBoolean
 
get50thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
get50thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
get75thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
get75thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
get95thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
get95thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
get98thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
get98thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
get999thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
get999thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
get99thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
get99thPercentile() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
getAbstractType() - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
 
getAcceptCount() - Method in class org.apache.cassandra.service.paxos.ProposeCallback
 
getAccess() - Method in class org.apache.cassandra.tools.JMXTool.Attribute
 
getAcquisitionCallable(ColumnFamilyStore, Set<Range<Token>>, UUID, int, int) - Method in class org.apache.cassandra.db.repair.PendingAntiCompaction
 
getAcquisitionCallback(UUID, RangesAtEndpoint) - Method in class org.apache.cassandra.db.repair.PendingAntiCompaction
 
getActiveCompactions() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getActiveContentSize() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getActiveContentSize() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
 
getActiveOnDiskSize() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getActiveOnDiskSize() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
 
getActiveSegmentCompressionRatios() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getActiveSegmentCompressionRatios() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
 
getActiveSegmentNames() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getActiveSegmentNames() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
 
getActiveSegments() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogSegmentManager
 
getActiveTaskCount() - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
getActiveTaskCount() - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
 
getActiveTaskCount() - Method in interface org.apache.cassandra.concurrent.LocalAwareExecutorService
Returns the approximate number of threads that are actively executing tasks.
getActiveTaskCount() - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
getAddress(ByteBuffer) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getAddressReplicas(TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getAddressReplicas(TokenMetadata, InetAddressAndPort) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getAddressReplicas() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getAddressReplicas(InetAddressAndPort) - 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.
getAggregator(TableId) - Method in class org.apache.cassandra.streaming.StreamSession
 
getAliasParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
 
getAll(String) - Static method in class org.apache.cassandra.db.virtual.TableMetricTables
Generates all table metric tables in a collection
getAllDataFileLocations() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
Returns the list of all the directories where the data files can be stored (for local system and non local system keyspaces).
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
getAllDirectories() - Method in class org.apache.cassandra.db.Directories.DataDirectories
 
getAllEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
 
getAllEndpointStates() - Method in class org.apache.cassandra.gms.FailureDetector
 
getAllEndpointStates(boolean) - Method in class org.apache.cassandra.gms.FailureDetector
 
getAllEndpointStates() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
Deprecated.
getAllEndpointStatesWithPort() - Method in class org.apache.cassandra.gms.FailureDetector
 
getAllEndpointStatesWithPort() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
getAllFilePaths() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getAllIndexColumnFamilyStores() - Method in class org.apache.cassandra.index.SecondaryIndexManager
 
getAllIndexesOf(String) - Method in class org.apache.cassandra.cql3.functions.types.UDTValue
 
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.UUIDGen
Helper function used exclusively by UUIDGen to create
getAllMemtables() - Method in class org.apache.cassandra.db.lifecycle.View
 
getAllocatedSize() - Method in class org.apache.cassandra.utils.DirectorySizeCalculator
 
getAllocateTokensForKeyspace() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getAllocateTokensForLocalRf() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getAllocator() - Method in class org.apache.cassandra.db.Memtable
 
getAllocator() - Method in class org.apache.cassandra.net.AsyncStreamingInputPlus
 
getAllocatorForEndpoint(InetAddress) - Static method in class org.apache.cassandra.transport.ClientResourceLimits
 
getAllRanges(List<Token>) - Method in class org.apache.cassandra.service.StorageService
Get all ranges that span the ring given a set of tokens.
getAllRoles() - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
getAllRoles() - Method in interface org.apache.cassandra.auth.IRoleManager
Called during the execution of an unqualified LIST ROLES query.
getAllSessionInfo() - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
getAllSSTables(SSTableSet) - Method in class org.apache.cassandra.db.Keyspace
 
getAllStreamSessions() - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
getAnalyzer() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
getAnalyzer(AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.conf.IndexMode
 
getAndAppendComparator(int, V, ValueAccessor<V>, StringBuilder, int) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
Adds type information from @param bb to @param sb.
getAndAppendComparator(int, V, ValueAccessor<V>, StringBuilder, int) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
getAndAppendComparator(int, V, ValueAccessor<V>, StringBuilder, int) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
getAndReferenceOverlappingLiveSSTables(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
 
getAntiCompactionIterator(List<ISSTableScanner>, CompactionController, int, UUID, ActiveCompactionsTracker, BooleanSupplier) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
 
getApplicationState(ApplicationState) - Method in class org.apache.cassandra.gms.EndpointState
 
getApplicationState(InetAddressAndPort, ApplicationState) - Method in class org.apache.cassandra.gms.Gossiper
The value for the provided application state for the provided endpoint as currently known by this Gossip instance.
getApproximateKeyCount(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
Calculate approximate key count.
getArchiveCommand() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getArchiveCommand() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
Command to execute to archive a commitlog segment.
getArchivingSegmentNames() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getArchivingSegmentNames() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
 
getArray(ByteBuffer) - Static method in class org.apache.cassandra.cql3.functions.types.utils.Bytes
Extract the content of the provided ByteBuffer as a byte array.
getArray() - Method in interface org.apache.cassandra.index.sasi.analyzer.StandardTokenizerInterface
 
getArray(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
You should almost never use this.
getArray(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
You should almost never use this.
getAtLeast(int, BufferType) - Method in class org.apache.cassandra.utils.memory.BufferPool
 
getAtLeast(int) - Method in class org.apache.cassandra.utils.memory.BufferPool.LocalPool
 
getAttachment(ByteBuffer) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getAttribute(String) - Method in class org.apache.cassandra.tools.JMXTool.Info
 
getAttributePresent(String) - Method in class org.apache.cassandra.tools.JMXTool.Info
 
getAttributes() - Method in class org.apache.cassandra.tools.JMXTool.Info
 
getAuditLogContext() - Method in interface org.apache.cassandra.cql3.CQLStatement
Provides the context needed for audit logging statements.
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.AlterRoleStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.CreateRoleStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.DescribeStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.DropRoleStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.GrantPermissionsStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.GrantRoleStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.ListRolesStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.RevokePermissionsStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.RevokeRoleStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.AlterKeyspaceStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.AlterTypeStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.AlterViewStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.CreateAggregateStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.CreateFunctionStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.CreateKeyspaceStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.CreateTriggerStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.CreateTypeStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.CreateViewStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.DropAggregateStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.DropFunctionStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.DropIndexStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.DropKeyspaceStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.DropTableStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.DropTriggerStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.DropTypeStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.schema.DropViewStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
 
getAuditLogContext() - Method in class org.apache.cassandra.cql3.statements.UseStatement
 
getAuditLoggingOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getAuthenticatedUser() - Method in interface org.apache.cassandra.auth.IAuthenticator.SaslNegotiator
Following a sucessful negotiation, get the AuthenticatedUser representing the logged in subject.
getAuthenticator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getAuthorizer() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getAutoCompactionDisabled(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
getAutocompactionOnStartupEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getAutoCompactionStatus(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
getAutoCompactionStatus(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getAutomaticSSTableUpgradeEnabled() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getAutomaticSSTableUpgradeEnabled() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Get automatic sstable upgrade enabled
getAutoSnapshot() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getAvailableProcessors() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getAvailableRanges(String, IPartitioner) - Static method in class org.apache.cassandra.db.SystemKeyspace
List of the streamed ranges, where transientness is encoded based on the source, where range was streamed from.
getAvailableRanges(String, IPartitioner) - Method in class org.apache.cassandra.dht.StreamStateStore
 
getAvailableSpace() - Method in class org.apache.cassandra.db.Directories.DataDirectory
 
getAverageIndexInterval() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
 
getAverageIndexInterval() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
 
getAvgColumnSetPerRow() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getBackgroundCompactionCandidate(ColumnFamilyStore) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getBackgroundCompactionTaskSubmitter() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
getBackgroundTaskSuppliers(int) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
 
getBackgroundTaskSuppliers(int) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
getBackgroundTaskSuppliers(int) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
getBackingSSTables() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
 
getBackingSSTables() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
getBackingSSTables() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
 
getBackingTable() - Method in interface org.apache.cassandra.index.Index
If the index implementation uses a local table to store its index data this method should return a handle to it.
getBackingTable() - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
getBackingTable() - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
getBackPressurePerHost() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Deprecated.
getBackPressurePerHost() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getBackupsDirectory(Descriptor) - Static method in class org.apache.cassandra.db.Directories
 
getBackupsDirectory(File) - Static method in class org.apache.cassandra.db.Directories
 
getBadnessThreshold() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getBadnessThreshold() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
getBaseColumn(ColumnMetadata) - Method in class org.apache.cassandra.db.view.View
The base column corresponding to the provided view column.
getBatch() - Method in class org.apache.cassandra.audit.AuditLogEntry
 
getBatchlogReplayThrottle() - Method in class org.apache.cassandra.tools.NodeProbe
 
getBatchlogReplayThrottleInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBatchlogReplayThrottleInKB() - Method in class org.apache.cassandra.service.StorageService
 
getBatchlogReplayThrottleInKB() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
GetBatchlogReplayTrottle - Class in org.apache.cassandra.tools.nodetool
 
GetBatchlogReplayTrottle() - Constructor for class org.apache.cassandra.tools.nodetool.GetBatchlogReplayTrottle
 
getBatchlogTimeout() - Static method in class org.apache.cassandra.batchlog.BatchlogManager
 
getBatchSizeFailThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBatchSizeFailThresholdInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBatchSizeFailureThreshold() - Method in class org.apache.cassandra.service.StorageService
 
getBatchSizeFailureThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the threshold for rejecting queries due to a large batch size
getBatchSizeWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBatchSizeWarnThreshold() - Method in class org.apache.cassandra.service.StorageService
 
getBatchSizeWarnThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the threshold for warning queries due to a large batch size
getBatchSizeWarnThresholdInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBestIndexFor(RowFilter.Expression) - Method in interface org.apache.cassandra.index.IndexRegistry
 
getBestIndexFor(RowFilter) - Method in class org.apache.cassandra.index.SecondaryIndexManager
Called at query time to choose which (if any) of the registered index implementations to use for a given query.
getBestIndexFor(RowFilter.Expression) - Method in class org.apache.cassandra.index.SecondaryIndexManager
 
getBindVariables() - Method in interface org.apache.cassandra.cql3.CQLStatement
Returns all bind variables for the statement
getBindVariables() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
getBindVariables() - Method in class org.apache.cassandra.cql3.statements.DescribeStatement
 
getBindVariables() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
getBindVariables() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
getBindVariables() - Method in class org.apache.cassandra.cql3.VariableSpecifications
 
getBinLogOptions() - Method in class org.apache.cassandra.utils.binlog.BinLog
 
getBlob(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getBlock(int) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.Level
 
getBlock() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.PointerTerm
 
getBlock(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.MurmurHash
 
getBlockForPeersInRemoteDatacenters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBlockForPeersTimeoutInSeconds() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBlockIndex() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
 
getBlockingFlushTask() - Method in interface org.apache.cassandra.index.Index
Return a task which performs a blocking flush of the index's data to persistent storage.
getBlockingFlushTask() - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
getBlockingFlushTask() - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
getBloomFilter() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getBloomFilterOffHeapSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Returns the amount of memory in bytes used off heap by the bloom filter.
getBloomFilterSerializedSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getBloomFilterTrueNegativeCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getBool(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a boolean.
getBool(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a boolean.
getBool(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a boolean.
getBoolean() - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
Gets the value of a system property as a boolean.
getBoolean(boolean) - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
Gets the value of a system property as a boolean.
getBoolean(String, Boolean) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
getBoolean(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getBoolean(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
returns a boolean from offset
getBoolean(byte[], int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
getBootstrapState() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
getBootstrapTokens(TokenMetadata, InetAddressAndPort, long) - 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
 
getBoundariesFromSSTableDirectory(Descriptor) - Method in class org.apache.cassandra.db.DiskBoundaries
Try to figure out location based on sstable directory
getBounds() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getBroadcastAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBroadcastAddressAndPort() - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
getBroadcastAddressAndPort() - Static method in class org.apache.cassandra.utils.FBUtilities
Get the broadcast address and port for intra-cluster storage traffic.
getBroadcastNativeAddressAndPort() - Static method in class org.apache.cassandra.utils.FBUtilities
This returns the address that is bound to for the native protocol for communicating with clients.
getBroadcastRpcAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
This is the address used to reach this instance for the native protocol to communicate with clients.
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
 
getBuffer(int) - Method in class org.apache.cassandra.io.util.ThreadLocalByteBufferHolder
Returns the buffer for the current thread.
getBufferArray() - Method in class org.apache.cassandra.db.AbstractArrayClusteringPrefix
 
getBufferArray() - Method in class org.apache.cassandra.db.AbstractBufferClusteringPrefix
 
getBufferArray() - Method in interface org.apache.cassandra.db.ClusteringPrefix
 
getBufferArray() - Method in class org.apache.cassandra.db.NativeClustering
 
getBuild() - Method in class org.apache.cassandra.utils.CassandraVersion
 
getBuildTaskSupport() - Method in interface org.apache.cassandra.index.Index
Get an instance of a helper to provide tasks for building the index from a set of SSTable data.
getBuildTaskSupport() - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
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(String, Set<String>) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
getBuiltIndexNames() - Method in class org.apache.cassandra.index.SecondaryIndexManager
 
getByAddress(byte[]) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
 
getByAddress(InetAddress) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
 
getByAddressOverrideDefaults(InetAddress, Integer) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
 
getByAddressOverrideDefaults(InetAddress, byte[], Integer) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
 
getByName(String) - Method in class org.apache.cassandra.db.view.ViewManager
 
getByName(String) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
 
getByNameOverrideDefaults(String, Integer) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
 
getByte(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a byte.
getByte(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a byte.
getByte(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a byte.
getByte(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getByte(byte[], int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
getByte(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
getByte(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
returns a byte from offset
getByte(long) - Method in class org.apache.cassandra.io.util.Memory
 
getByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getByteBuffer(long, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getByteBuffer(long, int, ByteOrder) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getBytes(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a byte array.
getBytes(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a byte array.
getBytes(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a byte array.
getBytes(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getBytes() - Method in interface org.apache.cassandra.index.sasi.analyzer.StandardTokenizerInterface
 
getBytes() - Method in class org.apache.cassandra.index.sasi.sa.IndexedTerm
 
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 interface org.apache.cassandra.io.util.BytesReadTracker
 
getBytesRead() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
 
getBytesRead() - Method in class org.apache.cassandra.io.util.TrackedInputStream
 
getBytesScanned() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
 
getBytesScanned() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
getBytesScanned() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
 
getBytesUnsafe(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a ByteBuffer.
getBytesUnsafe(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a ByteBuffer.
getBytesUnsafe(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a ByteBuffer.
getCacheCrcPath(String) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
getCacheDataPath(String) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
getCachedCounter(ByteBuffer, Clustering<?>, ColumnMetadata, CellPath) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getCachedPosition(DecoratedKey, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getCachedPosition(KeyCacheKey, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getCachedReplicaRowsFailThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCachedReplicaRowsFailThreshold() - Method in class org.apache.cassandra.service.StorageService
 
getCachedReplicaRowsFailThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the number of rows cached at the coordinator before filtering/index queries fail outright.
getCachedReplicaRowsWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCachedReplicaRowsWarnThreshold() - Method in class org.apache.cassandra.service.StorageService
 
getCachedReplicaRowsWarnThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the number of rows cached at the coordinator before filtering/index queries log a warning.
getCachedReplicas(Token) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getCacheKey(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getCacheMetric(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
Retrieve cache metrics based on the cache type (KeyCache, RowCache, or CounterCache)
getCacheServiceMBean() - Method in class org.apache.cassandra.tools.NodeProbe
 
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(TimeUnit) - 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
 
getCasContentionTimeout() - Method in class org.apache.cassandra.service.StorageService
 
getCasContentionTimeout() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getCategory() - Method in enum org.apache.cassandra.audit.AuditLogEntryType
 
getCDCDiskCheckInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCDCFile() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getCDCIndexFile() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getCDCLogLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCDCSpaceInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCDCState() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getCell(Row, ColumnMetadata) - Static method in class org.apache.cassandra.cql3.conditions.ColumnCondition
 
getCell(Row, ColumnMetadata, CellPath) - Static method in class org.apache.cassandra.cql3.conditions.ColumnCondition
 
getCell(ColumnMetadata) - Method in class org.apache.cassandra.db.rows.BTreeRow
 
getCell(ColumnMetadata, CellPath) - Method in class org.apache.cassandra.db.rows.BTreeRow
 
getCell(CellPath) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
getCell(ColumnMetadata) - Method in interface org.apache.cassandra.db.rows.Row
Returns a cell for a simple column.
getCell(ColumnMetadata, CellPath) - Method in interface org.apache.cassandra.db.rows.Row
Return a cell for a given complex column and cell path.
getCellByIndex(int) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
getCells(Row, ColumnMetadata) - Static method in class org.apache.cassandra.cql3.conditions.ColumnCondition
 
getCFDirectories() - Method in class org.apache.cassandra.db.Directories
 
getCfsProxy(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getChannel() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
 
getChannel() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
getChar(byte[], int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
getCheckForDuplicateRowsDuringCompaction() - Method in class org.apache.cassandra.service.StorageProxy
 
getCheckForDuplicateRowsDuringCompaction() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getCheckForDuplicateRowsDuringReads() - Method in class org.apache.cassandra.service.StorageProxy
 
getCheckForDuplicateRowsDuringReads() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getChunkLength() - Method in class org.apache.cassandra.security.EncryptionContext
 
getChunksForSections(Collection<SSTableReader.PartitionPositionBounds>) - Method in class org.apache.cassandra.io.compress.CompressionMetadata
 
getClass(String) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getClientAddress() - Method in class org.apache.cassandra.service.QueryState
 
getClientMetric(String) - Method in class org.apache.cassandra.tools.NodeProbe
Retrieve Proxy metrics
getClientState() - Method in class org.apache.cassandra.service.QueryState
 
getClientState() - Method in class org.apache.cassandra.transport.ServerConnection
 
getClock() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
getClockAndCountOf(ByteBuffer, CounterId) - Method in class org.apache.cassandra.db.context.CounterContext
Returns the clock and the count associated with the given counter id, or (0, 0) if no such shard is present.
getClosingString() - Method in class org.apache.cassandra.dht.AbstractBounds
 
getClosingString() - Method in class org.apache.cassandra.dht.Bounds
 
getClosingString() - Method in class org.apache.cassandra.dht.ExcludingBounds
 
getClosingString() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
getClosingString() - Method in class org.apache.cassandra.dht.Range
 
getCluster(String[], Configuration, int) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getClusteringColumns(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Returns the requested clustering columns.
getClusteringColumnsBounds(Bound, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Returns the bounds (start or end) of the clustering columns.
getClusteringTypes() - Method in class org.apache.cassandra.db.SerializationHeader.Component
 
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
 
getCodecRegistry() - Method in class org.apache.cassandra.cql3.functions.types.TupleValue
 
getCodecRegistry() - Method in class org.apache.cassandra.cql3.functions.types.UDTValue
 
getCollectionElementValue() - Method in class org.apache.cassandra.cql3.conditions.ColumnCondition.Bound
 
getCollectionsParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
 
getColumn() - Method in class org.apache.cassandra.cql3.selection.SimpleSelector.SimpleSelectorFactory
 
getColumn(ColumnIdentifier) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
getColumn(ByteBuffer) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
getColumn(ColumnIdentifier) - Method in class org.apache.cassandra.schema.TableMetadata
Returns the ColumnMetadata for name.
getColumn(ByteBuffer) - Method in class org.apache.cassandra.schema.TableMetadata
 
getColumnCount() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
getColumnDefs() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
 
getColumnDefs() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Returns the column definitions in position order.
getColumnDefs() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
 
getColumnDefs() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
getColumnFamilieMBeanName(String, String, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
getColumnFamilies() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
getColumnFamily() - Method in class org.apache.cassandra.db.AbstractCompactionController
 
getColumnFamilyMetric(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
Retrieve ColumnFamily metrics
getColumnFamilyName() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Deprecated.
getColumnFamilyName() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Deprecated.
getColumnFamilyName() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getColumnFamilyStore(String) - Method in class org.apache.cassandra.db.Keyspace
 
getColumnFamilyStore(TableId) - Method in class org.apache.cassandra.db.Keyspace
 
getColumnFamilyStoreInstance(TableId) - Method in class org.apache.cassandra.schema.Schema
 
getColumnFamilyStoreMBeanProxies() - Method in class org.apache.cassandra.tools.NodeProbe
 
getColumnFamilyStores() - Method in class org.apache.cassandra.db.Keyspace
 
getColumnFamilyStores() - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
getColumnFilter() - Method in interface org.apache.cassandra.cql3.selection.Selection.Selectors
Returns the ColumnFilter corresponding to those selectors
getColumnIndex(ColumnMetadata) - Method in class org.apache.cassandra.cql3.selection.Selection
Returns the index of the specified column
getColumnIndexCacheSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getColumnIndexCacheSize() - Method in class org.apache.cassandra.service.StorageService
 
getColumnIndexCacheSize() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the threshold for skipping the column index when caching partition info
getColumnIndexCacheSizeInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getColumnIndexSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getColumnIndexSizeInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getColumnMapping() - Method in class org.apache.cassandra.cql3.selection.Selection
 
getColumnName() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Returns the name of the column corresponding to the output value of the selector instances created by this factory.
getColumnName() - Method in class org.apache.cassandra.cql3.selection.SimpleSelector.SimpleSelectorFactory
 
getColumnName() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
getColumnNamesAsString() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
Returns the column names as a comma separated String.
getColumns() - Method in class org.apache.cassandra.cql3.conditions.ColumnConditions
 
getColumns() - Method in interface org.apache.cassandra.cql3.conditions.Conditions
Returns the column definitions to which apply the conditions.
getColumns() - Method in class org.apache.cassandra.cql3.selection.Selection
 
getColumns() - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getColumnsInCommons(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
Returns the names of the columns that are specified within this Restrictions and the other one as a comma separated String.
getColumnSpecification(TableMetadata) - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Returns the column specification corresponding to the output value of the selector instances created by this factory.
getColumnSpecifications() - Method in class org.apache.cassandra.cql3.QueryOptions
Returns the column specifications for the bound variables (optional operation).
getColumnSpecifications() - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
getColumnSpecifications() - Method in interface org.apache.cassandra.cql3.selection.SelectionColumns
 
getColumnsWithConditions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
getCommandPackages() - Method in class org.apache.cassandra.tools.nodetool.Sjk.Wrapper
 
getCommitFailurePolicy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCommitLogCompression() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCommitLogLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCommitLogLocation() - Method in class org.apache.cassandra.service.StorageService
 
getCommitLogLocation() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Get location of the commit log
getCommitLogLowerBound() - Method in class org.apache.cassandra.db.Memtable
 
getCommitLogMaxCompressionBuffersInPool() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
Maximum number of buffers in the compression pool.
getCommitLogPosition() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment.Allocation
Returns the position in the CommitLogSegment at the end of this allocation.
getCommitLogSegmentMgrProvider() - 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
 
getCommitLogSyncGroupWindow() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCommitLogSyncPeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCommitLogUpperBound() - Method in class org.apache.cassandra.db.Memtable
 
getCompacting() - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
getCompactionAwareWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
getCompactionAwareWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
getCompactionAwareWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
 
getCompactionAwareWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.SingleSSTableLCSTask
 
getCompactionAwareWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
 
getCompactionCandidates() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
getCompactionController(Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
getCompactionController(Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
 
getCompactionController(Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionTask
 
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.CompactionInfo.Holder
 
getCompactionInfo() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
 
getCompactionInfo() - Method in class org.apache.cassandra.db.view.ViewBuilderTask
 
getCompactionInfo() - Method in class org.apache.cassandra.index.internal.CollatedViewIndexBuilder
 
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
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
 
getCompactionParams() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
getCompactions() - Method in class org.apache.cassandra.db.compaction.ActiveCompactions
 
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.
getCompactionsForSSTable(SSTableReader, OperationType) - Method in class org.apache.cassandra.db.compaction.ActiveCompactions
Iterates over the active compactions and tries to find CompactionInfos with the given compactionType for the given sstable Number of entries in compactions should be small (< 10) but avoid calling in any time-sensitive context
getCompactionStrategyFor(SSTableReader) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
return the compaction strategy for the given sstable returns differently based on the repaired status and which vnode the compaction strategy belongs to
getCompactionStrategyManager() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getCompactionSummary() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getCompactionSummary() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
List of running compaction summary strings.
getCompactionTask(LifecycleTransaction, int, long) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getCompactionTask(LifecycleTransaction, int, long) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
getCompactionTask(LifecycleTransaction, int, long) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
GetCompactionThreshold - Class in org.apache.cassandra.tools.nodetool
 
GetCompactionThreshold() - Constructor for class org.apache.cassandra.tools.nodetool.GetCompactionThreshold
 
getCompactionThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
 
GetCompactionThroughput - Class in org.apache.cassandra.tools.nodetool
 
GetCompactionThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.GetCompactionThroughput
 
getCompactionThroughputMbPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCompactionThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
 
getCompactionThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getCompactValueColumn(RegularAndStaticColumns) - Static method in class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
 
getComparator() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getComparator(int, V, ValueAccessor<V>, int) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
getComparator(int, VL, ValueAccessor<VL>, VR, ValueAccessor<VR>, int, int) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
Adds DynamicCompositeType type information from @param bb1 to @param bb2.
getComparator(int, V, ValueAccessor<V>, int) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
getComparator(int, VL, ValueAccessor<VL>, VR, ValueAccessor<VR>, int, int) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
getComparator(int, V, ValueAccessor<V>, int) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
getComparator(int, VL, ValueAccessor<VL>, VR, ValueAccessor<VR>, int, int) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
getComparator() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
getComparatorSerializedSize() - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
 
getComparatorSize(int, V, ValueAccessor<V>, int) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
getComparatorSize(int, V, ValueAccessor<V>, int) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
getComparatorSize(int, V, ValueAccessor<V>, int) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
getCompleted() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getCompletedTaskCount() - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
 
getCompletedTaskCount() - Method in interface org.apache.cassandra.concurrent.LocalAwareExecutorService
Returns the approximate total number of tasks that have completed execution.
getCompletedTaskCount() - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
getCompletedTasks() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
 
getCompletedTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getComplex(int) - Method in class org.apache.cassandra.db.Columns
Returns the ith complex column of this object.
getComplexColumnData(ColumnMetadata) - Method in class org.apache.cassandra.db.rows.BTreeRow
 
getComplexColumnData(ColumnMetadata) - Method in interface org.apache.cassandra.db.rows.Row
The data for a complex column.
getComponent() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
getComponents(TableMetadata, DecoratedKey) - Static method in class org.apache.cassandra.cql3.statements.SelectStatement
 
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
 
getCompressedLengthInBytes() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
 
getCompressedLengthInBytes() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
getCompressedLengthInBytes() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
 
getCompressionLevel() - Method in class org.apache.cassandra.io.compress.ZstdCompressor
 
getCompressionMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Returns the compression metadata for this sstable.
getCompressionMetadataOffHeapSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Returns the amount of memory in bytes used off heap by the compression meta-data.
getCompressionParameters() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getCompressionParameters() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Get the compression parameters
getCompressionParametersJson() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getCompressionParametersJson() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getCompressionRatio() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy.ScannerList
 
getCompressionRatio() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getCompressor() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
Returns the compressor used to compress the segments.
getCompressor() - Method in class org.apache.cassandra.security.EncryptionContext
 
getCompressor() - Method in class org.apache.cassandra.transport.Connection
 
getCompressorClass() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
Returns the compressor class.
getCompressorName() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
Returns the compressor name.
getConcurrency(List<String>) - Method in class org.apache.cassandra.service.StorageService
 
getConcurrency(List<String>) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
GetConcurrency - Class in org.apache.cassandra.tools.nodetool
 
GetConcurrency() - Constructor for class org.apache.cassandra.tools.nodetool.GetConcurrency
 
getConcurrentCompactors() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConcurrentCompactors() - Method in class org.apache.cassandra.service.StorageService
 
getConcurrentCompactors() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getConcurrentCompactors() - Method in class org.apache.cassandra.tools.NodeProbe
 
GetConcurrentCompactors - Class in org.apache.cassandra.tools.nodetool
 
GetConcurrentCompactors() - Constructor for class org.apache.cassandra.tools.nodetool.GetConcurrentCompactors
 
getConcurrentCounterWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConcurrentReaders() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConcurrentValidations() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConcurrentValidators() - Method in class org.apache.cassandra.service.StorageService
 
getConcurrentValidators() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getConcurrentViewBuilders() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConcurrentViewBuilders() - Method in class org.apache.cassandra.service.StorageService
 
getConcurrentViewBuilders() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getConcurrentViewBuilders() - Method in class org.apache.cassandra.tools.NodeProbe
 
GetConcurrentViewBuilders - Class in org.apache.cassandra.tools.nodetool
 
GetConcurrentViewBuilders() - Constructor for class org.apache.cassandra.tools.nodetool.GetConcurrentViewBuilders
 
getConcurrentViewWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConcurrentWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConditions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
 
getConfiguration(JobContext) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
Invoke getConfiguration() on JobContext.
getConnectedClients() - Method in class org.apache.cassandra.transport.Server
 
getConnectionFactory() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
Provides connection factory.
getConsecutiveMessageErrorsThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConsistency() - Method in class org.apache.cassandra.cql3.BatchQueryOptions
 
getConsistency() - Method in class org.apache.cassandra.cql3.QueryOptions
 
getCoordinator() - Method in class org.apache.cassandra.streaming.StreamPlan
 
getCoordinator() - Method in class org.apache.cassandra.streaming.StreamResultFuture
 
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 class org.apache.cassandra.concurrent.ImmediateExecutor
 
getCorePoolSize() - Method in interface org.apache.cassandra.concurrent.ResizableThreadPool
Returns maximum pool size of thread pool.
getCorePoolSize() - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
getCorePoolSize() - Method in enum org.apache.cassandra.concurrent.Stage
Returns core thread pool size
getCoreThreads() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
Deprecated.
getCoreThreads() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
Deprecated.
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
getCoreViewBuildThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getCoreViewBuildThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Returns core size of view build thread pool
getCorrectDiskForKey(DecoratedKey) - Method in class org.apache.cassandra.db.DiskBoundaries
 
getCorrectDiskForSSTable(SSTableReader) - Method in class org.apache.cassandra.db.DiskBoundaries
 
getCorruptedTombstoneStrategy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCorruptedTombstoneStrategy() - Method in class org.apache.cassandra.service.StorageService
 
getCorruptedTombstoneStrategy() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getCount() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
getCount() - Method in class org.apache.cassandra.index.sasi.disk.TokenTree
 
getCount() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator
 
getCount() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxCounterMBean
 
getCount() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
getCount() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
 
getCount() - Method in class org.apache.cassandra.metrics.LatencyMetrics.LatencyMetricsTimer
 
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(TimeUnit) - 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
 
getCounterWriteRpcTimeout() - Method in class org.apache.cassandra.service.StorageService
 
getCounterWriteRpcTimeout() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getCQLQueryHandler() - Static method in class org.apache.cassandra.service.ClientState
 
getCqlType() - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the CQL type that this codec deserializes from and serializes to.
getCqlTypeName() - Method in class org.apache.cassandra.db.marshal.UserType
 
getCrcCheckChance() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getCrcCheckChance() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getCrcCheckChance() - Method in class org.apache.cassandra.io.util.AbstractReaderFileProxy
 
getCrcCheckChance() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
 
getCrcCheckChance() - Method in class org.apache.cassandra.io.util.CompressedChunkReader
 
getCrcCheckChance() - Method in class org.apache.cassandra.io.util.LimitingRebufferer
 
getCrcCheckChance() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
getCrcCheckChance() - Method in interface org.apache.cassandra.io.util.ReaderFileProxy
Needed for tests.
getCrcCheckChance() - Method in class org.apache.cassandra.schema.CompressionParams
 
getCreationTimeFor(Component) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getCredentialsCacheMaxEntries() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCredentialsUpdateInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCredentialsValidity() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCurrent() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator
 
getCurrent() - Method in class org.apache.cassandra.utils.concurrent.OpOrder
 
getCurrentCommitLogPosition() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getCurrentGenerationNumber(InetAddressAndPort) - 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
 
getCurrentGlobalUsage() - Static method in class org.apache.cassandra.transport.ClientResourceLimits
 
getCurrentIpUsage() - Static method in class org.apache.cassandra.transport.ClientResourceLimits
 
getCurrentKey() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
getCurrentlyBlockedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
getCurrentMemtable() - Method in class org.apache.cassandra.db.lifecycle.View
 
getCurrentMemtable() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
getCurrentPosition() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getCurrentPosition() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
 
getCurrentPosition() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
getCurrentPosition() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
 
getCurrentPosition() - Method in class org.apache.cassandra.security.EncryptionUtils.ChannelProxyReadChannel
 
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.cql3.CqlRecordReader
 
getCustomIndexExpressions() - Method in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
 
getCustomOptions(RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
getCustomOptions(RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
Where an implementation supports OPTIONS in CREATE and ALTER operations this method should return the Map<String, String> representing the custom options associated with the role, as supplied to CREATE or ALTER.
getCustomOptions() - Method in class org.apache.cassandra.auth.RoleOptions
Return a Map<String, String> representing custom options It is the responsiblity of IRoleManager implementations which support IRoleManager.Option.OPTION to handle type checking and conversion of these values, if present
getCustomPayload() - Method in class org.apache.cassandra.transport.Message
 
getData() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
getData() - Method in class org.apache.cassandra.service.reads.DataResolver
 
getData() - Method in class org.apache.cassandra.service.reads.DigestResolver
 
getDatacenter() - Static method in class org.apache.cassandra.db.SystemKeyspace
Gets the stored data center for the local node, or null if none have been set yet.
getDatacenter(InetAddressAndPort) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
Return the data center for which an endpoint resides in
getDatacenter(InetAddressAndPort) - Method in class org.apache.cassandra.locator.AlibabaCloudSnitch
 
getDatacenter(InetAddressAndPort) - Method in class org.apache.cassandra.locator.CloudstackSnitch
 
getDatacenter(InetAddressAndPort) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getDatacenter(InetAddressAndPort) - Method in class org.apache.cassandra.locator.Ec2Snitch
 
getDatacenter(String) - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
 
getDatacenter() - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
 
getDatacenter(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
Provides the Datacenter name depending on the respective snitch used, given the hostname/ip
getDatacenter() - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
Provides the Datacenter name depending on the respective snitch used for this node
getDatacenter(InetAddressAndPort) - Method in class org.apache.cassandra.locator.GoogleCloudSnitch
 
getDatacenter(InetAddressAndPort) - Method in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
Return the data center for which an endpoint resides in
getDatacenter(InetAddressAndPort) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
returns a String representing the datacenter the given endpoint belongs to
getDatacenter(Replica) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
 
getDatacenter(InetAddressAndPort) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
Return the data center for which an endpoint resides in
getDatacenter(InetAddressAndPort) - Method in class org.apache.cassandra.locator.RackInferringSnitch
 
getDatacenter(InetAddressAndPort) - Method in class org.apache.cassandra.locator.SimpleSnitch
 
getDataCenter() - Method in class org.apache.cassandra.tools.NodeProbe
 
getDatacenterEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
 
getDatacenterRacks() - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
 
getDatacenters() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
getDataCenters() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
getDataChannel() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getDataDirectoriesFor(TableMetadata) - Method in class org.apache.cassandra.db.Directories.DataDirectories
Returns the data directories for the specified table.
getDataDirectoryForFile(Descriptor) - Method in class org.apache.cassandra.db.Directories
 
getDataOffset() - Method in class org.apache.cassandra.index.sasi.Term
 
getDataPaths() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getDataPaths() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getDate(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a date (without time).
getDate(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a date (without time).
getDate(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a date (without time).
getDay() - Method in class org.apache.cassandra.cql3.functions.types.LocalDate
Returns the day in the month.
getDays() - Method in class org.apache.cassandra.cql3.Duration
 
getDays() - Method in class org.apache.cassandra.cql3.functions.types.Duration
Returns the number of days in this duration.
getDC2AllEndpoints(IEndpointSnitch) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getDecimal(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a variable length decimal.
getDecimal(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a variable length decimal.
getDecimal(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a variable length decimal.
getDecryptor(String, String, byte[]) - Method in class org.apache.cassandra.security.CipherFactory
 
getDecryptor() - Method in class org.apache.cassandra.security.EncryptionContext
 
getDefaultGcBefore(ColumnFamilyStore, int) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
 
getDefaultGcBefore(ColumnFamilyStore, int) - Static method in class org.apache.cassandra.db.repair.CassandraValidationIterator
 
getDefaultOptions() - Static method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
 
getDefaultOptions() - Static method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
getDefinition() - Method in class org.apache.cassandra.db.view.View
 
getDefinition() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
getDeleteSourceOnSuccess(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
getDependentIndexes(ColumnMetadata) - Method in class org.apache.cassandra.index.SecondaryIndexManager
 
getDescription() - Method in enum org.apache.cassandra.streaming.StreamOperation
 
getDescriptor() - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
 
getDigestsByEndpoint() - Method in class org.apache.cassandra.service.reads.DigestResolver
 
getDirectories() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getDirectories() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getDirectories() - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
getDirectories() - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
The directories we can write to
getDirectoriesVersion() - Static method in class org.apache.cassandra.db.DisallowedDirectories
 
getDirectoryForNewSSTables() - Method in class org.apache.cassandra.db.Directories
Basically the same as calling Directories.getWriteableLocationAsFile(long) with an unknown size (-1L), which may return any allowed directory - even a data directory that has no usable space.
getDirtyTableIds() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getDisableSTCSInL0() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDisableSTCSInL0() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getDisableSTCSInL0() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Enable / disable STCS in L0
getDiskAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDiskBoundaries() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getDiskBoundaries(ColumnFamilyStore) - Method in class org.apache.cassandra.db.DiskBoundaryManager
 
getDiskFailurePolicy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDiskIndex(SSTableReader) - Method in class org.apache.cassandra.db.DiskBoundaries
 
getDiskOptimizationEstimatePercentile() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDiskOptimizationStrategy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDouble(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a double.
getDouble(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a double.
getDouble(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a double.
getDouble(String, double) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
getDouble(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getDouble(byte[], int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
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
getDriverName() - Method in class org.apache.cassandra.service.ClientState
 
getDriverVersion() - Method in class org.apache.cassandra.service.ClientState
 
getDroppableTombstoneRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getDroppableTombstoneRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Get the ratio of droppable tombstones to real columns (and non-droppable tombstones)
getDroppableTombstonesBefore(int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getDroppableTombstonesBefore(int) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
getDroppedColumn(ByteBuffer) - Method in class org.apache.cassandra.schema.TableMetadata
 
getDroppedColumn(ByteBuffer, boolean) - Method in class org.apache.cassandra.schema.TableMetadata
Returns a "fake" ColumnMetadata corresponding to the dropped column name of null if there is no such dropped column.
getDroppedMessages() - Method in class org.apache.cassandra.metrics.MessagingMetrics
 
getDroppedMessages() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
dropped message counts for server lifetime
getDroppedMessages() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getDroppedMessages() - Method in class org.apache.cassandra.tools.NodeProbe
 
getDurationUnit() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
getDynamicBadnessThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDynamicEndpointSnitchInfoProxy() - Method in class org.apache.cassandra.tools.NodeProbe
 
getDynamicResetInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDynamicUpdateInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDynamicUpdateInterval() - Method in class org.apache.cassandra.service.StorageService
 
getDynamicUpdateInterval() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getEffectiveIndexInterval() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getEffectiveIndexInterval() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
getEffectiveIndexIntervalAfterIndex(int, int, int) - Static method in class org.apache.cassandra.io.sstable.Downsampling
Calculates the effective index interval after the entry at `index` in an IndexSummary.
getEffectiveIndexIntervalAfterIndex(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
Returns the number of primary (on-disk) index entries between the index summary entry at `index` and the next index summary entry (assuming there is one).
getElement(V, ValueAccessor<V>, int) - Method in class org.apache.cassandra.serializers.ListSerializer
Returns the element at the given index in a list.
getElement(ByteBuffer, int) - Method in class org.apache.cassandra.serializers.ListSerializer
 
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
 
getElements() - Method in class org.apache.cassandra.cql3.UserTypes.Value
 
getElementsType() - Method in class org.apache.cassandra.db.marshal.ListType
 
getElementsType() - Method in class org.apache.cassandra.db.marshal.SetType
 
getEnableMaterializedViews() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getEnableSASIIndexes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getEncodedMutations() - Method in class org.apache.cassandra.batchlog.Batch
 
getEncodingStats() - Method in class org.apache.cassandra.db.SerializationHeader.Component
 
getEncryptionContext() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getEncryptionContext() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
Returns the encryption context used to encrypt the segments.
getEncryptionContext() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
getEncryptor(String, String) - Method in class org.apache.cassandra.security.CipherFactory
 
getEncryptor() - Method in class org.apache.cassandra.security.EncryptionContext
 
getEndInSummary(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
getEndpoint(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getEndpoint() - Method in class org.apache.cassandra.tools.NodeProbe
 
getEndpointCount() - Method in class org.apache.cassandra.gms.Gossiper
 
getEndpointDowntime(InetAddressAndPort) - 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
getEndpointForHostId(UUID) - Method in class org.apache.cassandra.service.StorageService
 
getEndpointInfo(InetAddressAndPort) - Static method in class org.apache.cassandra.locator.PropertyFileSnitch
Get the raw information about an end point
getEndpointLimit() - Static method in class org.apache.cassandra.transport.ClientResourceLimits
 
getEndpoints() - Method in class org.apache.cassandra.gms.Gossiper
 
getEndpoints(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
GetEndpoints - Class in org.apache.cassandra.tools.nodetool
 
GetEndpoints() - Constructor for class org.apache.cassandra.tools.nodetool.GetEndpoints
 
getEndpointSnitch() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getEndpointSnitchInfoProxy() - Method in class org.apache.cassandra.tools.NodeProbe
 
getEndpointState(String) - Method in class org.apache.cassandra.gms.FailureDetector
 
getEndpointState(String) - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
getEndpointStateForEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
 
getEndpointsWithPort(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getEndpointToHostId() - Method in class org.apache.cassandra.service.StorageService
 
getEndpointToHostId() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
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
 
getEndpointWithPortToHostId() - Method in class org.apache.cassandra.service.StorageService
 
getEndpointWithPortToHostId() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getEndToken() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
getEntities() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
getEntity() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
getEntry() - Method in class org.apache.cassandra.audit.AuditEvent
 
getEstimatedBytes() - Method in class org.apache.cassandra.db.repair.CassandraValidationIterator
 
getEstimatedBytes() - Method in class org.apache.cassandra.repair.ValidationPartitionIterator
 
getEstimatedCellPerPartitionCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getEstimatedCompactionsByTasks(ColumnFamilyStore, List<List<SSTableReader>>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
getEstimatedDroppableTombstoneRatio(int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getEstimatedDroppableTombstoneRatio(int) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
getEstimatedKeyCount() - Method in class org.apache.cassandra.io.sstable.IndexSummary
Returns an estimate of the total number of keys in the SSTable.
getEstimatedOnDiskBytesWritten() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
Get a quick estimation on how many bytes have been written to disk It should for the most part be exactly the same as getOnDiskFilePointer()
getEstimatedOnDiskBytesWritten() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
getEstimatedOnDiskBytesWritten() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
getEstimatedOnDiskBytesWritten() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
getEstimatedPartitionSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
Deprecated.
 
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.TimeWindowCompactionStrategy
 
getEstimatedResultRows() - Method in interface org.apache.cassandra.index.Index
Return an estimate of the number of results this index is expected to return for any given query that it can be used to answer.
getEstimatedResultRows() - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
getEstimatedResultRows() - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
getEstimatedSize() - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
 
getEstimatedSize() - Method in interface org.apache.cassandra.streaming.OutgoingStream
 
getEstimatedTasks() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
getEvents(String, Long, int, boolean) - Method in class org.apache.cassandra.diag.DiagnosticEventPersistence
 
getExactListTypeIfKnown(List<T>, Function<T, AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.Lists
Returns the exact ListType from the items if it can be known.
getExactMapTypeIfKnown(List<Pair<T, T>>, Function<T, AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.Maps
Returns the exact MapType from the entries if it can be known.
getExactSetTypeIfKnown(List<T>, Function<T, AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.Sets
Returns the exact SetType from the items if it can be known.
getExactTupleTypeIfKnown(List<T>, Function<T, AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.Tuples
Returns the exact TupleType from the items if it can be known.
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.Constants.Literal
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.Lists.Literal
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.Maps.Literal
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.BetweenParenthesesOrWithTuple
 
getExactTypeIfKnown(String) - Method in interface org.apache.cassandra.cql3.selection.Selectable
The type of the Selectable if it can be infered.
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithCast
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithElementSelection
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFunction
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithList
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithMapOrUdt
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithSet
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithSliceSelection
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithTerm
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithToJSonFunction
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithTypeHint
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.Sets.Literal
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.Term.Raw
The type of the term if it can be infered.
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.Tuples.INRaw
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.Tuples.Literal
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.Tuples.Raw
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.TypeCast
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.UserTypes.Literal
 
getExactTypeIfKnown(String) - Method in class org.apache.cassandra.schema.ColumnMetadata
 
getExceptionCount() - Method in class org.apache.cassandra.tools.NodeProbe
 
getExistingColumn(ColumnIdentifier) - Method in class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
 
getExistingColumn(ColumnIdentifier) - Method in class org.apache.cassandra.schema.TableMetadata
Returns the column of the provided name if it exists, but throws a user-visible exception if that column doesn't exist.
getExistingTableMetadata(TableId) - Method in interface org.apache.cassandra.schema.SchemaProvider
 
getExpectedCompactedFileSize(Iterable<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Calculate expected file size of SSTable after compaction.
getExpireTimeForEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
 
getExpressions() - Method in class org.apache.cassandra.db.filter.RowFilter
 
getExpressions() - Method in class org.apache.cassandra.index.sasi.plan.QueryController
 
getFailedHosts() - Method in class org.apache.cassandra.io.sstable.SSTableLoader
 
getFailureDetectorPhilValues(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
 
getFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getfd(FileChannel) - Static method in class org.apache.cassandra.utils.NativeLibrary
 
getfd(FileDescriptor) - Static method in class org.apache.cassandra.utils.NativeLibrary
Get system file descriptor from FileDescriptor object.
getFifteenMinuteRate() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
 
getFifteenMinuteRate() - Method in class org.apache.cassandra.metrics.LatencyMetrics.LatencyMetricsTimer
 
getFileCacheEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFileCacheRoundUp() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFileCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFileDataInput(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getFileDescriptor() - Method in class org.apache.cassandra.io.util.ChannelProxy
 
getFileMessages() - Method in class org.apache.cassandra.streaming.StreamTransferTask
 
getFilename() - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
 
getFilename() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getFilename() - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
 
getFilename() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getFilename() - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
 
getFilename() - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
 
getFilePointer() - Method in class org.apache.cassandra.db.commitlog.EncryptedFileSegmentInputStream
 
getFilePointer() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
getFilePointer() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableZeroCopyWriter
 
getFilePointer() - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
 
getFilePointer() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
getFilePointer() - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
 
getFilePointer() - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
 
getFilePointer() - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
 
getFilePointer() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
getFilePointer() - Method in class org.apache.cassandra.io.util.FileSegmentInputStream
 
getFilePointer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
getFiles(Path, BiPredicate<File, Directories.FileType>, Directories.OnTxnErr) - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
Get the files in the folder specified, provided that the filter returns true.
getFileStore(Path) - Static method in class org.apache.cassandra.io.util.FileUtils
Returns the FileStore representing the file store where a file is located.
getFilter(long, int) - Static method in class org.apache.cassandra.utils.FilterFactory
 
getFilter(long, double) - Static method in class org.apache.cassandra.utils.FilterFactory
 
getFilteredCurrentToken() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
 
getFinalSessionRepairedAt(UUID) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
Returns the repairedAt time for a sessions which is unknown, failed, or finalized calling this for a session which is in progress throws an exception
getFirstColumn() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
 
getFirstColumn() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Returns the definition of the first column.
getFirstColumn() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
 
getFirstColumn() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
getFiveMinuteRate() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
 
getFiveMinuteRate() - Method in class org.apache.cassandra.metrics.LatencyMetrics.LatencyMetricsTimer
 
getFlags() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
getFloat(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a float.
getFloat(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a float.
getFloat(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a float.
getFloat(byte[], int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
getFlushBeforeTransfer() - Method in class org.apache.cassandra.streaming.StreamPlan
 
getFlushCompression() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFlushObserver(Descriptor, OperationType) - Method in interface org.apache.cassandra.index.Index
Get flush observer to observe partition/cell events generated by flushing SSTable (memtable flush or compaction).
getFlushObserver(Descriptor, OperationType) - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
getFlushWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getForAccessor(ValueAccessor) - Method in class org.apache.cassandra.db.marshal.ValueComparators
 
getForcedProtocolVersion() - Method in exception org.apache.cassandra.transport.ProtocolException
 
getFormat() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
getFreeSpace(File) - Static method in class org.apache.cassandra.io.util.FileUtils
Returns the number of unallocated bytes on the specified partition.
getFrozenList(String, AbstractType<T>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getFrozenMap(String, AbstractType<K>, AbstractType<V>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getFrozenSet(String, AbstractType<T>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getFrozenTextMap(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
GetFullQueryLog - Class in org.apache.cassandra.tools.nodetool
 
GetFullQueryLog() - Constructor for class org.apache.cassandra.tools.nodetool.GetFullQueryLog
 
getFullQueryLoggerOptions() - Method in class org.apache.cassandra.fql.FullQueryLogger
 
getFullQueryLoggerOptions() - Method in class org.apache.cassandra.service.StorageService
 
getFullQueryLoggerOptions() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the current state of FQL.
getFullQueryLoggerOptions() - Method in class org.apache.cassandra.tools.NodeProbe
 
getFullQueryLogOptions() - 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, boolean) - Static method in class org.apache.cassandra.db.compaction.CompactionController
Finds expired sstables works something like this; 1.
getFullyExpiredSSTables(ColumnFamilyStore, Iterable<SSTableReader>, Iterable<SSTableReader>, int) - Static method in class org.apache.cassandra.db.compaction.CompactionController
 
getFunctionName() - Method in class org.apache.cassandra.auth.FunctionResource
 
getFunctionName(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.CastFcts
Creates the name of the cast function use to cast to the specified type.
getFunctionName(CQL3Type) - Static method in class org.apache.cassandra.cql3.functions.CastFcts
Creates the name of the cast function use to cast to the specified type.
getFunctionNameFromOperator(char) - Static method in class org.apache.cassandra.cql3.functions.OperationFcts
Returns the name of the function associated to the specified operator.
getFunctions() - Method in interface org.apache.cassandra.cql3.CQLStatement
Return an Iterable over all of the functions (both native and user-defined) used by any component of the statement
getFunctions() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
getFunctions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
getFunctions() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
getFunctions(FunctionName) - Method in class org.apache.cassandra.schema.Schema
Get all function overloads with the specified name
getGCLogThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getGcLogThresholdInMs() - Method in class org.apache.cassandra.service.GCInspector
 
getGcLogThresholdInMs() - Method in interface org.apache.cassandra.service.GCInspectorMXBean
 
getGCWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getGcWarnThresholdInMs() - Method in class org.apache.cassandra.service.GCInspector
 
getGcWarnThresholdInMs() - Method in interface org.apache.cassandra.service.GCInspectorMXBean
 
getGlobalLimit() - Static method in class org.apache.cassandra.transport.ClientResourceLimits
 
getGossipInfo(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
 
getGossipMessageCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Deprecated.
getGossipMessageCompletedTasks() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getGossipMessageCompletedTasksWithPort() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
 
getGossipMessageCompletedTasksWithPort() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getGossipMessageDroppedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Deprecated.
getGossipMessageDroppedTasks() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getGossipMessageDroppedTasksWithPort() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
 
getGossipMessageDroppedTasksWithPort() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getGossipMessagePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Deprecated.
getGossipMessagePendingTasks() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getGossipMessagePendingTasksWithPort() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
 
getGossipMessagePendingTasksWithPort() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getGossProxy() - Method in class org.apache.cassandra.tools.NodeProbe
 
getGroup() - Method in class org.apache.cassandra.db.CassandraWriteContext
 
getGroup(int) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder.GroupedSSTableContainer
 
getGroup() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Returns the group to which the Metric belongs.
getHashBuckets(IFilter.FilterKey, int, long) - Method in class org.apache.cassandra.utils.BloomFilter
 
getHeader(TableMetadata) - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader
 
getHeapMemoryUsage() - Method in class org.apache.cassandra.tools.NodeProbe
 
getHeapSize() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
getHeapSize() - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
 
getHeapSize() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
getHeapSize() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner.StringToken
 
getHeapSize() - Method in class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
 
getHeapSize() - Method in class org.apache.cassandra.dht.Token
 
getHintedHandoffDisabledDCs() - Method in class org.apache.cassandra.service.StorageProxy
 
getHintedHandoffDisabledDCs() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getHintedHandoffDisabledDCs() - Method in class org.apache.cassandra.tools.NodeProbe
 
getHintedHandoffEnabled() - Method in class org.apache.cassandra.service.StorageProxy
 
getHintedHandoffEnabled() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getHintedHandoffThrottleInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getHintsCompression() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getHintsDirectory() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getHintsFlushPeriodInMS() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getHintsInProgress() - Method in class org.apache.cassandra.service.StorageProxy
 
getHintsInProgress() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getHollowByteBuffer() - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getHollowDirectByteBuffer() - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getHollowDirectByteBuffer(ByteOrder) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getHost() - Method in class org.apache.cassandra.audit.AuditLogEntry
 
getHostAddress(boolean) - Method in class org.apache.cassandra.locator.InetAddressAndPort
 
getHostAddressAndPort() - Method in class org.apache.cassandra.locator.InetAddressAndPort
 
getHostAddressAndPortForJMX() - Method in class org.apache.cassandra.locator.InetAddressAndPort
Return a version of getHostAddressAndPort suitable for use in JMX object names without requiring any escaping.
getHostId(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
 
getHostId(InetAddressAndPort, Map<InetAddressAndPort, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
 
getHostId(InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
Return the unique host ID for an end-point.
getHostIdForEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.service.StorageService
 
getHostIdMap() - Method in class org.apache.cassandra.service.StorageService
 
getHostIdMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
getHostIdMap(boolean) - 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
Deprecated.
getHostIdToEndpointWithPort() - Method in class org.apache.cassandra.service.StorageService
 
getHostIdToEndpointWithPort() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getHosts() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
getId() - Method in class org.apache.cassandra.cql3.statements.schema.TableAttributes
 
getId() - Method in class org.apache.cassandra.repair.RepairSession
 
getId(ProtocolVersion) - Method in enum org.apache.cassandra.transport.DataType
 
getIdealConsistencyLevel() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getIdealConsistencyLevel() - Method in class org.apache.cassandra.service.StorageProxy
 
getIdealConsistencyLevel() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getIfExists(TableId) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
Returns a ColumnFamilyStore by id if it exists, null otherwise Differently from others, this method does not throw exception if the table does not exist.
getIfExists(String, String) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
Returns a ColumnFamilyStore by ksname and cfname if it exists, null otherwise Differently from others, this method does not throw exception if the keyspace or table does not exist.
getIfPresent(K) - Method in class org.apache.cassandra.locator.ReplicaMultimap.Builder
 
getIgnoreHosts(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
Get the hosts to ignore as a collection of strings
getIncoming() - Method in class org.apache.cassandra.repair.asymmetric.IncomingRepairStreamTracker
 
getIndex(ColumnFamilyStore) - Method in class org.apache.cassandra.db.ReadCommand
 
getIndex(IndexMetadata) - Method in interface org.apache.cassandra.index.IndexRegistry
 
getIndex(ColumnMetadata) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
 
getIndex(RowFilter.Expression) - Method in class org.apache.cassandra.index.sasi.plan.QueryController
 
getIndex() - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
getIndex(IndexMetadata) - Method in class org.apache.cassandra.index.SecondaryIndexManager
 
getIndexAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getIndexBuildTask(ColumnFamilyStore, Set<Index>, Collection<SSTableReader>) - Method in class org.apache.cassandra.index.Index.CollatedViewIndexBuildingSupport
 
getIndexBuildTask(ColumnFamilyStore, Set<Index>, Collection<SSTableReader>) - Method in interface org.apache.cassandra.index.Index.IndexBuildingSupport
 
getIndexByName(String) - Method in class org.apache.cassandra.index.SecondaryIndexManager
 
getIndexCfs() - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
getIndexChannel() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getIndexComparator() - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
getIndexedColumn() - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
getIndexedValue(ByteBuffer, Clustering<?>, CellPath, ByteBuffer) - Method in class org.apache.cassandra.index.internal.CassandraIndex
Extract the value to be inserted into the index from the components of the base data
getIndexedValue(ByteBuffer, Clustering<?>, CellPath, ByteBuffer) - Method in class org.apache.cassandra.index.internal.composites.ClusteringColumnIndex
 
getIndexedValue(ByteBuffer, Clustering<?>, CellPath, ByteBuffer) - Method in class org.apache.cassandra.index.internal.composites.CollectionEntryIndex
 
getIndexedValue(ByteBuffer, Clustering<?>, CellPath, ByteBuffer) - Method in class org.apache.cassandra.index.internal.composites.CollectionKeyIndex
 
getIndexedValue(ByteBuffer, Clustering<?>, CellPath, ByteBuffer) - Method in class org.apache.cassandra.index.internal.composites.CollectionValueIndex
 
getIndexedValue(ByteBuffer, Clustering<?>, CellPath, ByteBuffer) - Method in class org.apache.cassandra.index.internal.composites.PartitionKeyIndex
 
getIndexedValue(ByteBuffer, Clustering<?>, CellPath, ByteBuffer) - Method in class org.apache.cassandra.index.internal.composites.RegularColumnIndex
 
getIndexedValue(ByteBuffer, Clustering<?>, CellPath, ByteBuffer) - Method in class org.apache.cassandra.index.internal.keys.KeysIndex
 
getIndexedValueType(ColumnMetadata) - Method in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
Returns the type of the the values in the index.
getIndexes() - Method in class org.apache.cassandra.index.sasi.conf.view.View
 
getIndexes(Operation.OperationType, Collection<Expression>) - Method in class org.apache.cassandra.index.sasi.plan.QueryController
Build a range iterator from the given list of expressions by applying given operation (OR/AND).
getIndexesAsCQL(TableMetadata, boolean) - Static method in class org.apache.cassandra.db.SchemaCQLHelper
Build a CQL String representation of Indexes on columns in the given Column Family
getIndexFile() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getIndexFilename() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getIndexForSSTable(SSTableReader) - Method in interface org.apache.cassandra.db.compaction.AbstractStrategyHolder.DestinationRouter
 
getIndexForSSTableDirectory(Descriptor) - Method in interface org.apache.cassandra.db.compaction.AbstractStrategyHolder.DestinationRouter
 
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.
getIndexMetadata() - Method in interface org.apache.cassandra.index.Index
Returns the IndexMetadata which configures and defines the index instance.
getIndexMetadata() - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
getIndexMetadata() - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
getIndexName() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
getIndexName(ColumnFamilyStore) - Static method in class org.apache.cassandra.index.SecondaryIndexManager
Returns the index name
getIndexName(String) - Static method in class org.apache.cassandra.index.SecondaryIndexManager
Returns the index name
getIndexOf(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the index corresponding to a given name.
getIndexPath() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
getIndexRestrictions() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
getIndexScanPosition(PartitionPosition) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Gets the position in the index file to start scanning to find the given key (at most indexInterval keys away, modulo downsampling of the index summary).
getIndexScanPositionFromBinarySearchResult(int, IndexSummary) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getIndexSerializer(TableMetadata, Version, SerializationHeader) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
 
getIndexSerializer(TableMetadata, Version, SerializationHeader) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
 
getIndexSummaryCapacityInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getIndexSummaryIndexFromBinarySearchResult(int) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getIndexSummaryKey(int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Returns the key for the index summary entry at `index`.
getIndexSummaryOffHeapSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getIndexSummaryResizeIntervalInMinutes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getIndexSummarySamplingLevel() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getIndexSummarySize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Returns the number of entries in the IndexSummary.
getIndexTableMetadataRef(String, String) - Method in class org.apache.cassandra.schema.Schema
 
getIndexValue() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
If this expression is used to query an index, the value to use as partition key for that index query.
getInet(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as an InetAddress.
getInet(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as an InetAddress.
getInet(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as an InetAddress.
getInetAddress(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getInflightTasks() - Method in class org.apache.cassandra.schema.MigrationCoordinator
 
getInitializationTask() - Method in interface org.apache.cassandra.index.Index
Return a task to perform any initialization work when a new index instance is created.
getInitializationTask() - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
getInitializationTask() - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
getInitialRangeTombstoneListAllocationSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInitialRangeTombstoneListAllocationSize() - Method in class org.apache.cassandra.service.StorageService
 
getInitialRangeTombstoneListAllocationSize() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the initial allocation size of backing arrays for new RangeTombstoneList objects
getInitialTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInputCluster(String, Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputCluster(String[], Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputColumnFamily(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputcolumns(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputCoreConnections(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputCql(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
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
The start and end token of the input key range as a pair.
getInputKeyspace(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputKeyspacePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputKeyspaceUserName(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputMaxConnections(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputMaxSimultReqPerConnections(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeAuthProvider(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeConnectionTimeout(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeKeepAlive(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativePort(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeReadConnectionTimeout(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeReceiveBufferSize(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeReuseAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeSendBufferSize(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeSolinger(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeSSLCipherSuites(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeSSLKeystorePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeSSLKeystorePath(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeSSLTruststorePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeSSLTruststorePath(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputNativeTcpNodelay(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputPageRowSize(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInputPartitioner(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputSplit() - Method in class org.apache.cassandra.hadoop.ReporterWrapper
 
getInputSplitSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputSplitSizeInMb(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
cassandra.input.split.size will be used if the value is undefined or negative.
getInputStream(File, File) - Method in interface org.apache.cassandra.cache.AutoSavingCache.IStreamFactory
 
getInputWhereClauses(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getInstance(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.FromJsonFct
 
getInstance(List<AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.functions.ToJsonFct
 
getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.CompositeType
 
getInstance(Iterable<AbstractType<?>>) - 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.PartitionerDefinedOrder
 
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>, ValueComparators) - Static method in class org.apache.cassandra.serializers.MapSerializer
 
getInstance(TypeSerializer<T>, ValueComparators) - Static method in class org.apache.cassandra.serializers.SetSerializer
 
getInstanceForTesting() - Static method in class org.apache.cassandra.service.CassandraDaemon
 
getInt() - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
Gets the value of a system property as a int.
getInt(int) - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
Gets the value of a system property as a int.
getInt(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as an integer.
getInt(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as an integer.
getInt(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as an integer.
getInt(String, Integer) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
getInt(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getInt(byte[], int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
getInt(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
getInt(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
returns an int from offset
getInt() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
getInt(long) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
getInt(long) - Method in class org.apache.cassandra.io.util.Memory
 
getInt(byte[], int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
getInt(byte[]) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
getInt(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getIntByByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getInterDCStreamThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
 
GetInterDCStreamThroughput - Class in org.apache.cassandra.tools.nodetool
 
GetInterDCStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.GetInterDCStreamThroughput
 
getInterDCStreamThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
 
getInterDCStreamThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getInterDCStreamThroughputOutboundMegabitsPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInterDCTcpNoDelay() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternal(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
getInternalStatements() - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
getInterned(ByteBuffer, AbstractType<?>) - Static method in class org.apache.cassandra.cql3.ColumnIdentifier
 
getInterned(String, boolean) - Static method in class org.apache.cassandra.cql3.ColumnIdentifier
 
getInterned(AbstractType<?>, ByteBuffer, String) - Static method in class org.apache.cassandra.cql3.ColumnIdentifier
 
getInternodeApplicationReceiveQueueCapacityInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternodeApplicationReceiveQueueReserveEndpointCapacityInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternodeApplicationReceiveQueueReserveGlobalCapacityInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternodeApplicationSendQueueCapacityInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternodeApplicationSendQueueReserveEndpointCapacityInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternodeApplicationSendQueueReserveGlobalCapacityInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternodeAuthenticator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternodeMaxMessageSizeInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternodeMessagingEncyptionOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternodeSocketReceiveBufferSizeInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternodeSocketSendBufferSizeInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternodeStreamingTcpUserTimeoutInMS() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternodeStreamingTcpUserTimeoutInMS() - Method in class org.apache.cassandra.service.StorageService
 
getInternodeStreamingTcpUserTimeoutInMS() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getInternodeTcpConnectTimeoutInMS() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternodeTcpConnectTimeoutInMS() - Method in class org.apache.cassandra.service.StorageService
 
getInternodeTcpConnectTimeoutInMS() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getInternodeTcpUserTimeoutInMS() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternodeTcpUserTimeoutInMS() - Method in class org.apache.cassandra.service.StorageService
 
getInternodeTcpUserTimeoutInMS() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getInvalidateTask() - Method in interface org.apache.cassandra.index.Index
Return a task which invalidates the index, indicating it should no longer be considered usable.
getInvalidateTask() - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
getInvalidateTask() - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
getInvalidMutations() - Method in class org.apache.cassandra.db.commitlog.CommitLogReader
 
getInValues() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
getInValues() - Method in class org.apache.cassandra.cql3.Relation
Returns the list of raw IN values for this relation, or null if this is not an IN relation.
getInValues() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
getInValues() - Method in class org.apache.cassandra.cql3.TokenRelation
 
getIsTransient(Set<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
 
getIV() - Method in class org.apache.cassandra.security.EncryptionContext
 
getJavaType() - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the Java type that this codec deserializes to and serializes from.
getJobThreads() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
getJoiningNodes() - Method in class org.apache.cassandra.service.StorageService
Deprecated.
getJoiningNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
getJoiningNodes(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
 
getJoiningNodesWithPort() - Method in class org.apache.cassandra.service.StorageService
 
getJoiningNodesWithPort() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getJsonColumnValue(int, ColumnIdentifier, Collection<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.QueryOptions
Returns the term corresponding to column columnName in the JSON value of bind index bindIndex.
getJsonDateFormatter() - Static method in class org.apache.cassandra.serializers.TimestampSerializer
 
getJustBroadcastAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
Retrieve just the broadcast address but not the port.
getJustBroadcastNativeAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
This returns the address that is bound to for the native protocol for communicating with clients.
getJustLocalAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
Please use getJustBroadcastAddress instead.
getKey() - Method in enum org.apache.cassandra.config.CassandraRelevantEnv
 
getKey() - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
 
getKey() - Method in class org.apache.cassandra.db.BufferDecoratedKey
 
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.service.reads.AbstractReadExecutor
 
getKeyCache() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getKeyCacheHit() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getKeyCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getKeyCacheKeysToSave() - Method in class org.apache.cassandra.service.CacheService
 
getKeyCacheKeysToSave() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getKeyCacheRequest() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getKeyCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getKeyCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
 
getKeyCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getKeyCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getKeyPosition() - Method in class org.apache.cassandra.io.sstable.KeyIterator
 
getKeySamples(Range<Token>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getKeyspace() - Method in class org.apache.cassandra.audit.AuditLogEntry
 
getKeyspace() - Method in class org.apache.cassandra.auth.DataResource
 
getKeyspace() - Method in class org.apache.cassandra.auth.FunctionResource
Get the name of the keyspace this resource relates to.
getKeyspace() - Method in class org.apache.cassandra.cql3.BatchQueryOptions
 
getKeyspace() - Method in class org.apache.cassandra.cql3.functions.types.UserType
The name of the keyspace this UDT is part of.
getKeyspace() - Method in class org.apache.cassandra.cql3.QualifiedName
 
getKeyspace() - Method in class org.apache.cassandra.cql3.QueryOptions
The keyspace that this query is bound to, or null if not relevant.
getKeyspace() - Method in class org.apache.cassandra.cql3.UTName
 
getKeyspace() - Method in class org.apache.cassandra.db.AbstractCompactionController
 
getKeyspace() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getKeyspace() - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
getKeyspace() - Method in class org.apache.cassandra.service.ClientState
 
getKeyspaceCountWarnThreshold() - Method in class org.apache.cassandra.service.StorageService
 
getKeyspaceCountWarnThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getKeyspaceInstance(String) - Method in class org.apache.cassandra.schema.Schema
Get keyspace instance by name
getKeyspaceInstance(String) - Method in interface org.apache.cassandra.schema.SchemaProvider
 
getKeyspaceMetadata(String) - Method in class org.apache.cassandra.schema.Schema
Get metadata about keyspace by its name
getKeyspaceMetadata(String) - Method in interface org.apache.cassandra.schema.SchemaProvider
 
getKeyspaceMetadataNullable(String) - Method in class org.apache.cassandra.db.virtual.VirtualKeyspaceRegistry
 
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.db.Mutation.PartitionUpdateCollector
 
getKeyspaceName() - Method in class org.apache.cassandra.db.virtual.VirtualMutation
 
getKeyspaceName() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getKeyspaceNullable(String) - Method in class org.apache.cassandra.db.virtual.VirtualKeyspaceRegistry
 
getKeyspaceReplicationInfo(String) - Method in class org.apache.cassandra.service.StorageService
 
getKeyspaceReplicationInfo(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Fetch the replication factor for a given keyspace.
getKeyspaceReplicationInfo(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getKeyspaces() - Method in class org.apache.cassandra.schema.Schema
 
getKeyspaces() - Method in class org.apache.cassandra.service.StorageService
 
getKeyspaces() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getKeyspaces() - Method in class org.apache.cassandra.tools.NodeProbe
 
getKeysType() - Method in class org.apache.cassandra.db.marshal.MapType
 
getKeyType() - Method in class org.apache.cassandra.db.SerializationHeader.Component
 
getKeyValidator() - Method in class org.apache.cassandra.index.sasi.plan.QueryController
 
getKeyValueParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
 
getKSChildDirectories(String) - Static method in class org.apache.cassandra.db.Directories
 
getLargeMessageCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Deprecated.
getLargeMessageCompletedTasks() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getLargeMessageCompletedTasksWithPort() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
 
getLargeMessageCompletedTasksWithPort() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getLargeMessageDroppedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Deprecated.
getLargeMessageDroppedTasks() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getLargeMessageDroppedTasksWithPort() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
 
getLargeMessageDroppedTasksWithPort() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getLargeMessagePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Deprecated.
getLargeMessagePendingTasks() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getLargeMessagePendingTasksWithPort() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
 
getLargeMessagePendingTasksWithPort() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getLargestBucketOffset() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
getLastColumn() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
 
getLastColumn() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Returns the definition of the last column.
getLastColumn() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
 
getLastColumn() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
getLastEventId() - Method in class org.apache.cassandra.diag.store.DiagnosticEventMemoryStore
 
getLastEventId() - Method in interface org.apache.cassandra.diag.store.DiagnosticEventStore
Returns the greatest event ID that can be used to fetch events via DiagnosticEventStore.scan(Comparable, int).
getLastEventIds() - Method in interface org.apache.cassandra.diag.LastEventIdBroadcasterMBean
Retrieves a list of all event types and their highest IDs.
getLastEventIdsIfModified(long) - Method in interface org.apache.cassandra.diag.LastEventIdBroadcasterMBean
Retrieves a list of all event types and their highest IDs, if updated since specified timestamp, or null.
getLastFlushOffset() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
getLastIntervalAcquire() - Method in class org.apache.cassandra.utils.concurrent.IntervalLock
 
getLastReadableBoundary() - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
getLastReturned() - Method in class org.apache.cassandra.db.DataRange.Paging
 
getLastUpdate() - Method in class org.apache.cassandra.repair.consistent.LocalSession
 
getLatestVersion() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
 
getLatestVersion() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
 
getLeavingEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
caller should not modify leavingEndpoints
getLeavingNodes() - Method in class org.apache.cassandra.service.StorageService
Deprecated.
getLeavingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
getLeavingNodes(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
 
getLeavingNodesWithPort() - Method in class org.apache.cassandra.service.StorageService
 
getLeavingNodesWithPort() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getLength() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
getLength() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
getLengthInBytes() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
 
getLengthInBytes() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
getLengthInBytes() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
 
getLevel() - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
getLevel() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
 
getLevelCount() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
getLevelFanoutSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getLevelFanoutSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getLevelFanoutSize() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
getLevelFanoutSize() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
getLevelSize(int) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
getLevelSize(int) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
getLimit(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
Returns the limit specified by the user.
getList(String, Class<T>) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a list.
getList(String, TypeToken<T>) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a list.
getList(int, Class<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a list.
getList(int, TypeToken<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a list.
getList(String, Class<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a list.
getList(String, TypeToken<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a list.
getList(String, AbstractType<T>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getListenAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getLiveDataSize() - Method in class org.apache.cassandra.db.Memtable
 
getLiveMembers() - Method in class org.apache.cassandra.gms.Gossiper
 
getLiveNodes() - Method in class org.apache.cassandra.service.StorageService
Deprecated.
getLiveNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
getLiveNodes(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
 
getLiveNodesWithPort() - Method in class org.apache.cassandra.service.StorageService
 
getLiveNodesWithPort() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getLiveRingMembers() - Method in class org.apache.cassandra.service.StorageService
 
getLiveRingMembers(boolean) - Method in class org.apache.cassandra.service.StorageService
 
getLiveSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getLiveTokenOwners() - Method in class org.apache.cassandra.gms.Gossiper
 
getLoadInfo() - Method in class org.apache.cassandra.service.LoadBroadcaster
 
getLoadMap() - Method in class org.apache.cassandra.service.StorageService
 
getLoadMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
getLoadMap(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
 
getLoadMapWithPort() - Method in class org.apache.cassandra.service.StorageService
 
getLoadMapWithPort() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
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
 
getLocal() - Method in class org.apache.cassandra.schema.TableMetadataRef
Returns node-local table metadata
getLocalAddressAndPort() - Static method in class org.apache.cassandra.utils.FBUtilities
The address and port to listen on for intra-cluster storage traffic (not client).
getLocalAndPendingRanges(String) - Method in class org.apache.cassandra.service.StorageService
 
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
 
getLocalCount(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Returns the count associated with the local counter id, or 0 if no such shard is present.
getLocalDataCenter() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getLocalDatacenter() - Method in interface org.apache.cassandra.locator.IEndpointSnitch
returns a String representing the datacenter current endpoint belongs to
getLocale() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
getLocalHost() - Static method in class org.apache.cassandra.locator.InetAddressAndPort
 
getLocalHostId() - Static method in class org.apache.cassandra.db.SystemKeyspace
Read the host ID from the system keyspace.
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
 
getLocalHostUUID() - Method in class org.apache.cassandra.service.StorageService
 
getLocalId() - Static method in class org.apache.cassandra.utils.CounterId
 
getLocalPrimaryRange() - Method in class org.apache.cassandra.service.StorageService
 
getLocalPrimaryRangeForDC(String, Metadata, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlClientHelper
 
getLocalPrimaryRangeForEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.service.StorageService
 
getLocalRack() - Method in interface org.apache.cassandra.locator.IEndpointSnitch
returns a String representing the rack current endpoint belongs to
getLocalReplicaFor(RingPosition<?>) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getLocalReplicas(String) - Method in class org.apache.cassandra.service.StorageService
 
getLocalSystemKeyspacesDataFileLocations() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
Returns the locations where the local system keyspaces data should be stored.
getLocalSystemKeyspacesDataFileLocations() - Method in class org.apache.cassandra.service.StorageService
 
getLocalSystemKeyspacesDataFileLocations() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the locations where the local system keyspaces data should be stored.
getLocalTokens() - Method in class org.apache.cassandra.service.StorageService
 
getLocation(InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata.Topology
 
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() - Method in class org.apache.cassandra.audit.AuditLogManager
 
getLogger(Logger, long, TimeUnit) - Static method in class org.apache.cassandra.utils.NoSpamLogger
 
getLoggingLevels() - Method in class org.apache.cassandra.service.StorageService
 
getLoggingLevels() - Method in interface org.apache.cassandra.service.StorageServiceMBean
get the runtime logging levels
getLoggingLevels() - Method in class org.apache.cassandra.tools.NodeProbe
 
GetLoggingLevels - Class in org.apache.cassandra.tools.nodetool
 
GetLoggingLevels() - Constructor for class org.apache.cassandra.tools.nodetool.GetLoggingLevels
 
getLoggingLevels() - Method in class org.apache.cassandra.utils.logging.LogbackLoggingSupport
 
getLoggingLevels() - Method in interface org.apache.cassandra.utils.logging.LoggingSupport
 
getLoggingLevels() - Method in class org.apache.cassandra.utils.logging.NoOpFallbackLoggingSupport
 
getLoggingSupport() - Static method in class org.apache.cassandra.utils.logging.LoggingSupportFactory
 
getLogin() - Method in class org.apache.cassandra.auth.RoleOptions
Return a boolean value of the login option
getLong(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a long.
getLong(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a long.
getLong(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a long.
getLong(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getLong(byte[], int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
getLong(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
getLong(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
returns a long from offset
getLong() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
getLong(long) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
getLong(long) - Method in class org.apache.cassandra.io.util.Memory
 
getLong(byte[]) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
getLong(byte[], int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
getLong(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getLongByByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getLoopbackAddress() - Static method in class org.apache.cassandra.locator.InetAddressAndPort
 
getManagers() - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
getMap(String, Class<K>, Class<V>) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a map.
getMap(String, TypeToken<K>, TypeToken<V>) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a map.
getMap(int, Class<K>, Class<V>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a map.
getMap(int, TypeToken<K>, TypeToken<V>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a map.
getMap(String, Class<K>, Class<V>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a map.
getMap(String, TypeToken<K>, TypeToken<V>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a map.
getMap(String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
getMap(String, AbstractType<K>, AbstractType<V>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getMapKey() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
getMappings() - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
getMappings() - Method in interface org.apache.cassandra.cql3.selection.SelectionColumns
 
getMax() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
getMax() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
getMaxConcurrentAutoUpgradeTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getMaxConcurrentAutoUpgradeTasks() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Get the number of concurrent sstable upgrade tasks we should run when automatic sstable upgrades are enabled
getMaxDataAge(Collection<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
 
getMaxEntries() - Method in class org.apache.cassandra.auth.AuthCache
 
getMaxEntries() - Method in interface org.apache.cassandra.auth.AuthCacheMBean
 
getMaxHintsDeliveryThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getMaxHintsFileSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getMaxHintsInProgress() - Method in class org.apache.cassandra.service.StorageProxy
 
getMaxHintsInProgress() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getMaxHintWindow() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getMaxHintWindow() - Method in class org.apache.cassandra.service.StorageProxy
 
getMaxHintWindow() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getMaxHintWindow() - Method in class org.apache.cassandra.tools.NodeProbe
 
GetMaxHintWindow - Class in org.apache.cassandra.tools.nodetool
 
GetMaxHintWindow() - Constructor for class org.apache.cassandra.tools.nodetool.GetMaxHintWindow
 
getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
Deprecated.
 
getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
getMaximalTask(int, boolean) - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
 
getMaximalTasks(int, boolean) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
 
getMaximalTasks(int, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
getMaximalTasks(int, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
getMaximalTasks(int, boolean) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
getMaximum() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
 
getMaximum() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator
 
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
getMaximumPoolSize() - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
 
getMaximumPoolSize() - Method in interface org.apache.cassandra.concurrent.ResizableThreadPool
Returns maximum pool size of thread pool.
getMaximumPoolSize() - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
getMaximumPoolSize() - Method in enum org.apache.cassandra.concurrent.Stage
Returns maximum pool size of thread pool.
getMaximumPoolSizes(List<String>) - Method in class org.apache.cassandra.tools.NodeProbe
 
getMaximumThreads() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
Deprecated.
getMaximumThreads() - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
Deprecated.
getMaximumToken() - Method in interface org.apache.cassandra.dht.IPartitioner
The biggest token for this partitioner, unlike getMinimumToken, this token is actually used and users wanting to include all tokens need to do getMaximumToken().maxKeyBound() Not implemented for the ordered partitioners
getMaximumToken() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
 
getMaximumToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
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
getMaximumViewBuildThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getMaximumViewBuildThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Returns size of view build thread pool
getMaxIndexSummarySize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Returns the approximate number of entries the IndexSummary would contain if it were at full sampling.
getMaxLocalDeletionTime() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getMaxMutationSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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.
getMaxOutstandingVersionRequests() - Method in class org.apache.cassandra.schema.MigrationCoordinator
 
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.CompactionStrategyManager
 
getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
Deprecated.
 
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.TimeWindowCompactionStrategy
 
getMaxTasksQueued() - Method in interface org.apache.cassandra.concurrent.LocalAwareExecutorService
 
getMaxTasksQueued() - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
getMaxTimestamp() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getMaxTokenLength() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
getMaxTokenSize() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getMaxTokenSize() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
 
getMaxTokenSize() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getMaxTTL() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getMaxValueSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getMBeanName() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Returns the MBean name for the Metric identified by this metric name.
getMbeanServerConn() - Method in class org.apache.cassandra.tools.NodeProbe
 
getMean() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
getMean() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
getMeanEstimatedCellPerPartitionCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMeanPartitionSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMeanRate() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
 
getMeanRate() - Method in class org.apache.cassandra.metrics.LatencyMetrics.LatencyMetricsTimer
 
getMeanRowCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
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.
getMemtableAllocationType() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getMemtableCleanupThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getMemtableFor(OpOrder.Group, CommitLogPosition) - Method in class org.apache.cassandra.db.lifecycle.Tracker
get the Memtable that the ordered writeOp should be directed to
getMemtableHeapSpaceInMb() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getMemtableOffheapSpaceInMb() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getMergedRowCounts() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
 
getMergeListener(P) - Method in class org.apache.cassandra.service.reads.repair.BlockingReadRepair
 
getMergeListener(P) - Method in class org.apache.cassandra.service.reads.repair.NoopReadRepair
 
getMergeListener(P) - Method in class org.apache.cassandra.service.reads.repair.ReadOnlyReadRepair
 
getMergeListener(P) - Method in interface org.apache.cassandra.service.reads.repair.ReadRepair
Used by DataResolver to generate corrections as the partition iterator is consumed
getMerkleTree(Range<Token>) - Method in class org.apache.cassandra.utils.MerkleTrees
Get the MerkleTree responsible for the given token range.
getMessage() - Method in exception org.apache.cassandra.exceptions.RepairException
 
getMessage() - Method in interface org.apache.cassandra.exceptions.TransportException
The exception message.
getMessage() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
 
getMessages() - Method in class org.apache.cassandra.service.reads.ResponseResolver
 
getMessageSender() - Method in class org.apache.cassandra.streaming.StreamSession
 
getMessagingQueueWaitMetrics(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getMessagingServiceProxy() - Method in class org.apache.cassandra.tools.NodeProbe
 
getMessagingVersion() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
getMetadata() - Method in class org.apache.cassandra.db.Keyspace
 
getMetadataReloadTask(IndexMetadata) - Method in interface org.apache.cassandra.index.Index
Return a task to reload the internal metadata of an index.
getMetadataReloadTask(IndexMetadata) - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
getMetadataReloadTask(IndexMetadata) - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
getMetadataSerializer() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
getMetricName() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
 
getMetrics() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
getMetrics() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getMigrateKeycacheOnCompaction() - Method in class org.apache.cassandra.service.StorageService
 
getMigrateKeycacheOnCompaction() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getMin() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
getMin() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
getMinFreeSpacePerDriveInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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.
getMinimum() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
 
getMinimum() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator
 
getMinimumCompactionThreshold() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMinimumCompactionThreshold() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Gets the minimum number of sstables in queue before compaction kicks off
getMinimumToken() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
getMinimumToken() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getMinimumToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
getMinimumToken() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
 
getMinimumToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getMinimumToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getMinIndexInterval() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getMinIndexInterval() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
getMinLocalDeletionTime() - Method in class org.apache.cassandra.db.Memtable.MemtableUnfilteredPartitionIterator
 
getMinLocalDeletionTime() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getMinRepairedAt(Set<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
 
getMinRpcTimeout(TimeUnit) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getMinTimestamp() - Method in class org.apache.cassandra.db.Memtable
 
getMinTimestamp() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getMinTokenLength() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
getMinTTL() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getMode() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
getMode(ColumnMetadata, Optional<IndexMetadata>) - Static method in class org.apache.cassandra.index.sasi.conf.IndexMode
 
getMode(ColumnMetadata, Map<String, String>) - Static method in class org.apache.cassandra.index.sasi.conf.IndexMode
 
getMode() - Method in class org.apache.cassandra.index.sasi.sa.SA
 
getMonth() - Method in class org.apache.cassandra.cql3.functions.types.LocalDate
Returns the month.
getMonths() - Method in class org.apache.cassandra.cql3.Duration
 
getMonths() - Method in class org.apache.cassandra.cql3.functions.types.Duration
Returns the number of months in this duration.
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
Deprecated.
getMovingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
getMovingNodes(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
 
getMovingNodesWithPort() - Method in class org.apache.cassandra.service.StorageService
 
getMovingNodesWithPort() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getMutation() - Method in class org.apache.cassandra.db.CounterMutation
 
getMutations(BatchQueryOptions, boolean, long, int, long) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
getName() - Method in class org.apache.cassandra.auth.AuthenticatedUser
 
getName() - Method in class org.apache.cassandra.auth.CassandraPrincipal
Return the username for this CassPrincipal.
getName() - Method in class org.apache.cassandra.auth.DataResource
 
getName() - Method in class org.apache.cassandra.auth.FunctionResource
 
getName() - Method in interface org.apache.cassandra.auth.IResource
 
getName() - Method in class org.apache.cassandra.auth.JMXResource
 
getName() - Method in class org.apache.cassandra.auth.RoleResource
 
getName() - Method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the name of that type.
getName(int) - Method in class org.apache.cassandra.cql3.functions.types.TupleValue
 
getName(int) - Method in class org.apache.cassandra.cql3.functions.types.UDTValue
 
getName() - Method in class org.apache.cassandra.cql3.functions.types.UserType.Field
Returns the name of the field.
getName() - Method in class org.apache.cassandra.cql3.QualifiedName
 
getName() - Method in class org.apache.cassandra.cql3.RoleName
 
getName() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getName() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getName() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
getName() - Method in class org.apache.cassandra.db.Keyspace
 
getName() - Method in class org.apache.cassandra.db.streaming.CassandraIncomingFile
 
getName() - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
 
getName() - Method in class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineTask
 
getName() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Returns the name of the Metric.
getName() - Method in enum org.apache.cassandra.repair.RepairParallelism
 
getName() - Method in interface org.apache.cassandra.streaming.IncomingStream
 
getName() - Method in class org.apache.cassandra.streaming.messages.OutgoingStreamMessage
 
getName() - Method in interface org.apache.cassandra.streaming.OutgoingStream
 
getName() - Method in class org.apache.cassandra.tools.JMXTool.Attribute
 
getName() - Method in class org.apache.cassandra.tools.JMXTool.Operation
 
getName() - Method in class org.apache.cassandra.tools.JMXTool.Parameter
 
getNameAsString() - Method in class org.apache.cassandra.db.marshal.UserType
 
getNanoseconds() - Method in class org.apache.cassandra.cql3.Duration
 
getNanoseconds() - Method in class org.apache.cassandra.cql3.functions.types.Duration
Returns the number of nanoseconds in this duration.
getNativeaddress(InetAddressAndPort, boolean) - Method in class org.apache.cassandra.service.StorageService
Return the native address associated with an endpoint as a string.
getNativeProtocolEncryptionOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNativeProtocolVersion() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
Return native version protocol of the cluster connection
getNativeTransportAllowOlderProtocols() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
 
getNativeTransportMaxConcurrentRequestsInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNativeTransportMaxConcurrentRequestsInBytes() - Method in class org.apache.cassandra.service.StorageService
 
getNativeTransportMaxConcurrentRequestsInBytes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getNativeTransportMaxConcurrentRequestsInBytesPerIp() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNativeTransportMaxConcurrentRequestsInBytesPerIp() - Method in class org.apache.cassandra.service.StorageService
 
getNativeTransportMaxConcurrentRequestsInBytesPerIp() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
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
This is the port used with RPC address for the native protocol to communicate with clients.
getNativeTransportPortSSL() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNativeTransportReceiveQueueCapacityInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNaturalEndpoints(String, String, String) - Method in class org.apache.cassandra.service.StorageService
Deprecated.
getNaturalEndpoints(String, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
Deprecated.
getNaturalEndpoints(String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
getNaturalEndpoints(String, ByteBuffer) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
getNaturalEndpointsWithPort(String, String, String) - Method in class org.apache.cassandra.service.StorageService
 
getNaturalEndpointsWithPort(String, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
 
getNaturalEndpointsWithPort(String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getNaturalEndpointsWithPort(String, ByteBuffer) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getNaturalReplicas(RingPosition<?>) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getNaturalReplicas(RingPosition<?>) - Method in class org.apache.cassandra.locator.LocalStrategy
We need to override this even if we override calculateNaturalReplicas, because the default implementation depends on token calculations but LocalStrategy may be used before tokens are set up.
getNaturalReplicasForToken(RingPosition<?>) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
get the (possibly cached) endpoints that should store the given Token.
getNaturalReplicasForToken(String, String, String) - Method in class org.apache.cassandra.service.StorageService
 
getNaturalReplicasForToken(String, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
 
getNeighbors(String, Iterable<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.
getNetworkAuthorizer() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNetworkingCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNetworkInterface(InetAddress) - Static method in class org.apache.cassandra.utils.FBUtilities
 
getNeverPurgeTombstones() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getNeverPurgeTombstones() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getNewEphemeralSnapshotMarkerFile(String) - Method in class org.apache.cassandra.db.Directories
 
getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
Return the next background task Returns a task for the compaction strategy that needs it the most (most estimated remaining tasks)
getNextBackgroundTask(int) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
Deprecated.
 
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.TimeWindowCompactionStrategy
 
getNextLevel(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
getNextToken() - Method in interface org.apache.cassandra.index.sasi.analyzer.StandardTokenizerInterface
Resumes scanning until the next regular expression is matched, the end of input is encountered or an I/O-Error occurs.
getNextVersion() - Static method in class org.apache.cassandra.gms.VersionGenerator
 
getNonLocalStrategyKeyspaces() - Method in class org.apache.cassandra.schema.Schema
 
getNonLocalStrategyKeyspaces() - Method in class org.apache.cassandra.service.StorageService
 
getNonLocalStrategyKeyspaces() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getNonLocalStrategyKeyspaces() - Method in class org.apache.cassandra.tools.NodeProbe
 
getNonLocalSystemKeyspacesDataFileLocations() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
Returns the locations where the non local system keyspaces data should be stored.
getNonLocalSystemKeyspacesDataFileLocations() - Method in class org.apache.cassandra.service.StorageService
 
getNonLocalSystemKeyspacesDataFileLocations() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the locations where should be stored the non system keyspaces data.
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.schema.Schema
 
getNonSystemKeyspaces() - Method in class org.apache.cassandra.service.StorageService
 
getNonSystemKeyspaces() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getNonSystemKeyspaces() - Method in class org.apache.cassandra.tools.NodeProbe
 
getNormalAndBootstrappingTokenToEndpointMap() - Method in class org.apache.cassandra.locator.TokenMetadata
 
getNotificationInfo() - Method in class org.apache.cassandra.streaming.StreamManager
 
getNow() - Method in class org.apache.cassandra.net.AsyncPromise
if isSuccess(), returns the value, otherwise returns null
getNowInSeconds(QueryState) - Method in class org.apache.cassandra.cql3.BatchQueryOptions
 
getNowInSeconds(QueryState) - Method in class org.apache.cassandra.cql3.QueryOptions
 
getNowInSeconds() - Method in class org.apache.cassandra.repair.RepairJob
 
getNowInSeconds() - Method in class org.apache.cassandra.service.QueryState
Generate, cache, and record a nowInSeconds value on the server-side.
getNullable(String) - Method in class org.apache.cassandra.schema.Keyspaces
 
getNullable(String) - Method in class org.apache.cassandra.schema.Tables
Get the table with the specified name
getNullable(ByteBuffer) - Method in class org.apache.cassandra.schema.Types
Get the type with the specified name
getNullable(String) - Method in class org.apache.cassandra.schema.Views
Get the view with the specified name
getNumberOfTables() - Method in class org.apache.cassandra.schema.Schema
 
getNumberOfTables() - Method in class org.apache.cassandra.service.StorageProxy
 
getNumberOfTables() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getNumberOfTables() - Method in class org.apache.cassandra.tools.NodeProbe
 
getNumFiles() - Method in class org.apache.cassandra.db.streaming.CassandraIncomingFile
 
getNumFiles() - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
 
getNumFiles() - Method in interface org.apache.cassandra.streaming.IncomingStream
 
getNumFiles() - Method in interface org.apache.cassandra.streaming.OutgoingStream
 
getNumPendingtasks() - Method in class org.apache.cassandra.utils.memory.MemtablePool
 
getNumRequests() - Method in class org.apache.cassandra.streaming.StreamSession
 
getNumTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNumTransfers() - Method in class org.apache.cassandra.streaming.StreamSession
 
getObfuscator() - Method in class org.apache.cassandra.cql3.QueryEvents
 
getObject(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as the Java type matching its CQL type.
getObject(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as the Java type matching its CQL type.
getObject(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as the Java type matching its CQL type.
getObjectName() - Method in class org.apache.cassandra.auth.AuthCache
 
getObjectName() - Method in class org.apache.cassandra.auth.JMXResource
 
getOffHeapSize() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
getOffsets() - Method in class org.apache.cassandra.index.sasi.disk.Token
 
getOffsets() - Method in class org.apache.cassandra.index.sasi.disk.TokenTree.OnDiskToken
 
getOnDiskFilePointer() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
getOnDiskFilePointer() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
getOnDiskFilePointer() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
getOnDiskFilePointer() - Method in class org.apache.cassandra.io.util.SequentialWriter
Returns the current file pointer of the underlying on-disk file.
getOneMinuteRate() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
 
getOneMinuteRate() - Method in class org.apache.cassandra.metrics.LatencyMetrics.LatencyMetricsTimer
 
getOnlyElement(PartitionIterator, SinglePartitionReadQuery) - Static method in class org.apache.cassandra.db.partitions.PartitionIterators
 
getOnlyElement(UnfilteredPartitionIterator, SinglePartitionReadCommand) - Static method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators
 
getOp() - Method in class org.apache.cassandra.index.sasi.plan.Expression
 
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
 
getOperation() - Method in class org.apache.cassandra.audit.AuditLogEntry
 
getOperation(String) - Method in class org.apache.cassandra.tools.JMXTool.Info
 
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
 
getOperationPresent(String) - Method in class org.apache.cassandra.tools.JMXTool.Info
 
getOperations() - Method in class org.apache.cassandra.db.Memtable
 
getOperations() - Method in class org.apache.cassandra.tools.JMXTool.Info
 
getOperator(FunctionName) - Static method in class org.apache.cassandra.cql3.functions.OperationFcts
Returns the operator associated to the specified function.
getOptions() - Method in class org.apache.cassandra.audit.AuditLogEntry
 
getOptions() - Method in class org.apache.cassandra.auth.RoleOptions
Return a map of all the options which have been set
getOptions(RoleResource) - Static method in class org.apache.cassandra.auth.Roles
Returns the map of custom options for the named role.
getOptions() - Method in class org.apache.cassandra.cql3.statements.schema.IndexAttributes
 
getOrCreate(int) - Static method in class org.apache.cassandra.io.compress.ZstdCompressor
Get a cached instance or return a new one
getOrCreateNextSession(InetAddressAndPort) - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
getOrCreateSession(Channel) - Method in class org.apache.cassandra.streaming.messages.IncomingStreamMessage
 
getOrCreateSession(Channel) - Method in class org.apache.cassandra.streaming.messages.StreamInitMessage
 
getOrCreateSession(Channel) - Method in class org.apache.cassandra.streaming.messages.StreamMessage
Get or create a StreamSession based on this stream message data: not all stream messages support this, so the default implementation just throws an exception.
getOrCreateSessionById(InetAddressAndPort, int) - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
getOrCreateSslContext(EncryptionOptions, boolean, SSLFactory.SocketType) - Static method in class org.apache.cassandra.security.SSLFactory
get a netty SslContext instance
getOrderingIndex(ColumnMetadata) - Method in class org.apache.cassandra.cql3.selection.Selection
Returns the corresponding column index used for post query ordering
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.
getOrInitializeLocalHostId() - Static method in class org.apache.cassandra.db.SystemKeyspace
Read the host ID from the system keyspace, creating (and storing) one if none exists.
getOtcBacklogExpirationInterval() - Method in class org.apache.cassandra.service.StorageProxy
Deprecated.
getOtcBacklogExpirationInterval() - Method in interface org.apache.cassandra.service.StorageProxyMBean
Deprecated.
getOtherOptions() - Method in class org.apache.cassandra.schema.CompressionParams
 
getOutgoingStreamsForRanges(RangesAtEndpoint, Collection<ColumnFamilyStore>, UUID, PreviewKind) - Method in class org.apache.cassandra.streaming.StreamSession
 
getOutput(ProtocolVersion) - Method in class org.apache.cassandra.cql3.selection.Selector
Returns the selector output.
getOutput(ProtocolVersion) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
 
getOutput(ProtocolVersion) - Method in class org.apache.cassandra.cql3.selection.TermSelector
 
getOutputCluster(String, Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getOutputCluster(String[], Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getOutputColumnFamily(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
The OutputCommitter for this format does not write any data to the DFS.
getOutputCompressionChunkLength(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputCompressionClass(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputCql(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getOutputInitialAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputInitialPort(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.cql3.CqlBulkRecordWriter
 
getOutputNativePort(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getOutputPartitioner(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputRow() - Method in interface org.apache.cassandra.cql3.selection.Selection.Selectors
 
getOutputStream(File, File) - Method in interface org.apache.cassandra.cache.AutoSavingCache.IStreamFactory
 
getOutstandingSchemaVersions() - Method in class org.apache.cassandra.service.StorageService
 
getOutstandingSchemaVersions() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
getOutstandingSchemaVersionsWithPort() - Method in class org.apache.cassandra.service.StorageService
 
getOutstandingSchemaVersionsWithPort() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getOverlappingLiveSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getOverrideLoadConfig() - Static method in class org.apache.cassandra.config.Config
 
getOwnership() - Method in class org.apache.cassandra.service.StorageService
 
getOwnership() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
getOwnership() - Method in class org.apache.cassandra.tools.NodeProbe
 
getOwnershipByDc(NodeProbe, boolean, Map<String, String>, Map<InetAddress, Float>) - Static method in class org.apache.cassandra.tools.NodeTool
 
getOwnershipByDcWithPort(NodeProbe, boolean, Map<String, String>, Map<String, Float>) - Static method in class org.apache.cassandra.tools.NodeTool
 
getOwnershipWithPort() - Method in class org.apache.cassandra.service.StorageService
 
getOwnershipWithPort() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getOwnershipWithPort() - Method in class org.apache.cassandra.tools.NodeProbe
 
getPager(PagingState, ProtocolVersion) - Method in interface org.apache.cassandra.db.PartitionRangeReadQuery
 
getPager(PagingState, ProtocolVersion) - Method in interface org.apache.cassandra.db.ReadQuery
Returns a pager for the query.
getPager(PagingState, ProtocolVersion) - Method in interface org.apache.cassandra.db.SinglePartitionReadQuery
 
getPager(PagingState, ProtocolVersion) - Method in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
 
getPageRegion(long, int) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
getPageSize() - Method in class org.apache.cassandra.cql3.QueryOptions
The pageSize for this query.
getPagingState() - Method in class org.apache.cassandra.cql3.QueryOptions
The paging state for this query, or null if not relevant.
getPagingState() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
getParallelism() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
getParameters() - Method in class org.apache.cassandra.tools.JMXTool.Operation
 
getParent() - Method in class org.apache.cassandra.auth.DataResource
 
getParent() - Method in class org.apache.cassandra.auth.FunctionResource
 
getParent() - Method in interface org.apache.cassandra.auth.IResource
Gets next resource in the hierarchy.
getParent() - Method in class org.apache.cassandra.auth.JMXResource
 
getParent() - Method in class org.apache.cassandra.auth.RoleResource
 
getParentCfs(ColumnFamilyStore) - Static method in class org.apache.cassandra.index.SecondaryIndexManager
Returns the parent of the specified ColumnFamilyStore.
getParentCfsName(String) - Static method in class org.apache.cassandra.index.SecondaryIndexManager
Returns the parent name of the specified ColumnFamilyStore.
getParentRepairSession(UUID) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
getParentRepairSession(UUID) - Method in class org.apache.cassandra.service.ActiveRepairService
 
getParentRepairStatus(int) - Method in class org.apache.cassandra.service.StorageService
 
getParentRepairStatus(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Get the status of a given parent repair session.
getPartition(DecoratedKey) - Method in class org.apache.cassandra.db.Memtable
 
getPartition(DecoratedKey) - Method in class org.apache.cassandra.db.virtual.AbstractVirtualTable.AbstractDataSet
 
getPartition(DecoratedKey) - Method in interface org.apache.cassandra.db.virtual.AbstractVirtualTable.DataSet
 
getPartition(DecoratedKey, ReadExecutionController) - Method in class org.apache.cassandra.index.sasi.plan.QueryController
 
getPartitionDeletion() - Method in interface org.apache.cassandra.db.DeletionInfo
 
getPartitionDeletion() - Method in class org.apache.cassandra.db.MutableDeletionInfo
 
getPartitioner() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPartitioner() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getPartitioner() - Method in class org.apache.cassandra.db.DecoratedKey
 
getPartitioner() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
getPartitioner() - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
 
getPartitioner() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
getPartitioner() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner.StringToken
 
getPartitioner() - Method in class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
 
getPartitioner() - Method in interface org.apache.cassandra.dht.RingPosition
 
getPartitioner() - Method in class org.apache.cassandra.dht.Token
 
getPartitioner() - Method in class org.apache.cassandra.dht.Token.KeyBound
 
getPartitioner() - Method in class org.apache.cassandra.io.sstable.SSTable
 
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
getPartitionKeyBindVariableIndexes() - Method in interface org.apache.cassandra.cql3.CQLStatement
Returns an array with the same length as the number of partition key columns for the table corresponding to table.
getPartitionKeyBindVariableIndexes() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
getPartitionKeyBindVariableIndexes() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
getPartitionKeyBindVariableIndexes() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
getPartitionKeyBindVariableIndexes(TableMetadata) - Method in class org.apache.cassandra.cql3.VariableSpecifications
Returns an array with the same length as the number of partition key columns for the table corresponding to table.
getPartitionKeyBounds(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Returns the partition key bounds.
getPartitionKeys(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Returns the partition keys for which the data is requested.
getPartitions(DataRange) - Method in class org.apache.cassandra.db.virtual.AbstractVirtualTable.AbstractDataSet
 
getPartitions(DataRange) - Method in interface org.apache.cassandra.db.virtual.AbstractVirtualTable.DataSet
 
getPartitionSample(int, int, int, List<String>) - Method in class org.apache.cassandra.tools.NodeProbe
 
getPartitionSample(String, String, int, int, int, List<String>) - Method in class org.apache.cassandra.tools.NodeProbe
 
getPartitionUpdate(TableMetadata) - Method in class org.apache.cassandra.db.Mutation
 
getPartitionUpdateBuilder(TableMetadata, DecoratedKey, ConsistencyLevel) - Method in interface org.apache.cassandra.cql3.statements.UpdatesCollector
 
getPartitionUpdates() - Method in class org.apache.cassandra.db.CounterMutation
 
getPartitionUpdates() - Method in interface org.apache.cassandra.db.IMutation
 
getPartitionUpdates() - Method in class org.apache.cassandra.db.Mutation
 
getPartitionUpdates() - Method in class org.apache.cassandra.db.virtual.VirtualMutation
 
getPassword() - Method in class org.apache.cassandra.auth.RoleOptions
Return the string value of the password option
getPath() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getPath() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
 
getPath() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
 
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.FileSegmentInputStream
 
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, InetAddressAndPort) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getPendingAddressRanges(TokenMetadata, Collection<Token>, InetAddressAndPort) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getPendingMemtables() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
getPendingRanges(String) - Method in class org.apache.cassandra.locator.TokenMetadata
a mutable map may be returned but caller should not modify it
getPendingRanges(String, InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getPendingRangesMM(String) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getPendingRangeToEndpointMap(String) - Method in class org.apache.cassandra.service.StorageService
 
getPendingRangeToEndpointMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
getPendingRangeToEndpointWithPortMap(String) - Method in class org.apache.cassandra.service.StorageService
 
getPendingRangeToEndpointWithPortMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getPendingRepair(Set<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
 
getPendingRepair() - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
 
getPendingRepair() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getPendingRepair() - Method in interface org.apache.cassandra.streaming.OutgoingStream
 
getPendingRepair() - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
getPendingRepair() - Method in class org.apache.cassandra.streaming.StreamPlan
 
getPendingRepair() - Method in class org.apache.cassandra.streaming.StreamSession
 
getPendingRepairStats() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getPendingStats(TableId, Collection<Range<Token>>) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
getPendingStats(List<String>, String) - Method in class org.apache.cassandra.service.ActiveRepairService
 
getPendingStats(List<String>, String) - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
 
getPendingTaskCount() - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
getPendingTaskCount() - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
 
getPendingTaskCount() - Method in interface org.apache.cassandra.concurrent.LocalAwareExecutorService
Returns the approximate total of tasks waiting to be executed.
getPendingTaskCount() - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
getPendingTasks() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
 
getPendingTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getPeriodicCommitLogSyncBlock() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPermissions(IResource) - Method in class org.apache.cassandra.auth.AuthenticatedUser
 
getPermissions - Variable in class org.apache.cassandra.auth.jmx.AuthorizationProxy
 
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
 
getPerPartitionLimit(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
Returns the per partition limit specified by the user.
getPhiConvictThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPhiConvictThreshold() - Method in class org.apache.cassandra.gms.FailureDetector
 
getPhiConvictThreshold() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
getPhiValues() - Method in class org.apache.cassandra.gms.FailureDetector
 
getPhiValues() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
Deprecated.
getPhiValuesWithPort() - Method in class org.apache.cassandra.gms.FailureDetector
 
getPhiValuesWithPort() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
getPid() - Method in class org.apache.cassandra.tools.NodeProbe
 
getPid() - Method in class org.apache.cassandra.utils.SigarLibrary
 
getPingTimeout(TimeUnit) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPointer(OnDiskIndex.PointerTerm, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.PointerLevel
 
getPos() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
getPosition() - Method in class org.apache.cassandra.db.CassandraWriteContext
 
getPosition() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
Returns the exact position in the uncompressed view of the file.
getPosition() - Method in class org.apache.cassandra.index.sasi.sa.Term
 
getPosition(PartitionPosition, SSTableReader.Operator, boolean, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
 
getPosition(PartitionPosition, SSTableReader.Operator) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Retrieves the position while updating the key cache and the stats.
getPosition(PartitionPosition, SSTableReader.Operator, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Retrieves the position while updating the key cache and the stats.
getPosition(PartitionPosition, SSTableReader.Operator, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getPosition(PartitionPosition, SSTableReader.Operator, boolean, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getPosition(int) - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
getPosition() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
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.format.SSTableReader
Determine the minimal set of sections that can be extracted from this SSTable to cover the given ranges.
getPostIndexQueryFilter(RowFilter) - Method in interface org.apache.cassandra.index.Index
Transform an initial RowFilter into the filter that will still need to applied to a set of Rows after the index has performed it's initial scan.
getPostIndexQueryFilter(RowFilter) - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
getPostIndexQueryFilter(RowFilter) - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
getPredecessor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getPreferedTypeFor(String) - Method in enum org.apache.cassandra.cql3.Constants.Type
Returns the exact type for the specified text
getPreferredIP(InetAddressAndPort) - Static method in class org.apache.cassandra.db.SystemKeyspace
Get preferred IP for given endpoint if it is known.
getPrefetchedRow(DecoratedKey, Clustering<?>) - Method in class org.apache.cassandra.cql3.UpdateParameters
Returns the prefetched row with the already performed modifications.
getPreJoinTask(boolean) - Method in interface org.apache.cassandra.index.Index
Return a task to be executed before the node enters NORMAL state and finally joins the ring.
getPrepared(MD5Digest) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
 
getPrepared(MD5Digest) - Method in interface org.apache.cassandra.cql3.QueryHandler
 
getPrepared(MD5Digest) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
getPreparedStatementsCacheSizeMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPreRelease() - Method in class org.apache.cassandra.utils.CassandraVersion
 
getPreviewKind() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
getPreviewKind() - Method in class org.apache.cassandra.streaming.StreamSession
 
getPreviousReleaseVersionString() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getPrimaryRangeFor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
Deprecated.
getPrimaryRangeForEndpointWithinDC(String, InetAddressAndPort) - 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, InetAddressAndPort) - Method in class org.apache.cassandra.service.StorageService
Get the "primary ranges" for the specified keyspace and endpoint.
getPrimaryRangesWithinDC(String) - Method in class org.apache.cassandra.service.StorageService
 
getPrimaryRole() - Method in class org.apache.cassandra.auth.AuthenticatedUser
 
getPriority() - Method in class org.apache.cassandra.streaming.messages.StreamMessage
 
getProcessID() - Static method in class org.apache.cassandra.utils.NativeLibrary
 
getProgress() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
getProgress() - Method in class org.apache.cassandra.hadoop.ReporterWrapper
 
getProgressCount() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
 
getProgressPercentage() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
 
getProtectedConstructor(Class<T>, Class<?>...) - Static method in class org.apache.cassandra.utils.Hex
Used to get access to protected/private constructor of the specified class
getProtectedField(Class, String) - Static method in class org.apache.cassandra.utils.FBUtilities
Used to get access to protected/private field of the specified class
getProtocolVersion() - Method in class org.apache.cassandra.cql3.QueryOptions
The protocol version for the query.
getProtocolVersion() - Method in enum org.apache.cassandra.transport.DataType
 
getProxyMetric(String) - Method in class org.apache.cassandra.tools.NodeProbe
Retrieve Proxy metrics
getPurgeEvaluator(DecoratedKey) - Method in class org.apache.cassandra.db.AbstractCompactionController
 
getPurgeEvaluator(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.CompactionController
 
getPurgeEvaluator(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplitController
 
getPurgeEvaluator() - Method in class org.apache.cassandra.db.partitions.PurgeFunction
 
getQuery(QueryOptions, int) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
getQuery(QueryOptions, ColumnFilter, int, int, int, int) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
getQueryOrIdList() - Method in class org.apache.cassandra.cql3.BatchQueryOptions
 
getRack() - Static method in class org.apache.cassandra.db.SystemKeyspace
Gets the stored rack for the local node, or null if none have been set yet.
getRack(InetAddressAndPort) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
Return the rack for which an endpoint resides in
getRack(InetAddressAndPort) - Method in class org.apache.cassandra.locator.AlibabaCloudSnitch
 
getRack(InetAddressAndPort) - Method in class org.apache.cassandra.locator.CloudstackSnitch
 
getRack(InetAddressAndPort) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getRack(InetAddressAndPort) - Method in class org.apache.cassandra.locator.Ec2Snitch
 
getRack(String) - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
 
getRack() - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
 
getRack(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
Provides the Rack name depending on the respective snitch used, given the host name/ip
getRack() - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
Provides the Rack name depending on the respective snitch used for this node
getRack(InetAddressAndPort) - Method in class org.apache.cassandra.locator.GoogleCloudSnitch
 
getRack(InetAddressAndPort) - Method in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
Return the rack for which an endpoint resides in
getRack(InetAddressAndPort) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
returns a String representing the rack the given endpoint belongs to
getRack(InetAddressAndPort) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
Return the rack for which an endpoint resides in
getRack(InetAddressAndPort) - Method in class org.apache.cassandra.locator.RackInferringSnitch
 
getRack(InetAddressAndPort) - Method in class org.apache.cassandra.locator.SimpleSnitch
 
getRack() - Method in class org.apache.cassandra.tools.NodeProbe
 
getRandomTimeUUIDFromMicros(long) - Static method in class org.apache.cassandra.utils.UUIDGen
Similar to UUIDGen.getTimeUUIDFromMicros(long), but randomize (using SecureRandom) the clock and sequence.
getRandomToken() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
getRandomToken(Random) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
getRandomToken() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getRandomToken(Random) - Method in interface org.apache.cassandra.dht.IPartitioner
 
getRandomToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
getRandomToken(Random) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
getRandomToken() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
 
getRandomToken(Random) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
 
getRandomToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getRandomToken(Random) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getRandomToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getRandomToken(Random) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getRandomTokens(TokenMetadata, int) - Static method in class org.apache.cassandra.dht.BootStrapper
 
getRange(int, int) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataBlock
 
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.
getRangeFetchMap() - Method in class org.apache.cassandra.dht.RangeFetchMapCalculator
 
getRangePartitionCounts() - Method in class org.apache.cassandra.db.repair.CassandraValidationIterator
 
getRangePartitionCounts() - Method in class org.apache.cassandra.repair.ValidationPartitionIterator
 
getRangeRpcTimeout(TimeUnit) - 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
 
getRangeRpcTimeout() - Method in class org.apache.cassandra.service.StorageService
 
getRangeRpcTimeout() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getRanges() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
getRanges() - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
getRangeSlice(PartitionRangeReadCommand, ConsistencyLevel, long) - 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
 
getRangeToEndpointMap(String, boolean) - 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
Deprecated.
getRangeToEndpointWithPortMap(String) - Method in class org.apache.cassandra.service.StorageService
 
getRangeToEndpointWithPortMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getRangeTombstoneListGrowthFactor() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRangeTombstoneResizeListGrowthFactor() - Method in class org.apache.cassandra.service.StorageService
 
getRangeTombstoneResizeListGrowthFactor() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the resize factor to use when growing/resizing a RangeTombstoneList
getRangeToNativeaddressWithPortMap(String) - Method in class org.apache.cassandra.service.StorageService
 
getRangeToNativeaddressWithPortMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getRangeToRpcaddressMap(String) - Method in class org.apache.cassandra.service.StorageService
 
getRangeToRpcaddressMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
getRateLimiter() - Method in class org.apache.cassandra.db.compaction.CompactionManager
Gets compaction rate limiter.
getRateLimiter(InetAddressAndPort) - Static method in class org.apache.cassandra.streaming.StreamManager
Gets streaming rate limiter.
getRateUnit() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
 
getRaw(InetAddressAndPort) - Method in class org.apache.cassandra.net.EndpointMessagingVersions
Returns the messaging-version exactly as announced by the given endpoint.
getRawCachedPartition(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRawConfig() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRawDiretoriesSize() - Method in class org.apache.cassandra.db.Directories
 
getRawKeyspace() - Method in class org.apache.cassandra.service.ClientState
 
getRawTermForColumn(ColumnMetadata, boolean) - Method in class org.apache.cassandra.cql3.Json.Prepared
 
getRawText() - Method in class org.apache.cassandra.cql3.Constants.Literal
 
getRawValues() - Method in class org.apache.cassandra.db.AbstractOnHeapClusteringPrefix
 
getRawValues() - Method in interface org.apache.cassandra.db.ClusteringPrefix
The values of this prefix as an array.
getRawValues() - Method in class org.apache.cassandra.db.NativeClustering
 
getReadConsistencyLevel(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getReaderFactory() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
 
getReaderFactory() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
 
getReadExecutor(SinglePartitionReadCommand, ConsistencyLevel, long) - Static method in class org.apache.cassandra.service.reads.AbstractReadExecutor
 
getReadMeter() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getReadRepair() - Method in class org.apache.cassandra.service.reads.AbstractReadExecutor
 
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
 
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(TimeUnit) - 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
 
getReadRpcTimeout() - Method in class org.apache.cassandra.service.StorageService
 
getReadRpcTimeout() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getReceiver() - Method in class org.apache.cassandra.streaming.StreamReceiveTask
 
getReceivingFiles() - Method in class org.apache.cassandra.streaming.SessionInfo
 
getReceivingStream(UUID) - Method in class org.apache.cassandra.streaming.StreamManager
 
getRecentBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getRecentBloomFilterTrueNegativeCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getRecentBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getRecentFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getRecentTrueNegativeCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getRecentTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getRecentValues() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
getRecentValues() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
getReclaiming() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator.SubAllocator
 
getReclaiming() - Method in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
 
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.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.
getRecoveryTaskSupport() - Method in interface org.apache.cassandra.index.Index
Same as getBuildTaskSupport but can be overloaded with a specific 'recover' logic different than the index building one
getReduced() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
 
getRef() - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
 
getReferencedUserTypes() - Method in class org.apache.cassandra.schema.TableMetadata
Returns the names of all the user types referenced by this table.
getRegularColumns() - Method in class org.apache.cassandra.db.SerializationHeader.Component
 
getRegularOperations() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
getRelativePath(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
Convert absolute path into a path relative to the base path
getReleaseVersion(InetAddressAndPort) - Static method in class org.apache.cassandra.db.SystemKeyspace
Get release version for given endpoint.
getReleaseVersion() - Method in class org.apache.cassandra.gms.EndpointState
 
getReleaseVersion(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
 
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
 
getReleaseVersionMajor() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getReleaseVersionString() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getReleaseVersionsWithPort() - Method in class org.apache.cassandra.gms.Gossiper
 
getReleaseVersionsWithPort() - Method in interface org.apache.cassandra.gms.GossiperMBean
Returns each node's database release version
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
 
getRemovalStatus() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
getRemovalStatus(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
 
getRemovalStatusWithPort() - Method in class org.apache.cassandra.service.StorageService
 
getRemovalStatusWithPort() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getRepairCommandPoolFullStrategy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRepairCommandPoolSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRepairedAt() - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
 
getRepairedAt() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getRepairedAt() - Method in interface org.apache.cassandra.streaming.OutgoingStream
 
getRepairedDataDigest() - Method in class org.apache.cassandra.db.ReadExecutionController
 
getRepairedDataInfo() - Method in class org.apache.cassandra.db.ReadExecutionController
 
getRepairedDataTrackingEnabledForPartitionReads() - Method in class org.apache.cassandra.service.StorageProxy
 
getRepairedDataTrackingEnabledForPartitionReads() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRepairedDataTrackingEnabledForRangeReads() - Method in class org.apache.cassandra.service.StorageProxy
 
getRepairedDataTrackingEnabledForRangeReads() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRepairedDataTrackingForPartitionReadsEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRepairedDataTrackingForRangeReadsEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRepairedDataVerifier(ReadCommand) - Method in class org.apache.cassandra.service.reads.DataResolver
 
getRepairedStats(TableId, Collection<Range<Token>>) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
getRepairedStats(Collection<Range<Token>>) - Method in class org.apache.cassandra.repair.consistent.RepairedState
 
getRepairManager() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRepairManager() - Method in class org.apache.cassandra.db.Keyspace
 
getRepairPendingCompactionRejectThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRepairPendingCompactionRejectThreshold() - Method in class org.apache.cassandra.service.ActiveRepairService
 
getRepairPendingCompactionRejectThreshold() - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
 
getRepairServiceProxy() - Method in class org.apache.cassandra.tools.NodeProbe
 
getRepairSessionMaxTreeDepth() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRepairSessionMaxTreeDepth() - Method in class org.apache.cassandra.service.StorageService
 
getRepairSessionMaxTreeDepth() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getRepairSessionSpaceInMegabytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRepairSessionSpaceInMegabytes() - Method in class org.apache.cassandra.service.ActiveRepairService
 
getRepairSessionSpaceInMegabytes() - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
 
getRepairStats(List<String>, String) - Method in class org.apache.cassandra.service.ActiveRepairService
 
getRepairStats(List<String>, String) - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
 
getReplaceAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getReplacementNode(InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getReplaceNode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getReplaceTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getReplacingNode(InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getReplicas() - Method in class org.apache.cassandra.dht.tokenallocator.NoReplicationTokenAllocator
 
getReplicas() - Method in class org.apache.cassandra.dht.tokenallocator.TokenAllocatorBase
 
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.SimpleStrategy
 
getReplicationStrategy() - Method in class org.apache.cassandra.db.Keyspace
 
getReportingUnconfirmedRepairedDataMismatchesEnabled() - Method in class org.apache.cassandra.service.StorageProxy
 
getReportingUnconfirmedRepairedDataMismatchesEnabled() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
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
 
getResponseCount() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
 
getRestoreCommand() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getRestoreCommand() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
Command to execute to make an archived commitlog live again
getRestoreDirectories() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getRestoreDirectories() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
Directory to scan the recovery files in
getRestorePointInTime() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getRestorePointInTime() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
Restore mutations created up to and including this timestamp in GMT Format: yyyy:MM:dd HH:mm:ss (2012:04:31 20:43:12) Recovery will continue through the segment when the first client-supplied timestamp greater than this time is encountered, but only mutations less than or equal to this timestamp will be applied.
getRestorePrecision() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getRestorePrecision() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
get precision of the timestamp used in the restore (MILLISECONDS, MICROSECONDS, ...) to determine if passed the restore point in time.
getRestrictions() - Method in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
 
getRestrictions(ColumnMetadata) - Method in interface org.apache.cassandra.cql3.restrictions.Restrictions
Returns the restrictions applied to the specified column.
getRestrictions(ColumnMetadata) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
getRestrictions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
getRestrictions() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
May be used by custom QueryHandler implementations
getResult() - Method in class org.apache.cassandra.service.reads.AbstractReadExecutor
 
getResultMetadata() - Method in class org.apache.cassandra.cql3.selection.Selection
 
getResultMetadata() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
getResultMetadataId() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
getResultSetIndex(ColumnMetadata) - Method in class org.apache.cassandra.cql3.selection.Selection
Returns the index of the specified column within the resultset
getReturnType() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Returns the type of the values returned by the selector instances created by this factory.
getReturnType() - Method in class org.apache.cassandra.cql3.selection.SimpleSelector.SimpleSelectorFactory
 
getReturnType() - Method in class org.apache.cassandra.tools.JMXTool.Operation
 
getRingVersion() - Method in class org.apache.cassandra.locator.TokenMetadata
 
getRoleDetails() - Method in class org.apache.cassandra.auth.AuthenticatedUser
Get the detailed info on roles granted to the user via IRoleManager
getRoleDetails(RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
getRoleDetails(RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
Used to retrieve detailed role info on the full set of roles granted to a grantee.
getRoleDetails(RoleResource) - Static method in class org.apache.cassandra.auth.Roles
Get detailed info on all the roles granted to the role identified by the supplied RoleResource.
getRoleManager() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRoleName() - Method in class org.apache.cassandra.auth.RoleResource
 
getRoles() - Method in class org.apache.cassandra.auth.AuthenticatedUser
Get the roles that have been granted to the user via the IRoleManager
getRoles(RoleResource, boolean) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
getRoles(RoleResource, boolean) - Method in interface org.apache.cassandra.auth.IRoleManager
Called during execution of a LIST ROLES query.
getRoles(RoleResource) - Static method in class org.apache.cassandra.auth.Roles
Identify all roles granted to the supplied Role, including both directly granted and inherited roles.
getRolesCacheMaxEntries() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRolesUpdateInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRolesValidity() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRow(Clustering<?>) - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
getRow(Clustering<?>) - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
 
getRow(Clustering<?>) - Method in interface org.apache.cassandra.db.partitions.Partition
Returns the row corresponding to the provided clustering, or null if there is not such row.
getRowCacheClassName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRowCacheKeysToSave() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRowCacheKeysToSave() - Method in class org.apache.cassandra.service.CacheService
 
getRowCacheKeysToSave() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getRowCacheSavePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRowCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.service.CacheService
 
getRowCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
getRowCacheSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRowFilter(IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
getRowFilter(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
May be used by custom QueryHandler implementations
getRowMergeListener(DecoratedKey, List<UnfilteredRowIterator>) - Method in interface org.apache.cassandra.db.partitions.UnfilteredPartitionIterators.MergeListener
 
getRowMergeListener(DecoratedKey, List<UnfilteredRowIterator>) - Method in class org.apache.cassandra.service.reads.repair.PartitionIteratorMergeListener
 
getRpcAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
This is the address used to bind for the native protocol to communicate with clients.
getRpcKeepAlive() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcTimeout(TimeUnit) - 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
 
getRpcTimeout() - Method in class org.apache.cassandra.service.StorageService
 
getRpcTimeout() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getSamplingLevel() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
getSamplingPattern(int) - Static method in class org.apache.cassandra.io.sstable.Downsampling
Gets a list L of starting indices for downsampling rounds: the first round should start with the offset given by L[0], the second by the offset in L[1], etc.
getSaslNegotiator(QueryState) - Method in class org.apache.cassandra.transport.ServerConnection
 
getSavedCachesLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSavedCachesLocation() - Method in class org.apache.cassandra.service.StorageService
 
getSavedCachesLocation() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Get location of the saved caches dir
getSavedTokens() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
getScanner(ColumnFilter, DataRange, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
 
getScanner(Iterator<AbstractBounds<PartitionPosition>>) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
Direct I/O SSTableScanner over an iterator of bounds.
getScanner() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
Direct I/O SSTableScanner over the full sstable.
getScanner(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
Direct I/O SSTableScanner over a defined collection of ranges of tokens.
getScanner(SSTableReader) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
getScanner(SSTableReader, ColumnFilter, DataRange, SSTableReadsListener) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
getScanner(SSTableReader, Collection<Range<Token>>) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
getScanner(SSTableReader, Iterator<AbstractBounds<PartitionPosition>>) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
getScanner(Range<Token>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Direct I/O SSTableScanner over a defined range of tokens.
getScanner() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Direct I/O SSTableScanner over the entirety of the sstable..
getScanner(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Direct I/O SSTableScanner over a defined collection of ranges of tokens.
getScanner(Iterator<AbstractBounds<PartitionPosition>>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Direct I/O SSTableScanner over an iterator of bounds.
getScanner(ColumnFilter, DataRange, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getScanners(Collection<SSTableReader>, Range<Token>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
getScanners(Collection<SSTableReader>, Collection<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(AbstractStrategyHolder.GroupedSSTableContainer, Collection<Range<Token>>) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
 
getScanners(AbstractStrategyHolder.GroupedSSTableContainer, Collection<Range<Token>>) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
getScanners(Collection<SSTableReader>, Collection<Range<Token>>) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
getScanners(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
getScanners(Collection<SSTableReader>, Collection<Range<Token>>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
getScanners(AbstractStrategyHolder.GroupedSSTableContainer, Collection<Range<Token>>) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
getSchemaVersion() - Method in class org.apache.cassandra.gms.EndpointState
 
getSchemaVersion(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
 
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
Deprecated.
getSchemaVersionsWithPort() - Method in class org.apache.cassandra.service.StorageProxy
 
getSchemaVersionsWithPort() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getScope() - Method in class org.apache.cassandra.audit.AuditLogEntry
 
getScope() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Returns the scope of the Metric.
getScores() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getScores() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
Deprecated.
getScoresWithPort() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getScoresWithPort() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
getScrubInfo() - Method in class org.apache.cassandra.db.compaction.Scrubber
 
getSecretKey(String) - Method in class org.apache.cassandra.security.JKSKeyProvider
 
getSecretKey(String) - Method in interface org.apache.cassandra.security.KeyProvider
 
getSeedProvider() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSeeds() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSeeds() - Method in class org.apache.cassandra.gms.Gossiper
JMX endpoint for getting the list of seeds from the node
getSeeds() - Method in interface org.apache.cassandra.gms.GossiperMBean
 
getSeeds() - Method in interface org.apache.cassandra.locator.SeedProvider
 
getSeeds() - Method in class org.apache.cassandra.locator.SimpleSeedProvider
 
getSeeds() - Method in class org.apache.cassandra.tools.NodeProbe
 
GetSeeds - Class in org.apache.cassandra.tools.nodetool
 
GetSeeds() - Constructor for class org.apache.cassandra.tools.nodetool.GetSeeds
 
getSeekPosition() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
Return a seekable representation of the current position.
getSeekPosition() - Method in class org.apache.cassandra.hints.CompressedChecksummedDataInput
 
getSeekPosition() - Method in class org.apache.cassandra.hints.EncryptedChecksummedDataInput
 
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.
getSerializationVal() - Method in enum org.apache.cassandra.streaming.PreviewKind
 
getSerializedCachePath(CacheService.CacheType, String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSerializedValue(ByteBuffer, ByteBuffer, AbstractType<?>) - Method in class org.apache.cassandra.serializers.CollectionSerializer
Extract an element from a serialized collection.
getSerializedValue(ByteBuffer, ByteBuffer, AbstractType<?>) - Method in class org.apache.cassandra.serializers.ListSerializer
 
getSerializedValue(ByteBuffer, ByteBuffer, AbstractType<?>) - Method in class org.apache.cassandra.serializers.MapSerializer
 
getSerializedValue(ByteBuffer, ByteBuffer, AbstractType<?>) - Method in class org.apache.cassandra.serializers.SetSerializer
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.AsciiType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.BooleanType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.BytesType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.ByteType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.CollectionType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.DateType
Deprecated.
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.DecimalType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.DoubleType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.DurationType
 
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.LongType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.MapType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.ReversedType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.SetType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.ShortType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.TimestampType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.TimeType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.TupleType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.UserType
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
getSerializer() - Method in class org.apache.cassandra.db.marshal.UUIDType
 
getSession(UUID) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSessions
 
getSession(UUID) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
getSession(InetAddressAndPort, int) - Method in class org.apache.cassandra.streaming.StreamResultFuture
 
getSessionById(InetAddressAndPort, int) - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
getSessionId() - Method in class org.apache.cassandra.tracing.Tracing
 
getSessionInfo() - Method in class org.apache.cassandra.streaming.StreamSession
 
getSessions(boolean, String) - Method in class org.apache.cassandra.service.ActiveRepairService
 
getSessions(boolean, String) - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
 
getSet(String, Class<T>) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a set.
getSet(String, TypeToken<T>) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a set.
getSet(int, Class<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a set.
getSet(int, TypeToken<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a set.
getSet(String, Class<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a set.
getSet(String, TypeToken<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a set.
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
 
getShort(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a short.
getShort(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a short.
getShort(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a short.
getShort(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getShort(byte[], int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
getShort(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
getShort(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
returns a short from offset
getShort() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
getShort(long) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
getShort(byte[], int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
getShort(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getShortByByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
getShortLength(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
getSimple(String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
getSimple(int) - Method in class org.apache.cassandra.db.Columns
Returns the ith simple column of this object.
getSimpleStates() - Method in class org.apache.cassandra.gms.FailureDetector
 
getSimpleStates() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
Deprecated.
getSimpleStatesWithPort() - Method in class org.apache.cassandra.gms.FailureDetector
 
getSimpleStatesWithPort() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
getSize() - Method in class org.apache.cassandra.db.streaming.CassandraIncomingFile
 
getSize() - Method in interface org.apache.cassandra.streaming.IncomingStream
 
getSizeOfAllEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
 
getSizeOfLeavingEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
 
getSizeOfMovingEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
 
getSliceFromSerialized(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ListType
 
getSliceFromSerialized(ByteBuffer, ByteBuffer, ByteBuffer, AbstractType<?>, boolean) - Method in class org.apache.cassandra.serializers.CollectionSerializer
Returns the slice of a collection directly from its serialized value.
getSliceFromSerialized(ByteBuffer, ByteBuffer, ByteBuffer, AbstractType<?>, boolean) - Method in class org.apache.cassandra.serializers.ListSerializer
 
getSliceFromSerialized(ByteBuffer, ByteBuffer, ByteBuffer, AbstractType<?>, boolean) - Method in class org.apache.cassandra.serializers.MapSerializer
 
getSliceFromSerialized(ByteBuffer, ByteBuffer, ByteBuffer, AbstractType<?>, boolean) - Method in class org.apache.cassandra.serializers.SetSerializer
 
getSlices(TableMetadata) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
 
getSlices(TableMetadata) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
 
getSlices(TableMetadata) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
 
getSlowQueryTimeout(TimeUnit) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSmallMessageCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Deprecated.
getSmallMessageCompletedTasks() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getSmallMessageCompletedTasksWithPort() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
 
getSmallMessageCompletedTasksWithPort() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getSmallMessageDroppedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Deprecated.
getSmallMessageDroppedTasks() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getSmallMessageDroppedTasksWithPort() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
 
getSmallMessageDroppedTasksWithPort() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getSmallMessagePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Deprecated.
getSmallMessagePendingTasks() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getSmallMessagePendingTasksWithPort() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
 
getSmallMessagePendingTasksWithPort() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getSnapshot() - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
Returns a snapshot of the decaying values in this reservoir.
getSnapshot() - Method in class org.apache.cassandra.metrics.LatencyMetrics.LatencyMetricsTimer
 
getSnapshotCreationTime(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getSnapshotDetails() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getSnapshotDetails() - Method in class org.apache.cassandra.db.Directories
 
getSnapshotDetails() - Method in class org.apache.cassandra.service.StorageService
 
getSnapshotDetails() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Get the details of all the snapshot
getSnapshotDetails() - Method in class org.apache.cassandra.tools.NodeProbe
 
getSnapshotDirectory(Descriptor, String) - Static method in class org.apache.cassandra.db.Directories
 
getSnapshotDirectory(File, String) - Static method in class org.apache.cassandra.db.Directories
Returns directory to write snapshot.
getSnapshotLinksPerSecond() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSnapshotLinksPerSecond() - Method in class org.apache.cassandra.service.StorageService
 
getSnapshotLinksPerSecond() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Get the current hardlink-per-second throttle for snapshots A setting of zero indicates no throttling.
getSnapshotLinksPerSecond() - Method in class org.apache.cassandra.tools.NodeProbe
 
getSnapshotManifestFile(String) - Method in class org.apache.cassandra.db.Directories
 
getSnapshotName(String) - Static method in class org.apache.cassandra.utils.DiagnosticSnapshotService
 
getSnapshotOnDuplicateRowDetectionEnabled() - Method in class org.apache.cassandra.service.StorageProxy
 
getSnapshotOnDuplicateRowDetectionEnabled() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getSnapshotOnRepairedDataMismatchEnabled() - Method in class org.apache.cassandra.service.StorageProxy
 
getSnapshotOnRepairedDataMismatchEnabled() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getSnapshotRateLimiter() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSnapshotSchemaFile(String) - Method in class org.apache.cassandra.db.Directories
 
getSnapshotSSTableReaders(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
GetSnapshotThrottle - Class in org.apache.cassandra.tools.nodetool
 
GetSnapshotThrottle() - Constructor for class org.apache.cassandra.tools.nodetool.GetSnapshotThrottle
 
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
getSortedFilteredTables() - Method in class org.apache.cassandra.tools.nodetool.stats.TableStatsHolder
Sort and filter this TableStatHolder's tables as specified by its sortKey and top attributes.
getSource() - Method in class org.apache.cassandra.audit.AuditEvent
 
getSource() - Method in class org.apache.cassandra.audit.AuditLogEntry
 
getSource() - Method in class org.apache.cassandra.transport.Message
 
getSourcePosition() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
Returns the position in the source file, which is different for getPosition() for compressed/encrypted files and may be imprecise.
getSourcePosition() - Method in class org.apache.cassandra.hints.CompressedChecksummedDataInput
 
getSourcePosition() - Method in class org.apache.cassandra.hints.EncryptedChecksummedDataInput
 
getSparseTokens() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataTerm
 
getSplits(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlInputFormat
 
getSplits(JobConf, int) - Method in class org.apache.cassandra.hadoop.cql3.CqlInputFormat
 
getSplits(String, String, Range<Token>, int) - Method in class org.apache.cassandra.service.StorageService
 
getSplitValues() - Method in class org.apache.cassandra.cql3.Tuples.InValue
 
getSpProxy() - Method in class org.apache.cassandra.tools.NodeProbe
 
getSSLOptions(Configuration) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
getSSLStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSSTable() - Method in class org.apache.cassandra.db.streaming.CassandraIncomingFile
 
getSSTable() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
 
getSstableCompressor() - Method in class org.apache.cassandra.schema.CompressionParams
Returns the SSTable compressor.
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.CompactionStrategyManager
 
getSSTableFormat() - Method in class org.apache.cassandra.io.sstable.format.Version
 
getSSTableLevel() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getSSTableMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getSSTablePreemptiveOpenIntervalInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSSTablePreemptiveOpenIntervalInMB() - Method in class org.apache.cassandra.service.StorageService
 
getSSTablePreemptiveOpenIntervalInMB() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
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(SSTableSet) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getSSTables() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
Returns the sstables managed by this strategy instance
getSSTables() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getSSTables() - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
Deprecated.
 
getSSTables() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
getSSTables() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
getSSTables() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
getSSTables() - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
 
getSSTables(String, String, String, boolean) - Method in class org.apache.cassandra.tools.NodeProbe
 
GetSSTables - Class in org.apache.cassandra.tools.nodetool
 
GetSSTables() - Constructor for class org.apache.cassandra.tools.nodetool.GetSSTables
 
getSSTablesForKey(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getSSTablesForKey(String, boolean) - 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
getSSTablesForKey(String, boolean) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Returns a list of filenames that contain the given key on this node
getSStablesPerLevelSnapshot() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
getSSTableTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getStartedAt() - Method in class org.apache.cassandra.repair.consistent.LocalSession
 
getStartPoints(int, int) - Static method in class org.apache.cassandra.io.sstable.Downsampling
 
getStartToken() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
getState() - Method in class org.apache.cassandra.audit.AuditLogEntry
 
getState() - Method in class org.apache.cassandra.repair.consistent.ConsistentSession
 
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, 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(String, String, long) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
getStatements() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
getStaticColumns() - Method in class org.apache.cassandra.db.SerializationHeader.Component
 
getStaticOperations() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
getStatus() - Method in class org.apache.cassandra.gms.EndpointState
 
getStatusThresholdInMs() - Method in class org.apache.cassandra.service.GCInspector
 
getStatusThresholdInMs() - Method in interface org.apache.cassandra.service.GCInspectorMXBean
 
getStdDev() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
getStdDev() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
getStemmer(Locale) - Static method in class org.apache.cassandra.index.sasi.analyzer.filter.StemmerFactory
 
getStopWordsForLanguage(Locale) - Static method in class org.apache.cassandra.index.sasi.analyzer.filter.StopWordFactory
 
getStorageMetric(String) - Method in class org.apache.cassandra.tools.NodeProbe
Retrieve Proxy metrics
getStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getStorageService() - Method in class org.apache.cassandra.tools.NodeProbe
 
getStrategies() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
getStrategyFolders(AbstractCompactionStrategy) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
getStrategyFor(SSTableReader) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
 
getStrategyFor(SSTableReader) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
getStrategyFor(SSTableReader) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
getStrategyIndex(AbstractCompactionStrategy) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
Return the directory index the given compaction strategy belongs to, or -1 if it's not held by this holder
getStrategyIndex(AbstractCompactionStrategy) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
getStrategyIndex(AbstractCompactionStrategy) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
getStreamId() - Method in class org.apache.cassandra.transport.Message
 
getStreamId() - Method in exception org.apache.cassandra.transport.messages.ErrorMessage.WrappedException
 
getStreamingConnectionsPerHost() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getStreamingKeepAlivePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getStreamManager() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getStreamOperation() - Method in class org.apache.cassandra.streaming.StreamSession
 
getStreamStatus() - Method in class org.apache.cassandra.tools.NodeProbe
 
getStreamThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
 
GetStreamThroughput - Class in org.apache.cassandra.tools.nodetool
 
GetStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.GetStreamThroughput
 
getStreamThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
 
getStreamThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getStreamThroughputOutboundMegabitsPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getString() - Method in enum org.apache.cassandra.config.CassandraRelevantEnv
 
getString() - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
Gets the value of the indicated system property.
getString(String) - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
Gets the value of a system property as a String.
getString(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a string.
getString(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a string.
getString(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a string.
getString(String, String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
getString(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getString(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
getString(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.AbstractType
get a string representation of the bytes used for various identifier (NOT just for log messages)
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
getString(Collection<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
getString(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.CollectionType
 
getString(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
getString(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.EmptyType
 
getString(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.FrozenType
 
getString(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
 
getString(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
getString(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.TupleType
 
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
 
getSuffix(int) - Method in class org.apache.cassandra.index.sasi.sa.ByteTerm
 
getSuffix(int) - Method in class org.apache.cassandra.index.sasi.sa.CharTerm
 
getSuffix(int) - Method in class org.apache.cassandra.index.sasi.sa.Term
 
getSummary() - Method in interface org.apache.cassandra.db.compaction.CompactionLogger.StrategySummary
 
getSummary() - Method in class org.apache.cassandra.streaming.StreamTask
 
getSuperBlock(int) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataLevel
 
getSuperuser() - Method in class org.apache.cassandra.auth.RoleOptions
Return a boolean value of the superuser option
getSupportedLoadTypeOnFailure(boolean) - Method in interface org.apache.cassandra.index.Index
Returns the type of operations supported by the index in case its building has failed and it's needing recovery.
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
getSystemReplica(InetAddressAndPort) - Static method in class org.apache.cassandra.locator.SystemReplicas
There are a few places where a system function borrows write path functionality, but doesn't otherwise fit into normal replication strategies (ie: hints and batchlog).
getSystemReplicas(Collection<InetAddressAndPort>) - Static method in class org.apache.cassandra.locator.SystemReplicas
 
getTable() - Method in class org.apache.cassandra.auth.DataResource
 
getTable() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
GettableByIndexData - Interface in org.apache.cassandra.cql3.functions.types
Collection of (typed) CQL values that can be retrieved by index (starting at zero).
GettableByNameData - Interface in org.apache.cassandra.cql3.functions.types
Collection of (typed) CQL values that can be retrieved by name.
getTableCountWarnThreshold() - Method in class org.apache.cassandra.service.StorageService
 
getTableCountWarnThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
GettableData - Interface in org.apache.cassandra.cql3.functions.types
Collection of (typed) CQL values that can be retrieved either by index (starting at zero) or by name.
getTableForAlias(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
getTableId() - Method in class org.apache.cassandra.db.streaming.CassandraIncomingFile
 
getTableId() - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
 
getTableId() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableZeroCopyWriter
 
getTableId() - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
 
getTableId() - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
 
getTableId() - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
 
getTableId() - Method in interface org.apache.cassandra.streaming.IncomingStream
 
getTableId() - Method in interface org.apache.cassandra.streaming.OutgoingStream
 
getTableIds() - Method in class org.apache.cassandra.db.CounterMutation
 
getTableIds() - Method in interface org.apache.cassandra.db.IMutation
 
getTableIds() - Method in class org.apache.cassandra.db.Mutation
 
getTableIds() - Method in class org.apache.cassandra.db.virtual.VirtualMutation
 
getTableIds() - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
getTableInsertStatement(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
getTableMBeanName(String, String, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTableMetadata() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getTableMetadata(String) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
Validate that keyspace is an existing keyspace and cfName one of its existing column family.
getTableMetadata(String, String) - Method in class org.apache.cassandra.schema.Schema
Given a keyspace name and table name, get the table meta data.
getTableMetadata(TableId) - Method in class org.apache.cassandra.schema.Schema
 
getTableMetadata(Descriptor) - Method in class org.apache.cassandra.schema.Schema
 
getTableMetadata(TableId) - Method in interface org.apache.cassandra.schema.SchemaProvider
 
getTableMetadata(String, String) - Method in interface org.apache.cassandra.schema.SchemaProvider
 
getTableMetadata(String) - Method in class org.apache.cassandra.utils.NativeSSTableLoaderClient
 
getTableMetadataAsCQL(TableMetadata, boolean, boolean, boolean) - Static method in class org.apache.cassandra.db.SchemaCQLHelper
Build a CQL String representation of Column Family Metadata.
getTableMetadataNullable(TableId) - Method in class org.apache.cassandra.db.virtual.VirtualKeyspaceRegistry
 
getTableMetadataRef(String, String) - Method in class org.apache.cassandra.schema.Schema
Given a keyspace name and table/view name, get the table metadata reference.
getTableMetadataRef(TableId) - Method in class org.apache.cassandra.schema.Schema
Get Table metadata by its identifier
getTableMetadataRef(Descriptor) - Method in class org.apache.cassandra.schema.Schema
 
getTableMetadataRef(String, String) - Method in interface org.apache.cassandra.schema.SchemaProvider
 
getTableMetadataRef(TableId) - Method in interface org.apache.cassandra.schema.SchemaProvider
 
getTableMetadataRef(Descriptor) - Method in interface org.apache.cassandra.schema.SchemaProvider
 
getTableName() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTableName() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getTableNullable(TableId) - Method in class org.apache.cassandra.db.virtual.VirtualKeyspaceRegistry
 
getTableOrViewNullable(String) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
getTableOrViewNullable(TableId) - Method in class org.apache.cassandra.schema.Keyspaces
 
getTablesAndViews(String) - Method in class org.apache.cassandra.schema.Schema
Get metadata about keyspace inner ColumnFamilies
getTableSchema(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
getTargetIndex() - Method in class org.apache.cassandra.db.filter.RowFilter.CustomExpression
 
getTask() - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder.TaskSupplier
 
getTaskAttemptID(TaskAttemptContext) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
returns TaskAttemptContext.getTaskAttemptID().
getTaskId() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getTaskType() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getTempDir() - Static method in class org.apache.cassandra.io.util.FileUtils
 
getTemporaryFiles() - Method in class org.apache.cassandra.io.sstable.Descriptor
Return any temporary files found in the directory
getTemporaryWriteableDirectoryAsFile(long) - Method in class org.apache.cassandra.db.Directories
Returns a temporary subdirectory on allowed data directory that _currently_ has writeSize bytes as usable space.
getTerm(int) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
 
getTerm() - Method in class org.apache.cassandra.index.sasi.sa.ByteTerm
 
getTerm() - Method in class org.apache.cassandra.index.sasi.sa.CharTerm
 
getTerm(ByteBuffer, TokenTreeBuilder) - Method in class org.apache.cassandra.index.sasi.sa.IntegralSA
 
getTerm(ByteBuffer, TokenTreeBuilder) - Method in class org.apache.cassandra.index.sasi.sa.SA
 
getTerm(ByteBuffer, TokenTreeBuilder) - Method in class org.apache.cassandra.index.sasi.sa.SuffixSA
 
getTerm() - Method in class org.apache.cassandra.index.sasi.sa.Term
 
getTerm() - Method in class org.apache.cassandra.index.sasi.Term
 
getTerm() - Method in class org.apache.cassandra.index.sasi.utils.CombinedTerm
 
getTermPosition(int) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
 
getText() - Method in class org.apache.cassandra.cql3.AbstractMarker.MultiColumnRaw
 
getText() - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
 
getText() - Method in class org.apache.cassandra.cql3.Constants.Literal
 
getText() - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
 
getText() - Method in class org.apache.cassandra.cql3.Lists.Literal
 
getText() - Method in class org.apache.cassandra.cql3.Maps.Literal
 
getText() - Method in class org.apache.cassandra.cql3.Sets.Literal
 
getText() - Method in class org.apache.cassandra.cql3.Term.Raw
 
getText() - Method in class org.apache.cassandra.cql3.Tuples.Literal
 
getText() - Method in class org.apache.cassandra.cql3.TypeCast
 
getText() - Method in class org.apache.cassandra.cql3.UserTypes.Literal
 
getText() - Method in interface org.apache.cassandra.index.sasi.analyzer.StandardTokenizerInterface
 
getTextMap(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
getThreadFactory() - Method in class org.apache.cassandra.concurrent.JMXEnabledSingleThreadExecutor
 
getThreadLocalReusableBuffer(int) - Method in class org.apache.cassandra.io.util.SimpleCachedBufferPool
 
getThreadLocalScratchBuffer() - Static method in class org.apache.cassandra.io.compress.DeflateCompressor
 
getThreadPoolMetric(String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getThreadPoolMetrics(String) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
getThreadPools() - Method in class org.apache.cassandra.tools.NodeProbe
Retrieve threadpool paths and names for threadpools with metrics.
getTime(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a long in nanoseconds since midnight.
getTime(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a long in nanoseconds since midnight.
getTime(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a long in nanoseconds since midnight.
getTimeout(TimeUnit) - Method in class org.apache.cassandra.db.CounterMutation
 
getTimeout(TimeUnit) - Method in interface org.apache.cassandra.db.IMutation
 
getTimeout(TimeUnit) - Method in class org.apache.cassandra.db.Mutation
 
getTimeout(TimeUnit) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
getTimeout(TimeUnit) - Method in class org.apache.cassandra.db.ReadCommand
The configured timeout for this command.
getTimeout(TimeUnit) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
getTimeout(TimeUnit) - Method in class org.apache.cassandra.db.virtual.VirtualMutation
 
getTimeout(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
GetTimeout - Class in org.apache.cassandra.tools.nodetool
 
GetTimeout() - Constructor for class org.apache.cassandra.tools.nodetool.GetTimeout
 
getTimeoutsPerHost() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Deprecated.
getTimeoutsPerHost() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getTimeoutsPerHostWithPort() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
 
getTimeoutsPerHostWithPort() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getTimestamp() - Method in class org.apache.cassandra.audit.AuditLogEntry
 
getTimestamp(long, QueryOptions) - Method in class org.apache.cassandra.cql3.Attributes
 
getTimestamp(QueryState) - Method in class org.apache.cassandra.cql3.BatchQueryOptions
 
getTimestamp(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a date.
getTimestamp(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a date.
getTimestamp(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a date.
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() - Static 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
Generate, cache, and record a timestamp value on the server-side.
getTimestampedSnapshotName(String) - Static method in class org.apache.cassandra.db.Keyspace
 
getTimestampedSnapshotNameWithPrefix(String, String) - Static method in class org.apache.cassandra.db.Keyspace
 
getTimestampForPaxos(long) - Method in class org.apache.cassandra.service.ClientState
Returns a timestamp suitable for paxos given the timestamp of the last known commit (or in progress update).
getTimeToLive(QueryOptions, TableMetadata) - Method in class org.apache.cassandra.cql3.Attributes
 
getTimeToLive(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
getTimeUUID() - Static method in class org.apache.cassandra.utils.UUIDGen
Creates a type 1 UUID (time-based UUID).
getTimeUUID(long) - Static method in class org.apache.cassandra.utils.UUIDGen
Creates a type 1 UUID (time-based UUID) with the timestamp of @param when, in milliseconds.
getTimeUUID(long, long) - Static method in class org.apache.cassandra.utils.UUIDGen
 
getTimeUUID(long, long, long) - Static method in class org.apache.cassandra.utils.UUIDGen
 
getTimeUUIDBytes() - Static method in class org.apache.cassandra.utils.UUIDGen
Returns a 16 byte representation of a type 1 UUID (a time-based UUID), based on the current system time.
getTimeUUIDBytes(long, int) - Static method in class org.apache.cassandra.utils.UUIDGen
Converts a 100-nanoseconds precision timestamp into the 16 byte representation of a type 1 UUID (a time-based UUID).
getTimeUUIDFromMicros(long) - Static method in class org.apache.cassandra.utils.UUIDGen
Returns a version 1 UUID using the provided timestamp and the local clock and sequence.
getToken() - Method in class org.apache.cassandra.db.DecoratedKey
 
getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
getToken(ByteBuffer) - Method in interface org.apache.cassandra.dht.IPartitioner
 
getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
Generate the token of a key.
getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getToken() - Method in interface org.apache.cassandra.dht.RingPosition
 
getToken() - Method in class org.apache.cassandra.dht.Token
 
getToken() - Method in class org.apache.cassandra.dht.Token.KeyBound
 
getToken() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
 
getToken(InetAddressAndPort) - 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
 
getTokenAt(MappedBuffer, int, short, Function<Long, DecoratedKey>) - Static method in class org.apache.cassandra.index.sasi.disk.TokenTree.OnDiskToken
 
getTokenCount() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
 
getTokenCount() - Method in class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
 
getTokenCount() - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
getTokenCount() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
 
getTokenFactory() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
getTokenFactory() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getTokenFactory() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
getTokenFactory() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
 
getTokenFactory() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getTokenFactory() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getTokenFactory() - Method in class org.apache.cassandra.service.StorageService
 
getTokenIterator() - Method in class org.apache.cassandra.index.sasi.utils.CombinedTerm
 
getTokenMetadata() - Method in class org.apache.cassandra.service.StorageService
 
getTokens() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataTerm
 
getTokens() - Method in class org.apache.cassandra.index.sasi.sa.Term
 
getTokens(InetAddressAndPort) - 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
Deprecated.
getTokenToEndpointMap(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
 
getTokenToEndpointWithPortMap() - Method in class org.apache.cassandra.service.StorageService
 
getTokenToEndpointWithPortMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getTokenTreeBuilder() - Method in class org.apache.cassandra.index.sasi.utils.CombinedTerm
 
getTokenValidator() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
getTokenValidator() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getTokenValidator() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
getTokenValidator() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
 
getTokenValidator() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getTokenValidator() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getTokenValue() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
getTokenValue() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
getTokenValue() - Method in class org.apache.cassandra.dht.Token
 
getTombstoneFailureThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTombstoneFailureThreshold() - Method in class org.apache.cassandra.service.StorageService
 
getTombstoneFailureThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the threshold for abandoning queries with many tombstones
getTombstoneWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTombstoneWarnThreshold() - Method in class org.apache.cassandra.service.StorageService
 
getTombstoneWarnThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the threshold for warning of queries with many tombstones
getToolsOutputDirectory() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getTopology() - Method in class org.apache.cassandra.locator.TokenMetadata
 
getTotal() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
getTotal() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
 
getTotalBatchesReplayed() - Method in class org.apache.cassandra.batchlog.BatchlogManager
 
getTotalBatchesReplayed() - Method in interface org.apache.cassandra.batchlog.BatchlogManagerMBean
 
getTotalBlockedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
getTotalBytes(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getTotalBytes() - Method in class org.apache.cassandra.io.sstable.KeyIterator
 
getTotalBytes() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
getTotalBytesCompacted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getTotalBytesScanned() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy.ScannerList
 
getTotalColumnsSet() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getTotalCommitlogSpaceInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTotalCompactionsCompleted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
getTotalCompressedSize() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy.ScannerList
 
getTotalFilesReceived() - Method in class org.apache.cassandra.streaming.SessionInfo
 
getTotalFilesSent() - Method in class org.apache.cassandra.streaming.SessionInfo
 
getTotalFilesToReceive() - Method in class org.apache.cassandra.streaming.SessionInfo
 
getTotalFilesToSend() - Method in class org.apache.cassandra.streaming.SessionInfo
 
getTotalHints() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalHints() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamReceiveTask
 
getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamTask
 
getTotalNumberOfFiles() - Method in class org.apache.cassandra.streaming.StreamTransferTask
 
getTotalRows() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getTotalSinceLastCheck() - Method in class org.apache.cassandra.service.GCInspector
 
getTotalSize() - Method in class org.apache.cassandra.db.streaming.CompressionInfo
Computes the size of the file to transfer.
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<SSTableReader.PartitionPositionBounds>) - 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
 
getTotalSourceCQLRows() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
 
getTotalSpace(File) - Static method in class org.apache.cassandra.io.util.FileUtils
Returns the size of the specified partition.
getTotalTimeouts() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Total number of timeouts happened on this node
getTotalTimeouts() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getTotalUncompressedBytes(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
getTraceProbability() - Method in class org.apache.cassandra.service.StorageService
 
getTraceProbability() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Returns the configured tracing probability.
getTraceProbability() - Method in class org.apache.cassandra.tools.NodeProbe
 
GetTraceProbability - Class in org.apache.cassandra.tools.nodetool
 
GetTraceProbability() - Constructor for class org.apache.cassandra.tools.nodetool.GetTraceProbability
 
getTraceType() - Method in class org.apache.cassandra.tracing.Tracing
 
getTracetypeQueryTTL() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTracetypeRepairTTL() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTracker() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Package protected for access from the CompactionManager.
getTracker() - Method in class org.apache.cassandra.transport.Connection
 
getTransferredRanges(String, String, IPartitioner) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
getTransparentDataEncryptionOptions() - Method in class org.apache.cassandra.security.EncryptionContext
 
getTrickleFsync() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTrickleFsyncIntervalInKb() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTrueAllocatedSizeIn(File) - Method in class org.apache.cassandra.db.Directories
 
getTrueNegativeCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getTruncatedAt(TableId) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
getTruncatedPosition(TableId) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
getTruncateRpcTimeout(TimeUnit) - 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
 
getTruncateRpcTimeout() - Method in class org.apache.cassandra.service.StorageService
 
getTruncateRpcTimeout() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getTruncateTask(long) - Method in interface org.apache.cassandra.index.Index
Return a task to truncate the index with the specified truncation timestamp.
getTruncateTask(long) - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
getTruncateTask(long) - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
getTTL() - Method in class org.apache.cassandra.tracing.Tracing
 
getTTL() - Method in enum org.apache.cassandra.tracing.Tracing.TraceType
 
getTupleType(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.Tuples
 
getTupleValue(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Return the value for name as a tuple value.
getTupleValue(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Return the ith value as a tuple value.
getTupleValue(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Return the value for name as a tuple value.
getType() - Method in class org.apache.cassandra.audit.AuditEvent
 
getType() - Method in class org.apache.cassandra.audit.AuditLogEntry
 
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(int) - Method in class org.apache.cassandra.cql3.functions.types.TupleValue
 
getType() - Method in class org.apache.cassandra.cql3.functions.types.TupleValue
The tuple type this is a value of.
getType(int) - Method in class org.apache.cassandra.cql3.functions.types.UDTValue
 
getType() - Method in class org.apache.cassandra.cql3.functions.types.UDTValue
The UDT this is a value of.
getType() - Method in class org.apache.cassandra.cql3.functions.types.UserType.Field
Returns the type of the field.
getType() - Method in class org.apache.cassandra.cql3.selection.Selector
Returns the Selector output type.
getType() - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
 
getType() - Method in class org.apache.cassandra.cql3.selection.TermSelector
 
getType() - Method in class org.apache.cassandra.db.SerializationHeader.Component
 
getType(ColumnMetadata) - Method in class org.apache.cassandra.db.SerializationHeader
 
getType() - Method in class org.apache.cassandra.diag.DiagnosticEvent
Returns event type discriminator.
getType() - Method in class org.apache.cassandra.gms.GossiperEvent
 
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.locator.TokenMetadataEvent
 
getType() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Returns the type to which the Metric belongs.
getType() - Method in class org.apache.cassandra.schema.SchemaEvent
 
getType() - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
 
getType() - Method in class org.apache.cassandra.serializers.BooleanSerializer
 
getType() - Method in class org.apache.cassandra.serializers.ByteSerializer
 
getType() - Method in class org.apache.cassandra.serializers.BytesSerializer
 
getType() - Method in class org.apache.cassandra.serializers.DecimalSerializer
 
getType() - Method in class org.apache.cassandra.serializers.DoubleSerializer
 
getType() - Method in class org.apache.cassandra.serializers.DurationSerializer
 
getType() - Method in class org.apache.cassandra.serializers.EmptySerializer
 
getType() - Method in class org.apache.cassandra.serializers.FloatSerializer
 
getType() - Method in class org.apache.cassandra.serializers.InetAddressSerializer
 
getType() - Method in class org.apache.cassandra.serializers.Int32Serializer
 
getType() - Method in class org.apache.cassandra.serializers.IntegerSerializer
 
getType() - Method in class org.apache.cassandra.serializers.ListSerializer
 
getType() - Method in class org.apache.cassandra.serializers.LongSerializer
 
getType() - Method in class org.apache.cassandra.serializers.MapSerializer
 
getType() - Method in class org.apache.cassandra.serializers.SetSerializer
 
getType() - Method in class org.apache.cassandra.serializers.ShortSerializer
 
getType() - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
 
getType() - Method in class org.apache.cassandra.serializers.TimeSerializer
 
getType() - Method in class org.apache.cassandra.serializers.TimestampSerializer
 
getType() - Method in class org.apache.cassandra.serializers.TypeSerializer
 
getType() - Method in class org.apache.cassandra.serializers.UUIDSerializer
 
getType() - Method in class org.apache.cassandra.tools.JMXTool.Attribute
 
getType() - Method in class org.apache.cassandra.tools.JMXTool.Parameter
 
getType() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
 
getTypeArguments() - Method in class org.apache.cassandra.cql3.functions.types.DataType.CollectionType
 
getTypeArguments() - Method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the type arguments of this type.
getTypeName() - Method in class org.apache.cassandra.cql3.functions.types.UserType
The name of this user type.
getTypeParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
 
getUdas(FunctionName) - Method in class org.apache.cassandra.schema.Functions
Get all UDAs overloads with the specified name
getUdfs(FunctionName) - Method in class org.apache.cassandra.schema.Functions
Get all UDFs overloads with the specified name
getUDTValue(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Return the value for name as a UDT value.
getUDTValue(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Return the ith value as a UDT value.
getUDTValue(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Return the value for name as a UDT value.
getUDType(String) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
Returns the User Defined type, used in this SSTable Writer, that can be used to create UDTValue instances.
getUncompacting() - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
getUncompacting(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
getUncompacting(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.View
 
getUncompactingSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getUnfilteredRowIterator(ColumnFilter, Partition) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
Given a partition, returns a row iterator for the rows of this partition that are selected by this filter.
getUnfilteredRowIterator(ColumnFilter, Partition) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
 
getUnfilteredRowIterator(ColumnFilter, Partition) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
 
getUnit() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
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.CompactionStrategyManager
 
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
Deprecated.
getUnreachableNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
getUnreachableNodes(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
 
getUnreachableNodesWithPort() - Method in class org.apache.cassandra.service.StorageService
 
getUnreachableNodesWithPort() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getUnreachableTokenOwners() - Method in class org.apache.cassandra.gms.Gossiper
 
getUnreadableDirectories() - Method in class org.apache.cassandra.db.DisallowedDirectories
 
getUnreadableDirectories() - Method in interface org.apache.cassandra.db.DisallowedDirectoriesMBean
 
getUnsignedShort(byte[], int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
getUnsignedShort(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
getUnsignedShort(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
returns an unsigned short from offset
getUnsignedShort(byte[], int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
getUnsignedShort(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
getUnsignedVInt(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
Note this method is the same as readUnsignedVInt(DataInput), except that we do *not* block if there are not enough bytes in the buffer to reconstruct the value.
getUnsignedVInt(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
 
getUnwritableDirectories() - Method in class org.apache.cassandra.db.DisallowedDirectories
 
getUnwritableDirectories() - Method in interface org.apache.cassandra.db.DisallowedDirectoriesMBean
 
getUpdateInterval() - Method in class org.apache.cassandra.auth.AuthCache
 
getUpdateInterval() - Method in interface org.apache.cassandra.auth.AuthCacheMBean
 
getUpdateInterval() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getUpdateInterval() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
getUpdateTimestamp() - Method in class org.apache.cassandra.gms.EndpointState
 
getUpEndpointCount() - Method in class org.apache.cassandra.gms.FailureDetector
 
getUpEndpointCount() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
getUptime() - Method in class org.apache.cassandra.tools.NodeProbe
 
getUsableSpace(File) - Static method in class org.apache.cassandra.io.util.FileUtils
Returns the number of available bytes on the specified partition.
getUseOffheapMerkleTrees() - Method in class org.apache.cassandra.service.ActiveRepairService
 
getUseOffheapMerkleTrees() - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
 
getUser() - Method in class org.apache.cassandra.audit.AuditLogEntry
 
getUser() - Method in class org.apache.cassandra.service.ClientState
 
getUserDefinedFunctionFailTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getUserDefinedFunctionWarnTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
Deprecated.
 
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.TimeWindowCompactionStrategy
 
getUserDefinedTasks(AbstractStrategyHolder.GroupedSSTableContainer, int) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
 
getUserDefinedTasks(AbstractStrategyHolder.GroupedSSTableContainer, int) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
getUserDefinedTasks(Collection<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
Return a list of compaction tasks corresponding to the sstables requested.
getUserDefinedTasks(AbstractStrategyHolder.GroupedSSTableContainer, int) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
getUserFunctionTimeoutPolicy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getUserKeyspaces() - Method in class org.apache.cassandra.schema.Schema
 
getUserTypeName() - Method in class org.apache.cassandra.cql3.UTName
 
getUserTypeParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
 
getUserTypesAsCQL(TableMetadata, Types, boolean) - Static method in class org.apache.cassandra.db.SchemaCQLHelper
Build a CQL String representation of User Types used in the given table.
getUUID(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a UUID.
getUUID(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a UUID.
getUUID(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a UUID.
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.
getValidationIterator(Collection<Range<Token>>, UUID, UUID, boolean, int) - Method in class org.apache.cassandra.db.repair.CassandraTableRepairManager
 
getValidationIterator(Collection<Range<Token>>, UUID, UUID, boolean, int) - Method in interface org.apache.cassandra.repair.TableRepairManager
Return a validation iterator for the given parameters.
getValidationPreviewPurgeHeadStartInSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getValidator() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
getValidColumnFamilies(boolean, boolean, String...) - Method in class org.apache.cassandra.db.Keyspace
 
getValidColumnFamilies(boolean, boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
getValidDatacenters() - Static method in class org.apache.cassandra.dht.Datacenters
 
getValidity() - Method in class org.apache.cassandra.auth.AuthCache
 
getValidity() - Method in interface org.apache.cassandra.auth.AuthCacheMBean
 
getValue() - Method in class org.apache.cassandra.cql3.conditions.ColumnCondition.Raw
 
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 enum org.apache.cassandra.cql3.Operator
 
getValue() - Method in class org.apache.cassandra.cql3.Relation
Returns the raw value for this relation, or null if this is an IN relation.
getValue() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
getValue() - Method in class org.apache.cassandra.cql3.TokenRelation
 
getValue() - Method in class org.apache.cassandra.db.filter.RowFilter.CustomExpression
 
getValue(TableMetadata, DecoratedKey, Row) - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
 
getValue() - Method in enum org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer.TokenType
 
getValue() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxGaugeMBean
 
getValueOf(ColumnMetadata, Row, int) - Static method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
getValues() - Method in class org.apache.cassandra.cql3.QueryOptions
 
getValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.INRestriction
 
getValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithMarker
 
getValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithValues
 
getValuesType() - Method in class org.apache.cassandra.db.marshal.MapType
 
getVarint(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns the value for name as a variable length integer.
getVarint(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns the ith value as a variable length integer.
getVarint(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns the value for name as a variable length integer.
getVerifyInfo() - Method in class org.apache.cassandra.db.compaction.Verifier
 
getVersion(String) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
 
getVersion(String) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
 
getVersion() - Method in class org.apache.cassandra.io.sstable.format.Version
 
getVersion(String) - Method in interface org.apache.cassandra.net.MessagingServiceMBean
 
getVersion(String) - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
getVersion() - Method in class org.apache.cassandra.schema.Schema
 
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
 
getVersionInfoUnsafe(UUID) - Method in class org.apache.cassandra.schema.MigrationCoordinator
 
getView() - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
getView() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
getView() - Method in class org.apache.cassandra.index.sasi.conf.DataTracker
 
getView(String, String) - Method in class org.apache.cassandra.schema.Schema
 
getViewBuildStatus(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
getViewBuildStatuses(String, String, boolean) - Method in class org.apache.cassandra.service.StorageService
 
getViewBuildStatuses(String, String) - Method in class org.apache.cassandra.service.StorageService
 
getViewBuildStatuses(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
getViewBuildStatuses(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getViewBuildStatusesWithPort(String, String) - Method in class org.apache.cassandra.service.StorageService
 
getViewBuildStatusesWithPort(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getViewColumn(ColumnMetadata) - Method in class org.apache.cassandra.db.view.View
The view column corresponding to the provided base column.
getViewNaturalEndpoint(AbstractReplicationStrategy, Token, Token) - Static method in class org.apache.cassandra.db.view.ViewUtils
Calculate the natural endpoint for the view.
getWaiting() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
Return how many threads are waiting
getWarnings() - Method in class org.apache.cassandra.service.ClientWarn
 
getWarnings() - Method in class org.apache.cassandra.transport.Message.Response
 
getWindowBoundsInMillis(TimeUnit, int, long) - Static method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
Find the lowest and highest timestamps in a given timestamp/unit pair Returns milliseconds, caller should adjust accordingly
getWindowsTimerInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getWithContacts(E) - Method in interface org.apache.cassandra.locator.ReplicaPlan.Shared
get the shared replica plan, non-volatile (so maybe stale) but no risk of partially initialised, but replace its 'contacts' with those provided
getWithContacts(EndpointsForRange) - Method in class org.apache.cassandra.locator.ReplicaPlan.SharedForRangeRead
 
getWithContacts(EndpointsForToken) - Method in class org.apache.cassandra.locator.ReplicaPlan.SharedForTokenRead
 
getWriteableLocation(long) - Method in class org.apache.cassandra.db.Directories
Returns an allowed data directory that _currently_ has writeSize bytes as usable space.
getWriteableLocationAsFile(long) - Method in class org.apache.cassandra.db.Directories
Returns an allowed directory that _currently_ has writeSize bytes as usable space.
getWriteableLocations() - Method in class org.apache.cassandra.db.Directories
 
getWriteableLocationToLoadFile(File) - Method in class org.apache.cassandra.db.Directories
Returns a data directory to load the file sourceFile.
getWriteConsistencyLevel(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getWriteContext() - Method in class org.apache.cassandra.db.ReadExecutionController
 
getWriteDirectory(Iterable<SSTableReader>, long) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
Return a directory where we can expect expectedWriteSize to fit.
getWriteEndpoints(Token, String, EndpointsForToken) - Method in class org.apache.cassandra.locator.TokenMetadata
Deprecated.
retained for benefit of old tests
getWriteHandler() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getWriteHandler() - Method in class org.apache.cassandra.db.Keyspace
 
getWriter(int) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
getWriteResponseHandler(ReplicaPlan.ForTokenWrite, Runnable, WriteType, long) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getWriteResponseHandler(ReplicaPlan.ForTokenWrite, Runnable, WriteType, long, ConsistencyLevel) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getWriterFactory() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
 
getWriterFactory() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
 
getWriteRpcTimeout(TimeUnit) - 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
 
getWriteRpcTimeout() - Method in class org.apache.cassandra.service.StorageService
 
getWriteRpcTimeout() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getYear() - Method in class org.apache.cassandra.cql3.functions.types.LocalDate
Returns the year.
global() - Static method in interface org.apache.cassandra.dht.IPartitioner
 
global - Variable in class org.apache.cassandra.metrics.TableMetrics.TableHistogram
 
global - Variable in class org.apache.cassandra.metrics.TableMetrics.TableMeter
 
global - Variable in class org.apache.cassandra.metrics.TableMetrics.TableTimer
 
global(ResourceLimits.Limit) - Static method in class org.apache.cassandra.net.AbstractMessageHandler.WaitQueue
 
global() - Method in class org.apache.cassandra.net.ResourceLimits.EndpointAndGlobal
 
GLOBAL_RANGE_LATENCY - Static variable in class org.apache.cassandra.metrics.TableMetrics
 
GLOBAL_READ_LATENCY - Static variable in class org.apache.cassandra.metrics.TableMetrics
 
GLOBAL_WRITE_LATENCY - Static variable in class org.apache.cassandra.metrics.TableMetrics
 
GlobalBufferPoolAllocator - Class in org.apache.cassandra.net
Primary ByteBuf / ByteBuffer allocator - using the global BufferPool.
globalBytesPendingRepair - Static variable in class org.apache.cassandra.metrics.TableMetrics
 
globalBytesRepaired - Static variable in class org.apache.cassandra.metrics.TableMetrics
 
globalBytesUnrepaired - Static variable in class org.apache.cassandra.metrics.TableMetrics
 
globalCount() - Method in class org.apache.cassandra.utils.concurrent.Ref
A convenience method for reporting:
globalPercentRepaired - Static variable in class org.apache.cassandra.metrics.TableMetrics
 
globalPool() - Method in class org.apache.cassandra.utils.memory.BufferPool
 
globalPrefix() - Static method in class org.apache.cassandra.concurrent.NamedThreadFactory
 
globalReserveCapacity - Variable in class org.apache.cassandra.net.AbstractMessageHandler
 
globalWaitQueue - Variable in class org.apache.cassandra.net.AbstractMessageHandler
 
goodPartitions - 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.
Gossiper.Props - Class in org.apache.cassandra.gms
 
GossiperEvent - Class in org.apache.cassandra.gms
DiagnosticEvent implementation for Gossiper activities.
GossiperEvent.GossiperEventType - Enum in org.apache.cassandra.gms
 
GossiperMBean - Interface in org.apache.cassandra.gms
 
gossiperStarting() - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
 
gossiperStarting() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
gossiperStarting() - Method in class org.apache.cassandra.locator.Ec2MultiRegionSnitch
 
gossiperStarting() - Method in class org.apache.cassandra.locator.GossipingPropertyFileSnitch
 
gossiperStarting() - Method in interface org.apache.cassandra.locator.IEndpointSnitch
called after Gossiper instance exists immediately before it starts gossiping
gossiperStarting() - Method in class org.apache.cassandra.locator.PropertyFileSnitch
 
GossipInfo - Class in org.apache.cassandra.tools.nodetool
 
GossipInfo() - Constructor for class org.apache.cassandra.tools.nodetool.GossipInfo
 
GossipingPropertyFileSnitch - Class in org.apache.cassandra.locator
 
GossipingPropertyFileSnitch() - Constructor for class org.apache.cassandra.locator.GossipingPropertyFileSnitch
 
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
 
GossipVerbHandler<T> - Class in org.apache.cassandra.gms
 
GossipVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipVerbHandler
 
gossProxy - Variable in class org.apache.cassandra.tools.NodeProbe
 
grant(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
grant(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
grant(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
Grants a set of permissions on a resource to a role.
grantee - Variable in class org.apache.cassandra.auth.PermissionDetails
 
grantee - Variable in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
 
grantee - Variable in class org.apache.cassandra.cql3.statements.RoleManagementStatement
 
GrantPermissionsStatement - Class in org.apache.cassandra.cql3.statements
 
GrantPermissionsStatement(Set<Permission>, IResource, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.GrantPermissionsStatement
 
grantRole(AuthenticatedUser, RoleResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
grantRole(AuthenticatedUser, RoleResource, RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
Called during execution of GRANT ROLE query.
GrantRoleStatement - Class in org.apache.cassandra.cql3.statements
 
GrantRoleStatement(RoleName, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.GrantRoleStatement
 
Group(List<SinglePartitionReadCommand>, DataLimits) - Constructor for class org.apache.cassandra.db.SinglePartitionReadCommand.Group
 
Group(List<T>, DataLimits) - Constructor for class org.apache.cassandra.db.SinglePartitionReadQuery.Group
 
Group(List<VirtualTableSinglePartitionReadQuery>, DataLimits) - Constructor for class org.apache.cassandra.db.VirtualTableSinglePartitionReadQuery.Group
 
GROUP_EVERYTHING - Static variable in class org.apache.cassandra.db.aggregation.GroupMaker
GroupMaker that groups all the rows together.
GROUP_NAME - Static variable in class org.apache.cassandra.metrics.DefaultNameFactory
 
groupByLimits(int, int, int, AggregationSpecification) - Static method in class org.apache.cassandra.db.filter.DataLimits
 
GroupByPartitionIterator(int, ConsistencyLevel, ClientState, long) - Constructor for class org.apache.cassandra.service.pager.AggregationQueryPager.GroupByPartitionIterator
 
GroupByPartitionIterator(int, ReadExecutionController, long) - Constructor for class org.apache.cassandra.service.pager.AggregationQueryPager.GroupByPartitionIterator
 
GroupCommitLogService - Class in org.apache.cassandra.db.commitlog
A commitlog service that will block returning an ACK back to the a coordinator/client for a minimum amount of time as we wait until the the commit log segment is flushed.
GroupCommitLogService(CommitLog) - Constructor for class org.apache.cassandra.db.commitlog.GroupCommitLogService
 
GroupingState - Class in org.apache.cassandra.db.aggregation
GroupMaker state.
GroupingState(ByteBuffer, Clustering<?>) - Constructor for class org.apache.cassandra.db.aggregation.GroupingState
 
GroupingState.Serializer - Class in org.apache.cassandra.db.aggregation
 
GroupMaker - Class in org.apache.cassandra.db.aggregation
A GroupMaker can be used to determine if some sorted rows belongs to the same group or not.
GroupMaker() - Constructor for class org.apache.cassandra.db.aggregation.GroupMaker
 
groups - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
 
groupSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
Split sstables into a list of grouped sstable containers, the list index an sstable lives in matches the list index of the holder that's responsible for it
groupSSTablesForAntiCompaction(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
Method for grouping similar SSTables together, This will be used by anti-compaction to determine which SSTables should be anitcompacted as a group.
groupSSTablesForAntiCompaction(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
groupSSTablesForAntiCompaction(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
Deprecated.
DTCS should not group sstables for anticompaction - this can mix new and old data
groupSSTablesForAntiCompaction(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
Leveled compaction strategy has guarantees on the data contained within each level so we have to make sure we only create groups of SSTables with members from the same level.
GT - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader.Operator
 
guid() - Static method in class org.apache.cassandra.utils.GuidGenerator
 
guidAsBytes(Random, String, long) - Static method in class org.apache.cassandra.utils.GuidGenerator
 
guidAsBytes() - Static method in class org.apache.cassandra.utils.GuidGenerator
 
GuidGenerator - Class in org.apache.cassandra.utils
 
GuidGenerator() - Constructor for class org.apache.cassandra.utils.GuidGenerator
 
guidToString(byte[]) - Static method in class org.apache.cassandra.utils.GuidGenerator
 

H

HadoopCompat - Class in org.apache.cassandra.hadoop
Utility methods to allow applications to deal with inconsistencies between MapReduce Context Objects API between Hadoop 1.x and 2.x.
HadoopCompat() - Constructor for class org.apache.cassandra.hadoop.HadoopCompat
 
HALF_TIME_IN_S - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
handleCaseSensitivity(Map<String, Object>) - Static method in class org.apache.cassandra.cql3.Json
Handles unquoting and case-insensitivity in map keys.
handleCommitError(String, Throwable) - Static method in class org.apache.cassandra.db.commitlog.CommitLog
 
handleConnectionClosed(long, String) - Method in class org.apache.cassandra.tools.BootstrapMonitor
 
handleConnectionClosed(long, String) - Method in class org.apache.cassandra.tools.RepairRunner
 
handleConnectionClosed(long, String) - Method in class org.apache.cassandra.utils.progress.jmx.JMXNotificationProgressListener
Called when JMX connection is closed.
handleConnectionFailed(long, String) - Method in class org.apache.cassandra.tools.BootstrapMonitor
 
handleConnectionFailed(long, String) - Method in class org.apache.cassandra.tools.RepairRunner
 
handleConnectionFailed(long, String) - Method in class org.apache.cassandra.utils.progress.jmx.JMXNotificationProgressListener
Called when JMX connection is failed.
handleCorruptSSTable(CorruptSSTableException) - Method in interface org.apache.cassandra.io.FSErrorHandler
 
handleCorruptSSTable(CorruptSSTableException) - Static method in class org.apache.cassandra.io.util.FileUtils
 
handleCorruptSSTable(CorruptSSTableException) - Method in class org.apache.cassandra.service.DefaultFSErrorHandler
 
handleFailedSnapshot(File) - Static method in class org.apache.cassandra.db.WindowsFailedSnapshotTracker
 
handleFailSessionMessage(FailSession) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSessions
 
handleFailSessionMessage(InetAddressAndPort, FailSession) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
handleFinalizeCommitMessage(InetAddressAndPort, FinalizeCommit) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
Finalizes the repair session, completing it as successful.
handleFinalizePromise(InetAddressAndPort, boolean) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
 
handleFinalizePromiseMessage(FinalizePromise) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSessions
 
handleFinalizeProposeMessage(InetAddressAndPort, FinalizePropose) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
handleFSError(FSError) - Method in interface org.apache.cassandra.io.FSErrorHandler
 
handleFSError(FSError) - Static method in class org.apache.cassandra.io.util.FileUtils
 
handleFSError(FSError) - Method in class org.apache.cassandra.service.DefaultFSErrorHandler
 
handleFSErrorAndPropagate(FSError) - Static method in class org.apache.cassandra.io.util.FileUtils
handleFSErrorAndPropagate will invoke the disk failure policy error handler, which may or may not stop the daemon or transports.
handleInvalid(TableMetadata, DecoratedKey, SSTableReader, String) - Static method in class org.apache.cassandra.db.UnfilteredValidation
 
handleMessage(Message<? extends RepairMessage>) - Method in class org.apache.cassandra.service.ActiveRepairService
 
handleMutation(Mutation, int, int, CommitLogDescriptor) - Method in interface org.apache.cassandra.db.commitlog.CommitLogReadHandler
Process a deserialized mutation
handleMutation(Mutation, int, int, CommitLogDescriptor) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
handleNotification(INotification, Object) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
handleNotification(INotification, Object) - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
handleNotification(INotification, Object) - Method in class org.apache.cassandra.index.SecondaryIndexManager
 
handleNotification(INotification, Object) - Method in interface org.apache.cassandra.notifications.INotificationConsumer
 
handleNotification(Notification, Object) - Method in class org.apache.cassandra.service.GCInspector
 
handleNotification(INotification, Object) - Method in class org.apache.cassandra.service.SSTablesGlobalTracker
 
handleNotification(Notification, Object) - Method in class org.apache.cassandra.utils.progress.jmx.JMXNotificationProgressListener
 
handleNotificationLost(long, String) - Method in class org.apache.cassandra.tools.BootstrapMonitor
 
handleNotificationLost(long, String) - Method in class org.apache.cassandra.tools.RepairRunner
 
handleNotificationLost(long, String) - Method in class org.apache.cassandra.utils.progress.jmx.JMXNotificationProgressListener
Called when receiving JMXConnectionNotification.NOTIFS_LOST message.
handleOrLog(Throwable) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
Send @param t to the default uncaught exception handler, or log it if none such is set up
handlePrepareMessage(InetAddressAndPort, PrepareConsistentRequest) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
The PrepareConsistentRequest promotes the parent repair session to a consistent incremental session, and isolates the data to be repaired from the rest of the table's data No response is sent to the repair coordinator until the data preparation / isolation has completed successfully.
handlePrepareResponse(InetAddressAndPort, boolean) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
 
handlePrepareResponse(PrepareConsistentResponse) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSessions
 
handleProgress(ProgressInfo) - Method in class org.apache.cassandra.streaming.StreamResultFuture
 
handler() - Method in enum org.apache.cassandra.net.Verb
 
handler - Variable in class org.apache.cassandra.service.reads.AbstractReadExecutor
 
handler - Variable in enum org.apache.cassandra.utils.MBeanWrapper.OnException
 
handlerAdded(ChannelHandlerContext) - Method in class org.apache.cassandra.net.AbstractMessageHandler
 
handlerAdded(ChannelHandlerContext) - Method in class org.apache.cassandra.net.FrameDecoder
 
handlerAdded(ChannelHandlerContext) - Method in class org.apache.cassandra.streaming.async.StreamingInboundHandler
 
handlers - Variable in class org.apache.cassandra.net.InboundConnectionSettings
 
handleStatusRequest(InetAddressAndPort, StatusRequest) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
handleStatusResponse(InetAddressAndPort, StatusResponse) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
handleStreamEvent(StreamEvent) - Method in class org.apache.cassandra.dht.StreamStateStore
When StreamSession completes, make all keyspaces/ranges in session available to be served.
handleStreamEvent(StreamEvent) - Method in class org.apache.cassandra.io.sstable.SSTableLoader
 
handleStreamEvent(StreamEvent) - Method in class org.apache.cassandra.repair.LocalSyncTask
 
handleStreamEvent(StreamEvent) - Method in class org.apache.cassandra.repair.StreamingRepairTask
 
handleStreamEvent(StreamEvent) - Method in class org.apache.cassandra.streaming.management.StreamEventJMXNotifier
 
handleStreamEvent(StreamEvent) - Method in interface org.apache.cassandra.streaming.StreamEventHandler
Callback for various streaming events.
handleUnrecoverableError(CommitLogReadHandler.CommitLogReadException) - Method in interface org.apache.cassandra.db.commitlog.CommitLogReadHandler
In instances where we cannot recover from a specific error and don't care what the reader thinks
handleUnrecoverableError(CommitLogReadHandler.CommitLogReadException) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
The logic for whether or not we throw on an error is identical for the replayer between recoverable or non.
hardlink(Descriptor, Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
has(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
has(String) - Method in class org.apache.cassandra.schema.Indexes
Answer true if contains an index with the specified name.
has(UUID) - Method in class org.apache.cassandra.schema.Indexes
Answer true if contains an index with the specified id.
hasAccurateMinMax() - Method in class org.apache.cassandra.io.sstable.format.Version
 
hasActiveSessions() - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
hasAllPKColumnsRestrictedByEqualities() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks that all the primary key columns (partition key and clustering columns) are restricted by an equality relation ('=' or 'IN').
hasAtleast(int, int) - Method in class org.apache.cassandra.locator.Replicas.ReplicaCount
 
hasAvailableDiskSpace(long, long) - Method in class org.apache.cassandra.db.Directories
 
hasBallot(UUID) - Method in class org.apache.cassandra.service.paxos.Commit
 
hasBound(Bound) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
 
hasBound(Bound) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
 
hasBound(Bound) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
 
hasBound(Bound) - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
Checks if the specified bound is set or not.
hasBound(Bound) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQRestriction
 
hasBound(Bound) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.SliceRestriction
 
hasChanges() - Method in class org.apache.cassandra.io.sstable.SSTableHeaderFix
Whether SSTableHeaderFix.execute() found mismatches.
hasClustering() - Method in class org.apache.cassandra.db.aggregation.GroupingState
Checks if the state contains a Clustering for the last row that has been processed.
hasClusteringColumnsRestrictions() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the query has some restrictions on the clustering columns.
hasColumnFamilyStore(TableId) - Method in class org.apache.cassandra.db.Keyspace
 
hasColumnSpecifications() - Method in class org.apache.cassandra.cql3.QueryOptions
Tells whether or not this QueryOptions contains the column specifications for the bound variables.
hasCombinedIndex - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
 
hasCommitLogIntervals() - Method in class org.apache.cassandra.io.sstable.format.Version
 
hasCommitLogLowerBound() - Method in class org.apache.cassandra.io.sstable.format.Version
 
hasComplex() - Method in class org.apache.cassandra.db.Columns
Whether this objects contains complex columns.
hasComplex() - Method in class org.apache.cassandra.db.rows.BTreeRow
 
hasComplex() - Method in interface org.apache.cassandra.db.rows.Row
Whether the row stores any (non-RT) data for any complex column.
hasComplexDeletion() - Method in class org.apache.cassandra.db.rows.BTreeRow
 
hasComplexDeletion() - Method in interface org.apache.cassandra.db.rows.Row
Whether the row stores any (non-live) complex deletion for any complex column.
hasConditions() - Method in interface org.apache.cassandra.cql3.CQLStatement
Whether or not this CQL Statement has LWT conditions
hasConditions() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
hasConditions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
hasContains() - Method in interface org.apache.cassandra.cql3.restrictions.Restrictions
Checks if any of the underlying restrictions is a CONTAINS / CONTAINS KEY restriction.
hasContains() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQRestriction
 
hasContains() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.SliceRestriction
 
hasControlChannel() - Method in class org.apache.cassandra.streaming.async.NettyStreamingMessageSender
 
hasCrossNodeTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
hasDataForPendingRepair(UUID) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
hasDataForSession(UUID) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
hasDayPrecision() - Method in class org.apache.cassandra.cql3.Duration
Checks if that duration has a day precision (nothing bellow the day level).
hasDeletion(int) - Method in class org.apache.cassandra.db.rows.BTreeRow
 
hasDeletion(int) - Method in interface org.apache.cassandra.db.rows.Row
Whether the row has any deletion info (row deletion, cell tombstone, expired cell or complex deletion).
hasDifferenceBetween(InetAddressAndPort, InetAddressAndPort, Range<Token>) - Method in class org.apache.cassandra.repair.asymmetric.DifferenceHolder
 
hasDifferencesFor(InetAddressAndPort, Range<Token>) - Method in class org.apache.cassandra.repair.asymmetric.HostDifferences
Does this instance have differences for range with node2?
hasEmptyCompactValue() - Method in class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
 
hasEnoughLiveData(CachedPartition, int, boolean, boolean) - Method in class org.apache.cassandra.db.filter.DataLimits
 
hasError() - Method in class org.apache.cassandra.io.sstable.SSTableHeaderFix
Whether SSTableHeaderFix.execute() encountered an error.
hasExpressionOnClusteringOrRegularColumns() - Method in class org.apache.cassandra.db.filter.RowFilter
Checks if some of the expressions apply to clustering or regular columns.
hasExtendedFlags(Row) - Static method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
hasFailedSession() - Method in class org.apache.cassandra.streaming.StreamState
 
hash - Variable in class org.apache.cassandra.utils.MerkleTree.RowHash
 
hash(byte[]) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
hash(Range<Token>) - Method in class org.apache.cassandra.utils.MerkleTrees
 
hash2_64(ByteBuffer, int, int, long) - Static method in class org.apache.cassandra.utils.MurmurHash
 
hash32(ByteBuffer, int, int, int) - Static method in class org.apache.cassandra.utils.MurmurHash
 
hash3_x64_128(ByteBuffer, int, int, long, long[]) - Static method in class org.apache.cassandra.utils.MurmurHash
 
hashCode() - Method in class org.apache.cassandra.auth.AuthenticatedUser
 
hashCode() - Method in class org.apache.cassandra.auth.CassandraPrincipal
Return a hash code for this CassPrincipal.
hashCode() - Method in class org.apache.cassandra.auth.DataResource
 
hashCode() - Method in class org.apache.cassandra.auth.FunctionResource
 
hashCode() - Method in class org.apache.cassandra.auth.JMXResource
 
hashCode() - Method in class org.apache.cassandra.auth.PermissionDetails
 
hashCode() - Method in class org.apache.cassandra.auth.Role
 
hashCode() - Method in class org.apache.cassandra.auth.RoleResource
 
hashCode() - Method in class org.apache.cassandra.cache.CounterCacheKey
 
hashCode() - Method in class org.apache.cassandra.cache.KeyCacheKey
 
hashCode() - Method in class org.apache.cassandra.cache.RowCacheKey
 
hashCode() - Method in class org.apache.cassandra.cache.RowCacheSentinel
 
hashCode() - Method in class org.apache.cassandra.config.EncryptionOptions
The method is being mainly used to cache SslContexts therefore, we only consider fields that would make a difference when the TrustStore or KeyStore files are updated
hashCode() - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
hashCode() - Method in class org.apache.cassandra.cql3.ColumnSpecification
 
hashCode() - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
 
hashCode() - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
 
hashCode() - Method in class org.apache.cassandra.cql3.CQL3Type.Tuple
 
hashCode() - Method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
 
hashCode() - Method in class org.apache.cassandra.cql3.Duration
 
hashCode() - Method in class org.apache.cassandra.cql3.FieldIdentifier
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.FunctionName
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.types.DataType.CollectionType
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.types.DataType.CustomType
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.types.DataType.NativeType
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.types.Duration
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.types.LocalDate
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.types.TupleType
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.types.TupleValue
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.types.UDTValue
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.types.UserType.Field
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.types.UserType
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
hashCode() - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
hashCode() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
hashCode() - Method in class org.apache.cassandra.cql3.QualifiedName
 
hashCode() - Method in class org.apache.cassandra.cql3.restrictions.CustomIndexExpression
 
hashCode() - Method in class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
 
hashCode() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
hashCode() - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
hashCode() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
hashCode() - Method in class org.apache.cassandra.cql3.Term.Raw
 
hashCode() - Method in class org.apache.cassandra.cql3.TokenRelation
 
hashCode() - Method in class org.apache.cassandra.cql3.WhereClause
 
hashCode() - Method in class org.apache.cassandra.db.AbstractOnHeapClusteringPrefix
 
hashCode() - Method in class org.apache.cassandra.db.ClockAndCount
 
hashCode() - Method in class org.apache.cassandra.db.ClusteringComparator
 
hashCode(ClusteringPrefix<V>) - Static method in interface org.apache.cassandra.db.ClusteringPrefix
 
hashCode() - Method in class org.apache.cassandra.db.Columns
 
hashCode() - Method in class org.apache.cassandra.db.commitlog.CommitLogPosition
 
hashCode() - Method in class org.apache.cassandra.db.commitlog.IntervalSet
 
hashCode() - Method in class org.apache.cassandra.db.DecoratedKey
 
hashCode() - Method in class org.apache.cassandra.db.DeletionTime
 
hashCode() - Method in class org.apache.cassandra.db.Directories.DataDirectories
 
hashCode() - Method in class org.apache.cassandra.db.Directories.DataDirectory
 
hashCode() - Method in class org.apache.cassandra.db.Directories.SnapshotSizeDetails
 
hashCode() - Method in class org.apache.cassandra.db.DiskBoundaries
 
hashCode() - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
 
hashCode() - Method in class org.apache.cassandra.db.filter.ColumnFilter.SelectionColumnFilter
 
hashCode() - Method in class org.apache.cassandra.db.filter.ColumnFilter.WildCardColumnFilter
 
hashCode() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
 
hashCode() - Method in class org.apache.cassandra.db.LivenessInfo
 
hashCode() - Method in class org.apache.cassandra.db.marshal.TupleType
 
hashCode() - Method in class org.apache.cassandra.db.marshal.UserType
 
hashCode(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
 
hashCode() - Method in class org.apache.cassandra.db.MutableDeletionInfo
 
hashCode() - Method in class org.apache.cassandra.db.NativeClustering
 
hashCode() - Method in class org.apache.cassandra.db.RangeTombstone
 
hashCode() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
hashCode() - Method in class org.apache.cassandra.db.RegularAndStaticColumns
 
hashCode() - Method in class org.apache.cassandra.db.rows.AbstractCell
 
hashCode() - Method in class org.apache.cassandra.db.rows.AbstractRow
 
hashCode() - Method in class org.apache.cassandra.db.rows.CellPath
 
hashCode() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
hashCode() - Method in class org.apache.cassandra.db.rows.EncodingStats
 
hashCode() - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
hashCode() - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
hashCode() - Method in class org.apache.cassandra.db.rows.Row.Deletion
 
hashCode() - Method in class org.apache.cassandra.db.SerializationHeader.Component
 
hashCode() - Method in class org.apache.cassandra.db.Slice
 
hashCode() - Method in class org.apache.cassandra.db.streaming.CassandraIncomingFile
 
hashCode() - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
 
hashCode() - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader
 
hashCode() - Method in class org.apache.cassandra.db.streaming.ComponentManifest
 
hashCode() - Method in class org.apache.cassandra.db.streaming.CompressionInfo
 
hashCode() - Method in class org.apache.cassandra.dht.AbstractBounds
 
hashCode() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
hashCode() - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
 
hashCode() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
hashCode() - Method in class org.apache.cassandra.dht.RangeStreamer.FetchReplica
 
hashCode() - Method in class org.apache.cassandra.dht.Splitter.WeightedRange
 
hashCode() - Method in class org.apache.cassandra.dht.Token.KeyBound
 
hashCode() - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
 
hashCode() - Method in class org.apache.cassandra.index.sasi.plan.Expression.Bound
 
hashCode() - Method in class org.apache.cassandra.index.sasi.plan.Expression
 
hashCode() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
 
hashCode() - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
 
hashCode - Variable in class org.apache.cassandra.io.sstable.Component
 
hashCode() - Method in class org.apache.cassandra.io.sstable.Component
 
hashCode() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
hashCode() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
hashCode() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.IndexesBounds
 
hashCode() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.PartitionPositionBounds
 
hashCode() - Method in class org.apache.cassandra.io.sstable.format.Version
 
hashCode() - Method in class org.apache.cassandra.io.sstable.format.VersionAndType
 
hashCode() - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
 
hashCode() - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
hashCode() - Method in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
 
hashCode() - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
It's not clear whether AbstractReplicaCollection should implement the order sensitive hashCode of List or the order oblivious equals of Set.
hashCode() - Method in class org.apache.cassandra.locator.InetAddressAndPort
 
hashCode() - Method in class org.apache.cassandra.locator.Replica
 
hashCode() - Method in interface org.apache.cassandra.locator.ReplicaCollection
 
hashCode() - Method in class org.apache.cassandra.locator.ReplicaMultimap
 
hashCode() - Method in class org.apache.cassandra.locator.ReplicationFactor
 
hashCode() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
 
hashCode() - Method in class org.apache.cassandra.repair.CommonRange
 
hashCode() - Method in class org.apache.cassandra.repair.consistent.ConsistentSession
 
hashCode() - Method in class org.apache.cassandra.repair.consistent.LocalSession
 
hashCode() - Method in class org.apache.cassandra.repair.consistent.RepairedState.Section
 
hashCode() - Method in class org.apache.cassandra.repair.messages.CleanupMessage
 
hashCode() - Method in class org.apache.cassandra.repair.messages.FailSession
 
hashCode() - Method in class org.apache.cassandra.repair.messages.FinalizeCommit
 
hashCode() - Method in class org.apache.cassandra.repair.messages.FinalizePromise
 
hashCode() - Method in class org.apache.cassandra.repair.messages.FinalizePropose
 
hashCode() - Method in class org.apache.cassandra.repair.messages.PrepareConsistentRequest
 
hashCode() - Method in class org.apache.cassandra.repair.messages.PrepareConsistentResponse
 
hashCode() - Method in class org.apache.cassandra.repair.messages.PrepareMessage
 
hashCode() - Method in class org.apache.cassandra.repair.messages.SnapshotMessage
 
hashCode() - Method in class org.apache.cassandra.repair.messages.StatusRequest
 
hashCode() - Method in class org.apache.cassandra.repair.messages.StatusResponse
 
hashCode() - Method in class org.apache.cassandra.repair.messages.SyncRequest
 
hashCode() - Method in class org.apache.cassandra.repair.messages.SyncResponse
 
hashCode() - Method in class org.apache.cassandra.repair.messages.ValidationRequest
 
hashCode() - Method in class org.apache.cassandra.repair.messages.ValidationResponse
 
hashCode() - Method in class org.apache.cassandra.repair.RepairJobDesc
 
hashCode() - Method in class org.apache.cassandra.repair.SyncNodePair
 
hashCode() - Method in class org.apache.cassandra.schema.CachingParams
 
hashCode() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
hashCode() - Method in class org.apache.cassandra.schema.CompactionParams
 
hashCode() - Method in class org.apache.cassandra.schema.CompressionParams
 
hashCode() - Method in class org.apache.cassandra.schema.DroppedColumn
 
hashCode() - Method in class org.apache.cassandra.schema.Functions
 
hashCode() - Method in class org.apache.cassandra.schema.Indexes
 
hashCode() - Method in class org.apache.cassandra.schema.IndexMetadata
 
hashCode() - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
hashCode() - Method in class org.apache.cassandra.schema.KeyspaceParams
 
hashCode() - Method in class org.apache.cassandra.schema.Keyspaces
 
hashCode() - Method in class org.apache.cassandra.schema.ReplicationParams
 
hashCode() - Method in class org.apache.cassandra.schema.TableId
 
hashCode() - Method in class org.apache.cassandra.schema.TableMetadata
 
hashCode() - Method in class org.apache.cassandra.schema.TableParams
 
hashCode() - Method in class org.apache.cassandra.schema.Tables
 
hashCode() - Method in class org.apache.cassandra.schema.TriggerMetadata
 
hashCode() - Method in class org.apache.cassandra.schema.Triggers
 
hashCode() - Method in class org.apache.cassandra.schema.Types
 
hashCode() - Method in class org.apache.cassandra.schema.ViewMetadata
 
hashCode() - Method in class org.apache.cassandra.schema.Views
 
hashCode() - Method in class org.apache.cassandra.service.pager.PagingState
 
hashCode() - Method in class org.apache.cassandra.service.pager.PagingState.RowMark
 
hashCode() - Method in class org.apache.cassandra.service.paxos.Commit
 
hashCode() - Method in class org.apache.cassandra.service.reads.AlwaysSpeculativeRetryPolicy
 
hashCode() - Method in class org.apache.cassandra.service.reads.FixedSpeculativeRetryPolicy
 
hashCode() - Method in class org.apache.cassandra.service.reads.HybridSpeculativeRetryPolicy
 
hashCode() - Method in class org.apache.cassandra.service.reads.NeverSpeculativeRetryPolicy
 
hashCode() - Method in class org.apache.cassandra.service.reads.PercentileSpeculativeRetryPolicy
 
hashCode() - Method in class org.apache.cassandra.service.reads.repair.RepairedDataTracker
 
hashCode() - Method in class org.apache.cassandra.streaming.messages.IncomingStreamMessage
 
hashCode() - Method in class org.apache.cassandra.streaming.messages.StreamMessageHeader
 
hashCode() - Method in class org.apache.cassandra.streaming.ProgressInfo
 
hashCode() - Method in class org.apache.cassandra.streaming.SessionSummary
 
hashCode() - Method in class org.apache.cassandra.streaming.StreamResultFuture
 
hashCode() - Method in class org.apache.cassandra.streaming.StreamSummary
 
hashCode() - Method in class org.apache.cassandra.tools.JMXTool.Attribute
 
hashCode() - Method in class org.apache.cassandra.tools.JMXTool.Info
 
hashCode() - Method in class org.apache.cassandra.tools.JMXTool.Operation
 
hashCode() - Method in class org.apache.cassandra.tools.JMXTool.Parameter
 
hashCode() - Method in class org.apache.cassandra.transport.Event.SchemaChange
 
hashCode() - Method in class org.apache.cassandra.transport.Event.StatusChange
 
hashCode() - Method in class org.apache.cassandra.transport.Event.TopologyChange
 
hashCode(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
 
hashCode() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
hashCode() - Method in class org.apache.cassandra.utils.CassandraVersion
 
hashCode() - Method in class org.apache.cassandra.utils.CounterId
 
hashCode() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
hashCode() - Method in class org.apache.cassandra.utils.IntegerInterval
 
hashCode() - Method in class org.apache.cassandra.utils.IntegerInterval.Set
 
hashCode() - Method in class org.apache.cassandra.utils.Interval
 
hashCode() - Method in class org.apache.cassandra.utils.IntervalTree
 
hashCode() - Method in class org.apache.cassandra.utils.MD5Digest
 
hashCode() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
hashCode() - Method in class org.apache.cassandra.utils.Pair
 
hashCode() - Method in class org.apache.cassandra.utils.RMIServerSocketFactoryImpl
 
hashCode() - Method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram
 
hashCount - Variable in class org.apache.cassandra.utils.BloomFilter
 
hasIfExistCondition() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
hasIfNotExistCondition() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
hasIN() - Method in interface org.apache.cassandra.cql3.restrictions.Restrictions
Checks if any of the underlying restriction is an IN.
hasIN() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
hasIndex(String) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
hasIndexes() - Method in class org.apache.cassandra.index.SecondaryIndexManager
 
hasInvalidDeletions() - Method in class org.apache.cassandra.db.rows.AbstractCell
 
hasInvalidDeletions() - Method in class org.apache.cassandra.db.rows.AbstractRow
 
hasInvalidDeletions() - Method in class org.apache.cassandra.db.rows.BTreeRow
 
hasInvalidDeletions() - Method in class org.apache.cassandra.db.rows.ColumnData
Validates the deletions (ttl and local deletion time) if any.
hasInvalidDeletions() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
hasInvalidDeletions() - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
hasInvalidDeletions() - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
hasInvalidDeletions() - Method in interface org.apache.cassandra.db.rows.Unfiltered
Do a quick validation of the deletions of the unfiltered (if any)
hasIsTransient() - Method in class org.apache.cassandra.io.sstable.format.Version
 
hasJoined() - Method in class org.apache.cassandra.service.StorageService
 
hasKeyspace() - Method in class org.apache.cassandra.cql3.functions.FunctionName
 
hasKeyspace() - Method in class org.apache.cassandra.cql3.QualifiedName
Checks if the keyspace is specified.
hasKeyspace() - Method in class org.apache.cassandra.cql3.UTName
 
hasLargeAddressSpace() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
hasLegacyCounterShards - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
hasLegacyCounterShards - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
hasLegacyShards(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.context.CounterContext
Detects whether or not the context has any legacy (local or remote) shards in it.
hasLegacyShards(Cell<V>) - Static method in class org.apache.cassandra.db.rows.CounterCells
 
hasListeners() - Method in class org.apache.cassandra.cql3.QueryEvents
 
hasLiveData(int, boolean) - Method in class org.apache.cassandra.db.rows.AbstractRow
 
hasLiveData(int, boolean) - Method in interface org.apache.cassandra.db.rows.Row
Whether the row has some live information (i.e.
hasLocalAccess() - Method in class org.apache.cassandra.auth.AuthenticatedUser
Verify that there is not DC level restriction on this user accessing this node.
hasLower() - Method in class org.apache.cassandra.index.sasi.plan.Expression
 
hasLowerBound() - Method in class org.apache.cassandra.db.Slices
Whether the slices has a lower bound, that is whether it's first slice start is Slice.BOTTOM.
hasMajorVersion3Nodes() - Method in class org.apache.cassandra.gms.Gossiper
Returns false only if the information about the version of each node in the cluster is available and ALL the nodes are on 4.0+ (regardless of the patch version).
hasMarkedPartials - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
hasMarkedPartials() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
hasMarkedPartials() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
 
hasMaxCompressedLength() - Method in class org.apache.cassandra.io.sstable.format.Version
 
hasMetadataChecksum() - Method in class org.apache.cassandra.io.sstable.format.Version
 
hasMillisecondPrecision() - Method in class org.apache.cassandra.cql3.Duration
Checks if that duration has a millisecond precision (nothing bellow the millisecond level).
hasMisplacedSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
hasMisplacedSSTables() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Check SSTables whether or not they are misplaced.
hasMissingElements - Variable in class org.apache.cassandra.db.MultiCBuilder
true if some empty collection have been added.
hasMissingElements() - Method in class org.apache.cassandra.db.MultiCBuilder
Checks if some empty list of values have been added
hasMoreSlices() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
Checks if there are more slice to process.
hasMoreSlices() - Method in class org.apache.cassandra.db.columniterator.SSTableIterator
 
hasMoreSlices() - Method in class org.apache.cassandra.db.columniterator.SSTableReversedIterator
 
hasName() - Method in class org.apache.cassandra.cql3.RoleName
 
hasNext() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
hasNext() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
 
hasNext() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
 
hasNext() - Method in class org.apache.cassandra.db.Memtable.MemtableUnfilteredPartitionIterator
 
hasNext() - Method in class org.apache.cassandra.db.partitions.SingletonUnfilteredPartitionIterator
 
hasNext() - Method in class org.apache.cassandra.db.repair.CassandraValidationIterator
 
hasNext() - Method in class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
 
hasNext() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader.StreamDeserializer
 
hasNext() - Method in class org.apache.cassandra.db.transform.BasePartitions
 
hasNext() - Method in class org.apache.cassandra.db.transform.BaseRows
 
hasNext() - Method in class org.apache.cassandra.db.UnfilteredDeserializer
Whether or not there is more atom to read.
hasNext() - Method in class org.apache.cassandra.index.sasi.analyzer.DelimiterAnalyzer
 
hasNext() - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingAnalyzer
 
hasNext() - Method in class org.apache.cassandra.index.sasi.analyzer.NoOpAnalyzer
 
hasNext() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
 
hasNext() - Method in class org.apache.cassandra.index.sasi.utils.AbstractIterator
 
hasNext() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
 
hasNext() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
hasNext() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
hasNext() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
hasNext() - Method in class org.apache.cassandra.service.pager.AggregationQueryPager.GroupByPartitionIterator
 
hasNext() - Method in class org.apache.cassandra.utils.AbstractIterator
 
hasNext() - Method in class org.apache.cassandra.utils.btree.FullBTreeSearchIterator
 
hasNext() - Method in class org.apache.cassandra.utils.btree.LeafBTreeSearchIterator
 
hasNext() - Method in interface org.apache.cassandra.utils.IndexedSearchIterator
 
hasNextInternal() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
 
hasNonPrimaryKeyRestrictions() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the restrictions contain any non-primary key restrictions
hasOldBfFormat() - Method in class org.apache.cassandra.io.sstable.format.Version
The old bloomfilter format serializes the data as BIG_ENDIAN long's, the new one uses the same format as in memory (serializes as bytes).
hasOnlyEqualityRestrictions() - Method in interface org.apache.cassandra.cql3.restrictions.Restrictions
Checks if all of the underlying restrictions are EQ or IN restrictions.
hasOnlyEqualityRestrictions() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
hasOption(KeyspaceParams.Option) - Method in class org.apache.cassandra.cql3.statements.schema.KeyspaceAttributes
 
hasOption(TableParams.Option) - Method in class org.apache.cassandra.cql3.statements.schema.TableAttributes
 
hasOriginatingHostId() - Method in class org.apache.cassandra.io.sstable.format.Version
 
hasParent() - Method in class org.apache.cassandra.auth.DataResource
 
hasParent() - Method in class org.apache.cassandra.auth.FunctionResource
 
hasParent() - Method in interface org.apache.cassandra.auth.IResource
Indicates whether or not this resource has a parent in the hierarchy.
hasParent() - Method in class org.apache.cassandra.auth.JMXResource
 
hasParent() - Method in class org.apache.cassandra.auth.RoleResource
 
hasPartitionKeyRestrictions() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
hasPending() - Method in class org.apache.cassandra.net.OutboundConnection
 
hasPendingRepair() - Method in class org.apache.cassandra.io.sstable.format.Version
 
hasPosition() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
hasPosition() - Method in interface org.apache.cassandra.io.util.DataOutputPlus
If the implementation supports providing a position, this method returns true, otherwise false.
hasPosition() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
hasPrivilege(File, Directories.FileAction) - Static method in enum org.apache.cassandra.db.Directories.FileAction
 
hasProperty(String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
hasRanges() - Method in interface org.apache.cassandra.db.DeletionInfo
 
hasRanges() - Method in class org.apache.cassandra.db.MutableDeletionInfo
 
hasReferenceTo(Function) - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
hasRegularColumns() - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
hasRegularColumnsRestrictions() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if one of the restrictions applies to a regular column.
hasRemaining() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
hasRemaining() - Method in class org.apache.cassandra.db.MultiCBuilder
Checks if some elements can still be added to the clusterings.
hasRemaining() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
hasRemaining() - Method in class org.apache.cassandra.net.ShareableBytes
 
hasRoom() - Method in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
 
hasRows() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
hasSamePrimaryKeyColumnsAsBaseTable() - Method in class org.apache.cassandra.db.view.View
 
hasSameSettings(AbstractReplicationStrategy) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
hasSameSettings(AbstractReplicationStrategy) - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
hasScope() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Returns true if the Metric has a scope, false otherwise.
hasSimple() - Method in class org.apache.cassandra.db.Columns
Whether this objects contains simple columns.
hasSkippedReplicas - Variable in class org.apache.cassandra.repair.CommonRange
 
hasSlice() - Method in interface org.apache.cassandra.cql3.restrictions.Restrictions
Checks if any of the underlying restrictions is a slice.
hasSlice() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
hasSlice() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.SliceRestriction
 
hasSlices() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
hasSSTable(SSTableReader) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
hasSSTable(SSTableReader) - Method in class org.apache.cassandra.index.sasi.conf.DataTracker
 
hasStatic() - Method in class org.apache.cassandra.db.SerializationHeader
 
hasStaticColumns() - Method in class org.apache.cassandra.schema.TableMetadata
 
hasSubscribers(Class<E>) - Method in class org.apache.cassandra.diag.DiagnosticEventService
Indicates if any Consumer has been registered for the specified class of events.
hasSubscribers(Class<E>, T) - Method in class org.apache.cassandra.diag.DiagnosticEventService
Indicates if any Consumer has been registered for the specified class of events.
hasSuperuserStatus(RoleResource) - Static method in class org.apache.cassandra.auth.Roles
Returns true if the supplied role or any other role granted to it (directly or indirectly) has superuser status.
hasSupportingIndex(IndexRegistry) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
 
hasSupportingIndex(IndexRegistry) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
Check if the restriction is on indexed columns.
hasSupportingIndex(IndexRegistry) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
 
hasSupportingIndex(IndexRegistry) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
hasTable(String) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
hasTransientReplicas() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
hasTransientReplicas() - Method in class org.apache.cassandra.locator.ReplicationFactor
 
hasTransientResponse() - Method in class org.apache.cassandra.service.reads.DigestResolver
 
hasUnrestrictedPartitionKeyComponents(TableMetadata) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
hasUpper() - Method in class org.apache.cassandra.index.sasi.plan.Expression
 
hasUpperBound() - Method in class org.apache.cassandra.db.Slices
Whether the slices has an upper bound, that is whether it's last slice end is Slice.TOP.
hasView(String) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
hasViews() - Method in class org.apache.cassandra.db.view.TableViews
 
hasWaiters() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
 
header - Variable in class org.apache.cassandra.db.rows.SerializationHelper
 
header - Variable in class org.apache.cassandra.db.streaming.CassandraStreamReader
 
header - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
header - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
header - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
header - Variable in class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
 
header - Variable in class org.apache.cassandra.net.Message
 
header - Variable in class org.apache.cassandra.streaming.messages.IncomingStreamMessage
 
header - Variable in class org.apache.cassandra.streaming.messages.OutgoingStreamMessage
 
header - Variable in class org.apache.cassandra.transport.Envelope
 
HEADER_AND_TRAILER_LENGTH - Static variable in class org.apache.cassandra.net.FrameEncoderCrc
 
HEADER_AND_TRAILER_LENGTH - Static variable in class org.apache.cassandra.net.FrameEncoderLZ4
 
headerLength - Variable in class org.apache.cassandra.db.ColumnIndex
 
headerLength - Variable in class org.apache.cassandra.db.context.CounterContext.ContextState
 
headerLength(V, ValueAccessor<V>) - Static method in class org.apache.cassandra.db.context.CounterContext
 
headMap(K) - Method in class org.apache.cassandra.index.sasi.utils.trie.PatriciaTrie
 
headSet(V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
 
headSet(V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
headSet(V, boolean) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
headSet(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
HEAP_SIZE - Static variable in class org.apache.cassandra.db.rows.EncodingStats
 
HeapAllocator - Class in org.apache.cassandra.utils.memory
 
HeapPool - Class in org.apache.cassandra.utils.memory
 
HeapPool(long, float, MemtableCleaner) - Constructor for class org.apache.cassandra.utils.memory.HeapPool
 
HeapUtils - Class in org.apache.cassandra.utils
Utility to log heap histogram.
HeartBeatState - Class in org.apache.cassandra.gms
HeartBeat State associated with any given endpoint.
HeartBeatState(HeartBeatState) - Constructor for class org.apache.cassandra.gms.HeartBeatState
 
HeartBeatState(int, int) - Constructor for class org.apache.cassandra.gms.HeartBeatState
 
HELP_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
helper - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
helper - Variable in class org.apache.cassandra.db.UnfilteredDeserializer
 
helper - Variable in class org.apache.cassandra.io.sstable.SSTableSimpleIterator
 
hex(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
 
Hex - Class in org.apache.cassandra.utils
 
Hex() - Constructor for class org.apache.cassandra.utils.Hex
 
hexToBytes(String) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
hexToBytes(String) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
hexToBytes(String) - Static method in class org.apache.cassandra.utils.Hex
 
HIBERNATE - Static variable in class org.apache.cassandra.gms.VersionedValue
 
hibernate(boolean) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
higher(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
 
higher(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
 
higher(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
higher(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
higherIndex(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
 
Hint - Class in org.apache.cassandra.hints
Encapsulates the hinted mutation, its creation time, and the gc grace seconds param for each table involved.
hinted_handoff_disabled_datacenters - Variable in class org.apache.cassandra.config.Config
 
hinted_handoff_enabled - Variable in class org.apache.cassandra.config.Config
 
hinted_handoff_throttle_in_kb - Variable in class org.apache.cassandra.config.Config
 
hintedHandoffDisabledDCs() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
hintedHandoffEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
HintedHandoffMetrics - Class in org.apache.cassandra.metrics
Metrics for HintsService.
HintedHandoffMetrics() - Constructor for class org.apache.cassandra.metrics.HintedHandoffMetrics
 
HintedHandoffMetrics.DifferencingCounter - Class in org.apache.cassandra.metrics
 
HintMessage - Class in org.apache.cassandra.hints
The message we use to dispatch and forward hints.
HintMessage.Serializer - Class in org.apache.cassandra.hints
 
hints_compression - Variable in class org.apache.cassandra.config.Config
 
hints_directory - Variable in class org.apache.cassandra.config.Config
 
hints_flush_period_in_ms - Variable in class org.apache.cassandra.config.Config
 
hintsFailed - Static variable in class org.apache.cassandra.metrics.HintsServiceMetrics
 
HintsService - Class in org.apache.cassandra.hints
A singleton-ish wrapper over various hints components: - a catalog of all hints stores - a single-threaded write executor - a multi-threaded dispatch executor - the buffer pool for writing hints into The front-end for everything hints related.
HintsServiceMBean - Interface in org.apache.cassandra.hints
 
HintsServiceMetrics - Class in org.apache.cassandra.metrics
Metrics for HintsService.
HintsServiceMetrics() - Constructor for class org.apache.cassandra.metrics.HintsServiceMetrics
 
hintsSucceeded - Static variable in class org.apache.cassandra.metrics.HintsServiceMetrics
 
hintsTimedOut - Static variable in class org.apache.cassandra.metrics.HintsServiceMetrics
 
HintVerbHandler - Class in org.apache.cassandra.hints
Verb handler used both for hint dispatch and streaming.
HintVerbHandler() - Constructor for class org.apache.cassandra.hints.HintVerbHandler
 
histogram(CassandraMetricsRegistry.MetricName, boolean) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
histogram(CassandraMetricsRegistry.MetricName, CassandraMetricsRegistry.MetricName, boolean) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
HistogramBuilder - Class in org.apache.cassandra.utils
Simple class for constructing an EsimtatedHistogram from a set of predetermined values
HistogramBuilder() - Constructor for class org.apache.cassandra.utils.HistogramBuilder
 
HistogramBuilder(long[]) - Constructor for class org.apache.cassandra.utils.HistogramBuilder
 
HistogramDataConsumer<T extends java.lang.Exception> - Interface in org.apache.cassandra.utils.streamhist
This interface exists to avoid boxing primitive ints to Integers (otherwise BiConsumer<Integer, Integer> would have been sufficient).
HistogramSerializer() - Constructor for class org.apache.cassandra.utils.streamhist.TombstoneHistogram.HistogramSerializer
 
hitRate - Variable in class org.apache.cassandra.metrics.CacheMetrics
all time cache hit rate
hits - Variable in class org.apache.cassandra.metrics.BufferPoolMetrics
Total number of hits
hits - Variable in class org.apache.cassandra.metrics.CacheMetrics
Total number of cache hits
Holder() - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo.Holder
 
holder() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
holder() - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
 
holder - Variable in class org.apache.cassandra.db.partitions.ImmutableBTreePartition
 
holder() - Method in class org.apache.cassandra.db.partitions.ImmutableBTreePartition
 
holder() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
 
HOLDER_UNSHARED_HEAP_SIZE - Static variable in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
host - Variable in class org.apache.cassandra.service.TokenRange.EndpointDetails
 
host - Variable in class org.apache.cassandra.tools.AbstractJmxClient
 
host - Variable in class org.apache.cassandra.transport.SimpleClient
 
HostDifferences - Class in org.apache.cassandra.repair.asymmetric
Tracks the differences for a single host
HostDifferences() - Constructor for class org.apache.cassandra.repair.asymmetric.HostDifferences
 
hostId(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
hosts() - Method in class org.apache.cassandra.repair.asymmetric.HostDifferences
 
hosts - Variable in class org.apache.cassandra.tools.LoaderOptions
 
HOSTS_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
HostStat - Class in org.apache.cassandra.tools.nodetool
 
HostStat(String, InetAddress, boolean, Float) - Constructor for class org.apache.cassandra.tools.nodetool.HostStat
 
HostStatWithPort - Class in org.apache.cassandra.tools.nodetool
 
HostStatWithPort(String, InetAddressAndPort, boolean, Float) - Constructor for class org.apache.cassandra.tools.nodetool.HostStatWithPort
 
hotfix - Variable in class org.apache.cassandra.utils.CassandraVersion
 
hotKeyIterator(int) - Method in class org.apache.cassandra.cache.CaffeineCache
 
hotKeyIterator(int) - Method in interface org.apache.cassandra.cache.ICache
 
hotKeyIterator(int) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
hotKeyIterator(int) - Method in class org.apache.cassandra.cache.SerializingCache
 
hsProxy - Variable in class org.apache.cassandra.tools.NodeProbe
 
humanReadable - Variable in class org.apache.cassandra.tools.nodetool.stats.TableStatsHolder
 
HybridSpeculativeRetryPolicy - Class in org.apache.cassandra.service.reads
 
HybridSpeculativeRetryPolicy.Function - Enum in org.apache.cassandra.service.reads
 

I

IAuditLogger - Interface in org.apache.cassandra.audit
 
IAuthenticator - Interface in org.apache.cassandra.auth
 
IAuthenticator.SaslNegotiator - Interface in org.apache.cassandra.auth
Performs the actual SASL negotiation for a single authentication attempt.
IAuthorizer - Interface in org.apache.cassandra.auth
Primary Cassandra authorization interface.
IBitSet - Interface in org.apache.cassandra.utils.obs
 
ICache<K,V> - Interface in org.apache.cassandra.cache
This is similar to the Map interface, but requires maintaining a given capacity and does not require put or remove to return values, which lets SerializingCache be more efficient by avoiding deserialize except on get.
ICompressor - Interface in org.apache.cassandra.io.compress
 
ICompressor.Uses - Enum in org.apache.cassandra.io.compress
Ways that a particular instance of ICompressor should be used internally in Cassandra.
id - Variable in class org.apache.cassandra.batchlog.Batch
 
id - Variable in class org.apache.cassandra.concurrent.NamedThreadFactory
 
ID - Static variable in class org.apache.cassandra.cql3.statements.schema.TableAttributes
 
id - Variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
id - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
ID - Static variable in class org.apache.cassandra.db.compaction.CompactionInfo
 
id - Variable in exception org.apache.cassandra.exceptions.PreparedQueryNotFoundException
 
id - Variable in exception org.apache.cassandra.exceptions.UnknownTableException
 
id() - Method in class org.apache.cassandra.net.AbstractMessageHandler
 
id - Variable in enum org.apache.cassandra.net.ConnectionType
 
id() - Method in class org.apache.cassandra.net.InboundMessageHandler
 
id - Variable in class org.apache.cassandra.net.Message.Header
 
id() - Method in class org.apache.cassandra.net.Message
id of the request/message.
id - Variable in enum org.apache.cassandra.net.Verb
 
id - Variable in class org.apache.cassandra.schema.IndexMetadata
 
id(TableId) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
id - Variable in class org.apache.cassandra.schema.TableMetadata
 
id - Variable in class org.apache.cassandra.schema.TableMetadataRef
 
id - Variable in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
 
id() - Method in class org.apache.cassandra.transport.CQLMessageHandler
 
id - Variable in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
 
ideal_consistency_level - Variable in class org.apache.cassandra.config.Config
Maintain statistics on whether writes achieve the ideal consistency level before expiring and becoming hints
idealCLWriteLatency - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Ideal CL write latency metrics
IdentityCollection(Set<RefCounted.Tidy>) - Constructor for class org.apache.cassandra.utils.concurrent.Ref.IdentityCollection
 
idx - Variable in enum org.apache.cassandra.cql3.statements.Bound
 
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 datacenter 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.
IF_EXISTS_CONDITION - Static variable in interface org.apache.cassandra.cql3.conditions.Conditions
IF EXISTS condition
IF_NOT_EXISTS_CONDITION - Static variable in interface org.apache.cassandra.cql3.conditions.Conditions
IF NOT EXISTS condition
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.
ifile - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
ifile - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
ifile - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
ifile - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
ifile(FileHandle) - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
IFilter - Interface in org.apache.cassandra.utils
 
IFilter.FilterKey - Interface in org.apache.cassandra.utils
 
IGNORE_HOSTS - Static variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
IGNORE_NODES_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
IGNORE_UNREPLICATED_KS - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
IGNORED_ENDPOINTS_PROP - Static variable in class org.apache.cassandra.schema.MigrationCoordinator
 
IGNORED_VERSIONS_PROP - Static variable in class org.apache.cassandra.schema.MigrationCoordinator
 
ignoreOverlaps() - Method in class org.apache.cassandra.db.compaction.CompactionController
Is overlapped sstables ignored Control whether or not we are taking into account overlapping sstables when looking for fully expired sstables.
ignoreOverlaps() - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionController
 
ignoreOverlaps - Variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
ignores - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
ignores - Variable in class org.apache.cassandra.tools.LoaderOptions
 
ignoreStopTerms(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
 
ignoreUnreplicatedKeyspaces() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
IInternodeAuthenticator - Interface in org.apache.cassandra.auth
 
ILifecycleTransaction - Interface in org.apache.cassandra.db.lifecycle
 
IMeasurableMemory - Interface in org.apache.cassandra.cache
 
IMergeIterator<In,Out> - Interface in org.apache.cassandra.utils
 
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
immediate(T) - Static method in class org.apache.cassandra.net.AsyncOneResponse
 
ImmediateExecutor - Class in org.apache.cassandra.concurrent
 
ImmutableBTreePartition - Class in org.apache.cassandra.db.partitions
 
ImmutableBTreePartition(TableMetadata, DecoratedKey, RegularAndStaticColumns, Row, Object[], DeletionInfo, EncodingStats) - Constructor for class org.apache.cassandra.db.partitions.ImmutableBTreePartition
 
ImmutableBTreePartition(TableMetadata, DecoratedKey, AbstractBTreePartition.Holder) - Constructor for class org.apache.cassandra.db.partitions.ImmutableBTreePartition
 
Import - Class in org.apache.cassandra.tools.nodetool
 
Import() - Constructor for class org.apache.cassandra.tools.nodetool.Import
 
importNewSSTables(Set<String>, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
#Load new sstables from the given directory
importNewSSTables(Set<String>, boolean, boolean, boolean, boolean, boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
importNewSSTables(Set<String>, boolean, boolean, boolean, boolean, boolean, boolean) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Deprecated.
importNewSSTables(Set<String>, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Load new sstables from the given directory
importNewSSTables(String, String, Set<String>, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Method in class org.apache.cassandra.tools.NodeProbe
 
IMutation - Interface in org.apache.cassandra.db
 
in - Variable in class org.apache.cassandra.db.UnfilteredDeserializer
 
in - Variable in class org.apache.cassandra.io.sstable.SSTableSimpleIterator
 
InboundConnectionInitiator - Class in org.apache.cassandra.net
 
InboundConnectionInitiator() - Constructor for class org.apache.cassandra.net.InboundConnectionInitiator
 
InboundConnectionSettings - Class in org.apache.cassandra.net
 
InboundConnectionSettings() - Constructor for class org.apache.cassandra.net.InboundConnectionSettings
 
InboundMessageHandler - Class in org.apache.cassandra.net
Implementation of AbstractMessageHandler for processing internode messages from peers.
InboundMessageHandlers - Class in org.apache.cassandra.net
An aggregation of InboundMessageHandlers for all connections from a peer.
InboundMessageHandlers(InetAddressAndPort, InetAddressAndPort, int, long, InboundMessageHandlers.GlobalResourceLimits, InboundMessageHandlers.GlobalMetricCallbacks, InboundMessageHandlers.MessageConsumer) - Constructor for class org.apache.cassandra.net.InboundMessageHandlers
 
InboundMessageHandlers(InetAddressAndPort, InetAddressAndPort, int, long, InboundMessageHandlers.GlobalResourceLimits, InboundMessageHandlers.GlobalMetricCallbacks, InboundMessageHandlers.MessageConsumer, InboundMessageHandlers.HandlerProvider) - Constructor for class org.apache.cassandra.net.InboundMessageHandlers
 
InboundMessageHandlers.GlobalMetricCallbacks - Interface in org.apache.cassandra.net
 
InboundMessageHandlers.MessageConsumer - Interface in org.apache.cassandra.net
 
InboundSink - Class in org.apache.cassandra.net
A message sink that all inbound messages go through.
inboundSink - Variable in class org.apache.cassandra.net.MessagingService
 
inclEnd() - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder.RangeTombstoneBuilder
Sets the end of this range as inclusive.
inclStart() - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder.RangeTombstoneBuilder
Sets the start of this range as inclusive.
includeAllColumns - Variable in class org.apache.cassandra.schema.ViewMetadata
 
includeBackups(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
included_categories - Variable in class org.apache.cassandra.audit.AuditLogOptions
 
included_keyspaces - Variable in class org.apache.cassandra.audit.AuditLogOptions
 
included_users - Variable in class org.apache.cassandra.audit.AuditLogOptions
 
includeRow(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
includes(RegularAndStaticColumns) - Method in class org.apache.cassandra.db.RegularAndStaticColumns
 
includes(ColumnMetadata) - Method in class org.apache.cassandra.db.rows.DeserializationHelper
 
includes(Cell<?>, LivenessInfo) - Method in class org.apache.cassandra.db.rows.DeserializationHelper
 
includes(CellPath) - Method in class org.apache.cassandra.db.rows.DeserializationHelper
 
includes(ClusteringComparator, ClusteringPrefix<?>) - Method in class org.apache.cassandra.db.Slice
Returns whether a given clustering or bound is included in this slice.
includes(Clustering<?>) - Method in interface org.apache.cassandra.db.Slices.InOrderTester
 
includes(ColumnIdentifier) - Method in class org.apache.cassandra.schema.ViewMetadata
 
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
 
inclusive - Variable in class org.apache.cassandra.index.sasi.plan.Expression.Bound
 
inclusiveClose(boolean, V[]) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor.ObjectFactory
 
inclusiveClose(boolean, V[], ValueAccessor<V>, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
inclusiveClose(boolean, ClusteringPrefix<V>, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
inclusiveCloseExclusiveOpen(boolean, V[]) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor.ObjectFactory
 
inclusiveCloseExclusiveOpen(boolean, V[], ValueAccessor<V>, DeletionTime, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
inclusiveCloseExclusiveOpen(boolean, ClusteringPrefix<V>, DeletionTime, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
inclusiveEndOf(ByteBuffer...) - Static method in class org.apache.cassandra.db.BufferClusteringBound
 
inclusiveEndOf(ClusteringPrefix<?>) - Static method in interface org.apache.cassandra.db.ClusteringBound
 
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
 
inclusiveOpen(boolean, V[]) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor.ObjectFactory
 
inclusiveOpen(boolean, V[], ValueAccessor<V>, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
inclusiveOpen(boolean, ClusteringPrefix<V>, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
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
 
inclusiveStartOf(ByteBuffer...) - Static method in class org.apache.cassandra.db.BufferClusteringBound
 
inclusiveStartOf(ClusteringPrefix<?>) - Static method in interface org.apache.cassandra.db.ClusteringBound
 
incomingBytes - Variable in class org.apache.cassandra.metrics.StreamingMetrics
 
incomingProcessTime - Variable in class org.apache.cassandra.metrics.StreamingMetrics
 
IncomingRepairStreamTracker - Class in org.apache.cassandra.repair.asymmetric
Tracks incoming streams for a single host
IncomingRepairStreamTracker(DifferenceHolder) - Constructor for class org.apache.cassandra.repair.asymmetric.IncomingRepairStreamTracker
 
IncomingStream - Interface in org.apache.cassandra.streaming
The counterpart of OutgoingStream on the receiving side.
IncomingStreamMessage - Class in org.apache.cassandra.streaming.messages
 
IncomingStreamMessage(IncomingStream, StreamMessageHeader) - Constructor for class org.apache.cassandra.streaming.messages.IncomingStreamMessage
 
incompatible() - Method in class org.apache.cassandra.net.OutboundConnectionInitiator.Result
 
IncompatibleSchemaException - Exception in org.apache.cassandra.exceptions
 
IncompatibleSchemaException(String) - Constructor for exception org.apache.cassandra.exceptions.IncompatibleSchemaException
 
inconclusiveDigests - Variable in class org.apache.cassandra.service.reads.repair.RepairedDataTracker
 
incrCounter(Enum<?>, long) - Method in class org.apache.cassandra.hadoop.ReporterWrapper
 
incrCounter(String, String, long) - Method in class org.apache.cassandra.hadoop.ReporterWrapper
 
incrCreatedHints(InetAddressAndPort) - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
 
increaseIndent() - Method in class org.apache.cassandra.cql3.CqlBuilder
 
increaseSlightly() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
increaseSlightly() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
increaseSlightly() - Method in class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
 
increaseSlightly() - Method in class org.apache.cassandra.dht.Token
Returns a token that is slightly greater than this.
increment(Replica) - Method in class org.apache.cassandra.locator.Replicas.ReplicaCount
 
incrementAborted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
incremental_backups - Variable in class org.apache.cassandra.config.Config
 
INCREMENTAL_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
incrementalSessionCompleted(UUID) - Method in class org.apache.cassandra.db.repair.CassandraTableRepairManager
 
incrementalSessionCompleted(UUID) - Method in interface org.apache.cassandra.repair.TableRepairManager
Called when the given incremental session has completed.
incrementAndGetGeneration() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
incrementCompactionsReduced() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
incrementCounter(Counter, long) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
Increment the counter.
incrementReadCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Increment the total read count and read rate for this SSTable.
incrementSstablesDropppedFromCompactions(long) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
incrementToken() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
 
incrPastWindow(InetAddressAndPort) - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
 
INDEFINITE - Static variable in class org.apache.cassandra.service.StorageService
 
index(String, String) - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
Creates a DescribeStatement for DESCRIBE INDEX.
index(int) - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
 
Index - Interface in org.apache.cassandra.index
Consisting of a top level Index interface and two sub-interfaces which handle read and write operations, Searcher and Indexer respectively, this defines a secondary index implementation.
index - Variable in class org.apache.cassandra.index.internal.CassandraIndexSearcher
 
index(DecoratedKey, Row) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
index - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskBlock.SearchResult
 
Index(ColumnIndex) - Constructor for class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
 
index(DecoratedKey, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.memory.IndexMemtable
 
index - Variable in class org.apache.cassandra.index.sasi.plan.Expression
 
Index.CollatedViewIndexBuildingSupport - Class in org.apache.cassandra.index
Default implementation of IndexBuildingSupport which uses a ReducingKeyIterator to obtain a collated view of the data in the SSTables.
Index.IndexBuildingSupport - Interface in org.apache.cassandra.index
Provider of SecondaryIndexBuilder instances.
Index.Indexer - Interface in org.apache.cassandra.index
Listener for processing events emitted during a single partition update.
Index.LoadType - Enum in org.apache.cassandra.index
Supported loads.
Index.Searcher - Interface in org.apache.cassandra.index
Performs the actual index lookup during execution of a ReadCommand.
INDEX_BUILDER_SUPPORT - Static variable in interface org.apache.cassandra.index.Index
Singleton instance of CollatedViewIndexBuildingSupport, which may be used by any Index implementation.
INDEX_NOT_FOUND - Static variable in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
 
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
 
IndexAttributes - Class in org.apache.cassandra.cql3.statements.schema
 
IndexAttributes() - Constructor for class org.apache.cassandra.cql3.statements.schema.IndexAttributes
 
indexCfs - Variable in class org.apache.cassandra.index.internal.CassandraIndex
 
indexCfsMetadata(TableMetadata, IndexMetadata) - Static method in class org.apache.cassandra.index.internal.CassandraIndex
Construct the TableMetadata for an index table, the clustering columns in the index table vary dependent on the kind of the indexed value.
indexClustering - Variable in class org.apache.cassandra.index.internal.IndexEntry
 
indexComparator(boolean) - Method in class org.apache.cassandra.db.ClusteringComparator
 
indexedColumn - Variable in class org.apache.cassandra.index.internal.CassandraIndex
 
indexedEntryClustering - Variable in class org.apache.cassandra.index.internal.IndexEntry
 
indexedKey - Variable in class org.apache.cassandra.index.internal.IndexEntry
 
IndexedSearchIterator<K,V> - Interface in org.apache.cassandra.utils
 
IndexedTerm - Class in org.apache.cassandra.index.sasi.sa
 
IndexedTerm(ByteBuffer, boolean) - Constructor for class org.apache.cassandra.index.sasi.sa.IndexedTerm
 
IndexEntry - Class in org.apache.cassandra.index.internal
Entries in indexes on non-compact tables (tables with composite comparators) can be encapsulated as IndexedEntry instances.
IndexEntry(DecoratedKey, Clustering<?>, long, ByteBuffer, Clustering<?>) - Constructor for class org.apache.cassandra.index.internal.IndexEntry
 
indexerFor(DecoratedKey, RegularAndStaticColumns, int, WriteContext, IndexTransaction.Type) - Method in interface org.apache.cassandra.index.Index
Creates an new Indexer object for updates to a given partition.
indexerFor(DecoratedKey, RegularAndStaticColumns, int, WriteContext, IndexTransaction.Type) - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
indexerFor(DecoratedKey, RegularAndStaticColumns, int, WriteContext, IndexTransaction.Type) - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
indexes - Variable in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
 
indexes(RegularAndStaticColumns) - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
Indexes - Class in org.apache.cassandra.schema
For backwards compatibility, in the first instance an IndexMetadata must have TargetType.COLUMN and its Set of target columns must contain only a single ColumnIdentifier.
INDEXES - Static variable in class org.apache.cassandra.schema.SchemaKeyspace
 
indexes(Indexes) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
indexes - Variable in class org.apache.cassandra.schema.TableMetadata
 
Indexes.Builder - Class in org.apache.cassandra.schema
 
IndexesBounds(int, int) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader.IndexesBounds
 
indexFile - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
indexFilePath - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
 
indexFor(ClusteringPrefix<?>, int) - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
 
indexId - Variable in exception org.apache.cassandra.exceptions.UnknownIndexException
 
IndexInfo - Class in org.apache.cassandra.io.sstable
IndexInfo is embedded in the indexed version of RowIndexEntry.
IndexInfo(ClusteringPrefix<?>, ClusteringPrefix<?>, long, long, DeletionTime) - Constructor for class org.apache.cassandra.io.sstable.IndexInfo
 
IndexInfo.Serializer - Class in org.apache.cassandra.io.sstable
 
indexInfoSerializedSize() - Method in class org.apache.cassandra.db.ColumnIndex
 
indexInfoSerializer() - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
 
indexInfoSerializer() - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
 
indexLength - Variable in class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
 
indexManager - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
IndexMemtable - Class in org.apache.cassandra.index.sasi.memory
 
IndexMemtable(ColumnIndex) - Constructor for class org.apache.cassandra.index.sasi.memory.IndexMemtable
 
indexMetadata() - Method in class org.apache.cassandra.db.ReadCommand
Index (metadata) chosen for this query.
IndexMetadata - Class in org.apache.cassandra.schema
An immutable representation of secondary index metadata.
IndexMetadata.Kind - Enum in org.apache.cassandra.schema
 
IndexMetadata.Serializer - Class in org.apache.cassandra.schema
 
IndexMode - Class in org.apache.cassandra.index.sasi.conf
 
indexName - Variable in class org.apache.cassandra.cache.CacheKey
 
indexName() - Method in class org.apache.cassandra.schema.TableMetadata
 
indexNames - Variable in class org.apache.cassandra.tools.nodetool.stats.CompactionHistoryHolder
 
IndexNotAvailableException - Exception in org.apache.cassandra.index
Thrown if a secondary index is not currently available.
IndexNotAvailableException(Index) - Constructor for exception org.apache.cassandra.index.IndexNotAvailableException
Creates a new IndexNotAvailableException for the specified index.
indexOf(Object) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
 
indexOf(Object) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
indexOf(Object) - Method in class org.apache.cassandra.utils.btree.BTreeSet
The index of the item within the list, or its insertion point otherwise.
indexOfCurrent() - Method in class org.apache.cassandra.utils.btree.FullBTreeSearchIterator
 
indexOfCurrent() - Method in class org.apache.cassandra.utils.btree.LeafBTreeSearchIterator
 
indexOfCurrent() - Method in interface org.apache.cassandra.utils.IndexedSearchIterator
 
indexOnHeap() - Method in class org.apache.cassandra.db.RowIndexEntry
 
indexPartition(DecoratedKey, Set<Index>, int) - Method in class org.apache.cassandra.index.SecondaryIndexManager
When building an index against existing data in sstables, add the given partition to the index
indexPath - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
indexReadController() - Method in class org.apache.cassandra.db.ReadExecutionController
 
IndexRegistry - Interface in org.apache.cassandra.index
The collection of all Index instances for a base table.
IndexRestrictions - Class in org.apache.cassandra.cql3.restrictions
 
IndexRestrictions() - Constructor for class org.apache.cassandra.cql3.restrictions.IndexRestrictions
 
indexSamples() - Method in class org.apache.cassandra.db.ColumnIndex
 
indexSize - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
indexSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Lists
 
IndexState(AbstractSSTableIterator.Reader, ClusteringComparator, RowIndexEntry, boolean, FileHandle) - Constructor for class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
 
indexSummary - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
IndexSummary - Class in org.apache.cassandra.io.sstable
 
IndexSummary(IPartitioner, Memory, int, Memory, long, int, int, int) - Constructor for class org.apache.cassandra.io.sstable.IndexSummary
 
IndexSummary.IndexSummarySerializer - Class in org.apache.cassandra.io.sstable
 
IndexSummaryBuilder - Class in org.apache.cassandra.io.sstable
 
IndexSummaryBuilder(long, int, int) - Constructor for class org.apache.cassandra.io.sstable.IndexSummaryBuilder
Build an index summary builder.
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.KeyspaceMetrics
Off heap memory used by index summary
indexSummaryOffHeapMemoryUsed - Variable in class org.apache.cassandra.metrics.TableMetrics
Off heap memory used by index summary
indexSummaryOffHeapMemoryUsed - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
indexSummaryOffHeapUsed - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
IndexSummaryRedistribution - Class in org.apache.cassandra.io.sstable
 
IndexSummaryRedistribution(Map<TableId, LifecycleTransaction>, long, long) - Constructor for class org.apache.cassandra.io.sstable.IndexSummaryRedistribution
 
IndexSummarySerializer() - Constructor for class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
 
indexTableName(IndexMetadata) - Method in class org.apache.cassandra.schema.TableMetadata
Generate a table name for an index corresponding to the given column.
IndexTarget - Class in org.apache.cassandra.cql3.statements.schema
 
IndexTarget(ColumnIdentifier, IndexTarget.Type) - Constructor for class org.apache.cassandra.cql3.statements.schema.IndexTarget
 
IndexTarget.Raw - Class in org.apache.cassandra.cql3.statements.schema
 
IndexTarget.Type - Enum in org.apache.cassandra.cql3.statements.schema
 
IndexTransaction - Interface in org.apache.cassandra.index.transactions
Base interface for the handling of index updates.
IndexTransaction.Type - Enum in org.apache.cassandra.index.transactions
Used to differentiate between type of index transaction when obtaining a handler from Index implementations.
indexValue - Variable in class org.apache.cassandra.index.internal.IndexEntry
 
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).
inet() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the INET type.
inet() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type inet.
INET_ADDRESS - Static variable in class org.apache.cassandra.transport.ClientStat
 
InetAddressAndPort - Class in org.apache.cassandra.locator
A class to replace the usage of InetAddress to identify hosts in the cluster.
InetAddressAndPort.FwdFrmSerializer - Class in org.apache.cassandra.locator
Serializer for handling FWD_FRM message parameters.
InetAddressAndPort.Serializer - Class in org.apache.cassandra.locator
As of version 4.0 the endpoint description includes a port number as an unsigned short This serializer matches the 3.0 CompactEndpointSerializationHelper, encoding the number of address bytes in a single byte before the address itself.
inetAddressAndPortSerializer - Static variable in class org.apache.cassandra.locator.InetAddressAndPort.Serializer
 
InetAddressSerializer - Class in org.apache.cassandra.serializers
 
InetAddressSerializer() - Constructor for class org.apache.cassandra.serializers.InetAddressSerializer
 
InetAddressType - Class in org.apache.cassandra.db.marshal
 
INetworkAuthorizer - Interface in org.apache.cassandra.auth
 
InfiniteLoopExecutor - Class in org.apache.cassandra.concurrent
 
InfiniteLoopExecutor(String, InfiniteLoopExecutor.InterruptibleRunnable) - Constructor for class org.apache.cassandra.concurrent.InfiniteLoopExecutor
 
InfiniteLoopExecutor.InterruptibleRunnable - Interface in org.apache.cassandra.concurrent
 
info - Variable in enum org.apache.cassandra.io.sstable.format.SSTableFormat.Type
 
info(Consumer<String>) - Method in class org.apache.cassandra.io.sstable.SSTableHeaderFix.Builder
 
info - Variable in class org.apache.cassandra.io.sstable.SSTableHeaderFix
 
Info() - Constructor for class org.apache.cassandra.tools.JMXTool.Info
 
Info(JMXTool.Attribute[], JMXTool.Operation[]) - Constructor for class org.apache.cassandra.tools.JMXTool.Info
 
Info - Class in org.apache.cassandra.tools.nodetool
 
Info() - Constructor for class org.apache.cassandra.tools.nodetool.Info
 
info(long, String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
info(String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
info(long, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
 
info(Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
 
init() - Method in class org.apache.cassandra.auth.AuthCache
Do setup for the cache and MBean.
init(String, String, int, LocalAwareExecutorService.MaximumPoolSizeListener) - Method in interface org.apache.cassandra.concurrent.Stage.ExecutorServiceInitialiser
 
init(Map<String, String>, AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
 
init(Map<String, String>, AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.DelimiterAnalyzer
 
init(Map<String, String>, AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingAnalyzer
 
init(NonTokenizingOptions, AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingAnalyzer
 
init(Map<String, String>, AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.NoOpAnalyzer
 
init(Map<String, String>, AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
 
init(StandardTokenizerOptions) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
 
init(StandardTokenizerOptions, AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
 
init(Set<SSTableReader>) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
Initialize this column index with specific set of SSTables.
init(String) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
Initialize the client.
init(Collection<Server>) - Method in class org.apache.cassandra.metrics.ClientMetrics
 
init() - Static method in class org.apache.cassandra.metrics.ReadRepairMetrics
 
init() - Static method in class org.apache.cassandra.metrics.RepairMetrics
 
init(String[]) - Method in class org.apache.cassandra.service.CassandraDaemon
Initialize the Cassandra Daemon based on the given Commons Daemon-specific arguments.
init(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamSession
Bind this session to report to specific StreamResultFuture and perform pre-streaming initialization.
init() - Method in class org.apache.cassandra.utils.MerkleTree
Initializes this tree by splitting it until hashdepth is reached, or until an additional level of splits would violate maxsize.
init() - Method in class org.apache.cassandra.utils.MerkleTrees
Init all MerkleTree's with an even tree distribution.
init(Range<Token>) - Method in class org.apache.cassandra.utils.MerkleTrees
Init a selected MerkleTree with an even tree distribution.
init(String) - Method in class org.apache.cassandra.utils.NativeSSTableLoaderClient
 
initCache(LoadingCache<K, V>) - Method in class org.apache.cassandra.auth.AuthCache
(Re-)initialise the underlying cache.
initCf(TableMetadataRef, boolean) - Method in class org.apache.cassandra.db.Keyspace
adds a cf to internal structures, ends up creating disk files).
initCfCustom(ColumnFamilyStore) - Method in class org.apache.cassandra.db.Keyspace
Registers a custom cf instance with this keyspace.
initcond - Variable in class org.apache.cassandra.cql3.functions.UDAggregate
 
initDatabaseDescriptor() - Static method in class org.apache.cassandra.tools.Util
This is used by standalone tools to force static initialization of DatabaseDescriptor, and fail if configuration is bad.
initHotReloading(EncryptionOptions.ServerEncryptionOptions, EncryptionOptions, boolean) - Static method in class org.apache.cassandra.security.SSLFactory
Determines whether to hot reload certificates and schedules a periodic task for it.
INITIAL_HOST_ADDRESS_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
initial_range_tombstone_list_allocation_size - Variable in class org.apache.cassandra.config.Config
The intial capacity for creating RangeTombstoneList.
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.NoopCompressor
 
initialCompressedBufferLength(int) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
 
initialCompressedBufferLength(int) - Method in class org.apache.cassandra.io.compress.ZstdCompressor
Get initial compressed buffer length
initialCondition() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
InitialConnectionHandler - Class in org.apache.cassandra.transport
Added to the Netty pipeline whenever a new Channel is initialized.
initialize() - Method in class org.apache.cassandra.audit.AuditLogManager
 
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.apache.cassandra.auth.CassandraLoginModule
Initialize this LoginModule.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
initialize() - Method in class org.apache.cassandra.streaming.async.NettyStreamingMessageSender
 
initialize() - Method in interface org.apache.cassandra.streaming.StreamingMessageSender
 
initializeChannel(EventLoopGroup, InetSocketAddress, Connection.Factory) - Method in class org.apache.cassandra.transport.PipelineConfigurator
 
initializeClientTransports() - Method in class org.apache.cassandra.service.CassandraDaemon
 
initialized() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
 
initialized() - Method in class org.apache.cassandra.utils.SigarLibrary
 
initializeDefaultPort(int) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
 
initializeFromMessage(Message.Header) - Method in class org.apache.cassandra.tracing.Tracing
Determines the tracing context from a message.
initializeIterator() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
 
initializeIterator() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
 
initializeNodeUnsafe(InetAddressAndPort, UUID, int) - Method in class org.apache.cassandra.gms.Gossiper
 
initializeNodeUnsafe(InetAddressAndPort, UUID, int, int) - Method in class org.apache.cassandra.gms.Gossiper
 
initializer(Connection.Factory) - Method in class org.apache.cassandra.transport.PipelineConfigurator
 
initializeThread() - Method in class org.apache.cassandra.security.SecurityThreadGroup
 
initializeThread() - Method in interface org.apache.cassandra.security.SecurityThreadGroup.ThreadInitializer
 
initializeUnreachableNodeUnsafe(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
Creates a new dead EndpointState that is empty.
InitialSSTableAddedNotification - Class in org.apache.cassandra.notifications
Fired when we load SSTables during the Cassandra initialization phase.
InitialSSTableAddedNotification(Iterable<SSTableReader>) - Constructor for class org.apache.cassandra.notifications.InitialSSTableAddedNotification
 
initiateMutation(Mutation, long, int, int, CommitLogReplayer) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer.MutationInitiator
 
initiateStreaming(EventLoop, OutboundConnectionSettings, int) - Static method in class org.apache.cassandra.net.OutboundConnectionInitiator
Initiate a connection with the requested messaging version.
initiator - Variable in class org.apache.cassandra.repair.messages.SyncRequest
 
initiator - Variable in class org.apache.cassandra.repair.Validator
 
initRolesCache(IRoleManager, BooleanSupplier) - Static method in class org.apache.cassandra.auth.Roles
 
initServer() - Method in class org.apache.cassandra.service.StorageService
 
initServer(int) - Method in class org.apache.cassandra.service.StorageService
 
initSigarLibrary - Static variable in class org.apache.cassandra.service.StartupChecks
 
injectApplicationState(InetAddressAndPort, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.Gossiper
 
injectControlMessageChannel(Channel) - Method in class org.apache.cassandra.streaming.async.NettyStreamingMessageSender
Used by follower to setup control message channel created by initiator
InMarker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Tuples.InMarker
 
INodeProbeFactory - Interface in org.apache.cassandra.tools
 
inOrderInclusionTester() - Method in class org.apache.cassandra.db.Columns
Returns a predicate to test whether columns are included in this Columns object, assuming that tes tested columns are passed to the predicate in sorted order.
inOrderTester(boolean) - Method in class org.apache.cassandra.db.Slices
An object that allows to test whether rows are selected by this Slices objects assuming those rows are tested in clustering order.
INotification - Interface in org.apache.cassandra.notifications
Created by IntelliJ IDEA.
INotificationConsumer - Interface in org.apache.cassandra.notifications
 
InOurDcTester - Class in org.apache.cassandra.locator
 
inProgressCommit - Variable in class org.apache.cassandra.service.paxos.PrepareResponse
 
input - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SyncSegment
the 'buffer' to replay commit log data from
inputBytes() - Method in class org.apache.cassandra.db.Digest
 
InputPosition - Interface in org.apache.cassandra.hints
Marker interface for file positions as provided by the various ChecksummedDataReader implementations.
inputReader - Variable in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
 
inputStream(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
InputTimeoutException() - Constructor for exception org.apache.cassandra.net.AsyncStreamingInputPlus.InputTimeoutException
 
inputVersion - Variable in class org.apache.cassandra.db.streaming.CassandraStreamReader
 
INRaw(int) - Constructor for class org.apache.cassandra.cql3.AbstractMarker.INRaw
 
INRaw(int) - Constructor for class org.apache.cassandra.cql3.Tuples.INRaw
 
INRestriction(List<ColumnMetadata>) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.INRestriction
 
INRestriction(ColumnMetadata) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.INRestriction
 
InRestrictionWithMarker(List<ColumnMetadata>, AbstractMarker) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithMarker
 
InRestrictionWithMarker(ColumnMetadata, AbstractMarker) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithMarker
 
InRestrictionWithValues(List<ColumnMetadata>, List<Term>) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithValues
 
InRestrictionWithValues(ColumnMetadata, List<Term>) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithValues
 
inSerializer - Variable in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
 
insert(T, long) - Method in class org.apache.cassandra.metrics.FrequencySampler
 
insert(T, long) - Method in class org.apache.cassandra.metrics.MaxSampler
 
insert(T, long) - Method in class org.apache.cassandra.metrics.Sampler
 
insertRow(Row) - Method in interface org.apache.cassandra.index.Index.Indexer
Notification that a new row was inserted into the Memtable holding the partition.
inspectCommitLogThrowable(Throwable) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
 
inspectJvmOptions - Static variable in class org.apache.cassandra.service.StartupChecks
 
inspectThrowable(Throwable) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
Certain Throwables and Exceptions represent "Die" conditions for the server.
inspectThrowable(Throwable, Consumer<Throwable>) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
 
install() - Static method in class org.apache.cassandra.security.ThreadAwareSecurityManager
 
instance - Static variable in class org.apache.cassandra.audit.AuditLogManager
 
instance - Static variable in class org.apache.cassandra.auth.AuthEvents
 
instance - Static variable in class org.apache.cassandra.batchlog.BatchlogManager
 
instance - Static variable in class org.apache.cassandra.batchlog.BatchRemoveVerbHandler
 
instance - Static variable in class org.apache.cassandra.batchlog.BatchStoreVerbHandler
 
instance - Static variable in class org.apache.cassandra.cache.ChunkCache
 
INSTANCE - Static variable in class org.apache.cassandra.concurrent.ImmediateExecutor
 
instance - Static variable in class org.apache.cassandra.cql3.QueryEvents
 
instance - Static variable in class org.apache.cassandra.cql3.QueryProcessor
 
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.CounterMutationVerbHandler
 
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.ByteArrayAccessor
 
instance - Static variable in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
instance - Static variable in class org.apache.cassandra.db.marshal.BytesType
 
instance - Static variable in class org.apache.cassandra.db.marshal.ByteType
 
instance - Static variable in class org.apache.cassandra.db.marshal.CounterColumnType
 
instance - Static variable in class org.apache.cassandra.db.marshal.DateType
Deprecated.
 
instance - Static variable in class org.apache.cassandra.db.marshal.DecimalType
 
instance - Static variable in class org.apache.cassandra.db.marshal.DoubleType
 
instance - Static variable in class org.apache.cassandra.db.marshal.DurationType
 
instance - Static variable in class org.apache.cassandra.db.marshal.EmptyType
 
instance - Static variable in class org.apache.cassandra.db.marshal.FloatType
 
instance - Static variable in class org.apache.cassandra.db.marshal.InetAddressType
 
instance - Static variable in class org.apache.cassandra.db.marshal.Int32Type
 
instance - Static variable in class org.apache.cassandra.db.marshal.IntegerType
 
instance - Static variable in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
instance - Static variable in class org.apache.cassandra.db.marshal.LongType
 
instance - Static variable in class org.apache.cassandra.db.marshal.ShortType
 
instance - Static variable in class org.apache.cassandra.db.marshal.SimpleDateType
 
instance - Static variable in class org.apache.cassandra.db.marshal.TimestampType
 
instance - Static variable in class org.apache.cassandra.db.marshal.TimeType
 
instance - Static variable in class org.apache.cassandra.db.marshal.TimeUUIDType
 
instance - Static variable in class org.apache.cassandra.db.marshal.UTF8Type
 
instance - Static variable in class org.apache.cassandra.db.marshal.UUIDType
 
instance - Static variable in class org.apache.cassandra.db.MutationVerbHandler
 
instance - Static variable in class org.apache.cassandra.db.ReadCommandVerbHandler
 
instance - Static variable in class org.apache.cassandra.db.ReadRepairVerbHandler
 
instance - Static variable in class org.apache.cassandra.db.SizeEstimatesRecorder
 
instance - Static variable in interface org.apache.cassandra.db.StorageHook
 
instance - Static variable in class org.apache.cassandra.db.TruncateVerbHandler
 
instance - Static variable in class org.apache.cassandra.db.virtual.SystemViewsKeyspace
 
instance - Static variable in class org.apache.cassandra.db.virtual.VirtualKeyspaceRegistry
 
instance - Static variable in class org.apache.cassandra.db.virtual.VirtualSchemaKeyspace
 
instance - Static variable in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
instance - Static variable in class org.apache.cassandra.dht.Murmur3Partitioner
 
instance - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
instance - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 
instance() - Static method in class org.apache.cassandra.diag.DiagnosticEventPersistence
 
instance() - Static method in class org.apache.cassandra.diag.DiagnosticEventService
 
instance - Static variable in class org.apache.cassandra.fql.FullQueryLogger
 
instance - Static variable in class org.apache.cassandra.gms.FailureDetector
 
instance - Static variable in class org.apache.cassandra.gms.GossipDigestAck2VerbHandler
 
instance - Static variable in class org.apache.cassandra.gms.GossipDigestAckVerbHandler
 
instance - Static variable in class org.apache.cassandra.gms.GossipDigestSynVerbHandler
 
instance - Static variable in class org.apache.cassandra.gms.Gossiper
 
instance - Static variable in class org.apache.cassandra.gms.GossipShutdownVerbHandler
 
instance - Static variable in class org.apache.cassandra.hints.HintsService
 
instance - Static variable in class org.apache.cassandra.hints.HintVerbHandler
 
instance - Static variable in class org.apache.cassandra.io.compress.DeflateCompressor
 
instance - Static variable in class org.apache.cassandra.io.compress.SnappyCompressor
 
instance - Static variable in class org.apache.cassandra.io.sstable.format.big.BigFormat
 
instance - Static variable in class org.apache.cassandra.io.sstable.IndexSummaryManager
 
instance - Static variable in class org.apache.cassandra.metrics.ClientMetrics
 
instance - Static variable in class org.apache.cassandra.net.FrameEncoderCrc
 
instance - Static variable in class org.apache.cassandra.net.GlobalBufferPoolAllocator
 
instance() - Static method in class org.apache.cassandra.net.MessagingService
 
instance - Static variable in class org.apache.cassandra.repair.RepairMessageVerbHandler
 
INSTANCE - Static variable in exception org.apache.cassandra.repair.SomeRepairFailedException
 
instance - Static variable in class org.apache.cassandra.repair.ValidationManager
 
instance - Static variable in class org.apache.cassandra.schema.MigrationCoordinator
 
instance - Static variable in class org.apache.cassandra.schema.MigrationManager
 
instance - Static variable in class org.apache.cassandra.schema.MigrationManager.MigrationsSerializer
 
instance - Static variable in class org.apache.cassandra.schema.Schema
 
instance - Static variable in class org.apache.cassandra.schema.SchemaPullVerbHandler
 
instance - Static variable in class org.apache.cassandra.schema.SchemaPushVerbHandler
 
instance - Static variable in class org.apache.cassandra.schema.SchemaVersionVerbHandler
 
instance - Static variable in class org.apache.cassandra.serializers.AsciiSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.BooleanSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.ByteSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.BytesSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.DecimalSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.DoubleSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.DurationSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.EmptySerializer
 
instance - Static variable in class org.apache.cassandra.serializers.FloatSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.InetAddressSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.Int32Serializer
 
instance - Static variable in class org.apache.cassandra.serializers.IntegerSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.LongSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.ShortSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.SimpleDateSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.TimeSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.TimestampSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.TimeUUIDSerializer
 
instance - Static variable in class org.apache.cassandra.serializers.UTF8Serializer
 
instance - Static variable in class org.apache.cassandra.serializers.UUIDSerializer
 
instance - Static variable in class org.apache.cassandra.service.ActiveRepairService
 
instance - Static variable in class org.apache.cassandra.service.CacheService
 
instance - Static variable in class org.apache.cassandra.service.ClientWarn
 
instance - Static variable in class org.apache.cassandra.service.EchoVerbHandler
 
instance - Static variable in class org.apache.cassandra.service.LoadBroadcaster
 
instance - Static variable in class org.apache.cassandra.service.paxos.CommitVerbHandler
 
instance - Static variable in class org.apache.cassandra.service.paxos.PrepareVerbHandler
 
instance - Static variable in class org.apache.cassandra.service.paxos.ProposeVerbHandler
 
instance - Static variable in class org.apache.cassandra.service.PendingRangeCalculatorService
 
INSTANCE - Static variable in class org.apache.cassandra.service.reads.AlwaysSpeculativeRetryPolicy
 
INSTANCE - Static variable in class org.apache.cassandra.service.reads.NeverSpeculativeRetryPolicy
 
instance - Static variable in class org.apache.cassandra.service.reads.repair.NoopReadRepair
 
instance - Static variable in class org.apache.cassandra.service.SnapshotVerbHandler
 
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.ReplicationDoneVerbHandler
 
instance - Static variable in interface org.apache.cassandra.streaming.StreamHook
 
instance - Static variable in class org.apache.cassandra.streaming.StreamManager
 
instance - Static variable in class org.apache.cassandra.tracing.Tracing
 
instance - Static variable in class org.apache.cassandra.transport.Compressor.LZ4Compressor
 
instance - Static variable in class org.apache.cassandra.transport.Compressor.SnappyCompressor
 
instance - Static variable in class org.apache.cassandra.transport.Envelope.Compressor
 
instance - Static variable in class org.apache.cassandra.transport.Envelope.Decompressor
 
instance - Static variable in class org.apache.cassandra.transport.Envelope.Encoder
 
instance - Static variable in class org.apache.cassandra.transport.messages.UnsupportedMessageCodec
 
instance - Static variable in class org.apache.cassandra.transport.PreV5Handlers.ExceptionHandler
 
instance - Static variable in class org.apache.cassandra.transport.PreV5Handlers.ProtocolDecoder
 
instance - Static variable in class org.apache.cassandra.transport.PreV5Handlers.ProtocolEncoder
 
instance - Static variable in class org.apache.cassandra.triggers.TriggerExecutor
 
instance - Static variable in class org.apache.cassandra.utils.DiagnosticSnapshotService
 
instance - Static variable in interface org.apache.cassandra.utils.MBeanWrapper
 
instance - Static variable in class org.apache.cassandra.utils.memory.HeapAllocator
 
instance - Static variable in class org.apache.cassandra.utils.SigarLibrary
 
instanceId - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
instanceOrConstruct(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
Constructs an instance of the given class, which must have a no-arg or default constructor.
instantiateRebufferer() - Method in class org.apache.cassandra.io.util.CompressedChunkReader
 
instantiateRebufferer() - Method in interface org.apache.cassandra.io.util.RebuffererFactory
 
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
 
INT_SIZE - Static variable in class org.apache.cassandra.db.TypeSizes
 
integer(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
 
IntegerInterval - Class in org.apache.cassandra.utils
Mutable integer interval class, thread-safe.
IntegerInterval(int, int) - Constructor for class org.apache.cassandra.utils.IntegerInterval
 
IntegerInterval(IntegerInterval) - Constructor for class org.apache.cassandra.utils.IntegerInterval
 
IntegerInterval.Set - Class in org.apache.cassandra.utils
A mutable set of closed integer intervals, stored in normalized form (i.e.
IntegerSerializer - Class in org.apache.cassandra.serializers
 
IntegerSerializer() - Constructor for class org.apache.cassandra.serializers.IntegerSerializer
 
IntegerType - Class in org.apache.cassandra.db.marshal
 
IntegralSA - Class in org.apache.cassandra.index.sasi.sa
 
IntegralSA(AbstractType<?>, OnDiskIndexBuilder.Mode) - Constructor for class org.apache.cassandra.index.sasi.sa.IntegralSA
 
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
 
INTER_DC_THROTTLE_MBITS - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
interDcThrottle - Variable in class org.apache.cassandra.tools.LoaderOptions
 
InteriorNode() - Constructor for class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
 
internalAddressAndPort(InetAddressAndPort) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
internalClose() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
Close the segment file.
internalClose() - Method in class org.apache.cassandra.db.commitlog.FileDirectSegment
 
internalClose() - Method in class org.apache.cassandra.db.commitlog.MemoryMappedSegment
 
internalDroppedLatency - Variable in class org.apache.cassandra.metrics.DroppedMessageMetrics
The dropped latency within node
internalIP(InetAddress) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
internalLatency - Variable in class org.apache.cassandra.metrics.MessagingMetrics
 
internalOpen(Descriptor, Set<Component>, TableMetadataRef, FileHandle, FileHandle, IndexSummary, IFilter, long, StatsMetadata, SSTableReader.OpenReason, SerializationHeader) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
Open a RowIndexedReader which already has its state initialized (by SSTableWriter).
internalQueryState() - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
internalReadForView(DecoratedKey, int) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
Returns a read command that can be used internally to query all the rows queried by this SELECT for a give key (used for materialized views).
internalResponse(Verb, T) - Static method in class org.apache.cassandra.net.Message
 
internode_application_receive_queue_capacity_in_bytes - Variable in class org.apache.cassandra.config.Config
 
internode_application_receive_queue_reserve_endpoint_capacity_in_bytes - Variable in class org.apache.cassandra.config.Config
 
internode_application_receive_queue_reserve_global_capacity_in_bytes - Variable in class org.apache.cassandra.config.Config
 
internode_application_send_queue_capacity_in_bytes - Variable in class org.apache.cassandra.config.Config
 
internode_application_send_queue_reserve_endpoint_capacity_in_bytes - Variable in class org.apache.cassandra.config.Config
 
internode_application_send_queue_reserve_global_capacity_in_bytes - Variable in class org.apache.cassandra.config.Config
 
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_max_message_size_in_bytes - Variable in class org.apache.cassandra.config.Config
 
internode_socket_receive_buffer_size_in_bytes - Variable in class org.apache.cassandra.config.Config
 
internode_socket_send_buffer_size_in_bytes - Variable in class org.apache.cassandra.config.Config
 
internode_streaming_tcp_user_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
internode_tcp_connect_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
internode_tcp_user_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
internodeCompression() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
InternodeInboundMetrics - Class in org.apache.cassandra.metrics
Metrics for internode connections.
InternodeInboundMetrics(InetAddressAndPort, InboundMessageHandlers) - Constructor for class org.apache.cassandra.metrics.InternodeInboundMetrics
Create metrics for given inbound message handlers.
InternodeInboundTable - Class in org.apache.cassandra.db.virtual
 
internodeLatencyRecorder(InetAddressAndPort) - Method in class org.apache.cassandra.metrics.MessagingMetrics
 
internodeLatencyRecorder(InetAddressAndPort) - Method in interface org.apache.cassandra.net.InboundMessageHandlers.GlobalMetricCallbacks
 
InternodeOutboundMetrics - Class in org.apache.cassandra.metrics
Metrics for internode connections.
InternodeOutboundMetrics(InetAddressAndPort, OutboundConnections) - Constructor for class org.apache.cassandra.metrics.InternodeOutboundMetrics
Create metrics for given connection pool.
InternodeOutboundTable - Class in org.apache.cassandra.db.virtual
 
interpret(InetAddressAndPort) - Method in class org.apache.cassandra.gms.FailureDetector
 
interpret(InetAddressAndPort) - 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.net.OutboundConnection
Close any currently open connection, forcing a reconnect if there are messages outstanding (or leaving it closed for now otherwise)
interruptCompactionFor(Iterable<TableMetadata>, Predicate<SSTableReader>, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
Try to stop all of the compactions for given ColumnFamilies.
interruptCompactionForCFs(Iterable<ColumnFamilyStore>, Predicate<SSTableReader>, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
interruptOutbound(InetAddressAndPort) - Method in class org.apache.cassandra.net.MessagingService
Closes any current open channel/connection to the endpoint, but does not cause any message loss, and we will try to re-establish connections immediately
intersectionWith(Range<T>) - Method in class org.apache.cassandra.dht.Range
 
intersects(ClusteringComparator, List<ByteBuffer>, List<ByteBuffer>) - Method in class org.apache.cassandra.db.Slice
Given the per-clustering column minimum and maximum value a sstable contains, whether or not this slice potentially intersects that sstable or not.
intersects(List<ByteBuffer>, List<ByteBuffer>) - Method in class org.apache.cassandra.db.Slices
Given the per-clustering column minimum and maximum value a sstable contains, whether or not this slices potentially intersects that sstable or not.
intersects(Iterable<Range<T>>) - Method in class org.apache.cassandra.dht.AbstractBounds
return true if @param range intersects any of the given @param ranges
intersects(Bounds<T>) - Method in class org.apache.cassandra.dht.Bounds
 
intersects(Range<T>) - Method in class org.apache.cassandra.dht.Range
 
intersects(AbstractBounds<T>) - Method in class org.apache.cassandra.dht.Range
 
intersects(Bounds<T>) - Method in class org.apache.cassandra.dht.Range
 
intersects(Iterable<Range<Token>>, Iterable<Range<Token>>) - Static method in class org.apache.cassandra.dht.Range
 
intersects(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
intersects(Iterable<Range<Token>>) - Method in class org.apache.cassandra.repair.consistent.ConsistentSession
 
intersectsOnRange(Replica) - Method in class org.apache.cassandra.locator.Replica
 
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.index.sasi.conf.view.RangeTermTree
 
intervalCount() - Method in interface org.apache.cassandra.index.sasi.conf.view.TermTree
 
intervalCount() - Method in class org.apache.cassandra.utils.IntervalTree
 
intervalInMillis - Static variable in class org.apache.cassandra.gms.Gossiper
 
IntervalLock - Class in org.apache.cassandra.utils.concurrent
This class extends ReentrantReadWriteLock to provide a write lock that can only be acquired at provided intervals.
IntervalLock(TimeSource) - Constructor for class org.apache.cassandra.utils.concurrent.IntervalLock
 
intervals() - Method in class org.apache.cassandra.utils.IntegerInterval.Set
 
IntervalSet<T extends java.lang.Comparable<T>> - Class in org.apache.cassandra.db.commitlog
An immutable set of closed intervals, stored in normalized form (i.e.
IntervalSet(T, T) - Constructor for class org.apache.cassandra.db.commitlog.IntervalSet
Construct new set containing the interval with the given start and end position.
IntervalSet.Builder<T extends java.lang.Comparable<T>> - Class in org.apache.cassandra.db.commitlog
Builder of interval sets, applying the necessary normalization while adding ranges.
IntervalTree<C extends java.lang.Comparable<? super C>,D,I extends Interval<C,D>> - Class in org.apache.cassandra.utils
 
IntervalTree(Collection<I>) - Constructor for class org.apache.cassandra.utils.IntervalTree
 
IntervalTree.Serializer<C extends java.lang.Comparable<? super C>,D,I extends Interval<C,D>> - Class in org.apache.cassandra.utils
 
inv_hash3_x64_128(long[]) - Static method in class org.apache.cassandra.utils.MurmurHash
 
INVALID_INDEX - Static variable in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
 
invalidate() - Method in class org.apache.cassandra.auth.AuthCache
Invalidate the entire cache.
invalidate(K) - Method in class org.apache.cassandra.auth.AuthCache
Invalidate a key
invalidate() - Method in interface org.apache.cassandra.auth.AuthCacheMBean
 
invalidate() - Method in class org.apache.cassandra.db.ColumnFamilyStore
call when dropping or renaming a CF.
invalidate(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
invalidate() - Method in class org.apache.cassandra.db.DiskBoundaries
 
invalidate() - Method in class org.apache.cassandra.db.DiskBoundaryManager
 
invalidate(Token) - Method in class org.apache.cassandra.utils.MerkleTrees
Invalidate the MerkleTree responsible for the given token.
invalidateAllIndexesBlocking() - Method in class org.apache.cassandra.index.SecondaryIndexManager
 
invalidateCachedPartition(RowCacheKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
invalidateCachedPartition(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
invalidateCachedRings() - Method in class org.apache.cassandra.locator.TokenMetadata
 
invalidateCounterCache(Collection<Bounds<Token>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
invalidateCounterCache() - Method in class org.apache.cassandra.service.CacheService
 
invalidateCounterCache() - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
invalidateCounterCache() - Method in class org.apache.cassandra.tools.NodeProbe
 
InvalidateCounterCache - Class in org.apache.cassandra.tools.nodetool
 
InvalidateCounterCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidateCounterCache
 
invalidateCounterCacheForCf(TableMetadata) - Method in class org.apache.cassandra.service.CacheService
 
invalidateCredentials(String) - Method in interface org.apache.cassandra.auth.PasswordAuthenticator.CredentialsCacheMBean
 
invalidateDiskBoundaries() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
invalidateFile(String) - Method in class org.apache.cassandra.cache.ChunkCache
 
invalidateKeyCache() - Method in class org.apache.cassandra.service.CacheService
 
invalidateKeyCache() - Method in interface org.apache.cassandra.service.CacheServiceMBean
invalidate the key cache; for use after invalidating row cache
invalidateKeyCache() - Method in class org.apache.cassandra.tools.NodeProbe
 
InvalidateKeyCache - Class in org.apache.cassandra.tools.nodetool
 
InvalidateKeyCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidateKeyCache
 
invalidateKeyCacheForCf(TableMetadata) - Method in class org.apache.cassandra.service.CacheService
 
invalidatePosition(FileHandle, long) - Method in class org.apache.cassandra.cache.ChunkCache
 
invalidateRowCache(Collection<Bounds<Token>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
invalidateRowCache() - Method in class org.apache.cassandra.service.CacheService
 
invalidateRowCache() - Method in interface org.apache.cassandra.service.CacheServiceMBean
invalidate the row cache; for use after bulk loading via BinaryMemtable
invalidateRowCache() - Method in class org.apache.cassandra.tools.NodeProbe
 
InvalidateRowCache - Class in org.apache.cassandra.tools.nodetool
 
InvalidateRowCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidateRowCache
 
invalidateRowCacheForCf(TableMetadata) - Method in class org.apache.cassandra.service.CacheService
 
invalidCrc - Variable in exception org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SegmentReadException
 
InvalidCrc(int, int) - Constructor for exception org.apache.cassandra.net.Crc.InvalidCrc
 
invalidRequest(String, Object...) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
Returns an InvalidRequestException with the specified message.
InvalidRequestException - Exception in org.apache.cassandra.exceptions
 
InvalidRequestException(String) - Constructor for exception org.apache.cassandra.exceptions.InvalidRequestException
 
InvalidRequestException(String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.InvalidRequestException
 
InvalidTypeException - Exception in org.apache.cassandra.cql3.functions.types.exceptions
Thrown when a TypeCodec is unable to perform the requested operation (serialization, deserialization, parsing or formatting) because the object or the byte buffer content being processed does not comply with the expected Java and/or CQL type.
InvalidTypeException(String) - Constructor for exception org.apache.cassandra.cql3.functions.types.exceptions.InvalidTypeException
 
InvalidTypeException(String, Throwable) - Constructor for exception org.apache.cassandra.cql3.functions.types.exceptions.InvalidTypeException
 
invalidVersionMessage(int) - Static method in enum org.apache.cassandra.transport.ProtocolVersion
 
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
 
invert() - Method in class org.apache.cassandra.db.ArrayClusteringBound
 
invert() - Method in class org.apache.cassandra.db.ArrayClusteringBoundary
 
invert() - Method in class org.apache.cassandra.db.BufferClusteringBound
 
invert() - Method in class org.apache.cassandra.db.BufferClusteringBoundary
 
invert() - Method in interface org.apache.cassandra.db.ClusteringBound
 
invert() - Method in interface org.apache.cassandra.db.ClusteringBoundary
 
invert() - Method in interface org.apache.cassandra.db.ClusteringBoundOrBoundary
Returns the inverse of the current bound.
invert() - Method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
Returns the inverse of the current kind.
invert() - Method in enum org.apache.cassandra.utils.btree.BTree.Dir
 
INVERTED_ORDER - Static variable in class org.apache.cassandra.utils.memory.MemoryUtil
 
invFmix(long) - Static method in class org.apache.cassandra.utils.MurmurHash
 
invoke(Object, Method, Object[]) - Method in class org.apache.cassandra.auth.jmx.AuthorizationProxy
 
invoke() - Method in interface org.apache.cassandra.service.BatchlogResponseHandler.BatchlogCleanupCallback
 
invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
invokeDiskFailurePolicy(boolean) - Method in class org.apache.cassandra.db.compaction.Verifier.Options.Builder
 
invokeDiskFailurePolicy - Variable in class org.apache.cassandra.db.compaction.Verifier.Options
 
invokeOnFailure() - Method in interface org.apache.cassandra.net.RequestCallback
 
invokeOnFailure() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
invokeOnFailure() - Method in class org.apache.cassandra.service.BatchlogResponseHandler
 
invokeOnFailure() - Method in class org.apache.cassandra.service.reads.ReadCallback
 
invokeOnFailure() - Method in class org.apache.cassandra.service.TruncateResponseHandler
 
invRotl64(long, int) - Static method in class org.apache.cassandra.utils.MurmurHash
 
invRShiftXor(long, int) - Static method in class org.apache.cassandra.utils.MurmurHash
 
invTailReverse(long) - Static method in class org.apache.cassandra.utils.MurmurHash
This gives a correct reversal of the tail byte flip which is needed if want a non mod16==0 byte hash inv or to target a hash for a given schema.
IPartitioner - Interface in org.apache.cassandra.dht
 
IPartitionerDependentSerializer<T> - Interface in org.apache.cassandra.dht
Versioned serializer where the serialization depends on partitioner.
ipOrDns() - Method in class org.apache.cassandra.tools.nodetool.HostStat
 
ipOrDns() - Method in class org.apache.cassandra.tools.nodetool.HostStatWithPort
 
ipOrDns(boolean) - Method in class org.apache.cassandra.tools.nodetool.HostStatWithPort
 
ipUsageReservoir() - Static method in class org.apache.cassandra.transport.ClientResourceLimits
This will recompute the ip usage histo on each query of the snapshot when requested instead of trying to keep a histogram up to date with each request
IResource - Interface in org.apache.cassandra.auth
The interface at the core of Cassandra authorization.
IRoleManager - Interface in org.apache.cassandra.auth
Responsible for managing roles (which also includes what used to be known as users), including creation, deletion, alteration and the granting and revoking of roles to other roles.
IRoleManager.Option - Enum in org.apache.cassandra.auth
Supported options for CREATE ROLE/ALTER ROLE (and CREATE USER/ALTER USER, which are aliases provided for backwards compatibility).
IRowCacheEntry - Interface in org.apache.cassandra.cache
 
IS_PARTIAL_BIT - Static variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
 
IS_UNALIGNED - Static variable in class org.apache.cassandra.utils.Architecture
 
isAborted() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
 
isAborted() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
 
isAcceptable(Path) - Method in class org.apache.cassandra.utils.DirectorySizeCalculator
 
isActive - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
pause/resume/getNextBackgroundTask must synchronize.
isActive() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
isAdministrativelyInactiveState(EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
 
isAdministrativelyInactiveState(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
 
isAfter(Commit) - Method in class org.apache.cassandra.service.paxos.Commit
 
isAfter(OpOrder.Group) - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
 
isAfter(long) - Method in interface org.apache.cassandra.utils.MonotonicClock
 
isAfter(long, long) - Method in interface org.apache.cassandra.utils.MonotonicClock
 
isAfter(long) - Method in class org.apache.cassandra.utils.MonotonicClock.SampledClock
 
isAfter(long, long) - Method in class org.apache.cassandra.utils.MonotonicClock.SampledClock
 
isAfter(long) - Method in class org.apache.cassandra.utils.MonotonicClock.SystemClock
 
isAfter(long, long) - Method in class org.apache.cassandra.utils.MonotonicClock.SystemClock
 
isAggregate() - Method in interface org.apache.cassandra.cql3.functions.Function
Checks whether the function is an aggregate function or not.
isAggregate() - Method in class org.apache.cassandra.cql3.functions.NativeAggregateFunction
 
isAggregate() - Method in class org.apache.cassandra.cql3.functions.NativeScalarFunction
 
isAggregate() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
isAggregate() - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
isAggregate() - Method in class org.apache.cassandra.cql3.selection.Selection
 
isAggregate() - Method in interface org.apache.cassandra.cql3.selection.Selection.Selectors
Checks if one of the selectors perform some aggregations.
isAggregateSelectorFactory() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Checks if this factory creates selectors instances that creates aggregates.
isAlive() - Method in class org.apache.cassandra.concurrent.InfiniteLoopExecutor
 
isAlive() - Method in class org.apache.cassandra.gms.EndpointState
 
isAlive(InetAddressAndPort) - Method in class org.apache.cassandra.gms.FailureDetector
 
isAlive(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
 
isAlive(InetAddressAndPort) - Method in interface org.apache.cassandra.gms.IFailureDetector
Failure Detector's knowledge of whether a node is up or down.
isAlive(Replica) - Method in class org.apache.cassandra.locator.ReplicaPlan.ForWrite
Test liveness, consistent with the upfront analysis done for this operation (i.e.
isAlive(InetAddressAndPort) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
isAlive(InetAddressAndPort) - Method in class org.apache.cassandra.schema.MigrationCoordinator
 
isAnalyzed - Variable in class org.apache.cassandra.index.sasi.conf.IndexMode
 
isAnonymous() - Method in class org.apache.cassandra.auth.AuthenticatedUser
If IAuthenticator doesn't require authentication, this method may return true.
isAssignable() - Method in enum org.apache.cassandra.cql3.AssignmentTestable.TestResult
 
isAuditLogEnabled() - Method in class org.apache.cassandra.service.StorageService
 
isAuditLogEnabled() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isAuditLoggerClassExists(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
isAuthSetupComplete - Variable in class org.apache.cassandra.auth.jmx.AuthorizationProxy
 
isAuthSetupComplete() - Method in class org.apache.cassandra.service.StorageService
 
isAuthzRequired - Variable in class org.apache.cassandra.auth.jmx.AuthorizationProxy
 
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
 
isAvailable() - Static method in class org.apache.cassandra.utils.NativeLibrary
Checks if the library has been successfully linked.
isAvailable() - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
 
isAvailable() - Method in class org.apache.cassandra.utils.NativeLibraryLinux
 
isAvailable() - Method in class org.apache.cassandra.utils.NativeLibraryWindows
 
isBackPressureEnabled() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Deprecated.
isBackPressureEnabled() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
isBeta() - Method in enum org.apache.cassandra.transport.ProtocolVersion
 
isBitSet(K, int) - Method in interface org.apache.cassandra.index.sasi.utils.trie.KeyAnalyzer
Returns true if a key's bit it set at the given index.
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
 
isBootstrapMode() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Check if currently bootstrapping.
isBootstrapMode() - Method in class org.apache.cassandra.tools.NodeProbe
 
IsBootstrappingException - Exception in org.apache.cassandra.exceptions
 
IsBootstrappingException() - Constructor for exception org.apache.cassandra.exceptions.IsBootstrappingException
 
isBottom() - Method in interface org.apache.cassandra.db.ClusteringPrefix
 
isBound() - Method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
 
isBoundary() - Method in interface org.apache.cassandra.db.ClusteringBoundOrBoundary
 
isBoundary() - Method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
 
isBoundary() - Method in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
 
isBoundary() - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
isBoundary() - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
 
isByteOrderComparable - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
isCallableWrtNullable(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
isCalledOnNullInput() - Method in class org.apache.cassandra.cql3.functions.NativeScalarFunction
 
isCalledOnNullInput() - Method in interface org.apache.cassandra.cql3.functions.ScalarFunction
 
isCalledOnNullInput() - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
isCancellable() - Method in class org.apache.cassandra.net.AsyncPromise
 
isCancelled() - Method in class org.apache.cassandra.net.AsyncPromise
 
isCancelled() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
 
isCaseSensitive() - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
 
isCaseSensitive() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
isCausedBy(Throwable, Predicate<Throwable>) - Static method in class org.apache.cassandra.utils.Throwables
 
isCDCEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isClean() - Method in class org.apache.cassandra.db.Memtable
 
isCleanedUp() - Method in class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
 
isClientInitialized() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isClientMode() - Static method in class org.apache.cassandra.config.Config
isClientOrToolInitialized() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isClose(boolean) - Method in interface org.apache.cassandra.db.ClusteringBoundOrBoundary
 
isClose(boolean) - Method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
 
isClose(boolean) - Method in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
 
isClose(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
isClose(boolean) - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
 
isClusteringColumn() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
isCollection() - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
 
isCollection() - Method in interface org.apache.cassandra.cql3.CQL3Type
 
isCollection() - Method in class org.apache.cassandra.cql3.functions.types.DataType
Returns whether this data type represent a CQL collection type, that is, a list, set or map.
isCollection() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isCollection() - Method in class org.apache.cassandra.db.marshal.CollectionType
 
isColumnRange() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the query returns a range of columns.
isColumnRestrictedByEq(ColumnMetadata) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the specified column is restricted by an EQ restriction.
isCompacting(Iterable<ColumnFamilyStore>, Predicate<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
isCompactionDiskSpaceCheckEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isCompactionDiskSpaceCheckEnabled() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
isCompactionManager - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
 
isCompactTable() - Method in class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
 
isCompactTable() - Method in class org.apache.cassandra.schema.TableMetadata
 
isCompatible() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
isCompatible() - Method in class org.apache.cassandra.io.sstable.format.Version
 
isCompatibleForStreaming() - Method in class org.apache.cassandra.io.sstable.format.Version
 
isCompatibleWith(DataType.Name) - Method in enum org.apache.cassandra.cql3.functions.types.DataType.Name
Return true if the provided Name is equal to this one, or if they are aliases for each other, and false otherwise.
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.SetField
 
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(ClusteringComparator) - Method in class org.apache.cassandra.db.ClusteringComparator
Returns whether this clustering comparator is compatible with the provided one, that is if the provided one can be safely replaced by this new one.
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.CompositeType
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.DateType
Deprecated.
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TimestampType
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TupleType
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
Test whether the given validator is compatible with the underlying analyzer.
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.DelimiterAnalyzer
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingAnalyzer
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.NoOpAnalyzer
 
isCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
 
isCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.CollectionType
A version of isCompatibleWith() to deal with non-multicell (frozen) collections
isCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.ListType
 
isCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.MapType
 
isCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.SetType
 
isComplete() - Method in interface org.apache.cassandra.auth.IAuthenticator.SaslNegotiator
Called after each invocation of IAuthenticator.SaslNegotiator.evaluateResponse(byte[]) to determine whether the authentication has completed successfully or should be continued.
isCompleted() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
 
isCompleted() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
 
isCompleted() - Method in class org.apache.cassandra.repair.consistent.LocalSession
 
isCompleted() - Method in class org.apache.cassandra.streaming.ProgressInfo
 
isComplex() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
isComposites() - Method in class org.apache.cassandra.schema.IndexMetadata
 
isCompound(Set<TableMetadata.Flag>) - Static method in enum org.apache.cassandra.schema.TableMetadata.Flag
 
isCompressed() - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader
 
isConcurrentValidatorsLimitEnforced() - Method in class org.apache.cassandra.service.StorageService
 
isConcurrentValidatorsLimitEnforced() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isConnected() - Method in class org.apache.cassandra.net.OutboundConnection
 
isConstant() - Method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.TermSize
 
isContained(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
Return true if file is contained in folder
isContains() - Method in class org.apache.cassandra.cql3.Relation
Checks if the operator of this relation is a CONTAINS.
isContains() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
 
isContains() - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
 
isContains() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
Checks if the operator of this IndexExpression is a CONTAINS operator.
isContainsKey() - Method in class org.apache.cassandra.cql3.Relation
Checks if the operator of this relation is a CONTAINS_KEY.
isContainsKey() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
Checks if the operator of this IndexExpression is a CONTAINS_KEY operator.
isCorrupt - Variable in class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
 
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
 
isCounter(boolean) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
isCounter() - Method in class org.apache.cassandra.schema.TableMetadata
 
isCounterCacheEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isCounterCell() - Method in class org.apache.cassandra.db.rows.AbstractCell
 
isCounterCell() - Method in class org.apache.cassandra.db.rows.Cell
Whether the cell is a counter cell or not.
isCounterColumn() - Method in class org.apache.cassandra.schema.ColumnMetadata
Check if column is counter type.
isCQLTable(Set<TableMetadata.Flag>) - Static method in enum org.apache.cassandra.schema.TableMetadata.Flag
 
isCrossNode() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
 
isCrossNode() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
 
isCrossNode() - Method in class org.apache.cassandra.net.Message
Whether the message has crossed the node boundary, that is whether it originated from another node.
isCustom - Variable in class org.apache.cassandra.cql3.statements.schema.IndexAttributes
 
isCustom() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
 
isCustom() - Method in class org.apache.cassandra.schema.IndexMetadata
 
isDaemonInitialized() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isDaemonSetupCompleted() - Method in class org.apache.cassandra.service.StorageService
 
isDataAvailable(String, Token) - Method in class org.apache.cassandra.dht.StreamStateStore
Check if given token's data is available in this node.
isDatacenterLocal() - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
isDataPresent() - Method in class org.apache.cassandra.service.reads.DataResolver
 
isDataPresent() - Method in class org.apache.cassandra.service.reads.DigestResolver
 
isDataPresent() - Method in class org.apache.cassandra.service.reads.ResponseResolver
 
isDeadState(EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
 
isDelete() - Method in enum org.apache.cassandra.cql3.statements.StatementType
Checks if this type is a delete.
isDeleted(Clustering<?>, 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(Set<TableMetadata.Flag>) - Static method in enum org.apache.cassandra.schema.TableMetadata.Flag
 
isDiagnosticsEnabled() - Method in class org.apache.cassandra.diag.DiagnosticEventService
 
isDiagnosticsEnabled() - Method in interface org.apache.cassandra.diag.DiagnosticEventServiceMBean
 
isDiagnosticSnapshotRequest(SnapshotCommand) - Static method in class org.apache.cassandra.utils.DiagnosticSnapshotService
 
isDigestQuery() - Method in class org.apache.cassandra.db.ReadCommand
Whether this query is a digest one or not.
isDigestResponse() - Method in class org.apache.cassandra.db.ReadResponse
 
isDigestResponse - Variable in class org.apache.cassandra.service.reads.DigestResolver.DigestResolverDebugResult
 
isDirectBufferPooled() - Method in class org.apache.cassandra.net.BufferPoolAllocator
 
isDisjoint() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
 
isDispatchPaused() - Method in class org.apache.cassandra.hints.HintsService
 
isDistinct - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
 
isDistinct() - Method in class org.apache.cassandra.db.filter.DataLimits
 
isDone() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
 
isDone() - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
 
isDone() - Method in interface org.apache.cassandra.db.Slices.InOrderTester
 
isDone() - Method in class org.apache.cassandra.net.AsyncPromise
 
isDone(int, int) - Method in class org.apache.cassandra.service.pager.AggregationQueryPager.AggregationPartitionIterator
 
isDone(int, int) - Method in class org.apache.cassandra.service.pager.AggregationQueryPager.GroupByPartitionIterator
 
isDoneForPartition() - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
 
isDrained() - Method in class org.apache.cassandra.service.StorageService
 
isDrained() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isDrained() - Method in class org.apache.cassandra.tools.NodeProbe
 
isDraining() - Method in class org.apache.cassandra.service.StorageService
 
isDraining() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isDraining() - Method in class org.apache.cassandra.tools.NodeProbe
 
isDropped(Cell<?>, boolean) - Method in class org.apache.cassandra.db.rows.DeserializationHelper
 
isDroppedComplexDeletion(DeletionTime) - Method in class org.apache.cassandra.db.rows.DeserializationHelper
 
isDummy() - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
isDummyList(RangesAtEndpoint) - Static method in class org.apache.cassandra.locator.RangesAtEndpoint
 
isDuration() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
isEmpty() - Method in class org.apache.cassandra.auth.RoleOptions
Return true if there are no options with values set, false otherwise
isEmpty() - Method in class org.apache.cassandra.cache.CaffeineCache
 
isEmpty() - Method in class org.apache.cassandra.cache.SerializingCache
 
isEmpty() - Method in class org.apache.cassandra.cql3.conditions.ColumnConditions
 
isEmpty() - Method in interface org.apache.cassandra.cql3.conditions.Conditions
Checks if this Conditions is empty.
isEmpty() - Method in class org.apache.cassandra.cql3.Operations
Checks if this Operations is empty.
isEmpty() - Method in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
 
isEmpty() - Method in interface org.apache.cassandra.cql3.restrictions.Restrictions
Checks if this Restrictions is empty or not.
isEmpty() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
isEmpty() - Method in class org.apache.cassandra.cql3.ResultSet
 
isEmpty() - Method in class org.apache.cassandra.cql3.UntypedResultSet
 
isEmpty() - Method in class org.apache.cassandra.cql3.VariableSpecifications
 
isEmpty() - Method in interface org.apache.cassandra.db.ClusteringPrefix
 
isEmpty() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isEmpty() - Method in class org.apache.cassandra.db.Columns
Whether this columns is empty.
isEmpty() - Method in class org.apache.cassandra.db.commitlog.IntervalSet
 
isEmpty(ClusteringComparator) - Method in class org.apache.cassandra.db.filter.AbstractClusteringIndexFilter
 
isEmpty(ClusteringComparator) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
 
isEmpty(ClusteringComparator) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
 
isEmpty() - Method in class org.apache.cassandra.db.filter.RowFilter
 
isEmpty() - Method in class org.apache.cassandra.db.lifecycle.View
 
isEmpty() - Method in class org.apache.cassandra.db.LivenessInfo
Whether this liveness info is empty (has no timestamp).
isEmpty(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
 
isEmpty() - Method in class org.apache.cassandra.db.Mutation
 
isEmpty() - Method in class org.apache.cassandra.db.Mutation.PartitionUpdateCollector
 
isEmpty() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
isEmpty() - Method in interface org.apache.cassandra.db.partitions.Partition
Whether the partition object has no informations at all, including any deletion informations.
isEmpty() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
isEmpty() - Method in interface org.apache.cassandra.db.ReadQuery
Whether this query is known to return nothing upfront.
isEmpty() - Method in class org.apache.cassandra.db.RegularAndStaticColumns
 
isEmpty() - Method in interface org.apache.cassandra.db.rows.BaseRowIterator
Returns whether the provided iterator has no data.
isEmpty() - Method in class org.apache.cassandra.db.rows.BTreeRow
 
isEmpty() - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
 
isEmpty() - Method in interface org.apache.cassandra.db.rows.Row
Whether the row has no information whatsoever.
isEmpty() - Method in interface org.apache.cassandra.db.rows.RowIterator
Returns whether the provided iterator has no data.
isEmpty() - Method in interface org.apache.cassandra.db.rows.Unfiltered
 
isEmpty() - Method in interface org.apache.cassandra.db.rows.UnfilteredRowIterator
Returns whether this iterator has no data (including no deletion data).
isEmpty - Variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer.Header
 
isEmpty(ClusteringComparator) - Method in class org.apache.cassandra.db.Slice
Return whether the slice is empty.
isEmpty(ClusteringComparator, ClusteringBound<?>, ClusteringBound<?>) - Static method in class org.apache.cassandra.db.Slice
Return whether the slice formed by the two provided bound is empty or not.
isEmpty() - Method in class org.apache.cassandra.db.Slices
Checks if this Slices is empty.
isEmpty() - Method in class org.apache.cassandra.db.transform.FilteredRows
 
isEmpty() - Method in class org.apache.cassandra.db.virtual.AbstractVirtualTable.AbstractDataSet
 
isEmpty() - Method in interface org.apache.cassandra.db.virtual.AbstractVirtualTable.DataSet
 
isEmpty(AbstractBounds.Boundary<T>, AbstractBounds.Boundary<T>) - Static method in class org.apache.cassandra.dht.AbstractBounds
 
isEmpty() - Method in class org.apache.cassandra.gms.HeartBeatState
 
isEmpty() - Method in class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
 
isEmpty() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
 
isEmpty() - Method in class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
 
isEmpty() - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
isEmpty() - Method in class org.apache.cassandra.io.util.MmappedRegions
 
isEmpty() - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
 
isEmpty() - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
 
isEmpty() - Method in interface org.apache.cassandra.locator.ReplicaCollection
 
isEmpty() - Method in class org.apache.cassandra.locator.ReplicaMultimap
 
isEmpty() - Method in class org.apache.cassandra.net.AsyncStreamingInputPlus
 
isEmpty() - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
 
isEmpty() - Method in class org.apache.cassandra.repair.consistent.SyncStatSummary
 
isEmpty() - Method in class org.apache.cassandra.schema.Functions
 
isEmpty() - Method in class org.apache.cassandra.schema.Indexes
 
isEmpty() - Method in class org.apache.cassandra.schema.Keyspaces
 
isEmpty() - Method in class org.apache.cassandra.schema.Keyspaces.KeyspacesDiff
 
isEmpty() - Method in class org.apache.cassandra.schema.Schema
Checks whether the current schema is empty.
isEmpty() - Method in class org.apache.cassandra.schema.Triggers
 
isEmpty() - Method in class org.apache.cassandra.schema.Views
 
isEmpty() - Method in class org.apache.cassandra.service.paxos.Commit
Whether this is an empty commit, that is one with no updates.
isEmpty() - Method in class org.apache.cassandra.streaming.StreamPlan
 
isEmpty() - Method in class org.apache.cassandra.utils.BiMultiValMap
 
isEmpty() - Method in class org.apache.cassandra.utils.btree.BTree.Builder
 
isEmpty(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
 
isEmpty() - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
isEmpty() - Method in class org.apache.cassandra.utils.btree.BTreeSet.Builder
 
isEmpty() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
isEmpty() - Method in class org.apache.cassandra.utils.concurrent.Accumulator
 
isEmpty() - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
isEmpty() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
isEmpty() - Method in class org.apache.cassandra.utils.IntervalTree
 
isEmptyFromOffset(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.AbstractType
Returns true for types where empty should be handled like null like Int32Type.
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.BooleanType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.DateType
Deprecated.
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.DecimalType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.DoubleType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.FloatType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.InetAddressType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.Int32Type
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.IntegerType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.LongType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.ReversedType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.TimestampType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.UUIDType
 
isEmptyWithoutStatus() - Method in class org.apache.cassandra.gms.EndpointState
 
isEnabled() - Method in class org.apache.cassandra.audit.AuditLogManager
 
isEnabled() - Method in class org.apache.cassandra.audit.BinAuditLogger
 
isEnabled() - Method in class org.apache.cassandra.audit.DiagnosticEventAuditLogger
 
isEnabled() - Method in class org.apache.cassandra.audit.FileAuditLogger
 
isEnabled() - Method in interface org.apache.cassandra.audit.IAuditLogger
 
isEnabled() - Method in class org.apache.cassandra.audit.NoOpAuditLogger
 
isEnabled - Variable in class org.apache.cassandra.config.EncryptionOptions
 
isEnabled() - Method in class org.apache.cassandra.config.EncryptionOptions
Indicates if the channel should be encrypted.
isEnabled() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
isEnabled(Class<E>) - Method in class org.apache.cassandra.diag.DiagnosticEventService
Indicates if events are enabled for specified event class based on DatabaseDescriptor.diagnosticEventsEnabled() and DiagnosticEventService.hasSubscribers(Class).
isEnabled(Class<E>, T) - Method in class org.apache.cassandra.diag.DiagnosticEventService
Indicates if events are enabled for specified event class based on DatabaseDescriptor.diagnosticEventsEnabled() and DiagnosticEventService.hasSubscribers(Class, Enum).
isEnabled() - Method in class org.apache.cassandra.fql.FullQueryLogger
 
isEnabled() - Method in class org.apache.cassandra.gms.Gossiper
 
isEnabled() - Method in class org.apache.cassandra.metrics.FrequencySampler
 
isEnabled() - Method in class org.apache.cassandra.metrics.MaxSampler
 
isEnabled() - Method in class org.apache.cassandra.metrics.Sampler
 
isEnabled() - Method in class org.apache.cassandra.schema.CompactionParams
 
isEnabled() - Method in class org.apache.cassandra.schema.CompressionParams
Checks if compression is enabled.
isEnabled(Map<String, String>) - Static method in class org.apache.cassandra.schema.CompressionParams
Returns true if the options contains the enabled option and that its value is true, otherwise returns false.
isEnabled() - Method in class org.apache.cassandra.security.EncryptionContext
 
isEnd() - Method in enum org.apache.cassandra.cql3.statements.Bound
 
isEnd() - Method in interface org.apache.cassandra.db.ClusteringBound
 
isEnd() - Method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
 
isEndInclusive() - Method in class org.apache.cassandra.dht.AbstractBounds
 
isEndInclusive() - Method in class org.apache.cassandra.dht.Bounds
 
isEndInclusive() - Method in class org.apache.cassandra.dht.ExcludingBounds
 
isEndInclusive() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
isEndInclusive() - Method in class org.apache.cassandra.dht.Range
 
isEndOfPartition(int) - Static method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
isEndpointAlive - Static variable in class org.apache.cassandra.gms.FailureDetector
 
isEntireSSTable(boolean) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.Builder
 
isEntireSSTable - Variable in class org.apache.cassandra.db.streaming.CassandraStreamHeader
 
isEOF() - Method in class org.apache.cassandra.db.commitlog.EncryptedFileSegmentInputStream
 
isEOF() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
 
isEOF() - Method in class org.apache.cassandra.hints.CompressedChecksummedDataInput
Since an entire block of compressed data is read off of disk, not just a hint at a time, we don't report EOF until the decompressed data has also been read completely
isEOF() - Method in class org.apache.cassandra.hints.EncryptedChecksummedDataInput
Since an entire block of compressed data is read off of disk, not just a hint at a time, we don't report EOF until the decompressed data has also been read completely
isEOF() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
isEOF() - Method in class org.apache.cassandra.io.util.FileSegmentInputStream
 
isEOF() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
isEQ() - Method in class org.apache.cassandra.cql3.Relation
Checks if the operator of this relation is a EQ.
isEQ() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
 
isEQ() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQRestriction
 
isEQ() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
 
isEQ() - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
 
ISerializer<T> - Interface in org.apache.cassandra.io
 
isExactlyDirect(ByteBuffer) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
isExactMatch() - Method in enum org.apache.cassandra.cql3.AssignmentTestable.TestResult
 
isExclusive() - Method in interface org.apache.cassandra.db.ClusteringBound
 
isExecutedBy(Thread) - Method in class org.apache.cassandra.concurrent.JMXEnabledSingleThreadExecutor
 
isExhausted(DataLimits.Counter) - Method in class org.apache.cassandra.db.filter.DataLimits
 
isExhausted() - Method in class org.apache.cassandra.service.pager.AggregationQueryPager
 
isExhausted() - Method in class org.apache.cassandra.service.pager.MultiPartitionPager
 
isExhausted() - Method in interface org.apache.cassandra.service.pager.QueryPager
Whether or not this pager is exhausted, i.e.
isExistingRole(RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
isExistingRole(RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
Return true is a Role with the given name exists in the system.
isExpired() - Method in class org.apache.cassandra.db.LivenessInfo
 
isExpired() - Method in class org.apache.cassandra.db.Memtable
 
isExpired - Variable in class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
 
isExpiring() - Method in class org.apache.cassandra.db.LivenessInfo
Whether the info has a ttl.
isExpiring() - Method in class org.apache.cassandra.db.rows.AbstractCell
 
isExpiring() - Method in class org.apache.cassandra.db.rows.Cell
Whether the cell is an expiring one or not.
isExplicitlyOptional() - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
EncryptionOptions.isOptional will be set to true implicitly for internode_encryption values of "dc" and "all".
isFailed() - Method in class org.apache.cassandra.streaming.SessionInfo
 
isFailed() - Method in class org.apache.cassandra.tools.NodeProbe
 
isFatal() - Method in exception org.apache.cassandra.transport.ProtocolException
 
isFileSize(String) - Static method in enum org.apache.cassandra.db.compaction.CompactionInfo.Unit
 
isFilterFullyCoveredBy(ClusteringIndexFilter, DataLimits, CachedPartition, int, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isFinalState() - Method in enum org.apache.cassandra.streaming.StreamSession.State
 
isFinished() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
 
isFloatingPoint() - Method in class org.apache.cassandra.db.marshal.DecimalType
 
isFloatingPoint() - Method in class org.apache.cassandra.db.marshal.DoubleType
 
isFloatingPoint() - Method in class org.apache.cassandra.db.marshal.FloatType
 
isFloatingPoint() - Method in class org.apache.cassandra.db.marshal.NumberType
Checks if this type support floating point numbers.
isFollower() - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
isFollower() - Method in class org.apache.cassandra.streaming.StreamSession
 
isForcedRepair() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
isForSSTable() - Method in class org.apache.cassandra.db.SerializationHeader
 
isFreezable() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isFreezable() - Method in class org.apache.cassandra.db.marshal.CollectionType
 
isFreezable() - Method in class org.apache.cassandra.db.marshal.UserType
 
isFrozen() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
isFrozen() - Method in class org.apache.cassandra.cql3.functions.types.DataType.CollectionType
 
isFrozen() - Method in class org.apache.cassandra.cql3.functions.types.DataType.CustomType
 
isFrozen() - Method in class org.apache.cassandra.cql3.functions.types.DataType
Returns whether this data type is frozen.
isFrozen() - Method in class org.apache.cassandra.cql3.functions.types.DataType.NativeType
 
isFrozen(String) - Static method in class org.apache.cassandra.cql3.functions.types.DataTypeClassNameParser
 
isFrozen() - Method in class org.apache.cassandra.cql3.functions.types.TupleType
 
isFrozen() - Method in class org.apache.cassandra.cql3.functions.types.UserType
 
isFrozenCollection() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isFull() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
 
isFull() - Method in class org.apache.cassandra.locator.Replica
 
isFullQueryLogEnabled() - Method in class org.apache.cassandra.service.StorageService
 
isFullQueryLogEnabled() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isFullyCoveredBy(CachedPartition) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
Returns whether we can guarantee that a given cached partition contains all the data selected by this filter.
isFullyCoveredBy(CachedPartition) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
 
isFullyCoveredBy(CachedPartition) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
 
isFullyRefused() - Method in class org.apache.cassandra.service.paxos.ProposeCallback
 
isGlobal() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
 
isGlobal() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
if this compaction involves several/all tables we can safely check globalCompactionsPaused in isStopRequested() below
isGlobal() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
 
isGlobal() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
isGlobal() - Method in class org.apache.cassandra.db.view.ViewBuilderTask
 
isGlobal() - Method in class org.apache.cassandra.index.SecondaryIndexBuilder
 
isGlobal() - Method in class org.apache.cassandra.io.sstable.IndexSummaryRedistribution
 
isGlobal - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
 
isGlobal() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
isGlobal - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
isGlobalCompactionPaused() - Method in class org.apache.cassandra.db.compaction.CompactionManager
Return whether "global" compactions should be paused, used by ColumnFamilyStore#runWithCompactionsDisabled a global compaction is one that includes several/all tables, currently only IndexSummaryBuilder
isGossipActive() - Method in class org.apache.cassandra.service.StorageService
 
isGossipOnlyMember(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
 
isGossipRunning() - Method in class org.apache.cassandra.service.StorageService
 
isGossipRunning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isGossipRunning() - Method in class org.apache.cassandra.tools.NodeProbe
 
isGreaterOrEqualTo(ProtocolVersion) - Method in enum org.apache.cassandra.transport.ProtocolVersion
 
isGreaterThan(ProtocolVersion) - Method in enum org.apache.cassandra.transport.ProtocolVersion
 
isGroupByLimit() - Method in class org.apache.cassandra.db.filter.DataLimits
 
isHandoffEnabled() - Method in class org.apache.cassandra.tools.NodeProbe
 
isHeadFilter() - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
Whether this filter selects the head of a partition (i.e.
isHeadFilter() - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
 
isHeadFilter() - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
 
isHiddenColumn(ColumnMetadata) - Method in class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
 
isIfExists() - Method in interface org.apache.cassandra.cql3.conditions.Conditions
Checks if this is a IF EXIST condition.
isIfNotExists() - Method in interface org.apache.cassandra.cql3.conditions.Conditions
Checks if this is a IF NOT EXIST condition.
isIN() - Method in enum org.apache.cassandra.cql3.Operator
Checks if this operator is an IN operator.
isIN() - Method in class org.apache.cassandra.cql3.Relation
Checks if the operator of this relation is a IN.
isIN() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.INRestriction
 
isIN() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.INRestriction
 
isIN() - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
 
isInBounds(T, Iterable<Bounds<T>>) - Static method in class org.apache.cassandra.dht.Bounds
 
isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
 
isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
 
isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
 
isInclusive(Bound) - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
Checks if the specified bound is inclusive or not.
isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQRestriction
 
isInclusive(Bound) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.SliceRestriction
 
isInclusive() - Method in interface org.apache.cassandra.db.ClusteringBound
 
isInCorrectLocation(SSTableReader, Directories.DataDirectory) - Method in class org.apache.cassandra.db.DiskBoundaries
 
isInCorrectLocation - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
isIncremental - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
 
isIncremental() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
isIncremental - Variable in class org.apache.cassandra.repair.RepairSession
 
isIncremental - Variable in class org.apache.cassandra.repair.Validator
 
isIncremental - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
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
isIndex() - Method in class org.apache.cassandra.schema.TableMetadata
 
isIndex - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
isIndexBuilding(String) - Method in class org.apache.cassandra.index.SecondaryIndexManager
Checks if the specified index has any running build task.
isIndexBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
isIndexColumnFamily(String) - Static method in class org.apache.cassandra.index.SecondaryIndexManager
Checks if the specified ColumnFamilyStore is the one secondary index.
isIndexColumnFamilyStore(ColumnFamilyStore) - Static method in class org.apache.cassandra.index.SecondaryIndexManager
Checks if the specified ColumnFamilyStore is a secondary index.
isIndexed() - Method in class org.apache.cassandra.db.RowIndexEntry
 
isIndexed() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
isIndexed() - Method in class org.apache.cassandra.index.sasi.plan.Expression
 
isIndexQueryable(Index) - Method in class org.apache.cassandra.index.SecondaryIndexManager
Checks if the specified index is queryable.
isIndexWritable(Index) - Method in class org.apache.cassandra.index.SecondaryIndexManager
Checks if the specified index is writable.
isInitialized() - Method in class org.apache.cassandra.service.StorageService
 
isInitialized() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isInitialized() - Method in class org.apache.cassandra.tools.NodeProbe
 
isInLocalDCOnly() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
isInProgress() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
 
isInProgress() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
 
isInRanges(T, Iterable<Range<T>>) - Static method in class org.apache.cassandra.dht.Range
 
isInsert() - Method in enum org.apache.cassandra.cql3.statements.StatementType
Checks if this type is an insert.
isInShadowRound() - Method in class org.apache.cassandra.gms.Gossiper
 
isInShutdownHook() - Method in class org.apache.cassandra.service.StorageService
Deprecated.
isInterestedIn(String) - Method in class org.apache.cassandra.tools.BootstrapMonitor
 
isInterestedIn(String) - Method in class org.apache.cassandra.tools.RepairRunner
 
isInterestedIn(String) - Method in class org.apache.cassandra.utils.progress.jmx.JMXNotificationProgressListener
 
isInternal - Variable in class org.apache.cassandra.service.ClientState
 
isInterned() - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
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
 
isJoining() - Method in class org.apache.cassandra.service.StorageService
 
isJson - Variable in class org.apache.cassandra.cql3.selection.Selection
 
isJson - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
 
isKeyCacheEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isKeyCacheEnabled() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
isKeyRange() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the query request a range of partition keys.
isKeys() - Method in class org.apache.cassandra.schema.IndexMetadata
 
isKeyspaceLevel() - Method in class org.apache.cassandra.auth.DataResource
 
isKnownEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
 
isLastLeaf() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
 
isLatestVersion() - Method in class org.apache.cassandra.io.sstable.format.Version
 
isLeaf() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
 
isLeaf(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
 
isLeaving(InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
 
isLeveledSstable - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
isLIKE() - Method in class org.apache.cassandra.cql3.Relation
 
isLIKE() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
 
isLIKE() - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
 
isLimitedToOnePartition() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
isLimitedToOnePartition() - Method in class org.apache.cassandra.db.ReadCommand
 
isLimitedToOnePartition() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
isLinux - Static variable in class org.apache.cassandra.utils.FBUtilities
 
isLiteral() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
isLiteral - Variable in class org.apache.cassandra.index.sasi.conf.IndexMode
 
isLiteral - Variable in class org.apache.cassandra.index.sasi.plan.Expression
 
isLive() - Method in interface 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(Row) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
 
isLive(int) - Method in class org.apache.cassandra.db.LivenessInfo
Whether that info is still live.
isLive() - Method in class org.apache.cassandra.db.Memtable
 
isLive() - Method in class org.apache.cassandra.db.MutableDeletionInfo
Returns whether this DeletionInfo is live, that is deletes no columns.
isLive(int) - Method in class org.apache.cassandra.db.rows.AbstractCell
 
isLive(int) - Method in class org.apache.cassandra.db.rows.Cell
Whether the cell is live or not given the current time.
isLive() - Method in class org.apache.cassandra.db.rows.Row.Deletion
Wether the deletion is live or not, that is if its an actual deletion or not.
isLive() - Method in class org.apache.cassandra.hints.Hint
 
isLive() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
 
isLocal() - Method in class org.apache.cassandra.batchlog.Batch
Local batches contain only already decoded Mutation instances.
isLocal() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
isLocal() - Method in class org.apache.cassandra.repair.LocalSyncTask
 
isLocal() - Method in class org.apache.cassandra.repair.SyncTask
 
isLocalId() - Method in class org.apache.cassandra.utils.CounterId
 
isLocalSystemKeyspace(String) - Static method in class org.apache.cassandra.schema.SchemaConstants
 
isLocalVersion(UUID) - Method in class org.apache.cassandra.schema.MigrationCoordinator
 
isLowerSatisfiedBy(OnDiskIndex.DataTerm) - Method in class org.apache.cassandra.index.sasi.plan.Expression
 
isMap() - Method in class org.apache.cassandra.db.marshal.CollectionType
Checks if this collection is Map.
isMarkedCompacted() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
isMarkedSuspect() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
isMember(InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
 
isMemoryLockable() - Method in interface org.apache.cassandra.service.NativeAccessMBean
 
isMessaging() - Method in enum org.apache.cassandra.net.ConnectionCategory
 
isMessaging() - Method in enum org.apache.cassandra.net.ConnectionType
 
isMinimum() - Method in class org.apache.cassandra.db.DecoratedKey
 
isMinimum() - Method in interface org.apache.cassandra.db.PartitionPosition
 
isMinimum() - Method in interface org.apache.cassandra.dht.RingPosition
 
isMinimum() - Method in class org.apache.cassandra.dht.Token
 
isMinimum() - Method in class org.apache.cassandra.dht.Token.KeyBound
 
isMinimumBound - Variable in class org.apache.cassandra.dht.Token.KeyBound
 
isModified() - Method in class org.apache.cassandra.auth.DCPermissions.Builder
 
isModified() - Method in class org.apache.cassandra.utils.DefaultValue
 
isMoving(InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
 
isMoving() - Method in class org.apache.cassandra.service.StorageService
 
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
 
isMultiCell() - Method in class org.apache.cassandra.db.marshal.UserType
 
isMultiColumn() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
isMultiColumn() - Method in class org.apache.cassandra.cql3.Relation
Checks if this relation apply to multiple columns.
isMultiColumn() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
 
isMultiColumn() - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
 
isNamesQuery() - Method in class org.apache.cassandra.db.DataRange
Whether the underlying clustering index filter is a names filter or not.
isNamesQuery() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
isNameValid(String) - Static method in class org.apache.cassandra.schema.IndexMetadata
 
isNative() - Method in interface org.apache.cassandra.cql3.functions.Function
Checks whether the function is a native/hard coded one or not.
isNative() - Method in class org.apache.cassandra.cql3.functions.NativeFunction
 
isNative() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
isNative() - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
isNativeTransportRunning() - Method in class org.apache.cassandra.service.CassandraDaemon
 
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
 
isNegation(FunctionName) - Static method in class org.apache.cassandra.cql3.functions.OperationFcts
Checks if the function with the specified name is a negation.
isNewGroup(DecoratedKey, Clustering<?>) - Method in class org.apache.cassandra.db.aggregation.GroupMaker
Checks if a given row belongs to the same group that the previous row or not.
isNodeInitialized() - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
isNormal() - Method in class org.apache.cassandra.service.StorageService
 
isNormalState() - Method in class org.apache.cassandra.gms.EndpointState
 
isNotNull() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.NotNullRestriction
 
isNotNull() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IsNotNullRestriction
 
isNotNull() - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
 
IsNotNullRestriction(ColumnMetadata) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IsNotNullRestriction
 
isNull(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
Returns whether the value for name is NULL.
isNull(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
Returns whether the ith value is NULL.
isNull(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
Returns whether the value for name is NULL.
isNullOrEmpty(AbstractType<?>, ByteBuffer) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
 
isNullRole(Role) - Static method in class org.apache.cassandra.auth.Roles
Just a convenience method which compares a role instance with the null object version, indicating if the return from some query/lookup method was a valid Role or indicates that the role does not exist.
isObsolete(SSTableReader) - Method in interface org.apache.cassandra.db.lifecycle.ILifecycleTransaction
 
isObsolete(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
indicates if the reader has been marked for obsoletion
isObsolete(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
 
isObsolete() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
 
isOffline() - Method in interface org.apache.cassandra.db.lifecycle.ILifecycleTransaction
 
isOffline() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
isOffline() - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
 
isOldestLiveGroup() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
 
isOnToken() - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
 
isOnToken() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
isOpen(boolean) - Method in interface org.apache.cassandra.db.ClusteringBoundOrBoundary
 
isOpen(boolean) - Method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
 
isOpen(boolean) - Method in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
 
isOpen(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
isOpen(boolean) - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
 
isOpen() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
isOpen() - Method in class org.apache.cassandra.security.EncryptionUtils.ChannelProxyReadChannel
 
isOperation(FunctionName) - Static method in class org.apache.cassandra.cql3.functions.OperationFcts
Checks if the function with the specified name is an operation.
isOptional - Variable in class org.apache.cassandra.config.EncryptionOptions
 
isOptional() - Method in class org.apache.cassandra.config.EncryptionOptions
Indicates if the channel may be encrypted (but is not required to be).
isOutOfDate() - Method in class org.apache.cassandra.db.DiskBoundaries
check if the given disk boundaries are out of date due not being set or to having too old diskVersion/ringVersion
isOverflowed() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
isOverlapping(RangeIterator<K, D>, RangeIterator<K, D>) - Static method in class org.apache.cassandra.index.sasi.utils.RangeIterator
 
isOverlapping(K, K, RangeIterator<K, D>) - Static method in class org.apache.cassandra.index.sasi.utils.RangeIterator
Ranges are overlapping the following cases: * When they have a common subrange: min b.current max b.max +---------|--------------+------------| b.current min max b.max |--------------+---------+------------| min b.current b.max max +----------|-------------|------------+ If either range is empty, they're disjoint.
isPackageAllowed(String) - Method in class org.apache.cassandra.security.SecurityThreadGroup
 
isPaging() - Method in class org.apache.cassandra.db.DataRange
Whether the data range is for a paged request or not.
isPaging() - Method in class org.apache.cassandra.db.DataRange.Paging
 
isPartial() - Method in class org.apache.cassandra.index.sasi.sa.IndexedTerm
 
isPartial() - Method in class org.apache.cassandra.index.sasi.Term
 
isPartial() - Method in class org.apache.cassandra.index.sasi.utils.CombinedTerm
 
isPartitionKey() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
isPartitionKeyRestrictionsOnToken() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the restrictions on the partition key are token restrictions.
isPastCurrentBlock() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
 
isPendingRepair() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
isPrefix(K, K) - Method in interface org.apache.cassandra.index.sasi.utils.trie.KeyAnalyzer
Returns true if the second argument is a prefix of the first argument.
isPrefix(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
isPresent() - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
 
isPresent(IFilter.FilterKey) - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
 
isPresent(IFilter.FilterKey) - Method in class org.apache.cassandra.utils.BloomFilter
 
isPresent(IFilter.FilterKey) - Method in interface org.apache.cassandra.utils.IFilter
 
isPreview() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
isPreview() - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
isPreview() - Method in enum org.apache.cassandra.streaming.PreviewKind
 
isPreview() - Method in class org.apache.cassandra.streaming.StreamSession
 
isPreviouslyReturnedPartition(DecoratedKey) - Method in class org.apache.cassandra.service.pager.PartitionRangeQueryPager
 
isPreviouslyReturnedPartition(DecoratedKey) - Method in class org.apache.cassandra.service.pager.SinglePartitionPager
 
isPrimaryKeyColumn() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
isPrimaryKeyKind() - Method in enum org.apache.cassandra.schema.ColumnMetadata.Kind
 
isPrimaryRange() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
isPullRepair() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
isRangeRequest() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
isRangeRequest() - Method in class org.apache.cassandra.db.ReadCommand
 
isRangeRequest() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
isRangeTombstoneMarker() - Method in interface org.apache.cassandra.db.rows.Unfiltered
 
isRecoverable() - Method in class org.apache.cassandra.net.FrameDecoder.CorruptFrame
 
isRegistered(ObjectName, MBeanWrapper.OnException) - Method in interface org.apache.cassandra.utils.MBeanWrapper
 
isRegistered(ObjectName) - Method in interface org.apache.cassandra.utils.MBeanWrapper
 
isRegistered(String, MBeanWrapper.OnException) - Method in interface org.apache.cassandra.utils.MBeanWrapper
 
isRegistered(String) - Method in interface org.apache.cassandra.utils.MBeanWrapper
 
isRegistered(ObjectName, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.NoOpMBeanWrapper
 
isRegistered(String, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.NoOpMBeanWrapper
 
isRegistered(ObjectName, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.PlatformMBeanWrapper
 
isRegular() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
isRemote() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
isRepaired(AbstractCompactionStrategy) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
isRepaired() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
isRepairedDataDigestConclusive() - Method in class org.apache.cassandra.db.ReadExecutionController
 
isRepairedDigestConclusive() - Method in class org.apache.cassandra.db.ReadResponse
 
isReplaced() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
isReplacingSameAddress() - Static method in class org.apache.cassandra.service.StorageService
 
isReplacingSameHostAddressAndHostId(UUID) - Method in class org.apache.cassandra.service.StorageService
 
isReplicaAlive - Static variable in class org.apache.cassandra.gms.FailureDetector
 
isReplicatedSystemKeyspace(String) - Static method in class org.apache.cassandra.schema.SchemaConstants
 
isReserved(String) - Static method in class org.apache.cassandra.cql3.ReservedKeywords
 
isResponse() - Method in enum org.apache.cassandra.net.Verb
 
isRestricted(ColumnMetadata) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
isReversed(String) - Static method in class org.apache.cassandra.cql3.functions.types.DataTypeClassNameParser
 
isReversed() - Method in class org.apache.cassandra.db.DataRange
Whether the underlying ClusteringIndexFilter is reversed or not.
isReversed() - Method in class org.apache.cassandra.db.filter.AbstractClusteringIndexFilter
 
isReversed() - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
Whether the filter query rows in reversed clustering order or not.
isReversed() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isReversed() - Method in class org.apache.cassandra.db.marshal.ReversedType
 
isReversed() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
isReversed() - Method in class org.apache.cassandra.db.ReadCommand
Whether the underlying ClusteringIndexFilter is reversed or not.
isReversed - Variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer.Header
 
isReversed() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
isReversed(List<UnfilteredRowIterator>) - Method in class org.apache.cassandra.service.reads.repair.PartitionIteratorMergeListener
 
isReversedType() - Method in class org.apache.cassandra.cql3.ColumnSpecification
 
isReverseOrder() - Method in class org.apache.cassandra.db.columniterator.SSTableIterator
 
isReverseOrder() - Method in class org.apache.cassandra.db.columniterator.SSTableReversedIterator
 
isReverseOrder - Variable in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
 
isReverseOrder() - Method in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
 
isReverseOrder() - Method in interface org.apache.cassandra.db.rows.BaseRowIterator
Whether or not the rows returned by this iterator are in reversed clustering order.
isReverseOrder() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
 
isReverseOrder() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
 
isReverseOrder() - Method in class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
 
isReverseOrder() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader.StreamDeserializer
 
isReverseOrder() - Method in class org.apache.cassandra.db.transform.BaseRows
 
isReverseOrder() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
isRoot() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
 
isRootLevel() - Method in class org.apache.cassandra.auth.DataResource
 
isRow() - Method in interface org.apache.cassandra.db.rows.Unfiltered
 
isRowCacheEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isRpcReady() - Method in class org.apache.cassandra.gms.EndpointState
 
isRpcReady(InetAddressAndPort) - Method in class org.apache.cassandra.service.StorageService
 
isRunning() - Method in interface org.apache.cassandra.service.CassandraDaemon.Server
Returns whether the server is currently running.
isRunning() - Method in class org.apache.cassandra.service.NativeTransportService
 
isRunning() - Method in class org.apache.cassandra.transport.Server
 
isSafeForStartup(InetAddressAndPort, UUID, boolean, Map<InetAddressAndPort, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
Check if this node can safely be started and join the ring.
isSameVersion(UUID) - Method in class org.apache.cassandra.schema.Schema
Checks whether the given schema version is the same as the current local schema.
isSatisfiedBy(AbstractType<?>, ByteBuffer, ByteBuffer) - Method in enum org.apache.cassandra.cql3.Operator
Whether 2 values satisfy this operator (given the type they should be compared with).
isSatisfiedBy(TableMetadata, DecoratedKey, Row) - Method in class org.apache.cassandra.db.filter.RowFilter.CustomExpression
 
isSatisfiedBy(TableMetadata, DecoratedKey, Row) - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
Returns whether the provided row satisfied this expression or not.
isSatisfiedBy(TableMetadata, DecoratedKey, Row, int) - Method in class org.apache.cassandra.db.filter.RowFilter
Whether the provided row in the provided partition satisfies this filter.
isSatisfiedBy(TableMetadata, DecoratedKey, Row) - Method in class org.apache.cassandra.db.filter.RowFilter.SimpleExpression
 
isSatisfiedBy(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.plan.Expression
 
isSecondaryIndexFolder(File) - Static method in class org.apache.cassandra.db.Directories
 
isSecuredThread() - Static method in class org.apache.cassandra.security.ThreadAwareSecurityManager
 
isSeed() - Static method in class org.apache.cassandra.service.StorageService
 
isSelect() - Method in enum org.apache.cassandra.cql3.statements.StatementType
Checks if this type is a select.
isSelf() - Method in class org.apache.cassandra.locator.Replica
 
isSelfContained - Variable in class org.apache.cassandra.net.FrameDecoder.Frame
 
isSerialConsistency() - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
isSerializable() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
 
isSerializable() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
 
isSessionFinalized(UUID) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
determines if a local session exists, and if it's in the finalized state
isSessionInProgress(UUID) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
determines if a local session exists, and if it's not finalized or failed
isSet() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
 
isShadowable() - Method in class org.apache.cassandra.db.rows.Row.Deletion
Whether the deletion is a shadowable one or not.
isShadowedBy(LivenessInfo) - Method in class org.apache.cassandra.db.rows.Row.Deletion
 
isShutdown() - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
 
isShutdown() - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
isShutDown() - Method in class org.apache.cassandra.hints.HintsService
Returns true in case service is shut down.
isShutdown() - Method in class org.apache.cassandra.service.StorageService
 
isSignaled() - Method in class org.apache.cassandra.utils.concurrent.SimpleCondition
 
isSignalled() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
 
isSilent() - Method in exception org.apache.cassandra.transport.ProtocolException
 
isSilentShutdownState(EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
 
isSimple() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
isSimpleSelectorFactory() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Checks if this factory creates Selectors that simply return a column value.
isSimpleSelectorFactory() - Method in class org.apache.cassandra.cql3.selection.SimpleSelector.SimpleSelectorFactory
 
isSimpleSelectorFactoryFor(int) - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Checks if this factory creates Selectors that simply return the specified column.
isSimpleSelectorFactoryFor(int) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector.SimpleSelectorFactory
 
isSlice() - Method in enum org.apache.cassandra.cql3.Operator
Checks if this operator is a slice operator.
isSlice() - Method in class org.apache.cassandra.cql3.Relation
Checks if the operator of this relation is a Slice (GT, GTE, LTE, LT).
isSlice() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
 
isSlice() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
 
isSlice() - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
 
isSlow() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
 
isSlow() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
 
isSmallerOrEqualTo(ProtocolVersion) - Method in enum org.apache.cassandra.transport.ProtocolVersion
 
isSmallerThan(ProtocolVersion) - Method in enum org.apache.cassandra.transport.ProtocolVersion
 
isSnapshotBeforeCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isSorted() - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
 
isSorted() - Method in interface org.apache.cassandra.db.rows.Row.Builder
Whether the builder is a sorted one or not.
isSparse() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataTerm
 
ISSTableScanner - Interface in org.apache.cassandra.io.sstable
An ISSTableScanner is an abstraction allowing multiple SSTableScanners to be chained together under the hood.
isStale(Row, ByteBuffer, int) - Method in class org.apache.cassandra.index.internal.CassandraIndex
Check whether a value retrieved from an index is still valid by comparing it to current row from the base table.
isStale(Row, ByteBuffer, int) - Method in class org.apache.cassandra.index.internal.composites.ClusteringColumnIndex
 
isStale(Row, ByteBuffer, int) - Method in class org.apache.cassandra.index.internal.composites.CollectionEntryIndex
 
isStale(Row, ByteBuffer, int) - Method in class org.apache.cassandra.index.internal.composites.CollectionKeyIndex
 
isStale(Row, ByteBuffer, int) - Method in class org.apache.cassandra.index.internal.composites.CollectionValueIndex
 
isStale(Row, ByteBuffer, int) - Method in class org.apache.cassandra.index.internal.composites.PartitionKeyIndex
 
isStale(Row, ByteBuffer, int) - Method in class org.apache.cassandra.index.internal.composites.RegularColumnIndex
 
isStale(Row, ByteBuffer, int) - Method in class org.apache.cassandra.index.internal.keys.KeysIndex
 
isStart() - Method in enum org.apache.cassandra.cql3.statements.Bound
 
isStart() - Method in interface org.apache.cassandra.db.ClusteringBound
 
isStart() - Method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
 
isStarted() - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
isStartInclusive() - Method in class org.apache.cassandra.dht.AbstractBounds
 
isStartInclusive() - Method in class org.apache.cassandra.dht.Bounds
 
isStartInclusive() - Method in class org.apache.cassandra.dht.ExcludingBounds
 
isStartInclusive() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
isStartInclusive() - Method in class org.apache.cassandra.dht.Range
 
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.db.rows.AbstractRow
 
isStatic() - Method in interface org.apache.cassandra.db.rows.Row
Whether the row correspond to a static row or not.
isStatic(int) - Static method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
isStatic() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
isStaticCompactTable() - Method in class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
 
isStaticCompactTable(Set<TableMetadata.Flag>) - Static method in enum org.apache.cassandra.schema.TableMetadata.Flag
 
isStaticCompactTable() - Method in class org.apache.cassandra.schema.TableMetadata
 
isStaticName(V, ValueAccessor<V>) - 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
 
isStoredInLocalSystemKeyspacesDataLocation(String, String) - Static method in class org.apache.cassandra.db.Directories
Checks if the specified table should be stored with local system data.
isStreaming() - Method in enum org.apache.cassandra.net.ConnectionCategory
 
isStreaming() - Method in enum org.apache.cassandra.net.ConnectionType
 
isSubDirectory(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
isSubList(AbstractReplicaCollection.ReplicaList) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
 
isSubrangeRepair() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
isSuccess() - Method in class org.apache.cassandra.net.AsyncPromise
 
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.
isSufficientLiveReplicasForRead(AbstractReplicationStrategy, ConsistencyLevel, Endpoints<?>) - Static method in class org.apache.cassandra.locator.ReplicaPlans
 
isSuper() - Method in class org.apache.cassandra.auth.AuthenticatedUser
Checks the user's superuser status.
isSuper(RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
isSuper(RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
Return true if there exists a Role with the given name that also has superuser status.
isSuper - Variable in class org.apache.cassandra.auth.Role
 
isSuper(Set<TableMetadata.Flag>) - Static method in enum org.apache.cassandra.schema.TableMetadata.Flag
 
isSuperuser - Variable in class org.apache.cassandra.auth.jmx.AuthorizationProxy
 
isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
 
isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.INRestriction
 
isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
Check if this type of restriction is supported for by the specified index.
isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.NotNullRestriction
 
isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
 
isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
 
isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQRestriction
 
isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.INRestriction
 
isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IsNotNullRestriction
 
isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
Check if this type of restriction is supported by the specified index.
isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
 
isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
 
isSurveyMode() - Method in class org.apache.cassandra.service.StorageService
 
isSuspect - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
isSystem() - Method in class org.apache.cassandra.auth.AuthenticatedUser
Some internal operations are performed on behalf of Cassandra itself, in those cases the system user should be used where an identity is required see CreateRoleStatement#execute() and overrides of AlterSchemaStatement#createdResources()
isSystemKeyspace(String) - Static method in class org.apache.cassandra.schema.SchemaConstants
Checks if the keyspace is a system keyspace (local replicated or virtual).
isTableLevel() - Method in class org.apache.cassandra.auth.DataResource
 
isTerminal() - Method in interface org.apache.cassandra.cql3.Term
Whether that term is terminal (this is a shortcut for this instanceof Term.Terminal).
isTerminal() - Method in class org.apache.cassandra.cql3.Term.Terminal
 
isTerminated() - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
 
isTerminated() - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
isTestTableStatsHolder() - Method in class org.apache.cassandra.tools.nodetool.stats.TableStatsHolder
 
isThrowOnOverload() - Method in class org.apache.cassandra.transport.Connection
 
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
 
isTinyPool() - Method in class org.apache.cassandra.utils.memory.BufferPool.LocalPool
 
isTokenizing() - Method in class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
 
isTokenizing() - Method in class org.apache.cassandra.index.sasi.analyzer.DelimiterAnalyzer
 
isTokenizing() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
 
isTombstone() - Method in class org.apache.cassandra.db.rows.AbstractCell
 
isTombstone() - Method in class org.apache.cassandra.db.rows.Cell
Whether the cell is a tombstone or not.
isToolInitialized() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isTop() - Method in interface org.apache.cassandra.db.ClusteringPrefix
 
isTraceable() - Method in class org.apache.cassandra.transport.Message.Request
 
isTraceable() - Method in class org.apache.cassandra.transport.messages.BatchMessage
 
isTraceable() - Method in class org.apache.cassandra.transport.messages.ExecuteMessage
 
isTraceable() - Method in class org.apache.cassandra.transport.messages.PrepareMessage
 
isTraceable() - Method in class org.apache.cassandra.transport.messages.QueryMessage
 
isTraced() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
isTracing() - Static method in class org.apache.cassandra.tracing.Tracing
Indicates if the current thread's execution is being traced.
isTrackingRepairedStatus() - Method in class org.apache.cassandra.db.ReadExecutionController
 
isTransient - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
isTransient() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
isTransient - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
isTransient - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
isTransient() - Method in class org.apache.cassandra.locator.Replica
 
isTransientReplicationEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
IStreamReader - Interface in org.apache.cassandra.db.streaming
This is the interface is used by the streaming code read a SSTable stream off a channel.
isTTLSelectorFactory() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Checks if this factory creates TTL selectors instances.
isTuple() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
isTuple() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isTuple() - Method in class org.apache.cassandra.db.marshal.TupleType
 
isTuple() - Method in class org.apache.cassandra.db.marshal.UserType
 
isUDT() - Method in interface org.apache.cassandra.cql3.CQL3Type
 
isUDT() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
isUDT() - Method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
 
isUDT() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isUDT() - Method in class org.apache.cassandra.db.marshal.UserType
 
isUnlimited() - Method in class org.apache.cassandra.db.filter.DataLimits
 
isUnreadable(File) - Static method in class org.apache.cassandra.db.DisallowedDirectories
Tells whether or not the directory is disallowed for reads.
isUnrestricted() - Method in class org.apache.cassandra.db.DataRange
Whether this DataRange queries everything (has no restriction neither on the partition queried, nor within the queried partition).
isUnrestricted() - Method in class org.apache.cassandra.db.DataRange.Paging
 
isUnsafeSystem() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isUnused() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
isUnwritable(File) - Static method in class org.apache.cassandra.db.DisallowedDirectories
Tells whether or not the directory is disallowed for writes.
isUpdate() - Method in enum org.apache.cassandra.cql3.statements.StatementType
Checks if this type is an update.
isUpdate(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Checks if a context is an update (see createUpdate() for justification).
isUpgradingFromVersionLowerThan(CassandraVersion) - Method in class org.apache.cassandra.gms.Gossiper
Returns true if there are nodes on version lower than the provided version
isUpperSatisfiedBy(OnDiskIndex.DataTerm) - Method in class org.apache.cassandra.index.sasi.plan.Expression
 
isUserDefined - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
isUserDefined() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
 
isValid() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isValid(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
isValid(ByteBuffer, AbstractType<?>) - Static method in class org.apache.cassandra.index.sasi.utils.TypeUtil
 
isValid(ChannelProxy) - Method in class org.apache.cassandra.io.util.MmappedRegions
 
isValidFile(File) - Static method in class org.apache.cassandra.io.sstable.Descriptor
 
isValidName(String) - Static method in class org.apache.cassandra.schema.SchemaConstants
 
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
 
isValueCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.UserType
 
isValueCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.CollectionType
A version of isValueCompatibleWith() to deal with non-multicell (frozen) collections
isValueCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.ListType
 
isValueCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.MapType
 
isValueCompatibleWithFrozen(CollectionType<?>) - Method in class org.apache.cassandra.db.marshal.SetType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.AbstractType
Needed to handle ReversedType in value-compatibility checks.
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.BytesType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.CollectionType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.DateType
Deprecated.
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.DurationType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.LongType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TimestampType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TimeType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.TupleType
 
isValueCompatibleWithInternal(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
isVersion2x() - Static method in class org.apache.cassandra.hadoop.HadoopCompat
True if runtime Hadoop version is 2.x, false otherwise.
isView() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
isView() - Method in class org.apache.cassandra.schema.TableMetadata
 
isViewBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
isViewStatusReplicated(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
isVirtual() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
isVirtual() - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
isVirtual() - Method in class org.apache.cassandra.schema.TableMetadata
 
isVirtualSystemKeyspace(String) - Static method in class org.apache.cassandra.schema.SchemaConstants
Checks if the keyspace is a virtual system keyspace.
isVoid() - Method in class org.apache.cassandra.net.AsyncChannelPromise
 
isWellFormed(Object[], Comparator<? extends Object>) - Static method in class org.apache.cassandra.utils.btree.BTree
 
isWildcard() - Method in class org.apache.cassandra.cql3.selection.Selection
 
isWildcard() - Method in class org.apache.cassandra.db.filter.ColumnFilter
Checks if this ColumnFilter is for a wildcard query.
isWildcard() - Method in class org.apache.cassandra.db.filter.ColumnFilter.WildCardColumnFilter
 
isWindows - Static variable in class org.apache.cassandra.utils.FBUtilities
 
isWorthMergingForRangeQuery(ReplicaCollection<?>, ReplicaCollection<?>, ReplicaCollection<?>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
 
isWorthMergingForRangeQuery(ReplicaCollection<?>, ReplicaCollection<?>, ReplicaCollection<?>) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
isWorthMergingForRangeQuery(ReplicaCollection<?>, ReplicaCollection<?>, ReplicaCollection<?>) - 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
Whether the range queried by this DataRange actually wraps around.
isWrapAround(T, T) - Static method in class org.apache.cassandra.dht.Range
Tells if the given range is a wrap around.
isWrapAround() - Method in class org.apache.cassandra.dht.Range
 
isWritetime - Variable in class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL
 
isWritetimeSelectorFactory() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Checks if this factory creates writetime selectors instances.
iterable(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
 
iterable(Object[], BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
 
iterable(Object[], int, int, BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
 
iterator() - Method in class org.apache.cassandra.cql3.functions.types.UserType
Returns an iterator over the fields of this UDT.
iterator() - Method in class org.apache.cassandra.cql3.Operations
iterator() - Method in class org.apache.cassandra.db.Columns
Iterator over all the columns of this object.
iterator() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentReader
 
iterator() - Method in class org.apache.cassandra.db.compaction.CompactionTasks
 
iterator() - Method in class org.apache.cassandra.db.Directories.DataDirectories
 
iterator() - Method in class org.apache.cassandra.db.filter.RowFilter
 
iterator() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
iterator() - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
 
iterator() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
iterator(boolean) - Method in class org.apache.cassandra.db.RangeTombstoneList
 
iterator(Slice, boolean) - Method in class org.apache.cassandra.db.RangeTombstoneList
 
iterator() - Method in class org.apache.cassandra.db.RegularAndStaticColumns
 
iterator() - Method in class org.apache.cassandra.db.rows.BTreeRow
 
iterator() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
iterator(boolean) - Method in class org.apache.cassandra.db.rows.SerializationHelper
 
iterator() - Method in class org.apache.cassandra.db.streaming.ComponentManifest
 
iterator() - Method in class org.apache.cassandra.db.view.TableViews
 
iterator() - Method in class org.apache.cassandra.index.sasi.conf.view.View
 
iterator() - Method in class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
 
iterator() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
iterator() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.OnDiskSuperBlock
 
iterator() - Method in class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
 
iterator(Function<Long, DecoratedKey>) - Method in class org.apache.cassandra.index.sasi.disk.TokenTree
 
iterator() - Method in class org.apache.cassandra.index.sasi.disk.TokenTree.OnDiskToken
 
iterator(DecoratedKey, Slices, ColumnFilter, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
 
iterator(FileDataInput, DecoratedKey, RowIndexEntry, Slices, ColumnFilter, boolean) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
 
iterator - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
iterator(DecoratedKey, Slices, ColumnFilter, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
iterator(FileDataInput, DecoratedKey, RowIndexEntry, Slices, ColumnFilter, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
iterator - Variable in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
iterator() - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
 
iterator() - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
 
iterator() - Method in class org.apache.cassandra.locator.PendingRangeMaps
 
iterator() - Method in interface org.apache.cassandra.locator.ReplicaCollection
 
iterator() - Method in class org.apache.cassandra.repair.consistent.admin.SchemaArgsParser
 
iterator() - Method in class org.apache.cassandra.schema.Functions
 
iterator() - Method in class org.apache.cassandra.schema.Indexes
 
iterator() - Method in class org.apache.cassandra.schema.Keyspaces
 
iterator() - Method in class org.apache.cassandra.schema.Tables
 
iterator() - Method in class org.apache.cassandra.schema.Triggers
 
iterator() - Method in class org.apache.cassandra.schema.Types
 
iterator() - Method in class org.apache.cassandra.schema.Views
 
iterator() - Method in class org.apache.cassandra.tools.nodetool.SetHostStat
 
iterator() - Method in class org.apache.cassandra.tools.nodetool.SetHostStatWithPort
 
iterator(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
 
iterator(Object[], BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
 
iterator(Object[], int, int, BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
 
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.concurrent.WeightedQueue
 
iterator() - Method in class org.apache.cassandra.utils.IntervalTree
 
iterator() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRangeIterator
 
iterator() - Method in class org.apache.cassandra.utils.MerkleTrees
Get an iterator of all ranges and their MerkleTrees.
iterator() - Method in class org.apache.cassandra.utils.MerkleTrees.TreeRangeIterator
 
iteratorAt(ByteBuffer, OnDiskIndex.IteratorOrder, boolean) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
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
 
iteratorType - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
 
IteratorWithLowerBound<In> - Interface in org.apache.cassandra.utils
 
iterToStream(Iterator<T>) - Static method in class org.apache.cassandra.tools.Util
 
ITrigger - Interface in org.apache.cassandra.triggers
Trigger interface, For every partition update received by the coordinator ITrigger.augment(Partition) is called.
iv_length - Variable in class org.apache.cassandra.config.TransparentDataEncryptionOptions
 
IVerbHandler<T> - Interface in org.apache.cassandra.net
IVerbHandler provides the method that all verb handlers need to implement.
IVersionedAsymmetricSerializer<In,Out> - Interface in org.apache.cassandra.io
 
IVersionedSerializer<T> - Interface in org.apache.cassandra.io
 

J

JAVA_UDF_NAME - Static variable in class org.apache.cassandra.cql3.functions.UDFByteCodeVerifier
 
JavaBasedUDFunction - Class in org.apache.cassandra.cql3.functions
 
javaSourceName(TypeToken<?>) - Static method in class org.apache.cassandra.cql3.functions.JavaBasedUDFunction
 
JavaUDF - Class in org.apache.cassandra.cql3.functions
Base class for all Java UDFs.
JavaUDF(TypeCodec<Object>, TypeCodec<Object>[], UDFContext) - Constructor for class org.apache.cassandra.cql3.functions.JavaUDF
 
JavaUtils - Class in org.apache.cassandra.utils
Utility method to retrieve information about the JRE.
JKSKeyProvider - Class in org.apache.cassandra.security
A KeyProvider that retrieves keys from a java keystore.
JKSKeyProvider(TransparentDataEncryptionOptions) - Constructor for class org.apache.cassandra.security.JKSKeyProvider
 
JMXBroadcastExecutor - Class in org.apache.cassandra.utils.progress.jmx
Holds dedicated executor for JMX event handling.
jmxc - Variable in class org.apache.cassandra.tools.NodeProbe
 
jmxConn - Variable in class org.apache.cassandra.tools.AbstractJmxClient
 
JMXEnabledSingleThreadExecutor - Class in org.apache.cassandra.concurrent
 
JMXEnabledSingleThreadExecutor(String, String) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledSingleThreadExecutor
 
JMXEnabledThreadPoolExecutor - Class in org.apache.cassandra.concurrent
This is a wrapper class for the ScheduledThreadPoolExecutor.
JMXEnabledThreadPoolExecutor(String) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(String, String) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(String, int) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(NamedThreadFactory, String) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(int, long, TimeUnit, BlockingQueue<Runnable>, NamedThreadFactory, String) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, NamedThreadFactory, String) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, NamedThreadFactory, String, RejectedExecutionHandler) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutorMBean - Interface in org.apache.cassandra.concurrent
 
jmxName - Variable in enum org.apache.cassandra.concurrent.Stage
 
JMXNotificationProgressListener - Class in org.apache.cassandra.utils.progress.jmx
JMXNotificationProgressListener uses JMX Notification API to convert JMX Notification message to progress event and notifies its ProgressListeners.
JMXNotificationProgressListener() - Constructor for class org.apache.cassandra.utils.progress.jmx.JMXNotificationProgressListener
 
JMXProgressSupport - Class in org.apache.cassandra.utils.progress.jmx
ProgressListener that translates ProgressEvent to JMX Notification message.
JMXProgressSupport(NotificationBroadcasterSupport) - Constructor for class org.apache.cassandra.utils.progress.jmx.JMXProgressSupport
 
JMXResource - Class in org.apache.cassandra.auth
 
JMXServerUtils - Class in org.apache.cassandra.utils
 
JMXServerUtils() - Constructor for class org.apache.cassandra.utils.JMXServerUtils
 
JMXTool - Class in org.apache.cassandra.tools
 
JMXTool() - Constructor for class org.apache.cassandra.tools.JMXTool
 
JMXTool.Attribute - Class in org.apache.cassandra.tools
 
JMXTool.CliPattern - Class in org.apache.cassandra.tools
 
JMXTool.Diff - Class in org.apache.cassandra.tools
 
JMXTool.Diff.Format - Enum in org.apache.cassandra.tools
 
JMXTool.Dump - Class in org.apache.cassandra.tools
 
JMXTool.Dump.Format - Enum in org.apache.cassandra.tools
 
JMXTool.Info - Class in org.apache.cassandra.tools
 
JMXTool.Operation - Class in org.apache.cassandra.tools
 
JMXTool.Parameter - Class in org.apache.cassandra.tools
 
jnaMemoryLockable() - Static method in class org.apache.cassandra.utils.NativeLibrary
 
JOB_THREADS_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
Join - Class in org.apache.cassandra.tools.nodetool
 
Join() - Constructor for class org.apache.cassandra.tools.nodetool.Join
 
joinRing() - Method in class org.apache.cassandra.service.StorageService
 
joinRing() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
joinRing() - Method in class org.apache.cassandra.tools.NodeProbe
 
joinTokenRing(boolean, boolean, long, long) - Method in class org.apache.cassandra.service.StorageService
 
Json - Class in org.apache.cassandra.cql3
Term-related classes for INSERT JSON support.
Json() - Constructor for class org.apache.cassandra.cql3.Json
 
json(Object) - Static method in class org.apache.cassandra.utils.FBUtilities
 
Json.Literal - Class in org.apache.cassandra.cql3
Represents a literal JSON string in an INSERT JSON statement.
Json.Marker - Class in org.apache.cassandra.cql3
Represents a marker for a JSON string in an INSERT JSON statement.
Json.Prepared - Class in org.apache.cassandra.cql3
A prepared, full set of JSON values.
Json.Raw - Interface in org.apache.cassandra.cql3
 
JSON_COLUMN_ID - Static variable in class org.apache.cassandra.cql3.Json
 
JSON_OBJECT_MAPPER - Static variable in class org.apache.cassandra.cql3.Json
 
JsonPrinter() - Constructor for class org.apache.cassandra.tools.nodetool.stats.StatsPrinter.JsonPrinter
 
JsonTransformer - Class in org.apache.cassandra.tools
 
JVMStabilityInspector - Class in org.apache.cassandra.utils
Responsible for deciding whether to kill the JVM if it gets in an "unstable" state (think OOM).
JVMStabilityInspector.Killer - Class in org.apache.cassandra.utils
 
JVMStabilityInspector.OnKillHook - Interface in org.apache.cassandra.utils
This class is usually used to avoid JVM exit when running junit tests.

K

keep(Set<InetAddressAndPort>) - Method in class org.apache.cassandra.locator.Endpoints
 
KEEP_ALIVE_SECONDS - Static variable in enum org.apache.cassandra.concurrent.Stage
 
KeepAliveMessage - Class in org.apache.cassandra.streaming.messages
 
KeepAliveMessage() - Constructor for class org.apache.cassandra.streaming.messages.KeepAliveMessage
 
keepOriginals - Variable in class org.apache.cassandra.db.compaction.CompactionTask
 
key - Variable in class org.apache.cassandra.cache.KeyCacheKey
 
key - Variable in class org.apache.cassandra.cache.RowCacheKey
 
key - Variable in class org.apache.cassandra.cql3.statements.CQL3CasRequest
 
key - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
key() - Method in class org.apache.cassandra.db.CounterMutation
 
key() - Method in interface org.apache.cassandra.db.IMutation
 
key() - Method in class org.apache.cassandra.db.Mutation
 
key() - Method in class org.apache.cassandra.db.Mutation.PartitionUpdateCollector
 
key - Variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer.Header
 
key() - Method in interface org.apache.cassandra.db.virtual.AbstractVirtualTable.Partition
 
key() - Method in class org.apache.cassandra.db.virtual.VirtualMutation
 
key() - Method in class org.apache.cassandra.service.pager.SinglePartitionPager
 
key_alias - Variable in class org.apache.cassandra.config.TransparentDataEncryptionOptions
 
key_cache_keys_to_save - Variable in class org.apache.cassandra.config.Config
 
key_cache_migrate_during_compaction - Variable in class org.apache.cassandra.config.Config
 
key_cache_save_period - Variable in class org.apache.cassandra.config.Config
 
key_cache_size_in_mb - Variable in class org.apache.cassandra.config.Config
 
key_provider - Variable in class org.apache.cassandra.config.TransparentDataEncryptionOptions
 
KeyAnalyzer<K> - Interface in org.apache.cassandra.index.sasi.utils.trie
The KeyAnalyzer provides bit-level access to keys for the PatriciaTrie.
keyAt(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
keyCache - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
keyCache - Variable in class org.apache.cassandra.service.CacheService
 
keyCacheHit - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
keyCacheHitRate - Variable in class org.apache.cassandra.metrics.TableMetrics
Key cache hit rate for this CF
KeyCacheKey - Class in org.apache.cassandra.cache
 
KeyCacheKey(TableMetadata, Descriptor, ByteBuffer) - Constructor for class org.apache.cassandra.cache.KeyCacheKey
 
keyCacheRequest - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
KeyCacheSerializer() - Constructor for class org.apache.cassandra.service.CacheService.KeyCacheSerializer
 
keyCount - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
keyFetcher - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
keyForToken(Murmur3Partitioner.LongToken) - Static method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
Reverses murmur3 to find a possible 16 byte key that generates a given token
keyHosts() - Method in class org.apache.cassandra.repair.asymmetric.DifferenceHolder
differences only holds one 'side' of the difference - if A and B mismatch, only A will be a key in the map
keyIsInRelation() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the restrictions on the partition key has IN restrictions.
keyIterator() - Method in class org.apache.cassandra.cache.CaffeineCache
 
keyIterator() - Method in interface org.apache.cassandra.cache.ICache
 
keyIterator() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
keyIterator() - Method in class org.apache.cassandra.cache.SerializingCache
 
KeyIterator - Class in org.apache.cassandra.io.sstable
 
KeyIterator(Descriptor, TableMetadata) - Constructor for class org.apache.cassandra.io.sstable.KeyIterator
 
KeyProvider - Interface in org.apache.cassandra.security
Customizable key retrieval mechanism.
keyRange - Variable in class org.apache.cassandra.db.DataRange
 
keyRange() - Method in class org.apache.cassandra.db.DataRange
The range of partition key queried by this DataRange.
KeyRangeIterator - Class in org.apache.cassandra.index.sasi.memory
 
KeyRangeIterator(ConcurrentSkipListSet<DecoratedKey>, int) - Constructor for class org.apache.cassandra.index.sasi.memory.KeyRangeIterator
 
keys - Variable in class org.apache.cassandra.serializers.MapSerializer
 
KEYS_INDEX_FUNCTIONS - Static variable in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
 
keySamples(Range<Token>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
keysAndValuesOf(ColumnIdentifier) - Static method in class org.apache.cassandra.cql3.statements.schema.IndexTarget.Raw
 
KeyScanningIterator() - Constructor for class org.apache.cassandra.io.sstable.format.big.BigTableScanner.KeyScanningIterator
 
keySet() - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaMap
 
keySet() - Method in class org.apache.cassandra.locator.ReplicaMultimap
 
keySet() - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
 
keySet() - Method in class org.apache.cassandra.utils.BiMultiValMap
 
keySet() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
KeysIndex - Class in org.apache.cassandra.index.internal.keys
 
KeysIndex(ColumnFamilyStore, IndexMetadata) - Constructor for class org.apache.cassandra.index.internal.keys.KeysIndex
 
keysOf(ColumnIdentifier) - Static method in class org.apache.cassandra.cql3.statements.schema.IndexTarget.Raw
 
keyspace - Variable in class org.apache.cassandra.audit.AuditLogContext
 
keyspace(String) - Static method in class org.apache.cassandra.auth.DataResource
Creates a DataResource representing a keyspace.
keyspace(String) - Static method in class org.apache.cassandra.auth.FunctionResource
Creates a FunctionResource representing the collection of functions scoped to a specific keyspace.
keyspace() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
keyspace - Variable in class org.apache.cassandra.cql3.functions.FunctionName
 
keyspace(String, boolean) - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
Creates a DescribeStatement for DESCRIBE KEYSPACE.
keyspace() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
keyspace() - Method in class org.apache.cassandra.cql3.statements.QualifiedStatement
 
keyspace() - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
 
keyspace(String) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
 
keyspace() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
keyspace - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
KEYSPACE - Static variable in class org.apache.cassandra.db.compaction.CompactionInfo
 
Keyspace - Class in org.apache.cassandra.db
It represents a Keyspace.
keyspace - Variable in class org.apache.cassandra.db.marshal.UserType
 
keyspace - Variable in class org.apache.cassandra.db.SnapshotCommand
 
keyspace - Variable in class org.apache.cassandra.db.TruncateRequest
 
keyspace - Variable in class org.apache.cassandra.db.TruncateResponse
 
KEYSPACE - Static variable in class org.apache.cassandra.fql.FullQueryLogger
 
keyspace - Variable in class org.apache.cassandra.locator.ReplicaPlan
 
keyspace() - Method in class org.apache.cassandra.locator.ReplicaPlan
 
keyspace - Variable in class org.apache.cassandra.repair.consistent.admin.CleanupSummary
 
keyspace - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStats
 
keyspace - Variable in class org.apache.cassandra.repair.consistent.admin.RepairStats
 
keyspace - Variable in class org.apache.cassandra.repair.RepairJobDesc
 
keyspace - Variable in class org.apache.cassandra.repair.RepairSession
 
keyspace - Variable in class org.apache.cassandra.repair.RepairSessionResult
 
keyspace - Variable in class org.apache.cassandra.schema.TableMetadata
 
keyspace - Variable in class org.apache.cassandra.schema.TableMetadataRef
 
keyspace() - Method in class org.apache.cassandra.schema.ViewMetadata
 
keyspace - Variable in class org.apache.cassandra.streaming.StreamRequest
 
KEYSPACE - Static variable in class org.apache.cassandra.transport.ConnectedClient
 
keyspace() - Method in class org.apache.cassandra.transport.ConnectedClient
 
keyspace - Variable in class org.apache.cassandra.transport.Event.SchemaChange
 
keyspace - Variable in class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
 
keyspace_count_warn_threshold - Variable in class org.apache.cassandra.config.Config
 
KeyspaceAttributes - Class in org.apache.cassandra.cql3.statements.schema
 
KeyspaceAttributes() - Constructor for class org.apache.cassandra.cql3.statements.schema.KeyspaceAttributes
 
keyspaceCountWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
KeyspaceMetadata - Class in org.apache.cassandra.schema
An immutable representation of keyspace metadata (name, params, tables, types, and functions).
KeyspaceMetadata.KeyspaceDiff - Class in org.apache.cassandra.schema
 
KeyspaceMetadata.Kind - Enum in org.apache.cassandra.schema
 
KeyspaceMetrics - Class in org.apache.cassandra.metrics
Metrics for ColumnFamilyStore.
KeyspaceMetrics(Keyspace) - Constructor for class org.apache.cassandra.metrics.KeyspaceMetrics
Creates metrics for given ColumnFamilyStore.
keyspaceName - Variable in class org.apache.cassandra.cql3.statements.schema.CreateKeyspaceStatement.Raw
 
keyspaceName - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
keyspaceName - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
KeyspaceNotDefinedException - Exception in org.apache.cassandra.db
 
KeyspaceNotDefinedException(String) - Constructor for exception org.apache.cassandra.db.KeyspaceNotDefinedException
 
KeyspaceParams - Class in org.apache.cassandra.schema
An immutable class representing keyspace parameters (durability and replication).
KeyspaceParams(boolean, ReplicationParams) - Constructor for class org.apache.cassandra.schema.KeyspaceParams
 
KeyspaceParams.Option - Enum in org.apache.cassandra.schema
 
KeyspaceRepairManager - Interface in org.apache.cassandra.repair
Keyspace level hook for repair.
KEYSPACES - Static variable in class org.apache.cassandra.auth.Resources
Deprecated.
keyspaces() - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
Creates a DescribeStatement for DESCRIBE KEYSPACES.
Keyspaces - Class in org.apache.cassandra.schema
 
KEYSPACES - Static variable in class org.apache.cassandra.schema.SchemaKeyspace
 
keyspaces - Variable in class org.apache.cassandra.tools.nodetool.stats.TableStatsHolder
 
Keyspaces.Builder - Class in org.apache.cassandra.schema
 
Keyspaces.KeyspacesDiff - Class in org.apache.cassandra.schema
 
KeyspaceWriteHandler - Interface in org.apache.cassandra.db
 
keySpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Maps
 
KeysSearcher - Class in org.apache.cassandra.index.internal.keys
 
KeysSearcher(ReadCommand, RowFilter.Expression, CassandraIndex) - Constructor for class org.apache.cassandra.index.internal.keys.KeysSearcher
 
keysToJson(ISSTableScanner, Stream<DecoratedKey>, boolean, TableMetadata, OutputStream) - Static method in class org.apache.cassandra.tools.JsonTransformer
 
keystore - Variable in class org.apache.cassandra.config.EncryptionOptions
 
keystore_password - Variable in class org.apache.cassandra.config.EncryptionOptions
 
keyType() - Method in class org.apache.cassandra.db.SerializationHeader
 
keyValidator() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
keyValidator - Variable in class org.apache.cassandra.index.sasi.memory.MemIndex
 
killCurrentJVM(Throwable, boolean) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
 
killCurrentJVM(Throwable) - Method in class org.apache.cassandra.utils.JVMStabilityInspector.Killer
Certain situations represent "Die" conditions for the server, and if so, the reason is logged and the current JVM is killed.
killCurrentJVM(Throwable, boolean) - Method in class org.apache.cassandra.utils.JVMStabilityInspector.Killer
 
Killer() - Constructor for class org.apache.cassandra.utils.JVMStabilityInspector.Killer
 
killerHook - Static variable in class org.apache.cassandra.utils.JVMStabilityInspector
 
kind - Variable in class org.apache.cassandra.db.AbstractOnHeapClusteringPrefix
 
kind() - Method in class org.apache.cassandra.db.AbstractOnHeapClusteringPrefix
 
kind() - Method in class org.apache.cassandra.db.aggregation.AggregationSpecification
Returns the AggregationSpecification kind.
kind() - Method in interface org.apache.cassandra.db.ClusteringPrefix
 
kind() - Method in class org.apache.cassandra.db.DecoratedKey
 
kind() - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
 
kind() - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
 
kind() - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
 
kind() - Method in class org.apache.cassandra.db.filter.ColumnSubselection
 
kind() - Method in class org.apache.cassandra.db.filter.DataLimits
 
kind() - Method in class org.apache.cassandra.db.filter.RowFilter.CustomExpression
 
kind() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
 
kind() - Method in class org.apache.cassandra.db.filter.RowFilter.SimpleExpression
 
kind() - Method in class org.apache.cassandra.db.filter.RowFilter.UserExpression
 
kind - Variable in class org.apache.cassandra.db.marshal.CollectionType
 
kind() - Method in class org.apache.cassandra.db.NativeClustering
 
kind() - Method in interface org.apache.cassandra.db.PartitionPosition
 
kind() - Method in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
 
kind() - Method in class org.apache.cassandra.db.rows.AbstractRow
 
kind() - Method in interface org.apache.cassandra.db.rows.Unfiltered
The kind of the atom: either row or range tombstone marker.
kind(int) - Static method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
kind() - Method in class org.apache.cassandra.dht.Token.KeyBound
 
kind - Variable in enum org.apache.cassandra.net.Verb
 
kind - Variable in class org.apache.cassandra.schema.ColumnMetadata
 
kind - Variable in class org.apache.cassandra.schema.Diff.Altered
 
kind - Variable in class org.apache.cassandra.schema.IndexMetadata
 
kind - Variable in class org.apache.cassandra.schema.KeyspaceMetadata
 
kind(TableMetadata.Kind) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
kind - Variable in class org.apache.cassandra.schema.TableMetadata
 
kind() - Method in class org.apache.cassandra.service.reads.AlwaysSpeculativeRetryPolicy
 
kind() - Method in class org.apache.cassandra.service.reads.FixedSpeculativeRetryPolicy
 
kind() - Method in class org.apache.cassandra.service.reads.HybridSpeculativeRetryPolicy
 
kind() - Method in class org.apache.cassandra.service.reads.NeverSpeculativeRetryPolicy
 
kind() - Method in class org.apache.cassandra.service.reads.PercentileSpeculativeRetryPolicy
 
kind() - Method in interface org.apache.cassandra.service.reads.SpeculativeRetryPolicy
 
kind - Variable in class org.apache.cassandra.transport.messages.ResultMessage
 
klass() - Method in class org.apache.cassandra.schema.CompactionParams
 
klass() - Method in class org.apache.cassandra.schema.CompressionParams
 
klass - Variable in class org.apache.cassandra.schema.ReplicationParams
 
knows(InetAddressAndPort) - Method in class org.apache.cassandra.net.EndpointMessagingVersions
 
ksName - Variable in class org.apache.cassandra.cql3.ColumnSpecification
 
ksName - Variable in exception org.apache.cassandra.exceptions.AlreadyExistsException
 
ksname - Variable in class org.apache.cassandra.io.sstable.Descriptor
 

L

LANDMARK_RESET_INTERVAL_IN_MS - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
language - Variable in class org.apache.cassandra.cql3.functions.UDFunction
 
language() - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
large - Variable in class org.apache.cassandra.net.OutboundConnections
 
LARGE_MESSAGE_THRESHOLD - Static variable in class org.apache.cassandra.net.OutboundConnections
 
LARGE_MESSAGE_THRESHOLD - Static variable in class org.apache.cassandra.transport.CQLMessageHandler
 
largeMessage - Variable in class org.apache.cassandra.net.AbstractMessageHandler
 
LargeMessage(int, H, long, boolean) - Constructor for class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
 
LargeMessage(int, H, long, ShareableBytes) - Constructor for class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
 
largeMessageCompletedBytes - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Completed bytes for large message TCP Connections
largeMessageCompletedTasks - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Completed tasks for large message TCP Connections
largeMessageDropped - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped tasks for large message TCP Connections
largeMessageDroppedBytesDueToError - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped bytes because of error for large message TCP Connections
largeMessageDroppedBytesDueToOverload - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped bytes because of overload for large message TCP Connections
largeMessageDroppedBytesDueToTimeout - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped bytes because of timeout for large message TCP Connections
largeMessageDroppedTasksDueToError - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped tasks because of error for large message TCP Connections
largeMessageDroppedTasksDueToOverload - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped tasks because of overload for large message TCP Connections
largeMessageDroppedTasksDueToTimeout - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped tasks because of timeout for large message TCP Connections
largeMessagePendingBytes - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Pending bytes for large message TCP Connections
largeMessagePendingTasks - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Pending tasks for large message TCP Connections
largeMessageThreshold(int) - Method in class org.apache.cassandra.transport.SimpleClient.Builder
 
largestToken() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
 
largeThreshold - Variable in class org.apache.cassandra.net.AbstractMessageHandler
 
last - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
last - Variable in class org.apache.cassandra.io.sstable.SSTable
 
last() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
LAST_LEAF_SHIFT - Static variable in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
LAST_SEEN_TIME - Static variable in class org.apache.cassandra.transport.ClientStat
 
LAST_UPDATE - Static variable in class org.apache.cassandra.repair.consistent.LocalSessionInfo
 
LastCommitLogPosition(CommitLogPosition) - Constructor for class org.apache.cassandra.db.Memtable.LastCommitLogPosition
 
LastEventIdBroadcasterMBean - Interface in org.apache.cassandra.diag
Provides a list of event types and the corresponding highest event IDs.
lastFlushOffset - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
lastIndexOf(Object) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
lastIndexOf(ByteBuffer, byte, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
ByteBuffer adaptation of org.apache.commons.lang3.ArrayUtils.lastIndexOf method
lastKey() - Method in class org.apache.cassandra.index.sasi.utils.trie.PatriciaTrie
 
lastKey - Variable in class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
 
lastName - Variable in class org.apache.cassandra.io.sstable.IndexInfo
 
lastRow() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
lastRow() - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
 
lastRow() - Method in interface org.apache.cassandra.db.partitions.CachedPartition
The last row in this cached partition (in order words, the row with the biggest clustering that the partition contains).
lastSyncedAt - Variable in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
 
lastWriteFuture - Variable in class org.apache.cassandra.transport.SimpleClient
 
latch - Variable in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
 
latency - Variable in class org.apache.cassandra.metrics.LatencyMetrics
Latency
LatencyConsumer - Interface in org.apache.cassandra.net
 
LatencyMetrics - Class in org.apache.cassandra.metrics
Metrics about latencies
LatencyMetrics(String, String) - Constructor for class org.apache.cassandra.metrics.LatencyMetrics
Create LatencyMetrics with given group, type, and scope.
LatencyMetrics(String, String, String) - Constructor for class org.apache.cassandra.metrics.LatencyMetrics
Create LatencyMetrics with given group, type, prefix to append to each metric name, and scope.
LatencyMetrics(MetricNameFactory, String) - Constructor for class org.apache.cassandra.metrics.LatencyMetrics
Create LatencyMetrics with given group, type, prefix to append to each metric name, and scope.
LatencyMetrics(MetricNameFactory, MetricNameFactory, String) - Constructor for class org.apache.cassandra.metrics.LatencyMetrics
 
LatencyMetrics(MetricNameFactory, String, LatencyMetrics...) - Constructor for class org.apache.cassandra.metrics.LatencyMetrics
Create LatencyMetrics with given group, type, prefix to append to each metric name, and scope.
LatencyMetrics.LatencyMetricsTimer - Class in org.apache.cassandra.metrics
 
LatencyMetricsTimer(Reservoir) - Constructor for class org.apache.cassandra.metrics.LatencyMetrics.LatencyMetricsTimer
 
LatencySubscribers - Class in org.apache.cassandra.net
Callback that DynamicEndpointSnitch listens to in order to update host scores.
LatencySubscribers() - Constructor for class org.apache.cassandra.net.LatencySubscribers
 
latencySubscribers - Variable in class org.apache.cassandra.net.MessagingService
 
LatencySubscribers.Subscriber - Interface in org.apache.cassandra.net
 
latestVersion - Static variable in class org.apache.cassandra.io.sstable.format.big.BigFormat
 
LazilyInitializedUnfilteredRowIterator - Class in org.apache.cassandra.db.rows
Abstract class to create UnfilteredRowIterator that lazily initialize themselves.
LazilyInitializedUnfilteredRowIterator(DecoratedKey) - Constructor for class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
 
lcs(Map<String, String>) - Static method in class org.apache.cassandra.schema.CompactionParams
 
Leaf(Long, Long) - Constructor for class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf
 
LeafBTreeSearchIterator<K,V> - Class in org.apache.cassandra.utils.btree
 
LeafBTreeSearchIterator(Object[], Comparator<? super K>, BTree.Dir) - Constructor for class org.apache.cassandra.utils.btree.LeafBTreeSearchIterator
 
LeafEntry(long) - Constructor for class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf.LeafEntry
 
leaving(Collection<Token>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
left - Variable in class org.apache.cassandra.dht.AbstractBounds
 
left() - Method in class org.apache.cassandra.dht.Splitter.WeightedRange
 
left(Collection<Token>, long) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
left - Variable in class org.apache.cassandra.index.sasi.plan.Operation.Builder
 
left - Variable in class org.apache.cassandra.index.sasi.plan.Operation
 
left - Variable in class org.apache.cassandra.utils.Pair
 
left() - Method in class org.apache.cassandra.utils.Pair
 
leftBoundary() - Method in class org.apache.cassandra.dht.AbstractBounds
 
leftmostLeaf - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
 
LEGACY_AUTH_TABLES - Static variable in class org.apache.cassandra.schema.SchemaConstants
 
LEGACY_AVAILABLE_RANGES - Static variable in class org.apache.cassandra.db.SystemKeyspace
Deprecated.
LEGACY_PEER_EVENTS - Static variable in class org.apache.cassandra.db.SystemKeyspace
Deprecated.
LEGACY_PEERS - Static variable in class org.apache.cassandra.db.SystemKeyspace
Deprecated.
LEGACY_SIZE_ESTIMATES - Static variable in class org.apache.cassandra.db.SystemKeyspace
Deprecated.
LEGACY_TRANSFERRED_RANGES - Static variable in class org.apache.cassandra.db.SystemKeyspace
Deprecated.
legacyAuthenticate(Map<String, String>) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
legacyAuthenticate(Map<String, String>) - Method in interface org.apache.cassandra.auth.IAuthenticator
A legacy method that is still used by JMX authentication.
legacyAuthenticate(Map<String, String>) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
length() - Method in class org.apache.cassandra.index.sasi.sa.ByteTerm
 
length() - Method in class org.apache.cassandra.index.sasi.sa.CharTerm
 
length() - Method in class org.apache.cassandra.index.sasi.sa.Term
 
length - Variable in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
 
length() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
length() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
length() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
LENGTH - Static variable in class org.apache.cassandra.transport.Envelope.Header
 
LENGTH - Static variable in class org.apache.cassandra.utils.CounterId
 
LengthAvailableInputStream - Class in org.apache.cassandra.io.util
a FilterInputStream that returns the remaining bytes to read from available() regardless of whether the device is ready to provide them.
LengthAvailableInputStream(InputStream, long) - Constructor for class org.apache.cassandra.io.util.LengthAvailableInputStream
 
lengthInBits(K) - Method in interface org.apache.cassandra.index.sasi.utils.trie.KeyAnalyzer
Returns the key's length in bits.
level - Variable in class org.apache.cassandra.db.compaction.LeveledManifest.CompactionCandidate
 
Level(long, int) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskIndex.Level
 
LeveledCompactionStrategy - Class in org.apache.cassandra.db.compaction
 
LeveledCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
LeveledCompactionTask - Class in org.apache.cassandra.db.compaction
 
LeveledCompactionTask(ColumnFamilyStore, LifecycleTransaction, int, int, long, boolean) - Constructor for class org.apache.cassandra.db.compaction.LeveledCompactionTask
 
LeveledManifest - Class in org.apache.cassandra.db.compaction
 
LeveledManifest.CompactionCandidate - Class in org.apache.cassandra.db.compaction
 
levelIterator() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
 
levels - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
LexicalUUIDType - Class in org.apache.cassandra.db.marshal
 
LifecycleNewTracker - Interface in org.apache.cassandra.db.lifecycle
An interface for tracking new sstables added to a LifecycleTransaction, possibly through some proxy.
LifecycleTransaction - Class in org.apache.cassandra.db.lifecycle
IMPORTANT: When this object is involved in a transactional graph, for correct behaviour its commit MUST occur before any others, since it may legitimately fail.
LifecycleTransaction.ReaderState - Class in org.apache.cassandra.db.lifecycle
 
LifecycleTransaction.ReaderState.Action - Enum in org.apache.cassandra.db.lifecycle
 
LikeRestriction(ColumnMetadata, Operator, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
 
limit - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
 
limit(long) - Method in class org.apache.cassandra.hints.ChecksummedDataInput
 
limit() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
limit(long) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
limit() - Method in class org.apache.cassandra.net.ResourceLimits.Basic
 
limit() - Method in class org.apache.cassandra.net.ResourceLimits.Concurrent
 
limit() - Method in interface org.apache.cassandra.net.ResourceLimits.Limit
 
limit - Variable in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
 
limiter - Variable in class org.apache.cassandra.db.streaming.CassandraStreamWriter
 
LimitingRebufferer - Class in org.apache.cassandra.io.util
Rebufferer wrapper that applies rate limiting.
LimitingRebufferer(Rebufferer, RateLimiter, int) - Constructor for class org.apache.cassandra.io.util.LimitingRebufferer
 
limits() - Method in interface org.apache.cassandra.db.ReadQuery
The limits for the query.
limits() - Method in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
 
limits() - Method in class org.apache.cassandra.service.pager.SinglePartitionPager
 
list(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
list(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
list(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
Returns a list of permissions on a resource granted to a role.
list(CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
list(DataType, boolean) - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the type of lists of elementType elements.
list(DataType) - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the type of "not frozen" lists of elementType elements.
list(TypeCodec<T>) - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return a newly-created codec for the CQL type list whose element type is determined by the given element codec.
list() - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
list - Variable in class org.apache.cassandra.locator.AbstractReplicaCollection
 
ListCmd() - Constructor for class org.apache.cassandra.tools.nodetool.RepairAdmin.ListCmd
 
listen() - Method in class org.apache.cassandra.net.MessagingService
 
listen_address - Variable in class org.apache.cassandra.config.Config
 
listen_interface - Variable in class org.apache.cassandra.config.Config
 
listen_interface_prefer_ipv6 - Variable in class org.apache.cassandra.config.Config
 
listen_on_broadcast_address - Variable in class org.apache.cassandra.config.Config
 
listenerCount() - Method in class org.apache.cassandra.auth.AuthEvents
 
listenerCount() - Method in class org.apache.cassandra.cql3.QueryEvents
 
listeners(StreamEventHandler, StreamEventHandler...) - Method in class org.apache.cassandra.streaming.StreamPlan
 
listEphemeralSnapshots() - Method in class org.apache.cassandra.db.Directories
 
listFiles() - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
listIndexes() - Method in interface org.apache.cassandra.index.IndexRegistry
 
listIndexes() - Method in class org.apache.cassandra.index.SecondaryIndexManager
 
Listing(Function<KeyspaceMetadata, Stream<? extends SchemaElement>>) - Constructor for class org.apache.cassandra.cql3.statements.DescribeStatement.Listing
 
listIterator() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
listIterator(int) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
listOf(Class<T>) - Static method in class org.apache.cassandra.cql3.functions.types.TypeTokens
Create a TypeToken that represents a List whose elements are of the given type.
listOf(TypeToken<T>) - Static method in class org.apache.cassandra.cql3.functions.types.TypeTokens
Create a TypeToken that represents a List whose elements are of the given type.
ListPermissionsStatement - Class in org.apache.cassandra.cql3.statements
 
ListPermissionsStatement(Set<Permission>, IResource, RoleName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
ListRolesStatement - Class in org.apache.cassandra.cql3.statements
 
ListRolesStatement() - Constructor for class org.apache.cassandra.cql3.statements.ListRolesStatement
 
ListRolesStatement(RoleName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.ListRolesStatement
 
Lists - Class in org.apache.cassandra.cql3
Static helper methods and classes for lists.
Lists.Appender - Class in org.apache.cassandra.cql3
 
Lists.DelayedValue - Class in org.apache.cassandra.cql3
Basically similar to a Value, but with some non-pure function (that need to be evaluated at execution time) in it.
Lists.Discarder - Class in org.apache.cassandra.cql3
 
Lists.DiscarderByIndex - Class in org.apache.cassandra.cql3
 
Lists.Literal - Class in org.apache.cassandra.cql3
 
Lists.Marker - Class in org.apache.cassandra.cql3
A marker for List values and IN relations
Lists.Prepender - Class in org.apache.cassandra.cql3
 
Lists.Setter - Class in org.apache.cassandra.cql3
 
Lists.SetterByIndex - Class in org.apache.cassandra.cql3
 
Lists.Value - Class in org.apache.cassandra.cql3
 
ListSerializer<T> - Class in org.apache.cassandra.serializers
 
ListSnapshots - Class in org.apache.cassandra.tools.nodetool
 
ListSnapshots() - Constructor for class org.apache.cassandra.tools.nodetool.ListSnapshots
 
listToString(List<?>) - Static method in class org.apache.cassandra.cql3.Lists
Create a String representation of the list containing the specified elements.
listToString(Iterable<T>, Function<T, String>) - Static method in class org.apache.cassandra.cql3.Lists
Create a String representation of the list from the specified items associated to the list elements.
ListType<T> - Class in org.apache.cassandra.db.marshal
 
ListUsersStatement - Class in org.apache.cassandra.cql3.statements
 
ListUsersStatement() - Constructor for class org.apache.cassandra.cql3.statements.ListUsersStatement
 
Literal(String) - Constructor for class org.apache.cassandra.cql3.Json.Literal
 
Literal(List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.Lists.Literal
 
Literal(List<Pair<Term.Raw, Term.Raw>>) - Constructor for class org.apache.cassandra.cql3.Maps.Literal
 
Literal(List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.Sets.Literal
 
Literal(List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.Tuples.Literal
 
Literal(Map<FieldIdentifier, Term.Raw>) - Constructor for class org.apache.cassandra.cql3.UserTypes.Literal
 
LIVE - Static variable in interface org.apache.cassandra.db.DeletionInfo
 
LIVE - Static variable in class org.apache.cassandra.db.DeletionTime
A special DeletionTime that signifies that there is no top-level (row) tombstone.
live() - Static method in class org.apache.cassandra.db.MutableDeletionInfo
Returns a new DeletionInfo that has no top-level tombstone or any range tombstones.
live(ColumnMetadata, long, ByteBuffer) - Static method in class org.apache.cassandra.db.rows.BufferCell
 
live(ColumnMetadata, long, ByteBuffer, CellPath) - Static method in class org.apache.cassandra.db.rows.BufferCell
 
LIVE - Static variable in class org.apache.cassandra.db.rows.Row.Deletion
 
live() - Method in class org.apache.cassandra.locator.ReplicaPlan.ForWrite
The live replicas present in liveAndDown, usually derived from FailureDetector.isReplicaAlive
liveAndDown() - Method in class org.apache.cassandra.locator.ReplicaPlan.ForWrite
Replicas that can participate in the write - this always includes all nodes (pending and natural) in all DCs, except for paxos LOCAL_QUORUM (which is local DC only)
liveDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Disk space used by SSTables belonging to this CF
liveDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.TableMetrics
Disk space used by SSTables belonging to this table
liveMemtables - Variable in class org.apache.cassandra.db.lifecycle.View
ordinarily a list of size 1, but when preparing to flush will contain both the memtable we will flush and the new replacement memtable, until all outstanding write operations on the old table complete.
LivenessInfo - Class in org.apache.cassandra.db
Stores the information relating to the liveness of the primary key columns of a row.
LivenessInfo(long) - Constructor for class org.apache.cassandra.db.LivenessInfo
 
liveScannedHistogram - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Live cells scanned in queries on this Keyspace
liveScannedHistogram - Variable in class org.apache.cassandra.metrics.TableMetrics
Live rows scanned in queries on this CF
liveSSTableCount - Variable in class org.apache.cassandra.metrics.TableMetrics
Number of SSTables on disk for this CF
liveSSTables() - Method in class org.apache.cassandra.db.lifecycle.View
 
liveSSTablesInBounds(PartitionPosition, PartitionPosition) - Method in class org.apache.cassandra.db.lifecycle.View
Returns the sstables that have any partition between left and right, when both bounds are taken inclusively.
liveUncontacted() - Method in class org.apache.cassandra.locator.ReplicaPlan.ForWrite
Calculate which live endpoints we could have contacted, but chose not to
load(ChunkCache.Key) - Method in class org.apache.cassandra.cache.ChunkCache
 
load() - Method in class org.apache.cassandra.diag.store.DiagnosticEventMemoryStore
 
load() - Method in interface org.apache.cassandra.diag.store.DiagnosticEventStore
Initializes the store.
load(double) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
load - Static variable in class org.apache.cassandra.metrics.StorageMetrics
 
load(KeyspaceMetadata) - Method in class org.apache.cassandra.schema.Schema
Update (or insert) new keyspace definition
load(LoaderOptions) - Static method in class org.apache.cassandra.tools.BulkLoader
 
LoadBroadcaster - Class in org.apache.cassandra.service
 
loadClass(String) - Method in class org.apache.cassandra.triggers.CustomClassLoader
 
loadClassInternal(String) - Method in class org.apache.cassandra.triggers.CustomClassLoader
 
loadConfig() - Method in interface org.apache.cassandra.config.ConfigurationLoader
Loads a Config object to use to configure a node.
loadConfig() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
loadConfig() - Method in class org.apache.cassandra.config.YamlConfigurationLoader
 
loadConfig(URL) - Method in class org.apache.cassandra.config.YamlConfigurationLoader
 
loadDcRackInfo() - Static method in class org.apache.cassandra.db.SystemKeyspace
Return a map of IP addresses containing a map of dc and rack info
loader - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
LoaderOptions - Class in org.apache.cassandra.tools
 
loadFromDisk() - Method in class org.apache.cassandra.schema.Schema
load keyspace (keyspace) definitions, but do not initialize the keyspace instances.
loadFromDisk(boolean) - Method in class org.apache.cassandra.schema.Schema
Load schema definitions from disk.
loadHostIds() - Static method in class org.apache.cassandra.db.SystemKeyspace
Return a map of store host_ids to IP addresses
loadNewSSTables(String, String) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
See #StorageService.importNewSSTables for more info
loadNewSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Deprecated.
loadNewSSTables() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Deprecated.
loadNewSSTables(String, String) - Method in class org.apache.cassandra.service.StorageService
Deprecated.
loadNewSSTables(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
loadNewSSTables(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
Deprecated.
loadPaxosState(DecoratedKey, TableMetadata, int) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
loadPreparedStatements() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
loadSaved() - Method in class org.apache.cassandra.cache.AutoSavingCache
 
loadSavedAsync() - Method in class org.apache.cassandra.cache.AutoSavingCache
 
loadsstables - Variable in class org.apache.cassandra.db.lifecycle.Tracker
 
loadTokens() - Static method in class org.apache.cassandra.db.SystemKeyspace
Return a map of stored tokens to IP addresses
loadTriggerInstance(String) - Method in class org.apache.cassandra.triggers.TriggerExecutor
 
LOCAL - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
local - Variable in class org.apache.cassandra.dht.RangeStreamer.FetchReplica
 
local() - Static method in class org.apache.cassandra.schema.KeyspaceParams
 
local - Variable in class org.apache.cassandra.service.ActiveRepairService.ConsistentSessions
 
local_system_data_file_directory - Variable in class org.apache.cassandra.config.Config
The directory to use for storing the system keyspaces data.
LOCAL_SYSTEM_KEYSPACE_NAMES - Static variable in class org.apache.cassandra.schema.SchemaConstants
 
LocalAwareExecutorService - Interface in org.apache.cassandra.concurrent
 
LocalAwareExecutorService.MaximumPoolSizeListener - Interface in org.apache.cassandra.concurrent
 
LocalDate - Class in org.apache.cassandra.cql3.functions.types
A date with no time components, no time zone, in the ISO 8601 calendar.
localDeletionTime() - Method in class org.apache.cassandra.db.DeletionTime
The local server timestamp, in seconds since the unix epoch, at which this tombstone was created.
localDeletionTime() - Method in class org.apache.cassandra.db.rows.ArrayCell
 
localDeletionTime() - Method in class org.apache.cassandra.db.rows.BufferCell
 
localDeletionTime() - Method in class org.apache.cassandra.db.rows.Cell
The cell local deletion time.
localDeletionTime() - Method in class org.apache.cassandra.db.rows.NativeCell
 
localDeletionTimeSerializedSize(int) - Method in class org.apache.cassandra.db.SerializationHeader
 
localDeletionTimeTracker - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
localExpirationTime() - Method in class org.apache.cassandra.db.LivenessInfo
The expiration time (in seconds) if the info is expiring (LivenessInfo.NO_EXPIRATION_TIME otherwise).
LocalPartitioner - Class in org.apache.cassandra.dht
 
LocalPartitioner(AbstractType<?>) - Constructor for class org.apache.cassandra.dht.LocalPartitioner
 
LocalPartitioner.LocalToken - Class in org.apache.cassandra.dht
 
LocalPool() - Constructor for class org.apache.cassandra.utils.memory.BufferPool.LocalPool
 
localQuorumFor(AbstractReplicationStrategy, String) - Static method in enum org.apache.cassandra.db.ConsistencyLevel
 
localQuorumForOurDc(AbstractReplicationStrategy) - Static method in enum org.apache.cassandra.db.ConsistencyLevel
 
localReadCount - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
localReadLatencyMs - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
LocalReadRunnable(ReadCommand, ReadCallback) - Constructor for class org.apache.cassandra.service.StorageProxy.LocalReadRunnable
 
LocalReadRunnable(ReadCommand, ReadCallback, boolean) - Constructor for class org.apache.cassandra.service.StorageProxy.LocalReadRunnable
 
LocalSession - Class in org.apache.cassandra.repair.consistent
Basically just a record of a local session.
LocalSession(LocalSession.Builder) - Constructor for class org.apache.cassandra.repair.consistent.LocalSession
 
LocalSession.Builder - Class in org.apache.cassandra.repair.consistent
 
LocalSessionInfo - Class in org.apache.cassandra.repair.consistent
helper for JMX management functions
LocalSessions - Class in org.apache.cassandra.repair.consistent
Manages all consistent repair sessions a node is participating in.
LocalSessions() - Constructor for class org.apache.cassandra.repair.consistent.LocalSessions
 
LocalSessions.Listener - Interface in org.apache.cassandra.repair.consistent
 
LocalStrategy - Class in org.apache.cassandra.locator
 
LocalStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.LocalStrategy
 
LocalSyncTask - Class in org.apache.cassandra.repair
LocalSyncTask performs streaming between local(coordinator) node and remote replica.
LocalSyncTask(RepairJobDesc, InetAddressAndPort, InetAddressAndPort, List<Range<Token>>, UUID, boolean, boolean, PreviewKind) - Constructor for class org.apache.cassandra.repair.LocalSyncTask
 
LocalToken(ByteBuffer) - Constructor for class org.apache.cassandra.dht.LocalPartitioner.LocalToken
 
localWriteCount - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
localWriteLatencyMs - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
location - Variable in class org.apache.cassandra.db.Directories.DataDirectory
 
locationCheck - Variable in class org.apache.cassandra.tools.nodetool.stats.TableStatsHolder
 
LockedDynamicList<E> - Class in org.apache.cassandra.utils
 
LockedDynamicList(int) - Constructor for class org.apache.cassandra.utils.LockedDynamicList
 
log(AuditLogEntry) - Method in class org.apache.cassandra.audit.BinAuditLogger
 
log(AuditLogEntry) - Method in class org.apache.cassandra.audit.DiagnosticEventAuditLogger
 
log(AuditLogEntry) - Method in class org.apache.cassandra.audit.FileAuditLogger
 
log(AuditLogEntry) - Method in interface org.apache.cassandra.audit.IAuditLogger
Logs AuditLogEntry.
log(AuditLogEntry) - Method in class org.apache.cassandra.audit.NoOpAuditLogger
 
log(Config) - Static method in class org.apache.cassandra.config.Config
 
log() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
log() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
 
log(Logger) - Method in class org.apache.cassandra.utils.EstimatedHistogram
log.debug() every record in the histogram
log(Logger, NoSpamLogger.Level, long, TimeUnit, String, Object...) - Static method in class org.apache.cassandra.utils.NoSpamLogger
 
log(Logger, NoSpamLogger.Level, String, long, TimeUnit, String, Object...) - Static method in class org.apache.cassandra.utils.NoSpamLogger
 
log(Logger, NoSpamLogger.Level, String, long, TimeUnit, long, String, Object...) - Static method in class org.apache.cassandra.utils.NoSpamLogger
 
log(NoSpamLogger.Level, String, long, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
log(NoSpamLogger.Level, long, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
 
log() - Static method in class org.apache.cassandra.utils.StatusLogger
 
LOG_ALL_OPTION - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
log_dir - Variable in class org.apache.cassandra.fql.FullQueryLoggerOptions
 
logAll - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
LogbackLoggingSupport - Class in org.apache.cassandra.utils.logging
Encapsulates all logback-specific implementations in a central place.
LogbackLoggingSupport() - Constructor for class org.apache.cassandra.utils.logging.LogbackLoggingSupport
 
logExceptionsAfterExecute(Runnable, Throwable) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
Send @param t and any exception wrapped by @param r to the default uncaught exception handler, or log them if none such is set up
logger - Variable in class org.apache.cassandra.audit.AuditLogOptions
 
logger - Static variable in class org.apache.cassandra.audit.FileAuditLogger
 
logger - Static variable in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
logger - Static variable in interface org.apache.cassandra.cql3.CQL3Type
 
logger - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
 
logger - Static variable in class org.apache.cassandra.cql3.functions.UDAggregate
 
logger - Static variable in class org.apache.cassandra.cql3.functions.UDFunction
 
logger - Static variable in class org.apache.cassandra.cql3.statements.ModificationStatement
 
logger - Static variable in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
logger - Static variable in class org.apache.cassandra.db.compaction.CompactionTask
 
logger - Static variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
logger - Static variable in class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
 
logger - Static variable in class org.apache.cassandra.db.partitions.PartitionUpdate
 
logger - Static variable in class org.apache.cassandra.db.ReadCommand
 
logger - Static variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
 
logger - Static variable in class org.apache.cassandra.fql.FullQueryLogger
 
logger - Static variable in class org.apache.cassandra.gms.EndpointState
 
logger - Static variable in class org.apache.cassandra.locator.AlibabaCloudSnitch
 
logger - Static variable in class org.apache.cassandra.locator.CloudstackSnitch
 
logger - Static variable in class org.apache.cassandra.locator.Ec2Snitch
 
logger - Static variable in class org.apache.cassandra.locator.GoogleCloudSnitch
 
logger - Static variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
logger - Static variable in class org.apache.cassandra.service.reads.ReadCallback
 
logger - Static variable in class org.apache.cassandra.service.reads.ResponseResolver
 
logger - Static variable in class org.apache.cassandra.service.TruncateResponseHandler
 
logger - Static variable in class org.apache.cassandra.service.WriteResponseHandler
 
logger - Static variable in class org.apache.cassandra.tracing.Tracing
 
logger - Static variable in class org.apache.cassandra.transport.Message
 
logger - Static variable in interface org.apache.cassandra.utils.MBeanWrapper
 
LoggingCipherSuiteFilter(String) - Constructor for class org.apache.cassandra.security.SSLFactory.LoggingCipherSuiteFilter
 
loggingIterator(PartitionIterator, String) - Static method in class org.apache.cassandra.db.partitions.PartitionIterators
Wraps the provided iterator so it logs the returned rows for debugging purposes.
loggingIterator(UnfilteredPartitionIterator, String, boolean) - Static method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators
Wraps the provided iterator so it logs the returned rows/RT for debugging purposes.
loggingIterator(RowIterator, String) - Static method in class org.apache.cassandra.db.rows.RowIterators
Wraps the provided iterator so it logs the returned rows for debugging purposes.
loggingIterator(UnfilteredRowIterator, String, boolean) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
Wraps the provided iterator so it logs the returned atoms for debugging purposes.
LoggingSupport - Interface in org.apache.cassandra.utils.logging
Common abstraction of functionality which can be implemented for different logging backend implementations (slf4j bindings).
LoggingSupportFactory - Class in org.apache.cassandra.utils.logging
Dynamically loads and instantiates an appropriate LoggingSupport implementation according to the used slf4j binding.
logHeapHistogram() - Static method in class org.apache.cassandra.utils.HeapUtils
Generates a HEAP histogram in the log file.
login() - Method in class org.apache.cassandra.auth.CassandraLoginModule
Authenticate the user, obtaining credentials from the CallbackHandler supplied in initialize.
login(AuthenticatedUser) - Method in class org.apache.cassandra.service.ClientState
Attempts to login the given user.
logout() - Method in class org.apache.cassandra.auth.CassandraLoginModule
Logout the user.
LogOutput() - Constructor for class org.apache.cassandra.utils.OutputHandler.LogOutput
 
logPrefix() - Method in enum org.apache.cassandra.streaming.PreviewKind
 
logPrefix(UUID) - Method in enum org.apache.cassandra.streaming.PreviewKind
 
logRecord(BinLog.ReleaseableWriteMarshallable) - Method in class org.apache.cassandra.utils.binlog.BinLog
 
LogReplicaSet - Class in org.apache.cassandra.db.lifecycle
A set of log replicas.
LogReplicaSet() - Constructor for class org.apache.cassandra.db.lifecycle.LogReplicaSet
 
logResponseToIdealCLDelegate(Message<T>) - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
This logs the response but doesn't do any further processing related to this write response handler on whether the CL was achieved.
logRowCountPerLeaf(Logger) - Method in class org.apache.cassandra.utils.MerkleTrees
Log the row count per leaf for all MerkleTrees.
logRowSizePerLeaf(Logger) - Method in class org.apache.cassandra.utils.MerkleTrees
Log the row size per leaf for all MerkleTrees.
logStackTrace - Variable in exception org.apache.cassandra.exceptions.ConfigurationException
 
logToList(List<String>) - Method in class org.apache.cassandra.io.sstable.SSTableHeaderFix.Builder
 
LONG_SIZE - Static variable in class org.apache.cassandra.db.TypeSizes
 
LongAccumulator<T> - Interface in org.apache.cassandra.utils
 
LongSerializer - Class in org.apache.cassandra.serializers
 
LongSerializer() - Constructor for class org.apache.cassandra.serializers.LongSerializer
 
LongTimSort - Class in org.apache.cassandra.utils
A stable, adaptive, iterative mergesort that requires far fewer than n lg(n) comparisons when running on partially sorted arrays, while offering performance comparable to a traditional mergesort when run on random arrays.
LongTimSort.LongComparator - Interface in org.apache.cassandra.utils
 
LongToken(long) - Constructor for class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
LongType - Class in org.apache.cassandra.db.marshal
 
lookup(InetAddressAndPort) - Method in class org.apache.cassandra.locator.ReplicaPlan.ForRead
 
lookup(InetAddressAndPort) - Method in class org.apache.cassandra.locator.ReplicaPlan.ForWrite
 
lookupById(int) - Static method in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
 
lower - Variable in class org.apache.cassandra.index.sasi.plan.Expression
 
lower(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
 
lower(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
 
lower(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
lower(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
lower() - Method in class org.apache.cassandra.utils.IntegerInterval
 
lowerBound() - Method in class org.apache.cassandra.db.commitlog.IntervalSet
 
lowerBound() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
 
lowerBound - Variable in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
lowerBound() - Method in class org.apache.cassandra.utils.IntegerInterval.Set
Returns a lower bound for the whole set.
lowerBound() - Method in interface org.apache.cassandra.utils.IteratorWithLowerBound
 
LowerCase(Locale) - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.BasicResultFilters.LowerCase
 
LowerCase() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.BasicResultFilters.LowerCase
 
lowerCaseOutput(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions.OptionsBuilder
 
lowerIndex(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
 
lowerPosition - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader.IndexesBounds
 
lowerPosition - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader.PartitionPositionBounds
 
lz4() - Static method in class org.apache.cassandra.schema.CompressionParams
 
lz4(int) - Static method in class org.apache.cassandra.schema.CompressionParams
 
lz4(int, int) - Static method in class org.apache.cassandra.schema.CompressionParams
 
LZ4_COMPRESSOR_TYPE - Static variable in class org.apache.cassandra.io.compress.LZ4Compressor
 
LZ4_FAST_COMPRESSOR - Static variable in class org.apache.cassandra.io.compress.LZ4Compressor
 
LZ4_HIGH_COMPRESSION_LEVEL - Static variable in class org.apache.cassandra.io.compress.LZ4Compressor
 
LZ4_HIGH_COMPRESSOR - Static variable in class org.apache.cassandra.io.compress.LZ4Compressor
 
LZ4Compressor - Class in org.apache.cassandra.io.compress
 

M

main(String[]) - Static method in class org.apache.cassandra.service.CassandraDaemon
 
main(String[]) - Static method in class org.apache.cassandra.tools.AuditLogViewer
 
main(String[]) - Static method in class org.apache.cassandra.tools.BulkLoader
 
main(String[]) - Static method in class org.apache.cassandra.tools.GenerateTokens
 
main(String[]) - Static method in class org.apache.cassandra.tools.GetVersion
 
main(String[]) - Static method in class org.apache.cassandra.tools.JMXTool
 
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.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.StandaloneSSTableUtil
 
main(String[]) - Static method in class org.apache.cassandra.tools.StandaloneUpgrader
 
main(String[]) - Static method in class org.apache.cassandra.tools.StandaloneVerifier
 
main(String[]) - Static method in class org.apache.cassandra.transport.Client
 
main(String[]) - Static method in class org.apache.cassandra.utils.DynamicList
 
major - Variable in class org.apache.cassandra.utils.CassandraVersion
 
MajorLeveledCompactionWriter - Class in org.apache.cassandra.db.compaction.writers
 
MajorLeveledCompactionWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, long) - Constructor for class org.apache.cassandra.db.compaction.writers.MajorLeveledCompactionWriter
 
MajorLeveledCompactionWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, long, boolean) - Constructor for class org.apache.cassandra.db.compaction.writers.MajorLeveledCompactionWriter
 
make(byte[]...) - Static method in class org.apache.cassandra.db.ArrayClustering
 
make(ByteBuffer...) - Static method in class org.apache.cassandra.db.BufferClustering
 
make(ByteBuffer...) - Static method in interface org.apache.cassandra.db.Clustering
 
make(Object...) - Method in class org.apache.cassandra.db.ClusteringComparator
Creates a row clustering based on the clustering values.
make(TableMetadata, Collection<SSTableReader>) - Static method in class org.apache.cassandra.db.SerializationHeader
 
make(ClusteringBound<?>, ClusteringBound<?>) - Static method in class org.apache.cassandra.db.Slice
 
make(ClusteringComparator, Object...) - Static method in class org.apache.cassandra.db.Slice
 
make(Clustering<?>) - Static method in class org.apache.cassandra.db.Slice
 
make(Clustering<?>, Clustering<?>) - Static method in class org.apache.cassandra.db.Slice
 
makeArgSpec(String, String, Function, int) - Static method in class org.apache.cassandra.cql3.functions.FunctionResolver
 
makeBoundary(boolean, ClusteringBound<V1>, ClusteringBound<V2>, DeletionTime, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
makeCollectionReceiver(ColumnSpecification, boolean) - Method in enum org.apache.cassandra.db.marshal.CollectionType.Kind
 
makeCollectionReceiver(ColumnSpecification, boolean) - Method in class org.apache.cassandra.db.marshal.CollectionType
 
makeColumnFilter() - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
makeCountFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.AggregateFcts
Creates a COUNT function for the specified type.
makeDigest(UnfilteredPartitionIterator, ReadCommand) - Static method in class org.apache.cassandra.db.ReadResponse
 
makeDigestRequests(Iterable<Replica>) - Method in class org.apache.cassandra.service.reads.AbstractReadExecutor
 
makeFilter() - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
makeFromBlobFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.BytesConversionFcts
 
makeFullDataRequests(ReplicaCollection<?>) - Method in class org.apache.cassandra.service.reads.AbstractReadExecutor
 
makeIndexClustering(ByteBuffer, Clustering<?>) - Method in class org.apache.cassandra.index.internal.CassandraIndexSearcher
 
makeInternalOptions(CQLStatement, Object[]) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
makeIterator(ReadCommand) - Method in class org.apache.cassandra.db.ReadResponse
 
makeLimits() - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
makeMaxFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.AggregateFcts
Creates a MAX function for the specified type.
makeMinFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.AggregateFcts
Creates a MIN function for the specified type.
makeMutation() - Method in class org.apache.cassandra.service.paxos.Commit
 
makePartitionIterator(ColumnFilter, DataRange) - Method in class org.apache.cassandra.db.Memtable
 
makeRangeTombstone(ClusteringComparator, Clustering<?>) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
makeRangeTombstone(Slice) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
makeRowBounds(Token, Token) - Static method in class org.apache.cassandra.dht.Bounds
Compute a bounds of keys corresponding to a given bounds of token.
makeRowIterator(ColumnFamilyStore, SSTableReader, DecoratedKey, Slices, ColumnFilter, boolean, SSTableReadsListener) - Method in interface org.apache.cassandra.db.StorageHook
 
makeRowIteratorWithLowerBound(ColumnFamilyStore, DecoratedKey, SSTableReader, ClusteringIndexFilter, ColumnFilter, SSTableReadsListener) - Method in interface org.apache.cassandra.db.StorageHook
 
makeRowRange(Token, Token) - Static method in class org.apache.cassandra.dht.Range
Compute a range of keys corresponding to a given range of token.
makeRowRange(Range<Token>) - Static method in class org.apache.cassandra.dht.Range
 
makeSlices(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
makeToBlobFunction(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.BytesConversionFcts
 
makeTransientDataRequests(Iterable<Replica>) - Method in class org.apache.cassandra.service.reads.AbstractReadExecutor
 
makeUnflushable() - Method in class org.apache.cassandra.db.Memtable
For testing only.
makeUpdates(FilteredPartition) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
 
makeUpdates(FilteredPartition) - Method in interface org.apache.cassandra.service.CASRequest
The updates to perform of a CAS success.
makeWithoutStats(TableMetadata) - Static method in class org.apache.cassandra.db.SerializationHeader
 
manager - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
managesRepairedGroup(boolean, boolean, boolean) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
SSTables are grouped by their repaired and pending repair status.
managesRepairedGroup(boolean, boolean, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
managesRepairedGroup(boolean, boolean, boolean) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
managesSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
 
manifest() - Method in class org.apache.cassandra.db.streaming.ComponentContext
 
map(CQL3Type.Raw, CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
map(DataType, DataType, boolean) - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the type of maps of keyType to valueType elements.
map(DataType, DataType) - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the type of "not frozen" maps of keyType to valueType elements.
map(TypeCodec<K>, TypeCodec<V>) - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return a newly-created codec for the CQL type map whose key type and value type are determined by the given codecs.
map - Variable in class org.apache.cassandra.cql3.Maps.Value
 
map(FileChannel.MapMode, long, long) - Method in class org.apache.cassandra.io.util.ChannelProxy
 
map(ChannelProxy, CompressionMetadata) - Static method in class org.apache.cassandra.io.util.MmappedRegions
 
map(ChannelProxy, long) - Static method in class org.apache.cassandra.io.util.MmappedRegions
 
mapOf(Class<K>, Class<V>) - Static method in class org.apache.cassandra.cql3.functions.types.TypeTokens
Create a TypeToken that represents a Map whose keys and values are of the given key and value types.
mapOf(TypeToken<K>, TypeToken<V>) - Static method in class org.apache.cassandra.cql3.functions.types.TypeTokens
Create a TypeToken that represents a Map whose keys and values are of the given key and value types.
MappedBuffer - Class in org.apache.cassandra.index.sasi.utils
 
MappedBuffer(RandomAccessReader) - Constructor for class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
MappedBuffer(ChannelProxy) - Constructor for class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
MappedBuffer(ChannelProxy, int) - Constructor for class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
MAPRED_TASK_ID - Static variable in class org.apache.cassandra.hadoop.cql3.CqlInputFormat
 
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
 
mapToString(List<Pair<T, T>>) - Static method in class org.apache.cassandra.cql3.Maps
Create a String representation of the list containing the specified elements.
mapToString(List<Pair<T, T>>, Function<T, String>) - Static method in class org.apache.cassandra.cql3.Maps
Create a String representation of the map from the specified items associated to the map entries.
MapType<K,V> - Class in org.apache.cassandra.db.marshal
 
mark() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
mark() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
mark() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
mark() - Method in class org.apache.cassandra.io.util.FileSegmentInputStream
 
mark(int) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
 
mark() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
mark() - Method in interface org.apache.cassandra.io.util.RewindableDataInput
 
mark() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
Marks the current position of a stream to return to this position later via the RewindableDataInputStreamPlus.reset(DataPosition) method.
mark(int) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
Marks the current position of a stream to return to this position later via the RewindableDataInputStreamPlus.reset() method.
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.
mark() - Method in class org.apache.cassandra.metrics.TableMetrics.TableMeter
 
markAllCompacting(OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
markAllIndexesRemoved() - Method in class org.apache.cassandra.index.SecondaryIndexManager
Called when dropping a Table
markAsShutdown(InetAddressAndPort) - 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
markAuthFailure() - Method in class org.apache.cassandra.metrics.ClientMetrics
 
markAuthSuccess() - Method in class org.apache.cassandra.metrics.ClientMetrics
 
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(TableId, CommitLogPosition, CommitLogPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
Marks the ColumnFamily specified by id as clean for this log segment.
markClusteringColumn(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
 
markClusteringColumn(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.statements.schema.CreateViewStatement.Raw
 
markCounterLocalToBeCleared() - Method in class org.apache.cassandra.db.rows.AbstractCell
 
markCounterLocalToBeCleared() - Method in class org.apache.cassandra.db.rows.BTreeRow
 
markCounterLocalToBeCleared() - Method in class org.apache.cassandra.db.rows.Cell
 
markCounterLocalToBeCleared() - Method in class org.apache.cassandra.db.rows.ColumnData
 
markCounterLocalToBeCleared() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
markCounterLocalToBeCleared() - Method in interface org.apache.cassandra.db.rows.Row
Returns a copy of this row where all counter cells have they "local" shard marked for clearing.
markDataSynced(long) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
markDead(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
 
markedForDeleteAt() - Method 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.
Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Constants.Marker
 
Marker(int) - Constructor for class org.apache.cassandra.cql3.Json.Marker
 
Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Lists.Marker
 
Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Maps.Marker
 
marker - Variable in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithMarker
 
marker - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithMarker
 
Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Sets.Marker
 
Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Tuples.Marker
 
Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.UserTypes.Marker
 
markFlushing(Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
markIndexSynced(long) - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
markLocalToBeCleared(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Mark context to delete local references afterward.
markObsolete(Collection<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
markObsolete() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
 
markObsolete(Runnable) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Mark the sstable as obsolete, i.e., compacted into newer sstables.
markProtocolException() - Method in class org.apache.cassandra.metrics.ClientMetrics
 
markRequestDiscarded() - Method in class org.apache.cassandra.metrics.ClientMetrics
 
markSupported() - Method in class org.apache.cassandra.io.util.FileSegmentInputStream
 
markSupported() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
 
markSupported() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
markSupported() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
markSuspect() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
markUnknownException() - Method in class org.apache.cassandra.metrics.ClientMetrics
 
markUnreadable(String) - Method in class org.apache.cassandra.db.DisallowedDirectories
 
markUnreadable(String) - Method in interface org.apache.cassandra.db.DisallowedDirectoriesMBean
 
markUnwritable(String) - Method in class org.apache.cassandra.db.DisallowedDirectories
 
markUnwritable(String) - Method in interface org.apache.cassandra.db.DisallowedDirectoriesMBean
 
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
 
match(Expression) - Method in class org.apache.cassandra.index.sasi.conf.view.View
 
match(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.conf.view.View
 
matchesEndpoints(Set<InetAddressAndPort>, Set<InetAddressAndPort>) - Method in class org.apache.cassandra.repair.CommonRange
 
matchesViewFilter(DecoratedKey, Row, int) - Method in class org.apache.cassandra.db.view.View
Whether a given base row matches the view filter (and thus if is should have a corresponding entry).
max - Variable in class org.apache.cassandra.index.sasi.conf.view.RangeTermTree
 
max - Variable in class org.apache.cassandra.index.sasi.conf.view.TermTree.Builder
 
max() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
max - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
 
max() - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxIntTracker
 
max() - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxLongTracker
 
max - Variable in class org.apache.cassandra.tools.Util.TermHistogram
 
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_archive_retries - Variable in class org.apache.cassandra.utils.binlog.BinLogOptions
Limit the number of times to retry a command.
MAX_BUCKET_COUNT - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
MAX_BUFFER_SIZE - Static variable in interface org.apache.cassandra.io.util.DiskOptimizationStrategy
 
max_concurrent_automatic_sstable_upgrades - Variable in class org.apache.cassandra.config.Config
 
MAX_CONNECT_ATTEMPTS - Static variable in class org.apache.cassandra.streaming.DefaultConnectionFactory
 
MAX_DELETION_TIME - Static variable in class org.apache.cassandra.db.rows.Cell
 
MAX_FAILED_HOSTS - Static variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
max_hint_window_in_ms - Variable in class org.apache.cassandra.config.Config
 
max_hints_delivery_threads - Variable in class org.apache.cassandra.config.Config
 
max_hints_file_size_in_mb - Variable in class org.apache.cassandra.config.Config
 
MAX_JOB_THREADS - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
max_log_size - Variable in class org.apache.cassandra.utils.binlog.BinLogOptions
Maximum size of the rolled files to retain on disk before deleting the oldest file.
MAX_MUTATION_SIZE - Static variable in interface org.apache.cassandra.db.IMutation
 
max_mutation_size_in_kb - Variable in class org.apache.cassandra.config.Config
 
MAX_OFFSET - Static variable in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
MAX_OUTSTANDING_REPLAY_BYTES - Static variable in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
MAX_POOL_SIZE - Static variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
 
max_queue_weight - Variable in class org.apache.cassandra.utils.binlog.BinLogOptions
Maximum weight of in memory queue for records waiting to be written to the binlog file before blocking or dropping the log records.
MAX_SEGMENT_SIZE - Static variable in class org.apache.cassandra.io.util.MmappedRegions
In a perfect world, MAX_SEGMENT_SIZE would be final, but we need to test with a smaller size
MAX_SIZE - Static variable in class org.apache.cassandra.net.FrameEncoder.Payload
 
MAX_SIZE - Static variable in class org.apache.cassandra.utils.vint.VIntCoding
 
MAX_SSTABLE_AGE_KEY - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
Deprecated.
max_streaming_retries - Variable in class org.apache.cassandra.config.Config
Deprecated.
retry support removed on CASSANDRA-10992
MAX_TASKS_QUEUED - Static variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
 
MAX_TERM_SIZE - Static variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
 
MAX_TTL - Static variable in class org.apache.cassandra.cql3.Attributes
If this limit is ever raised, make sure @Integer.MAX_VALUE is not allowed, as this is used as a flag to represent expired liveness.
MAX_UNSIGNED_SHORT - Static variable in class org.apache.cassandra.utils.FBUtilities
 
max_value_size_in_mb - Variable in class org.apache.cassandra.config.Config
Max size of values in SSTables, in MegaBytes.
MAX_WINDOW_SIZE_KEY - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
maxAge - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
maxArchiveRetries(int) - Method in class org.apache.cassandra.utils.binlog.BinLog.Builder
 
maxBucketsPerElement(long) - Static method in class org.apache.cassandra.utils.BloomCalculations
Calculates the maximum number of buckets per element that this implementation can support.
maxBytesForLevel(int, long) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
maxBytesForLevel(int, int, long) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
 
maxClusteringValues - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
maxCompactionFlushMemoryInBytes - Variable in class org.apache.cassandra.index.sasi.conf.IndexMode
 
maxCompactionThreshold() - Method in class org.apache.cassandra.schema.CompactionParams
 
maxCompressedLength() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
 
maxCompressedLength() - Method in class org.apache.cassandra.schema.CompressionParams
 
maxConcurrentAutoUpgradeTasks() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
maxDataAge - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
maxDataAge is a timestamp in local server time (e.g.
maxDataAge - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
maxDataAge - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
maxFailures - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
maxFunctionForCounter - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
MAX function for counter column values.
MAXIMUM - Static variable in class org.apache.cassandra.dht.Murmur3Partitioner
 
MAXIMUM - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 
MAXIMUM_EXPIRATION_DATE_EXCEEDED_REJECT_MESSAGE - Static variable in class org.apache.cassandra.db.ExpirationDateOverflowHandling
 
MAXIMUM_EXPIRATION_DATE_EXCEEDED_WARNING - Static variable in class org.apache.cassandra.db.ExpirationDateOverflowHandling
 
MAXIMUM_SIZE - Static variable in class org.apache.cassandra.locator.InetAddressAndPort.Serializer
 
MAXIMUM_TOKEN_SIZE - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 
maximumLiveCellsPerSliceLastFiveMinutes - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
maximumPoolSize - Variable in class org.apache.cassandra.service.StorageServiceMBean.StageConcurrency
 
maximumTombstonesPerSliceLastFiveMinutes - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
maxIndexInterval(int) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
maxIndexInterval(int) - Method in class org.apache.cassandra.schema.TableParams.Builder
 
maxIndexInterval - Variable in class org.apache.cassandra.schema.TableParams
 
maxKey - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
maxKey() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
maxKey() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
 
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.metadata.StatsMetadata
 
maxLogSize(long) - Method in class org.apache.cassandra.utils.binlog.BinLog.Builder
 
maxMarkedAt() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
maxMemorySize(ColumnIndex) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
 
maxOffset(OnDiskIndex.IteratorOrder) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
 
maxOrdering() - Static method in class org.apache.cassandra.utils.Interval
 
maxPartitionSize - Variable in class org.apache.cassandra.metrics.TableMetrics
Size of the largest compacted partition
maxPoolSize - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
Maximum number of threads before it will start queuing tasks
maxQueueWeight(int) - Method in class org.apache.cassandra.utils.binlog.BinLog.Builder
 
maxRange - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
 
maxRemaining() - Method in class org.apache.cassandra.service.pager.AggregationQueryPager
 
maxRemaining() - Method in class org.apache.cassandra.service.pager.MultiPartitionPager
 
maxRemaining() - Method in interface org.apache.cassandra.service.pager.QueryPager
The maximum number of cells/CQL3 row that we may still have to return.
maxRepaired - Variable in class org.apache.cassandra.repair.consistent.admin.RepairStats
 
maxRepaired - Variable in class org.apache.cassandra.repair.consistent.RepairedState.Stats
 
MaxSampler<T> - Class in org.apache.cassandra.metrics
 
MaxSampler() - Constructor for class org.apache.cassandra.metrics.MaxSampler
 
maxsize() - Method in class org.apache.cassandra.utils.MerkleTree
 
maxsize(long) - Method in class org.apache.cassandra.utils.MerkleTree
 
maxsize(Range<Token>, int) - Method in class org.apache.cassandra.utils.MerkleTrees
 
maxSSTableAge - Variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
Deprecated.
maxSSTableBytes - Variable in class org.apache.cassandra.db.compaction.LeveledManifest.CompactionCandidate
 
MaxSSTableSizeWriter - Class in org.apache.cassandra.db.compaction.writers
 
MaxSSTableSizeWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, long, int) - Constructor for class org.apache.cassandra.db.compaction.writers.MaxSSTableSizeWriter
 
MaxSSTableSizeWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, long, int, boolean) - Constructor for class org.apache.cassandra.db.compaction.writers.MaxSSTableSizeWriter
 
maxTasksQueued - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
Maximum number of tasks queued before a task get blocked
maxTerm - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
maxTerm() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
maxTerm() - Method in class org.apache.cassandra.index.sasi.sa.TermIterator
 
maxTerm() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
 
maxTerm() - Method in class org.apache.cassandra.index.sasi.utils.CombinedTermIterator
 
maxTimestamp() - Method in interface org.apache.cassandra.db.DeletionInfo
 
maxTimestamp() - Method in class org.apache.cassandra.db.MutableDeletionInfo
 
maxTimestamp() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
The maximum timestamp used in this update.
maxTimestamp() - Method in class org.apache.cassandra.db.rows.AbstractCell
 
maxTimestamp() - Method in class org.apache.cassandra.db.rows.ColumnData
 
maxTimestamp() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
maxTimestamp - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
maxTimestampAscending - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
maxTimestampDescending - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
maxTimeUUID(long) - Static method in class org.apache.cassandra.utils.UUIDGen
Returns the biggest possible type 1 UUID having the provided timestamp.
maxTimeuuidFct - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
 
maxTokenLength(int) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
Set the max allowed token length.
maxTTL - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
maxWindowSize - Variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
maybeAdd(RequestCallback, InetAddressAndPort, long, TimeUnit) - Method in class org.apache.cassandra.net.LatencySubscribers
Track latency information for the dynamic snitch
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
 
mayBeAffectedBy(DecoratedKey, Row) - Method in class org.apache.cassandra.db.view.View
Whether the view might be affected by the provided update.
maybeApplyExpirationDateOverflowPolicy(TableMetadata, int, boolean) - Static method in class org.apache.cassandra.db.ExpirationDateOverflowHandling
 
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), and in the treatment of failures.
maybeClearCounterValue(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.rows.DeserializationHelper
 
maybeCorrectResource(IResource, ClientState) - Static method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
maybeExecuteImmediately(Runnable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
maybeExecuteImmediately(Runnable) - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
 
maybeExecuteImmediately(Runnable) - Method in interface org.apache.cassandra.concurrent.LocalAwareExecutorService
 
maybeExecuteImmediately(Runnable) - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
maybeExecuteImmediately(Runnable) - Method in enum org.apache.cassandra.concurrent.Stage
 
maybeFail(Throwable) - Static method in class org.apache.cassandra.utils.Throwables
 
maybeFail(Throwable, Class<T>) - Static method in class org.apache.cassandra.utils.Throwables
 
maybeFail(Throwables.DiscreteAction<? extends E>...) - Static method in class org.apache.cassandra.utils.Throwables
 
maybeFinishShadowRound(InetAddressAndPort, boolean, Map<InetAddressAndPort, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
 
maybeGetScanners(Collection<SSTableReader>, Collection<Range<Token>>) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
Create ISSTableScanners from the given sstables Delegates the call to the compaction strategies to allow LCS to create a scanner
maybeIncrementallyBackup(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
maybeInit() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
 
maybeInitializeLocalState(int) - Method in class org.apache.cassandra.gms.Gossiper
 
maybeIssueRead() - Method in class org.apache.cassandra.net.AsyncStreamingInputPlus
 
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.DisallowedDirectories
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.DisallowedDirectories
Adds parent directory of the file (or the file itself, if it is a directory) to the set of unwritable directories.
maybeMerge(Keyspace, ConsistencyLevel, ReplicaPlan.ForRangeRead, ReplicaPlan.ForRangeRead) - Static method in class org.apache.cassandra.locator.ReplicaPlans
Take two range read plans for adjacent ranges, and check if it is OK (and worthwhile) to combine them into a single plan
maybeQuote(String) - Static method in class org.apache.cassandra.cql3.ColumnIdentifier
 
maybeReconnectWithNewIp(InetAddressAndPort, InetAddressAndPort) - Method in class org.apache.cassandra.net.MessagingService
Reconnect to the peer using the given addr.
maybeRefreshOverlaps() - Method in class org.apache.cassandra.db.compaction.CompactionController
 
maybeReload(TableMetadata) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
maybeReloadDiskBoundaries() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
Checks if the disk boundaries changed and reloads the compaction strategies to reflect the most up-to-date disk boundaries.
maybeResetTraceSessionWrapper(Runnable) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
maybeRestoreArchive() - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
maybeSendAdditionalDataRequests() - Method in class org.apache.cassandra.service.reads.AbstractReadExecutor
 
maybeSendAdditionalReads() - Method in class org.apache.cassandra.service.reads.repair.AbstractReadRepair
 
maybeSendAdditionalReads() - Method in class org.apache.cassandra.service.reads.repair.NoopReadRepair
 
maybeSendAdditionalReads() - Method in interface org.apache.cassandra.service.reads.repair.ReadRepair
if it looks like we might not receive data requests from everyone in time, send additional requests to additional replicas not contacted in the initial full data read.
maybeSendAdditionalWrites(long, TimeUnit) - Method in class org.apache.cassandra.service.reads.repair.BlockingPartitionRepair
If it looks like we might not receive acks for all the repair mutations we sent out, combine all the unacked mutations and send them to the minority of nodes not involved in the read repair data read / write cycle.
maybeSendAdditionalWrites() - Method in class org.apache.cassandra.service.reads.repair.BlockingReadRepair
 
maybeSendAdditionalWrites() - Method in class org.apache.cassandra.service.reads.repair.NoopReadRepair
 
maybeSendAdditionalWrites() - Method in class org.apache.cassandra.service.reads.repair.ReadOnlyReadRepair
 
maybeSendAdditionalWrites() - Method in interface org.apache.cassandra.service.reads.repair.ReadRepair
If it looks like we might not receive acks for all the repair mutations we sent out, combine all the unacked mutations and send them to the minority of nodes not involved in the read repair data read / write cycle.
maybeSetRepairing(UUID) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
maybeSwitchWriter(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
Guaranteed to be called before the first call to realAppend.
maybeTryAdditionalReplicas(IMutation, StorageProxy.WritePerformer, String) - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
Cheap Quorum backup.
maybeTryAdditionalReplicas() - Method in class org.apache.cassandra.service.reads.AbstractReadExecutor
Perform additional requests if it looks like the original will time out.
maybeTryAdditionalReplicas() - Method in class org.apache.cassandra.service.reads.AbstractReadExecutor.NeverSpeculatingReadExecutor
 
maybeValidateIndex() - Method in class org.apache.cassandra.db.ReadCommand
If the index manager for the CFS determines that there's an applicable 2i that can be used to execute this command, call its (optional) validation method to check that nothing in this command's parameters violates the implementation specific validation rules.
maybeValidateIndex() - Method in interface org.apache.cassandra.db.ReadQuery
If the index manager for the table determines that there's an applicable 2i that can be used to execute this query, call its (optional) validation method to check that nothing in this query's parameters violates the implementation specific validation rules.
maybeValidateUnfiltered(Unfiltered, TableMetadata, DecoratedKey, SSTableReader) - Static method in class org.apache.cassandra.db.UnfilteredValidation
 
maybeWaitForArchiving(String) - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
maybeWaitForSync(CommitLogSegment.Allocation) - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
 
maybeWaitForSync(CommitLogSegment.Allocation) - Method in class org.apache.cassandra.db.commitlog.GroupCommitLogService
 
maybeWarnOnOptions() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
maybeWarnOnOptions() - Method in class org.apache.cassandra.locator.LocalStrategy
 
maybeWarnOnOptions() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
maybeWarnOnOptions() - Method in class org.apache.cassandra.locator.SimpleStrategy
 
maybeWrap(ChunkReader) - Static method in class org.apache.cassandra.cache.ChunkCache
 
maybeWrite(ChannelHandlerContext, Promise<Void>) - Method in class org.apache.cassandra.transport.SimpleClient.SimpleFlusher
 
mayContainDataBefore(CommitLogPosition) - Method in class org.apache.cassandra.db.Memtable
 
mayHaveTombstones() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Whether the sstable may contain tombstones or if it is guaranteed to not contain any.
mayIncludeRepairedDigest() - Method in class org.apache.cassandra.db.ReadResponse
 
mayModify(DeletionInfo) - Method in interface org.apache.cassandra.db.DeletionInfo
Whether this deletion info may modify the provided one if added to it.
mayModify(DeletionInfo) - Method in class org.apache.cassandra.db.MutableDeletionInfo
Whether this deletion info may modify the provided one if added to it.
mbean(String) - Static method in class org.apache.cassandra.auth.JMXResource
 
MBEAN_NAME - Static variable in class org.apache.cassandra.batchlog.BatchlogManager
 
MBEAN_NAME - Static variable in class org.apache.cassandra.db.DisallowedDirectories
 
MBEAN_NAME - Static variable in class org.apache.cassandra.gms.FailureDetector
 
MBEAN_NAME - Static variable in class org.apache.cassandra.gms.Gossiper
 
MBEAN_NAME - Static variable in class org.apache.cassandra.hints.HintsService
 
MBEAN_NAME - Static variable in class org.apache.cassandra.io.sstable.IndexSummaryManager
 
MBEAN_NAME - Static variable in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
MBEAN_NAME - Static variable in interface org.apache.cassandra.service.ActiveRepairServiceMBean
 
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
 
mbeanServerConn - Variable in class org.apache.cassandra.tools.NodeProbe
 
MBeanWrapper - Interface in org.apache.cassandra.utils
Helper class to avoid catching and rethrowing checked exceptions on MBean and allow turning of MBean registration for test purposes.
MBeanWrapper.NoOpMBeanWrapper - Class in org.apache.cassandra.utils
 
MBeanWrapper.OnException - Enum in org.apache.cassandra.utils
 
MBeanWrapper.PlatformMBeanWrapper - Class in org.apache.cassandra.utils
 
MD5Digest - Class in org.apache.cassandra.utils
The result of the computation of an MD5 digest.
mean() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
MEAN_LIFETIME_IN_S - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
meanPartitionSize - Variable in class org.apache.cassandra.metrics.TableMetrics
Size of the smallest compacted partition
meanRate() - Method in class org.apache.cassandra.metrics.RestorableMeter
Returns the mean rate of events per second since this object was created.
measure(Object) - Static method in class org.apache.cassandra.utils.ObjectSizes
 
measureDeep(Object) - Static method in class org.apache.cassandra.utils.ObjectSizes
 
memAvailable - Variable in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
memberOf - Variable in class org.apache.cassandra.auth.Role
 
MemIndex - Class in org.apache.cassandra.index.sasi.memory
 
MemIndex(AbstractType<?>, ColumnIndex) - Constructor for class org.apache.cassandra.index.sasi.memory.MemIndex
 
Memoized(T) - Constructor for class org.apache.cassandra.utils.ExpiringMemoizingSupplier.Memoized
 
memoizeWithExpiration(Supplier<ExpiringMemoizingSupplier.ReturnValue<T>>, long, TimeUnit) - Static method in class org.apache.cassandra.utils.ExpiringMemoizingSupplier
 
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_POOL - Static variable in class org.apache.cassandra.db.Memtable
 
MemoryInputStream - Class in org.apache.cassandra.io.util
 
MemoryInputStream(Memory) - Constructor for class org.apache.cassandra.io.util.MemoryInputStream
 
MemoryInputStream(Memory, int) - Constructor for class org.apache.cassandra.io.util.MemoryInputStream
 
MemoryMappedSegment - Class in org.apache.cassandra.db.commitlog
 
MemoryOutputStream - Class in org.apache.cassandra.io.util
This class provides a way to stream the writes into the Memory
MemoryOutputStream(Memory) - Constructor for class org.apache.cassandra.io.util.MemoryOutputStream
 
memoryUsageThreshold() - Method in class org.apache.cassandra.utils.memory.BufferPool
 
MemoryUtil - Class in org.apache.cassandra.utils.memory
 
MemoryUtil() - Constructor for class org.apache.cassandra.utils.memory.MemoryUtil
 
memProxy - Variable in class org.apache.cassandra.tools.NodeProbe
 
Memtable - Class in org.apache.cassandra.db
 
Memtable(AtomicReference<CommitLogPosition>, ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.Memtable
 
Memtable(TableMetadata) - Constructor for class org.apache.cassandra.db.Memtable
 
memtable - Variable in class org.apache.cassandra.notifications.MemtableDiscardedNotification
 
memtable - Variable in class org.apache.cassandra.notifications.MemtableSwitchedNotification
 
memtable() - Method in class org.apache.cassandra.notifications.SSTableAddedNotification
Returns the memtable from which the tables come when they have been added due to a memtable flush.
Memtable.LastCommitLogPosition - Class in org.apache.cassandra.db
 
Memtable.MemtableUnfilteredPartitionIterator - 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.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
 
memtableCellCount - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
MemtableCleaner - Interface in org.apache.cassandra.utils.memory
The cleaner is used by MemtableCleanerThread in order to reclaim space from memtables, normally by flushing the largest memtable.
MemtableCleanerThread<P extends MemtablePool> - Class in org.apache.cassandra.utils.memory
A thread that reclaims memory from a MemtablePool on demand.
MemtableCleanerThread(P, MemtableCleaner) - Constructor for class org.apache.cassandra.utils.memory.MemtableCleanerThread
 
MemtableCleanerThread.Clean<P extends MemtablePool> - Class in org.apache.cassandra.utils.memory
 
memtableColumnsCount - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Total number of columns present in the memtable.
memtableColumnsCount - Variable in class org.apache.cassandra.metrics.TableMetrics
Total number of columns present in the memtable.
memtableDataSize - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
MemtableDiscardedNotification - Class in org.apache.cassandra.notifications
 
MemtableDiscardedNotification(Memtable) - Constructor for class org.apache.cassandra.notifications.MemtableDiscardedNotification
 
memtableFlushPeriod(int) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
memtableFlushPeriodInMs(int) - Method in class org.apache.cassandra.schema.TableParams.Builder
 
memtableFlushPeriodInMs - Variable in class org.apache.cassandra.schema.TableParams
 
memtableLiveDataSize - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Total amount of live data stored in the memtable, excluding any data structure overhead
memtableLiveDataSize - Variable in class org.apache.cassandra.metrics.TableMetrics
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 partitions overwritten.
memtableOffHeapDataSize - Variable in class org.apache.cassandra.metrics.TableMetrics
Total amount of data stored in the memtable that resides off-heap, including column related overhead and partitions overwritten.
memtableOffHeapMemoryUsed - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
memtableOffHeapUsed - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
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 partitions overwritten.
memtableOnHeapDataSize - Variable in class org.apache.cassandra.metrics.TableMetrics
Total amount of data stored in the memtable that resides on-heap, including column related overhead and partitions overwritten.
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.KeyspaceMetrics
Number of times flush has resulted in the memtable being switched out.
memtableSwitchCount - Variable in class org.apache.cassandra.metrics.TableMetrics
Number of times flush has resulted in the memtable being switched out.
memtableSwitchCount - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
MemtableSwitchedNotification - Class in org.apache.cassandra.notifications
 
MemtableSwitchedNotification(Memtable) - Constructor for class org.apache.cassandra.notifications.MemtableSwitchedNotification
 
MemtableUnfilteredPartitionIterator(ColumnFamilyStore, Iterator<Map.Entry<PartitionPosition, AtomicBTreePartition>>, int, ColumnFilter, DataRange) - Constructor for class org.apache.cassandra.db.Memtable.MemtableUnfilteredPartitionIterator
 
merge(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Return a context w/ an aggregated count for each counter id.
merge(List<Mutation>) - Static method in class org.apache.cassandra.db.Mutation
Creates a new mutation that merges all the provided mutations.
merge(List<PartitionUpdate>) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
Merges the provided updates, yielding a new update that incorporates all those updates.
merge(List<? extends UnfilteredPartitionIterator>, UnfilteredPartitionIterators.MergeListener) - Static method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators
 
merge(List<V>, F) - Static method in class org.apache.cassandra.db.rows.EncodingStats
Merge one or more EncodingStats, that are lazily materialized from some list of arbitrary type by the provided function
merge() - Method in class org.apache.cassandra.db.rows.RangeTombstoneMarker.Merger
 
merge(DeletionTime) - Method in class org.apache.cassandra.db.rows.Row.Merger
 
merge(Row, Row) - Static method in class org.apache.cassandra.db.rows.Rows
 
merge(Row, Row, Row.Builder) - Static method in class org.apache.cassandra.db.rows.Rows
Merges two rows into the given builder, mainly for merging memtable rows.
merge(List<UnfilteredRowIterator>) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
Returns an iterator that is the result of merging other iterators.
merge(List<UnfilteredRowIterator>, UnfilteredRowIterators.MergeListener) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
Returns an iterator that is the result of merging other iterators, and (optionally) using specific MergeListener.
merge(CombinedValue<Long>) - Method in class org.apache.cassandra.index.sasi.disk.TokenTree.OnDiskToken
 
merge(CombinedValue<OnDiskIndex.DataTerm>) - Method in class org.apache.cassandra.index.sasi.utils.CombinedTerm
 
merge(CombinedValue<V>) - Method in interface org.apache.cassandra.index.sasi.utils.CombinedValue
 
merge(Object[], Object[], Comparator<? super K>, UpdateFunction<K, K>) - Static method in class org.apache.cassandra.utils.btree.BTree
 
merge(T, T) - Static method in class org.apache.cassandra.utils.Throwables
 
mergeAndAnnounceVersion(Collection<Mutation>) - Method in class org.apache.cassandra.schema.Schema
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)
mergedClustering() - Method in class org.apache.cassandra.db.rows.Row.Merger
 
mergedMarkers() - Method in class org.apache.cassandra.db.rows.RangeTombstoneMarker.Merger
 
mergedRows() - Method in class org.apache.cassandra.db.rows.Row.Merger
 
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.
mergeLazily(List<? extends UnfilteredPartitionIterator>) - Static method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators
 
Merger(int, DeletionTime, boolean) - Constructor for class org.apache.cassandra.db.rows.RangeTombstoneMarker.Merger
 
Merger(int, boolean) - Constructor for class org.apache.cassandra.db.rows.Row.Merger
 
mergeSchemaFrom(InetAddressAndPort, Collection<Mutation>) - Method in class org.apache.cassandra.schema.MigrationCoordinator
 
mergeTo(Columns) - Method in class org.apache.cassandra.db.Columns
Returns the result of merging this Columns object with the provided one.
mergeTo(RegularAndStaticColumns) - Method in class org.apache.cassandra.db.RegularAndStaticColumns
 
mergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
 
mergeWith(SingleRestriction) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
 
mergeWith(SingleRestriction) - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
Merges this restriction with the specified one.
mergeWith(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
mergeWith(EncodingStats) - Method in class org.apache.cassandra.db.rows.EncodingStats
Merge this stats with another one.
MerkleTree - Class in org.apache.cassandra.utils
A MerkleTree implemented as a binary tree.
MerkleTree(IPartitioner, Range<Token>, int, long) - Constructor for class org.apache.cassandra.utils.MerkleTree
 
MerkleTree.RowHash - Class in org.apache.cassandra.utils
Hash value representing a row, to be used to pass hashes to the MerkleTree.
MerkleTree.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.
MerkleTrees - Class in org.apache.cassandra.utils
Wrapper class for handling of multiple MerkleTrees at once.
MerkleTrees(IPartitioner) - Constructor for class org.apache.cassandra.utils.MerkleTrees
Creates empty MerkleTrees object.
MerkleTrees.MerkleTreesSerializer - Class in org.apache.cassandra.utils
 
MerkleTrees.TreeRangeIterator - Class in org.apache.cassandra.utils
 
MerkleTreesSerializer() - Constructor for class org.apache.cassandra.utils.MerkleTrees.MerkleTreesSerializer
 
Message(String) - Constructor for class org.apache.cassandra.audit.BinAuditLogger.Message
 
message(Replica) - Method in class org.apache.cassandra.dht.RangeStreamer.AllowedSourcesFilter
 
message(Replica) - Method in class org.apache.cassandra.dht.RangeStreamer.ExcludeLocalNodeFilter
 
message(Replica) - Method in class org.apache.cassandra.dht.RangeStreamer.FailureDetectorSourceFilter
 
message(Replica) - Method in class org.apache.cassandra.dht.RangeStreamer.SingleDatacenterFilter
 
message(Replica) - Method in interface org.apache.cassandra.dht.RangeStreamer.SourceFilter
 
Message<T> - Class in org.apache.cassandra.net
Immutable main unit of internode communication - what used to be MessageIn and MessageOut fused in one class.
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.Builder<T> - Class in org.apache.cassandra.net
 
Message.Codec<M extends Message> - Interface in org.apache.cassandra.transport
 
Message.Direction - Enum in org.apache.cassandra.transport
 
Message.Header - Class in org.apache.cassandra.net
Split into a separate object to allow partial message deserialization without wasting work and allocation afterwards, if the entire message is necessary and available.
Message.InvalidLegacyProtocolMagic - Exception in org.apache.cassandra.net
 
Message.Request - Class in org.apache.cassandra.transport
 
Message.Response - Class in org.apache.cassandra.transport
 
Message.Serializer - Class in org.apache.cassandra.net
Each message contains a header with several fixed fields, an optional key-value params section, and then the message payload itself.
Message.Type - Enum in org.apache.cassandra.transport
 
messageConsumer() - Method in class org.apache.cassandra.transport.PipelineConfigurator
 
messageDecoder() - Method in class org.apache.cassandra.transport.PipelineConfigurator
 
MessageFlag - Enum in org.apache.cassandra.net
Binary message flags to be passed as flags field of Message.
messageHandlers - Variable in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
messageReceived(StreamMessage) - Method in class org.apache.cassandra.streaming.StreamSession
 
MESSAGING_TYPES - Static variable in enum org.apache.cassandra.net.ConnectionType
 
MessagingMetrics - Class in org.apache.cassandra.metrics
Metrics for messages
MessagingMetrics() - Constructor for class org.apache.cassandra.metrics.MessagingMetrics
 
MessagingMetrics.DCLatencyRecorder - Class in org.apache.cassandra.metrics
 
MessagingService - Class in org.apache.cassandra.net
MessagingService implements all internode communication - with the exception of SSTable streaming (for now).
MessagingService.Version - Enum in org.apache.cassandra.net
 
MessagingServiceMBean - Interface in org.apache.cassandra.net
MBean exposing MessagingService metrics plus allowing to enable/disable back-pressure.
MessagingServiceMBeanImpl - Class in org.apache.cassandra.net
 
messagingVersion - Variable in class org.apache.cassandra.net.OutboundConnectionInitiator.Result.Success
 
metadata() - Static method in class org.apache.cassandra.auth.AuthKeyspace
 
Metadata - Class in org.apache.cassandra.cql3.functions.types
Keeps metadata on the connected cluster, including known nodes and schema definitions.
Metadata() - Constructor for class org.apache.cassandra.cql3.functions.types.Metadata
 
metadata - Variable in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
metadata - Variable in class org.apache.cassandra.cql3.ResultSet
 
metadata - Variable in class org.apache.cassandra.cql3.selection.Selection
 
metadata - Variable in class org.apache.cassandra.cql3.statements.CQL3CasRequest
 
metadata(ClientState) - Method in class org.apache.cassandra.cql3.statements.DescribeStatement.Element
 
metadata(ClientState) - Method in class org.apache.cassandra.cql3.statements.DescribeStatement.Listing
 
metadata(ClientState) - Method in class org.apache.cassandra.cql3.statements.DescribeStatement
Returns the columns of the ResultMetadata
metadata - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement
 
metadata() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
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.ColumnFamilyStore
 
metadata() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
metadata - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
metadata() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
metadata() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
 
metadata() - Method in class org.apache.cassandra.db.Memtable.MemtableUnfilteredPartitionIterator
 
metadata() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
metadata() - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
 
metadata - Variable in class org.apache.cassandra.db.partitions.ImmutableBTreePartition
 
metadata() - Method in class org.apache.cassandra.db.partitions.ImmutableBTreePartition
 
metadata() - Method in interface org.apache.cassandra.db.partitions.Partition
 
metadata() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
 
metadata() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
 
metadata() - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder
The metadata of the table this is a builder on.
metadata() - Method in class org.apache.cassandra.db.partitions.SingletonUnfilteredPartitionIterator
 
metadata() - Method in interface org.apache.cassandra.db.partitions.UnfilteredPartitionIterator
 
metadata() - Method in class org.apache.cassandra.db.ReadExecutionController
 
metadata() - Method in interface org.apache.cassandra.db.ReadQuery
The metadata for the table this is a query on.
metadata() - Method in class org.apache.cassandra.db.repair.CassandraValidationIterator
 
metadata - Variable in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
 
metadata() - Method in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
 
metadata() - Method in interface org.apache.cassandra.db.rows.BaseRowIterator
The metadata for the table this iterator on.
metadata() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
 
metadata() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
 
metadata() - Method in class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
 
metadata() - Method in class org.apache.cassandra.db.SimpleBuilders.PartitionUpdateBuilder
 
metadata() - Method in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
 
metadata() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader.StreamDeserializer
 
metadata() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
metadata() - Method in class org.apache.cassandra.db.transform.BaseRows
 
metadata - Variable in class org.apache.cassandra.db.UnfilteredDeserializer
 
metadata - Variable in class org.apache.cassandra.db.virtual.AbstractVirtualTable
 
metadata() - Method in class org.apache.cassandra.db.virtual.AbstractVirtualTable
 
metadata() - Method in class org.apache.cassandra.db.virtual.VirtualKeyspace
 
metadata() - Method in interface org.apache.cassandra.db.virtual.VirtualTable
Returns the view metadata.
metadata - Variable in class org.apache.cassandra.index.internal.CassandraIndex
 
metadata() - Method in class org.apache.cassandra.index.sasi.plan.QueryController
 
metadata() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
 
metadata() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
metadata - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
metadata - Variable in class org.apache.cassandra.io.sstable.SSTable
 
metadata() - Method in class org.apache.cassandra.io.sstable.SSTable
 
metadata() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
metadata() - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
metadata() - Static method in class org.apache.cassandra.schema.SchemaKeyspace
 
metadata - Variable in class org.apache.cassandra.schema.ViewMetadata
 
metadata() - Static method in class org.apache.cassandra.tracing.TraceKeyspace
 
metadata - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
Describes the variables to be bound in the prepared statement
metadataChanged(StatsMetadata, SSTableReader) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
Called when the metadata has changed for an sstable - for example if the level changed Not called when repair status changes (which is also metadata), because this results in the sstable getting removed from the compaction strategy instance.
metadataChanged(StatsMetadata, SSTableReader) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
metadataCollector - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
MetadataCollector - Class in org.apache.cassandra.io.sstable.metadata
 
MetadataCollector(ClusteringComparator) - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
MetadataCollector(ClusteringComparator, UUID) - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
MetadataCollector(Iterable<SSTableReader>, ClusteringComparator, int) - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
MetadataCollector.MinMaxIntTracker - Class in org.apache.cassandra.io.sstable.metadata
 
MetadataCollector.MinMaxLongTracker - Class in org.apache.cassandra.io.sstable.metadata
 
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
 
metadataFromSSTable(Descriptor) - Static method in class org.apache.cassandra.tools.Util
Construct table schema from info stored in SSTable's Stats.db
metadataRef - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
MetadataSerializer - Class in org.apache.cassandra.io.sstable.metadata
Metadata serializer for SSTables version >= 'na'.
MetadataSerializer() - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
 
MetadataType - Enum in org.apache.cassandra.io.sstable.metadata
Defines Metadata component type.
meter(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
meter(CassandraMetricsRegistry.MetricName, CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
metric - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
metric - Variable in class org.apache.cassandra.db.Keyspace
 
MetricName(Class<?>, String) - Constructor for class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Creates a new CassandraMetricsRegistry.MetricName without a scope.
MetricName(String, String, String) - Constructor for class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Creates a new CassandraMetricsRegistry.MetricName without a scope.
MetricName(Class<?>, String, String) - Constructor for class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Creates a new CassandraMetricsRegistry.MetricName without a scope.
MetricName(String, String, String, String) - Constructor for class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Creates a new CassandraMetricsRegistry.MetricName without a scope.
MetricName(String, String, String, String, String) - Constructor for class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
Creates a new CassandraMetricsRegistry.MetricName without a scope.
MetricNameFactory - Interface in org.apache.cassandra.metrics
 
metricPercentilesAsArray(CassandraMetricsRegistry.JmxHistogramMBean) - Method in class org.apache.cassandra.tools.NodeProbe
 
metricPercentilesAsArray(CassandraMetricsRegistry.JmxTimerMBean) - Method in class org.apache.cassandra.tools.NodeProbe
 
metrics - Variable in class org.apache.cassandra.cache.ChunkCache
 
metrics - Variable in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
metrics - Variable in class org.apache.cassandra.concurrent.SEPExecutor
 
metrics - Static variable in class org.apache.cassandra.cql3.QueryProcessor
 
metrics - Static variable in class org.apache.cassandra.cql3.statements.BatchStatement
 
metrics - Variable in class org.apache.cassandra.db.commitlog.CommitLog
 
metrics - Variable in class org.apache.cassandra.hints.HintsService
 
Metrics - Static variable in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
metrics - Variable in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
metrics - Variable in class org.apache.cassandra.utils.memory.BufferPool
 
metrics() - Method in class org.apache.cassandra.utils.memory.BufferPool
 
metricsFor(TableId) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
microsTimestamp(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
 
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
midpoint(Token, Token) - Method in interface org.apache.cassandra.dht.IPartitioner
Calculate a Token representing the approximate "middle" of the given range.
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
 
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
midpoint(BigInteger, BigInteger, int) - Static method in class org.apache.cassandra.utils.FBUtilities
Given two bit arrays represented as BigIntegers, containing the given number of significant bits, calculate a midpoint.
migrate() - Static method in class org.apache.cassandra.db.SystemKeyspaceMigrator40
 
migrateSystemDataIfNeeded() - Method in class org.apache.cassandra.service.CassandraDaemon
Checks if the data of the local system keyspaces need to be migrated to a different location.
MigrationCoordinator - Class in org.apache.cassandra.schema
 
MigrationCoordinator() - Constructor for class org.apache.cassandra.schema.MigrationCoordinator
 
MigrationManager - Class in org.apache.cassandra.schema
 
MigrationManager.MigrationsSerializer - Class in org.apache.cassandra.schema
 
MigrationsSerializer() - Constructor for class org.apache.cassandra.schema.MigrationManager.MigrationsSerializer
 
min - Variable in class org.apache.cassandra.index.sasi.conf.view.RangeTermTree
 
min - Variable in class org.apache.cassandra.index.sasi.conf.view.TermTree.Builder
 
min() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
min - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
 
min() - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxIntTracker
 
min() - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxLongTracker
 
min - Variable in class org.apache.cassandra.tools.Util.TermHistogram
 
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_BUFFER_SIZE - Static variable in interface org.apache.cassandra.io.util.DiskOptimizationStrategy
 
MIN_BUFFER_SIZE_MASK - Static variable in interface org.apache.cassandra.io.util.DiskOptimizationStrategy
 
MIN_COMPRESS_RATIO - Static variable in class org.apache.cassandra.schema.CompressionParams
 
min_free_space_per_drive_in_mb - Variable in class org.apache.cassandra.config.Config
 
MIN_SSTABLE_SIZE_KEY - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
minClusteringValues - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
minCompactionThreshold() - Method in class org.apache.cassandra.schema.CompactionParams
 
minFunctionForCounter - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The MIN function for counter column values.
minimal(String, String) - Static method in class org.apache.cassandra.schema.TableMetadata
There is a couple of places in the code where we need a TableMetadata object and don't have one readily available and know that only the keyspace and name matter.
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
minimize() - Method in class org.apache.cassandra.db.AbstractArrayClusteringPrefix
 
minimize() - Method in class org.apache.cassandra.db.AbstractBufferClusteringPrefix
 
minimize() - Method in interface org.apache.cassandra.db.ClusteringPrefix
If the prefix contains byte buffers that can be minimized (see ByteBufferUtil.minimalBufferFor(ByteBuffer)), this will return a copy of the prefix with minimized values, otherwise it returns itself.
minimize() - Method in class org.apache.cassandra.db.NativeClustering
 
minimizeBuffers(ByteBuffer[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
MINIMUM - Static variable in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
MINIMUM - Static variable in class org.apache.cassandra.dht.Murmur3Partitioner
 
MINIMUM - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
MINIMUM - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 
minimum_version - Static variable in class org.apache.cassandra.net.MessagingService
 
minimumVersion - Variable in enum org.apache.cassandra.transport.Event.Type
 
minIndexInterval(int) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
minIndexInterval(int) - Method in class org.apache.cassandra.schema.TableParams.Builder
 
minIndexInterval - Variable in class org.apache.cassandra.schema.TableParams
 
minKey - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
minKey() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
minKey() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
 
minKeyBound() - Method in class org.apache.cassandra.dht.Token
 
minLocalDeletionTime - Variable in class org.apache.cassandra.db.rows.EncodingStats
 
minLocalDeletionTime - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
MinMaxIntTracker() - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxIntTracker
 
MinMaxIntTracker(int, int) - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxIntTracker
 
MinMaxLongTracker() - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxLongTracker
 
MinMaxLongTracker(long, long) - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxLongTracker
 
minOffset(OnDiskIndex.IteratorOrder) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
 
minor - Variable in class org.apache.cassandra.utils.CassandraVersion
 
minOrdering() - Static method in class org.apache.cassandra.utils.Interval
 
minPartitionSize - Variable in class org.apache.cassandra.metrics.TableMetrics
Size of the smallest compacted partition
minRange - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
 
minRepaired - Variable in class org.apache.cassandra.repair.consistent.admin.RepairStats
 
minRepaired - Variable in class org.apache.cassandra.repair.consistent.RepairedState.Stats
 
minRepairedAt - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
minRepairedAt(Collection<Range<Token>>) - Method in class org.apache.cassandra.repair.consistent.RepairedState
 
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
 
minSSTableSize - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
minSupportedBloomFilterFpChance() - Static method in class org.apache.cassandra.utils.BloomCalculations
Retrieves the minimum supported BloomFilterFpChance value
minTerm - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
minTerm() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
minTerm() - Method in class org.apache.cassandra.index.sasi.sa.TermIterator
 
minTerm() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
 
minTerm() - Method in class org.apache.cassandra.index.sasi.utils.CombinedTermIterator
 
minTimestamp - Variable in class org.apache.cassandra.db.rows.EncodingStats
 
minTimestamp - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
minTimeUUID(long) - Static method in class org.apache.cassandra.utils.UUIDGen
Returns the smaller possible type 1 UUID having the provided timestamp.
minTimeuuidFct - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
 
minTokenLength(int) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
Set the min allowed token length.
minTTL - Variable in class org.apache.cassandra.db.rows.EncodingStats
 
minTTL - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
minValue() - Method in class org.apache.cassandra.db.DecoratedKey
 
minValue() - Method in interface org.apache.cassandra.dht.RingPosition
 
minValue() - Method in class org.apache.cassandra.dht.Token.KeyBound
 
minValue() - Method in class org.apache.cassandra.dht.Token
 
misses - Variable in class org.apache.cassandra.metrics.BufferPoolMetrics
Total number of misses
misses - Variable in class org.apache.cassandra.metrics.CacheMetrics
Total number of cache misses
missLatency - Variable in class org.apache.cassandra.metrics.ChunkCacheMetrics
Latency of misses
Mmap(ChannelProxy, CompressionMetadata, MmappedRegions) - Constructor for class org.apache.cassandra.io.util.CompressedChunkReader.Mmap
 
mmapped(boolean) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
Set whether to use mmap for reading
MmappedRegions - Class in org.apache.cassandra.io.util
 
MmappedRegions.Region - Class in org.apache.cassandra.io.util
 
MmappedRegions.Tidier - Class in org.apache.cassandra.io.util
 
mockKS(KeyspaceMetadata) - Static method in class org.apache.cassandra.db.Keyspace
 
mod(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteType
 
mod(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
mod(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
mod(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
mod(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
 
mod(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
mod(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
mod(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
 
mod(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.NumberType
Return the remainder.
mod(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ShortType
 
mode - Variable in class org.apache.cassandra.index.sasi.conf.IndexMode
 
mode - Variable in class org.apache.cassandra.index.sasi.conf.view.TermTree.Builder
 
mode - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
mode() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
mode(String) - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.Mode
 
mode - Variable in class org.apache.cassandra.index.sasi.sa.SA
 
mode() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
 
ModificationStatement - Class in org.apache.cassandra.cql3.statements
 
ModificationStatement(StatementType, VariableSpecifications, TableMetadata, Operations, StatementRestrictions, Conditions, Attributes) - Constructor for class org.apache.cassandra.cql3.statements.ModificationStatement
 
ModificationStatement.Parsed - Class in org.apache.cassandra.cql3.statements
 
Monitorable - Interface in org.apache.cassandra.db.monitoring
 
MonitorableImpl - Class in org.apache.cassandra.db.monitoring
 
MonitorableImpl() - Constructor for class org.apache.cassandra.db.monitoring.MonitorableImpl
 
MonitoringState - Enum in org.apache.cassandra.db.monitoring
 
MonotonicClock - Interface in org.apache.cassandra.utils
Wrapper around time related functions that are either implemented by using the default JVM calls or by using a custom implementation for testing purposes.
MonotonicClock.AbstractEpochSamplingClock - Class in org.apache.cassandra.utils
 
MonotonicClock.Defaults - Class in org.apache.cassandra.utils
 
MonotonicClock.SampledClock - Class in org.apache.cassandra.utils
 
MonotonicClock.SystemClock - Class in org.apache.cassandra.utils
 
MonotonicClockTranslation - Interface in org.apache.cassandra.utils
 
MONTHS_PER_YEAR - Static variable in class org.apache.cassandra.cql3.Duration
 
moreContents() - Method in class org.apache.cassandra.service.reads.ShortReadPartitionsProtection
 
MorePartitions<I extends BasePartitionIterator<?>> - Interface in org.apache.cassandra.db.transform
An interface for providing new partitions for a partitions iterator.
MoreRows<I extends BaseRowIterator<?>> - Interface in org.apache.cassandra.db.transform
An interface for providing new row contents for a partition.
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
 
move(String) - Method in class org.apache.cassandra.service.StorageService
 
move(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
move(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
Move - Class in org.apache.cassandra.tools.nodetool
 
Move() - Constructor for class org.apache.cassandra.tools.nodetool.Move
 
moveAndOpenSSTable(ColumnFamilyStore, Descriptor, Descriptor, Set<Component>, boolean) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
Moves the sstable in oldDescriptor to a new place (with generation etc) in newDescriptor.
movedNode(InetAddressAndPort) - Static method in class org.apache.cassandra.transport.Event.TopologyChange
 
moveRecursively(Path, Path) - Static method in class org.apache.cassandra.io.util.FileUtils
Moves the contents of a directory to another directory.
moveToNext() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
moving(Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
msProxy - Variable in class org.apache.cassandra.tools.NodeProbe
 
MultiCBuilder - Class in org.apache.cassandra.db
Builder that allow to build multiple Clustering/ClusteringBound at the same time.
MultiCBuilder(ClusteringComparator) - Constructor for class org.apache.cassandra.db.MultiCBuilder
 
MultiColumnRaw(int) - Constructor for class org.apache.cassandra.cql3.AbstractMarker.MultiColumnRaw
 
MultiColumnRaw() - Constructor for class org.apache.cassandra.cql3.Term.MultiColumnRaw
 
MultiColumnRelation - Class in org.apache.cassandra.cql3
A relation using the tuple notation, which typically affects multiple columns.
MultiColumnRestriction - Class in org.apache.cassandra.cql3.restrictions
 
MultiColumnRestriction(List<ColumnMetadata>) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
 
MultiColumnRestriction.EQRestriction - Class in org.apache.cassandra.cql3.restrictions
 
MultiColumnRestriction.INRestriction - Class in org.apache.cassandra.cql3.restrictions
 
MultiColumnRestriction.InRestrictionWithMarker - Class in org.apache.cassandra.cql3.restrictions
An IN restriction that uses a single marker for a set of IN values that are tuples.
MultiColumnRestriction.InRestrictionWithValues - Class in org.apache.cassandra.cql3.restrictions
An IN restriction that has a set of terms for in values.
MultiColumnRestriction.NotNullRestriction - Class in org.apache.cassandra.cql3.restrictions
 
MultiColumnRestriction.SliceRestriction - Class in org.apache.cassandra.cql3.restrictions
 
MultiItemTerminal() - Constructor for class org.apache.cassandra.cql3.Term.MultiItemTerminal
 
MultiPartitionPager<T extends SinglePartitionReadQuery> - Class in org.apache.cassandra.service.pager
Pager over a list of SinglePartitionReadQuery.
MultiPartitionPager(SinglePartitionReadQuery.Group<T>, PagingState, ProtocolVersion) - Constructor for class org.apache.cassandra.service.pager.MultiPartitionPager
 
MULTIPLE_EXPRESSIONS - Static variable in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
 
multiply(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteType
 
multiply(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
multiply(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
multiply(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
multiply(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
 
multiply(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
multiply(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
multiply(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
 
multiply(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.NumberType
Multiplies the left argument with the right one.
multiply(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ShortType
 
Murmur3Partitioner - Class in org.apache.cassandra.dht
This class generates a BigIntegerToken using a Murmur3 hash.
Murmur3Partitioner() - Constructor for class org.apache.cassandra.dht.Murmur3Partitioner
 
Murmur3Partitioner.LongToken - Class in org.apache.cassandra.dht
 
MurmurHash - Class in org.apache.cassandra.utils
This is a very fast, non-cryptographic hash suitable for general hash-based lookup.
MurmurHash() - Constructor for class org.apache.cassandra.utils.MurmurHash
 
mutableCopy() - Method in interface org.apache.cassandra.db.DeletionInfo
 
mutableCopy() - Method in class org.apache.cassandra.db.MutableDeletionInfo
 
MutableDeletionInfo - Class in org.apache.cassandra.db
A mutable implementation of DeletionInfo.
MutableDeletionInfo(long, int) - Constructor for class org.apache.cassandra.db.MutableDeletionInfo
Creates a DeletionInfo with only a top-level (row) tombstone.
MutableDeletionInfo(DeletionTime) - Constructor for class org.apache.cassandra.db.MutableDeletionInfo
 
MutableDeletionInfo(DeletionTime, RangeTombstoneList) - Constructor for class org.apache.cassandra.db.MutableDeletionInfo
 
MutableDeletionInfo.Builder - Class in org.apache.cassandra.db
Builds DeletionInfo object from (in order) range tombstone markers.
mutate(Descriptor, String, UnaryOperator<StatsMetadata>) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
Mutate SSTable Metadata NOTE: mutating stats metadata of a live sstable will race with entire-sstable-streaming, please use SSTableReader.mutateLevelAndReload(int) instead on live sstable.
mutate(Descriptor, String, UnaryOperator<StatsMetadata>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
 
mutate(List<? extends IMutation>, ConsistencyLevel, long) - Static method in class org.apache.cassandra.service.StorageProxy
Use this method to have these Mutations applied across all replicas.
mutateAtomically(Collection<Mutation>, ConsistencyLevel, boolean, long) - Static method in class org.apache.cassandra.service.StorageProxy
See mutate.
mutateCounter(CounterMutation, String, long) - Static method in class org.apache.cassandra.service.StorageProxy
Handle counter mutation on the coordinator host.
mutatedAnticompactionGauge - Variable in class org.apache.cassandra.metrics.TableMetrics
ratio of how much we anticompact vs how much we could mutate the repair status
mutateLevel(Descriptor, int) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
Mutate SSTable level NOTE: mutating stats metadata of a live sstable will race with entire-sstable-streaming, please use SSTableReader.mutateLevelAndReload(int) instead on live sstable.
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
 
mutateLevelAndReload(int) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Mutate sstable level with a lock to avoid racing with entire-sstable-streaming and then reload sstable metadata
mutateMV(ByteBuffer, Collection<Mutation>, boolean, AtomicLong, long) - Static method in class org.apache.cassandra.service.StorageProxy
Use this method to have these Mutations applied across all replicas.
mutateRepaired(Collection<SSTableReader>, long, UUID, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
Mutates sstable repairedAt times and notifies listeners of the change with the writeLock held.
mutateRepairedAndReload(long, UUID, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Mutate sstable repair metadata with a lock to avoid racing with entire-sstable-streaming and then reload sstable metadata
mutateRepairedMetadata(long, UUID, boolean) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
mutateRepairMetadata(Descriptor, long, UUID, boolean) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
Mutate the repairedAt time, pendingRepair ID, and transient status.
mutateRepairMetadata(Descriptor, long, UUID, boolean) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
 
mutateRepairStatus(boolean) - Method in class org.apache.cassandra.db.compaction.Verifier.Options.Builder
 
mutateRepairStatus - Variable in class org.apache.cassandra.db.compaction.Verifier.Options
 
mutateWithTriggers(List<? extends IMutation>, ConsistencyLevel, boolean, long) - Static method in class org.apache.cassandra.service.StorageProxy
 
Mutation - Class in org.apache.cassandra.db
 
Mutation(PartitionUpdate) - Constructor for class org.apache.cassandra.db.Mutation
 
Mutation(String, DecoratedKey, ImmutableMap<TableId, PartitionUpdate>, long) - Constructor for class org.apache.cassandra.db.Mutation
 
Mutation(String, DecoratedKey, ImmutableMap<TableId, PartitionUpdate>, long, boolean) - Constructor for class org.apache.cassandra.db.Mutation
 
Mutation.MutationSerializer - Class in org.apache.cassandra.db
 
Mutation.PartitionUpdateCollector - Class in org.apache.cassandra.db
Collects finalized partition updates
Mutation.SimpleBuilder - Interface in org.apache.cassandra.db
Interface for building mutations geared towards human.
MutationBuilder(String, DecoratedKey) - Constructor for class org.apache.cassandra.db.SimpleBuilders.MutationBuilder
 
MutationExceededMaxSizeException - Exception in org.apache.cassandra.db
 
mutationInitiator - Static variable in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
MutationInitiator() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogReplayer.MutationInitiator
 
mutations - Variable in class org.apache.cassandra.schema.Schema.TransformationResult
 
MutationSerializer() - Constructor for class org.apache.cassandra.db.Mutation.MutationSerializer
 
mutationSize - Variable in exception org.apache.cassandra.db.MutationExceededMaxSizeException
 
mutationSize - Variable in class org.apache.cassandra.metrics.CASClientWriteRequestMetrics
Metric for tracking the mutation sizes in bytes.
mutationSize - Variable in class org.apache.cassandra.metrics.ClientWriteRequestMetrics
Metric for tracking the mutation sizes in bytes.
mutationsWaitingFor - Variable in class org.apache.cassandra.service.BatchlogResponseHandler.BatchlogCleanup
 
MutationVerbHandler - Class in org.apache.cassandra.db
 
MutationVerbHandler() - Constructor for class org.apache.cassandra.db.MutationVerbHandler
 
Mx4jTool - Class in org.apache.cassandra.utils
If mx4j-tools is in the classpath call maybeLoad to load the HTTP interface of mx4j.
Mx4jTool() - Constructor for class org.apache.cassandra.utils.Mx4jTool
 

N

n - Variable in class org.apache.cassandra.concurrent.NamedThreadFactory
 
name - Variable in class org.apache.cassandra.concurrent.SEPExecutor
 
name - Variable in class org.apache.cassandra.cql3.ColumnSpecification
 
name - Variable in class org.apache.cassandra.cql3.functions.AbstractFunction
 
name() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
NAME - Static variable in class org.apache.cassandra.cql3.functions.FromJsonFct
 
name() - Method in interface org.apache.cassandra.cql3.functions.Function
 
name - Variable in class org.apache.cassandra.cql3.functions.FunctionName
 
NAME - Static variable in class org.apache.cassandra.cql3.functions.ToJsonFct
 
name - Variable in class org.apache.cassandra.cql3.functions.types.DataType
 
name() - Method in class org.apache.cassandra.cql3.statements.QualifiedStatement
 
name - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
name - Variable in class org.apache.cassandra.db.marshal.UserType
 
name() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
 
name() - Method in class org.apache.cassandra.db.ReadCommand
 
name - Variable in class org.apache.cassandra.db.view.View
 
name() - Method in class org.apache.cassandra.db.virtual.VirtualKeyspace
 
name() - Method in interface org.apache.cassandra.db.virtual.VirtualTable
Returns the view name.
name - Variable in class org.apache.cassandra.io.sstable.Component
 
name() - Method in class org.apache.cassandra.io.sstable.Component
 
name - Variable in enum org.apache.cassandra.io.sstable.format.SSTableFormat.Type
 
name() - Method in class org.apache.cassandra.io.util.MmappedRegions.Tidier
 
name - Variable in class org.apache.cassandra.schema.IndexMetadata
 
name - Variable in class org.apache.cassandra.schema.KeyspaceMetadata
 
name - Variable in class org.apache.cassandra.schema.TableMetadata
 
name - Variable in class org.apache.cassandra.schema.TableMetadataRef
 
name - Variable in class org.apache.cassandra.schema.TriggerMetadata
 
name() - Method in class org.apache.cassandra.schema.ViewMetadata
 
name - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsKeyspace
 
name - Variable in class org.apache.cassandra.transport.Event.SchemaChange
 
name() - Method in interface org.apache.cassandra.utils.concurrent.RefCounted.Tidy
 
name - Variable in class org.apache.cassandra.utils.memory.BufferPool
 
NAME_COMPARATOR - Static variable in interface org.apache.cassandra.cql3.SchemaElement
Comparator used to sort Describable name.
NAME_LENGTH - Static variable in class org.apache.cassandra.schema.SchemaConstants
longest permissible KS or CF name.
nameComparator() - Method in class org.apache.cassandra.db.marshal.CollectionType
 
nameComparator() - Method in class org.apache.cassandra.db.marshal.ListType
 
nameComparator() - Method in class org.apache.cassandra.db.marshal.MapType
 
nameComparator() - Method in class org.apache.cassandra.db.marshal.SetType
 
nameComparator() - Method in class org.apache.cassandra.db.marshal.UserType
 
NamedThreadFactory - Class in org.apache.cassandra.concurrent
This class is an implementation of the ThreadFactory interface.
NamedThreadFactory(String) - Constructor for class org.apache.cassandra.concurrent.NamedThreadFactory
 
NamedThreadFactory(String, int) - Constructor for class org.apache.cassandra.concurrent.NamedThreadFactory
 
NamedThreadFactory(String, int, ClassLoader, ThreadGroup) - Constructor for class org.apache.cassandra.concurrent.NamedThreadFactory
 
namePrefix - Variable in class org.apache.cassandra.metrics.LatencyMetrics
 
names - Variable in class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
 
names - Variable in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
names() - Method in class org.apache.cassandra.schema.Keyspaces
 
NANOS_PER_HOUR - Static variable in class org.apache.cassandra.cql3.Duration
 
NANOS_PER_MICRO - Static variable in class org.apache.cassandra.cql3.Duration
 
NANOS_PER_MILLI - Static variable in class org.apache.cassandra.cql3.Duration
 
NANOS_PER_MINUTE - Static variable in class org.apache.cassandra.cql3.Duration
 
NANOS_PER_SECOND - Static variable in class org.apache.cassandra.cql3.Duration
 
nanoTime() - Static method in class org.apache.cassandra.utils.ApproximateTime
no guarantees about relationship to currentTimeMillis; monotonic
nanoTime() - Method in class org.apache.cassandra.utils.SystemTimeSource
 
nanoTime() - Method in interface org.apache.cassandra.utils.TimeSource
 
NATIVE_PORT_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
native_transport_allow_older_protocols - Variable in class org.apache.cassandra.config.Config
 
native_transport_flush_in_batches_legacy - Variable in class org.apache.cassandra.config.Config
 
native_transport_idle_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
native_transport_max_concurrent_connections - Variable in class org.apache.cassandra.config.Config
 
native_transport_max_concurrent_connections_per_ip - Variable in class org.apache.cassandra.config.Config
 
native_transport_max_concurrent_requests_in_bytes - Variable in class org.apache.cassandra.config.Config
 
native_transport_max_concurrent_requests_in_bytes_per_ip - Variable in class org.apache.cassandra.config.Config
 
native_transport_max_frame_size_in_mb - Variable in class org.apache.cassandra.config.Config
 
native_transport_max_negotiable_protocol_version - Variable in class org.apache.cassandra.config.Config
Deprecated.
native_transport_max_threads - Variable in class org.apache.cassandra.config.Config
 
native_transport_port - Variable in class org.apache.cassandra.config.Config
 
native_transport_port_ssl - Variable in class org.apache.cassandra.config.Config
 
native_transport_receive_queue_capacity_in_bytes - Variable in class org.apache.cassandra.config.Config
 
NativeAccessMBean - Interface in org.apache.cassandra.service
 
nativeAddress - Variable in class org.apache.cassandra.service.TokenRange.EndpointDetails
 
nativeaddressAndPort(InetAddressAndPort) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
NativeAggregateFunction - Class in org.apache.cassandra.cql3.functions
Base class for the AggregateFunction native classes.
NativeAggregateFunction(String, AbstractType<?>, AbstractType<?>...) - Constructor for class org.apache.cassandra.cql3.functions.NativeAggregateFunction
 
NativeAllocator - Class in org.apache.cassandra.utils.memory
This NativeAllocator uses global slab allocation strategy with slab size that scales exponentially from 8kb to 1Mb to serve allocation of up to 128kb.
NativeAllocator(NativePool) - Constructor for class org.apache.cassandra.utils.memory.NativeAllocator
 
NativeCell - Class in org.apache.cassandra.db.rows
 
NativeCell(NativeAllocator, OpOrder.Group, Cell<?>) - Constructor for class org.apache.cassandra.db.rows.NativeCell
 
NativeCell(NativeAllocator, OpOrder.Group, ColumnMetadata, long, int, int, ByteBuffer, CellPath) - Constructor for class org.apache.cassandra.db.rows.NativeCell
 
NativeClustering - Class in org.apache.cassandra.db
 
NativeClustering(NativeAllocator, OpOrder.Group, Clustering<?>) - Constructor for class org.apache.cassandra.db.NativeClustering
 
NativeDecoratedKey - Class in org.apache.cassandra.db
 
NativeDecoratedKey(Token, NativeAllocator, OpOrder.Group, ByteBuffer) - Constructor for class org.apache.cassandra.db.NativeDecoratedKey
 
nativeFunction(String) - Static method in class org.apache.cassandra.cql3.functions.FunctionName
 
NativeFunction - Class in org.apache.cassandra.cql3.functions
Base class for our native/hardcoded functions.
NativeFunction(String, AbstractType<?>, AbstractType<?>...) - Constructor for class org.apache.cassandra.cql3.functions.NativeFunction
 
NativeLibrary - Class in org.apache.cassandra.utils
 
NativeLibrary.OSType - Enum in org.apache.cassandra.utils
 
NativeLibraryDarwin - Class in org.apache.cassandra.utils
A NativeLibraryWrapper implementation for Darwin/Mac.
NativeLibraryDarwin() - Constructor for class org.apache.cassandra.utils.NativeLibraryDarwin
 
NativeLibraryLinux - Class in org.apache.cassandra.utils
A NativeLibraryWrapper implementation for Linux.
NativeLibraryLinux() - Constructor for class org.apache.cassandra.utils.NativeLibraryLinux
 
NativeLibraryWindows - Class in org.apache.cassandra.utils
A NativeLibraryWrapper implementation for Windows.
NativeLibraryWindows() - Constructor for class org.apache.cassandra.utils.NativeLibraryWindows
 
NativePool - Class in org.apache.cassandra.utils.memory
 
NativePool(long, long, float, MemtableCleaner) - Constructor for class org.apache.cassandra.utils.memory.NativePool
 
nativePort - Variable in class org.apache.cassandra.tools.LoaderOptions
 
nativeProtocolVersion - Variable in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
NativeScalarFunction - Class in org.apache.cassandra.cql3.functions
Base class for the ScalarFunction native classes.
NativeScalarFunction(String, AbstractType<?>, AbstractType<?>...) - Constructor for class org.apache.cassandra.cql3.functions.NativeScalarFunction
 
NativeSSTableLoaderClient - Class in org.apache.cassandra.utils
 
NativeSSTableLoaderClient(Collection<InetSocketAddress>, int, String, String, SSLOptions) - Constructor for class org.apache.cassandra.utils.NativeSSTableLoaderClient
 
NativeSSTableLoaderClient(Collection<InetSocketAddress>, int, AuthProvider, SSLOptions) - Constructor for class org.apache.cassandra.utils.NativeSSTableLoaderClient
 
nativeTransportIdleTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
NativeTransportService - Class in org.apache.cassandra.service
Handles native transport server lifecycle and associated resources.
NativeTransportService() - Constructor for class org.apache.cassandra.service.NativeTransportService
 
natural() - Method in class org.apache.cassandra.locator.ReplicaLayout
The 'natural' owners of the ring position(s), as implied by the current ring layout.
NATURAL_WEIGHER - Static variable in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
needFiltering() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the query need to use filtering.
needFiltering(TableMetadata) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
needsAdvance() - Method in class org.apache.cassandra.utils.MergeIterator.Candidate
 
needsCleaning() - Method in class org.apache.cassandra.utils.memory.MemtablePool
 
needsCleanup(SSTableReader, Collection<Range<Token>>) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
Determines if a cleanup would actually remove any data in this SSTable based on a set of owned ranges.
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
 
negate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteType
 
negate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
negate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
negate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
negate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
 
negate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
negate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
negate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
 
negate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.NumberType
Negates the argument.
negate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ShortType
 
NEGATION_FUNCTION_NAME - Static variable in class org.apache.cassandra.cql3.functions.OperationFcts
The name of the function used to perform negations
NegativeLocalDeletionInfoMetrics() - Constructor for class org.apache.cassandra.db.compaction.Scrubber.NegativeLocalDeletionInfoMetrics
 
NetStats - Class in org.apache.cassandra.tools.nodetool
 
NetStats() - Constructor for class org.apache.cassandra.tools.nodetool.NetStats
 
NettyStreamingMessageSender - Class in org.apache.cassandra.streaming.async
Responsible for sending StreamMessages to a given peer.
NettyStreamingMessageSender(StreamSession, OutboundConnectionSettings, StreamConnectionFactory, int, boolean) - Constructor for class org.apache.cassandra.streaming.async.NettyStreamingMessageSender
 
network_authorizer - Variable in class org.apache.cassandra.config.Config
 
NETWORK_PERMISSIONS - Static variable in class org.apache.cassandra.auth.AuthKeyspace
 
NetworkAuthCache - Class in org.apache.cassandra.auth
 
NetworkAuthCache(INetworkAuthorizer) - Constructor for class org.apache.cassandra.auth.NetworkAuthCache
 
networking_cache_size_in_mb - Variable in class org.apache.cassandra.config.Config
 
NetworkTopologyStrategy - Class in org.apache.cassandra.locator
This Replication Strategy takes a property file that gives the intended replication factor in each datacenter.
NetworkTopologyStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.NetworkTopologyStrategy
 
networkVersion(int) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
networkVersion() - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
NeverSpeculatingReadExecutor(ColumnFamilyStore, ReadCommand, ReplicaPlan.ForTokenRead, long, boolean) - Constructor for class org.apache.cassandra.service.reads.AbstractReadExecutor.NeverSpeculatingReadExecutor
 
NeverSpeculativeRetryPolicy - Class in org.apache.cassandra.service.reads
 
newAggregate() - Method in interface org.apache.cassandra.cql3.functions.AggregateFunction
Creates a new Aggregate instance.
newAggregate() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
newAllocator() - Method in class org.apache.cassandra.utils.memory.HeapPool
 
newAllocator() - Method in class org.apache.cassandra.utils.memory.MemtablePool
 
newAllocator() - Method in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
 
newAllocator() - Method in class org.apache.cassandra.utils.memory.NativePool
 
newAllocator() - Method in class org.apache.cassandra.utils.memory.SlabPool
 
newArgTupleValue(String) - Method in interface org.apache.cassandra.cql3.functions.UDFContext
Creates a new TupleValue instance for an argument.
newArgTupleValue(int) - Method in interface org.apache.cassandra.cql3.functions.UDFContext
Creates a new TupleValue instance for an argument.
newArgTupleValue(String) - Method in class org.apache.cassandra.cql3.functions.UDFContextImpl
 
newArgTupleValue(int) - Method in class org.apache.cassandra.cql3.functions.UDFContextImpl
 
newArgUDTValue(String) - Method in interface org.apache.cassandra.cql3.functions.UDFContext
Creates a new UDTValue instance for an argument.
newArgUDTValue(int) - Method in interface org.apache.cassandra.cql3.functions.UDFContext
Creates a new UDTValue instance for an argument.
newArgUDTValue(String) - Method in class org.apache.cassandra.cql3.functions.UDFContextImpl
 
newArgUDTValue(int) - Method in class org.apache.cassandra.cql3.functions.UDFContextImpl
 
newAuditLogger(String, Map<String, String>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newAuthenticator(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newAuthorizer(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newBarrier() - Method in class org.apache.cassandra.utils.concurrent.OpOrder
Creates a new barrier.
newBuilder() - Static method in class org.apache.cassandra.cql3.conditions.ColumnConditions
Creates a new Builder for ColumnConditions.
newBuilder() - Static method in class org.apache.cassandra.io.util.SequentialWriterOption
 
newBuilder(int) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
construct a new Builder of our own type, so that we can concatenate TODO: this isn't terribly pretty, but we need sometimes to select / merge two Endpoints of unknown type;
newBuilder(Range<Token>) - Method in class org.apache.cassandra.locator.EndpointsByRange.Builder
 
newBuilder(Replica) - Method in class org.apache.cassandra.locator.EndpointsByReplica.Builder
 
newBuilder(int) - Method in class org.apache.cassandra.locator.EndpointsForRange
 
newBuilder(int) - Method in class org.apache.cassandra.locator.EndpointsForToken
 
newBuilder(int) - Method in class org.apache.cassandra.locator.RangesAtEndpoint
 
newBuilder(InetAddressAndPort) - Method in class org.apache.cassandra.locator.RangesByEndpoint.Builder
 
newBuilder(K) - Method in class org.apache.cassandra.locator.ReplicaMultimap.Builder
 
newChannel() - Method in class org.apache.cassandra.io.util.ChannelProxy
ChannelProxy.sharedCopy() can not be used if thread will be interruped, as the backing channel will be closed.
newCleanupTransaction(DecoratedKey, RegularAndStaticColumns, int) - Method in class org.apache.cassandra.index.SecondaryIndexManager
Transaction for use when removing partitions during cleanup
newColumn(ColumnMetadata) - Method in class org.apache.cassandra.db.rows.ComplexColumnData.Builder
 
newCompactionTransaction(DecoratedKey, RegularAndStaticColumns, int, int) - Method in class org.apache.cassandra.index.SecondaryIndexManager
Transaction for use when merging rows during compaction
newConnection(Channel, ProtocolVersion) - Method in interface org.apache.cassandra.transport.Connection.Factory
 
newContainsRestriction(TableMetadata, VariableSpecifications, boolean) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
newContainsRestriction(TableMetadata, VariableSpecifications, boolean) - Method in class org.apache.cassandra.cql3.Relation
Creates a new Contains restriction instance.
newContainsRestriction(TableMetadata, VariableSpecifications, boolean) - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
newContainsRestriction(TableMetadata, VariableSpecifications, boolean) - Method in class org.apache.cassandra.cql3.TokenRelation
 
newCounter(int, boolean, boolean, boolean) - Method in class org.apache.cassandra.db.filter.DataLimits
Returns a new Counter for this limits.
newCountRowsFunction() - Static method in class org.apache.cassandra.cql3.selection.Selectable.WithFunction.Raw
 
newDefaultChannel() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
newDefaultChannel() - Method in class org.apache.cassandra.io.util.DataOutputStreamPlus
 
newDefaultChannel() - Method in class org.apache.cassandra.net.AsyncChannelOutputPlus
 
newDirectBuffer(int, int) - Method in class org.apache.cassandra.net.BufferPoolAllocator
 
newEQRestriction(TableMetadata, VariableSpecifications) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
newEQRestriction(TableMetadata, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Relation
Creates a new EQ restriction instance.
newEQRestriction(TableMetadata, VariableSpecifications) - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
newEQRestriction(TableMetadata, VariableSpecifications) - Method in class org.apache.cassandra.cql3.TokenRelation
 
newExecutor(int, String, String) - Method in class org.apache.cassandra.concurrent.SharedExecutorPool
 
newExecutor(int, LocalAwareExecutorService.MaximumPoolSizeListener, String, String) - Method in class org.apache.cassandra.concurrent.SharedExecutorPool
 
newFactory(ColumnMetadata, int) - Static method in class org.apache.cassandra.cql3.selection.SimpleSelector
 
newFactory(String, Term, AbstractType<?>) - Static method in class org.apache.cassandra.cql3.selection.TermSelector
 
newGenericCounter(String, String, long) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
 
newGroupMaker() - Method in class org.apache.cassandra.db.aggregation.AggregationSpecification
Creates a new GroupMaker instance.
newGroupMaker(GroupingState) - Method in class org.apache.cassandra.db.aggregation.AggregationSpecification
Creates a new GroupMaker instance.
newHeapBuffer(int, int) - Method in class org.apache.cassandra.net.BufferPoolAllocator
shouldn't be invoked
newIndex(ColumnFamilyStore, IndexMetadata) - Static method in class org.apache.cassandra.index.internal.CassandraIndex
Factory method for new CassandraIndex instances
newIndex(ColumnIndex) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
 
newIndexInstance(ColumnFamilyStore, IndexMetadata) - Method in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
 
newINRestriction(TableMetadata, VariableSpecifications) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
newINRestriction(TableMetadata, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Relation
Creates a new IN restriction instance.
newINRestriction(TableMetadata, VariableSpecifications) - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
newINRestriction(TableMetadata, VariableSpecifications) - Method in class org.apache.cassandra.cql3.TokenRelation
 
newInstance(int, int, long) - Static method in class org.apache.cassandra.cql3.Duration
 
newInstance(int, int, long) - Static method in class org.apache.cassandra.cql3.functions.types.Duration
Creates a duration with the given number of months, days and nanoseconds.
newInstance(int) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractCollectionCodec
Return a new instance of C with the given estimated size.
newInstance(int) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractMapCodec
Return a new Map instance with the given estimated size.
newInstance() - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractTupleCodec
Return a new instance of T.
newInstance() - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractUDTCodec
Return a new instance of T.
newInstance(QueryOptions) - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
Creates a new Selector instance.
newInstance(QueryOptions) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector.SimpleSelectorFactory
 
newInstance(ClusteringComparator, int, GroupingState) - Static method in class org.apache.cassandra.db.aggregation.GroupMaker
 
newInstance(ClusteringComparator, int) - Static method in class org.apache.cassandra.db.aggregation.GroupMaker
 
newInstance(ColumnFilter.FetchingStrategy, TableMetadata, RegularAndStaticColumns, SortedSetMultimap<ColumnIdentifier, ColumnSubselection>) - Static method in class org.apache.cassandra.db.filter.ColumnFilter.SelectionColumnFilter
 
newInstance(CompressionMetadata.Chunk[], CompressionParams) - Static method in class org.apache.cassandra.db.streaming.CompressionInfo
Create a CompressionInfo instance which is fully initialized.
newInstance() - Method in enum org.apache.cassandra.utils.ChecksumType
 
newIsNotRestriction(TableMetadata, VariableSpecifications) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
newIsNotRestriction(TableMetadata, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Relation
 
newIsNotRestriction(TableMetadata, VariableSpecifications) - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
newIsNotRestriction(TableMetadata, VariableSpecifications) - Method in class org.apache.cassandra.cql3.TokenRelation
 
newJobContext(Configuration, JobID) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
Creates JobContext from a JobConf and jobId using the correct constructor for based on Hadoop version.
newLikeRestriction(TableMetadata, VariableSpecifications, Operator) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
newLikeRestriction(TableMetadata, VariableSpecifications, Operator) - Method in class org.apache.cassandra.cql3.Relation
 
newLikeRestriction(TableMetadata, VariableSpecifications, Operator) - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
newLikeRestriction(TableMetadata, VariableSpecifications, Operator) - Method in class org.apache.cassandra.cql3.TokenRelation
 
newLine() - Method in class org.apache.cassandra.cql3.CqlBuilder
 
newMapContext(Configuration, TaskAttemptID, RecordReader, RecordWriter, OutputCommitter, StatusReporter, InputSplit) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
Instantiates MapContext under Hadoop 1 and MapContextImpl under Hadoop 2.
newMapping() - Static method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
newMessageDigest(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newNegation(Term.Raw) - Static method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
 
newNegation(Selectable.Raw) - Static method in class org.apache.cassandra.cql3.selection.Selectable.WithFunction.Raw
 
newNetworkAuthorizer(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newNode(InetAddressAndPort) - Static method in class org.apache.cassandra.transport.Event.TopologyChange
 
newOffsets(int, boolean) - Static method in class org.apache.cassandra.utils.EstimatedHistogram
 
newOperation(char, Term.Raw, Term.Raw) - Static method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
 
newOperation(char, Selectable.Raw, Selectable.Raw) - Static method in class org.apache.cassandra.cql3.selection.Selectable.WithFunction.Raw
 
newPartition() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader.StreamDeserializer
 
newPartitioner(Descriptor) - Static method in class org.apache.cassandra.utils.FBUtilities
Create a new instance of a partitioner defined in an SSTable Descriptor
newPartitioner(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newPrepare(DecoratedKey, TableMetadata, UUID) - Static method in class org.apache.cassandra.service.paxos.Commit
 
newProposal(UUID, PartitionUpdate) - Static method in class org.apache.cassandra.service.paxos.Commit
 
newRestrictions(TableMetadata, VariableSpecifications, Operations, WhereClause, Conditions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
Creates the restrictions.
newReturnTupleValue() - Method in interface org.apache.cassandra.cql3.functions.UDFContext
Creates a new TupleValue instance for the return value.
newReturnTupleValue() - Method in class org.apache.cassandra.cql3.functions.UDFContextImpl
 
newReturnUDTValue() - Method in interface org.apache.cassandra.cql3.functions.UDFContext
Creates a new UDTValue instance for the return value.
newReturnUDTValue() - Method in class org.apache.cassandra.cql3.functions.UDFContextImpl
 
newRoleManager(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newRow(DecoratedKey, Clustering<?>) - Method in class org.apache.cassandra.cql3.selection.ResultSetBuilder
Notifies this Builder that a new row is being processed.
newRow(Clustering<V>) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
newRow(Clustering<?>) - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
 
newRow(Clustering<?>) - Method in interface org.apache.cassandra.db.rows.Row.Builder
Prepares the builder to build a new row of clustering clustering.
newSaslNegotiator(InetAddress) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
newSaslNegotiator(InetAddress) - Method in interface org.apache.cassandra.auth.IAuthenticator
Provide a SASL handler to perform authentication for an single connection.
newSaslNegotiator(InetAddress, X509Certificate[]) - Method in interface org.apache.cassandra.auth.IAuthenticator
Provide a SASL handler to perform authentication for an single connection.
newSaslNegotiator(InetAddress) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
newSelectorFactory(TableMetadata, AbstractType<?>, List<ColumnMetadata>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.selection.Selectable.BetweenParenthesesOrWithTuple
 
newSelectorFactory(TableMetadata, AbstractType<?>, List<ColumnMetadata>, VariableSpecifications) - Method in interface org.apache.cassandra.cql3.selection.Selectable
 
newSelectorFactory(TableMetadata, AbstractType<?>, List<ColumnMetadata>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithCast
 
newSelectorFactory(TableMetadata, AbstractType<?>, List<ColumnMetadata>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithElementSelection
 
newSelectorFactory(TableMetadata, AbstractType<?>, List<ColumnMetadata>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection
 
newSelectorFactory(TableMetadata, AbstractType<?>, List<ColumnMetadata>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFunction
 
newSelectorFactory(TableMetadata, AbstractType<?>, List<ColumnMetadata>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithList
 
newSelectorFactory(TableMetadata, AbstractType<?>, List<ColumnMetadata>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithMapOrUdt
 
newSelectorFactory(TableMetadata, AbstractType<?>, List<ColumnMetadata>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithSet
 
newSelectorFactory(TableMetadata, AbstractType<?>, List<ColumnMetadata>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithSliceSelection
 
newSelectorFactory(TableMetadata, AbstractType<?>, List<ColumnMetadata>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithTerm
 
newSelectorFactory(TableMetadata, AbstractType<?>, List<ColumnMetadata>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithToJSonFunction
 
newSelectorFactory(TableMetadata, AbstractType<?>, List<ColumnMetadata>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithTypeHint
 
newSelectorFactory(TableMetadata, AbstractType<?>, List<ColumnMetadata>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL
 
newSelectorFactory(TableMetadata, AbstractType<?>, List<ColumnMetadata>, VariableSpecifications) - Method in class org.apache.cassandra.schema.ColumnMetadata
 
newSelectors(QueryOptions) - Method in class org.apache.cassandra.cql3.selection.Selection
 
newSession(Map<String, ByteBuffer>) - Method in class org.apache.cassandra.tracing.Tracing
 
newSession(Tracing.TraceType) - Method in class org.apache.cassandra.tracing.Tracing
 
newSession(UUID, Map<String, ByteBuffer>) - Method in class org.apache.cassandra.tracing.Tracing
 
newSession(UUID, Tracing.TraceType, Map<String, ByteBuffer>) - Method in class org.apache.cassandra.tracing.Tracing
This method is intended to be overridden in tracing implementations that need access to the customPayload
newSince(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Tests if the sstable contains data newer than the given age param (in localhost currentMilli time).
newSliceRestriction(TableMetadata, VariableSpecifications, Bound, boolean) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
newSliceRestriction(TableMetadata, VariableSpecifications, Bound, boolean) - Method in class org.apache.cassandra.cql3.Relation
Creates a new Slice restriction instance.
newSliceRestriction(TableMetadata, VariableSpecifications, Bound, boolean) - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
newSliceRestriction(TableMetadata, VariableSpecifications, Bound, boolean) - Method in class org.apache.cassandra.cql3.TokenRelation
 
newSSTableDescriptor(File) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
newSSTableDescriptor(File, SSTableFormat.Type) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
newSSTableDescriptor(File, Version, SSTableFormat.Type) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
newTaskAttemptContext(Configuration, TaskAttemptID) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
Creates TaskAttempContext from a JobConf and jobId using the correct constructor for based on Hadoop version.
newTaskFor(Runnable, T) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
newTaskFor(Runnable, T, ExecutorLocals) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
newTaskFor(Callable<T>) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
newTaskFor(Runnable, T) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
newTaskFor(Callable<T>) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
newTester(ColumnMetadata) - Method in class org.apache.cassandra.db.filter.ColumnFilter
Creates a new Tester to efficiently test the inclusion of cells of complex column column.
newTester(ColumnMetadata) - Method in class org.apache.cassandra.db.filter.ColumnFilter.SelectionColumnFilter
 
newTester(ColumnMetadata) - Method in class org.apache.cassandra.db.filter.ColumnFilter.WildCardColumnFilter
 
newThread(Runnable) - Method in class org.apache.cassandra.concurrent.NamedThreadFactory
 
newTraceState(InetAddressAndPort, UUID, Tracing.TraceType) - Method in class org.apache.cassandra.tracing.Tracing
 
newTupleValue(String) - Method in interface org.apache.cassandra.cql3.functions.UDFContext
Creates a new TupleValue instance for the CQL type definition.
newTupleValue(String) - Method in class org.apache.cassandra.cql3.functions.UDFContextImpl
 
newUDTValue(String) - Method in interface org.apache.cassandra.cql3.functions.UDFContext
Creates a new UDTValue instance by name in the same keyspace.
newUDTValue(String) - Method in class org.apache.cassandra.cql3.functions.UDFContextImpl
 
newUpdateTransaction(PartitionUpdate, WriteContext, int) - Method in class org.apache.cassandra.index.SecondaryIndexManager
Transaction for updates on the write path.
newValue() - Method in class org.apache.cassandra.cql3.functions.types.TupleType
Returns a new empty value for this tuple type.
newValue(Object...) - Method in class org.apache.cassandra.cql3.functions.types.TupleType
Returns a new value for this tuple type that uses the provided values for the components.
newValue() - Method in class org.apache.cassandra.cql3.functions.types.UserType
Returns a new empty value for this user type definition.
newWriter(AbstractType<?>, Descriptor, Map<ColumnMetadata, ColumnIndex>, OperationType) - Static method in class org.apache.cassandra.index.sasi.SASIIndex
 
next() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
next() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
 
next() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
 
next() - Method in class org.apache.cassandra.db.Memtable.MemtableUnfilteredPartitionIterator
 
next() - Method in class org.apache.cassandra.db.partitions.SingletonUnfilteredPartitionIterator
 
next() - Method in class org.apache.cassandra.db.repair.CassandraValidationIterator
 
next() - Method in class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
 
next() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader.StreamDeserializer
 
next(Long, Row) - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
next - Variable in class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
 
next() - Method in class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
 
next() - Method in class org.apache.cassandra.index.sasi.analyzer.DelimiterAnalyzer
 
next - Variable in class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineTask
 
next - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
 
next - Variable in class org.apache.cassandra.index.sasi.utils.AbstractIterator
 
next() - Method in class org.apache.cassandra.index.sasi.utils.AbstractIterator
 
next() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.EmptySSTableScanner
 
next() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
next() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
next() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
next() - Method in class org.apache.cassandra.service.pager.AggregationQueryPager.GroupByPartitionIterator
 
next() - Method in class org.apache.cassandra.tools.nodetool.formatter.TableBuilder.SharedTable
 
next() - Method in class org.apache.cassandra.utils.AbstractIterator
 
next() - Method in class org.apache.cassandra.utils.btree.FullBTreeSearchIterator
 
next(K) - Method in class org.apache.cassandra.utils.btree.FullBTreeSearchIterator
 
next() - Method in class org.apache.cassandra.utils.btree.LeafBTreeSearchIterator
 
next(K) - Method in class org.apache.cassandra.utils.btree.LeafBTreeSearchIterator
 
next(K) - Method in interface org.apache.cassandra.utils.SearchIterator
Searches "forwards" (in direction of travel) in the iterator for the required key; if this or any key greater has already been returned by the iterator, the method may choose to return null, the correct or incorrect output, or fail an assertion.
nextChunk() - Method in interface org.apache.cassandra.db.commitlog.EncryptedFileSegmentInputStream.ChunkProvider
Get the next chunk from the backing provider, if any chunks remain.
nextInternal() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
 
nextIsRow() - Method in class org.apache.cassandra.db.UnfilteredDeserializer
Returns whether the next atom is a row or not.
nextKeyValue() - Method in class org.apache.cassandra.hadoop.cql3.CqlRecordReader
 
nextPageReadQuery(int) - Method in class org.apache.cassandra.service.pager.PartitionRangeQueryPager
 
nextPageReadQuery(int) - Method in class org.apache.cassandra.service.pager.SinglePartitionPager
 
nextSliceIndex() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
Returns the index of the next slice to process.
nextSliceIndex() - Method in class org.apache.cassandra.db.columniterator.SSTableIterator
 
nextSliceIndex() - Method in class org.apache.cassandra.db.columniterator.SSTableReversedIterator
 
nextUnfilteredCluster(Unfiltered) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
 
nextUnfilteredCluster(Unfiltered) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFlushObserver
Called after the unfiltered cluster is written to the sstable.
NINETY_NINE_P - Static variable in class org.apache.cassandra.service.reads.PercentileSpeculativeRetryPolicy
 
NIODataInputStream - Class in org.apache.cassandra.io.util
Rough equivalent of BufferedInputStream and DataInputStream wrapping the input stream of a File or Socket Created to work around the fact that when BIS + DIS delegate to NIO for socket IO they will allocate large thread local direct byte buffers when a large array is used to read.
NIODataInputStream(ReadableByteChannel, int) - Constructor for class org.apache.cassandra.io.util.NIODataInputStream
 
NO_BYTE_BUFFERS - Static variable in class org.apache.cassandra.io.util.Memory
 
NO_COMPRESSION_RATIO - Static variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
NO_DELETION_TIME - Static variable in class org.apache.cassandra.db.rows.Cell
 
NO_EXPIRATION_TIME - Static variable in class org.apache.cassandra.db.LivenessInfo
 
NO_GC - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
 
NO_LIMIT - Static variable in class org.apache.cassandra.db.filter.DataLimits
 
NO_OP - Static variable in interface org.apache.cassandra.index.transactions.CleanupTransaction
 
NO_OP - Static variable in interface org.apache.cassandra.index.transactions.CompactionTransaction
 
NO_OP - Static variable in interface org.apache.cassandra.index.transactions.UpdateTransaction
 
NO_PENDING_REPAIR - Static variable in class org.apache.cassandra.service.ActiveRepairService
 
NO_POSITION - Static variable in class org.apache.cassandra.schema.ColumnMetadata
 
NO_STATS - Static variable in class org.apache.cassandra.db.rows.EncodingStats
 
NO_TIMESTAMP - Static variable in class org.apache.cassandra.db.LivenessInfo
 
NO_TTL - Static variable in class org.apache.cassandra.db.LivenessInfo
 
NO_TTL - Static variable in class org.apache.cassandra.db.rows.Cell
 
noCellLiveRow(Clustering<?>, LivenessInfo) - Static method in class org.apache.cassandra.db.rows.BTreeRow
 
noCompression() - Static method in class org.apache.cassandra.schema.CompressionParams
 
Node(Long, Long) - Constructor for class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
 
node - Variable in class org.apache.cassandra.transport.Event.NodeEvent
 
nodeAddressAndPort() - Method in class org.apache.cassandra.transport.Event.NodeEvent
 
nodeDown(InetAddressAndPort) - Static method in class org.apache.cassandra.transport.Event.StatusChange
 
nodeId() - Method in class org.apache.cassandra.dht.tokenallocator.OfflineTokenAllocator.FakeNode
 
nodeMaxToken - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
 
nodeMinToken - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
 
nodePair - Variable in class org.apache.cassandra.repair.SyncTask
 
nodePair() - Method in class org.apache.cassandra.repair.SyncTask
 
NodePairSerializer() - Constructor for class org.apache.cassandra.repair.SyncNodePair.NodePairSerializer
 
NodeProbe - Class in org.apache.cassandra.tools
JMX client operations for Cassandra.
NodeProbe(String, int, String, String) - Constructor for class org.apache.cassandra.tools.NodeProbe
Creates a NodeProbe using the specified JMX host, port, username, and password.
NodeProbe(String, int) - Constructor for class org.apache.cassandra.tools.NodeProbe
Creates a NodeProbe using the specified JMX host and port.
NodeProbe(String) - Constructor for class org.apache.cassandra.tools.NodeProbe
Creates a NodeProbe using the specified JMX host and default port.
NodeProbe() - Constructor for class org.apache.cassandra.tools.NodeProbe
 
nodes - Variable in class org.apache.cassandra.repair.messages.SyncResponse
nodes that involved in this sync
nodes - Variable in class org.apache.cassandra.repair.SyncStat
 
NodeTool - Class in org.apache.cassandra.tools
 
NodeTool(INodeProbeFactory, Output) - Constructor for class org.apache.cassandra.tools.NodeTool
 
NodeTool.CassHelp - Class in org.apache.cassandra.tools
 
NodeTool.NodeToolCmd - Class in org.apache.cassandra.tools
 
NodeTool.NodeToolCmd.KeyspaceSet - Enum in org.apache.cassandra.tools
 
NodeToolCmd() - Constructor for class org.apache.cassandra.tools.NodeTool.NodeToolCmd
 
nodeUp(InetAddressAndPort) - Static method in class org.apache.cassandra.transport.Event.StatusChange
 
NON_CUSTOM_INDEX_IN_EXPRESSION - Static variable in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
 
NON_DAEMON - Static variable in interface org.apache.cassandra.index.IndexRegistry
An IndexRegistry intended for use when Cassandra is initialized in client or tool mode.
none() - Static method in class org.apache.cassandra.auth.DCPermissions
 
NONE - Static variable in enum org.apache.cassandra.auth.Permission
 
none() - Static method in class org.apache.cassandra.cql3.Attributes
 
NONE - Static variable in class org.apache.cassandra.db.Columns
 
NONE - Static variable in class org.apache.cassandra.db.commitlog.CommitLogPosition
 
none - Static variable in interface org.apache.cassandra.db.compaction.CompactionLogger.Strategy
 
NONE - Static variable in class org.apache.cassandra.db.filter.ColumnFilter
 
NONE - Static variable in class org.apache.cassandra.db.filter.DataLimits
 
NONE - Static variable in class org.apache.cassandra.db.filter.RowFilter
 
NONE - Static variable in class org.apache.cassandra.db.RegularAndStaticColumns
 
NONE - Static variable in class org.apache.cassandra.db.Slices
Slices selecting no rows in a partition.
none() - Static method in class org.apache.cassandra.schema.Functions
 
none() - Static method in class org.apache.cassandra.schema.Indexes
 
none() - Static method in class org.apache.cassandra.schema.Keyspaces
 
none() - Static method in class org.apache.cassandra.schema.Tables
 
none() - Static method in class org.apache.cassandra.schema.Triggers
 
none() - Static method in class org.apache.cassandra.schema.Types
 
none() - Static method in class org.apache.cassandra.schema.Views
 
NONE - Static variable in interface org.apache.cassandra.streaming.StreamSession.MessageStateSink
 
noneStrictlyWrapsAround(Collection<AbstractBounds<T>>) - Static method in class org.apache.cassandra.dht.AbstractBounds
 
nonExpiredSSTables - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
nonLocalStrategy() - Static method in class org.apache.cassandra.db.Keyspace
 
nonPeriodicTasks - Static variable in class org.apache.cassandra.concurrent.ScheduledExecutors
This executor is used for tasks that can have longer execution times, and usually are non periodic.
nonPKRestrictedColumns(boolean) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Returns the non-PK column that are restricted.
nonSystem() - Static method in class org.apache.cassandra.db.Keyspace
 
NonTerminal() - Constructor for class org.apache.cassandra.cql3.Term.NonTerminal
 
NonTokenizingAnalyzer - Class in org.apache.cassandra.index.sasi.analyzer
Analyzer that does *not* tokenize the input.
NonTokenizingAnalyzer() - Constructor for class org.apache.cassandra.index.sasi.analyzer.NonTokenizingAnalyzer
 
NonTokenizingOptions - Class in org.apache.cassandra.index.sasi.analyzer
 
NonTokenizingOptions() - Constructor for class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
 
NonTokenizingOptions.OptionsBuilder - Class in org.apache.cassandra.index.sasi.analyzer
 
NOOP - Static variable in interface org.apache.cassandra.db.compaction.ActiveCompactionsTracker
 
NOOP - Static variable in interface org.apache.cassandra.db.partitions.UnfilteredPartitionIterators.MergeListener
 
NOOP - Static variable in interface org.apache.cassandra.db.rows.UnfilteredRowIterators.MergeListener
 
NOOP - Static variable in class org.apache.cassandra.schema.CompressionParams
 
noop() - Static method in class org.apache.cassandra.schema.CompressionParams
 
noOp - Static variable in interface org.apache.cassandra.utils.btree.UpdateFunction
 
noOp() - Static method in interface org.apache.cassandra.utils.btree.UpdateFunction
 
NOOP_LISTENER - Static variable in interface org.apache.cassandra.io.sstable.format.SSTableReadsListener
Listener that does nothing.
NoOpAnalyzer - Class in org.apache.cassandra.index.sasi.analyzer
Default noOp tokenizer.
NoOpAnalyzer() - Constructor for class org.apache.cassandra.index.sasi.analyzer.NoOpAnalyzer
 
NoOpAuditLogger - Class in org.apache.cassandra.audit
No-Op implementation of IAuditLogger to be used as a default audit logger when audit logging is disabled.
NoOpAuditLogger(Map<String, String>) - Constructor for class org.apache.cassandra.audit.NoOpAuditLogger
 
NoopCompressor - Class in org.apache.cassandra.io.compress
A Compressor which doesn't actually compress any data.
NoopCompressor() - Constructor for class org.apache.cassandra.io.compress.NoopCompressor
 
NoOperation() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.BasicResultFilters.NoOperation
 
NoOpFallbackLoggingSupport - Class in org.apache.cassandra.utils.logging
A fallback implementation with empty implementations which ensures other slf4j bindings (logging implementations) than the default supported framework can be used.
NoOpFallbackLoggingSupport() - Constructor for class org.apache.cassandra.utils.logging.NoOpFallbackLoggingSupport
 
NoOpMBeanWrapper() - Constructor for class org.apache.cassandra.utils.MBeanWrapper.NoOpMBeanWrapper
 
NoopReadRepair<E extends Endpoints<E>,P extends ReplicaPlan.ForRead<E>> - Class in org.apache.cassandra.service.reads.repair
Bypasses the read repair path for short read protection and testing
NoPayload - Class in org.apache.cassandra.net
Empty message payload - primarily used for responses.
noPayload - Static variable in class org.apache.cassandra.net.NoPayload
 
NopCacheProvider - Class in org.apache.cassandra.cache
 
NopCacheProvider() - Constructor for class org.apache.cassandra.cache.NopCacheProvider
 
noPermissions - Static variable in class org.apache.cassandra.security.ThreadAwareSecurityManager
 
noPrimaryKeyLivenessInfo() - Method in interface org.apache.cassandra.db.rows.Row.SimpleBuilder
Don't include any primary key LivenessInfo in the built row.
noPrimaryKeyLivenessInfo() - Method in class org.apache.cassandra.db.SimpleBuilders.RowBuilder
 
noProgress - Variable in class org.apache.cassandra.tools.LoaderOptions
 
NOPROGRESS_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
NoReplicationTokenAllocator<Unit> - Class in org.apache.cassandra.dht.tokenallocator
 
NoReplicationTokenAllocator(NavigableMap<Token, Unit>, ReplicationStrategy<Unit>, IPartitioner) - Constructor for class org.apache.cassandra.dht.tokenallocator.NoReplicationTokenAllocator
 
normal(Collection<Token>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
NORMAL_ALLOCATION_UNIT - Static variable in class org.apache.cassandra.utils.memory.BufferPool
 
NORMAL_CHUNK_SIZE - Static variable in class org.apache.cassandra.utils.memory.BufferPool
The size of a page aligned buffer, 128KiB
normalize(Collection<Range<T>>) - Static method in class org.apache.cassandra.dht.Range
 
normalize(String) - Static method in class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
 
NORMALIZE_LOWERCASE - Static variable in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
 
NORMALIZE_UPPERCASE - Static variable in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
 
noRowsIterator(TableMetadata, DecoratedKey, Row, DeletionTime, boolean) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
Returns an empty unfiltered iterator for a given partition.
NoSpamLogger - Class in org.apache.cassandra.utils
Logging that limits each log statement to firing based on time since the statement last fired.
NoSpamLogger.Level - Enum in org.apache.cassandra.utils
Levels for programmatically specifying the severity of a log statement
NoSpamLogger.NoSpamLogStatement - Class in org.apache.cassandra.utils
 
NoSpamLogStatement(String, long) - Constructor for class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
 
NOT_INDEXED - Static variable in class org.apache.cassandra.index.sasi.conf.IndexMode
 
notification(String) - Method in class org.apache.cassandra.repair.RepairRunnable
 
notifyActivity() - Method in class org.apache.cassandra.tracing.TraceState
 
notifyAuthFailure(QueryState, Exception) - Method in class org.apache.cassandra.auth.AuthEvents
 
notifyAuthSuccess(QueryState) - Method in class org.apache.cassandra.auth.AuthEvents
 
notifyBatchFailure(List<QueryHandler.Prepared>, BatchStatement.Type, List<Object>, List<List<ByteBuffer>>, QueryOptions, QueryState, Exception) - Method in class org.apache.cassandra.cql3.QueryEvents
 
notifyBatchSuccess(BatchStatement.Type, List<? extends CQLStatement>, List<String>, List<List<ByteBuffer>>, QueryOptions, QueryState, long, Message.Response) - Method in class org.apache.cassandra.cql3.QueryEvents
 
notifyDeleting(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
notifyDiscarded(Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
notifyError(Throwable) - Method in class org.apache.cassandra.repair.RepairRunnable
 
notifyExecuteFailure(QueryHandler.Prepared, QueryOptions, QueryState, Exception) - Method in class org.apache.cassandra.cql3.QueryEvents
 
notifyExecuteSuccess(CQLStatement, String, QueryOptions, QueryState, long, Message.Response) - Method in class org.apache.cassandra.cql3.QueryEvents
 
notifyPrepareFailure(CQLStatement, String, QueryState, Exception) - Method in class org.apache.cassandra.cql3.QueryEvents
 
notifyPrepareSuccess(Supplier<QueryHandler.Prepared>, String, QueryState, long, ResultMessage.Prepared) - Method in class org.apache.cassandra.cql3.QueryEvents
 
notifyQueryFailure(CQLStatement, String, QueryOptions, QueryState, Exception) - Method in class org.apache.cassandra.cql3.QueryEvents
 
notifyQuerySuccess(CQLStatement, String, QueryOptions, QueryState, long, Message.Response) - Method in class org.apache.cassandra.cql3.QueryEvents
 
notifyRenewed(Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
notifySSTableMetadataChanged(SSTableReader, StatsMetadata) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
notifySSTableRepairedStatusChanged(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
notifySwitched(Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
notifyTruncated(long) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
NotMemoized(T) - Constructor for class org.apache.cassandra.utils.ExpiringMemoizingSupplier.NotMemoized
 
notNullColumns() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
NotNullRestriction(List<ColumnMetadata>) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.NotNullRestriction
 
now(String, TemporalType<?>) - Static method in class org.apache.cassandra.cql3.functions.TimeFcts
 
now() - Method in class org.apache.cassandra.db.marshal.TemporalType
Returns the current temporal value.
now() - Method in class org.apache.cassandra.db.marshal.TimeType
 
now() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
now() - Method in interface org.apache.cassandra.utils.MonotonicClock
 
now() - Method in class org.apache.cassandra.utils.MonotonicClock.SampledClock
 
now() - Method in class org.apache.cassandra.utils.MonotonicClock.SystemClock
 
nowInSec - Variable in class org.apache.cassandra.db.filter.DataLimits.Counter
 
nowInSec(int) - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder
Sets the current time to use for the following additions to this builder or any derived (row) builder.
nowInSec() - Method in interface org.apache.cassandra.db.ReadQuery
The time in seconds to use as "now" for this query.
nowInSec() - Method in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
 
nowInSec - Variable in class org.apache.cassandra.repair.messages.ValidationRequest
 
nowInSec - Variable in class org.apache.cassandra.repair.Validator
 
nowInSeconds - Variable in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
nowInSeconds() - Static method in class org.apache.cassandra.utils.FBUtilities
 
nts(Object...) - Static method in class org.apache.cassandra.schema.KeyspaceParams
 
NULL_BIT_KEY - Static variable in interface org.apache.cassandra.index.sasi.utils.trie.KeyAnalyzer
Returned by KeyAnalyzer.bitIndex(Object, Object) if a key's bits were all zero (0).
NULL_LITERAL - Static variable in class org.apache.cassandra.cql3.Constants
 
NULL_VALUE - Static variable in class org.apache.cassandra.cql3.Constants
 
NULL_VERSION - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
NullOutputCommitter() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
 
NullOutputHandler() - Constructor for class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter.NullOutputHandler
 
nullRole() - Static method in class org.apache.cassandra.auth.Roles
Return the NullObject Role instance which can be safely used to indicate no information is available when querying for a specific named role.
num_tokens - Variable in class org.apache.cassandra.config.Config
 
numberOfDifferences - Variable in class org.apache.cassandra.repair.SyncStat
 
numberOfEntries() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
 
numberOfExtraBytesToRead(int) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
 
numberOfFetchedColumns() - Method in interface org.apache.cassandra.cql3.selection.Selection.Selectors
Returns the number of fetched columns
numberOfKeys() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
 
numberOfPartitionsEstimate - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
numberOfTables - Variable in class org.apache.cassandra.tools.nodetool.stats.TableStatsHolder
 
numberOfValues() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
 
NumberType<T extends java.lang.Number> - Class in org.apache.cassandra.db.marshal
Base type for the numeric types.
NumberType(AbstractType.ComparisonType) - Constructor for class org.apache.cassandra.db.marshal.NumberType
 
numBlocks - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
 
numGroups() - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder.GroupedSSTableContainer
 
numPendingTasks() - Method in class org.apache.cassandra.utils.memory.MemtableCleanerThread.Clean
Return the number of pending tasks
numPendingTasks() - Method in class org.apache.cassandra.utils.memory.MemtableCleanerThread
Return the number of pending tasks
numPendingTasks - Variable in class org.apache.cassandra.utils.memory.MemtablePool
 
numSSTables - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStat.Builder
 
numSSTables - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStat
 
numWarnings() - Method in class org.apache.cassandra.service.ClientWarn
 

O

obfuscate(String) - Method in class org.apache.cassandra.cql3.PasswordObfuscator
 
OBFUSCATION_TOKEN - Static variable in class org.apache.cassandra.cql3.PasswordObfuscator
 
OBJECT_NAME - Static variable in class org.apache.cassandra.cql3.functions.UDFByteCodeVerifier
 
OBJECT_NAME - Static variable in interface org.apache.cassandra.streaming.StreamManagerMBean
 
objectName() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricMBean
 
ObjectSizes - Class in org.apache.cassandra.utils
A convenience class for wrapping access to MemoryMeter
ObjectSizes() - Constructor for class org.apache.cassandra.utils.ObjectSizes
 
objectToBytes(Object) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
observers - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
obsolete(SSTableReader) - Method in interface org.apache.cassandra.db.lifecycle.ILifecycleTransaction
 
obsolete(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
mark this reader as for obsoletion : on checkpoint() the reader will be removed from the live set
obsolete(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
 
obsoleteOriginals() - Method in interface org.apache.cassandra.db.lifecycle.ILifecycleTransaction
 
obsoleteOriginals() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
obsolete every file in the original transaction
obsoleteOriginals() - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
 
obtain(TableMetadata) - Static method in interface org.apache.cassandra.index.IndexRegistry
Returns the IndexRegistry associated to the specified table.
of(ProtocolVersion, CodecRegistry, DataType...) - Static method in class org.apache.cassandra.cql3.functions.types.TupleType
Creates a "disconnected" tuple type (you should prefer Metadata#newTupleType(DataType...) cluster.getMetadata().newTupleType(...) whenever possible).
of(Term) - Static method in interface org.apache.cassandra.cql3.Terms
Creates a Terms containing a single Term.
of(List<Term>) - Static method in interface org.apache.cassandra.cql3.Terms
Creates a Terms containing a set of Term.
of(ColumnMetadata) - Static method in class org.apache.cassandra.db.Columns
Creates a Columns holding only the one column provided.
of(ColumnMetadata) - Static method in class org.apache.cassandra.db.RegularAndStaticColumns
 
of(int) - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.TermSize
 
of(int) - Static method in enum org.apache.cassandra.index.sasi.disk.TokenTreeBuilder.EntryType
 
of(Replica) - Static method in class org.apache.cassandra.locator.EndpointsForRange
 
of(Replica...) - Static method in class org.apache.cassandra.locator.EndpointsForRange
 
of(Token, Replica) - Static method in class org.apache.cassandra.locator.EndpointsForToken
 
of(Token, Replica...) - Static method in class org.apache.cassandra.locator.EndpointsForToken
 
of(Replica) - Static method in class org.apache.cassandra.locator.RangesAtEndpoint
 
of(Replica...) - Static method in class org.apache.cassandra.locator.RangesAtEndpoint
 
of(Function...) - Static method in class org.apache.cassandra.schema.Functions
 
of(IndexMetadata...) - Static method in class org.apache.cassandra.schema.Indexes
 
of(Iterable<IndexMetadata>) - Static method in class org.apache.cassandra.schema.Indexes
 
of(KeyspaceMetadata...) - Static method in class org.apache.cassandra.schema.Keyspaces
 
of(TableMetadata...) - Static method in class org.apache.cassandra.schema.Tables
 
of(Iterable<TableMetadata>) - Static method in class org.apache.cassandra.schema.Tables
 
of(TriggerMetadata...) - Static method in class org.apache.cassandra.schema.Triggers
 
of(Iterable<TriggerMetadata>) - Static method in class org.apache.cassandra.schema.Triggers
 
of(UserType...) - Static method in class org.apache.cassandra.schema.Types
 
of(Collection<V>) - Static method in class org.apache.cassandra.utils.btree.BTreeSet
 
of(V) - Static method in class org.apache.cassandra.utils.btree.BTreeSet
 
of(Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTreeSet
 
of(BiFunction<V, V, V>) - Static method in class org.apache.cassandra.utils.btree.UpdateFunction.Simple
 
of(ByteBuffer) - Method in enum org.apache.cassandra.utils.ChecksumType
 
of(byte[], int, int) - Method in enum org.apache.cassandra.utils.ChecksumType
 
offer(BinLog.ReleaseableWriteMarshallable) - Method in class org.apache.cassandra.utils.binlog.BinLog
Offer a record to the log.
offer(T) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
offer(T, long, TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
offHeap() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
 
offHeap - Variable in class org.apache.cassandra.utils.memory.MemtablePool
 
OffHeapBitSet - Class in org.apache.cassandra.utils.obs
Off-heap bitset, file compatible with OpeBitSet
OffHeapBitSet(long) - Constructor for class org.apache.cassandra.utils.obs.OffHeapBitSet
 
offHeapMemoryUsedTotal - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
offHeapSize() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
Returns the amount of memory in bytes used off heap.
offHeapSize() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
 
offHeapSize() - Method in class org.apache.cassandra.utils.BloomFilter
 
offHeapSize() - Method in interface org.apache.cassandra.utils.IFilter
Returns the amount of memory in bytes used off heap.
offHeapSize() - Method in interface org.apache.cassandra.utils.obs.IBitSet
Returns the amount of memory in bytes used off heap.
offHeapSize() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
offHeapUsed - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
offline(OperationType, SSTableReader) - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
construct a Transaction for use in an offline operation
offline(OperationType, Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
construct a Transaction for use in an offline operation
offline(OperationType) - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
construct an empty Transaction with no existing readers
OfflineTokenAllocator - Class in org.apache.cassandra.dht.tokenallocator
 
OfflineTokenAllocator() - Constructor for class org.apache.cassandra.dht.tokenallocator.OfflineTokenAllocator
 
OfflineTokenAllocator.FakeNode - Class in org.apache.cassandra.dht.tokenallocator
 
offset - Variable in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
 
offset - Variable in class org.apache.cassandra.io.sstable.IndexInfo
 
offset - Variable in class org.apache.cassandra.io.util.BufferManagingRebufferer
 
offset() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
 
offset() - Method in class org.apache.cassandra.io.util.LimitingRebufferer
 
offset - Variable in class org.apache.cassandra.io.util.MmappedRegions.Region
 
offset() - Method in class org.apache.cassandra.io.util.MmappedRegions.Region
 
offset() - Method in interface org.apache.cassandra.io.util.Rebufferer.BufferHolder
Position in the file of the start of the buffer.
offsetData() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf.LeafEntry
 
offsetData() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf.SimpleLeafEntry
 
offsetExtra() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf.LeafEntry
 
offsetExtra() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf.SimpleLeafEntry
 
offsets() - Method in class org.apache.cassandra.db.ColumnIndex
 
ofListMarker(Lists.Marker, AbstractType<?>) - Static method in interface org.apache.cassandra.cql3.Terms
Creates a Terms for the specified list marker.
ofVerb(Verb) - Method in class org.apache.cassandra.net.Message.Builder
 
OHCProvider - Class in org.apache.cassandra.cache
 
OHCProvider() - Constructor for class org.apache.cassandra.cache.OHCProvider
 
oldMetadata - Variable in class org.apache.cassandra.notifications.SSTableMetadataChanged
 
oldSSTableCount - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
oldVersionSSTableCount - Variable in class org.apache.cassandra.metrics.TableMetrics
Number of SSTables with old version on disk for this CF
onAlive(InetAddressAndPort, EndpointState) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onAlive(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.locator.ReconnectableSnitchHelper
 
onAlive(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.repair.RepairSession
 
onAlive(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.ActiveRepairService
 
onAlive(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onAlive(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onAlive(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.streaming.StreamSession
 
onAlterAggregate(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
onAlterAggregate(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onAlterFunction(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
onAlterFunction(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onAlterKeyspace(String) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
onAlterKeyspace(String) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onAlterTable(String, String, boolean) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
onAlterTable(String, String, boolean) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onAlterType(String, String) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
onAlterType(String, String) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onAlterView(String, String, boolean) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
onCell(int, Clustering<?>, Cell<?>, Cell<?>) - Method in interface org.apache.cassandra.db.rows.RowDiffListener
Called for any cell that is either in the merged row or in input i.
onChange(InetAddressAndPort, ApplicationState, VersionedValue) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onChange(InetAddressAndPort, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.locator.ReconnectableSnitchHelper
 
onChange(InetAddressAndPort, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.repair.RepairSession
 
onChange(InetAddressAndPort, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.ActiveRepairService
 
onChange(InetAddressAndPort, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onChange(InetAddressAndPort, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.StorageService
 
onChange(InetAddressAndPort, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.streaming.StreamSession
 
onClose() - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
 
onClose() - Method in class org.apache.cassandra.db.transform.StoppingTransformation
 
onClose() - Method in class org.apache.cassandra.db.transform.Transformation
Run on the close of any (logical) partitions iterator this function was applied to We stipulate logical, because if applied to a transformed iterator the lifetime of the iterator object may be longer than the lifetime of the "logical" iterator it was applied to; if the iterator is refilled with MoreContents, for instance, the iterator may outlive this function
onClose(InetAddressAndPort) - Method in interface org.apache.cassandra.streaming.StreamSession.MessageStateSink
 
onClosed - Variable in class org.apache.cassandra.net.AbstractMessageHandler
 
onComplete() - Method in class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
 
onCompletion() - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
onCompletion() - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
onComplexDeletion(int, Clustering<?>, ColumnMetadata, DeletionTime, DeletionTime) - Method in interface org.apache.cassandra.db.rows.RowDiffListener
Called for every (non-live) complex deletion of any complex column present in either the merged row of input i.
onCreateAggregate(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
onCreateAggregate(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onCreateFunction(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
onCreateFunction(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onCreateKeyspace(String) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
onCreateKeyspace(String) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onCreateTable(String, String) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
onCreateTable(String, String) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onCreateType(String, String) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
onCreateType(String, String) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onCreateView(String, String) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
onDead(InetAddressAndPort, EndpointState) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onDead(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.locator.ReconnectableSnitchHelper
 
onDead(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.repair.RepairSession
 
onDead(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.ActiveRepairService
 
onDead(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onDead(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onDead(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.streaming.StreamSession
 
onDeletion(int, Clustering<?>, Row.Deletion, Row.Deletion) - Method in interface org.apache.cassandra.db.rows.RowDiffListener
Called for the row deletion of input i.
onDiscardOnClose(Message<?>, InetAddressAndPort) - Method in class org.apache.cassandra.net.RequestCallbacks
 
OnDiskBlock<T extends Term> - Class in org.apache.cassandra.index.sasi.disk
 
OnDiskBlock(Descriptor, MappedBuffer, OnDiskBlock.BlockType) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskBlock
 
OnDiskBlock.BlockType - Enum in org.apache.cassandra.index.sasi.disk
 
OnDiskBlock.SearchResult<T> - Class in org.apache.cassandra.index.sasi.disk
 
OnDiskIndex - Class in org.apache.cassandra.index.sasi.disk
 
OnDiskIndex(File, AbstractType<?>, Function<Long, DecoratedKey>) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
OnDiskIndex.DataBlock - Class in org.apache.cassandra.index.sasi.disk
 
OnDiskIndex.DataLevel - Class in org.apache.cassandra.index.sasi.disk
 
OnDiskIndex.DataTerm - Class in org.apache.cassandra.index.sasi.disk
 
OnDiskIndex.IteratorOrder - Enum in org.apache.cassandra.index.sasi.disk
 
OnDiskIndex.Level<T extends OnDiskBlock> - Class in org.apache.cassandra.index.sasi.disk
 
OnDiskIndex.OnDiskSuperBlock - Class in org.apache.cassandra.index.sasi.disk
 
OnDiskIndex.PointerBlock - Class in org.apache.cassandra.index.sasi.disk
 
OnDiskIndex.PointerLevel - Class in org.apache.cassandra.index.sasi.disk
 
OnDiskIndex.PointerTerm - Class in org.apache.cassandra.index.sasi.disk
 
OnDiskIndexBuilder - Class in org.apache.cassandra.index.sasi.disk
 
OnDiskIndexBuilder(AbstractType<?>, AbstractType<?>, OnDiskIndexBuilder.Mode) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
 
OnDiskIndexBuilder(AbstractType<?>, AbstractType<?>, OnDiskIndexBuilder.Mode, boolean) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
 
OnDiskIndexBuilder.Mode - Enum in org.apache.cassandra.index.sasi.disk
 
OnDiskIndexBuilder.TermSize - Enum in org.apache.cassandra.index.sasi.disk
 
OnDiskIndexIterator - Class in org.apache.cassandra.index.sasi.utils
 
OnDiskIndexIterator(OnDiskIndex) - Constructor for class org.apache.cassandra.index.sasi.utils.OnDiskIndexIterator
 
onDiskLength() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
onDiskLength - Variable in class org.apache.cassandra.io.util.FileHandle
 
onDiskSize() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogSegmentManager
 
onDiskSize() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
onDiskSize() - Method in class org.apache.cassandra.db.commitlog.CompressedSegment
 
onDiskSize() - Method in class org.apache.cassandra.db.commitlog.EncryptedSegment
 
onDiskSize() - Method in class org.apache.cassandra.db.commitlog.MemoryMappedSegment
 
OnDiskSuperBlock(MappedBuffer) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskIndex.OnDiskSuperBlock
 
OnDiskToken(MappedBuffer, long, short, Function<Long, DecoratedKey>) - Constructor for class org.apache.cassandra.index.sasi.disk.TokenTree.OnDiskToken
 
onDown(InetAddressAndPort) - Method in interface org.apache.cassandra.service.IEndpointLifecycleSubscriber
Called when a node is marked DOWN.
onDown(InetAddressAndPort) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onDropAggregate(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.auth.AuthSchemaChangeListener
 
onDropAggregate(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
onDropAggregate(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onDropFunction(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.auth.AuthSchemaChangeListener
 
onDropFunction(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
onDropFunction(String, String, List<AbstractType<?>>) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onDropKeyspace(String) - Method in class org.apache.cassandra.auth.AuthSchemaChangeListener
 
onDropKeyspace(String) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
onDropKeyspace(String) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onDropTable(String, String) - Method in class org.apache.cassandra.auth.AuthSchemaChangeListener
 
onDropTable(String, String) - Method in class org.apache.cassandra.db.SizeEstimatesRecorder
 
onDropTable(String, String) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
onDropTable(String, String) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onDropType(String, String) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
onDropType(String, String) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onDropView(String, String) - Method in class org.apache.cassandra.schema.SchemaChangeListener
 
one() - Method in class org.apache.cassandra.cql3.UntypedResultSet
 
one(SinglePartitionReadCommand) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand.Group
 
one(VirtualTableSinglePartitionReadQuery) - Static method in class org.apache.cassandra.db.VirtualTableSinglePartitionReadQuery.Group
 
ONE_GB - Static variable in class org.apache.cassandra.io.util.FileUtils
 
ONE_KB - Static variable in class org.apache.cassandra.io.util.FileUtils
 
ONE_MB - Static variable in class org.apache.cassandra.io.util.FileUtils
 
ONE_TB - Static variable in class org.apache.cassandra.io.util.FileUtils
 
oneMinuteHitRate - Variable in class org.apache.cassandra.metrics.CacheMetrics
1m hit rate
onEmptyPartitionPostPurge(DecoratedKey) - Method in class org.apache.cassandra.db.partitions.PurgeFunction
 
onError(Throwable) - Method in class org.apache.cassandra.streaming.StreamSession
Signal an error to this stream session: if it's an EOF exception, it tries to understand if the socket was closed after completion or because the peer was down, otherwise sends a SessionFailedMessage and closes the session as StreamSession.State.FAILED.
oneSerializedSize(Pair<DataType, Object>, ProtocolVersion) - Method in class org.apache.cassandra.transport.DataType.Codec
 
onEvent(Event) - Method in interface org.apache.cassandra.transport.SimpleClient.EventHandler
 
onEvent(Event) - Method in class org.apache.cassandra.transport.SimpleClient.SimpleEventHandler
 
onExpired(Message<?>, InetAddressAndPort) - Method in class org.apache.cassandra.net.RequestCallbacks
 
onFailedSerialize(Message<?>, InetAddressAndPort, int, int, Throwable) - Method in class org.apache.cassandra.net.RequestCallbacks
 
onFailure(Throwable) - Method in class org.apache.cassandra.dht.StreamStateStore
 
onFailure(Throwable) - Method in class org.apache.cassandra.io.sstable.SSTableLoader
 
onFailure(InetAddressAndPort, RequestFailureReason) - Method in interface org.apache.cassandra.net.RequestCallback
Called when there is an exception on the remote node or timeout happens
onFailure(Throwable) - Method in class org.apache.cassandra.repair.LocalSyncTask
 
onFailure(Throwable) - Method in class org.apache.cassandra.repair.StreamingRepairTask
If we failed on either stream in or out, respond fail to coordinator
onFailure(InetAddressAndPort, RequestFailureReason) - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
onFailure(InetAddressAndPort, RequestFailureReason) - Method in class org.apache.cassandra.service.BatchlogResponseHandler
 
onFailure(InetAddressAndPort, RequestFailureReason) - Method in class org.apache.cassandra.service.reads.ReadCallback
 
onFailure(InetAddressAndPort, RequestFailureReason) - Method in class org.apache.cassandra.service.TruncateResponseHandler
 
onFailure(Throwable) - Method in class org.apache.cassandra.streaming.management.StreamEventJMXNotifier
 
onFinalAccept(Runnable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
onFinalAccept(Runnable) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
onFinalRejection(Runnable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
onFinalRejection(Runnable) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
onHeap() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
 
onHeap - Variable in class org.apache.cassandra.utils.memory.MemtablePool
 
onInitializationComplete() - Method in class org.apache.cassandra.streaming.StreamSession
Call back when connection initialization is complete to start the prepare phase.
onInitialPipelineReady(ChannelPipeline) - Method in class org.apache.cassandra.transport.PipelineConfigurator
 
onInitialRejection(Runnable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
onInitialRejection(Runnable) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
onInserted(Row) - Method in interface org.apache.cassandra.index.transactions.UpdateTransaction
 
onIRStateChange(LocalSession) - Method in interface org.apache.cassandra.repair.consistent.LocalSessions.Listener
 
onIRStateChange(LocalSession) - Method in class org.apache.cassandra.repair.RepairSession
 
onJoin(InetAddressAndPort, EndpointState) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
Use to inform interested parties about the change in the state for specified endpoint
onJoin(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.locator.ReconnectableSnitchHelper
 
onJoin(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.repair.RepairSession
 
onJoin(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.ActiveRepairService
 
onJoin(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onJoin(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onJoin(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.streaming.StreamSession
 
onJoinCluster(InetAddressAndPort) - Method in interface org.apache.cassandra.service.IEndpointLifecycleSubscriber
Called when a new node joins the cluster, i.e.
onJoinCluster(InetAddressAndPort) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onKeyChange() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
Called at the beginning of each new key, before any reduce is called.
onLeaveCluster(InetAddressAndPort) - Method in interface org.apache.cassandra.service.IEndpointLifecycleSubscriber
Called when a new node leave the cluster (decommission or removeToken).
onLeaveCluster(InetAddressAndPort) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
ONLY_EXPLICITLY_REPAIRED - Static variable in class org.apache.cassandra.tools.nodetool.Repair
 
ONLY_PURGE_REPAIRED_TOMBSTONES - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
onlyBackups(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
onlyCount() - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
 
onlyFull() - Method in class org.apache.cassandra.locator.RangesAtEndpoint
 
onlyOne() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
onlyPurgeRepairedTombstones() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
onlyTransient() - Method in class org.apache.cassandra.locator.RangesAtEndpoint
 
onMergedPartitionLevelDeletion(DeletionTime, DeletionTime[]) - Method in interface org.apache.cassandra.db.rows.UnfilteredRowIterators.MergeListener
Called once for the merged partition.
onMergedPartitionLevelDeletion(DeletionTime, DeletionTime[]) - Method in class org.apache.cassandra.service.reads.repair.RowIteratorMergeListener
 
onMergedRangeTombstoneMarkers(RangeTombstoneMarker, RangeTombstoneMarker[]) - Method in interface org.apache.cassandra.db.rows.UnfilteredRowIterators.MergeListener
Called once for every range tombstone marker participating in the merge.
onMergedRangeTombstoneMarkers(RangeTombstoneMarker, RangeTombstoneMarker[]) - Method in class org.apache.cassandra.service.reads.repair.RowIteratorMergeListener
 
onMergedRows(Row, Row[]) - Method in interface org.apache.cassandra.db.rows.UnfilteredRowIterators.MergeListener
Called once for every row participating in the merge.
onMergedRows(Row, Row[]) - Method in class org.apache.cassandra.service.reads.repair.RowIteratorMergeListener
 
onMove(InetAddressAndPort) - Method in interface org.apache.cassandra.service.IEndpointLifecycleSubscriber
Called when a node has moved (to a new token).
onMove(InetAddressAndPort) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onNegotiationComplete(ChannelPipeline) - Method in class org.apache.cassandra.transport.PipelineConfigurator
 
onNewPartition(DecoratedKey) - Method in class org.apache.cassandra.db.partitions.PurgeFunction
 
onOverloaded(Message<?>, InetAddressAndPort) - Method in class org.apache.cassandra.net.RequestCallbacks
 
onPartitionClose() - Method in class org.apache.cassandra.db.transform.DuplicateRowChecker
 
onPartitionClose() - Method in class org.apache.cassandra.db.transform.StoppingTransformation
 
onPartitionClose() - Method in class org.apache.cassandra.db.transform.Transformation
Run on the close of any (logical) rows iterator this function was applied to We stipulate logical, because if applied to a transformed iterator the lifetime of the iterator object may be longer than the lifetime of the "logical" iterator it was applied to; if the iterator is refilled with MoreContents, for instance, the iterator may outlive this function
onPartitionDeletion(DeletionTime) - Method in interface org.apache.cassandra.index.transactions.CleanupTransaction
 
onPartitionDeletion(DeletionTime) - Method in interface org.apache.cassandra.index.transactions.UpdateTransaction
 
onPrimaryKeyLivenessInfo(int, Clustering<?>, LivenessInfo, LivenessInfo) - Method in interface org.apache.cassandra.db.rows.RowDiffListener
Called for the row primary key liveness info of input i.
onRangeTombstone(RangeTombstone) - Method in interface org.apache.cassandra.index.transactions.UpdateTransaction
 
onReleased(int, File) - Method in interface org.apache.cassandra.utils.binlog.BinLogArchiver
 
onReleased(int, File) - Method in class org.apache.cassandra.utils.binlog.DeletingArchiver
Track store files as they are added and their storage impact.
onReleased(int, File) - Method in class org.apache.cassandra.utils.binlog.ExternalArchiver
 
onRemoval(ChunkCache.Key, ChunkCache.Buffer, RemovalCause) - Method in class org.apache.cassandra.cache.ChunkCache
 
onRemove(InetAddressAndPort) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onRemove(InetAddressAndPort) - Method in class org.apache.cassandra.locator.ReconnectableSnitchHelper
 
onRemove(InetAddressAndPort) - Method in class org.apache.cassandra.repair.RepairSession
 
onRemove(InetAddressAndPort) - Method in class org.apache.cassandra.service.ActiveRepairService
 
onRemove(InetAddressAndPort) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onRemove(InetAddressAndPort) - Method in class org.apache.cassandra.service.StorageService
 
onRemove(InetAddressAndPort) - Method in class org.apache.cassandra.streaming.StreamSession
 
onResponse(Message<T>) - Method in class org.apache.cassandra.net.AsyncOneResponse
 
onResponse(Message<T>) - Method in interface org.apache.cassandra.net.RequestCallback
 
onResponse(Message<T>) - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
null message means "response from local write"
onResponse(Message<T>) - Method in class org.apache.cassandra.service.BatchlogResponseHandler
 
onResponse(Message<T>) - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
onResponse(Message<T>) - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
onResponse(Message<PrepareResponse>) - Method in class org.apache.cassandra.service.paxos.PrepareCallback
 
onResponse(Message<Boolean>) - Method in class org.apache.cassandra.service.paxos.ProposeCallback
 
onResponse(Message<ReadResponse>) - Method in class org.apache.cassandra.service.reads.ReadCallback
 
onResponse(Message<Object>) - Method in class org.apache.cassandra.service.reads.repair.BlockingPartitionRepair
 
onResponse(Message<TruncateResponse>) - Method in class org.apache.cassandra.service.TruncateResponseHandler
 
onResponse(Message<T>) - Method in class org.apache.cassandra.service.WriteResponseHandler
 
onRestart(InetAddressAndPort, EndpointState) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
Called whenever a node is restarted.
onRestart(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.locator.ReconnectableSnitchHelper
 
onRestart(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.repair.RepairSession
 
onRestart(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.ActiveRepairService
 
onRestart(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.LoadBroadcaster
 
onRestart(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onRestart(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.streaming.StreamSession
 
onRowDelete(Row) - Method in interface org.apache.cassandra.index.transactions.CleanupTransaction
 
onRowMerge(Row, Row...) - Method in interface org.apache.cassandra.index.transactions.CompactionTransaction
 
onScanningStarted(SSTableReader) - Method in interface org.apache.cassandra.io.sstable.format.SSTableReadsListener
Handles notification that the specified SSTable is being scanned during a partition range query.
onShutdown() - Method in class org.apache.cassandra.utils.logging.LogbackLoggingSupport
 
onShutdown() - Method in interface org.apache.cassandra.utils.logging.LoggingSupport
Hook used to execute logging implementation specific customization at Cassandra shutdown time.
onSSTableSelected(SSTableReader, RowIndexEntry<?>, SSTableReadsListener.SelectionReason) - Method in interface org.apache.cassandra.io.sstable.format.SSTableReadsListener
Handles notification that the specified SSTable has been selected during a single partition query.
onSSTableSkipped(SSTableReader, SSTableReadsListener.SkippingReason) - Method in interface org.apache.cassandra.io.sstable.format.SSTableReadsListener
Handles notification that the specified SSTable has been skipped during a single partition query.
onStartup() - Method in class org.apache.cassandra.utils.logging.LogbackLoggingSupport
 
onStartup() - Method in interface org.apache.cassandra.utils.logging.LoggingSupport
Hook used to execute logging implementation specific customization at Cassandra startup time.
onSuccess(StreamState) - Method in class org.apache.cassandra.dht.StreamStateStore
 
onSuccess(StreamState) - Method in class org.apache.cassandra.io.sstable.SSTableLoader
 
onSuccess(StreamState) - Method in class org.apache.cassandra.repair.LocalSyncTask
 
onSuccess(StreamState) - Method in class org.apache.cassandra.repair.StreamingRepairTask
If we succeeded on both stream in and out, respond back to coordinator
onSuccess(StreamState) - Method in class org.apache.cassandra.streaming.management.StreamEventJMXNotifier
 
onToken() - Method in class org.apache.cassandra.cql3.Relation
Checks if this relation is a token relation (e.g.
onToken() - Method in class org.apache.cassandra.cql3.TokenRelation
 
onUp(InetAddressAndPort) - Method in interface org.apache.cassandra.service.IEndpointLifecycleSubscriber
Called when a node is marked UP.
onUp(InetAddressAndPort) - Method in class org.apache.cassandra.transport.Server.EventNotifier
 
onUpdated(Row, Row) - Method in interface org.apache.cassandra.index.transactions.UpdateTransaction
 
onUpdateMaximumPoolSize(int) - Method in interface org.apache.cassandra.concurrent.LocalAwareExecutorService.MaximumPoolSizeListener
Listener to follow changes to the maximum pool size
op - Variable in class org.apache.cassandra.index.sasi.plan.Operation.Builder
 
op - Variable in class org.apache.cassandra.index.sasi.plan.Operation
 
opcode - Variable in enum org.apache.cassandra.transport.Message.Type
 
open(String) - Static method in class org.apache.cassandra.db.Keyspace
 
open(boolean) - Method in class org.apache.cassandra.db.Slice
 
open(File) - Static method in class org.apache.cassandra.hints.ChecksummedDataInput
 
open(long) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
open(CompressionParams, String) - Static method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
open(long, long) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
 
open(SSTableReaderBuilder) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Factory
 
open(Descriptor) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
open(Descriptor, TableMetadataRef) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
open(Descriptor, Set<Component>, TableMetadataRef) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
open(Descriptor, Set<Component>, TableMetadataRef, boolean, boolean) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
Open an SSTable for reading
open(Descriptor, long, long, UUID, boolean, TableMetadataRef, MetadataCollector, SerializationHeader, Collection<SSTableFlushObserver>, LifecycleNewTracker) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Factory
 
open(File, File) - Static method in class org.apache.cassandra.io.util.ChecksummedRandomAccessReader
 
open(File) - Static method in class org.apache.cassandra.io.util.RandomAccessReader
Open a RandomAccessReader (not compressed, not mmapped, no read throttling) that will own its channel.
openAll(Set<Map.Entry<Descriptor, Set<Component>>>, TableMetadataRef) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
openAndGetStore(TableMetadataRef) - Static method in class org.apache.cassandra.db.Keyspace
 
openAndGetStore(TableMetadata) - Static method in class org.apache.cassandra.db.Keyspace
 
openBound(boolean) - Method in class org.apache.cassandra.db.ArrayClusteringBoundary
 
openBound(boolean) - Method in class org.apache.cassandra.db.BufferClusteringBoundary
 
openBound(boolean) - Method in interface org.apache.cassandra.db.ClusteringBoundary
 
openBound(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
openBound(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
openBound(boolean) - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
 
openBoundOfBoundary(boolean) - Method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
 
openChannel(File) - Static method in class org.apache.cassandra.io.util.ChannelProxy
 
openDataReader(RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
openDataReader() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
openDeletionTime(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
openDeletionTime(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
openDeletionTime(boolean) - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
 
openEarly() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
openEarly() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
Open the resultant SSTableReader before it has been fully written
openFinalEarly() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
openFinalEarly() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
Open the resultant SSTableReader once it has been fully written, but before the _set_ of tables that are being written together as one atomic operation are all ready
openForBatch(Descriptor, Set<Component>, TableMetadataRef) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
Open SSTable reader to be used in batch mode(such as sstableloader).
openIndexReader() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
openIsInclusive(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
openIsInclusive(boolean) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
openIsInclusive(boolean) - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
 
openMarker - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
 
openNoValidation(Descriptor, Set<Component>, ColumnFamilyStore) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
openNoValidation(Descriptor, TableMetadataRef) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
openReason - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
openReason - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
openResult - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter.TransactionalProxy
 
openSslIsAvailable() - Static method in class org.apache.cassandra.security.SSLFactory
 
openSSTables(Map<InetAddressAndPort, Collection<Range<Token>>>) - Method in class org.apache.cassandra.io.sstable.SSTableLoader
 
openWithIndex(FileHandle) - Method in class org.apache.cassandra.db.RowIndexEntry
 
openWithoutSSTables(String) - Static method in class org.apache.cassandra.db.Keyspace
 
Operation - Class in org.apache.cassandra.cql3
An UPDATE or DELETE operation.
Operation(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Operation
 
operation - Variable in class org.apache.cassandra.index.sasi.plan.Expression
 
Operation - Class in org.apache.cassandra.index.sasi.plan
 
Operation() - Constructor for class org.apache.cassandra.tools.JMXTool.Operation
 
Operation(String, JMXTool.Parameter[], String) - Constructor for class org.apache.cassandra.tools.JMXTool.Operation
 
Operation.Addition - Class in org.apache.cassandra.cql3
 
Operation.Builder - Class in org.apache.cassandra.index.sasi.plan
 
Operation.ColumnDeletion - Class in org.apache.cassandra.cql3
 
Operation.ElementDeletion - Class in org.apache.cassandra.cql3
 
Operation.FieldDeletion - Class in org.apache.cassandra.cql3
 
Operation.OperationType - Enum in org.apache.cassandra.index.sasi.plan
 
Operation.Prepend - Class in org.apache.cassandra.cql3
 
Operation.RawDeletion - Interface in org.apache.cassandra.cql3
A parsed raw DELETE operation.
Operation.RawUpdate - Interface in org.apache.cassandra.cql3
A parsed raw UPDATE operation.
Operation.SetElement - Class in org.apache.cassandra.cql3
 
Operation.SetField - Class in org.apache.cassandra.cql3
 
Operation.SetValue - Class in org.apache.cassandra.cql3
 
Operation.Substraction - Class in org.apache.cassandra.cql3
 
operationCount() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
The number of "operations" contained in the update.
OperationExecutionException - Exception in org.apache.cassandra.exceptions
Thrown when an operation problem has occured (e.g.
OperationExecutionException(String) - Constructor for exception org.apache.cassandra.exceptions.OperationExecutionException
Creates an OperationExecutionException with the specified message.
OperationFcts - Class in org.apache.cassandra.cql3.functions
Operation functions (Mathematics).
operationNames() - Method in class org.apache.cassandra.tools.JMXTool.Info
 
Operations - Class in org.apache.cassandra.cql3
A set of Operations.
Operations(StatementType) - Constructor for class org.apache.cassandra.cql3.Operations
 
operationSet() - Method in class org.apache.cassandra.tools.JMXTool.Info
 
OperationType - Enum in org.apache.cassandra.db.compaction
 
operator - Variable in class org.apache.cassandra.cql3.conditions.ColumnCondition
 
Operator - Enum in org.apache.cassandra.cql3
 
operator() - Method in class org.apache.cassandra.cql3.Relation
 
operator - Variable in class org.apache.cassandra.db.filter.RowFilter.Expression
 
operator() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
 
Operator() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader.Operator
 
opId() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
OpOrder - Class in org.apache.cassandra.utils.concurrent
A class for providing synchronization between producers and consumers that do not communicate directly with each other, but where the consumers need to process their work in contiguous batches.
OpOrder() - Constructor for class org.apache.cassandra.utils.concurrent.OpOrder
 
OpOrder.Barrier - Class in org.apache.cassandra.utils.concurrent
This class represents a synchronisation point providing ordering guarantees on operations started against the enclosing OpOrder.
OpOrder.Group - Class in org.apache.cassandra.utils.concurrent
Represents a group of identically ordered operations, i.e.
OPTIMISE_STREAMS_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
optimiseStreams() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
optimiseStreams - Variable in class org.apache.cassandra.repair.RepairSession
 
optimizationStrategy - Variable in class org.apache.cassandra.io.sstable.SSTable
 
optional - Variable in class org.apache.cassandra.config.EncryptionOptions
 
optionalTasks - Static variable in class org.apache.cassandra.concurrent.ScheduledExecutors
This executor is used for tasks that do not need to be waited for on shutdown/drain.
options - Variable in class org.apache.cassandra.auth.Role
 
options - Variable in class org.apache.cassandra.cql3.UpdateParameters
 
options - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
options() - Method in interface org.apache.cassandra.db.compaction.CompactionLogger.Strategy
 
options() - Static method in class org.apache.cassandra.db.compaction.Verifier
 
Options(Set<String>, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.db.SSTableImporter.Options
 
options(String) - Static method in class org.apache.cassandra.db.SSTableImporter.Options
 
options(Set<String>) - Static method in class org.apache.cassandra.db.SSTableImporter.Options
 
options() - Static method in class org.apache.cassandra.db.SSTableImporter.Options
 
options() - Method in class org.apache.cassandra.schema.CompactionParams
All strategy options - excluding 'class'.
options - Variable in class org.apache.cassandra.schema.IndexMetadata
 
options - Variable in class org.apache.cassandra.schema.ReplicationParams
 
options - Variable in class org.apache.cassandra.transport.messages.BatchMessage
 
options - Variable in class org.apache.cassandra.transport.messages.ExecuteMessage
 
options - Variable in class org.apache.cassandra.transport.messages.QueryMessage
 
options - Variable in class org.apache.cassandra.transport.messages.StartupMessage
 
OptionsBuilder() - Constructor for class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions.OptionsBuilder
 
OptionsBuilder() - Constructor for class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
 
OptionsMessage - Class in org.apache.cassandra.transport.messages
Message to indicate that the server is ready to receive requests.
OptionsMessage() - Constructor for class org.apache.cassandra.transport.messages.OptionsMessage
 
opType() - Method in interface org.apache.cassandra.db.lifecycle.LifecycleNewTracker
 
opType() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
opType() - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
 
order(ByteOrder) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
order(ByteOrder) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
OrderedRangeContainmentChecker(Collection<Range<Token>>) - Constructor for class org.apache.cassandra.dht.Range.OrderedRangeContainmentChecker
 
orderingColumns - Variable in class org.apache.cassandra.cql3.selection.Selection
 
orderings - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
 
OrderPreservingPartitioner - Class in org.apache.cassandra.dht
 
OrderPreservingPartitioner() - Constructor for class org.apache.cassandra.dht.OrderPreservingPartitioner
 
OrderPreservingPartitioner.StringToken - Class in org.apache.cassandra.dht
 
orFail(FailingConsumer<T>) - Static method in interface org.apache.cassandra.utils.FailingConsumer
 
org.apache.cassandra.audit - package org.apache.cassandra.audit
 
org.apache.cassandra.auth - package org.apache.cassandra.auth
 
org.apache.cassandra.auth.jmx - package org.apache.cassandra.auth.jmx
 
org.apache.cassandra.batchlog - package org.apache.cassandra.batchlog
 
org.apache.cassandra.cache - package org.apache.cassandra.cache
 
org.apache.cassandra.concurrent - package org.apache.cassandra.concurrent
 
org.apache.cassandra.config - package org.apache.cassandra.config
 
org.apache.cassandra.cql3 - package org.apache.cassandra.cql3
 
org.apache.cassandra.cql3.conditions - package org.apache.cassandra.cql3.conditions
 
org.apache.cassandra.cql3.functions - package org.apache.cassandra.cql3.functions
 
org.apache.cassandra.cql3.functions.types - package org.apache.cassandra.cql3.functions.types
Contains pieces of the Java Driver that are needed to handle data types in C* User-Defined-Functions/Aggregates.
org.apache.cassandra.cql3.functions.types.exceptions - package org.apache.cassandra.cql3.functions.types.exceptions
 
org.apache.cassandra.cql3.functions.types.utils - package org.apache.cassandra.cql3.functions.types.utils
 
org.apache.cassandra.cql3.restrictions - package org.apache.cassandra.cql3.restrictions
 
org.apache.cassandra.cql3.selection - package org.apache.cassandra.cql3.selection
 
org.apache.cassandra.cql3.statements - package org.apache.cassandra.cql3.statements
 
org.apache.cassandra.cql3.statements.schema - package org.apache.cassandra.cql3.statements.schema
 
org.apache.cassandra.db - package org.apache.cassandra.db
 
org.apache.cassandra.db.aggregation - package org.apache.cassandra.db.aggregation
 
org.apache.cassandra.db.columniterator - package org.apache.cassandra.db.columniterator
 
org.apache.cassandra.db.commitlog - package org.apache.cassandra.db.commitlog
 
org.apache.cassandra.db.compaction - package org.apache.cassandra.db.compaction
 
org.apache.cassandra.db.compaction.writers - package org.apache.cassandra.db.compaction.writers
 
org.apache.cassandra.db.context - package org.apache.cassandra.db.context
 
org.apache.cassandra.db.filter - package org.apache.cassandra.db.filter
 
org.apache.cassandra.db.lifecycle - package org.apache.cassandra.db.lifecycle
 
org.apache.cassandra.db.marshal - package org.apache.cassandra.db.marshal
 
org.apache.cassandra.db.monitoring - package org.apache.cassandra.db.monitoring
 
org.apache.cassandra.db.partitions - package org.apache.cassandra.db.partitions
 
org.apache.cassandra.db.repair - package org.apache.cassandra.db.repair
 
org.apache.cassandra.db.rows - package org.apache.cassandra.db.rows
 
org.apache.cassandra.db.streaming - package org.apache.cassandra.db.streaming
File transfer
org.apache.cassandra.db.transform - package org.apache.cassandra.db.transform
 
org.apache.cassandra.db.view - package org.apache.cassandra.db.view
 
org.apache.cassandra.db.virtual - package org.apache.cassandra.db.virtual
 
org.apache.cassandra.dht - package org.apache.cassandra.dht
 
org.apache.cassandra.dht.tokenallocator - package org.apache.cassandra.dht.tokenallocator
 
org.apache.cassandra.diag - package org.apache.cassandra.diag
 
org.apache.cassandra.diag.store - package org.apache.cassandra.diag.store
 
org.apache.cassandra.exceptions - package org.apache.cassandra.exceptions
 
org.apache.cassandra.fql - package org.apache.cassandra.fql
 
org.apache.cassandra.gms - package org.apache.cassandra.gms
 
org.apache.cassandra.hadoop - package org.apache.cassandra.hadoop
 
org.apache.cassandra.hadoop.cql3 - package org.apache.cassandra.hadoop.cql3
 
org.apache.cassandra.hints - package org.apache.cassandra.hints
Hints subsystem consists of several components.
org.apache.cassandra.index - package org.apache.cassandra.index
 
org.apache.cassandra.index.internal - package org.apache.cassandra.index.internal
 
org.apache.cassandra.index.internal.composites - package org.apache.cassandra.index.internal.composites
 
org.apache.cassandra.index.internal.keys - package org.apache.cassandra.index.internal.keys
 
org.apache.cassandra.index.sasi - package org.apache.cassandra.index.sasi
 
org.apache.cassandra.index.sasi.analyzer - package org.apache.cassandra.index.sasi.analyzer
 
org.apache.cassandra.index.sasi.analyzer.filter - package org.apache.cassandra.index.sasi.analyzer.filter
 
org.apache.cassandra.index.sasi.conf - package org.apache.cassandra.index.sasi.conf
 
org.apache.cassandra.index.sasi.conf.view - package org.apache.cassandra.index.sasi.conf.view
 
org.apache.cassandra.index.sasi.disk - package org.apache.cassandra.index.sasi.disk
 
org.apache.cassandra.index.sasi.exceptions - package org.apache.cassandra.index.sasi.exceptions
 
org.apache.cassandra.index.sasi.memory - package org.apache.cassandra.index.sasi.memory
 
org.apache.cassandra.index.sasi.plan - package org.apache.cassandra.index.sasi.plan
 
org.apache.cassandra.index.sasi.sa - package org.apache.cassandra.index.sasi.sa
 
org.apache.cassandra.index.sasi.utils - package org.apache.cassandra.index.sasi.utils
 
org.apache.cassandra.index.sasi.utils.trie - package org.apache.cassandra.index.sasi.utils.trie
 
org.apache.cassandra.index.transactions - package org.apache.cassandra.index.transactions
 
org.apache.cassandra.io - package org.apache.cassandra.io
 
org.apache.cassandra.io.compress - package org.apache.cassandra.io.compress
 
org.apache.cassandra.io.sstable - package org.apache.cassandra.io.sstable
 
org.apache.cassandra.io.sstable.format - package org.apache.cassandra.io.sstable.format
 
org.apache.cassandra.io.sstable.format.big - package org.apache.cassandra.io.sstable.format.big
 
org.apache.cassandra.io.sstable.metadata - package org.apache.cassandra.io.sstable.metadata
 
org.apache.cassandra.io.util - package org.apache.cassandra.io.util
 
org.apache.cassandra.locator - package org.apache.cassandra.locator
 
org.apache.cassandra.metrics - package org.apache.cassandra.metrics
 
org.apache.cassandra.net - package org.apache.cassandra.net
 
org.apache.cassandra.notifications - package org.apache.cassandra.notifications
 
org.apache.cassandra.repair - package org.apache.cassandra.repair
 
org.apache.cassandra.repair.asymmetric - package org.apache.cassandra.repair.asymmetric
 
org.apache.cassandra.repair.consistent - package org.apache.cassandra.repair.consistent
 
org.apache.cassandra.repair.consistent.admin - package org.apache.cassandra.repair.consistent.admin
 
org.apache.cassandra.repair.messages - package org.apache.cassandra.repair.messages
 
org.apache.cassandra.schema - package org.apache.cassandra.schema
 
org.apache.cassandra.security - package org.apache.cassandra.security
 
org.apache.cassandra.serializers - package org.apache.cassandra.serializers
 
org.apache.cassandra.service - package org.apache.cassandra.service
 
org.apache.cassandra.service.pager - package org.apache.cassandra.service.pager
 
org.apache.cassandra.service.paxos - package org.apache.cassandra.service.paxos
 
org.apache.cassandra.service.reads - package org.apache.cassandra.service.reads
 
org.apache.cassandra.service.reads.range - package org.apache.cassandra.service.reads.range
 
org.apache.cassandra.service.reads.repair - package org.apache.cassandra.service.reads.repair
 
org.apache.cassandra.streaming - package org.apache.cassandra.streaming
 
org.apache.cassandra.streaming.async - package org.apache.cassandra.streaming.async
Non-blocking streaming with netty
org.apache.cassandra.streaming.compress - package org.apache.cassandra.streaming.compress
 
org.apache.cassandra.streaming.management - package org.apache.cassandra.streaming.management
 
org.apache.cassandra.streaming.messages - package org.apache.cassandra.streaming.messages
 
org.apache.cassandra.tools - package org.apache.cassandra.tools
 
org.apache.cassandra.tools.nodetool - package org.apache.cassandra.tools.nodetool
 
org.apache.cassandra.tools.nodetool.formatter - package org.apache.cassandra.tools.nodetool.formatter
 
org.apache.cassandra.tools.nodetool.stats - package org.apache.cassandra.tools.nodetool.stats
 
org.apache.cassandra.tracing - package org.apache.cassandra.tracing
 
org.apache.cassandra.transport - package org.apache.cassandra.transport
 
org.apache.cassandra.transport.messages - package org.apache.cassandra.transport.messages
 
org.apache.cassandra.triggers - package org.apache.cassandra.triggers
 
org.apache.cassandra.utils - package org.apache.cassandra.utils
 
org.apache.cassandra.utils.binlog - package org.apache.cassandra.utils.binlog
 
org.apache.cassandra.utils.btree - package org.apache.cassandra.utils.btree
 
org.apache.cassandra.utils.concurrent - package org.apache.cassandra.utils.concurrent
 
org.apache.cassandra.utils.logging - package org.apache.cassandra.utils.logging
 
org.apache.cassandra.utils.memory - package org.apache.cassandra.utils.memory
 
org.apache.cassandra.utils.obs - package org.apache.cassandra.utils.obs
 
org.apache.cassandra.utils.progress - package org.apache.cassandra.utils.progress
 
org.apache.cassandra.utils.progress.jmx - package org.apache.cassandra.utils.progress.jmx
 
org.apache.cassandra.utils.streamhist - package org.apache.cassandra.utils.streamhist
 
org.apache.cassandra.utils.vint - package org.apache.cassandra.utils.vint
 
originals() - Method in interface org.apache.cassandra.db.lifecycle.ILifecycleTransaction
 
originals() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
the set of readers guarded by this transaction _in their original instance/state_ call current(SSTableReader) on any reader in this set to get the latest instance
originals() - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
 
originatingHostId - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
osType - Static variable in class org.apache.cassandra.utils.NativeLibrary
 
otc_coalescing_enough_coalesced_messages - Variable in class org.apache.cassandra.config.Config
 
otc_coalescing_strategy - Variable in class org.apache.cassandra.config.Config
 
otc_coalescing_window_us - Variable in class org.apache.cassandra.config.Config
 
otc_coalescing_window_us_default - Static variable in class org.apache.cassandra.config.Config
 
out - Variable in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
 
out(Verb, T) - Static method in class org.apache.cassandra.net.Message
Make a request Message with supplied verb and payload.
out(Verb, T, long) - Static method in class org.apache.cassandra.net.Message
 
out - Variable in class org.apache.cassandra.tools.AbstractJmxClient
 
out - Variable in class org.apache.cassandra.tools.Output
 
OUT_OF_BOUNDS_BIT_KEY - Static variable in interface org.apache.cassandra.index.sasi.utils.trie.KeyAnalyzer
Returned by KeyAnalyzer.bitIndex(Object, Object) if a keys indices are out of bounds.
OutboundConnection - Class in org.apache.cassandra.net
Represents a connection type to a peer, and handles the state transistions on the connection and the netty Channel.
OutboundConnectionInitiator<SuccessType extends OutboundConnectionInitiator.Result.Success> - Class in org.apache.cassandra.net
A ChannelHandler to execute the send-side of the internode handshake protocol.
OutboundConnectionInitiator.Result<SuccessType extends OutboundConnectionInitiator.Result.Success> - Class in org.apache.cassandra.net
The result of the handshake.
OutboundConnectionInitiator.Result.MessagingSuccess - Class in org.apache.cassandra.net
 
OutboundConnectionInitiator.Result.StreamingSuccess - Class in org.apache.cassandra.net
 
OutboundConnectionInitiator.Result.Success<SuccessType extends OutboundConnectionInitiator.Result.Success> - Class in org.apache.cassandra.net
 
OutboundConnections - Class in org.apache.cassandra.net
Groups a set of outbound connections to a given peer, and routes outgoing messages to the appropriate connection (based upon message's type or size).
OutboundConnectionSettings - Class in org.apache.cassandra.net
A collection of settings to be passed around for outbound connections.
OutboundConnectionSettings(InetAddressAndPort) - Constructor for class org.apache.cassandra.net.OutboundConnectionSettings
 
OutboundConnectionSettings(InetAddressAndPort, InetAddressAndPort) - Constructor for class org.apache.cassandra.net.OutboundConnectionSettings
 
OutboundConnectionSettings.Framing - Enum in org.apache.cassandra.net
 
outboundSink - Variable in class org.apache.cassandra.net.MessagingService
 
OutboundSink - Class in org.apache.cassandra.net
A message sink that all outbound messages go through.
OutboundSink.Sink - Interface in org.apache.cassandra.net
 
outboundStreamingGroup() - Method in class org.apache.cassandra.net.SocketFactory
 
outgoingBytes - Variable in class org.apache.cassandra.metrics.StreamingMetrics
 
OutgoingStream - Interface in org.apache.cassandra.streaming
Some subset of data to be streamed.
OutgoingStreamMessage - Class in org.apache.cassandra.streaming.messages
 
OutgoingStreamMessage(TableId, StreamSession, OutgoingStream, int) - Constructor for class org.apache.cassandra.streaming.messages.OutgoingStreamMessage
 
output(String) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter.NullOutputHandler
 
output - Variable in class org.apache.cassandra.tools.NodeProbe
 
output() - Method in class org.apache.cassandra.tools.NodeProbe
 
output - Variable in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
 
Output - Class in org.apache.cassandra.tools
 
Output(PrintStream, PrintStream) - Constructor for class org.apache.cassandra.tools.Output
 
output(String) - Method in class org.apache.cassandra.utils.OutputHandler.LogOutput
 
output(String) - Method in interface org.apache.cassandra.utils.OutputHandler
 
output(String) - Method in class org.apache.cassandra.utils.OutputHandler.SystemOutput
 
OUTPUT_LOCATION - Static variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
outputFile - Variable in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
 
OutputHandler - Interface in org.apache.cassandra.utils
 
OutputHandler.LogOutput - Class in org.apache.cassandra.utils
 
OutputHandler.SystemOutput - Class in org.apache.cassandra.utils
 
outSerializer - Variable in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
 
outstandingVersions() - Method in class org.apache.cassandra.schema.MigrationCoordinator
 
outWithFlag(Verb, T, MessageFlag) - Static method in class org.apache.cassandra.net.Message
 
outWithFlags(Verb, T, MessageFlag, MessageFlag) - Static method in class org.apache.cassandra.net.Message
 
OVERFLOW_ENTRY_BYTES - Static variable in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
OVERFLOW_TRAILER_BYTES - Static variable in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
OVERFLOW_TRAILER_CAPACITY - Static variable in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
overflowCollisionCount() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf
 
overflowCollisions - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf
 
overflowCount() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
overflowMemoryInBytes() - Method in class org.apache.cassandra.utils.memory.BufferPool
 
overflowSize - Variable in class org.apache.cassandra.metrics.BufferPoolMetrics
Total size, in bytes, of direct or heap buffers allocated by the pool but not part of the pool either because they are too large to fit or because the pool has exceeded its maximum limit or because it's on-heap allocation.
OverlapIterator<I extends java.lang.Comparable<? super I>,V> - Class in org.apache.cassandra.utils
A class for iterating sequentially through an ordered collection and efficiently finding the overlapping set of matching intervals.
OverlapIterator(Collection<Interval<I, V>>) - Constructor for class org.apache.cassandra.utils.OverlapIterator
 
overlaps() - Method in class org.apache.cassandra.utils.OverlapIterator
 
overloadedBytes() - Method in class org.apache.cassandra.net.OutboundConnection
 
overloadedCount() - Method in class org.apache.cassandra.net.OutboundConnection
 
OverloadedException - Exception in org.apache.cassandra.exceptions
 
OverloadedException(String) - Constructor for exception org.apache.cassandra.exceptions.OverloadedException
 
overrideReadMeter(RestorableMeter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
oversizedMutations - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
Number and rate of oversized mutations
ownershipRatio() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator.SubAllocator
 
owns - Variable in class org.apache.cassandra.tools.nodetool.HostStat
 
owns() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator.SubAllocator
 

P

pack(ByteBuffer[], int, ProtocolVersion) - Static method in class org.apache.cassandra.cql3.functions.types.CodecUtils
Utility method that "packs" together a list of ByteBuffers containing serialized collection elements.
pack(Collection<ByteBuffer>, int, ProtocolVersion) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
 
pack(Collection<V>, ValueAccessor<V>, int, ProtocolVersion) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
 
pageSize() - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
PagingState - Class in org.apache.cassandra.service.pager
 
PagingState(ByteBuffer, PagingState.RowMark, int, int) - Constructor for class org.apache.cassandra.service.pager.PagingState
 
PagingState.RowMark - Class in org.apache.cassandra.service.pager
Marks the last row returned by paging, the one from which paging should continue.
Pair<T1,T2> - Class in org.apache.cassandra.utils
 
Pair(T1, T2) - Constructor for class org.apache.cassandra.utils.Pair
 
PARALLELISM_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
parallelismDegree - Variable in class org.apache.cassandra.repair.RepairSession
 
Parameter() - Constructor for class org.apache.cassandra.tools.JMXTool.Parameter
 
Parameter(String, String) - Constructor for class org.apache.cassandra.tools.JMXTool.Parameter
 
ParameterizedClass - Class in org.apache.cassandra.config
 
ParameterizedClass() - Constructor for class org.apache.cassandra.config.ParameterizedClass
 
ParameterizedClass(String, Map<String, String>) - Constructor for class org.apache.cassandra.config.ParameterizedClass
 
ParameterizedClass(Map<String, ?>) - Constructor for class org.apache.cassandra.config.ParameterizedClass
 
PARAMETERS - Static variable in class org.apache.cassandra.config.ParameterizedClass
 
parameters - Variable in class org.apache.cassandra.config.ParameterizedClass
 
parameters - Variable in class org.apache.cassandra.cql3.statements.SelectStatement
 
Parameters(Map<ColumnIdentifier, Boolean>, List<ColumnIdentifier>, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
 
parameters - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
 
parameters() - Method in class org.apache.cassandra.db.streaming.CompressionInfo
Returns the compression parameters.
parameters - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
 
parameterTypes() - Method in class org.apache.cassandra.tools.JMXTool.Operation
 
params - Variable in class org.apache.cassandra.schema.KeyspaceMetadata
 
params(TableParams) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
params - Variable in class org.apache.cassandra.schema.TableMetadata
 
ParamType - Enum in org.apache.cassandra.net
Type names and serializers for various parameters that can be put in Message params map.
parent - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
 
PARENT_REPAIR_HISTORY - Static variable in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
parentRepairSession - Variable in class org.apache.cassandra.repair.messages.CleanupMessage
 
parentRepairSession - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
 
parentRepairSession - Variable in class org.apache.cassandra.repair.RepairSession
 
ParentRepairSession(InetAddressAndPort, List<ColumnFamilyStore>, Collection<Range<Token>>, boolean, long, boolean, PreviewKind) - Constructor for class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
parentRepairSessionsCount() - Method in class org.apache.cassandra.service.ActiveRepairService
 
parentRepairSessionsCount() - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
Each ongoing repair (incremental and non-incremental) is represented by a ActiveRepairService.ParentRepairSession entry in the ActiveRepairService cache.
parentSession - Variable in class org.apache.cassandra.repair.messages.PrepareConsistentRequest
 
parentSession - Variable in class org.apache.cassandra.repair.messages.PrepareConsistentResponse
 
parentSessionId - Variable in class org.apache.cassandra.repair.RepairJobDesc
 
parkUntilFlushed(long, long) - Method in class org.apache.cassandra.net.AsyncChannelOutputPlus
Utility method for waitUntilFlushed, which actually parks the current thread until the necessary number of bytes have been flushed This may only be invoked by the writer thread, never by the eventLoop.
parse(CqlParser) - Method in interface org.apache.cassandra.cql3.CQLFragmentParser.CQLParserFunction
 
parse(String, QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
 
parse(String) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractCollectionCodec
 
parse(String) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractMapCodec
 
parse(String) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractTupleCodec
 
parse(String) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractUDTCodec
 
parse(String) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Parse the given CQL literal into an instance of the Java type handled by this codec.
parse(String, QueryState, QueryOptions) - Method in interface org.apache.cassandra.cql3.QueryHandler
 
parse(String, QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
parse(String, String) - Static method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement
 
parse(String) - Static method in class org.apache.cassandra.cql3.WhereClause
 
parse(String) - Static method in class org.apache.cassandra.db.marshal.TypeParser
Parse a string containing an type definition.
parse(CharSequence) - Static method in class org.apache.cassandra.db.marshal.TypeParser
 
parse() - Method in class org.apache.cassandra.db.marshal.TypeParser
Parse an AbstractType from current position of this parser.
parse(TableMetadata, IndexMetadata) - Static method in class org.apache.cassandra.index.TargetParser
 
parse(TableMetadata, String) - Static method in class org.apache.cassandra.index.TargetParser
 
parse(String) - Static method in class org.apache.cassandra.io.sstable.Component
Parse the component part of a sstable filename into a Component object.
parse(List<String>) - Static method in class org.apache.cassandra.repair.consistent.admin.SchemaArgsParser
 
parse(String...) - Static method in class org.apache.cassandra.repair.consistent.admin.SchemaArgsParser
 
parse(Map<String, String>, IPartitioner) - Static method in class org.apache.cassandra.repair.messages.RepairOption
Construct RepairOptions object from given map of Strings.
parse(String, String, Types) - Static method in class org.apache.cassandra.schema.CQLTypeParser
 
parseAndSetField(String, T, int) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractTupleCodec
Parse an individual field and set it on an object, as part of parsing the whole object (see TypeCodec.AbstractTupleCodec.parse(String)).
parseAndSetField(String, T, String) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractUDTCodec
Parse an individual field and set it on an object, as part of parsing the whole object (see TypeCodec.AbstractUDTCodec.parse(String)).
parseAny(CQLFragmentParser.CQLParserFunction<R>, String, String) - Static method in class org.apache.cassandra.cql3.CQLFragmentParser
 
parseAnyUnhandled(CQLFragmentParser.CQLParserFunction<R>, String) - Static method in class org.apache.cassandra.cql3.CQLFragmentParser
Just call a parser method in CqlParser - does not do any error handling.
parseComparator(int, String) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
Used by fromString
parseComparator(int, String) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
parseComparator(int, String) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
Parsed(BatchStatement.Type, Attributes.Raw, List<ModificationStatement.Parsed>) - Constructor for class org.apache.cassandra.cql3.statements.BatchStatement.Parsed
 
Parsed(QualifiedName, Attributes.Raw, List<Operation.RawDeletion>, WhereClause, List<Pair<ColumnIdentifier, ColumnCondition.Raw>>, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DeleteStatement.Parsed
 
Parsed(QualifiedName, StatementType, Attributes.Raw, List<Pair<ColumnIdentifier, ColumnCondition.Raw>>, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
 
parseDefaultParameters(AbstractType<?>, TypeParser) - Static method in class org.apache.cassandra.db.marshal.AbstractType
 
ParsedInsert(QualifiedName, Attributes.Raw, List<ColumnIdentifier>, List<Term.Raw>, boolean) - Constructor for class org.apache.cassandra.cql3.statements.UpdateStatement.ParsedInsert
A parsed INSERT statement.
ParsedInsertJson(QualifiedName, Attributes.Raw, Json.Raw, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.UpdateStatement.ParsedInsertJson
 
ParsedUpdate(QualifiedName, Attributes.Raw, List<Pair<ColumnIdentifier, Operation.RawUpdate>>, WhereClause, List<Pair<ColumnIdentifier, ColumnCondition.Raw>>, boolean) - Constructor for class org.apache.cassandra.cql3.statements.UpdateStatement.ParsedUpdate
Creates a new UpdateStatement from a column family name, columns map, consistency level, and key term.
parseFileSize(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
parseJson(String, Collection<ColumnMetadata>) - Static method in class org.apache.cassandra.cql3.Json
Given a JSON string, return a map of columns to their values for the insert.
parseOne(String, ProtocolVersion, CodecRegistry) - Static method in class org.apache.cassandra.cql3.functions.types.DataTypeClassNameParser
 
parseOptionalKeyspace(List<String>, NodeProbe) - Method in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
 
parseOptionalKeyspace(List<String>, NodeProbe, NodeTool.NodeToolCmd.KeyspaceSet) - Method in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
 
parseOptionalTables(List<String>) - Method in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
 
parseRanges(String, IPartitioner) - Static method in class org.apache.cassandra.repair.messages.RepairOption
 
parseStatement(String, ClientState) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
parseStatement(String, Class<T>, String) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
parseStatement(String) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
ParseUtils - Class in org.apache.cassandra.cql3.functions.types
Simple utility class used to help parsing CQL values (mainly UDT and collection ones).
partialCompactionsAcceptable() - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
partialCompactionsAcceptable() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
 
partialCompactionsAcceptable() - Method in class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
 
participant - Variable in class org.apache.cassandra.repair.messages.FinalizePromise
 
participant - Variable in class org.apache.cassandra.repair.messages.PrepareConsistentResponse
 
participants - Variable in class org.apache.cassandra.repair.consistent.ConsistentSession
 
PARTICIPANTS - Static variable in class org.apache.cassandra.repair.consistent.LocalSessionInfo
 
participants - Variable in class org.apache.cassandra.repair.messages.PrepareConsistentRequest
 
PARTICIPANTS_WP - Static variable in class org.apache.cassandra.repair.consistent.LocalSessionInfo
 
partition() - Static method in class org.apache.cassandra.db.EmptyIterators
 
Partition - Interface in org.apache.cassandra.db.partitions
In-memory representation of a Partition.
PARTITION_KEY_INDEX_FUNCTIONS - Static variable in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
 
PARTITION_MESSAGE_LIMIT - Static variable in exception org.apache.cassandra.db.MutationExceededMaxSizeException
 
partitionCount() - Method in class org.apache.cassandra.db.Memtable
 
partitionDelete(DeletionTime) - Method in interface org.apache.cassandra.index.Index.Indexer
Notification of a top level partition delete.
partitionDeletion - Variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer.Header
 
partitioner - Variable in class org.apache.cassandra.config.Config
 
partitioner - Variable in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
 
partitioner - Variable in class org.apache.cassandra.locator.TokenMetadata
 
partitioner(IPartitioner) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
partitioner - Variable in class org.apache.cassandra.schema.TableMetadata
 
partitioner() - Method in class org.apache.cassandra.utils.MerkleTree
 
partitioner() - Method in class org.apache.cassandra.utils.MerkleTrees
Get the partitioner in use.
PartitionerDefinedOrder - Class in org.apache.cassandra.db.marshal
for sorting columns representing row keys in the row ordering as determined by a partitioner.
PartitionerDefinedOrder(IPartitioner) - Constructor for class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
 
PartitionIterator - Interface in org.apache.cassandra.db.partitions
An iterator over a number of (filtered) partition.
PartitionIteratorMergeListener<E extends Endpoints<E>> - Class in org.apache.cassandra.service.reads.repair
 
PartitionIteratorMergeListener(ReplicaPlan.ForRead<E>, ReadCommand, ReadRepair) - Constructor for class org.apache.cassandra.service.reads.repair.PartitionIteratorMergeListener
 
PartitionIterators - Class in org.apache.cassandra.db.partitions
 
partitionKey() - Method in class org.apache.cassandra.cache.CounterCacheKey
 
partitionKey() - Method in class org.apache.cassandra.db.aggregation.GroupingState
Returns the last row partition key or null if no rows has been processed yet.
partitionKey() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
partitionKey - Variable in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
partitionKey() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
partitionKey() - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
 
partitionKey() - Method in interface org.apache.cassandra.db.partitions.Partition
 
partitionKey() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
 
partitionKey - Variable in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
 
partitionKey() - Method in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
 
partitionKey() - Method in interface org.apache.cassandra.db.rows.BaseRowIterator
The partition key of the partition this in an iterator over.
partitionKey() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
 
partitionKey() - Method in class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
 
partitionKey() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
partitionKey() - Method in interface org.apache.cassandra.db.SinglePartitionReadQuery
Returns the key of the partition queried by this ReadQuery
partitionKey() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader.StreamDeserializer
 
partitionKey() - Method in class org.apache.cassandra.db.transform.BaseRows
 
partitionKey() - Method in class org.apache.cassandra.db.VirtualTableSinglePartitionReadQuery
 
partitionKey() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
partitionKey - Variable in class org.apache.cassandra.service.pager.PagingState
 
partitionKeyAsClusteringComparator() - Method in class org.apache.cassandra.schema.TableMetadata
 
partitionKeyColumn(TableMetadata, ByteBuffer, AbstractType<?>, int) - Static method in class org.apache.cassandra.schema.ColumnMetadata
 
partitionKeyColumn(String, String, String, AbstractType<?>, int) - Static method in class org.apache.cassandra.schema.ColumnMetadata
 
partitionKeyColumns - Variable in class org.apache.cassandra.schema.TableMetadata
 
partitionKeyColumns() - Method in class org.apache.cassandra.schema.TableMetadata
 
PartitionKeyIndex - Class in org.apache.cassandra.index.internal.composites
Index on a PARTITION_KEY column definition.
PartitionKeyIndex(ColumnFamilyStore, IndexMetadata) - Constructor for class org.apache.cassandra.index.internal.composites.PartitionKeyIndex
 
partitionKeyRestrictionsAreSatisfiedBy(DecoratedKey, AbstractType<?>) - Method in class org.apache.cassandra.db.filter.RowFilter
Returns true if all of the expressions within this filter that apply to the partition key are satisfied by the given key, false otherwise.
partitionKeyType - Variable in class org.apache.cassandra.schema.TableMetadata
 
partitionLevelDeletion - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
partitionLevelDeletion() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
partitionLevelDeletion() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
partitionLevelDeletion() - Method in interface org.apache.cassandra.db.partitions.Partition
 
partitionLevelDeletion() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
 
partitionLevelDeletion - Variable in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
 
partitionLevelDeletion() - Method in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
 
partitionLevelDeletion() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
 
partitionLevelDeletion() - Method in interface org.apache.cassandra.db.rows.UnfilteredRowIterator
The partition level deletion for the partition this iterate over.
partitionLevelDeletion() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
 
partitionLevelDeletion() - Method in class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
 
partitionLevelDeletion() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader.StreamDeserializer
 
partitionLevelDeletion() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
partitionOrdering() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
partitionOrdering() - Method in interface org.apache.cassandra.dht.IPartitioner
Abstract type that orders the same way as DecoratedKeys provided by this partitioner.
partitionOrdering() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
partitionOrdering - Static variable in class org.apache.cassandra.dht.Murmur3Partitioner
 
partitionOrdering() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
 
partitionOrdering() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
partitionOrdering - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 
partitionOrdering() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
PartitionPosition - Interface in org.apache.cassandra.db
 
PartitionPosition.ForKey - Class in org.apache.cassandra.db
 
PartitionPosition.Kind - Enum in org.apache.cassandra.db
 
PartitionPosition.RowPositionSerializer - Class in org.apache.cassandra.db
 
PartitionPositionBounds(long, long) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader.PartitionPositionBounds
 
PartitionRangeBuilder(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.AbstractReadCommandBuilder.PartitionRangeBuilder
 
PartitionRangeQueryPager - Class in org.apache.cassandra.service.pager
Pages a PartitionRangeReadQuery.
PartitionRangeQueryPager(PartitionRangeReadQuery, PagingState, ProtocolVersion) - Constructor for class org.apache.cassandra.service.pager.PartitionRangeQueryPager
 
PartitionRangeQueryPager(PartitionRangeReadQuery, ProtocolVersion, DecoratedKey, PagingState.RowMark, int, int) - Constructor for class org.apache.cassandra.service.pager.PartitionRangeQueryPager
 
PartitionRangeReadCommand - Class in org.apache.cassandra.db
A read command that selects a (part of a) range of partitions.
PartitionRangeReadQuery - Interface in org.apache.cassandra.db
A ReadQuery for a range of partitions.
partitions - Variable in class org.apache.cassandra.db.virtual.AbstractVirtualTable.AbstractDataSet
 
partitions(PartitionRangeReadCommand, ConsistencyLevel, long) - Static method in class org.apache.cassandra.service.reads.range.RangeCommands
 
PartitionSerializationException - Exception in org.apache.cassandra.db.rows
 
PartitionSerializationException(BaseRowIterator<Unfiltered>, Throwable) - Constructor for exception org.apache.cassandra.db.rows.PartitionSerializationException
 
partitionsPerCounterBatch - Variable in class org.apache.cassandra.metrics.BatchMetrics
 
partitionsPerLoggedBatch - Variable in class org.apache.cassandra.metrics.BatchMetrics
 
partitionsPerUnloggedBatch - Variable in class org.apache.cassandra.metrics.BatchMetrics
 
PartitionStatisticsCollector - Interface in org.apache.cassandra.db.partitions
 
partitionsValidated - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
histogram over the number of partitions we have validated
partitionsValidated - Variable in class org.apache.cassandra.metrics.TableMetrics
number of partitions read creating merkle trees
PartitionUpdate - Class in org.apache.cassandra.db.partitions
Stores updates made on a partition.
PartitionUpdate.Builder - Class in org.apache.cassandra.db.partitions
Builder for PartitionUpdates This class is not thread safe, but the PartitionUpdate it produces is (since it is immutable).
PartitionUpdate.CounterMark - Class in org.apache.cassandra.db.partitions
A counter mark is basically a pointer to a counter update inside this partition update.
PartitionUpdate.PartitionUpdateSerializer - Class in org.apache.cassandra.db.partitions
 
PartitionUpdate.SimpleBuilder - Interface in org.apache.cassandra.db.partitions
Interface for building partition updates geared towards human.
PartitionUpdate.SimpleBuilder.RangeTombstoneBuilder - Interface in org.apache.cassandra.db.partitions
Interface to build range tombstone.
PartitionUpdateBuilder(TableMetadata, Object...) - Constructor for class org.apache.cassandra.db.SimpleBuilders.PartitionUpdateBuilder
 
PartitionUpdateCollector(String, DecoratedKey) - Constructor for class org.apache.cassandra.db.Mutation.PartitionUpdateCollector
 
PartitionUpdateSerializer() - Constructor for class org.apache.cassandra.db.partitions.PartitionUpdate.PartitionUpdateSerializer
 
passwd - Variable in class org.apache.cassandra.tools.LoaderOptions
 
PASSWD_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
password - Variable in class org.apache.cassandra.tools.AbstractJmxClient
 
PASSWORD_KEY - Static variable in class org.apache.cassandra.auth.PasswordAuthenticator
 
PasswordAuthenticator - Class in org.apache.cassandra.auth
PasswordAuthenticator is an IAuthenticator implementation that keeps credentials (rolenames and bcrypt-hashed passwords) internally in C* - in system_auth.roles CQL3 table.
PasswordAuthenticator() - Constructor for class org.apache.cassandra.auth.PasswordAuthenticator
 
PasswordAuthenticator.CredentialsCacheMBean - Interface in org.apache.cassandra.auth
 
PasswordObfuscator - Class in org.apache.cassandra.cql3
Obfuscates passwords in a given string
PasswordObfuscator() - Constructor for class org.apache.cassandra.cql3.PasswordObfuscator
 
patch - Variable in class org.apache.cassandra.utils.CassandraVersion
 
path() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.CounterMark
 
path() - Method in class org.apache.cassandra.db.rows.ArrayCell
 
path() - Method in class org.apache.cassandra.db.rows.BufferCell
 
path() - Method in class org.apache.cassandra.db.rows.Cell
For cells belonging to complex types (non-frozen collection and UDT), the path to the cell.
path() - Method in class org.apache.cassandra.db.rows.NativeCell
 
path - Variable in error org.apache.cassandra.io.FSError
 
path - Variable in exception org.apache.cassandra.io.sstable.CorruptSSTableException
 
path - Variable in class org.apache.cassandra.io.sstable.SnapshotDeletingTask
 
path() - Method in class org.apache.cassandra.io.util.FileHandle
 
path - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
 
path(Path) - Method in class org.apache.cassandra.utils.binlog.BinLog.Builder
 
path - Variable in class org.apache.cassandra.utils.binlog.BinLog
 
path - Variable in class org.apache.cassandra.utils.DirectorySizeCalculator
 
PatriciaTrie<K,V> - Class in org.apache.cassandra.index.sasi.utils.trie
PATRICIA Trie
PatriciaTrie(KeyAnalyzer<? super K>) - Constructor for class org.apache.cassandra.index.sasi.utils.trie.PatriciaTrie
 
PatriciaTrie(KeyAnalyzer<? super K>, Map<? extends K, ? extends V>) - Constructor for class org.apache.cassandra.index.sasi.utils.trie.PatriciaTrie
 
PATTERN_WORD_CHARS - Static variable in class org.apache.cassandra.schema.SchemaConstants
 
pause() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
For internal, temporary suspension of background compactions so that we can do exceptional things like truncate or major compaction
pause() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
pause compaction while we cancel all ongoing compactions Separate call from enable/disable to not have to save the enabled-state externally
pauseConnection() - Method in class org.apache.cassandra.metrics.ClientMetrics
 
pauseDispatch() - Method in class org.apache.cassandra.hints.HintsService
 
pauseDispatch() - Method in interface org.apache.cassandra.hints.HintsServiceMBean
Pause dispatch of all hints.
pauseEpochSampling() - Method in class org.apache.cassandra.utils.MonotonicClock.AbstractEpochSamplingClock
 
pauseGlobalCompaction() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
PauseHandoff - Class in org.apache.cassandra.tools.nodetool
 
PauseHandoff() - Constructor for class org.apache.cassandra.tools.nodetool.PauseHandoff
 
pauseHintsDelivery() - Method in class org.apache.cassandra.tools.NodeProbe
 
pauseNowSampling() - Method in class org.apache.cassandra.utils.MonotonicClock.SampledClock
 
PAXOS - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
PaxosState - Class in org.apache.cassandra.service.paxos
 
PaxosState(DecoratedKey, TableMetadata) - Constructor for class org.apache.cassandra.service.paxos.PaxosState
 
PaxosState(Commit, Commit, Commit) - Constructor for class org.apache.cassandra.service.paxos.PaxosState
 
paxosTtlSec(TableMetadata) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
payload - Variable in class org.apache.cassandra.net.Message
 
peek() - Method in class org.apache.cassandra.index.sasi.utils.AbstractIterator
Returns the next element in the iteration without advancing the iteration, according to the contract of PeekingIterator.peek().
peek() - Method in class org.apache.cassandra.utils.AbstractIterator
 
peek() - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
peer - Variable in class org.apache.cassandra.io.util.Memory
 
peer - Variable in class org.apache.cassandra.repair.SyncNodePair
 
peer - Variable in class org.apache.cassandra.streaming.ProgressInfo
 
peer - Variable in class org.apache.cassandra.streaming.SessionInfo
 
peer - Variable in class org.apache.cassandra.streaming.SessionSummary
 
peer - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
 
peer - Variable in class org.apache.cassandra.streaming.StreamSession
Streaming endpoint.
PEER_EVENTS_V2 - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
PEERS_V2 - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
pending - Variable in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
 
pending(AbstractCompactionStrategy, int) - Method in class org.apache.cassandra.db.compaction.CompactionLogger
 
pending() - Method in class org.apache.cassandra.locator.ReplicaLayout.ForWrite
 
pending() - Method in class org.apache.cassandra.locator.ReplicaPlan.ForWrite
Replicas that a region of the ring is moving to; not yet ready to serve reads, but should receive writes
pending - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStats
 
PENDING_TASKS - Static variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
 
PendingAntiCompaction - Class in org.apache.cassandra.db.repair
Performs an anti compaction on a set of tables and token ranges, isolating the unrepaired sstables for a give token range into a pending repair group so they can't be compacted with other sstables while they are being repaired.
PendingAntiCompaction(UUID, Collection<ColumnFamilyStore>, RangesAtEndpoint, ExecutorService, BooleanSupplier) - Constructor for class org.apache.cassandra.db.repair.PendingAntiCompaction
 
PendingAntiCompaction.AcquireResult - Class in org.apache.cassandra.db.repair
 
PendingAntiCompaction.AcquisitionCallable - Class in org.apache.cassandra.db.repair
 
pendingBytes() - Method in class org.apache.cassandra.net.OutboundConnection
 
pendingCompactions - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Estimate of number of pending compactios for this CF
pendingCompactions - Variable in class org.apache.cassandra.metrics.TableMetrics
Estimate of number of pending compactios for this table
pendingCount() - Method in class org.apache.cassandra.net.OutboundConnection
 
pendingDeletionCount() - Static method in class org.apache.cassandra.io.sstable.SnapshotDeletingTask
 
pendingEndpointsFor(Token) - Method in class org.apache.cassandra.locator.PendingRangeMaps
 
pendingEndpointsForToken(Token, String) - Method in class org.apache.cassandra.locator.TokenMetadata
 
pendingFlushes - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Estimated number of tasks pending for this column family
pendingFlushes - Variable in class org.apache.cassandra.metrics.TableMetrics
Estimated number of tasks pending for this table
pendingFlushes - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsKeyspace
 
pendingFlushes - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
PendingRangeCalculatorService - Class in org.apache.cassandra.service
 
PendingRangeCalculatorService() - Constructor for class org.apache.cassandra.service.PendingRangeCalculatorService
 
pendingRangeChanges(InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
 
PendingRangeMaps - Class in org.apache.cassandra.locator
 
PendingRangeMaps() - Constructor for class org.apache.cassandra.locator.PendingRangeMaps
 
pendingRepair - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
pendingRepair - Variable in class org.apache.cassandra.db.streaming.CassandraStreamReader
 
pendingRepair - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
pendingRepair - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
pendingRepair - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
 
pendingRepair - Variable in class org.apache.cassandra.streaming.messages.StreamMessageHeader
 
PendingRepairHolder - Class in org.apache.cassandra.db.compaction
 
PendingRepairHolder(ColumnFamilyStore, AbstractStrategyHolder.DestinationRouter, boolean) - Constructor for class org.apache.cassandra.db.compaction.PendingRepairHolder
 
PendingStat - Class in org.apache.cassandra.repair.consistent.admin
 
PendingStat(long, int, Set<UUID>) - Constructor for class org.apache.cassandra.repair.consistent.admin.PendingStat
 
PendingStat.Builder - Class in org.apache.cassandra.repair.consistent.admin
 
PendingStats - Class in org.apache.cassandra.repair.consistent.admin
 
PendingStats(String, String, PendingStat, PendingStat, PendingStat) - Constructor for class org.apache.cassandra.repair.consistent.admin.PendingStats
 
pendingTasks - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
Number of pending tasks
pendingTasks - Variable in class org.apache.cassandra.metrics.CompactionMetrics
Estimated number of compactions remaining to perform
pendingTasks - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
Number of tasks waiting to be executed.
pendingTasksByTableName - Variable in class org.apache.cassandra.metrics.CompactionMetrics
Estimated number of compactions remaining to perform, group by keyspace and then table name
percentile(double) - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
PercentileSpeculativeRetryPolicy - Class in org.apache.cassandra.service.reads
 
PercentileSpeculativeRetryPolicy(double) - Constructor for class org.apache.cassandra.service.reads.PercentileSpeculativeRetryPolicy
 
percentRepaired - Variable in class org.apache.cassandra.metrics.TableMetrics
percent of the data that is repaired
percentRepaired - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
perform() - Method in interface org.apache.cassandra.utils.Throwables.DiscreteAction
 
perform(Throwables.DiscreteAction<? extends E>...) - Static method in class org.apache.cassandra.utils.Throwables
 
perform(Stream<? extends Throwables.DiscreteAction<? extends E>>, Throwables.DiscreteAction<? extends E>...) - Static method in class org.apache.cassandra.utils.Throwables
 
perform(Stream<Throwables.DiscreteAction<? extends E>>) - Static method in class org.apache.cassandra.utils.Throwables
 
perform(Throwable, Throwables.DiscreteAction<?>...) - Static method in class org.apache.cassandra.utils.Throwables
 
perform(Throwable, Stream<? extends Throwables.DiscreteAction<?>>) - Static method in class org.apache.cassandra.utils.Throwables
 
perform(Throwable, Iterator<? extends Throwables.DiscreteAction<?>>) - Static method in class org.apache.cassandra.utils.Throwables
 
perform(File, Throwables.FileOpType, Throwables.DiscreteAction<? extends IOException>...) - Static method in class org.apache.cassandra.utils.Throwables
 
perform(String, Throwables.FileOpType, Throwables.DiscreteAction<? extends IOException>...) - Static method in class org.apache.cassandra.utils.Throwables
 
perform(Throwable, String, Throwables.FileOpType, Throwables.DiscreteAction<? extends IOException>...) - Static method in class org.apache.cassandra.utils.Throwables
 
perform(Throwable, String, Throwables.FileOpType, Stream<Throwables.DiscreteAction<? extends IOException>>) - Static method in class org.apache.cassandra.utils.Throwables
 
performAnticompaction(ColumnFamilyStore, RangesAtEndpoint, Refs<SSTableReader>, LifecycleTransaction, UUID, BooleanSupplier) - Method in class org.apache.cassandra.db.compaction.CompactionManager
Make sure the {validatedForRepair} are marked for compaction before calling this.
performCleanup(ColumnFamilyStore, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
performGarbageCollection(ColumnFamilyStore, CompactionParams.TombstoneOption, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
performMaximal(ColumnFamilyStore, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
performScrub(ColumnFamilyStore, boolean, boolean, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
performScrub(ColumnFamilyStore, boolean, boolean, boolean, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
performSkipTo(Long) - Method in class org.apache.cassandra.index.sasi.disk.TokenTree.TokenTreeIterator
 
performSkipTo(Long) - Method in class org.apache.cassandra.index.sasi.memory.KeyRangeIterator
 
performSkipTo(Long) - Method in class org.apache.cassandra.index.sasi.plan.Operation
 
performSkipTo(Long) - Method in class org.apache.cassandra.index.sasi.TermIterator
 
performSkipTo(OnDiskIndex.DataTerm) - Method in class org.apache.cassandra.index.sasi.utils.OnDiskIndexIterator
 
performSkipTo(K) - Method in class org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator.BounceIntersectionIterator
 
performSkipTo(K) - Method in class org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator.LookupIntersectionIterator
 
performSkipTo(K) - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.EmptyRangeIterator
 
performSkipTo(K) - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator
 
performSkipTo(K) - Method in class org.apache.cassandra.index.sasi.utils.RangeUnionIterator
 
performSSTableRewrite(ColumnFamilyStore, boolean, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
performVerify(ColumnFamilyStore, Verifier.Options) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
performWrite(IMutation, ConsistencyLevel, String, StorageProxy.WritePerformer, Runnable, WriteType, long) - Static method in class org.apache.cassandra.service.StorageProxy
Perform the write of a mutation given a WritePerformer.
periodic_commitlog_sync_lag_block_in_ms - Variable in class org.apache.cassandra.config.Config
 
permissible - Variable in exception org.apache.cassandra.db.commitlog.CommitLogReadHandler.CommitLogReadException
 
Permission - Enum in org.apache.cassandra.auth
An enum encapsulating the set of possible permissions that an authenticated user can have on a resource.
permission - Variable in class org.apache.cassandra.auth.PermissionDetails
 
PermissionDetails - Class in org.apache.cassandra.auth
Sets of instances of this class are returned by IAuthorizer.listPermissions() method for LIST PERMISSIONS query.
PermissionDetails(String, IResource, Permission) - Constructor for class org.apache.cassandra.auth.PermissionDetails
 
permissions - Variable in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
permissions - Variable in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
 
permissions_cache_max_entries - Variable in class org.apache.cassandra.config.Config
 
permissions_update_interval_in_ms - Variable in class org.apache.cassandra.config.Config
 
permissions_validity_in_ms - Variable in class org.apache.cassandra.config.Config
 
PermissionsCache - Class in org.apache.cassandra.auth
 
PermissionsCache(IAuthorizer) - Constructor for class org.apache.cassandra.auth.PermissionsCache
 
PermissionsManagementStatement - Class in org.apache.cassandra.cql3.statements
 
PermissionsManagementStatement(Set<Permission>, IResource, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
 
perPartitionCount() - Method in class org.apache.cassandra.db.filter.DataLimits
 
perPartitionLimit - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
 
persistedIntervals(Iterable<SSTableReader>, CommitLogPosition, UUID) - Static method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
A set of known safe-to-discard commit log replay positions, based on the range covered by on disk sstables and those prior to the most recent truncation record
persistLocalMetadata() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
persistSSTableReadMeter(String, String, int, RestorableMeter) - Static method in class org.apache.cassandra.db.SystemKeyspace
Writes the current read rates for a given SSTable to system.sstable_activity
PerSSTableIndexWriter - Class in org.apache.cassandra.index.sasi.disk
 
PerSSTableIndexWriter(AbstractType<?>, Descriptor, OperationType, Map<ColumnMetadata, ColumnIndex>) - Constructor for class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
 
PerSSTableIndexWriter.Index - Class in org.apache.cassandra.index.sasi.disk
 
phi_convict_threshold - Variable in class org.apache.cassandra.config.Config
 
PingRequest - Class in org.apache.cassandra.net
Indicates to the recipient which ConnectionType should be used for the response.
PipelineConfigurator - Class in org.apache.cassandra.transport
Takes care of intializing a Netty Channel and Pipeline for client protocol connections.
PipelineConfigurator(boolean, boolean, boolean, EncryptionOptions.TlsEncryptionPolicy) - Constructor for class org.apache.cassandra.transport.PipelineConfigurator
 
planId - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
 
planId - Variable in class org.apache.cassandra.streaming.messages.StreamMessageHeader
 
planId - Variable in class org.apache.cassandra.streaming.StreamEvent
 
planId - Variable in class org.apache.cassandra.streaming.StreamResultFuture
 
planId() - Method in class org.apache.cassandra.streaming.StreamSession
 
planId - Variable in class org.apache.cassandra.streaming.StreamState
 
PlatformMBeanWrapper() - Constructor for class org.apache.cassandra.utils.MBeanWrapper.PlatformMBeanWrapper
 
PointerBlock(MappedBuffer) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskIndex.PointerBlock
 
PointerLevel(long, int) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskIndex.PointerLevel
 
PointerTerm(MappedBuffer, OnDiskIndexBuilder.TermSize, boolean) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskIndex.PointerTerm
 
pointInTimeExceeded(Mutation) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
policy - Static variable in class org.apache.cassandra.db.ExpirationDateOverflowHandling
 
poll() - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
poll(long, TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
pollFirst() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
pollLast() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
poolName - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
 
populateTokenMetadata() - Method in class org.apache.cassandra.service.StorageService
 
port - Variable in class org.apache.cassandra.locator.InetAddressAndPort
 
port - Variable in class org.apache.cassandra.tools.AbstractJmxClient
 
port - Variable in class org.apache.cassandra.transport.SimpleClient
 
position - Variable in class org.apache.cassandra.db.commitlog.CommitLogPosition
 
position - Variable in class org.apache.cassandra.db.RowIndexEntry
 
position(long) - Method in class org.apache.cassandra.db.streaming.CompressedInputStream
Invoked when crossing into the next SSTableReader.PartitionPositionBounds section in CassandraCompressedStreamReader.read(DataInputPlus).
position - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
 
position - Variable in class org.apache.cassandra.index.sasi.sa.Term
 
position() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
position(long) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
position() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
position() - Method in interface org.apache.cassandra.io.util.DataOutputPlus
Returns the current position of the underlying target like a file-pointer or the position withing a buffer.
position() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
position() - Method in class org.apache.cassandra.net.AsyncChannelOutputPlus
 
position() - Method in class org.apache.cassandra.net.AsyncMessageOutputPlus
 
position() - Method in class org.apache.cassandra.net.AsyncStreamingOutputPlus
 
position() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
positionInRange(Token, Range<Token>) - Method in class org.apache.cassandra.dht.Splitter
Computes the normalized position of this token relative to this range
positions - Variable in class org.apache.cassandra.db.DiskBoundaries
 
postProcessorFor(ReadCommand) - Method in interface org.apache.cassandra.index.Index
Return a function which performs post processing on the results of a partition range read command.
postProcessorFor(ReadCommand) - Method in class org.apache.cassandra.index.internal.CassandraIndex
No post processing of query results, just return them unchanged
postProcessorFor(ReadCommand) - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
postReconciliationProcessing(PartitionIterator) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
Allow to post-process the result of the query after it has been reconciled on the coordinator but before it is passed to the CQL layer to return the ResultSet.
postV5Handler(FrameEncoder.PayloadAllocator, ProtocolVersion) - Static method in class org.apache.cassandra.transport.ExceptionHandlers
 
pre40DeserializeWithLength(DataInputPlus, int, int) - Method in class org.apache.cassandra.locator.InetAddressAndPort.FwdFrmSerializer
 
preciseTime - Static variable in interface org.apache.cassandra.utils.MonotonicClock
Static singleton object that will be instantiated by default with a system clock implementation.
precision - Variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
predicate() - Method in enum org.apache.cassandra.streaming.PreviewKind
 
PreferedNodeFilter - Interface in org.apache.cassandra.repair.asymmetric
 
preferredBufferType() - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
preferredBufferType() - Method in interface org.apache.cassandra.io.compress.ICompressor
Returns the preferred (most efficient) buffer type for this compressor.
preferredBufferType() - Method in class org.apache.cassandra.io.compress.LZ4Compressor
 
preferredBufferType() - Method in class org.apache.cassandra.io.compress.NoopCompressor
 
preferredBufferType() - Method in class org.apache.cassandra.io.compress.SnappyCompressor
 
preferredBufferType() - Method in class org.apache.cassandra.io.compress.ZstdCompressor
Return the preferred BufferType
preferredBufferType() - Method in interface org.apache.cassandra.io.util.ChunkReader
Specifies type of buffer the caller should attempt to give.
preferredBufferType() - Method in class org.apache.cassandra.io.util.CompressedChunkReader
 
prefixComparison - Variable in class org.apache.cassandra.cql3.ColumnIdentifier
since these objects are compared frequently, we stash an efficiently compared prefix of the bytes, in the expectation that the majority of comparisons can be answered by this value only
prefixMap(K) - Method in class org.apache.cassandra.index.sasi.utils.trie.PatriciaTrie
 
prefixMap(K) - Method in interface org.apache.cassandra.index.sasi.utils.trie.Trie
Returns a view of this Trie of all elements that are prefixed by the given key.
PrefixTermTree - Class in org.apache.cassandra.index.sasi.conf.view
This class is an extension over RangeTermTree for string terms, it is required because interval tree can't handle matching if search is on the prefix of min/max of the range, so for ascii/utf8 fields we build an additional prefix trie (including both min/max terms of the index) and do union of the results of the prefix tree search and results from the interval tree lookup.
PrefixTermTree(ByteBuffer, ByteBuffer, Trie<ByteBuffer, Set<SSTableIndex>>, IntervalTree<RangeTermTree.Term, SSTableIndex, Interval<RangeTermTree.Term, SSTableIndex>>, OnDiskIndexBuilder.Mode, AbstractType<?>) - Constructor for class org.apache.cassandra.index.sasi.conf.view.PrefixTermTree
 
PrefixTermTree.Builder - Class in org.apache.cassandra.index.sasi.conf.view
 
PreHashedDecoratedKey - Class in org.apache.cassandra.db
 
PreHashedDecoratedKey(Token, ByteBuffer, long, long) - Constructor for class org.apache.cassandra.db.PreHashedDecoratedKey
 
preloadPreparedStatement() - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.AbstractMarker.INRaw
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.AbstractMarker.MultiColumnRaw
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
 
prepare(String, String) - Method in class org.apache.cassandra.cql3.Attributes.Raw
 
prepare(String, ColumnMetadata, TableMetadata) - Method in class org.apache.cassandra.cql3.conditions.ColumnCondition.Raw
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Constants.Literal
 
prepare(String) - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
prepare(String, Types) - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.CQLStatement.Raw
 
prepare(String, ClientState, Map<String, ByteBuffer>) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Lists.Literal
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Maps.Literal
 
prepare(TableMetadata, ColumnMetadata) - Method in class org.apache.cassandra.cql3.Operation.Addition
 
prepare(String, ColumnMetadata, TableMetadata) - Method in class org.apache.cassandra.cql3.Operation.ColumnDeletion
 
prepare(String, ColumnMetadata, TableMetadata) - Method in class org.apache.cassandra.cql3.Operation.ElementDeletion
 
prepare(String, ColumnMetadata, TableMetadata) - Method in class org.apache.cassandra.cql3.Operation.FieldDeletion
 
prepare(TableMetadata, ColumnMetadata) - Method in class org.apache.cassandra.cql3.Operation.Prepend
 
prepare(String, ColumnMetadata, TableMetadata) - Method in interface org.apache.cassandra.cql3.Operation.RawDeletion
This method validates the operation (i.e.
prepare(TableMetadata, ColumnMetadata) - Method in interface org.apache.cassandra.cql3.Operation.RawUpdate
This method validates the operation (i.e.
prepare(TableMetadata, ColumnMetadata) - Method in class org.apache.cassandra.cql3.Operation.SetElement
 
prepare(TableMetadata, ColumnMetadata) - Method in class org.apache.cassandra.cql3.Operation.SetField
 
prepare(TableMetadata, ColumnMetadata) - Method in class org.apache.cassandra.cql3.Operation.SetValue
 
prepare(TableMetadata, ColumnMetadata) - Method in class org.apache.cassandra.cql3.Operation.Substraction
 
prepare(String, ClientState, Map<String, ByteBuffer>) - Method in interface org.apache.cassandra.cql3.QueryHandler
 
prepare(List<ColumnSpecification>) - Method in class org.apache.cassandra.cql3.QueryOptions
 
prepare(String, ClientState, Map<String, ByteBuffer>) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
prepare(String, ClientState) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
prepare(TableMetadata) - Method in class org.apache.cassandra.cql3.selection.Selectable.BetweenParenthesesOrWithTuple.Raw
 
prepare(TableMetadata) - Method in interface org.apache.cassandra.cql3.selection.Selectable.Raw
 
prepare(TableMetadata) - Method in class org.apache.cassandra.cql3.selection.Selectable.RawIdentifier
 
prepare(TableMetadata) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithCast.Raw
 
prepare(TableMetadata) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithElementSelection.Raw
 
prepare(TableMetadata) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection.Raw
 
prepare(TableMetadata) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFunction.Raw
 
prepare(TableMetadata) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithList.Raw
 
prepare(TableMetadata) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithMapOrUdt.Raw
 
prepare(TableMetadata) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithSet.Raw
 
prepare(TableMetadata) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithSliceSelection.Raw
 
prepare(TableMetadata) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithTerm.Raw
 
prepare(TableMetadata) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithTypeHint.Raw
 
prepare(TableMetadata) - Method in class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL.Raw
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Sets.Literal
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement.Parsed
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.DescribeStatement
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
 
prepare(VariableSpecifications) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.AlterKeyspaceStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTypeStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.AlterViewStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateAggregateStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateFunctionStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateKeyspaceStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTriggerStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTypeStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateViewStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.DropAggregateStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.DropFunctionStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.DropIndexStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.DropKeyspaceStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.DropTableStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.DropTriggerStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.DropTypeStatement.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.DropViewStatement.Raw
 
prepare(TableMetadata) - Method in class org.apache.cassandra.cql3.statements.schema.IndexTarget.Raw
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
 
prepare(boolean) - Method in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
 
prepare(ClientState) - Method in class org.apache.cassandra.cql3.statements.UseStatement
 
prepare(String, List<? extends ColumnSpecification>) - Method in class org.apache.cassandra.cql3.Term.MultiColumnRaw
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Term.Raw
This method validates this RawTerm is valid for provided column specification and "prepare" this RawTerm, returning the resulting prepared Term.
prepare(String, List<? extends ColumnSpecification>) - Method in class org.apache.cassandra.cql3.Tuples.INRaw
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Tuples.Literal
 
prepare(String, List<? extends ColumnSpecification>) - Method in class org.apache.cassandra.cql3.Tuples.Literal
 
prepare(String, List<? extends ColumnSpecification>) - Method in class org.apache.cassandra.cql3.Tuples.Raw
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.TypeCast
 
prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.UserTypes.Literal
 
prepare(int, int) - Method in class org.apache.cassandra.db.ClusteringPrefix.Deserializer
 
prepare() - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
 
prepare(ColumnFamilyStore, MerkleTrees) - Method in class org.apache.cassandra.repair.Validator
 
prepare(Commit) - Static method in class org.apache.cassandra.service.paxos.PaxosState
 
prepare(Collection<StreamRequest>, Collection<StreamSummary>) - Method in class org.apache.cassandra.streaming.StreamSession
Prepare this session for sending/receiving files.
prepare(String[], PrintStream, PrintStream) - Method in class org.apache.cassandra.tools.nodetool.Sjk.Wrapper
 
prepare(String) - Method in class org.apache.cassandra.transport.SimpleClient
 
PrepareAckMessage - Class in org.apache.cassandra.streaming.messages
 
PrepareAckMessage() - Constructor for class org.apache.cassandra.streaming.messages.PrepareAckMessage
 
prepareAndCollectMarkers(TableMetadata, Collection<ColumnMetadata>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Json.Literal
 
prepareAndCollectMarkers(TableMetadata, Collection<ColumnMetadata>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Json.Marker
 
prepareAndCollectMarkers(TableMetadata, Collection<ColumnMetadata>, VariableSpecifications) - Method in interface org.apache.cassandra.cql3.Json.Raw
 
PrepareCallback - Class in org.apache.cassandra.service.paxos
 
PrepareCallback(DecoratedKey, TableMetadata, int, ConsistencyLevel, long) - Constructor for class org.apache.cassandra.service.paxos.PrepareCallback
 
PrepareConsistentRequest - Class in org.apache.cassandra.repair.messages
 
PrepareConsistentRequest(UUID, InetAddressAndPort, Set<InetAddressAndPort>) - Constructor for class org.apache.cassandra.repair.messages.PrepareConsistentRequest
 
PrepareConsistentResponse - Class in org.apache.cassandra.repair.messages
 
PrepareConsistentResponse(UUID, InetAddressAndPort, boolean) - Constructor for class org.apache.cassandra.repair.messages.PrepareConsistentResponse
 
Prepared() - Constructor for class org.apache.cassandra.cql3.Json.Prepared
 
Prepared(CQLStatement) - Constructor for class org.apache.cassandra.cql3.QueryHandler.Prepared
 
Prepared(CQLStatement, String) - Constructor for class org.apache.cassandra.cql3.QueryHandler.Prepared
 
Prepared(MD5Digest, MD5Digest, ResultSet.PreparedMetadata, ResultSet.ResultMetadata) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Prepared
 
PREPARED_STATEMENTS - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
prepared_statements_cache_size_mb - Variable in class org.apache.cassandra.config.Config
Size of the CQL prepared statements cache in MB.
PreparedMetadata(List<ColumnSpecification>, short[]) - Constructor for class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
 
PreparedQueryNotFoundException - Exception in org.apache.cassandra.exceptions
 
PreparedQueryNotFoundException(MD5Digest) - Constructor for exception org.apache.cassandra.exceptions.PreparedQueryNotFoundException
 
preparedStatementsCount() - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
preparedStatementsCount - Variable in class org.apache.cassandra.metrics.CQLMetrics
 
preparedStatementsEvicted - Variable in class org.apache.cassandra.metrics.CQLMetrics
 
preparedStatementsExecuted - Variable in class org.apache.cassandra.metrics.CQLMetrics
 
preparedStatementsRatio - Variable in class org.apache.cassandra.metrics.CQLMetrics
 
prepareFailure(CQLStatement, String, QueryState, Exception) - Method in class org.apache.cassandra.audit.AuditLogManager
 
prepareFailure(CQLStatement, String, QueryState, Exception) - Method in interface org.apache.cassandra.cql3.QueryEvents.Listener
 
prepareForBootstrap(long) - Method in class org.apache.cassandra.service.StorageService
 
prepareForRepair(UUID, InetAddressAndPort, Set<InetAddressAndPort>, RepairOption, boolean, List<ColumnFamilyStore>) - Method in class org.apache.cassandra.service.ActiveRepairService
 
prepareIncomingStream(StreamSession, StreamMessageHeader) - Method in class org.apache.cassandra.db.streaming.CassandraStreamManager
 
prepareIncomingStream(StreamSession, StreamMessageHeader) - Method in interface org.apache.cassandra.streaming.TableStreamManager
Creates an IncomingStream for the given header
prepareIncrementalRepair(UUID, Collection<ColumnFamilyStore>, RangesAtEndpoint, ExecutorService, BooleanSupplier) - Method in class org.apache.cassandra.db.repair.CassandraKeyspaceRepairManager
 
prepareIncrementalRepair(UUID, Collection<ColumnFamilyStore>, RangesAtEndpoint, ExecutorService, BooleanSupplier) - Method in interface org.apache.cassandra.repair.KeyspaceRepairManager
Isolate the unrepaired ranges of the given tables, and make referenceable by session id.
prepareInternal(String, Types) - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
prepareInternal(String) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
prepareInternal(TableMetadata, VariableSpecifications, Conditions, Attributes) - Method in class org.apache.cassandra.cql3.statements.DeleteStatement.Parsed
 
prepareInternal(TableMetadata, VariableSpecifications, Conditions, Attributes) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
 
prepareInternal(TableMetadata, VariableSpecifications, Conditions, Attributes) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement.ParsedInsert
 
prepareInternal(TableMetadata, VariableSpecifications, Conditions, Attributes) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement.ParsedInsertJson
 
prepareInternal(TableMetadata, VariableSpecifications, Conditions, Attributes) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement.ParsedUpdate
 
PrepareMessage - Class in org.apache.cassandra.repair.messages
 
PrepareMessage(UUID, List<TableId>, Collection<Range<Token>>, boolean, long, boolean, PreviewKind) - Constructor for class org.apache.cassandra.repair.messages.PrepareMessage
 
PrepareMessage - Class in org.apache.cassandra.transport.messages
 
PrepareMessage(String, String) - Constructor for class org.apache.cassandra.transport.messages.PrepareMessage
 
prepareOptions(Map<String, String>, Map<String, String>) - Static method in class org.apache.cassandra.locator.NetworkTopologyStrategy
Support datacenter auto-expansion for CASSANDRA-14303.
prepareReceiving(StreamSummary) - Method in class org.apache.cassandra.streaming.StreamSession
 
prepareReplicationStrategyOptions(Class<? extends AbstractReplicationStrategy>, Map<String, String>, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
Before constructing the ARS we first give it a chance to prepare the options map in any way it would like to.
PrepareResponse - Class in org.apache.cassandra.service.paxos
 
PrepareResponse(boolean, Commit, Commit) - Constructor for class org.apache.cassandra.service.paxos.PrepareResponse
 
PrepareResponse.PrepareResponseSerializer - Class in org.apache.cassandra.service.paxos
 
PrepareResponseSerializer() - Constructor for class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
 
prepareStatement(int, List<ColumnSpecification>) - Method in class org.apache.cassandra.cql3.BatchQueryOptions
 
prepareSuccess(CQLStatement, String, QueryState, long, ResultMessage.Prepared) - Method in class org.apache.cassandra.audit.AuditLogManager
 
prepareSuccess(CQLStatement, String, QueryState, long, ResultMessage.Prepared) - Method in interface org.apache.cassandra.cql3.QueryEvents.Listener
 
PrepareSynAckMessage - Class in org.apache.cassandra.streaming.messages
 
PrepareSynAckMessage() - Constructor for class org.apache.cassandra.streaming.messages.PrepareSynAckMessage
 
PrepareSynMessage - Class in org.apache.cassandra.streaming.messages
 
PrepareSynMessage() - Constructor for class org.apache.cassandra.streaming.messages.PrepareSynMessage
 
prepareToCommit() - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
 
prepareToCommit() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableZeroCopyWriter
 
prepareToCommit() - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
 
prepareToCommit() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
prepareToCommit() - Method in class org.apache.cassandra.io.sstable.IndexSummaryBuilder
 
prepareToCommit() - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
 
prepareToCommit() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
prepareToCommit() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
The first phase of commit: delegates to doPrepare(), with valid state transition enforcement.
prepareToCommit() - Method in interface org.apache.cassandra.utils.concurrent.Transactional
 
prepareValue(TableMetadata, AbstractType<?>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.restrictions.CustomIndexExpression
 
PrepareVerbHandler - Class in org.apache.cassandra.service.paxos
 
PrepareVerbHandler() - Constructor for class org.apache.cassandra.service.paxos.PrepareVerbHandler
 
Prepend(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.Prepend
 
Prepender(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Lists.Prepender
 
preprocess(Message<ReadResponse>) - Method in class org.apache.cassandra.service.reads.DigestResolver
 
preprocess(Message<ReadResponse>) - Method in class org.apache.cassandra.service.reads.ResponseResolver
 
preservesOrder() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
preservesOrder() - Method in interface org.apache.cassandra.dht.IPartitioner
 
preservesOrder() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
preservesOrder() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
 
preservesOrder() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
preservesOrder() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
prettyPrintMemory(long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
prettyPrintMemory(long, boolean) - Static method in class org.apache.cassandra.utils.FBUtilities
 
prettyPrintMemoryPerSecond(long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
prettyPrintMemoryPerSecond(long, long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
prev() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
 
PreV5Handlers - Class in org.apache.cassandra.transport
 
PreV5Handlers() - Constructor for class org.apache.cassandra.transport.PreV5Handlers
 
PreV5Handlers.ExceptionHandler - Class in org.apache.cassandra.transport
Pre-V5 exception handler which closes the connection if an ProtocolException is thrown
PreV5Handlers.LegacyDispatchHandler - Class in org.apache.cassandra.transport
Wraps an Dispatcher so that it can be used as an channel inbound handler in pre-V5 pipelines.
PreV5Handlers.ProtocolDecoder - Class in org.apache.cassandra.transport
Simple adaptor to allow Message.Decoder.decodeMessage(Channel, Envelope) to be used as a handler in pre-V5 pipelines
PreV5Handlers.ProtocolEncoder - Class in org.apache.cassandra.transport
Simple adaptor to plug CQL message encoding into pre-V5 pipelines
preventIllegalAccessWarnings() - Static method in class org.apache.cassandra.utils.FBUtilities
Hack to prevent the ugly "illegal access" warnings in Java 11+ like the following.
PREVIEW - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
previewFailures - Static variable in class org.apache.cassandra.metrics.RepairMetrics
 
previewKind - Variable in exception org.apache.cassandra.exceptions.RepairException
 
previewKind - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
 
previewKind - Variable in class org.apache.cassandra.repair.messages.SyncRequest
 
previewKind - Variable in class org.apache.cassandra.repair.RepairSession
 
previewKind - Variable in class org.apache.cassandra.repair.SyncTask
 
previewKind - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
previewKind - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
 
PreviewKind - Enum in org.apache.cassandra.streaming
 
PreviewRepairConflictWithIncrementalRepairException - Exception in org.apache.cassandra.repair
 
PreviewRepairConflictWithIncrementalRepairException(String) - Constructor for exception org.apache.cassandra.repair.PreviewRepairConflictWithIncrementalRepairException
 
PRIMARY_INDEX - Static variable in class org.apache.cassandra.io.sstable.Component
 
PRIMARY_RANGE_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
primaryKeyColumns() - Method in class org.apache.cassandra.schema.TableMetadata
 
primaryKeyLivenessInfo - Variable in class org.apache.cassandra.db.rows.BTreeRow.Builder
 
primaryKeyLivenessInfo() - Method in class org.apache.cassandra.db.rows.BTreeRow
 
primaryKeyLivenessInfo() - Method in interface org.apache.cassandra.db.rows.Row
Liveness information for the primary key columns of this row.
print(CompactionHistoryHolder, PrintStream) - Method in class org.apache.cassandra.tools.nodetool.stats.CompactionHistoryPrinter.DefaultPrinter
 
print(T, PrintStream) - Method in class org.apache.cassandra.tools.nodetool.stats.StatsPrinter.JsonPrinter
 
print(T, PrintStream) - Method in interface org.apache.cassandra.tools.nodetool.stats.StatsPrinter
 
print(T, PrintStream) - Method in class org.apache.cassandra.tools.nodetool.stats.StatsPrinter.YamlPrinter
 
print(TpStatsHolder, PrintStream) - Method in class org.apache.cassandra.tools.nodetool.stats.TpStatsPrinter.DefaultPrinter
 
printDebugInfo() - Method in class org.apache.cassandra.utils.concurrent.Ref
 
printHelp(String, String) - Static method in class org.apache.cassandra.tools.AbstractJmxClient
 
printHistogram(PrintStream, boolean, boolean) - Method in class org.apache.cassandra.tools.Util.TermHistogram
 
printPendingRanges() - Method in class org.apache.cassandra.locator.PendingRangeMaps
 
printPort - Variable in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
 
printReceivingSummaries(PrintStream, SessionInfo, boolean) - Method in class org.apache.cassandra.tools.nodetool.NetStats
 
printSendingSummaries(PrintStream, SessionInfo, boolean) - Method in class org.apache.cassandra.tools.nodetool.NetStats
 
printStack - Variable in class org.apache.cassandra.utils.OutputHandler.SystemOutput
 
printTo(PrintStream) - Method in class org.apache.cassandra.tools.nodetool.formatter.TableBuilder
 
printUsage(Options) - Static method in class org.apache.cassandra.tools.GenerateTokens
 
printUsage(Options) - Static method in class org.apache.cassandra.tools.LoaderOptions
 
priority - Variable in enum org.apache.cassandra.net.Verb
 
priority - Variable in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
 
probe - Variable in class org.apache.cassandra.tools.nodetool.stats.CompactionHistoryHolder
 
probe - Variable in class org.apache.cassandra.tools.nodetool.stats.TpStatsHolder
 
process(CQLStatement, QueryState, QueryOptions, Map<String, ByteBuffer>, long) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
 
process(CQLStatement, QueryState, QueryOptions, Map<String, ByteBuffer>, long) - Method in interface org.apache.cassandra.cql3.QueryHandler
 
process(String, ConsistencyLevel, QueryState, long) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
process(CQLStatement, QueryState, QueryOptions, Map<String, ByteBuffer>, long) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
process(CQLStatement, QueryState, QueryOptions, long) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
process(String, ConsistencyLevel) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
process(String, ConsistencyLevel, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
process(PartitionIterator, int) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
process(String) - Method in class org.apache.cassandra.index.sasi.analyzer.filter.BasicResultFilters.LowerCase
 
process(Object) - Method in class org.apache.cassandra.index.sasi.analyzer.filter.BasicResultFilters.NoOperation
 
process(String) - Method in class org.apache.cassandra.index.sasi.analyzer.filter.BasicResultFilters.UpperCase
 
process(F) - Method in class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineTask
 
process(String) - Method in class org.apache.cassandra.index.sasi.analyzer.filter.StemmingFilters.DefaultStemmingFilter
 
process(String) - Method in class org.apache.cassandra.index.sasi.analyzer.filter.StopWordFilters.DefaultStopWordFilter
 
process(FrameDecoder.Frame) - Method in class org.apache.cassandra.net.AbstractMessageHandler
 
process(FrameDecoder.Frame) - Method in interface org.apache.cassandra.net.FrameDecoder.FrameProcessor
Frame processor that the frames should be handed off to.
process(FrameDecoder.Frame) - Method in class org.apache.cassandra.transport.CQLMessageHandler
 
processArguments(String[]) - Static method in class org.apache.cassandra.tools.AbstractJmxClient
 
processBatch(BatchStatement, QueryState, BatchQueryOptions, Map<String, ByteBuffer>, long) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
 
processBatch(BatchStatement, QueryState, BatchQueryOptions, Map<String, ByteBuffer>, long) - Method in interface org.apache.cassandra.cql3.QueryHandler
 
processBatch(BatchStatement, QueryState, BatchQueryOptions, Map<String, ByteBuffer>, long) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
processBatch(BatchStatement, QueryState, BatchQueryOptions, long) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
processCorruptFrame(FrameDecoder.CorruptFrame) - Method in class org.apache.cassandra.net.AbstractMessageHandler
 
processCorruptFrame(FrameDecoder.CorruptFrame) - Method in class org.apache.cassandra.net.InboundMessageHandler
 
processCorruptFrame(FrameDecoder.CorruptFrame) - Method in class org.apache.cassandra.transport.CQLMessageHandler
 
processedBytes() - Method in class org.apache.cassandra.net.InboundMessageHandlers
 
processedCount() - Method in class org.apache.cassandra.net.InboundMessageHandlers
 
processesSelection() - Method in interface org.apache.cassandra.cql3.selection.Selectable
Checks if any processing is performed on the selected columns, false otherwise.
processesSelection() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
processFirstFrameOfLargeMessage(FrameDecoder.IntactFrame, ResourceLimits.Limit, ResourceLimits.Limit) - Method in class org.apache.cassandra.net.AbstractMessageHandler
 
processFirstFrameOfLargeMessage(FrameDecoder.IntactFrame, ResourceLimits.Limit, ResourceLimits.Limit) - Method in class org.apache.cassandra.net.InboundMessageHandler
 
processFirstFrameOfLargeMessage(FrameDecoder.IntactFrame, ResourceLimits.Limit, ResourceLimits.Limit) - Method in class org.apache.cassandra.transport.CQLMessageHandler
 
processOneContainedMessage(ShareableBytes, ResourceLimits.Limit, ResourceLimits.Limit) - Method in class org.apache.cassandra.net.AbstractMessageHandler
 
processOneContainedMessage(ShareableBytes, ResourceLimits.Limit, ResourceLimits.Limit) - Method in class org.apache.cassandra.net.InboundMessageHandler
 
processOneContainedMessage(ShareableBytes, ResourceLimits.Limit, ResourceLimits.Limit) - Method in class org.apache.cassandra.transport.CQLMessageHandler
 
processPrepared(CQLStatement, QueryState, QueryOptions, Map<String, ByteBuffer>, long) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
 
processPrepared(CQLStatement, QueryState, QueryOptions, Map<String, ByteBuffer>, long) - Method in interface org.apache.cassandra.cql3.QueryHandler
 
processPrepared(CQLStatement, QueryState, QueryOptions, Map<String, ByteBuffer>, long) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
processPrepared(CQLStatement, QueryState, QueryOptions, long) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
processRequest(Envelope) - Method in class org.apache.cassandra.transport.CQLMessageHandler
 
processStatement(CQLStatement, QueryState, QueryOptions, long) - Method in class org.apache.cassandra.cql3.QueryProcessor
 
processSubsequentFrameOfLargeMessage(FrameDecoder.Frame) - Method in class org.apache.cassandra.net.AbstractMessageHandler
 
ProfileLoad - Class in org.apache.cassandra.tools.nodetool
 
ProfileLoad() - Constructor for class org.apache.cassandra.tools.nodetool.ProfileLoad
 
progress - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
progress(TaskAttemptContext) - Static method in class org.apache.cassandra.hadoop.HadoopCompat
Invoke TaskAttemptContext.progress().
progress() - Method in class org.apache.cassandra.hadoop.ReporterWrapper
 
progress - Variable in class org.apache.cassandra.streaming.StreamEvent.ProgressEvent
 
progress(String, ProgressInfo.Direction, long, long) - Method in class org.apache.cassandra.streaming.StreamSession
 
progress(String, ProgressEvent) - Method in class org.apache.cassandra.tools.BootstrapMonitor
 
progress(String, ProgressEvent) - Method in class org.apache.cassandra.tools.RepairRunner
 
progress(double, int, boolean) - Static method in class org.apache.cassandra.tools.Util
 
progress(String, ProgressEvent) - Method in class org.apache.cassandra.utils.progress.jmx.JMXProgressSupport
 
progress(String, ProgressEvent) - Method in interface org.apache.cassandra.utils.progress.ProgressListener
Called when some progress is made by progress publisher.
ProgressEvent(UUID, ProgressInfo) - Constructor for class org.apache.cassandra.streaming.StreamEvent.ProgressEvent
 
ProgressEvent - Class in org.apache.cassandra.utils.progress
Progress event
ProgressEvent(ProgressEventType, int, int) - Constructor for class org.apache.cassandra.utils.progress.ProgressEvent
 
ProgressEvent(ProgressEventType, int, int, String) - Constructor for class org.apache.cassandra.utils.progress.ProgressEvent
 
ProgressEventNotifier - Interface in org.apache.cassandra.utils.progress
Interface for ProgressEvent publisher.
ProgressEventNotifierSupport - Class in org.apache.cassandra.utils.progress
Provides basic, thread safe ProgressEvent notification support
ProgressEventNotifierSupport() - Constructor for class org.apache.cassandra.utils.progress.ProgressEventNotifierSupport
 
ProgressEventType - Enum in org.apache.cassandra.utils.progress
Progress event type.
ProgressInfo - Class in org.apache.cassandra.streaming
ProgressInfo contains stream transfer progress.
ProgressInfo(InetAddressAndPort, int, String, ProgressInfo.Direction, long, long) - Constructor for class org.apache.cassandra.streaming.ProgressInfo
 
ProgressInfo.Direction - Enum in org.apache.cassandra.streaming
Direction of the stream.
ProgressInfoCompositeData - Class in org.apache.cassandra.streaming.management
 
ProgressInfoCompositeData() - Constructor for class org.apache.cassandra.streaming.management.ProgressInfoCompositeData
 
ProgressListener - Interface in org.apache.cassandra.utils.progress
Listener interface to handle ProgressEvent
promised - Variable in class org.apache.cassandra.repair.messages.FinalizePromise
 
promised - Variable in class org.apache.cassandra.service.paxos.PrepareCallback
 
promised - Variable in class org.apache.cassandra.service.paxos.PrepareResponse
 
properties - Variable in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
PROPERTY_PREFIX - Static variable in class org.apache.cassandra.config.Config
 
PropertyDefinitions - Class in org.apache.cassandra.cql3.statements
 
PropertyDefinitions() - Constructor for class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
PropertyFileSnitch - Class in org.apache.cassandra.locator
Used to determine if two IP's are in the same datacenter or on the same rack.
PropertyFileSnitch() - Constructor for class org.apache.cassandra.locator.PropertyFileSnitch
 
PropertyFileSnitch(int) - Constructor for class org.apache.cassandra.locator.PropertyFileSnitch
 
propose(Commit) - Static method in class org.apache.cassandra.service.paxos.PaxosState
 
ProposeCallback - Class in org.apache.cassandra.service.paxos
ProposeCallback has two modes of operation, controlled by the failFast parameter.
ProposeCallback(int, int, boolean, ConsistencyLevel, long) - Constructor for class org.apache.cassandra.service.paxos.ProposeCallback
 
ProposeVerbHandler - Class in org.apache.cassandra.service.paxos
 
ProposeVerbHandler() - Constructor for class org.apache.cassandra.service.paxos.ProposeVerbHandler
 
Props() - Constructor for class org.apache.cassandra.gms.Gossiper.Props
 
protectedResources() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
protectedResources() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
protectedResources() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
protectedResources() - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
protectedResources() - Method in interface org.apache.cassandra.auth.IAuthenticator
Set of resources that should be made inaccessible to users and only accessible internally.
protectedResources() - Method in interface org.apache.cassandra.auth.IAuthorizer
Set of resources that should be made inaccessible to users and only accessible internally.
protectedResources() - Method in interface org.apache.cassandra.auth.IRoleManager
Set of resources that should be made inaccessible to users and only accessible internally.
protectedResources() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
protocol - Variable in class org.apache.cassandra.config.EncryptionOptions
 
PROTOCOL - Static variable in class org.apache.cassandra.transport.ConnectedClient
 
PROTOCOL_VERSION - Static variable in class org.apache.cassandra.fql.FullQueryLogger
 
PROTOCOL_VERSION - Static variable in class org.apache.cassandra.transport.ClientStat
 
PROTOCOL_VERSION_MASK - Static variable in class org.apache.cassandra.transport.Envelope
 
PROTOCOL_VERSIONS - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
 
ProtocolException - Exception in org.apache.cassandra.transport
Exceptions thrown when a client didn't respect the protocol.
ProtocolException(String) - Constructor for exception org.apache.cassandra.transport.ProtocolException
 
ProtocolException(String, ProtocolVersion) - Constructor for exception org.apache.cassandra.transport.ProtocolException
 
protocolVersion() - Method in class org.apache.cassandra.transport.ConnectedClient
 
ProtocolVersion - Enum in org.apache.cassandra.transport
The native (CQL binary) protocol version.
protocolVersion(ProtocolVersion) - Method in class org.apache.cassandra.transport.SimpleClient.Builder
 
ProtocolVersionTracker - Class in org.apache.cassandra.transport
This class tracks the last 100 connections per protocol version
ProxyHistograms - Class in org.apache.cassandra.tools.nodetool
 
ProxyHistograms() - Constructor for class org.apache.cassandra.tools.nodetool.ProxyHistograms
 
prune() - Method in class org.apache.cassandra.utils.SlidingTimeRate
Prunes the time window of old unused updates.
publish(DiagnosticEvent) - Method in class org.apache.cassandra.diag.DiagnosticEventService
Makes provided event available to all subscribers.
PULL_REPAIR_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
pullRepair - Variable in class org.apache.cassandra.repair.RepairSession
 
PureJavaOperations() - Constructor for class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
 
purge(DeletionPurger, int) - Method in class org.apache.cassandra.db.rows.AbstractCell
 
purge(DeletionPurger, int, boolean) - Method in class org.apache.cassandra.db.rows.BTreeRow
 
purge(DeletionPurger, int) - Method in class org.apache.cassandra.db.rows.Cell
 
purge(DeletionPurger, int) - Method in class org.apache.cassandra.db.rows.ColumnData
 
purge(DeletionPurger, int) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
purge(DeletionPurger, int, boolean) - Method in interface org.apache.cassandra.db.rows.Row
Returns a copy of this row without any deletion info that should be purged according to purger.
PURGE_ALL - Static variable in interface org.apache.cassandra.db.DeletionPurger
 
PurgeFunction - Class in org.apache.cassandra.db.partitions
 
PurgeFunction(int, int, int, boolean, boolean) - Constructor for class org.apache.cassandra.db.partitions.PurgeFunction
 
pushViewReplicaUpdates(PartitionUpdate, boolean, AtomicLong) - Method in class org.apache.cassandra.db.view.TableViews
Calculates and pushes updates to the views replicas.
put(K, V) - Method in class org.apache.cassandra.cache.CaffeineCache
 
put(K, V) - Method in interface org.apache.cassandra.cache.ICache
 
put(K, V) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
put(K, V) - Method in class org.apache.cassandra.cache.SerializingCache
 
put(long, Memory, long, long) - Method in class org.apache.cassandra.io.util.Memory
 
put(K, Replica) - Method in class org.apache.cassandra.locator.ReplicaMultimap.Builder
 
put(Range<Token>, T) - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
 
put(ViewMetadata) - Method in class org.apache.cassandra.schema.Views.Builder
 
put(Iterable<ViewMetadata>) - Method in class org.apache.cassandra.schema.Views.Builder
 
put(K, V) - Method in class org.apache.cassandra.utils.BiMultiValMap
 
put(BinLog.ReleaseableWriteMarshallable) - Method in class org.apache.cassandra.utils.binlog.BinLog
Put a record into the log.
put(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
put(T) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
put(K, V) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
put(ByteBuffer) - Method in class org.apache.cassandra.utils.memory.BufferPool.LocalPool
 
put(ByteBuffer) - Method in class org.apache.cassandra.utils.memory.BufferPool
 
putAll(Range<Token>, EndpointsForRange, ReplicaCollection.Builder.Conflict) - Method in class org.apache.cassandra.locator.EndpointsByRange.Builder
 
putAll(Replica, EndpointsForRange, ReplicaCollection.Builder.Conflict) - Method in class org.apache.cassandra.locator.EndpointsByReplica.Builder
 
putAll(Map<? extends Range<Token>, ? extends T>) - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.cassandra.utils.BiMultiValMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
putBoolean(byte[], int, boolean) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
putCachedCounter(ByteBuffer, Clustering<?>, ColumnMetadata, CellPath, ClockAndCount) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
putChar(byte[], int, char) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
putDouble(byte[], int, double) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
putFloat(byte[], int, float) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
putIfAbsent(K, V) - Method in class org.apache.cassandra.cache.CaffeineCache
 
putIfAbsent(K, V) - Method in interface org.apache.cassandra.cache.ICache
 
putIfAbsent(K, V) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
putIfAbsent(K, V) - Method in class org.apache.cassandra.cache.SerializingCache
 
putIfAbsent(String, ConcurrentSkipListSet<DecoratedKey>) - Method in class org.apache.cassandra.index.sasi.memory.TrieMemIndex.ConcurrentPrefixTrie
 
putIfAbsent(String, ConcurrentSkipListSet<DecoratedKey>) - Method in class org.apache.cassandra.index.sasi.memory.TrieMemIndex.ConcurrentSuffixTrie
 
putInt(byte[], int, int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
putInt(ByteBuffer, int, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
putInt(V, int, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
writes the int value to at offset
putInt(byte[], int, int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
putIntByByte(long, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
putLong(byte[], int, long) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
putLong(ByteBuffer, int, long) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
putLong(V, int, long) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
writes the long value to at offset
putLong(byte[], int, long) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
putLongByByte(long, long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
putShort(byte[], int, short) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
putShort(ByteBuffer, int, short) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
putShort(V, int, short) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
writes the short value to at offset
putShort(byte[], int, short) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
Putter(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Maps.Putter
 
putUnusedPortion(ByteBuffer) - Method in class org.apache.cassandra.utils.memory.BufferPool.LocalPool
 
putUnusedPortion(ByteBuffer) - Method in class org.apache.cassandra.utils.memory.BufferPool
 

Q

QualifiedName - Class in org.apache.cassandra.cql3
Class for the names of the keyspace-prefixed elements (e.g.
QualifiedName() - Constructor for class org.apache.cassandra.cql3.QualifiedName
 
QualifiedName(String, String) - Constructor for class org.apache.cassandra.cql3.QualifiedName
 
QualifiedStatement - Class in org.apache.cassandra.cql3.statements
Abstract class for statements that work on sub-keyspace level (tables, views, indexes, functions, etc.)
QUARANTINE_DELAY - Static variable in class org.apache.cassandra.gms.Gossiper
 
queriedColumns() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
The columns to fetch internally for this SELECT statement (which can be more than the one selected by the user as it also include any restricted column in particular).
queriedColumns() - Method in class org.apache.cassandra.db.filter.ColumnFilter
The columns actually queried by the user.
queriedColumns() - Method in class org.apache.cassandra.db.filter.ColumnFilter.SelectionColumnFilter
 
queriedColumns() - Method in class org.apache.cassandra.db.filter.ColumnFilter.WildCardColumnFilter
 
queries - Variable in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
 
QUERIES - Static variable in class org.apache.cassandra.fql.FullQueryLogger
 
QUERY - Static variable in class org.apache.cassandra.fql.FullQueryLogger
 
Query(String, QueryOptions, QueryState, long) - Constructor for class org.apache.cassandra.fql.FullQueryLogger.Query
 
query - Variable in class org.apache.cassandra.transport.messages.QueryMessage
 
QUERY_OPTIONS - Static variable in class org.apache.cassandra.fql.FullQueryLogger
 
QUERY_START_TIME - Static variable in class org.apache.cassandra.fql.FullQueryLogger
 
QueryController - Class in org.apache.cassandra.index.sasi.plan
 
QueryController(ColumnFamilyStore, PartitionRangeReadCommand, long) - Constructor for class org.apache.cassandra.index.sasi.plan.QueryController
 
queryDataFromIndex(DecoratedKey, RowIterator, ReadCommand, ReadExecutionController) - Method in class org.apache.cassandra.index.internal.CassandraIndexSearcher
 
queryDataFromIndex(DecoratedKey, RowIterator, ReadCommand, ReadExecutionController) - Method in class org.apache.cassandra.index.internal.composites.CompositesSearcher
 
queryDataFromIndex(DecoratedKey, RowIterator, ReadCommand, ReadExecutionController) - Method in class org.apache.cassandra.index.internal.keys.KeysSearcher
 
QueryEvents - Class in org.apache.cassandra.cql3
 
QueryEvents() - Constructor for class org.apache.cassandra.cql3.QueryEvents
 
QueryEvents.Listener - Interface in org.apache.cassandra.cql3
 
queryFailure(CQLStatement, String, QueryOptions, QueryState, Exception) - Method in class org.apache.cassandra.audit.AuditLogManager
 
queryFailure(CQLStatement, String, QueryOptions, QueryState, Exception) - Method in interface org.apache.cassandra.cql3.QueryEvents.Listener
 
QueryHandler - Interface in org.apache.cassandra.cql3
 
QueryHandler.Prepared - Class in org.apache.cassandra.cql3
 
queryMemtableAndDisk(ColumnFamilyStore, ReadExecutionController) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
Queries both memtable and sstables to fetch the result of this query.
QueryMessage - Class in org.apache.cassandra.transport.messages
A CQL query
QueryMessage(String, QueryOptions) - Constructor for class org.apache.cassandra.transport.messages.QueryMessage
 
queryNames - Variable in class org.apache.cassandra.auth.jmx.AuthorizationProxy
 
QueryOptions - Class in org.apache.cassandra.cql3
Options for a query.
QueryOptions() - Constructor for class org.apache.cassandra.cql3.QueryOptions
 
queryOrIdList - Variable in class org.apache.cassandra.transport.messages.BatchMessage
 
QueryPager - Interface in org.apache.cassandra.service.pager
Perform a query, paging it by page of a given size.
QueryPlan - Class in org.apache.cassandra.index.sasi.plan
 
QueryPlan(ColumnFamilyStore, ReadCommand, long) - Constructor for class org.apache.cassandra.index.sasi.plan.QueryPlan
 
QueryProcessor - Class in org.apache.cassandra.cql3
 
queryStartNanoTime - Variable in class org.apache.cassandra.service.reads.AbstractReadExecutor
 
queryStartNanoTime - Variable in class org.apache.cassandra.service.reads.repair.AbstractReadRepair
 
queryStartNanoTime - Variable in class org.apache.cassandra.service.reads.ResponseResolver
 
QueryState - Class in org.apache.cassandra.service
Primarily used as a recorder for server-generated timestamps (timestamp, in microseconds, and nowInSeconds - in, well, seconds).
QueryState(ClientState) - Constructor for class org.apache.cassandra.service.QueryState
 
QueryState(ClientState, long, int) - Constructor for class org.apache.cassandra.service.QueryState
 
queryStorage(ColumnFamilyStore, ReadExecutionController) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
queryStorage(ColumnFamilyStore, ReadExecutionController) - Method in class org.apache.cassandra.db.ReadCommand
 
queryStorage(ColumnFamilyStore, ReadExecutionController) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
querySuccess(CQLStatement, String, QueryOptions, QueryState, long, Message.Response) - Method in class org.apache.cassandra.audit.AuditLogManager
 
querySuccess(CQLStatement, String, QueryOptions, QueryState, long, Message.Response) - Method in interface org.apache.cassandra.cql3.QueryEvents.Listener
 
querySuccess(CQLStatement, String, QueryOptions, QueryState, long, Message.Response) - Method in class org.apache.cassandra.fql.FullQueryLogger
Log a single CQL query
queryVirtualTable() - Method in class org.apache.cassandra.db.VirtualTablePartitionRangeReadQuery
 
queryVirtualTable() - Method in class org.apache.cassandra.db.VirtualTableReadQuery
 
queryVirtualTable() - Method in class org.apache.cassandra.db.VirtualTableSinglePartitionReadQuery
 
queue - Variable in class org.apache.cassandra.transport.SimpleClient.SimpleEventHandler
 
QUEUE_SIZE - Static variable in class org.apache.cassandra.hadoop.cql3.CqlOutputFormat
 
queueCapacity - Variable in class org.apache.cassandra.net.AbstractMessageHandler
 
quick(boolean) - Method in class org.apache.cassandra.db.compaction.Verifier.Options.Builder
 
quick - Variable in class org.apache.cassandra.db.compaction.Verifier.Options
 
QUIET_FILTER - Static variable in class org.apache.cassandra.security.SSLFactory.LoggingCipherSuiteFilter
 
quorumFor(AbstractReplicationStrategy) - Static method in enum org.apache.cassandra.db.ConsistencyLevel
 
quote(String) - Static method in class org.apache.cassandra.cql3.functions.types.Metadata
Quote a keyspace, table or column identifier to make it case sensitive.
quote(String) - Static method in class org.apache.cassandra.cql3.functions.types.ParseUtils
Quote the given string; single quotes are escaped.
quoteAsJsonString(String) - Static method in class org.apache.cassandra.cql3.Json
Quotes string contents using standard JSON quoting.

R

rack(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
rack - Variable in class org.apache.cassandra.service.TokenRange.EndpointDetails
 
RACK_NAME - Static variable in class org.apache.cassandra.locator.SimpleSnitch
 
RACKDC_PROPERTY_FILENAME - Static variable in class org.apache.cassandra.locator.SnitchProperties
 
rackId() - Method in class org.apache.cassandra.dht.tokenallocator.OfflineTokenAllocator.FakeNode
 
RackInferringSnitch - Class in org.apache.cassandra.locator
A simple endpoint snitch implementation that assumes datacenter and rack information is encoded in the 2nd and 3rd octets of the ip address, respectively.
RackInferringSnitch() - Constructor for class org.apache.cassandra.locator.RackInferringSnitch
 
RandomAccessReader - Class in org.apache.cassandra.io.util
 
RandomPartitioner - Class in org.apache.cassandra.dht
This class generates a BigIntegerToken using MD5 hash.
RandomPartitioner() - Constructor for class org.apache.cassandra.dht.RandomPartitioner
 
RandomPartitioner.BigIntegerToken - Class in org.apache.cassandra.dht
 
Range<T extends RingPosition<T>> - Class in org.apache.cassandra.dht
A representation of the range that a node is responsible for on the DHT ring.
Range(T, T) - Constructor for class org.apache.cassandra.dht.Range
 
range() - Method in class org.apache.cassandra.dht.Splitter.WeightedRange
 
range - Variable in class org.apache.cassandra.index.sasi.plan.Operation
 
range() - Method in class org.apache.cassandra.locator.EndpointsForRange
 
range() - Method in class org.apache.cassandra.locator.Replica
 
range() - Method in interface org.apache.cassandra.locator.ReplicaLayout.ForRange
 
range() - Method in class org.apache.cassandra.locator.ReplicaLayout.ForRangeRead
 
range() - Method in class org.apache.cassandra.locator.ReplicaPlan.ForRangeRead
 
range - Variable in class org.apache.cassandra.repair.consistent.RepairedState.Section
 
range - Variable in class org.apache.cassandra.service.TokenRange
 
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_list_growth_factor - Variable in class org.apache.cassandra.config.Config
The growth factor to enlarge a RangeTombstoneList.
RangeAwareSSTableWriter - Class in org.apache.cassandra.io.sstable.format
 
RangeAwareSSTableWriter(ColumnFamilyStore, long, long, UUID, boolean, SSTableFormat.Type, int, long, LifecycleNewTracker, SerializationHeader) - Constructor for class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
 
RangeCommands - Class in org.apache.cassandra.service.reads.range
 
RangeCommands() - Constructor for class org.apache.cassandra.service.reads.range.RangeCommands
 
rangeCount() - Method in interface org.apache.cassandra.db.DeletionInfo
 
rangeCount() - Method in class org.apache.cassandra.db.MutableDeletionInfo
 
rangeCount() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
 
rangeCovering(Clustering<?>) - Method in interface org.apache.cassandra.db.DeletionInfo
 
rangeCovering(Clustering<?>) - Method in class org.apache.cassandra.db.MutableDeletionInfo
 
RangeDenormalizer - Class in org.apache.cassandra.repair.asymmetric
 
RangeDenormalizer() - Constructor for class org.apache.cassandra.repair.asymmetric.RangeDenormalizer
 
RangeFetchMapCalculator - Class in org.apache.cassandra.dht
We model the graph like this: * Each range we are about to stream is a vertex in the graph * Each node that can provide a range is a vertex in the graph * We add an edge from each range to the node that can provide the range * Then, to be able to solve the maximum flow problem using Ford-Fulkerson we add a super source with edges to all range vertices and a super sink with incoming edges from all the node vertices.
RangeFetchMapCalculator(EndpointsByRange, Collection<RangeStreamer.SourceFilter>, String) - Constructor for class org.apache.cassandra.dht.RangeFetchMapCalculator
 
RangeIntersectionIterator - Class in org.apache.cassandra.index.sasi.utils
 
RangeIntersectionIterator() - Constructor for class org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator
 
RangeIntersectionIterator.BounceIntersectionIterator<K extends java.lang.Comparable<K>,D extends CombinedValue<K>> - Class in org.apache.cassandra.index.sasi.utils
Iterator which performs intersection of multiple ranges by using bouncing (merge-join) technique to identify common elements in the given ranges.
RangeIntersectionIterator.Builder<K extends java.lang.Comparable<K>,D extends CombinedValue<K>> - Class in org.apache.cassandra.index.sasi.utils
 
RangeIntersectionIterator.LookupIntersectionIterator<K extends java.lang.Comparable<K>,D extends CombinedValue<K>> - Class in org.apache.cassandra.index.sasi.utils
Iterator which performs a linear scan over a primary range (the smallest of the ranges) and O(log(n)) lookup into secondary ranges using values from the primary iterator.
RangeIntersectionIterator.Strategy - Enum in org.apache.cassandra.index.sasi.utils
 
rangeIterator(boolean) - Method in interface org.apache.cassandra.db.DeletionInfo
 
rangeIterator(Slice, boolean) - Method in interface org.apache.cassandra.db.DeletionInfo
 
rangeIterator(boolean) - Method in class org.apache.cassandra.db.MutableDeletionInfo
 
rangeIterator(Slice, boolean) - Method in class org.apache.cassandra.db.MutableDeletionInfo
 
RangeIterator<K extends java.lang.Comparable<K>,T extends CombinedValue<K>> - Class in org.apache.cassandra.index.sasi.utils
 
RangeIterator(RangeIterator.Builder.Statistics<K, T>) - Constructor for class org.apache.cassandra.index.sasi.utils.RangeIterator
 
RangeIterator(RangeIterator<K, T>) - Constructor for class org.apache.cassandra.index.sasi.utils.RangeIterator
 
RangeIterator(K, K, long) - Constructor for class org.apache.cassandra.index.sasi.utils.RangeIterator
 
rangeIterator() - Method in class org.apache.cassandra.utils.MerkleTrees
Get an iterator for all the iterator generated by the MerkleTrees.
RangeIterator.Builder<K extends java.lang.Comparable<K>,D extends CombinedValue<K>> - Class in org.apache.cassandra.index.sasi.utils
 
RangeIterator.Builder.EmptyRangeIterator<K extends java.lang.Comparable<K>,D extends CombinedValue<K>> - Class in org.apache.cassandra.index.sasi.utils
 
RangeIterator.Builder.IteratorType - Enum in org.apache.cassandra.index.sasi.utils
 
RangeIterator.Builder.Statistics<K extends java.lang.Comparable<K>,D extends CombinedValue<K>> - Class in org.apache.cassandra.index.sasi.utils
 
RangeKeySample - Class in org.apache.cassandra.tools.nodetool
 
RangeKeySample() - Constructor for class org.apache.cassandra.tools.nodetool.RangeKeySample
 
rangeLatency - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
(Local) range slice metrics
rangeLatency - Variable in class org.apache.cassandra.metrics.TableMetrics
(Local) range slice metrics
RangeMap<T> - Class in org.apache.cassandra.repair.asymmetric
 
RangeMap() - Constructor for class org.apache.cassandra.repair.asymmetric.RangeMap
 
RangeOwnHelper(List<Range<Token>>) - Constructor for class org.apache.cassandra.db.compaction.Verifier.RangeOwnHelper
 
RangeRelocator - Class in org.apache.cassandra.service
 
RangeRelocator() - Constructor for class org.apache.cassandra.service.RangeRelocator
 
ranges - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
 
ranges() - Method in class org.apache.cassandra.locator.RangesAtEndpoint
 
ranges - Variable in class org.apache.cassandra.repair.CommonRange
 
ranges - Variable in class org.apache.cassandra.repair.consistent.ConsistentSession
 
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.repair.RepairJobDesc
repairing range
ranges() - Method in class org.apache.cassandra.repair.RepairSession
 
ranges - Variable in class org.apache.cassandra.repair.RepairSessionResult
 
ranges() - Method in class org.apache.cassandra.utils.MerkleTrees
Get the ranges that these merkle trees covers.
RANGES_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
RangesAtEndpoint - Class in org.apache.cassandra.locator
A ReplicaCollection for Ranges occurring at an endpoint.
RangesAtEndpoint.Builder - Class in org.apache.cassandra.locator
 
RangesByEndpoint - Class in org.apache.cassandra.locator
 
RangesByEndpoint(Map<InetAddressAndPort, RangesAtEndpoint>) - Constructor for class org.apache.cassandra.locator.RangesByEndpoint
 
RangesByEndpoint.Builder - Class in org.apache.cassandra.locator
 
rangeSet(Range<T>...) - Static method in class org.apache.cassandra.dht.Range
 
rangeSet(Range<T>) - Static method in class org.apache.cassandra.dht.Range
 
rangesToSync - Variable in class org.apache.cassandra.repair.SyncTask
 
RangeStreamer - Class in org.apache.cassandra.dht
Assists in streaming ranges to this node.
RangeStreamer(TokenMetadata, Collection<Token>, InetAddressAndPort, StreamOperation, boolean, IEndpointSnitch, StreamStateStore, boolean, int) - Constructor for class org.apache.cassandra.dht.RangeStreamer
 
RangeStreamer.AllowedSourcesFilter - Class in org.apache.cassandra.dht
Source filter which only includes endpoints contained within a provided set.
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.FetchReplica - Class in org.apache.cassandra.dht
 
RangeStreamer.SingleDatacenterFilter - Class in org.apache.cassandra.dht
Source filter which excludes any endpoints that are not in a specific data center.
RangeStreamer.SourceFilter - Interface in org.apache.cassandra.dht
 
RangeTermTree - Class in org.apache.cassandra.index.sasi.conf.view
 
RangeTermTree(ByteBuffer, ByteBuffer, IntervalTree<RangeTermTree.Term, SSTableIndex, Interval<RangeTermTree.Term, SSTableIndex>>, AbstractType<?>) - Constructor for class org.apache.cassandra.index.sasi.conf.view.RangeTermTree
 
RangeTermTree.Term - Class in org.apache.cassandra.index.sasi.conf.view
This is required since IntervalTree doesn't support custom Comparator implementations and relied on items to be comparable which "raw" terms are not.
RangeTombstone - Class in org.apache.cassandra.db
A range tombstone is a tombstone that covers a slice/range of rows.
RangeTombstone(Slice, DeletionTime) - Constructor for class org.apache.cassandra.db.RangeTombstone
 
rangeTombstone(RangeTombstone) - Method in interface org.apache.cassandra.index.Index.Indexer
Notification of a RangeTombstone.
RangeTombstoneBoundaryMarker - Class in org.apache.cassandra.db.rows
A range tombstone marker that represents a boundary between 2 range tombstones (i.e.
RangeTombstoneBoundaryMarker(ClusteringBoundary<?>, DeletionTime, DeletionTime) - Constructor for class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
RangeTombstoneBoundMarker - Class in org.apache.cassandra.db.rows
A range tombstone marker that indicates the bound of a range tombstone (start or end).
RangeTombstoneBoundMarker(ClusteringBound<?>, DeletionTime) - Constructor for class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
RangeTombstoneList - Class in org.apache.cassandra.db
Data structure holding the range tombstones of a ColumnFamily.
RangeTombstoneList(ClusteringComparator, int) - Constructor for class org.apache.cassandra.db.RangeTombstoneList
 
RangeTombstoneMarker - Interface in org.apache.cassandra.db.rows
A marker for a range tombstone bound.
RangeTombstoneMarker.Merger - Class in org.apache.cassandra.db.rows
Utility class to help merging range tombstone markers coming from multiple inputs (UnfilteredRowIterators).
rangeTree - Variable in class org.apache.cassandra.index.sasi.conf.view.RangeTermTree
 
RangeUnionIterator<K extends java.lang.Comparable<K>,D extends CombinedValue<K>> - Class in org.apache.cassandra.index.sasi.utils
Range Union Iterator is used to return sorted stream of elements from multiple RangeIterator instances.
RangeUnionIterator.Builder<K extends java.lang.Comparable<K>,D extends CombinedValue<K>> - Class in org.apache.cassandra.index.sasi.utils
 
Raw(int) - Constructor for class org.apache.cassandra.cql3.AbstractMarker.Raw
 
Raw() - Constructor for class org.apache.cassandra.cql3.Attributes.Raw
 
Raw(boolean) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Raw
 
Raw() - Constructor for class org.apache.cassandra.cql3.CQLStatement.Raw
 
Raw(FunctionName, List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.functions.FunctionCall.Raw
 
Raw(List<Selectable.Raw>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.BetweenParenthesesOrWithTuple.Raw
 
Raw(Selectable.Raw, CQL3Type) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithCast.Raw
 
Raw(Selectable.Raw, Term.Raw) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithElementSelection.Raw
 
Raw(Selectable.Raw, FieldIdentifier) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection.Raw
 
Raw(FunctionName, List<Selectable.Raw>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithFunction.Raw
 
Raw(List<Selectable.Raw>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithList.Raw
 
Raw(List<Pair<Selectable.Raw, Selectable.Raw>>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithMapOrUdt.Raw
 
Raw(List<Selectable.Raw>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithSet.Raw
 
Raw(Selectable.Raw, Term.Raw, Term.Raw) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithSliceSelection.Raw
 
Raw(Term.Raw) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithTerm.Raw
 
Raw(CQL3Type.Raw, Selectable.Raw) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithTypeHint.Raw
 
Raw(Selectable.RawIdentifier, boolean) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL.Raw
 
Raw(String, KeyspaceAttributes) - Constructor for class org.apache.cassandra.cql3.statements.schema.AlterKeyspaceStatement.Raw
 
Raw(QualifiedName) - Constructor for class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
 
Raw(UTName) - Constructor for class org.apache.cassandra.cql3.statements.schema.AlterTypeStatement.Raw
 
Raw(QualifiedName, TableAttributes) - Constructor for class org.apache.cassandra.cql3.statements.schema.AlterViewStatement.Raw
 
Raw(FunctionName, List<CQL3Type.Raw>, CQL3Type.Raw, String, String, Term.Raw, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateAggregateStatement.Raw
 
Raw(FunctionName, List<ColumnIdentifier>, List<CQL3Type.Raw>, CQL3Type.Raw, boolean, String, String, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateFunctionStatement.Raw
 
Raw(QualifiedName, QualifiedName, List<IndexTarget.Raw>, IndexAttributes, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement.Raw
 
Raw(String, KeyspaceAttributes, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateKeyspaceStatement.Raw
 
Raw(QualifiedName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
 
Raw(QualifiedName, String, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateTriggerStatement.Raw
 
Raw(UTName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateTypeStatement.Raw
 
Raw(QualifiedName, QualifiedName, List<RawSelector>, WhereClause, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateViewStatement.Raw
 
Raw(FunctionName, List<CQL3Type.Raw>, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropAggregateStatement.Raw
 
Raw(FunctionName, List<CQL3Type.Raw>, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropFunctionStatement.Raw
 
Raw(QualifiedName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropIndexStatement.Raw
 
Raw(String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropKeyspaceStatement.Raw
 
Raw(QualifiedName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropTableStatement.Raw
 
Raw(QualifiedName, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropTriggerStatement.Raw
 
Raw(UTName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropTypeStatement.Raw
 
Raw(QualifiedName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropViewStatement.Raw
 
Raw() - Constructor for class org.apache.cassandra.cql3.Term.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.
rawBuilder(String) - Static method in class org.apache.cassandra.schema.Types
 
rawCQLStatement - Variable in class org.apache.cassandra.cql3.QueryHandler.Prepared
Contains the CQL statement source if the statement has been "regularly" perpared via QueryHandler.prepare(String, ClientState, Map).
rawMean() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
rawRangesToRangeSet(Set<ByteBuffer>, IPartitioner) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
RawSelector - Class in org.apache.cassandra.cql3.selection
 
RawSelector(Selectable.Raw, ColumnIdentifier) - Constructor for class org.apache.cassandra.cql3.selection.RawSelector
 
RawStatement(QualifiedName, SelectStatement.Parameters, List<RawSelector>, WhereClause, Term.Raw, Term.Raw) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
 
read(TableMetadata, DataInputPlus) - Static method in class org.apache.cassandra.cache.CounterCacheKey
 
read(ValueAccessor<V>, DataInputPlus, int) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
read(DataInputPlus, int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
read(DataInputPlus, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
read(DataInputPlus, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
Reads a value of bytes from
read(DataInputPlus) - Method in class org.apache.cassandra.db.streaming.CassandraCompressedStreamReader
 
read(DataInputPlus) - Method in class org.apache.cassandra.db.streaming.CassandraEntireSSTableStreamReader
 
read(DataInputPlus, int) - Method in class org.apache.cassandra.db.streaming.CassandraIncomingFile
 
read(DataInputPlus) - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader
 
read(DataInputPlus) - Method in interface org.apache.cassandra.db.streaming.IStreamReader
 
read(DataInput) - Static method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
read(byte[], int, int) - Method in class org.apache.cassandra.hints.ChecksummedDataInput
 
read(ByteBuffer, long) - Method in class org.apache.cassandra.io.util.ChannelProxy
 
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(byte[], int, int) - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
read() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
read() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
read(byte[], int, int) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
read(byte[]) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
read() - Method in class org.apache.cassandra.io.util.TrackedInputStream
 
read(byte[], int, int) - Method in class org.apache.cassandra.io.util.TrackedInputStream
 
read(byte[]) - Method in class org.apache.cassandra.io.util.TrackedInputStream
 
read - Variable in exception org.apache.cassandra.net.Message.InvalidLegacyProtocolMagic
 
read(ByteBuffer) - Method in class org.apache.cassandra.security.EncryptionUtils.ChannelProxyReadChannel
 
read(SinglePartitionReadCommand.Group, ConsistencyLevel, long) - Static method in class org.apache.cassandra.service.StorageProxy
 
read(SinglePartitionReadCommand.Group, ConsistencyLevel, ClientState, long) - 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(DataInputPlus, int) - Method in interface org.apache.cassandra.streaming.IncomingStream
Read in the stream data.
read(DataInput, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
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
 
readAllFiles(CommitLogReadHandler, File[]) - Method in class org.apache.cassandra.db.commitlog.CommitLogReader
Reads all passed in files with no minimum, no start, and no mutation limit.
readAllFiles(CommitLogReadHandler, File[], CommitLogPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogReader
Reads all passed in files with minPosition, no start, and no mutation limit.
readArray(DataInputPlus, int) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
readBoolean() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
readBoolean() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
readBoolean() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
 
readBoundValue(ByteBuf, ProtocolVersion) - Static method in class org.apache.cassandra.transport.CBUtil
 
readBuffer(DataInputPlus) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
readBuffer(DataInputPlus, int) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
readBuffer(DataInputPlus) - Method in class org.apache.cassandra.db.marshal.EmptyType
 
readBuffer(DataInputPlus, int) - Method in class org.apache.cassandra.db.marshal.EmptyType
 
readBuffer() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
 
readBuffer() - Method in class org.apache.cassandra.hints.CompressedChecksummedDataInput
 
readBuffer() - Method in class org.apache.cassandra.hints.EncryptedChecksummedDataInput
 
readByte() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
readByte() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
readByte() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
 
readBytes(ByteBuffer, int) - Static method in class org.apache.cassandra.cql3.functions.types.CodecUtils
Read length bytes from bb into a new ByteBuffer.
readBytes(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readBytes(DataInput, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
readBytes(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
readBytesMap(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readBytesWithLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
readBytesWithShortLength(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
ReadCallback<E extends Endpoints<E>,P extends ReplicaPlan.ForRead<E>> - Class in org.apache.cassandra.service.reads
 
ReadCallback(ResponseResolver<E, P>, ReadCommand, ReplicaPlan.Shared<E, P>, long) - Constructor for class org.apache.cassandra.service.reads.ReadCallback
 
readChar() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
readChar() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
readChar() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
 
readChunk(long, ByteBuffer) - Method in interface org.apache.cassandra.io.util.ChunkReader
Read the chunk at the given position, attempting to fill the capacity of the given buffer.
readChunk(long, ByteBuffer) - Method in class org.apache.cassandra.io.util.CompressedChunkReader.Mmap
 
readChunk(long, ByteBuffer) - Method in class org.apache.cassandra.io.util.CompressedChunkReader.Standard
 
readCollectionSize(ByteBuffer, ProtocolVersion) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
 
readCollectionSize(V, ValueAccessor<V>, ProtocolVersion) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
 
readCommand(int) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
 
ReadCommand - Class in org.apache.cassandra.db
General interface for storage-engine read commands (common to both range and single partition commands).
ReadCommand(ReadCommand.Kind, boolean, int, boolean, TableMetadata, int, ColumnFilter, RowFilter, DataLimits, IndexMetadata) - Constructor for class org.apache.cassandra.db.ReadCommand
 
readCommand(int) - Method in interface org.apache.cassandra.service.CASRequest
The command to use to fetch the value to compare for the CAS.
ReadCommand.CheckForAbort - Class in org.apache.cassandra.db
 
ReadCommand.Kind - Enum in org.apache.cassandra.db
 
ReadCommand.SelectionDeserializer - Class in org.apache.cassandra.db
 
ReadCommand.Serializer - Class in org.apache.cassandra.db
 
ReadCommandVerbHandler - Class in org.apache.cassandra.db
 
ReadCommandVerbHandler() - Constructor for class org.apache.cassandra.db.ReadCommandVerbHandler
 
readCommitLogSegment(CommitLogReadHandler, File, boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLogReader
Reads passed in file fully
readCommitLogSegment(CommitLogReadHandler, File, CommitLogPosition, boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLogReader
Reads all mutations from passed in file from minPosition
readCommitLogSegment(CommitLogReadHandler, File, int, boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLogReader
Reads passed in file fully, up to mutationLimit count
readCommitLogSegment(CommitLogReadHandler, File, CommitLogPosition, int, boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLogReader
Reads mutations from file, handing them off to handler
readConsistencyLevel(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readCount - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsKeyspace
 
readCounterValue(ColumnFamilyStore) - Method in class org.apache.cassandra.cache.CounterCacheKey
Reads the value of the counter represented by this key.
readCRC - Variable in class org.apache.cassandra.net.FrameDecoder.CorruptFrame
 
readDeletionTime(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
 
readDouble() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
readDouble() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
readDouble() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
 
readEnumValue(Class<T>, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
reader - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
Reader(FileDataInput, boolean) - Constructor for class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
 
readerFactory - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
ReaderFileProxy - Interface in org.apache.cassandra.io.util
Base class for the RandomAccessReader components that implement reading.
ReaderState(LifecycleTransaction.ReaderState.Action, LifecycleTransaction.ReaderState.Action, SSTableReader, SSTableReader, boolean) - Constructor for class org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState
 
readEvents(String, Long, int) - Method in class org.apache.cassandra.diag.DiagnosticEventService
 
readEvents(String, Long, int) - Method in interface org.apache.cassandra.diag.DiagnosticEventServiceMBean
Retrieved all events of specified type starting with provided key.
ReadExecutionController - Class in org.apache.cassandra.db
 
readExtendedFlags(DataInputPlus, int) - Static method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
ReadFailureException - Exception in org.apache.cassandra.exceptions
 
ReadFailureException(ConsistencyLevel, int, int, boolean, Map<InetAddressAndPort, RequestFailureReason>) - Constructor for exception org.apache.cassandra.exceptions.ReadFailureException
 
readFields(DataInput) - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
readFloat() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
readFloat() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
readFloat() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
 
readFrom(DataInput) - Static method in enum org.apache.cassandra.cql3.Operator
Deserializes a Operator instance from the specified input.
readFully(byte[]) - Method in class org.apache.cassandra.hints.ChecksummedDataInput
 
readFully(byte[]) - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
readFully(ByteBuffer) - Method in class org.apache.cassandra.io.util.RebufferingInputStream
Equivalent to RebufferingInputStream.read(byte[], int, int), where offset is dst.position() and length is dst.remaining()
readFully(byte[]) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
 
readFully(byte[]) - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
 
readHeader(DataInput, EncryptionContext) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
readInet(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readInetAddr(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readInt() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
readInt() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
readInt() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
 
readIsStatic(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
readIsStatic(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
readIsStatic(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
readIsStaticInternal(V, ValueAccessor<V>) - Static method in class org.apache.cassandra.db.marshal.CompositeType
 
readLatency - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
(Local) read metrics
readLatency - Variable in class org.apache.cassandra.metrics.TableMetrics
(Local) read metrics
readLatency() - Method in class org.apache.cassandra.tools.nodetool.stats.StatsKeyspace
 
readLine() - Method in class org.apache.cassandra.io.util.RandomAccessReader
Reads a line of text form the current position in this file.
readLine() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
readLine() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
readLine() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
 
readLines(File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
readLocalDeletionTime(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
 
readLong() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
readLong() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
readLong() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
 
readLongString(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readMutation(CommitLogReadHandler, byte[], int, CommitLogPosition, int, CommitLogDescriptor) - Method in class org.apache.cassandra.db.commitlog.CommitLogReader
Deserializes and passes a Mutation to the ICommitLogReadHandler requested
readNameAndValueList(ByteBuf, ProtocolVersion) - Static method in class org.apache.cassandra.transport.CBUtil
 
readNext() - Method in class org.apache.cassandra.db.UnfilteredDeserializer
Returns the next atom.
readNextIdentifier() - Method in class org.apache.cassandra.db.marshal.TypeParser
 
readOne(SinglePartitionReadCommand, ConsistencyLevel, long) - Static method in class org.apache.cassandra.service.StorageProxy
 
readOne(SinglePartitionReadCommand, ConsistencyLevel, ClientState, long) - Static method in class org.apache.cassandra.service.StorageProxy
 
ReadOnlyReadRepair<E extends Endpoints<E>,P extends ReplicaPlan.ForRead<E>> - Class in org.apache.cassandra.service.reads.repair
Only performs the collection of data responses and reconciliation of them, doesn't send repair mutations to replicas.
readOrdering - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
readPosition(DataInputPlus) - Static method in class org.apache.cassandra.db.RowIndexEntry.Serializer
Reads only the data 'position' of the index entry and returns it.
readPrimitiveSlowly(int) - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
ReadQuery - Interface in org.apache.cassandra.db
Generic abstraction for read queries.
readRawBytes(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readRepair(ReadRepairStrategy) - Method in class org.apache.cassandra.schema.TableParams.Builder
 
readRepair - Variable in class org.apache.cassandra.schema.TableParams
 
readRepair - Variable in class org.apache.cassandra.service.reads.AbstractReadExecutor
 
ReadRepair<E extends Endpoints<E>,P extends ReplicaPlan.ForRead<E>> - Interface in org.apache.cassandra.service.reads.repair
 
ReadRepair.Factory - Interface in org.apache.cassandra.service.reads.repair
 
ReadRepairMetrics - Class in org.apache.cassandra.metrics
Metrics related to Read Repair.
ReadRepairMetrics() - Constructor for class org.apache.cassandra.metrics.ReadRepairMetrics
 
readRepairRequests - Variable in class org.apache.cassandra.metrics.TableMetrics
 
ReadRepairStrategy - Enum in org.apache.cassandra.service.reads.repair
 
ReadRepairVerbHandler - Class in org.apache.cassandra.db
 
ReadRepairVerbHandler() - Constructor for class org.apache.cassandra.db.ReadRepairVerbHandler
 
ReadResponse - Class in org.apache.cassandra.db
 
ReadResponse() - Constructor for class org.apache.cassandra.db.ReadResponse
 
readShort() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
readShort() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
readShort() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
 
readShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
readShortLength(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
readStaticRow() - Method in class org.apache.cassandra.io.sstable.SSTableSimpleIterator
 
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
 
readTimestamp(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
 
readTOC(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTable
Reads the list of components from the TOC component.
readTOC(Descriptor, boolean) - Static method in class org.apache.cassandra.io.sstable.SSTable
Reads the list of components from the TOC component.
readTTL(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
 
readUnsignedByte() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
readUnsignedByte() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
readUnsignedByte() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
 
readUnsignedShort() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
readUnsignedShort() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
readUnsignedShort() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
 
readUnsignedVInt() - Method in interface org.apache.cassandra.io.util.DataInputPlus
Think hard before opting for an unsigned encoding.
readUnsignedVInt() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
readUnsignedVInt(DataInput) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
 
readUTF() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
readUTF() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
readUTF() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
 
readUUID(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readValue(ByteBuffer, ProtocolVersion) - Static method in class org.apache.cassandra.cql3.functions.types.CodecUtils
Utility method that reads a value.
readValue(V, ValueAccessor<V>, int, ProtocolVersion) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
 
readValue(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readValue(ByteBuf, ProtocolVersion) - Method in enum org.apache.cassandra.transport.DataType
 
readValueList(ByteBuf, ProtocolVersion) - Static method in class org.apache.cassandra.transport.CBUtil
 
readValueNoCopy(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
readVInt() - Method in interface org.apache.cassandra.io.util.DataInputPlus
 
readVInt() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
readVInt(DataInput) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
 
readWithLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
readWithLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
readWithShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
readWithShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
readWithVIntLength(DataInputPlus) - 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
 
realAppend(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
realAppend(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
 
realAppend(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.compaction.writers.MajorLeveledCompactionWriter
 
realAppend(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.compaction.writers.MaxSSTableSizeWriter
 
realAppend(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
 
realMarkAlive(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
 
reason - Variable in exception org.apache.cassandra.db.commitlog.CommitLogReadHandler.CommitLogReadException
 
rebase(DecayingEstimatedHistogramReservoir.EstimatedHistogramReservoirSnapshot) - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
Replaces current internal values with the given one from a Snapshot.
reBuffer() - Method in class org.apache.cassandra.db.commitlog.EncryptedFileSegmentInputStream
 
reBuffer() - Method in class org.apache.cassandra.db.streaming.CompressedInputStream
 
reBuffer() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
 
rebuffer(long) - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
 
reBuffer() - Method in class org.apache.cassandra.io.util.DataInputBuffer
 
rebuffer(long) - Method in class org.apache.cassandra.io.util.LimitingRebufferer
 
reBuffer() - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
reBuffer() - Method in class org.apache.cassandra.io.util.NIODataInputStream
 
reBuffer() - Method in class org.apache.cassandra.io.util.RandomAccessReader
Read data from file starting from current currentOffset to populate buffer.
rebuffer(long) - Method in interface org.apache.cassandra.io.util.Rebufferer
Rebuffer (move on or seek to) a given position, and return a buffer that can be used there.
reBuffer() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
Implementations must implement this method to refill the buffer.
reBuffer() - Method in class org.apache.cassandra.net.AsyncStreamingInputPlus
Implementations must implement this method to refill the buffer.
reBuffer() - Method in class org.apache.cassandra.streaming.compress.StreamCompressionInputStream
 
Rebufferer - Interface in org.apache.cassandra.io.util
Rebufferer for reading data by a RandomAccessReader.
Rebufferer.BufferHolder - Interface in org.apache.cassandra.io.util
 
rebuffererFactory() - Method in class org.apache.cassandra.io.util.FileHandle
 
RebuffererFactory - Interface in org.apache.cassandra.io.util
Interface for the classes that can be used to instantiate rebufferers over a given file.
RebufferingInputStream - Class in org.apache.cassandra.io.util
Rough equivalent of BufferedInputStream and DataInputStream wrapping a ByteBuffer that can be refilled via rebuffer.
RebufferingInputStream(ByteBuffer) - Constructor for class org.apache.cassandra.io.util.RebufferingInputStream
 
rebuild(String) - Method in class org.apache.cassandra.service.StorageService
 
rebuild(String, String, String, 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, String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Same as StorageServiceMBean.rebuild(String), but only for specified keyspace and ranges.
rebuild(String, String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
Rebuild - Class in org.apache.cassandra.tools.nodetool
 
Rebuild() - Constructor for class org.apache.cassandra.tools.nodetool.Rebuild
 
rebuildIndex(String, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
RebuildIndex - Class in org.apache.cassandra.tools.nodetool
 
RebuildIndex() - Constructor for class org.apache.cassandra.tools.nodetool.RebuildIndex
 
rebuildIndexesBlocking(Set<String>) - Method in class org.apache.cassandra.index.SecondaryIndexManager
Does a blocking full rebuild/recovery of the specifed indexes from all the sstables in the base table.
rebuildOnFailedScrub(Throwable) - Method in class org.apache.cassandra.db.ColumnFamilyStore
CASSANDRA-5174 : For an index cfs we may be able to discard everything and just rebuild the index when a scrub fails.
rebuildSecondaryIndex(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
rebuildSecondaryIndex(String, String, String...) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
rebuildSecondaryIndex(String, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
rebuildSecondaryIndex(String, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
rebuild the specified indexes
receive(IncomingStreamMessage) - Method in class org.apache.cassandra.streaming.StreamSession
Call back after receiving a stream.
received(IncomingStream) - Method in class org.apache.cassandra.db.streaming.CassandraStreamReceiver
 
received - Variable in exception org.apache.cassandra.exceptions.CasWriteUnknownResultException
 
received - Variable in exception org.apache.cassandra.exceptions.RequestFailureException
 
received - Variable in exception org.apache.cassandra.exceptions.RequestTimeoutException
 
received - Variable in class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
 
received(IncomingStream) - Method in interface org.apache.cassandra.streaming.StreamReceiver
Called after we've finished receiving stream data.
received(IncomingStream) - Method in class org.apache.cassandra.streaming.StreamReceiveTask
Process received stream.
received(TableId, int) - Method in class org.apache.cassandra.streaming.StreamSession
 
receivedBytes - Variable in class org.apache.cassandra.net.AbstractMessageHandler
 
receivedBytes() - Method in class org.apache.cassandra.net.InboundMessageHandlers
 
receivedCount - Variable in class org.apache.cassandra.net.AbstractMessageHandler
 
receivedCount() - Method in class org.apache.cassandra.net.InboundMessageHandlers
 
ReceivedMessage - Class in org.apache.cassandra.streaming.messages
 
ReceivedMessage(TableId, int) - Constructor for class org.apache.cassandra.streaming.messages.ReceivedMessage
 
receiver - Variable in class org.apache.cassandra.cql3.AbstractMarker
 
receivers(TableMetadata) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
receiveTiming(InetAddressAndPort, long, TimeUnit) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
receiveTiming(InetAddressAndPort, long, TimeUnit) - Method in interface org.apache.cassandra.net.LatencySubscribers.Subscriber
 
receivingSummaries - Variable in class org.apache.cassandra.streaming.SessionInfo
Immutable collection of receiving summaries
receivingSummaries - Variable in class org.apache.cassandra.streaming.SessionSummary
Immutable collection of receiving summaries
recentBloomFilterFalsePositives - Variable in class org.apache.cassandra.metrics.TableMetrics
Number of false positives in bloom filter from last read
recentBloomFilterFalseRatio - Variable in class org.apache.cassandra.metrics.TableMetrics
False positive ratio of bloom filter from last read
recentClientStats() - Method in class org.apache.cassandra.transport.Server
 
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.SimpleStrategy
 
RECOMMENDED_DEPTH - Static variable in class org.apache.cassandra.utils.MerkleTree
 
recommendedUses() - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
recommendedUses() - Method in interface org.apache.cassandra.io.compress.ICompressor
Hints to Cassandra which uses this compressor is recommended for.
recommendedUses() - Method in class org.apache.cassandra.io.compress.LZ4Compressor
 
recommendedUses() - Method in class org.apache.cassandra.io.compress.ZstdCompressor
 
recomputeNext() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator
 
reconcile(Cell<?>, Cell<?>, DeletionTime, Row.Builder) - Static method in class org.apache.cassandra.db.rows.Cells
Reconciles/merges two cells, one being an update to an existing cell, yielding index updates if appropriate.
reconcile(Cell<?>, Cell<?>) - Static method in class org.apache.cassandra.db.rows.Cells
Reconciles/merge two cells.
reconcileComplex(ColumnMetadata, Iterator<Cell<?>>, Iterator<Cell<?>>, DeletionTime, Row.Builder) - Static method in class org.apache.cassandra.db.rows.Cells
Computes the reconciliation of a complex column given its pre-existing cells and the ones it is updated with, and generating index update if appropriate.
reconcileRead - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
 
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(ColumnMetadata, long) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
recordDeprecatedSystemColumn(String, AbstractType<?>) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
Records a deprecated column for a system table.
recordDigest(InetAddressAndPort, ByteBuffer, boolean) - Method in class org.apache.cassandra.service.reads.repair.RepairedDataTracker
 
recordDroppedMessage(Message<?>, long, TimeUnit) - Method in class org.apache.cassandra.metrics.MessagingMetrics
 
recordDroppedMessage(Verb, long, TimeUnit, boolean) - Method in class org.apache.cassandra.metrics.MessagingMetrics
 
recordEviction() - Method in class org.apache.cassandra.metrics.ChunkCacheMetrics
 
recordHits(int) - Method in class org.apache.cassandra.metrics.ChunkCacheMetrics
 
recordInternalLatency(Verb, long, TimeUnit) - Method in class org.apache.cassandra.metrics.MessagingMetrics
 
recordInternalLatency(Verb, long, TimeUnit) - Method in interface org.apache.cassandra.net.InboundMessageHandlers.GlobalMetricCallbacks
 
recordInternodeDroppedMessage(Verb, long, TimeUnit) - Method in class org.apache.cassandra.metrics.MessagingMetrics
 
recordInternodeDroppedMessage(Verb, long, TimeUnit) - Method in interface org.apache.cassandra.net.InboundMessageHandlers.GlobalMetricCallbacks
 
recordLast(DecoratedKey, Row) - Method in class org.apache.cassandra.service.pager.PartitionRangeQueryPager
 
recordLast(DecoratedKey, Row) - Method in class org.apache.cassandra.service.pager.SinglePartitionPager
 
recordLatency(TableMetrics, long) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
recordLatency(TableMetrics, long) - Method in class org.apache.cassandra.db.ReadCommand
 
recordLatency(TableMetrics, long) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
recordLoadFailure(long) - Method in class org.apache.cassandra.metrics.ChunkCacheMetrics
 
recordLoadSuccess(long) - Method in class org.apache.cassandra.metrics.ChunkCacheMetrics
 
recordMessage(InetAddressAndPort, StreamMessage.Type) - Method in interface org.apache.cassandra.streaming.StreamSession.MessageStateSink
 
recordMisses(int) - Method in class org.apache.cassandra.metrics.ChunkCacheMetrics
 
recordRepairStatus(int, ActiveRepairService.ParentRepairStatus, List<String>) - Method in class org.apache.cassandra.service.ActiveRepairService
 
recordSelfDroppedMessage(Verb) - Method in class org.apache.cassandra.metrics.MessagingMetrics
 
recordSelfDroppedMessage(Verb, long, TimeUnit) - Method in class org.apache.cassandra.metrics.MessagingMetrics
 
recordState(InetAddressAndPort, StreamSession.State) - Method in interface org.apache.cassandra.streaming.StreamSession.MessageStateSink
 
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.
recoverFiles(File...) - Method in class org.apache.cassandra.db.commitlog.CommitLog
Perform recovery on a list of commit log files.
recoverPath(String) - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
recoverSegmentsOnDisk() - Method in class org.apache.cassandra.db.commitlog.CommitLog
Perform recovery on commit logs located in the directory specified by the config file.
reCreateStatements(TableMetadata, boolean, boolean, boolean, boolean) - Static method in class org.apache.cassandra.db.SchemaCQLHelper
 
reCreateStatementsForSchemaCql(TableMetadata, Types) - Static method in class org.apache.cassandra.db.SchemaCQLHelper
Generates the DDL statement for a schema.cql snapshot file.
recursive - Variable in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
recycle(BufferPool.Chunk) - Method in class org.apache.cassandra.utils.memory.BufferPool.LocalPool
 
recyclePartially(BufferPool.Chunk) - Method in class org.apache.cassandra.utils.memory.BufferPool.LocalPool
 
recycleWhenFree(boolean) - Method in class org.apache.cassandra.utils.memory.BufferPool.LocalPool
 
redistributeSummaries() - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
 
redistributeSummaries(IndexSummaryRedistribution) - Static method in class org.apache.cassandra.io.sstable.IndexSummaryManager
Attempts to fairly distribute a fixed pool of memory for index summaries across a set of SSTables based on their recent read rates.
redistributeSummaries() - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
 
redistributeSummaries() - Method in class org.apache.cassandra.io.sstable.IndexSummaryRedistribution
 
reduce(DifferenceHolder, PreferedNodeFilter) - Static method in class org.apache.cassandra.repair.asymmetric.ReduceHelper
Reduces the differences provided by the merkle trees to a minimum set of differences
reduce(int, In) - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
combine this object with the previous ones.
ReduceHelper - Class in org.apache.cassandra.repair.asymmetric
Basic idea is that we track incoming ranges instead of blindly just exchanging the ranges that mismatch between two nodes Say node X has tracked that it will stream range r1 from node Y.
ReduceHelper() - Constructor for class org.apache.cassandra.repair.asymmetric.ReduceHelper
 
reducer - Variable in class org.apache.cassandra.utils.MergeIterator
 
Reducer() - Constructor for class org.apache.cassandra.utils.MergeIterator.Reducer
 
reduceScopeForLimitedSpace(Set<SSTableReader>, long) - Method in class org.apache.cassandra.db.compaction.CompactionTask
 
ReducingKeyIterator - Class in org.apache.cassandra.io.sstable
Caller must acquire and release references to the sstables used here.
ReducingKeyIterator(Collection<SSTableReader>) - Constructor for class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
ref() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
Ref<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
 
Ref.IdentityCollection - Class in org.apache.cassandra.utils.concurrent
 
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
 
reference() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
 
referencesDuration() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
referencesDuration() - Method in class org.apache.cassandra.db.marshal.DurationType
 
referencesDuration() - Method in class org.apache.cassandra.db.marshal.ListType
 
referencesDuration() - Method in class org.apache.cassandra.db.marshal.MapType
 
referencesDuration() - Method in class org.apache.cassandra.db.marshal.TupleType
 
referencesDuration() - Method in class org.apache.cassandra.db.marshal.UserType
 
referencesUserType(String) - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
referencesUserType(ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
referencesUserType(ByteBuffer) - Method in interface org.apache.cassandra.cql3.functions.Function
 
referencesUserType(ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
referencesUserType(ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
referencesUserType(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
referencesUserType(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
referencesUserType(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
referencesUserType(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
referencesUserType(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.ListType
 
referencesUserType(T, ValueAccessor<T>) - Method in class org.apache.cassandra.db.marshal.MapType
 
referencesUserType(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
referencesUserType(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.SetType
 
referencesUserType(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.TupleType
 
referencesUserType(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.UserType
 
referencesUserType(ByteBuffer) - Method in class org.apache.cassandra.schema.ViewMetadata
 
referencingUserType(ByteBuffer) - Method in class org.apache.cassandra.schema.Functions
 
referencingUserType(ByteBuffer) - Method in class org.apache.cassandra.schema.Tables
 
referencingUserType(ByteBuffer) - Method in class org.apache.cassandra.schema.Types
 
Refresh - Class in org.apache.cassandra.tools.nodetool
 
Refresh() - Constructor for class org.apache.cassandra.tools.nodetool.Refresh
 
refresh(ApproximateTime.Measurement) - Static method in class org.apache.cassandra.utils.ApproximateTime
Request an immediate refresh; this shouldn't generally be invoked, except perhaps by tests
refreshNow() - Method in class org.apache.cassandra.utils.MonotonicClock.SampledClock
 
refreshSizeEstimates() - Method in class org.apache.cassandra.service.StorageService
 
refreshSizeEstimates() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Forces refresh of values stored in system.size_estimates of all column families.
refreshSizeEstimates() - Method in class org.apache.cassandra.tools.NodeProbe
 
RefreshSizeEstimates - Class in org.apache.cassandra.tools.nodetool
 
RefreshSizeEstimates() - Constructor for class org.apache.cassandra.tools.nodetool.RefreshSizeEstimates
 
refs - Variable in class org.apache.cassandra.db.ColumnFamilyStore.RefViewFragment
 
Refs<T extends RefCounted<T>> - Class in org.apache.cassandra.utils.concurrent
A collection of managed Ref references to RefCounted objects, and the objects they are referencing.
Refs() - Constructor for class org.apache.cassandra.utils.concurrent.Refs
 
Refs(Map<T, Ref<T>>) - Constructor for class org.apache.cassandra.utils.concurrent.Refs
 
RefViewFragment(List<SSTableReader>, Iterable<Memtable>, Refs<SSTableReader>) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.RefViewFragment
 
Region(long, ByteBuffer) - Constructor for class org.apache.cassandra.io.util.MmappedRegions.Region
 
regions - Variable in class org.apache.cassandra.io.util.CompressedChunkReader.Mmap
 
register(TypeCodec<?>) - Method in class org.apache.cassandra.cql3.functions.types.CodecRegistry
Register the given codec with this registry.
register(TypeCodec<?>...) - Method in class org.apache.cassandra.cql3.functions.types.CodecRegistry
Register the given codecs with this registry.
register(Iterable<? extends TypeCodec<?>>) - Method in class org.apache.cassandra.cql3.functions.types.CodecRegistry
Register the given codecs with this registry.
register(Class<? extends RowFilter.UserExpression>, RowFilter.UserExpression.Deserializer) - Static method in class org.apache.cassandra.db.filter.RowFilter.UserExpression
 
register(VirtualKeyspace) - Method in class org.apache.cassandra.db.virtual.VirtualKeyspaceRegistry
 
register(IEndpointStateChangeSubscriber) - Method in class org.apache.cassandra.gms.Gossiper
Register for interesting state changes.
register(IndexRegistry) - Method in interface org.apache.cassandra.index.Index
An index must be registered in order to be able to either subscribe to update events on the base table and/or to provide Searcher functionality for reads.
register(IndexRegistry) - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
register(IndexRegistry) - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
register(CassandraMetricsRegistry.MetricName, T) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
register(CassandraMetricsRegistry.MetricName, CassandraMetricsRegistry.MetricName, T) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
register(CassandraMetricsRegistry.MetricName, T, CassandraMetricsRegistry.MetricName...) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
register() - Method in class org.apache.cassandra.metrics.ThreadPoolMetrics
 
register() - Static method in class org.apache.cassandra.service.GCInspector
 
register(INotificationConsumer) - Method in class org.apache.cassandra.service.SSTablesGlobalTracker
Register a new subscriber to this tracker.
register(IEndpointLifecycleSubscriber) - Method in class org.apache.cassandra.service.StorageService
 
register(Event.Type, Channel) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
 
register() - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
Register to be signalled once allPriorOpsAreFinished() or allPriorOpsAreFinishedOrSafe() may return true
register() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
The calling thread MUST be the thread that uses the signal
register(Timer.Context) - Method in class org.apache.cassandra.utils.concurrent.WaitQueue
The calling thread MUST be the thread that uses the signal.
register3xAlias() - Method in class org.apache.cassandra.metrics.BufferPoolMetrics
used to register alias for 3.0/3.11 compatibility
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.
registerFollower(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamManager
 
registerIndex(Index) - Method in interface org.apache.cassandra.index.IndexRegistry
 
registerIndex(Index) - Method in class org.apache.cassandra.index.SecondaryIndexManager
 
registerInitiator(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamManager
 
registerListener(AuthEvents.Listener) - Method in class org.apache.cassandra.auth.AuthEvents
 
registerListener(QueryEvents.Listener) - Method in class org.apache.cassandra.cql3.QueryEvents
 
registerListener(LocalSessions.Listener) - Static method in class org.apache.cassandra.repair.consistent.LocalSessions
 
registerListener(SchemaChangeListener) - Method in class org.apache.cassandra.schema.Schema
 
registerMBean() - Method in class org.apache.cassandra.hints.HintsService
 
registerMBean(Metric, ObjectName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
registerMBean(Object, ObjectName, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.NoOpMBeanWrapper
 
registerMBean(Object, String, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.NoOpMBeanWrapper
 
registerMBean(Object, ObjectName, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.PlatformMBeanWrapper
 
registerMBean(Object, ObjectName, MBeanWrapper.OnException) - Method in interface org.apache.cassandra.utils.MBeanWrapper
 
registerMBean(Object, ObjectName) - Method in interface org.apache.cassandra.utils.MBeanWrapper
 
registerMBean(Object, String, MBeanWrapper.OnException) - Method in interface org.apache.cassandra.utils.MBeanWrapper
 
registerMBean(Object, String) - Method in interface org.apache.cassandra.utils.MBeanWrapper
 
RegisterMessage - Class in org.apache.cassandra.transport.messages
 
RegisterMessage(List<Event.Type>) - Constructor for class org.apache.cassandra.transport.messages.RegisterMessage
 
registerNativeAccess() - Static method in class org.apache.cassandra.service.CassandraDaemon
 
registerParentRepairSession(UUID, InetAddressAndPort, List<ColumnFamilyStore>, Collection<Range<Token>>, boolean, long, boolean, PreviewKind) - Method in class org.apache.cassandra.service.ActiveRepairService
 
registerSession(UUID, Set<InetAddressAndPort>, boolean) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSessions
 
regular(DeletionTime) - Static method in class org.apache.cassandra.db.rows.Row.Deletion
 
REGULAR_COLUMN_INDEX_FUNCTIONS - Static variable in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
 
RegularAndStaticColumns - Class in org.apache.cassandra.db
Columns (or a subset of the columns) that a partition contains.
RegularAndStaticColumns(Columns, Columns) - Constructor for class org.apache.cassandra.db.RegularAndStaticColumns
 
regularAndStaticColumns - Variable in class org.apache.cassandra.schema.TableMetadata
 
regularAndStaticColumns() - Method in class org.apache.cassandra.schema.TableMetadata
 
RegularAndStaticColumns.Builder - Class in org.apache.cassandra.db
 
regularColumn(TableMetadata, ByteBuffer, AbstractType<?>) - Static method in class org.apache.cassandra.schema.ColumnMetadata
 
regularColumn(String, String, String, AbstractType<?>) - Static method in class org.apache.cassandra.schema.ColumnMetadata
 
RegularColumnIndex - Class in org.apache.cassandra.index.internal.composites
Index on a REGULAR column definition on a composite type.
RegularColumnIndex(ColumnFamilyStore, IndexMetadata) - Constructor for class org.apache.cassandra.index.internal.composites.RegularColumnIndex
 
regularColumns() - Method in class org.apache.cassandra.schema.TableMetadata
 
regularOperations() - Method in class org.apache.cassandra.cql3.Operations
Returns the operation on regular columns.
regulars - Variable in class org.apache.cassandra.db.RegularAndStaticColumns
 
regularStatementsExecuted - Variable in class org.apache.cassandra.metrics.CQLMetrics
 
REINSERT_OVERFLOWED_TTL_OPTION_DESCRIPTION - Static variable in class org.apache.cassandra.tools.StandaloneScrubber
 
reject_repair_compaction_threshold - Variable in class org.apache.cassandra.config.Config
 
rejectedExecutionHandler - Static variable in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
 
relaseAllExcept(Collection<T>) - Method in class org.apache.cassandra.utils.concurrent.Refs
 
Relation - Class in org.apache.cassandra.cql3
 
Relation() - Constructor for class org.apache.cassandra.cql3.Relation
 
relations - Variable in class org.apache.cassandra.cql3.WhereClause
 
relationType - Variable in class org.apache.cassandra.cql3.Relation
 
relativeFilenameFor(Component) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
release() - Method in class org.apache.cassandra.audit.BinAuditLogger.Message
 
release() - Method in class org.apache.cassandra.db.ColumnFamilyStore.RefViewFragment
 
release() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
 
release() - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
Release large memory objects while keeping metrics intact
release() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
 
release() - Method in class org.apache.cassandra.io.util.LimitingRebufferer
 
release() - Method in class org.apache.cassandra.io.util.MmappedRegions.Region
 
release() - Method in interface org.apache.cassandra.io.util.Rebufferer.BufferHolder
To be called when this buffer is no longer in use.
release() - Method in class org.apache.cassandra.metrics.CASClientRequestMetrics
 
release() - Method in class org.apache.cassandra.metrics.CASClientWriteRequestMetrics
 
release() - Method in class org.apache.cassandra.metrics.ClientRequestMetrics
 
release() - Method in class org.apache.cassandra.metrics.ClientWriteRequestMetrics
 
release() - Method in class org.apache.cassandra.metrics.InternodeInboundMetrics
 
release() - Method in class org.apache.cassandra.metrics.InternodeOutboundMetrics
 
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 interface org.apache.cassandra.metrics.TableMetrics.ReleasableMetric
 
release() - Method in class org.apache.cassandra.metrics.TableMetrics
Release all associated metrics.
release() - Method in class org.apache.cassandra.metrics.ThreadPoolMetrics
 
release() - Method in class org.apache.cassandra.metrics.ViewWriteMetrics
 
release() - Method in class org.apache.cassandra.net.FrameEncoder.Payload
 
release(long) - Method in class org.apache.cassandra.net.ResourceLimits.Basic
 
release(long) - Method in class org.apache.cassandra.net.ResourceLimits.Concurrent
 
release(long) - Method in class org.apache.cassandra.net.ResourceLimits.EndpointAndGlobal
 
release(long) - Method in interface org.apache.cassandra.net.ResourceLimits.Limit
 
release() - Method in class org.apache.cassandra.net.ShareableBytes
 
release() - Method in class org.apache.cassandra.net.SharedDefaultFileRegion.SharedFileChannel
 
release() - Method in class org.apache.cassandra.transport.Envelope
 
release() - Method in class org.apache.cassandra.utils.binlog.BinLog.ReleaseableWriteMarshallable
 
release() - Method in class org.apache.cassandra.utils.concurrent.Ref
Must be called exactly once, when the logical operation for which this Ref was created has terminated.
release() - Method in class org.apache.cassandra.utils.concurrent.Refs
Release ALL of the references held by this Refs collection
release(T) - Method in class org.apache.cassandra.utils.concurrent.Refs
 
release(Collection<T>) - Method in class org.apache.cassandra.utils.concurrent.Refs
Release a retained Ref to all of the provided objects; if any is not held, an exception will be thrown
release(Iterable<? extends Ref<?>>) - Static method in class org.apache.cassandra.utils.concurrent.Refs
 
release(Iterable<? extends Ref<?>>, Throwable) - Static method in class org.apache.cassandra.utils.concurrent.Refs
 
release() - Method in class org.apache.cassandra.utils.memory.BufferPool.LocalPool
 
release() - Method in class org.apache.cassandra.utils.MerkleTree
 
release() - Method in class org.apache.cassandra.utils.MerkleTrees
Dereference all merkle trees and release direct memory for all off-heap trees.
ReleaseableWriteMarshallable() - Constructor for class org.apache.cassandra.utils.binlog.BinLog.ReleaseableWriteMarshallable
 
releaseAll() - Method in class org.apache.cassandra.transport.SimpleClient.SimpleFlusher
 
releaseBuffer(ByteBuffer) - Method in class org.apache.cassandra.io.util.SimpleCachedBufferPool
 
releaseBuffers() - Method in class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
 
releaseBuffers() - Method in class org.apache.cassandra.utils.streamhist.StreamingTombstoneHistogramBuilder
Release inner spool buffers.
releaseBuffersAndCapacity() - Method in class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
 
releaseCapacity(int) - Method in class org.apache.cassandra.net.AbstractMessageHandler
 
releaseIfHolds(T) - Method in class org.apache.cassandra.utils.concurrent.Refs
Release the retained Ref to the provided object, if held, return false otherwise
releaseIndexes(Operation) - Method in class org.apache.cassandra.index.sasi.plan.QueryController
 
releaseIntervalLock() - Method in class org.apache.cassandra.utils.concurrent.IntervalLock
Release the last acquired interval lock.
releaseMetadataOverhead() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
releaseProcessedCapacity(int, Message.Header) - Method in class org.apache.cassandra.net.AbstractMessageHandler
Invoked to release capacity for a message that has been fully, successfully processed.
releaseReference() - Method in class org.apache.cassandra.tracing.TraceState
 
releaseRepairData(Collection<UUID>, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
promotes (or demotes) data attached to an incremental repair session that has either completed successfully, or failed
releaseRepairData(Collection<UUID>) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
releaseSpace(long) - Method in class org.apache.cassandra.net.AsyncChannelOutputPlus
Update our flushed count, and signal any waiters.
releaseSummary() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
releaseVersion() - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
releaseVersion(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
reload() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
reload(boolean) - Method in class org.apache.cassandra.db.view.ViewManager
 
reload() - Method in class org.apache.cassandra.index.SecondaryIndexManager
Drops and adds new indexes associated with the underlying CF
reloadClasses() - Method in class org.apache.cassandra.triggers.TriggerExecutor
Reload the triggers which is already loaded, Invoking this will update the class loader so new jars can be loaded.
reloadConfiguration(boolean) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
 
reloadLocalSchema() - Method in class org.apache.cassandra.service.StorageService
 
reloadLocalSchema() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
reloadLocalSchema() - Method in class org.apache.cassandra.tools.NodeProbe
 
ReloadLocalSchema - Class in org.apache.cassandra.tools.nodetool
 
ReloadLocalSchema() - Constructor for class org.apache.cassandra.tools.nodetool.ReloadLocalSchema
 
reloadSchemaAndAnnounceVersion() - Method in class org.apache.cassandra.schema.Schema
 
reloadSeeds() - Method in class org.apache.cassandra.gms.Gossiper
JMX interface for triggering an update of the seed node list.
reloadSeeds() - Method in interface org.apache.cassandra.gms.GossiperMBean
 
reloadSeeds() - Method in class org.apache.cassandra.tools.NodeProbe
 
ReloadSeeds - Class in org.apache.cassandra.tools.nodetool
 
ReloadSeeds() - Constructor for class org.apache.cassandra.tools.nodetool.ReloadSeeds
 
reloadSslCertificates() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
 
reloadSslCertificates() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
ReloadSslCertificates - Class in org.apache.cassandra.tools
 
ReloadSslCertificates() - Constructor for class org.apache.cassandra.tools.ReloadSslCertificates
 
reloadSslCerts() - Method in class org.apache.cassandra.tools.NodeProbe
 
reloadSSTableMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Reloads the sstable metadata from disk.
reloadTriggerClasses() - Method in class org.apache.cassandra.service.StorageProxy
 
reloadTriggerClasses() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
reloadTriggers() - Method in class org.apache.cassandra.tools.NodeProbe
 
ReloadTriggers - Class in org.apache.cassandra.tools.nodetool
 
ReloadTriggers() - Constructor for class org.apache.cassandra.tools.nodetool.ReloadTriggers
 
relocateSSTables(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
relocateSSTables(ColumnFamilyStore, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
relocateSSTables(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
relocateSSTables(int, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
relocateSSTables(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
relocateSSTables(int, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
relocateSSTables(int, String, String[]) - Method in class org.apache.cassandra.tools.NodeProbe
 
RelocateSSTables - Class in org.apache.cassandra.tools.nodetool
 
RelocateSSTables() - Constructor for class org.apache.cassandra.tools.nodetool.RelocateSSTables
 
remaining() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
 
remaining() - Method in class org.apache.cassandra.net.FrameEncoder.Payload
 
remaining() - Method in class org.apache.cassandra.net.ResourceLimits.Basic
 
remaining() - Method in class org.apache.cassandra.net.ResourceLimits.Concurrent
 
remaining() - Method in interface org.apache.cassandra.net.ResourceLimits.Limit
 
remaining() - Method in class org.apache.cassandra.net.ShareableBytes
 
remaining - Variable in class org.apache.cassandra.service.pager.PagingState
 
remainingCapacity() - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
remainingCount() - Method in class org.apache.cassandra.db.CBuilder
 
remainingCount() - Method in class org.apache.cassandra.db.MultiCBuilder
Returns the number of elements that can be added to the clusterings.
remainingInPartition - Variable in class org.apache.cassandra.service.pager.PagingState
 
remote - Variable in class org.apache.cassandra.dht.RangeStreamer.FetchReplica
 
remoteAddress() - Method in class org.apache.cassandra.transport.ConnectedClient
 
REMOVAL_COORDINATOR - Static variable in class org.apache.cassandra.gms.VersionedValue
 
removalCoordinator(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
remove(UUID) - Static method in class org.apache.cassandra.batchlog.BatchlogManager
 
remove(K) - Method in class org.apache.cassandra.cache.CaffeineCache
 
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(String) - Method in class org.apache.cassandra.config.TransparentDataEncryptionOptions
 
remove() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
remove() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
 
remove(SSTableReader) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
 
remove() - Method in class org.apache.cassandra.db.partitions.AbstractUnfilteredPartitionIterator
 
remove() - Method in class org.apache.cassandra.db.partitions.SingletonUnfilteredPartitionIterator
 
remove(InetAddressAndPort) - Method in class org.apache.cassandra.gms.FailureDetector
 
remove(InetAddressAndPort) - Method in interface org.apache.cassandra.gms.IFailureDetector
remove endpoint from failure detector
remove() - Method in class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
 
remove() - Method in class org.apache.cassandra.index.sasi.utils.AbstractIterator
 
remove() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
remove() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
remove(Object) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaMap
 
remove(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
remove(CassandraMetricsRegistry.MetricName, CassandraMetricsRegistry.MetricName...) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
remove(Predicate<Message<?>>) - Method in class org.apache.cassandra.net.InboundSink
 
remove(BiPredicate<Message<?>, InetAddressAndPort>) - Method in class org.apache.cassandra.net.OutboundSink
 
remove(Object) - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
 
remove(String) - Method in class org.apache.cassandra.schema.Views.Builder
 
remove() - Method in class org.apache.cassandra.utils.AbstractIterator
 
remove(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
 
remove(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTreeRemoval
Remove |elem| from |btree|.
remove(Object) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
remove(int) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
remove() - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
remove(Object) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
remove(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
remove(DynamicList.Node<E>) - Method in class org.apache.cassandra.utils.DynamicList
 
remove(DynamicList.Node<E>) - Method in class org.apache.cassandra.utils.LockedDynamicList
 
removeAll(Collection<?>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
removeAll(Collection<?>) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
removeAndIgnoreEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.schema.MigrationCoordinator
 
removeAndRespond(long, InetAddressAndPort, Message) - Method in class org.apache.cassandra.net.RequestCallbacks
 
removeBootstrapTokens(Collection<Token>) - Method in class org.apache.cassandra.locator.TokenMetadata
 
removeByName(String) - Method in class org.apache.cassandra.db.view.TableViews
 
removed - Variable in class org.apache.cassandra.notifications.SSTableListChangedNotification
 
REMOVED_TOKEN - Static variable in class org.apache.cassandra.gms.VersionedValue
 
removedNode(InetAddressAndPort) - Static method in class org.apache.cassandra.transport.Event.TopologyChange
 
removedNonlocal(UUID, long) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
removeEndpoint(InetAddressAndPort) - Static method in class org.apache.cassandra.db.SystemKeyspace
Remove stored tokens being used by another node
removeEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
Removes the endpoint from Gossip but retains endpoint state
removeEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
 
removeFromMoving(InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
Remove pair of token/address from moving endpoints
removeInbound(InetAddressAndPort) - Method in class org.apache.cassandra.net.MessagingService
Only to be invoked once we believe the connections will never be used again.
removeIndex(String) - Method in class org.apache.cassandra.index.SecondaryIndexManager
 
removeIntersecting(Range<Token>) - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
 
removeKeyspaceInstance(String) - Method in class org.apache.cassandra.schema.Schema
Remove keyspace from schema
removeListener(GenericFutureListener<? extends Future<? super Void>>) - Method in class org.apache.cassandra.net.AsyncChannelPromise
 
removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in class org.apache.cassandra.net.AsyncPromise
 
removeListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in class org.apache.cassandra.net.AsyncChannelPromise
 
removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class org.apache.cassandra.net.AsyncPromise
 
removeNode(String) - Method in class org.apache.cassandra.service.StorageService
Remove a node that has died, attempting to restore the replica count.
removeNode(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
removeToken removes token (and all data associated with enpoint that had it) from the ring
removeNode(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
RemoveNode - Class in org.apache.cassandra.tools.nodetool
 
RemoveNode() - Constructor for class org.apache.cassandra.tools.nodetool.RemoveNode
 
removeNotificationListener(NotificationListener) - Method in class org.apache.cassandra.streaming.StreamManager
 
removeNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class org.apache.cassandra.streaming.StreamManager
 
removeParentRepairSession(UUID) - Method in class org.apache.cassandra.service.ActiveRepairService
called when the repair session is done - either failed or anticompaction has completed clears out any snapshots created by this repair
removePostShutdownHook(Runnable) - Method in class org.apache.cassandra.service.StorageService
Remove a postshutdownhook
removePreparedStatement(MD5Digest) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
removePreShutdownHook(Runnable) - Method in class org.apache.cassandra.service.StorageService
Remove a preshutdown hook
removeProgressListener(ProgressListener) - Method in class org.apache.cassandra.repair.RepairRunnable
 
removeProgressListener(ProgressListener) - Method in class org.apache.cassandra.tracing.TraceState
 
removeProgressListener(ProgressListener) - Method in interface org.apache.cassandra.utils.progress.ProgressEventNotifier
Remove progress listener from this publisher.
removeProgressListener(ProgressListener) - Method in class org.apache.cassandra.utils.progress.ProgressEventNotifierSupport
 
removeRegularOrStaticColumn(ColumnIdentifier) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
removeRow(Row) - Method in interface org.apache.cassandra.index.Index.Indexer
Notification that a row was removed from the partition.
removeShadowedCells(Row, Row, DeletionTime) - Static method in class org.apache.cassandra.db.rows.Rows
Returns a row that is obtained from the given existing row by removing everything that is shadowed by data in the update row.
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
Removes sstable from the strategy, implementations must be able to handle the sstable having already been removed.
removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
Deprecated.
 
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.TimeWindowCompactionStrategy
 
removeSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
Removes sstables from the strategy, implementations must be able to handle the sstables having already been removed.
removeSSTables(AbstractStrategyHolder.GroupedSSTableContainer) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
 
removeSSTables(AbstractStrategyHolder.GroupedSSTableContainer) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
removeSSTables(AbstractStrategyHolder.GroupedSSTableContainer) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
removeTemporaryDirectories() - Method in class org.apache.cassandra.db.Directories
 
removeTruncationRecord(TableId) - Static method in class org.apache.cassandra.db.SystemKeyspace
This method is used to remove information about truncation time for specified column family
removeUnfinishedLeftovers(ColumnFamilyStore) - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
removeUnfinishedLeftovers(TableMetadata) - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
removeUnreadableSSTables(File) - Static method in class org.apache.cassandra.db.Keyspace
Removes every SSTable in the directory from the appropriate Tracker's view.
removeUnreadableSSTables(File) - Method in class org.apache.cassandra.db.lifecycle.Tracker
Removes every SSTable in the directory from the Tracker's view.
removeUnsafe(Set<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
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(ColumnIdentifier, ColumnIdentifier) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
 
rename(FieldIdentifier, FieldIdentifier) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTypeStatement.Raw
 
rename(Descriptor, Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
renameIdentifier(ColumnIdentifier, ColumnIdentifier) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
renameIdentifier(ColumnIdentifier, ColumnIdentifier) - Method in class org.apache.cassandra.cql3.Relation
Renames an identifier in this Relation, if applicable.
renameIdentifier(ColumnIdentifier, ColumnIdentifier) - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
renameIdentifier(ColumnIdentifier, ColumnIdentifier) - Method in class org.apache.cassandra.cql3.TokenRelation
 
renameIdentifier(ColumnIdentifier, ColumnIdentifier) - Method in class org.apache.cassandra.cql3.WhereClause
Renames identifiers in all relations
renamePrimaryKeyColumn(ColumnIdentifier, ColumnIdentifier) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
renameWithConfirm(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
renameWithConfirm(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
renameWithOutConfirm(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
renewed - Variable in class org.apache.cassandra.notifications.MemtableRenewedNotification
 
reorderTimestampBytes(long) - Static method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
repair(String, Map<String, String>, List<ProgressListener>) - Method in class org.apache.cassandra.service.StorageService
 
Repair - Class in org.apache.cassandra.tools.nodetool
 
Repair() - Constructor for class org.apache.cassandra.tools.nodetool.Repair
 
repair_command_pool_full_strategy - Variable in class org.apache.cassandra.config.Config
 
repair_command_pool_size - Variable in class org.apache.cassandra.config.Config
 
REPAIR_HISTORY - Static variable in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
repair_session_max_tree_depth - Variable in class org.apache.cassandra.config.Config
Deprecated.
repair_session_space_in_mb - Variable in class org.apache.cassandra.config.Config
 
RepairAdmin - Class in org.apache.cassandra.tools.nodetool
Supports listing and failing incremental repair sessions
RepairAdmin() - Constructor for class org.apache.cassandra.tools.nodetool.RepairAdmin
 
RepairAdmin.CancelCmd - Class in org.apache.cassandra.tools.nodetool
 
RepairAdmin.CleanupDataCmd - Class in org.apache.cassandra.tools.nodetool
 
RepairAdmin.ListCmd - Class in org.apache.cassandra.tools.nodetool
 
RepairAdmin.SummarizePendingCmd - Class in org.apache.cassandra.tools.nodetool
 
RepairAdmin.SummarizeRepairedCmd - Class in org.apache.cassandra.tools.nodetool
 
repairAsync(String, Map<String, String>) - Method in class org.apache.cassandra.service.StorageService
 
repairAsync(String, Map<String, String>) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Invoke repair asynchronously.
repairAsync(PrintStream, String, Map<String, String>) - Method in class org.apache.cassandra.tools.NodeProbe
 
repairCommandExecutor() - Static method in class org.apache.cassandra.service.ActiveRepairService
 
RepairCommandExecutorHandle() - Constructor for class org.apache.cassandra.service.ActiveRepairService.RepairCommandExecutorHandle
 
REPAIRED_DATA_MISMATCH_SNAPSHOT_PREFIX - Static variable in class org.apache.cassandra.utils.DiagnosticSnapshotService
 
repaired_data_tracking_for_partition_reads_enabled - Variable in class org.apache.cassandra.config.Config
 
repaired_data_tracking_for_range_reads_enabled - Variable in class org.apache.cassandra.config.Config
flags for enabling tracking repaired state of data during reads separate flags for range & single partition reads as single partition reads are only tracked when CL > 1 and a digest mismatch occurs.
repairedAt - Variable in class org.apache.cassandra.db.streaming.CassandraStreamReader
 
repairedAt - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
repairedAt - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
repairedAt - Variable in class org.apache.cassandra.repair.consistent.ConsistentSession
 
repairedAt - Variable in class org.apache.cassandra.repair.consistent.RepairedState.Section
 
repairedAt - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
 
repairedAt - Variable in class org.apache.cassandra.streaming.messages.StreamMessageHeader
 
repairedBackground - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
Deprecated.
repairedBlocking - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
 
repairedDataDigest() - Method in class org.apache.cassandra.db.ReadResponse
 
repairedDataMismatch(TableMetadata, Iterable<InetAddressAndPort>) - Static method in class org.apache.cassandra.utils.DiagnosticSnapshotService
 
RepairedDataTracker - Class in org.apache.cassandra.service.reads.repair
 
RepairedDataTracker(RepairedDataVerifier) - Constructor for class org.apache.cassandra.service.reads.repair.RepairedDataTracker
 
repairedDataTrackingOverreadRows - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Tracks the amount overreading of repaired data replicas perform in order to produce digests at query time.
repairedDataTrackingOverreadRows - Variable in class org.apache.cassandra.metrics.TableMetrics
 
repairedDataTrackingOverreadTime - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
 
repairedDataTrackingOverreadTime - Variable in class org.apache.cassandra.metrics.TableMetrics
 
RepairedDataVerifier - Interface in org.apache.cassandra.service.reads.repair
 
RepairedDataVerifier.SimpleVerifier - Class in org.apache.cassandra.service.reads.repair
 
RepairedDataVerifier.SnapshottingVerifier - Class in org.apache.cassandra.service.reads.repair
 
RepairedState - Class in org.apache.cassandra.repair.consistent
Tracks the repaired state of token ranges per table, and is effectively an in memory representation of the on-disk local incremental repair state.
RepairedState() - Constructor for class org.apache.cassandra.repair.consistent.RepairedState
 
RepairedState.Section - Class in org.apache.cassandra.repair.consistent
 
RepairedState.Stats - Class in org.apache.cassandra.repair.consistent
 
RepairException - Exception in org.apache.cassandra.exceptions
Exception thrown during repair
RepairException(RepairJobDesc, String) - Constructor for exception org.apache.cassandra.exceptions.RepairException
 
RepairException(RepairJobDesc, PreviewKind, String) - Constructor for exception org.apache.cassandra.exceptions.RepairException
 
repairExceptions - Static variable in class org.apache.cassandra.metrics.StorageMetrics
 
RepairJob - Class in org.apache.cassandra.repair
RepairJob runs repair on given ColumnFamily.
RepairJob(RepairSession, String) - 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, Collection<Range<Token>>) - Constructor for class org.apache.cassandra.repair.RepairJobDesc
 
repairJobResults - Variable in class org.apache.cassandra.repair.RepairSessionResult
 
RepairMessage - Class in org.apache.cassandra.repair.messages
Base class of all repair related request/response messages.
RepairMessage(RepairJobDesc) - Constructor for class org.apache.cassandra.repair.messages.RepairMessage
 
RepairMessageVerbHandler - Class in org.apache.cassandra.repair
Handles all repair related message.
RepairMessageVerbHandler() - Constructor for class org.apache.cassandra.repair.RepairMessageVerbHandler
 
RepairMetrics - Class in org.apache.cassandra.metrics
 
RepairMetrics() - Constructor for class org.apache.cassandra.metrics.RepairMetrics
 
RepairOption - Class in org.apache.cassandra.repair.messages
Repair options.
RepairOption(RepairParallelism, boolean, boolean, boolean, int, Collection<Range<Token>>, boolean, boolean, boolean, PreviewKind, boolean, boolean) - Constructor for class org.apache.cassandra.repair.messages.RepairOption
 
RepairParallelism - Enum in org.apache.cassandra.repair
Specify the degree of parallelism when calculating the merkle trees in a repair job.
repairPartition(DecoratedKey, Map<Replica, Mutation>, ReplicaPlan.ForTokenWrite) - Method in class org.apache.cassandra.service.reads.repair.BlockingReadRepair
 
repairPartition(DecoratedKey, Map<Replica, Mutation>, ReplicaPlan.ForTokenWrite) - Method in class org.apache.cassandra.service.reads.repair.NoopReadRepair
 
repairPartition(DecoratedKey, Map<Replica, Mutation>, ReplicaPlan.ForTokenWrite) - Method in class org.apache.cassandra.service.reads.repair.ReadOnlyReadRepair
 
repairPartition(DecoratedKey, Map<Replica, Mutation>, ReplicaPlan.ForTokenWrite) - Method in interface org.apache.cassandra.service.reads.repair.ReadRepair
Repairs a partition _after_ receiving data responses.
repairPrepareTime - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
total time spent preparing for repair
RepairResult - Class in org.apache.cassandra.repair
RepairJob's result
RepairResult(RepairJobDesc, List<SyncStat>) - Constructor for class org.apache.cassandra.repair.RepairResult
 
RepairRunnable - Class in org.apache.cassandra.repair
 
RepairRunnable(StorageService, int, RepairOption, String) - Constructor for class org.apache.cassandra.repair.RepairRunnable
 
RepairRunner - Class in org.apache.cassandra.tools
 
RepairRunner(PrintStream, StorageServiceMBean, String, Map<String, String>) - Constructor for class org.apache.cassandra.tools.RepairRunner
 
REPAIRS - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
repairs - Variable in class org.apache.cassandra.service.reads.repair.BlockingReadRepair
 
repairsCompleted - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Number of completed repairs as coordinator on this keyspace
repairsCompleted - Variable in class org.apache.cassandra.metrics.TableMetrics
Number of completed repairs as coordinator on this table
RepairSession - Class in org.apache.cassandra.repair
Coordinates the (active) repair of a list of non overlapping token ranges.
RepairSession(UUID, UUID, CommonRange, String, RepairParallelism, boolean, boolean, PreviewKind, boolean, String...) - Constructor for class org.apache.cassandra.repair.RepairSession
Create new repair session.
RepairSessionResult - Class in org.apache.cassandra.repair
Repair session result
RepairSessionResult(UUID, String, Collection<Range<Token>>, Collection<RepairResult>, boolean) - Constructor for class org.apache.cassandra.repair.RepairSessionResult
 
repairsStarted - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Number of started repairs as coordinator on this keyspace
repairsStarted - Variable in class org.apache.cassandra.metrics.TableMetrics
Number of started repairs as coordinator on this table
RepairStats - Class in org.apache.cassandra.repair.consistent.admin
 
RepairStats.Section - Class in org.apache.cassandra.repair.consistent.admin
 
repairSyncTime - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
total time spent syncing data after repair
repairSyncTime - Variable in class org.apache.cassandra.metrics.TableMetrics
time spent syncing data in a repair
repairTime - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
total time spent as a repair coordinator
replace(K, V, V) - Method in class org.apache.cassandra.cache.CaffeineCache
 
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
 
replace(File, String...) - Static method in class org.apache.cassandra.io.util.FileUtils
 
replace(IndexMetadata) - Method in class org.apache.cassandra.schema.Indexes
Creates a SecondaryIndexes instance which contains an updated index definition
replacedEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
Remove the Endpoint and evict immediately, to avoid gossiping about this node.
replaceFlushed(Memtable, Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
replaceInSitu(Object[], int, V) - Static method in class org.apache.cassandra.utils.btree.BTree
Modifies the provided btree directly.
replaceInSitu(Object[], Comparator<? super V>, V, V) - Static method in class org.apache.cassandra.utils.btree.BTree
Modifies the provided btree directly.
replaceKiller(JVMStabilityInspector.Killer) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
 
replacementQuarantine(InetAddressAndPort) - 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
Replaces sstables in the compaction strategy Note that implementations must be able to handle duplicate notifications here (that removed are already gone and added have already been added)
replaceSSTables(AbstractStrategyHolder.GroupedSSTableContainer, AbstractStrategyHolder.GroupedSSTableContainer) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
 
replaceSSTables(AbstractStrategyHolder.GroupedSSTableContainer, AbstractStrategyHolder.GroupedSSTableContainer) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
replaceSSTables(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
replaceSSTables(AbstractStrategyHolder.GroupedSSTableContainer, AbstractStrategyHolder.GroupedSSTableContainer) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
replayBatchlog() - Method in class org.apache.cassandra.tools.NodeProbe
 
ReplayBatchlog - Class in org.apache.cassandra.tools.nodetool
 
ReplayBatchlog() - Constructor for class org.apache.cassandra.tools.nodetool.ReplayBatchlog
 
replayFiles(File[]) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
replayPath(File, boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
Replica - Class in org.apache.cassandra.locator
A Replica represents an owning node for a copy of a portion of the token ring.
Replica(InetAddressAndPort, Range<Token>, boolean) - Constructor for class org.apache.cassandra.locator.Replica
 
Replica(InetAddressAndPort, Token, Token, boolean) - Constructor for class org.apache.cassandra.locator.Replica
 
replica_filtering_protection - Variable in class org.apache.cassandra.config.Config
 
ReplicaCollection<C extends ReplicaCollection<C>> - Interface in org.apache.cassandra.locator
A collection like class for Replica objects.
ReplicaCollection.Builder<C extends ReplicaCollection<C>> - Interface in org.apache.cassandra.locator
A mutable (append-only) extension of a ReplicaCollection.
ReplicaCollection.Builder.Conflict - Enum in org.apache.cassandra.locator
Passed to add() and addAll() as ignoreConflicts parameter.
ReplicaCount() - Constructor for class org.apache.cassandra.locator.Replicas.ReplicaCount
 
ReplicaFilteringProtection<E extends Endpoints<E>> - Class in org.apache.cassandra.service.reads
Helper in charge of collecting additional queries to be done on the coordinator to protect against invalid results being included due to replica-side filtering (secondary indexes or ALLOW * FILTERING).
ReplicaFilteringProtectionOptions - Class in org.apache.cassandra.config
 
ReplicaFilteringProtectionOptions() - Constructor for class org.apache.cassandra.config.ReplicaFilteringProtectionOptions
 
replicaFilteringProtectionRequests - Variable in class org.apache.cassandra.metrics.TableMetrics
 
ReplicaLayout<E extends Endpoints<E>> - Class in org.apache.cassandra.locator
The relevant replicas for an operation over a given range or token.
ReplicaLayout.ForRange - Interface in org.apache.cassandra.locator
 
ReplicaLayout.ForRangeRead - Class in org.apache.cassandra.locator
 
ReplicaLayout.ForToken - Interface in org.apache.cassandra.locator
 
ReplicaLayout.ForTokenRead - Class in org.apache.cassandra.locator
 
ReplicaLayout.ForTokenWrite - Class in org.apache.cassandra.locator
 
ReplicaLayout.ForWrite<E extends Endpoints<E>> - Class in org.apache.cassandra.locator
 
ReplicaList() - Constructor for class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
 
ReplicaList(int) - Constructor for class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
 
ReplicaList(Replica[], int, int) - Constructor for class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
 
ReplicaMap(AbstractReplicaCollection.ReplicaList, Function<Replica, K>) - Constructor for class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaMap
 
ReplicaMap(AbstractReplicaCollection.ReplicaList, Function<Replica, K>, ObjectIntHashMap<K>) - Constructor for class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaMap
 
ReplicaMultimap<K,C extends ReplicaCollection<?>> - Class in org.apache.cassandra.locator
 
ReplicaMultimap.Builder<K,B extends ReplicaCollection.Builder<?>> - Class in org.apache.cassandra.locator
 
ReplicaPlan<E extends Endpoints<E>> - Class in org.apache.cassandra.locator
 
replicaPlan - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
replicaPlan() - Method in class org.apache.cassandra.service.reads.ReadCallback
 
replicaPlan - Variable in class org.apache.cassandra.service.reads.repair.AbstractReadRepair
 
replicaPlan() - Method in class org.apache.cassandra.service.reads.repair.AbstractReadRepair
 
replicaPlan - Variable in class org.apache.cassandra.service.reads.ResponseResolver
 
replicaPlan() - Method in class org.apache.cassandra.service.reads.ResponseResolver
 
ReplicaPlan.ForPaxosWrite - Class in org.apache.cassandra.locator
 
ReplicaPlan.ForRangeRead - Class in org.apache.cassandra.locator
 
ReplicaPlan.ForRead<E extends Endpoints<E>> - Class in org.apache.cassandra.locator
 
ReplicaPlan.ForTokenRead - Class in org.apache.cassandra.locator
 
ReplicaPlan.ForTokenWrite - Class in org.apache.cassandra.locator
 
ReplicaPlan.ForWrite<E extends Endpoints<E>> - Class in org.apache.cassandra.locator
 
ReplicaPlan.Shared<E extends Endpoints<E>,P extends ReplicaPlan<E>> - Interface in org.apache.cassandra.locator
Used by AbstractReadExecutor, {Data,Digest}Resolver and ReadRepair to share a ReplicaPlan whose 'contacts' replicas we progressively modify via various forms of speculation (initial speculation, rr-read and rr-write) The internal reference is not volatile, despite being shared between threads.
ReplicaPlan.SharedForRangeRead - Class in org.apache.cassandra.locator
 
ReplicaPlan.SharedForTokenRead - Class in org.apache.cassandra.locator
 
ReplicaPlans - Class in org.apache.cassandra.locator
 
ReplicaPlans() - Constructor for class org.apache.cassandra.locator.ReplicaPlans
 
ReplicaPlans.Selector - Interface in org.apache.cassandra.locator
 
replicas() - Static method in class org.apache.cassandra.locator.InOurDcTester
 
Replicas - Class in org.apache.cassandra.locator
 
Replicas() - Constructor for class org.apache.cassandra.locator.Replicas
 
Replicas.ReplicaCount - Class in org.apache.cassandra.locator
 
replicasMissingMostRecentCommit(TableMetadata, int) - Method in class org.apache.cassandra.service.paxos.PrepareCallback
 
REPLICATED_SYSTEM_KEYSPACE_NAMES - Static variable in class org.apache.cassandra.schema.SchemaConstants
 
replication - Variable in class org.apache.cassandra.schema.KeyspaceParams
 
REPLICATION_FACTOR - Static variable in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
ReplicationDoneVerbHandler - Class in org.apache.cassandra.streaming
 
ReplicationDoneVerbHandler() - Constructor for class org.apache.cassandra.streaming.ReplicationDoneVerbHandler
 
ReplicationFactor - Class in org.apache.cassandra.locator
 
ReplicationParams - Class in org.apache.cassandra.schema
 
replicationStrategy() - Method in class org.apache.cassandra.locator.ReplicaLayout
 
replicationStrategy - Variable in class org.apache.cassandra.locator.ReplicaPlan
 
replicationStrategy() - Method in class org.apache.cassandra.locator.ReplicaPlan
 
report(InetAddressAndPort) - Method in class org.apache.cassandra.gms.FailureDetector
 
report(InetAddressAndPort) - Method in interface org.apache.cassandra.gms.IFailureDetector
This method is invoked by the receiver of the heartbeat.
report_unconfirmed_repaired_data_mismatches - Variable in class org.apache.cassandra.config.Config
 
reportCompactionTable(List<Map<String, String>>, int, boolean, PrintStream) - Static method in class org.apache.cassandra.tools.nodetool.CompactionStats
 
reportEndpointVersion(InetAddressAndPort, UUID) - Method in class org.apache.cassandra.schema.MigrationCoordinator
 
reportEndpointVersion(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.schema.MigrationCoordinator
 
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
 
reportIncomingStream(TableId, IncomingStream, StreamSession, int) - Method in interface org.apache.cassandra.streaming.StreamHook
 
reportOutgoingStream(StreamSession, OutgoingStream, OutgoingStreamMessage) - Method in interface org.apache.cassandra.streaming.StreamHook
 
reportRead(TableId, DecoratedKey) - Method in interface org.apache.cassandra.db.StorageHook
 
reportStreamFuture(StreamSession, StreamResultFuture) - Method in interface org.apache.cassandra.streaming.StreamHook
 
reportUnconfirmedRepairedDataMismatches() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
reportUnconfirmedRepairedDataMismatches(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
reportWrite(TableId, PartitionUpdate) - Method in interface org.apache.cassandra.db.StorageHook
 
Request(Message.Type) - Constructor for class org.apache.cassandra.transport.Message.Request
 
request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
RequestCallback<T> - Interface in org.apache.cassandra.net
implementors of RequestCallback need to make sure that any public methods are threadsafe with respect to RequestCallback.onResponse(org.apache.cassandra.net.Message<T>) being called from the message service.
RequestCallbacks - Class in org.apache.cassandra.net
An expiring map of request callbacks.
requestClosure() - Method in class org.apache.cassandra.net.AsyncStreamingInputPlus
Mark this stream as closed, but do not release any of the resources.
requestCount() - Method in class org.apache.cassandra.transport.ConnectedClient
 
requestedRows() - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
The set of requested rows.
requestedSlices() - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
 
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.CommitLog
Preempts the CLExecutor, telling to to sync immediately
RequestFailureException - Exception in org.apache.cassandra.exceptions
 
RequestFailureException(ExceptionCode, ConsistencyLevel, int, int, Map<InetAddressAndPort, RequestFailureReason>) - Constructor for exception org.apache.cassandra.exceptions.RequestFailureException
 
RequestFailureReason - Enum in org.apache.cassandra.exceptions
 
RequestFailureReason.Serializer - Class in org.apache.cassandra.exceptions
 
requestNames() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
Return only the column names requested by the user, excluding those added for post-query re-orderings, see definition of names and columnCount.
requestRanges - Variable in class org.apache.cassandra.repair.LocalSyncTask
 
requestRanges(InetAddressAndPort, String, RangesAtEndpoint, RangesAtEndpoint) - Method in class org.apache.cassandra.streaming.StreamPlan
Request data in keyspace and ranges from specific node.
requestRanges(InetAddressAndPort, String, RangesAtEndpoint, RangesAtEndpoint, 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.streaming.messages.PrepareSynMessage
Streaming requests
requests - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
 
requests - Variable in class org.apache.cassandra.streaming.StreamSession
 
REQUESTS - Static variable in class org.apache.cassandra.transport.ConnectedClient
 
requests - Variable in class org.apache.cassandra.transport.ServerConnection
 
RequestTimeoutException - Exception in org.apache.cassandra.exceptions
 
RequestTimeoutException(ExceptionCode, ConsistencyLevel, int, int) - Constructor for exception org.apache.cassandra.exceptions.RequestTimeoutException
 
RequestTimeoutException(ExceptionCode, ConsistencyLevel, int, int, String) - Constructor for exception org.apache.cassandra.exceptions.RequestTimeoutException
 
RequestValidationException - Exception in org.apache.cassandra.exceptions
 
RequestValidationException(ExceptionCode, String) - Constructor for exception org.apache.cassandra.exceptions.RequestValidationException
 
RequestValidationException(ExceptionCode, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.RequestValidationException
 
RequestValidations - Class in org.apache.cassandra.cql3.statements
Utility methods use to perform request validation.
require_client_auth - Variable in class org.apache.cassandra.config.EncryptionOptions
 
require_endpoint_verification - Variable in class org.apache.cassandra.config.EncryptionOptions
 
requireAuthentication() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
requireAuthentication() - Method in interface org.apache.cassandra.auth.IAuthenticator
Whether or not the authenticator requires explicit login.
requireAuthentication() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
requireAuthorization() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
requireAuthorization() - Method in class org.apache.cassandra.auth.AllowAllNetworkAuthorizer
 
requireAuthorization() - Method in interface org.apache.cassandra.auth.IAuthorizer
Whether or not the authorizer will attempt authorization.
requireAuthorization() - Method in interface org.apache.cassandra.auth.INetworkAuthorizer
Whether or not the authorizer will attempt authorization.
required - Variable in exception org.apache.cassandra.exceptions.UnavailableException
 
requiredBeforeFinish - Variable in class org.apache.cassandra.service.BatchlogResponseHandler
 
requiredParticipants() - Method in class org.apache.cassandra.locator.ReplicaPlan.ForPaxosWrite
 
REQUIRES_ALLOW_FILTERING_MESSAGE - Static variable in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
requiresRead() - Method in class org.apache.cassandra.cql3.Lists.Discarder
 
requiresRead() - Method in class org.apache.cassandra.cql3.Lists.DiscarderByIndex
 
requiresRead() - Method in class org.apache.cassandra.cql3.Lists.SetterByIndex
 
requiresRead() - Method in class org.apache.cassandra.cql3.Operation
 
requiresRead() - Method in class org.apache.cassandra.cql3.Operations
Checks if one of the operations requires a read.
requiresRead() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
requiresViewBuild() - Method in enum org.apache.cassandra.streaming.StreamOperation
Wether this operation requires views to be updated
rescheduleFailedDeletions() - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
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.
rescheduleFailedDeletions() - Method in class org.apache.cassandra.service.StorageService
 
rescheduleFailedDeletions() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
rescheduleFailedTasks() - Static method in class org.apache.cassandra.io.sstable.SnapshotDeletingTask
Retry all failed deletions.
RESERVED_POOL_SPACE_IN_MB - Static variable in class org.apache.cassandra.cache.ChunkCache
 
ReservedKeywords - Class in org.apache.cassandra.cql3
 
ReservedKeywords() - Constructor for class org.apache.cassandra.cql3.ReservedKeywords
 
reset() - Method in interface org.apache.cassandra.cql3.functions.AggregateFunction.Aggregate
Reset this aggregate.
reset() - Method in interface org.apache.cassandra.cql3.selection.Selection.Selectors
 
reset() - Method in class org.apache.cassandra.cql3.selection.Selector
Reset the internal state of this Selector.
reset() - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
 
reset() - Method in class org.apache.cassandra.cql3.selection.TermSelector
 
reset() - Method in class org.apache.cassandra.db.ColumnIndex
 
reset() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
reset(Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
(Re)initializes the tracker, purging all references.
reset() - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
 
reset(String) - Method in class org.apache.cassandra.fql.FullQueryLogger
Need the path as a parameter as well because if the process is restarted the config file might be the only location for retrieving the path to the full query log files, but JMX also allows you to specify a path that isn't persisted anywhere so we have to clean that one as well.
reset(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
 
reset(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.analyzer.DelimiterAnalyzer
 
reset(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingAnalyzer
 
reset(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.analyzer.NoOpAnalyzer
 
reset(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
 
reset(InputStream) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
 
reset(long) - Method in interface org.apache.cassandra.io.util.BytesReadTracker
reset counter to @param count
reset(DataPosition) - Method in class org.apache.cassandra.io.util.FileSegmentInputStream
 
reset() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
 
reset() - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
reset(DataPosition) - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
reset(DataPosition) - Method in interface org.apache.cassandra.io.util.RewindableDataInput
 
reset(DataPosition) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
Rewinds to the previously marked position via the RewindableDataInputStreamPlus.mark() method.
reset() - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
reset(long) - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
reset counter to @param count
reset(long) - Method in class org.apache.cassandra.io.util.TrackedInputStream
reset counter to @param count
reset() - Method in class org.apache.cassandra.metrics.CacheMetrics
 
reset(InetAddressAndPort) - Method in class org.apache.cassandra.net.EndpointMessagingVersions
 
reset() - Method in class org.apache.cassandra.schema.MigrationCoordinator
 
reset() - Method in class org.apache.cassandra.utils.DefaultValue
 
reset() - Static method in class org.apache.cassandra.utils.FBUtilities
 
resetAndConsumeDroppedErrors(Consumer<String>) - Method in class org.apache.cassandra.metrics.MessagingMetrics
 
resetAndTruncate(DataPosition) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
resetAndTruncate(int) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
Reset the writer so that the next chunk offset written will be the one of chunkIndex.
resetAndTruncate() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
resetAndTruncate() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
resetAndTruncate(DataPosition) - Method in class org.apache.cassandra.io.util.SequentialWriter
Drops all buffered data that's past the limits of our new file mark + buffer capacity, or syncs and truncates the underlying file to the marked position
resetAvailableRanges() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
resetBuffer() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
resetConfiguration() - Method in class org.apache.cassandra.db.commitlog.CommitLog
FOR TESTING PURPOSES.
resetCrc() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
 
resetDroppedMessages() - Method in class org.apache.cassandra.metrics.MessagingMetrics
 
resetForTests() - Static method in class org.apache.cassandra.db.WindowsFailedSnapshotTracker
 
ResetFullQueryLog - Class in org.apache.cassandra.tools.nodetool
 
ResetFullQueryLog() - Constructor for class org.apache.cassandra.tools.nodetool.ResetFullQueryLog
 
resetFullQueryLogger() - Method in class org.apache.cassandra.service.StorageService
 
resetFullQueryLogger() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Disable the full query logger if it is enabled.
resetFullQueryLogger() - Method in class org.apache.cassandra.tools.NodeProbe
 
resetLimit() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
 
resetLocalSchema() - Static method in class org.apache.cassandra.schema.MigrationManager
Clear all locally stored schema information and reset schema to initial state.
resetLocalSchema() - Method in class org.apache.cassandra.service.StorageService
 
resetLocalSchema() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
resetLocalSchema() - Method in class org.apache.cassandra.tools.NodeProbe
 
ResetLocalSchema - Class in org.apache.cassandra.tools.nodetool
 
ResetLocalSchema() - Constructor for class org.apache.cassandra.tools.nodetool.ResetLocalSchema
 
resetPreparedStatements() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
resetTidying() - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
resetUnsafe(boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLog
FOR TESTING PURPOSES
resetWarnings() - Method in class org.apache.cassandra.service.ClientWarn
 
ResizableThreadPool - Interface in org.apache.cassandra.concurrent
 
resolve() - Method in class org.apache.cassandra.service.reads.DataResolver
 
resolve(V, V) - Method in interface org.apache.cassandra.utils.btree.BTree.Builder.QuickResolver
 
resolve(BTree.Builder.Resolver) - Method in class org.apache.cassandra.utils.btree.BTree.Builder
 
resolve(Object[], int, int) - Method in interface org.apache.cassandra.utils.btree.BTree.Builder.Resolver
 
resolveIp - Variable in class org.apache.cassandra.tools.nodetool.HostStat
 
resolver - Variable in class org.apache.cassandra.service.reads.ReadCallback
 
resource - Variable in class org.apache.cassandra.auth.PermissionDetails
 
resource - Variable in class org.apache.cassandra.auth.Role
Represents a user or group in the auth subsystem.
resource - Variable in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
resource - Variable in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
 
resource - Variable in class org.apache.cassandra.schema.TableMetadata
 
RESOURCE_ROLE_INDEX - Static variable in class org.apache.cassandra.auth.AuthKeyspace
 
ResourceLimits - Class in org.apache.cassandra.net
 
ResourceLimits() - Constructor for class org.apache.cassandra.net.ResourceLimits
 
ResourceLimits.Basic - Class in org.apache.cassandra.net
A cheaper, thread-unsafe permit container to be used for unshared limits.
ResourceLimits.Concurrent - Class in org.apache.cassandra.net
A thread-safe permit container.
ResourceLimits.EndpointAndGlobal - Class in org.apache.cassandra.net
A convenience class that groups a per-endpoint limit with the global one to allow allocating/releasing permits from/to both limits as one logical operation.
ResourceLimits.Limit - Interface in org.apache.cassandra.net
Represents permits to utilise a resource and ways to allocate and release them.
ResourceLimits.Outcome - Enum in org.apache.cassandra.net
 
resourceProvider(ClientResourceLimits.Allocator) - Method in class org.apache.cassandra.transport.PipelineConfigurator
 
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
 
respondTo() - Method in class org.apache.cassandra.net.Message
The originator of the request - used when forwarding and will differ from Message.from()
response(ReadResponse) - Method in class org.apache.cassandra.service.reads.ReadCallback
 
Response(Message.Type) - Constructor for class org.apache.cassandra.transport.Message.Response
 
responseHandler - Variable in class org.apache.cassandra.transport.SimpleClient
 
ResponseResolver<E extends Endpoints<E>,P extends ReplicaPlan.ForRead<E>> - Class in org.apache.cassandra.service.reads
 
ResponseResolver(ReadCommand, ReplicaPlan.Shared<E, P>, long) - Constructor for class org.apache.cassandra.service.reads.ResponseResolver
 
responses - Variable in class org.apache.cassandra.service.reads.ResponseResolver
 
responses - Variable in class org.apache.cassandra.service.TruncateResponseHandler
 
responses - Variable in class org.apache.cassandra.service.WriteResponseHandler
 
responsesMatch() - Method in class org.apache.cassandra.service.reads.DigestResolver
 
responseWith(T) - Method in class org.apache.cassandra.net.Message
Builds a response Message with provided payload, and all the right fields inferred from request Message
restartUnsafe() - Method in class org.apache.cassandra.db.commitlog.CommitLog
FOR TESTING PURPOSES
RestorableMeter - Class in org.apache.cassandra.metrics
A meter metric which measures mean throughput as well as fifteen-minute and two-hour exponentially-weighted moving average throughputs.
RestorableMeter() - Constructor for class org.apache.cassandra.metrics.RestorableMeter
Creates a new, uninitialized RestorableMeter.
RestorableMeter(double, double) - Constructor for class org.apache.cassandra.metrics.RestorableMeter
Restores a RestorableMeter from the last seen 15m and 2h rates.
restorePointInTime - Variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
 
Restriction - Interface in org.apache.cassandra.cql3.restrictions
Implementation of this class must be immutable.
Restrictions - Interface in org.apache.cassandra.cql3.restrictions
Sets of restrictions
restrictsAccess() - Method in class org.apache.cassandra.auth.DCPermissions
Indicates whether the permissions object explicitly allow access to some dcs (true) or if it implicitly allows access to all dcs (false)
result - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskBlock.SearchResult
 
result - Variable in class org.apache.cassandra.service.reads.AbstractReadExecutor
 
result - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Rows
 
resultify(String, RowIterator) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
resultify(String, PartitionIterator) - 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(MD5Digest, List<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
ResultMetadata(List<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
ResultMetadata(List<ColumnSpecification>, PagingState) - Constructor for class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
resultMetadata - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
Describes the results of executing this prepared statement
resultMetadataId - Variable in class org.apache.cassandra.cql3.QueryHandler.Prepared
 
resultMetadataId - Variable in class org.apache.cassandra.transport.messages.ExecuteMessage
 
resultMetadataId - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
 
ResultSet - Class in org.apache.cassandra.cql3
 
ResultSet(ResultSet.ResultMetadata) - Constructor for class org.apache.cassandra.cql3.ResultSet
 
ResultSet(ResultSet.ResultMetadata, List<List<ByteBuffer>>) - Constructor for class org.apache.cassandra.cql3.ResultSet
 
ResultSet.Codec - Class in org.apache.cassandra.cql3
 
ResultSet.Flag - Enum in org.apache.cassandra.cql3
 
ResultSet.PreparedMetadata - Class in org.apache.cassandra.cql3
The metadata for the query parameters in a prepared statement.
ResultSet.ResultMetadata - Class in org.apache.cassandra.cql3
The metadata for the results of executing a query or prepared statement.
ResultSetBuilder - Class in org.apache.cassandra.cql3.selection
 
ResultSetBuilder(ResultSet.ResultMetadata, Selection.Selectors) - Constructor for class org.apache.cassandra.cql3.selection.ResultSetBuilder
 
ResultSetBuilder(ResultSet.ResultMetadata, Selection.Selectors, GroupMaker) - Constructor for class org.apache.cassandra.cql3.selection.ResultSetBuilder
 
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
resume() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
resumeBootstrap() - Method in class org.apache.cassandra.service.StorageService
 
resumeBootstrap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Resume bootstrap streaming when there is failed data streaming.
resumeBootstrap(PrintStream) - Method in class org.apache.cassandra.tools.NodeProbe
 
resumeDispatch() - Method in class org.apache.cassandra.hints.HintsService
 
resumeDispatch() - Method in interface org.apache.cassandra.hints.HintsServiceMBean
Resume dispatch of all hints.
resumeEpochSampling() - Method in class org.apache.cassandra.utils.MonotonicClock.AbstractEpochSamplingClock
 
ResumeHandoff - Class in org.apache.cassandra.tools.nodetool
 
ResumeHandoff() - Constructor for class org.apache.cassandra.tools.nodetool.ResumeHandoff
 
resumeHintsDelivery() - Method in class org.apache.cassandra.tools.NodeProbe
 
resumeNowSampling() - Method in class org.apache.cassandra.utils.MonotonicClock.SampledClock
 
retain() - Method in class org.apache.cassandra.transport.Envelope
 
retainAll(Collection<?>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
retainAll(Collection<?>) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
retrieveTemporaryBuffer(int) - Static method in class org.apache.cassandra.io.util.DataOutputStreamPlus
 
retry() - Method in class org.apache.cassandra.net.OutboundConnectionInitiator.Result
 
returnAtLeastOneRow() - Method in class org.apache.cassandra.db.aggregation.GroupMaker
Specify if at least one row must be returned.
returnCode - Variable in exception org.apache.cassandra.exceptions.StartupException
 
returnCodec - Variable in class org.apache.cassandra.cql3.functions.UDFunction
 
returnStaticContentOnPartitionWithNoRows() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Determines if the query should return the static content when a partition without rows is returned (as a result set row with null for all other regular columns.)
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
 
reuse() - Method in class org.apache.cassandra.utils.btree.BTree.Builder
 
reuse(Comparator<? super V>) - Method in class org.apache.cassandra.utils.btree.BTree.Builder
 
reverse() - Method in class org.apache.cassandra.cql3.ResultSet
 
reverse() - Method in enum org.apache.cassandra.cql3.statements.Bound
 
reverse() - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
reverse() - Method in class org.apache.cassandra.utils.AsymmetricOrdering
 
reverse() - Method in class org.apache.cassandra.utils.btree.BTree.Builder
 
reverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
reversed - Variable in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
reversed() - Method in class org.apache.cassandra.db.ClusteringComparator
 
reversed - Variable in class org.apache.cassandra.db.filter.AbstractClusteringIndexFilter
 
ReversedType<T> - Class in org.apache.cassandra.db.marshal
 
reverseIfNeeded(ColumnMetadata) - Method in enum org.apache.cassandra.cql3.statements.Bound
Reverses the bound if the column type is a reversed one.
reverseIterator() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
reverseMap - Variable in class org.apache.cassandra.utils.BiMultiValMap
 
reverseMap - Variable in class org.apache.cassandra.utils.ConcurrentBiMap
 
revoke(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
revoke(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
revoke(AuthenticatedUser, Set<Permission>, IResource, RoleResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
Revokes a set of permissions on a resource from a user.
revokeAllFrom(RoleResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
revokeAllFrom(RoleResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
revokeAllFrom(RoleResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
Called before deleting a role with DROP ROLE statement (or the alias provided for compatibility, DROP USER) so that a new role with the same name wouldn't inherit permissions of the deleted one in the future.
revokeAllOn(IResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
revokeAllOn(IResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
revokeAllOn(IResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
This method is called after a resource is removed (i.e.
RevokePermissionsStatement - Class in org.apache.cassandra.cql3.statements
 
RevokePermissionsStatement(Set<Permission>, IResource, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.RevokePermissionsStatement
 
revokeRole(AuthenticatedUser, RoleResource, RoleResource) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
revokeRole(AuthenticatedUser, RoleResource, RoleResource) - Method in interface org.apache.cassandra.auth.IRoleManager
Called during the execution of a REVOKE ROLE query.
RevokeRoleStatement - Class in org.apache.cassandra.cql3.statements
 
RevokeRoleStatement(RoleName, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.RevokeRoleStatement
 
rewind() - Method in interface org.apache.cassandra.utils.btree.BTreeSearchIterator
Reset this Iterator to its starting position
rewind() - Method in class org.apache.cassandra.utils.btree.FullBTreeSearchIterator
Reset this Iterator to its starting position
rewind() - Method in class org.apache.cassandra.utils.btree.LeafBTreeSearchIterator
 
RewindableDataInput - Interface in org.apache.cassandra.io.util
 
RewindableDataInputPlusMark() - Constructor for class org.apache.cassandra.io.util.RewindableDataInputStreamPlus.RewindableDataInputPlusMark
 
RewindableDataInputStreamPlus - Class in org.apache.cassandra.io.util
Adds mark/reset functionality to another input stream by caching read bytes to a memory buffer and spilling to disk if necessary.
RewindableDataInputStreamPlus(InputStream, int, int, File, int) - Constructor for class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
RewindableDataInputStreamPlus.RewindableDataInputPlusMark - Class in org.apache.cassandra.io.util
 
rewriteSSTableMetadata(Descriptor, Map<MetadataType, MetadataComponent>) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
Replace the sstable metadata file (-Statistics.db) with the given components.
rewriteSSTableMetadata(Descriptor, Map<MetadataType, MetadataComponent>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
 
rfpRowsCachedPerQuery - Variable in class org.apache.cassandra.metrics.TableMetrics
This histogram records the maximum number of rows ReplicaFilteringProtection caches at a point in time per query.
right - Variable in class org.apache.cassandra.dht.AbstractBounds
 
right() - Method in class org.apache.cassandra.dht.Splitter.WeightedRange
 
right - Variable in class org.apache.cassandra.index.sasi.plan.Operation.Builder
 
right - Variable in class org.apache.cassandra.index.sasi.plan.Operation
 
right - Variable in class org.apache.cassandra.utils.Pair
 
right() - Method in class org.apache.cassandra.utils.Pair
 
rightBoundary() - Method in class org.apache.cassandra.dht.AbstractBounds
 
rightmostLeaf - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
 
rightmostParent - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
 
Ring - Class in org.apache.cassandra.tools.nodetool
 
Ring() - Constructor for class org.apache.cassandra.tools.nodetool.Ring
 
RING_DELAY - Static variable in class org.apache.cassandra.service.StorageService
 
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(InetAddress) - Constructor for class org.apache.cassandra.utils.RMIServerSocketFactoryImpl
 
Role - Class in org.apache.cassandra.auth
 
Role(String, boolean, boolean, Map<String, String>, Set<String>) - Constructor for class org.apache.cassandra.auth.Role
 
role(String) - Static method in class org.apache.cassandra.auth.RoleResource
Creates a RoleResource representing an individual Role.
role - Variable in class org.apache.cassandra.cql3.statements.RoleManagementStatement
 
role_manager - Variable in class org.apache.cassandra.config.Config
 
ROLE_MEMBERS - Static variable in class org.apache.cassandra.auth.AuthKeyspace
 
ROLE_PERMISSIONS - Static variable in class org.apache.cassandra.auth.AuthKeyspace
 
RoleManagementStatement - Class in org.apache.cassandra.cql3.statements
 
RoleManagementStatement(RoleName, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.RoleManagementStatement
 
RoleName - Class in org.apache.cassandra.cql3
 
RoleName() - Constructor for class org.apache.cassandra.cql3.RoleName
 
RoleOptions - Class in org.apache.cassandra.auth
 
RoleOptions() - Constructor for class org.apache.cassandra.auth.RoleOptions
 
RoleResource - Class in org.apache.cassandra.auth
IResource implementation representing database roles.
ROLES - Static variable in class org.apache.cassandra.auth.AuthKeyspace
 
Roles - Class in org.apache.cassandra.auth
 
Roles() - Constructor for class org.apache.cassandra.auth.Roles
 
roles_cache_max_entries - Variable in class org.apache.cassandra.config.Config
 
roles_update_interval_in_ms - Variable in class org.apache.cassandra.config.Config
 
roles_validity_in_ms - Variable in class org.apache.cassandra.config.Config
 
RolesCache - Class in org.apache.cassandra.auth
 
RolesCache(IRoleManager, BooleanSupplier) - Constructor for class org.apache.cassandra.auth.RolesCache
 
roll_cycle - Variable in class org.apache.cassandra.utils.binlog.BinLogOptions
How often to roll BinLog segments so they can potentially be reclaimed.
rollCycle(String) - Method in class org.apache.cassandra.utils.binlog.BinLog.Builder
 
root() - Static method in class org.apache.cassandra.auth.DataResource
 
root() - Static method in class org.apache.cassandra.auth.FunctionResource
 
root() - Static method in class org.apache.cassandra.auth.JMXResource
 
ROOT - Static variable in class org.apache.cassandra.auth.Resources
Deprecated.
root() - Static method in class org.apache.cassandra.auth.RoleResource
 
root - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
 
rotl64(long, int) - Static method in class org.apache.cassandra.utils.MurmurHash
 
roundBufferSize(long) - Method in interface org.apache.cassandra.io.util.DiskOptimizationStrategy
Round up to the next multiple of 4k but no more than DiskOptimizationStrategy.MAX_BUFFER_SIZE.
roundForCaching(int, boolean) - Static method in interface org.apache.cassandra.io.util.DiskOptimizationStrategy
Round either up or down to the next power of two, which is required by the ChunkCache.CachingRebufferer, but capping between DiskOptimizationStrategy.MIN_BUFFER_SIZE and DiskOptimizationStrategy.MAX_BUFFER_SIZE.
roundUp - Static variable in class org.apache.cassandra.cache.ChunkCache
 
roundUp(int) - Static method in class org.apache.cassandra.utils.memory.BufferPool
 
roundUp(int, int) - Static method in class org.apache.cassandra.utils.memory.BufferPool
 
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(TableMetadata, DecoratedKey, boolean) - Static method in class org.apache.cassandra.db.EmptyIterators
 
row(Object...) - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder
Adds the row identifier by the provided clustering and return a builder for that row.
Row - Interface in org.apache.cassandra.db.rows
Storage engine representation of a row.
row(Object...) - Method in class org.apache.cassandra.db.SimpleBuilders.PartitionUpdateBuilder
 
row(Object...) - Method in class org.apache.cassandra.db.virtual.SimpleDataSet
 
Row.Builder - Interface in org.apache.cassandra.db.rows
Interface for building rows.
Row.Deletion - Class in org.apache.cassandra.db.rows
A row deletion/tombstone.
Row.Merger - Class in org.apache.cassandra.db.rows
Utility class to help merging rows from multiple inputs (UnfilteredRowIterators).
Row.SimpleBuilder - Interface in org.apache.cassandra.db.rows
Row builder interface geared towards human.
row_cache_class_name - Variable in class org.apache.cassandra.config.Config
 
row_cache_keys_to_save - Variable in class org.apache.cassandra.config.Config
 
row_cache_save_period - Variable in class org.apache.cassandra.config.Config
 
row_cache_size_in_mb - Variable in class org.apache.cassandra.config.Config
 
RowAndDeletionMergeIterator - Class in org.apache.cassandra.db.rows
An iterator that merges a source of rows with the range tombstone and partition level deletion of a give partition.
RowAndDeletionMergeIterator(TableMetadata, DecoratedKey, DeletionTime, ColumnFilter, Row, boolean, EncodingStats, Iterator<Row>, Iterator<RangeTombstone>, boolean) - Constructor for class org.apache.cassandra.db.rows.RowAndDeletionMergeIterator
 
RowBuilder(TableMetadata, Object...) - Constructor for class org.apache.cassandra.db.SimpleBuilders.RowBuilder
 
rowBuilder(OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
 
rowBuilder(OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
 
rowBuilder(OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
 
rowCache - Variable in class org.apache.cassandra.service.CacheService
 
rowCacheHit - Variable in class org.apache.cassandra.metrics.TableMetrics
Number of row cache hits
rowCacheHitOutOfRange - Variable in class org.apache.cassandra.metrics.TableMetrics
Row cache hits, but result out of range
RowCacheKey - Class in org.apache.cassandra.cache
 
RowCacheKey(TableId, String, byte[]) - Constructor for class org.apache.cassandra.cache.RowCacheKey
 
RowCacheKey(TableMetadata, DecoratedKey) - Constructor for class org.apache.cassandra.cache.RowCacheKey
 
RowCacheKey(TableId, String, ByteBuffer) - Constructor for class org.apache.cassandra.cache.RowCacheKey
 
rowCacheMiss - Variable in class org.apache.cassandra.metrics.TableMetrics
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.cache.SerializingCacheProvider.RowCacheSerializer
 
RowCacheSerializer() - Constructor for class org.apache.cassandra.service.CacheService.RowCacheSerializer
 
rowComparator() - Method in class org.apache.cassandra.db.ClusteringComparator
A comparator for rows.
rowCount() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
rowCount() - Method in interface org.apache.cassandra.db.partitions.CachedPartition
The number of Row objects in this cached partition.
rowCount() - Method in class org.apache.cassandra.utils.MerkleTree
 
rowCount() - Method in class org.apache.cassandra.utils.MerkleTrees
 
RowDiffListener - Interface in org.apache.cassandra.db.rows
Interface that allows to act on the result of merging multiple rows.
rowEstimate - Variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer.Header
 
RowFilter - Class in org.apache.cassandra.db.filter
A filter on which rows a given query should include or exclude.
RowFilter(List<RowFilter.Expression>) - Constructor for class org.apache.cassandra.db.filter.RowFilter
 
rowFilter() - Method in interface org.apache.cassandra.db.ReadQuery
Filters/Resrictions on CQL rows.
rowFilter() - Method in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
 
RowFilter.CustomExpression - Class in org.apache.cassandra.db.filter
A custom index expression for use with 2i implementations which support custom syntax and which are not necessarily linked to a single column in the base table.
RowFilter.Expression - Class in org.apache.cassandra.db.filter
 
RowFilter.Expression.Kind - Enum in org.apache.cassandra.db.filter
 
RowFilter.Serializer - Class in org.apache.cassandra.db.filter
 
RowFilter.SimpleExpression - Class in org.apache.cassandra.db.filter
An expression of the form 'column' 'op' 'value'.
RowFilter.UserExpression - Class in org.apache.cassandra.db.filter
A user defined filtering expression.
RowFilter.UserExpression.Deserializer - Class in org.apache.cassandra.db.filter
 
rowFilterForInternalCalls() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
The RowFilter for this SELECT, assuming an internal call (no bound values in particular).
RowHash(Token, byte[], long) - Constructor for class org.apache.cassandra.utils.MerkleTree.RowHash
 
RowIndexEntry<T> - Class in org.apache.cassandra.db
Binary format of RowIndexEntry is defined as follows: {@code (long) position (64 bit long, vint encoded) (int) serialized size of data that follows (32 bit int, vint encoded) -- following for indexed entries only (so serialized size > 0) (int) DeletionTime.localDeletionTime (long) DeletionTime.markedForDeletionAt (int) number of IndexInfo objects (32 bit int, vint encoded) (*) serialized IndexInfo objects, see below (*) offsets of serialized IndexInfo objects, since version "ma" (3.0) Each IndexInfo object's offset is relative to the first IndexInfo object.
RowIndexEntry(long) - Constructor for class org.apache.cassandra.db.RowIndexEntry
 
RowIndexEntry.IndexInfoRetriever - Interface in org.apache.cassandra.db
Base class to access IndexInfo objects.
RowIndexEntry.IndexSerializer<T> - Interface in org.apache.cassandra.db
 
RowIndexEntry.Serializer - Class in org.apache.cassandra.db
 
rowIndexEntrySerializer - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
rowIndexEntrySerializer - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
rowIterator() - Method in class org.apache.cassandra.db.partitions.FilteredPartition
 
RowIterator - Interface in org.apache.cassandra.db.rows
An iterator over rows belonging to a partition.
RowIteratorMergeListener<E extends Endpoints<E>> - Class in org.apache.cassandra.service.reads.repair
 
RowIteratorMergeListener(DecoratedKey, RegularAndStaticColumns, boolean, ReplicaPlan.ForRead<E>, ReadCommand, ReadRepair) - Constructor for class org.apache.cassandra.service.reads.repair.RowIteratorMergeListener
 
RowIterators - Class in org.apache.cassandra.db.rows
Static methods to work with row iterators.
rowMark - Variable in class org.apache.cassandra.service.pager.PagingState
 
RowPositionSerializer() - Constructor for class org.apache.cassandra.db.PartitionPosition.RowPositionSerializer
 
rowPositionSerializer - Static variable in class org.apache.cassandra.dht.AbstractBounds
 
rows - Variable in class org.apache.cassandra.cql3.ResultSet
 
Rows - Class in org.apache.cassandra.db.rows
Static utilities to work on Row objects.
Rows(ResultSet) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Rows
 
rowsCounted() - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
The number of rows counted.
rowsCountedInCurrentPartition() - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
The number of rows counted in the current partition.
rowsPerPartitionToCache() - Method in class org.apache.cassandra.schema.CachingParams
 
rowsWithNonExpiringCells() - Method in class org.apache.cassandra.db.partitions.CachedBTreePartition
The number of rows in this cached partition that have at least one non-expiring non-deleted cell.
rowsWithNonExpiringCells() - Method in interface org.apache.cassandra.db.partitions.CachedPartition
The number of rows in this cached partition that have at least one non-expiring non-deleted cell.
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
 
rpcaddress(InetAddress) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
rpcReady(boolean) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
RTBoundCloser - Class in org.apache.cassandra.db.transform
A transformation that appends an RT bound marker to row iterators in case they don't have one.
RTBoundValidator - Class in org.apache.cassandra.db.transform
A validating transformation that sanity-checks the sequence of RT bounds and boundaries in every partition.
RTBoundValidator.Stage - Enum in org.apache.cassandra.db.transform
 
run() - Method in interface org.apache.cassandra.concurrent.InfiniteLoopExecutor.InterruptibleRunnable
 
run() - Method in class org.apache.cassandra.db.repair.PendingAntiCompaction
 
run() - Method in class org.apache.cassandra.db.SizeEstimatesRecorder
 
run() - Method in class org.apache.cassandra.io.sstable.SnapshotDeletingTask
 
run() - Method in class org.apache.cassandra.repair.RepairJob
Runs repair job.
run() - Method in class org.apache.cassandra.repair.RepairRunnable
 
run() - Method in class org.apache.cassandra.repair.SnapshotTask
 
run() - Method in class org.apache.cassandra.repair.StreamingRepairTask
 
run() - Method in class org.apache.cassandra.repair.SyncTask
Compares trees, and triggers repairs for any ranges that mismatch.
run() - Method in class org.apache.cassandra.repair.ValidationTask
Send ValidationRequest to replica
run() - Method in class org.apache.cassandra.repair.Validator
Called after the validation lifecycle to respond with the now valid tree.
run(INodeProbeFactory, Output) - Method in class org.apache.cassandra.tools.NodeTool.CassHelp
 
run(INodeProbeFactory, Output) - Method in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
 
run(NodeProbe, Output) - Method in class org.apache.cassandra.tools.nodetool.Sjk.Wrapper
 
run() - Method in class org.apache.cassandra.tools.RepairRunner
 
run() - Method in class org.apache.cassandra.transport.Client
 
run() - Method in class org.apache.cassandra.utils.binlog.BinLog
 
run() - Method in class org.apache.cassandra.utils.memory.MemtableCleanerThread.Clean
 
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
 
runInGossipStageBlocking(Runnable) - Static method in class org.apache.cassandra.gms.Gossiper
 
runInternal() - Method in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
 
runInternal() - Method in class org.apache.cassandra.tools.nodetool.Sjk
 
runMayThrow() - Method in class org.apache.cassandra.db.compaction.CompactionTask
For internal use and testing only.
runMayThrow() - Method in class org.apache.cassandra.db.compaction.SingleSSTableLCSTask
 
runMayThrow() - Method in class org.apache.cassandra.service.StorageProxy.LocalReadRunnable
 
runMayThrow() - Method in class org.apache.cassandra.utils.WrappedRunnable
 
runOnAbort(Runnable) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
runOnClose(int) - Method in class org.apache.cassandra.db.transform.BasePartitions
 
runOnClose(int) - Method in class org.apache.cassandra.db.transform.BaseRows
 
runOnClose(Runnable) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
runOnCommit(Runnable) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
runPostFlush - Variable in class org.apache.cassandra.io.util.SequentialWriter
 
runStartupChecks() - Method in class org.apache.cassandra.service.CassandraDaemon
 
runtimeProxy - Variable in class org.apache.cassandra.tools.NodeProbe
 
runWithCompactionsDisabled(Callable<V>, boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
runWithCompactionsDisabled(Callable<V>, Predicate<SSTableReader>, boolean, boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Runs callable with compactions paused and compactions including sstables matching sstablePredicate stopped
runWithLock(CheckedFunction<Descriptor, R, IOException>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
Execute provided task with sstable lock to avoid racing with index summary redistribution, SEE CASSANDRA-15861.
runWithThreadName(Runnable, String) - Static method in class org.apache.cassandra.utils.ExecutorUtils
 

S

SA<T extends java.nio.Buffer> - Class in org.apache.cassandra.index.sasi.sa
 
SA(AbstractType<?>, OnDiskIndexBuilder.Mode) - Constructor for class org.apache.cassandra.index.sasi.sa.SA
 
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
 
sameTable(TableMetadata) - Method in class org.apache.cassandra.cache.CacheKey
 
Sample(S, long, long) - Constructor for class org.apache.cassandra.metrics.Sampler.Sample
 
SampledClock(MonotonicClock) - Constructor for class org.apache.cassandra.utils.MonotonicClock.SampledClock
 
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
 
samplePartitions(int, int, int, List<String>) - Method in class org.apache.cassandra.service.StorageService
 
samplePartitions(int, int, int, List<String>) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
Sampler<T> - Class in org.apache.cassandra.metrics
 
Sampler() - Constructor for class org.apache.cassandra.metrics.Sampler
 
Sampler.Sample<S> - Class in org.apache.cassandra.metrics
Represents the ranked items collected during a sample period
Sampler.SamplerType - Enum in org.apache.cassandra.metrics
 
sampleReadLatencyNanos - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
samplers - Variable in class org.apache.cassandra.metrics.TableMetrics
 
SASIIndex - Class in org.apache.cassandra.index.sasi
 
SASIIndex(ColumnFamilyStore, IndexMetadata) - Constructor for class org.apache.cassandra.index.sasi.SASIIndex
 
satisfiedBy(Unfiltered, Row, boolean) - Method in class org.apache.cassandra.index.sasi.plan.Operation
Recursive "satisfies" checks based on operation and data from the lower level members using depth-first search and bubbling the results back to the top level caller.
satisfies(ConsistencyLevel, AbstractReplicationStrategy) - Method in enum org.apache.cassandra.db.ConsistencyLevel
Determine if this consistency level meets or exceeds the consistency requirements of the given cl for the given keyspace WARNING: this is not locality aware; you cannot safely use this with mixed locality consistency levels (e.g.
saturatingCastToInt(long) - Static method in class org.apache.cassandra.utils.streamhist.StreamingTombstoneHistogramBuilder
 
saturatingCastToMaxDeletionTime(long) - Static method in class org.apache.cassandra.utils.streamhist.StreamingTombstoneHistogramBuilder
Cast to an int with maximum value of Cell.MAX_DELETION_TIME to avoid representing values that aren't a tombstone
saveBloomFilter(Descriptor, IFilter) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
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(Descriptor, DecoratedKey, DecoratedKey, IndexSummary) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
Save index summary to Summary.db file.
saveSystemKeyspacesSchema() - Static method in class org.apache.cassandra.schema.SchemaKeyspace
Add entries to system_schema.* for the hardcoded system keyspaces
saveTask - Variable in class org.apache.cassandra.cache.AutoSavingCache
 
saveTruncationRecord(ColumnFamilyStore, long, CommitLogPosition) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
sawCDCMutation - Variable in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
ScalarFunction - Interface in org.apache.cassandra.cql3.functions
Determines a single output value based on a single input value.
scan(Long, int) - Method in class org.apache.cassandra.diag.store.DiagnosticEventMemoryStore
 
scan(T, int) - Method in interface org.apache.cassandra.diag.store.DiagnosticEventStore
Returns a view on all events with a key greater than the provided value (inclusive) up to the specified number of results.
scannedOverviewOutput(String, long) - Method in class org.apache.cassandra.tools.SSTableMetadataViewer
 
ScannerList(List<ISSTableScanner>) - Constructor for class org.apache.cassandra.db.compaction.AbstractCompactionStrategy.ScannerList
 
scanners - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy.ScannerList
 
schedule(ChannelHandlerContext) - Method in class org.apache.cassandra.transport.SimpleClient.SimpleFlusher
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
 
scheduledBytes() - Method in class org.apache.cassandra.net.InboundMessageHandlers
 
scheduledCount() - Method in class org.apache.cassandra.net.InboundMessageHandlers
 
ScheduledExecutors - Class in org.apache.cassandra.concurrent
Centralized location for shared executors
ScheduledExecutors() - Constructor for class org.apache.cassandra.concurrent.ScheduledExecutors
 
scheduledFastTasks - Static variable in class org.apache.cassandra.concurrent.ScheduledExecutors
This pool is used for periodic fast (sub-microsecond) tasks.
scheduledTasks - Static variable in class org.apache.cassandra.concurrent.ScheduledExecutors
This pool is used for periodic short (sub-second) tasks.
scheduleLogging() - Method in class org.apache.cassandra.metrics.MessagingMetrics
 
scheduleSaving(int, int) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
scheduleSegmentFlush(boolean) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
 
scheduleSetupTask(Callable<Void>) - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
scheduleTimeout(int, long, TimeUnit) - Method in class org.apache.cassandra.streaming.StreamTransferTask
Schedule timeout task to release reference for stream sent.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
 
schema(boolean) - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
Creates a DescribeStatement for DESCRIBE [FULL] SCHEMA.
schema(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
Schema - Class in org.apache.cassandra.schema
 
Schema.TransformationResult - Class in org.apache.cassandra.schema
 
SCHEMA_DELAY_MILLIS - Static variable in class org.apache.cassandra.service.StorageService
 
SCHEMA_KEYSPACE_NAME - Static variable in class org.apache.cassandra.schema.SchemaConstants
 
SchemaArgsParser - Class in org.apache.cassandra.repair.consistent.admin
 
schemaCallback(Supplier<Function<Descriptor, TableMetadata>>) - Method in class org.apache.cassandra.io.sstable.SSTableHeaderFix.Builder
Schema callback to retrieve the schema of a table.
schemaCallback - Variable in class org.apache.cassandra.io.sstable.SSTableHeaderFix
 
SchemaChange(Event.SchemaChange.Change, Event.SchemaChange.Target, String, String, List<String>) - Constructor for class org.apache.cassandra.transport.Event.SchemaChange
 
SchemaChange(Event.SchemaChange.Change, Event.SchemaChange.Target, String, String) - Constructor for class org.apache.cassandra.transport.Event.SchemaChange
 
SchemaChange(Event.SchemaChange.Change, String) - Constructor for class org.apache.cassandra.transport.Event.SchemaChange
 
SchemaChange(Event.SchemaChange) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
 
SchemaChangeListener - Class in org.apache.cassandra.schema
 
SchemaChangeListener() - Constructor for class org.apache.cassandra.schema.SchemaChangeListener
 
SchemaConstants - Class in org.apache.cassandra.schema
 
SchemaConstants() - Constructor for class org.apache.cassandra.schema.SchemaConstants
 
SchemaCQLHelper - Class in org.apache.cassandra.db
Helper methods to represent TableMetadata and related objects in CQL format
SchemaCQLHelper() - Constructor for class org.apache.cassandra.db.SchemaCQLHelper
 
SchemaElement - Interface in org.apache.cassandra.cql3
A schema element (keyspace, udt, udf, uda, table, index, view).
SchemaElement.SchemaElementType - Enum in org.apache.cassandra.cql3
 
SchemaEvent - Class in org.apache.cassandra.schema
 
SchemaEvent.SchemaEventType - Enum in org.apache.cassandra.schema
 
SchemaKeyspace - Class in org.apache.cassandra.schema
system_schema.* tables and methods for manipulating them.
SchemaProvider - Interface in org.apache.cassandra.schema
 
SchemaPullVerbHandler - Class in org.apache.cassandra.schema
Sends it's current schema state in form of mutations in response to the remote node's request.
SchemaPullVerbHandler() - Constructor for class org.apache.cassandra.schema.SchemaPullVerbHandler
 
SchemaPushVerbHandler - Class in org.apache.cassandra.schema
Called when node receives updated schema state from the schema migration coordinator node.
SchemaPushVerbHandler() - Constructor for class org.apache.cassandra.schema.SchemaPushVerbHandler
 
SchemaTransformation - Interface in org.apache.cassandra.schema
 
schemaVersionToString(UUID) - Static method in class org.apache.cassandra.schema.Schema
Converts the given schema version to a string.
SchemaVersionVerbHandler - Class in org.apache.cassandra.schema
 
SchemaVersionVerbHandler() - Constructor for class org.apache.cassandra.schema.SchemaVersionVerbHandler
 
scope - Variable in class org.apache.cassandra.audit.AuditLogContext
 
scratchBuffer - Static variable in class org.apache.cassandra.io.util.DataOutputBuffer
Scratch buffers used mostly for serializing in memory.
scrub(boolean, boolean, boolean, boolean, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
scrub(boolean, boolean, boolean, boolean, boolean, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
scrub() - Method in class org.apache.cassandra.db.compaction.Scrubber
 
scrub(boolean, boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
scrub(boolean, boolean, boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
scrub(boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
scrub(boolean, boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
scrub(boolean, boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
scrub(boolean, boolean, boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
scrub(boolean, boolean, boolean, int, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
scrub(boolean, boolean, boolean, boolean, int, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
scrub(boolean, boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
scrub(PrintStream, boolean, boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
Scrub - Class in org.apache.cassandra.tools.nodetool
 
Scrub() - Constructor for class org.apache.cassandra.tools.nodetool.Scrub
 
Scrubber - Class in org.apache.cassandra.db.compaction
 
Scrubber(ColumnFamilyStore, LifecycleTransaction, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
 
Scrubber(ColumnFamilyStore, LifecycleTransaction, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
 
Scrubber(ColumnFamilyStore, LifecycleTransaction, boolean, OutputHandler, boolean, boolean) - Constructor for class org.apache.cassandra.db.compaction.Scrubber
 
Scrubber.NegativeLocalDeletionInfoMetrics - Class in org.apache.cassandra.db.compaction
 
Scrubber.ScrubResult - Class in org.apache.cassandra.db.compaction
 
scrubDataDirectories(TableMetadata) - 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(Clustering<?>) - Method in class org.apache.cassandra.db.RangeTombstoneList
 
search(ReadExecutionController) - Method in interface org.apache.cassandra.index.Index.Searcher
 
search(ReadExecutionController) - Method in class org.apache.cassandra.index.internal.CassandraIndexSearcher
 
search(Expression) - Method in class org.apache.cassandra.index.sasi.conf.view.PrefixTermTree
 
search(Expression) - Method in class org.apache.cassandra.index.sasi.conf.view.RangeTermTree
 
search(Expression) - Method in interface org.apache.cassandra.index.sasi.conf.view.TermTree
 
search(AbstractType<?>, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
 
search(Expression) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
Search for rows which match all of the terms inside the given expression in the index file.
search(Expression) - Method in class org.apache.cassandra.index.sasi.memory.IndexMemtable
 
search(Expression) - Method in class org.apache.cassandra.index.sasi.memory.MemIndex
 
search(Expression) - Method in class org.apache.cassandra.index.sasi.memory.SkipListMemIndex
 
search(Expression.Op, String) - Method in class org.apache.cassandra.index.sasi.memory.TrieMemIndex.ConcurrentPrefixTrie
 
search(Expression.Op, String) - Method in class org.apache.cassandra.index.sasi.memory.TrieMemIndex.ConcurrentSuffixTrie
 
search(Expression) - Method in class org.apache.cassandra.index.sasi.memory.TrieMemIndex
 
search(Expression) - Method in class org.apache.cassandra.index.sasi.SSTableIndex
 
search(Interval<C, D>) - Method in class org.apache.cassandra.utils.IntervalTree
 
search(C) - Method in class org.apache.cassandra.utils.IntervalTree
 
searchConcurrencyFactor() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
searchDeletionTime(Clustering<?>) - 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.
searcherFor(ReadCommand) - Method in interface org.apache.cassandra.index.Index
Factory method for query time search helper.
searcherFor(ReadCommand) - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
searcherFor(ReadCommand) - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
searchIterator() - Method in class org.apache.cassandra.db.rows.BTreeRow
 
searchIterator() - Method in interface org.apache.cassandra.db.rows.Row
An iterator to efficiently search data for a given column.
SearchIterator<K,V> - Interface in org.apache.cassandra.utils
 
searchMemtable(Expression) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
SearchResult(T, int, int) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskBlock.SearchResult
 
SECONDARY_INDEX_NAME_SEPARATOR - Static variable in class org.apache.cassandra.db.Directories
 
SecondaryIndexBuilder - Class in org.apache.cassandra.index
Manages building an entire index from column family data.
SecondaryIndexBuilder() - Constructor for class org.apache.cassandra.index.SecondaryIndexBuilder
 
SecondaryIndexManager - Class in org.apache.cassandra.index
Handles the core maintenance functionality associated with indexes: adding/removing them to or from a table, (re)building during bootstrap or other streaming operations, flushing, reloading metadata and so on.
SecondaryIndexManager(ColumnFamilyStore) - Constructor for class org.apache.cassandra.index.SecondaryIndexManager
 
Section(String, String, long) - Constructor for class org.apache.cassandra.repair.consistent.admin.RepairStats.Section
 
sections - Variable in class org.apache.cassandra.db.streaming.CassandraStreamHeader
 
sections - Variable in class org.apache.cassandra.db.streaming.CassandraStreamReader
 
sections - Variable in class org.apache.cassandra.db.streaming.CassandraStreamWriter
 
sections - Variable in class org.apache.cassandra.repair.consistent.admin.RepairStats
 
sections - Variable in class org.apache.cassandra.repair.consistent.RepairedState.Stats
 
SecurityThreadGroup - Class in org.apache.cassandra.security
Used by ThreadAwareSecurityManager to determine whether access-control checks needs to be performed.
SecurityThreadGroup(String, Set<String>, SecurityThreadGroup.ThreadInitializer) - Constructor for class org.apache.cassandra.security.SecurityThreadGroup
 
SecurityThreadGroup.ThreadInitializer - Interface in org.apache.cassandra.security
 
seed_provider - Variable in class org.apache.cassandra.config.Config
 
SeedProvider - Interface in org.apache.cassandra.locator
 
seek(long) - Method in class org.apache.cassandra.db.commitlog.EncryptedFileSegmentInputStream
 
seek(InputPosition) - Method in class org.apache.cassandra.hints.ChecksummedDataInput
 
seek(InputPosition) - Method in class org.apache.cassandra.hints.CompressedChecksummedDataInput
 
seek(InputPosition) - Method in class org.apache.cassandra.hints.EncryptedChecksummedDataInput
 
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.FileSegmentInputStream
 
seek(long) - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
seekToPosition(long) - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
 
seenAnySeed() - Method in class org.apache.cassandra.gms.Gossiper
 
segmentId - Variable in class org.apache.cassandra.db.commitlog.CommitLogPosition
 
SegmentIterator() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SegmentIterator
 
segmentManager - Variable in class org.apache.cassandra.db.commitlog.CommitLog
 
SegmentReadException(String, boolean) - Constructor for exception org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SegmentReadException
 
segments - Variable in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
 
select(Function<View, Iterable<SSTableReader>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
select(ColumnMetadata, CellPath) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Builder
 
select(SSTableSet) - Method in class org.apache.cassandra.db.lifecycle.View
 
select(SSTableSet, Predicate<SSTableReader>) - Static method in class org.apache.cassandra.db.lifecycle.View
 
select(SSTableSet, DecoratedKey) - Static method in class org.apache.cassandra.db.lifecycle.View
 
select(DecoratedKey, ClusteringIndexFilter, ColumnFilter) - Method in class org.apache.cassandra.db.virtual.AbstractVirtualTable
 
select(DataRange, ColumnFilter) - Method in class org.apache.cassandra.db.virtual.AbstractVirtualTable
 
select(DecoratedKey, ClusteringIndexFilter, ColumnFilter) - Method in interface org.apache.cassandra.db.virtual.VirtualTable
Selects the rows from a single partition.
select(DataRange, ColumnFilter) - Method in interface org.apache.cassandra.db.virtual.VirtualTable
Selects the rows from a range of partitions.
select(Map.Entry<? extends K, ? extends V>) - Method in interface org.apache.cassandra.index.sasi.utils.trie.Cursor
Called for each Map.Entry in the Trie.
select(K) - Method in interface org.apache.cassandra.index.sasi.utils.trie.Trie
Returns the Map.Entry whose key is closest in a bitwise XOR metric to the given key.
select(K, Cursor<? super K, ? super V>) - Method in interface org.apache.cassandra.index.sasi.utils.trie.Trie
Iterates through the Trie, starting with the entry whose bitwise value is closest in an XOR metric to the given key.
select(Iterable<InetAddressAndPort>, boolean) - Method in class org.apache.cassandra.locator.Endpoints
 
select(ConsistencyLevel, L, L) - Method in interface org.apache.cassandra.locator.ReplicaPlans.Selector
Select the Endpoints from and to contact according to the consistency level.
selectable - Variable in class org.apache.cassandra.cql3.selection.RawSelector
 
Selectable - Interface in org.apache.cassandra.cql3.selection
 
Selectable.BetweenParenthesesOrWithTuple - Class in org.apache.cassandra.cql3.selection
Selectable for Selectable between parentheses or tuples.
Selectable.BetweenParenthesesOrWithTuple.Raw - Class in org.apache.cassandra.cql3.selection
 
Selectable.Raw - Interface in org.apache.cassandra.cql3.selection
 
Selectable.RawIdentifier - Class in org.apache.cassandra.cql3.selection
In the selection clause, the parser cannot differentiate between Maps and UDTs as a column identifier and field identifier have the same syntax.
Selectable.WithCast - Class in org.apache.cassandra.cql3.selection
 
Selectable.WithCast.Raw - Class in org.apache.cassandra.cql3.selection
 
Selectable.WithElementSelection - Class in org.apache.cassandra.cql3.selection
Represents the selection of an element of a collection (eg.
Selectable.WithElementSelection.Raw - Class in org.apache.cassandra.cql3.selection
 
Selectable.WithFieldSelection - Class in org.apache.cassandra.cql3.selection
Represents the selection of the field of a UDT (eg.
Selectable.WithFieldSelection.Raw - Class in org.apache.cassandra.cql3.selection
 
Selectable.WithFunction - Class in org.apache.cassandra.cql3.selection
 
Selectable.WithFunction.Raw - Class in org.apache.cassandra.cql3.selection
 
Selectable.WithList - Class in org.apache.cassandra.cql3.selection
Selectable for literal Lists.
Selectable.WithList.Raw - Class in org.apache.cassandra.cql3.selection
 
Selectable.WithMapOrUdt - Class in org.apache.cassandra.cql3.selection
Selectable for literal Maps or UDTs.
Selectable.WithMapOrUdt.Raw - Class in org.apache.cassandra.cql3.selection
 
Selectable.WithSet - Class in org.apache.cassandra.cql3.selection
Selectable for literal Sets.
Selectable.WithSet.Raw - Class in org.apache.cassandra.cql3.selection
 
Selectable.WithSliceSelection - Class in org.apache.cassandra.cql3.selection
Represents the selection of a slice of a collection (eg.
Selectable.WithSliceSelection.Raw - Class in org.apache.cassandra.cql3.selection
 
Selectable.WithTerm - Class in org.apache.cassandra.cql3.selection
 
Selectable.WithTerm.Raw - Class in org.apache.cassandra.cql3.selection
 
Selectable.WithToJSonFunction - Class in org.apache.cassandra.cql3.selection
 
Selectable.WithTypeHint - Class in org.apache.cassandra.cql3.selection
Selectable for type hints (e.g.
Selectable.WithTypeHint.Raw - Class in org.apache.cassandra.cql3.selection
 
Selectable.WritetimeOrTTL - Class in org.apache.cassandra.cql3.selection
 
Selectable.WritetimeOrTTL.Raw - Class in org.apache.cassandra.cql3.selection
 
selectAndReference(Function<View, Iterable<SSTableReader>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
selectClause - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
 
selectColumns(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.Selectable.BetweenParenthesesOrWithTuple
 
selectColumns(Predicate<ColumnMetadata>) - Method in interface org.apache.cassandra.cql3.selection.Selectable
Checks if this Selectable select columns matching the specified predicate.
selectColumns(List<Selectable>, Predicate<ColumnMetadata>) - Static method in interface org.apache.cassandra.cql3.selection.Selectable
Checks if the specified Selectables select columns matching the specified predicate.
selectColumns(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithCast
 
selectColumns(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithElementSelection
 
selectColumns(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection
 
selectColumns(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFunction
 
selectColumns(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithList
 
selectColumns(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithMapOrUdt
 
selectColumns(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithSet
 
selectColumns(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithSliceSelection
 
selectColumns(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithTerm
 
selectColumns(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithToJSonFunction
 
selectColumns(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithTypeHint
 
selectColumns(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL
 
selectColumns(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.schema.ColumnMetadata
 
selected - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithElementSelection
 
selected - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection
 
selected - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithSliceSelection
 
selectFunction(SSTableSet) - Static method in class org.apache.cassandra.db.lifecycle.View
 
Selection - Class in org.apache.cassandra.cql3.selection
 
Selection(TableMetadata, List<ColumnMetadata>, Set<ColumnMetadata>, SelectionColumnMapping, ColumnFilterFactory, boolean) - Constructor for class org.apache.cassandra.cql3.selection.Selection
 
selection(RegularAndStaticColumns) - Static method in class org.apache.cassandra.db.filter.ColumnFilter
A filter that only fetches/queries the provided columns.
selection(TableMetadata, RegularAndStaticColumns, boolean) - Static method in class org.apache.cassandra.db.filter.ColumnFilter
A filter that fetches all columns for the provided table, but returns only the queried ones.
Selection.Selectors - Interface in org.apache.cassandra.cql3.selection
 
selectionBuilder() - Static method in class org.apache.cassandra.db.filter.ColumnFilter
Returns a ColumnFilter builder that only fetches the columns/cells added to the builder.
SelectionColumnFilter(ColumnFilter.FetchingStrategy, RegularAndStaticColumns, RegularAndStaticColumns, SortedSetMultimap<ColumnIdentifier, ColumnSubselection>) - Constructor for class org.apache.cassandra.db.filter.ColumnFilter.SelectionColumnFilter
Creates a ColumnFilter for queries with selected columns.
SelectionColumnMapping - Class in org.apache.cassandra.cql3.selection
Separately maintains the ColumnSpecifications and their mappings to underlying columns as we may receive null mappings.
SelectionColumns - Interface in org.apache.cassandra.cql3.selection
Represents a mapping between the actual columns used to satisfy a Selection and the column definitions included in the resultset metadata for the query.
selectionDeserializer - Static variable in class org.apache.cassandra.db.PartitionRangeReadCommand
 
SelectionDeserializer() - Constructor for class org.apache.cassandra.db.ReadCommand.SelectionDeserializer
 
selectionDeserializer - Static variable in class org.apache.cassandra.db.SinglePartitionReadCommand
 
selectionSerializedSize(int) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
selectionSerializedSize(int) - Method in class org.apache.cassandra.db.ReadCommand
 
selectionSerializedSize(int) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
selectKey(K) - Method in interface org.apache.cassandra.index.sasi.utils.trie.Trie
Returns the key that is closest in a bitwise XOR metric to the provided key.
selectLive(AbstractBounds<PartitionPosition>) - Static method in class org.apache.cassandra.db.lifecycle.View
 
Selector - Class in org.apache.cassandra.cql3.selection
A Selector is used to convert the data returned by the storage engine into the data requested by the user.
Selector() - Constructor for class org.apache.cassandra.cql3.selection.Selector
 
Selector.Factory - Class in org.apache.cassandra.cql3.selection
A factory for Selector instances.
selectOrderIterator() - Method in class org.apache.cassandra.db.Columns
An iterator that returns the columns of this object in "select" order (that is in global alphabetical order, where the "normal" iterator returns simple columns first and the complex second).
selectOrderIterator() - Method in class org.apache.cassandra.db.RegularAndStaticColumns
 
selects(Clustering<?>) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
Whether a given row is selected by this filter.
selects(Clustering<?>) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
 
selects(Clustering<?>) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
 
selects(Clustering<?>) - Method in class org.apache.cassandra.db.Slices
Whether a given clustering (row) is selected by this Slices object.
selectsAllPartition() - Method in class org.apache.cassandra.db.DataRange
 
selectsAllPartition() - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
Whether this filter selects all the row of a partition (it's an "identity" filter).
selectsAllPartition() - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
 
selectsAllPartition() - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
 
selectsClustering(DecoratedKey, Clustering<?>) - Method in interface org.apache.cassandra.db.PartitionRangeReadQuery
 
selectsClustering(DecoratedKey, Clustering<?>) - Method in interface org.apache.cassandra.db.ReadQuery
 
selectsClustering(DecoratedKey, Clustering<?>) - Method in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
 
selectsClustering(DecoratedKey, Clustering<?>) - Method in interface org.apache.cassandra.db.SinglePartitionReadQuery
 
selectsFullPartition() - Method in interface org.apache.cassandra.db.PartitionRangeReadQuery
 
selectsFullPartition() - Method in interface org.apache.cassandra.db.ReadQuery
Checks if this ReadQuery selects full partitions, that is it has no filtering on clustering or regular columns.
selectsFullPartition() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
selectsFullPartition() - Method in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
 
selectsFullPartition() - Method in class org.apache.cassandra.db.VirtualTableSinglePartitionReadQuery
 
selectsKey(DecoratedKey) - Method in interface org.apache.cassandra.db.PartitionRangeReadQuery
 
selectsKey(DecoratedKey) - Method in interface org.apache.cassandra.db.ReadQuery
 
selectsKey(DecoratedKey) - Method in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
 
selectsKey(DecoratedKey) - Method in interface org.apache.cassandra.db.SinglePartitionReadQuery
 
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(TableMetadata, VariableSpecifications, SelectStatement.Parameters, Selection, StatementRestrictions, boolean, AggregationSpecification, Comparator<List<ByteBuffer>>, Term, 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
 
selectValue(K) - Method in interface org.apache.cassandra.index.sasi.utils.trie.Trie
Returns the value whose key is closest in a bitwise XOR metric to the provided key.
selfIfPresent() - Method in class org.apache.cassandra.locator.Endpoints
 
selfRef() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
selfRef() - Method in interface org.apache.cassandra.utils.concurrent.SelfRefCounted
 
SelfRefCounted<T extends SelfRefCounted<T>> - Interface in org.apache.cassandra.utils.concurrent
 
selfRefs(Iterable<T>) - Static method in class org.apache.cassandra.utils.concurrent.Refs
 
send(Message, InetAddressAndPort) - Method in class org.apache.cassandra.net.MessagingService
Send a message to a given endpoint.
send(Message, InetAddressAndPort, ConnectionType) - Method in class org.apache.cassandra.net.MessagingService
 
send(Event) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
 
sendByFollower - Variable in class org.apache.cassandra.streaming.messages.StreamMessageHeader
 
sender - Variable in class org.apache.cassandra.streaming.messages.StreamMessageHeader
 
sendingSummaries - Variable in class org.apache.cassandra.streaming.SessionInfo
Immutable collection of sending summaries
sendingSummaries - Variable in class org.apache.cassandra.streaming.SessionSummary
Immutable collection of sending summaries
sendInitialRepairs() - Method in class org.apache.cassandra.service.reads.repair.BlockingPartitionRepair
 
sendMessage(InetAddressAndPort, Message<RepairMessage>) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
 
sendMessage(InetAddressAndPort, Message<? extends RepairMessage>) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
sendMessage(StreamMessage) - Method in class org.apache.cassandra.streaming.async.NettyStreamingMessageSender
 
sendMessage(StreamMessage) - Method in interface org.apache.cassandra.streaming.StreamingMessageSender
 
sendMigrationMessage(MigrationCoordinator.Callback) - Method in class org.apache.cassandra.schema.MigrationCoordinator
 
sendRR(Message<Mutation>, InetAddressAndPort) - Method in class org.apache.cassandra.service.reads.repair.BlockingPartitionRepair
 
sendStatusRequest(LocalSession) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
sendToHintedReplicas(Mutation, ReplicaPlan.ForTokenWrite, AbstractWriteResponseHandler<IMutation>, String, Stage) - 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.
sendWithCallback(Message, InetAddressAndPort, RequestCallback) - Method in class org.apache.cassandra.net.MessagingService
Send a non-mutation message to a given endpoint.
sendWithCallback(Message, InetAddressAndPort, RequestCallback, ConnectionType) - Method in class org.apache.cassandra.net.MessagingService
 
sendWriteWithCallback(Message, Replica, AbstractWriteResponseHandler<?>, boolean) - Method in class org.apache.cassandra.net.MessagingService
Send a mutation message or a Paxos Commit to a given endpoint.
sentBytes() - Method in class org.apache.cassandra.net.OutboundConnection
 
sentCount() - Method in class org.apache.cassandra.net.OutboundConnection
 
separator - Static variable in class org.apache.cassandra.io.sstable.Component
 
SEPExecutor - Class in org.apache.cassandra.concurrent
 
SEPExecutor.TakeTaskPermitResult - Enum in org.apache.cassandra.concurrent
 
SEPExecutorMBean - Interface in org.apache.cassandra.concurrent
 
sequenceNumber - Variable in class org.apache.cassandra.streaming.messages.ReceivedMessage
 
sequenceNumber - Variable in class org.apache.cassandra.streaming.messages.StreamMessageHeader
 
sequenceRun(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.Sjk
 
SequentialWriter - Class in org.apache.cassandra.io.util
Adds buffering, mark, and fsyncing to OutputStream.
SequentialWriter(File) - Constructor for class org.apache.cassandra.io.util.SequentialWriter
Create heap-based, non-compressed SequenialWriter with default buffer size(64k).
SequentialWriter(File, SequentialWriterOption) - Constructor for class org.apache.cassandra.io.util.SequentialWriter
Create SequentialWriter for given file with specific writer option.
SequentialWriter(File, SequentialWriterOption, boolean) - Constructor for class org.apache.cassandra.io.util.SequentialWriter
Create SequentialWriter for given file with specific writer option.
SequentialWriter.BufferedFileWriterMark - Class in org.apache.cassandra.io.util
Class to hold a mark to the position of the file
SequentialWriter.TransactionalProxy - Class in org.apache.cassandra.io.util
 
SequentialWriterOption - Class in org.apache.cassandra.io.util
SequentialWriter option
SequentialWriterOption.Builder - Class in org.apache.cassandra.io.util
 
SerializableHintMessage - Interface in org.apache.cassandra.hints
 
SerializationHeader - Class in org.apache.cassandra.db
 
SerializationHeader(boolean, TableMetadata, RegularAndStaticColumns, EncodingStats) - Constructor for class org.apache.cassandra.db.SerializationHeader
 
serializationHeader - Variable in class org.apache.cassandra.db.streaming.CassandraStreamHeader
 
SerializationHeader.Component - Class in org.apache.cassandra.db
We need the TableMetadata to properly deserialize a SerializationHeader but it's clunky to pass that to a SSTable component, so we use this temporary object to delay the actual need for the metadata.
SerializationHeader.Serializer - Class in org.apache.cassandra.db
 
SerializationHelper - Class in org.apache.cassandra.db.rows
 
SerializationHelper(SerializationHeader) - Constructor for class org.apache.cassandra.db.rows.SerializationHelper
 
serialize(Batch, DataOutputPlus, int) - Method in class org.apache.cassandra.batchlog.Batch.Serializer
 
serialize(K, DataOutputPlus, ColumnFamilyStore) - Method in interface org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
 
serialize(IRowCacheEntry, DataOutputPlus) - Method in class org.apache.cassandra.cache.SerializingCacheProvider.RowCacheSerializer
 
serialize(C, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractCollectionCodec
 
serialize(Map<K, V>, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractMapCodec
 
serialize(T, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractTupleCodec
 
serialize(T, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractUDTCodec
 
serialize(Boolean, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveBooleanCodec
 
serialize(Byte, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveByteCodec
 
serialize(Double, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveDoubleCodec
 
serialize(Float, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveFloatCodec
 
serialize(Integer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveIntCodec
 
serialize(Long, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveLongCodec
 
serialize(Short, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveShortCodec
 
serialize(T, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Serialize the given value according to the CQL type handled by this codec.
serialize(TypeCodec<?>, ProtocolVersion, Object) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
 
serialize(EnumSet<ResultSet.Flag>) - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
 
serialize(AggregationSpecification, DataOutputPlus, int) - Method in class org.apache.cassandra.db.aggregation.AggregationSpecification.Serializer
 
serialize(GroupingState, DataOutputPlus, int, ClusteringComparator) - Method in class org.apache.cassandra.db.aggregation.GroupingState.Serializer
 
serialize(Clustering<?>, DataOutputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Clustering.Serializer
 
serialize(Clustering<?>, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Clustering.Serializer
 
serialize(ClusteringBoundOrBoundary<T>, DataOutputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.ClusteringBoundOrBoundary.Serializer
 
serialize(ClusteringPrefix<?>, DataOutputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.ClusteringPrefix.Serializer
 
serialize(Columns, DataOutputPlus) - Method in class org.apache.cassandra.db.Columns.Serializer
 
serialize(CommitLogPosition, DataOutputPlus) - Method in class org.apache.cassandra.db.commitlog.CommitLogPosition.CommitLogPositionSerializer
 
serialize(CounterMutation, DataOutputPlus, int) - Method in class org.apache.cassandra.db.CounterMutation.CounterMutationSerializer
 
serialize(DataRange, DataOutputPlus, int, TableMetadata) - Method in class org.apache.cassandra.db.DataRange.Serializer
 
serialize(DeletionTime, DataOutputPlus) - Method in class org.apache.cassandra.db.DeletionTime.Serializer
 
serialize(ClusteringIndexFilter, DataOutputPlus, int) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter.Serializer
 
serialize(ColumnFilter, DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Serializer
 
serialize(ColumnSubselection, DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.ColumnSubselection.Serializer
 
serialize(DataLimits, DataOutputPlus, int, ClusteringComparator) - Method in class org.apache.cassandra.db.filter.DataLimits.Serializer
 
serialize(RowFilter, DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.RowFilter.Serializer
 
serialize(DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.RowFilter.UserExpression
 
serialize(Mutation, DataOutputPlus, int) - Method in class org.apache.cassandra.db.Mutation.MutationSerializer
 
serialize(PartitionPosition, DataOutputPlus, int) - Method in class org.apache.cassandra.db.PartitionPosition.RowPositionSerializer
 
serialize(PartitionUpdate, DataOutputPlus, int) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.PartitionUpdateSerializer
 
serialize(UnfilteredPartitionIterator, ColumnFilter, DataOutputPlus, int) - Method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators.Serializer
 
serialize(ReadCommand, DataOutputPlus, int) - Method in class org.apache.cassandra.db.ReadCommand.Serializer
 
serialize(RowIndexEntry<T>, DataOutputPlus, ByteBuffer) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
 
serialize(DataOutputPlus, ByteBuffer) - Method in class org.apache.cassandra.db.RowIndexEntry
 
serialize(RowIndexEntry<IndexInfo>, DataOutputPlus, ByteBuffer) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
 
serialize(CellPath, DataOutputPlus) - Method in interface org.apache.cassandra.db.rows.CellPath.Serializer
 
serialize(EncodingStats, DataOutputPlus) - Method in class org.apache.cassandra.db.rows.EncodingStats.Serializer
 
serialize(UnfilteredRowIterator, ColumnFilter, DataOutputPlus, int) - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
 
serialize(UnfilteredRowIterator, ColumnFilter, DataOutputPlus, int, int) - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
 
serialize(Unfiltered, SerializationHelper, DataOutputPlus, int) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
serialize(Unfiltered, SerializationHelper, DataOutputPlus, long, int) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
serialize(Version, SerializationHeader.Component, DataOutputPlus) - Method in class org.apache.cassandra.db.SerializationHeader.Serializer
 
serialize(Slice, DataOutputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Slice.Serializer
 
serialize(Slices, DataOutputPlus, int) - Method in class org.apache.cassandra.db.Slices.Serializer
 
serialize(CassandraStreamHeader, DataOutputPlus, int) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.CassandraStreamHeaderSerializer
 
serialize(TruncateResponse, DataOutputPlus, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
 
serialize(AbstractBounds<T>, DataOutputPlus, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
 
serialize(T, DataOutputPlus, int) - Method in interface org.apache.cassandra.dht.IPartitionerDependentSerializer
Serialize the specified type into the specified DataOutputStream instance.
serialize(Token, DataOutputPlus) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
serialize(Token, ByteBuffer) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
serialize(Token, DataOutputPlus, int) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
 
serialize(RequestFailureReason, DataOutputPlus, int) - Method in class org.apache.cassandra.exceptions.RequestFailureReason.Serializer
 
serialize(IPartitioner, Collection<Token>, DataOutput) - Static method in class org.apache.cassandra.gms.TokenSerializer
 
serialize(SerializableHintMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.hints.HintMessage.Serializer
 
serialize(long, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
 
serialize(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf.LeafEntry
 
serialize(long, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf
 
serialize(long, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
 
serialize(T, DataOutputPlus) - Method in interface org.apache.cassandra.io.ISerializer
Serialize the specified type into the specified DataOutput instance.
serialize(In, DataOutputPlus, int) - Method in interface org.apache.cassandra.io.IVersionedAsymmetricSerializer
Serialize the specified type into the specified DataOutputStream instance.
serialize(IndexInfo, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.IndexInfo.Serializer
 
serialize(IndexSummary, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.IndexSummary.IndexSummarySerializer
 
serialize(Version, CompactionMetadata, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
 
serialize(Version, T, DataOutputPlus) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataComponentSerializer
Serialize metadata component to given output.
serialize(Map<MetadataType, MetadataComponent>, DataOutputPlus, Version) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
Serialize given metadata components
serialize(Map<MetadataType, MetadataComponent>, DataOutputPlus, Version) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
 
serialize(Version, StatsMetadata, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata.StatsMetadataSerializer
 
serialize(Version, ValidationMetadata, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata.ValidationMetadataSerializer
 
serialize(InetAddressAndPort, DataOutputPlus, int) - Method in class org.apache.cassandra.locator.InetAddressAndPort.FwdFrmSerializer
 
serialize(InetAddressAndPort, DataOutputPlus, int) - Method in class org.apache.cassandra.locator.InetAddressAndPort.Serializer
 
serialize(Message<T>, DataOutputPlus, int) - Method in class org.apache.cassandra.net.Message.Serializer
 
serialize(SyncNodePair, DataOutputPlus, int) - Method in class org.apache.cassandra.repair.SyncNodePair.NodePairSerializer
 
serialize(IndexMetadata, DataOutputPlus, int) - Method in class org.apache.cassandra.schema.IndexMetadata.Serializer
 
serialize(Collection<Mutation>, DataOutputPlus, int) - Method in class org.apache.cassandra.schema.MigrationManager.MigrationsSerializer
 
serialize(DataOutput) - Method in class org.apache.cassandra.schema.TableId
 
serialize(String) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
 
serialize(Boolean) - Method in class org.apache.cassandra.serializers.BooleanSerializer
 
serialize(Byte) - Method in class org.apache.cassandra.serializers.ByteSerializer
 
serialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
 
serialize(T) - Method in class org.apache.cassandra.serializers.CollectionSerializer
 
serialize(BigDecimal) - Method in class org.apache.cassandra.serializers.DecimalSerializer
 
serialize(Double) - Method in class org.apache.cassandra.serializers.DoubleSerializer
 
serialize(Duration) - Method in class org.apache.cassandra.serializers.DurationSerializer
 
serialize(Void) - Method in class org.apache.cassandra.serializers.EmptySerializer
 
serialize(Float) - Method in class org.apache.cassandra.serializers.FloatSerializer
 
serialize(InetAddress) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
 
serialize(Integer) - Method in class org.apache.cassandra.serializers.Int32Serializer
 
serialize(BigInteger) - Method in class org.apache.cassandra.serializers.IntegerSerializer
 
serialize(Long) - Method in class org.apache.cassandra.serializers.LongSerializer
 
serialize(Short) - Method in class org.apache.cassandra.serializers.ShortSerializer
 
serialize(Integer) - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
 
serialize(Long) - Method in class org.apache.cassandra.serializers.TimeSerializer
 
serialize(Date) - Method in class org.apache.cassandra.serializers.TimestampSerializer
 
serialize(T) - Method in class 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(ProtocolVersion) - 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(LZ4Compressor, ByteBuffer, int) - Static method in class org.apache.cassandra.streaming.async.StreamCompressionSerializer
 
serialize(DataOutputStreamPlus, int, StreamSession) - Method in class org.apache.cassandra.streaming.messages.OutgoingStreamMessage
 
serialize(StreamMessage, DataOutputStreamPlus, int, StreamSession) - Static method in class org.apache.cassandra.streaming.messages.StreamMessage
 
serialize(V, DataOutputStreamPlus, int, StreamSession) - Method in interface org.apache.cassandra.streaming.messages.StreamMessage.Serializer
 
serialize(StreamMessageHeader, DataOutputPlus, int) - Method in class org.apache.cassandra.streaming.messages.StreamMessageHeader.FileMessageHeaderSerializer
 
serialize(StreamRequest, DataOutputPlus, int) - Method in class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
 
serialize(StreamSummary, DataOutputPlus, int) - Method in class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
 
serialize(Tracing.TraceType) - Static method in enum org.apache.cassandra.tracing.Tracing.TraceType
 
serialize(EnumSet<Envelope.Header.Flag>) - Static method in enum org.apache.cassandra.transport.Envelope.Header.Flag
 
serialize(ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.transport.Event
 
serialize(BloomFilter, DataOutputPlus) - Static method in class org.apache.cassandra.utils.BloomFilterSerializer
 
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(IntervalTree<C, D, I>, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
 
serialize(DataOutputPlus, int) - Method in class org.apache.cassandra.utils.MerkleTree
 
serialize(MerkleTrees, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.MerkleTrees.MerkleTreesSerializer
 
serialize(DataOutputPlus) - Method in interface org.apache.cassandra.utils.obs.IBitSet
 
serialize(DataOutputPlus) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
serialize(TombstoneHistogram, DataOutputPlus) - Method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram.HistogramSerializer
 
serialize(UUID, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
 
serializeAsPartitionKey() - Method in interface org.apache.cassandra.db.ClusteringPrefix
 
serializeComparator(ByteBuffer) - Method in interface org.apache.cassandra.db.marshal.AbstractCompositeType.ParsedComparator
 
serializeData(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf
 
serializedSize(Batch, int) - Method in class org.apache.cassandra.batchlog.Batch.Serializer
 
serializedSize(IRowCacheEntry) - Method in class org.apache.cassandra.cache.SerializingCacheProvider.RowCacheSerializer
 
serializedSize() - Method in enum org.apache.cassandra.cql3.Operator
 
serializedSize(AggregationSpecification, int) - Method in class org.apache.cassandra.db.aggregation.AggregationSpecification.Serializer
 
serializedSize(GroupingState, int, ClusteringComparator) - Method in class org.apache.cassandra.db.aggregation.GroupingState.Serializer
 
serializedSize(Clustering<?>, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Clustering.Serializer
 
serializedSize(ClusteringBoundOrBoundary<T>, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.ClusteringBoundOrBoundary.Serializer
 
serializedSize(ClusteringPrefix<?>, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.ClusteringPrefix.Serializer
 
serializedSize(Columns) - Method in class org.apache.cassandra.db.Columns.Serializer
 
serializedSize(CommitLogPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogPosition.CommitLogPositionSerializer
 
serializedSize(CounterMutation, int) - Method in class org.apache.cassandra.db.CounterMutation.CounterMutationSerializer
 
serializedSize(int) - Method in class org.apache.cassandra.db.CounterMutation
 
serializedSize(DataRange, int, TableMetadata) - Method in class org.apache.cassandra.db.DataRange.Serializer
 
serializedSize(DeletionTime) - Method in class org.apache.cassandra.db.DeletionTime.Serializer
 
serializedSize(ClusteringIndexFilter, int) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter.Serializer
 
serializedSize(ColumnFilter, int) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Serializer
 
serializedSize(ColumnSubselection, int) - Method in class org.apache.cassandra.db.filter.ColumnSubselection.Serializer
 
serializedSize(DataLimits, int, ClusteringComparator) - Method in class org.apache.cassandra.db.filter.DataLimits.Serializer
 
serializedSize(RowFilter, int) - Method in class org.apache.cassandra.db.filter.RowFilter.Serializer
 
serializedSize(int) - Method in class org.apache.cassandra.db.filter.RowFilter.UserExpression
 
serializedSize(Mutation, int) - Method in class org.apache.cassandra.db.Mutation.MutationSerializer
 
serializedSize(int) - Method in class org.apache.cassandra.db.Mutation
 
serializedSize(PartitionPosition, int) - Method in class org.apache.cassandra.db.PartitionPosition.RowPositionSerializer
 
serializedSize(PartitionUpdate, int) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.PartitionUpdateSerializer
 
serializedSize(ReadCommand, int) - Method in class org.apache.cassandra.db.ReadCommand.Serializer
 
serializedSize(CellPath) - Method in interface org.apache.cassandra.db.rows.CellPath.Serializer
 
serializedSize(EncodingStats) - Method in class org.apache.cassandra.db.rows.EncodingStats.Serializer
 
serializedSize(UnfilteredRowIterator, ColumnFilter, int, int) - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
 
serializedSize(Unfiltered, SerializationHelper, int) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
serializedSize(Unfiltered, SerializationHelper, long, int) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
serializedSize(Version, SerializationHeader.Component) - Method in class org.apache.cassandra.db.SerializationHeader.Serializer
 
serializedSize(Slice, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Slice.Serializer
 
serializedSize(Slices, int) - Method in class org.apache.cassandra.db.Slices.Serializer
 
serializedSize(CassandraStreamHeader, int) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.CassandraStreamHeaderSerializer
 
serializedSize(TruncateResponse, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
 
serializedSize(AbstractBounds<T>, int) - Method in class org.apache.cassandra.dht.AbstractBounds.AbstractBoundsSerializer
 
serializedSize(T, int) - Method in interface org.apache.cassandra.dht.IPartitionerDependentSerializer
Calculate serialized size of object without actually serializing.
serializedSize(Token, int) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
 
serializedSize(RequestFailureReason, int) - Method in class org.apache.cassandra.exceptions.RequestFailureReason.Serializer
 
serializedSize(SerializableHintMessage, int) - Method in class org.apache.cassandra.hints.HintMessage.Serializer
 
serializedSize() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
 
serializedSize() - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
serializedSize(T) - Method in interface org.apache.cassandra.io.ISerializer
 
serializedSize(In, int) - Method in interface org.apache.cassandra.io.IVersionedAsymmetricSerializer
Calculate serialized size of object without actually serializing.
serializedSize(IndexInfo) - Method in class org.apache.cassandra.io.sstable.IndexInfo.Serializer
 
serializedSize(Version, CompactionMetadata) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
 
serializedSize(Version, T) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataComponentSerializer
Calculate and return serialized size.
serializedSize(Version, StatsMetadata) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata.StatsMetadataSerializer
 
serializedSize(Version, ValidationMetadata) - Method in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata.ValidationMetadataSerializer
 
serializedSize(InetAddressAndPort, int) - Method in class org.apache.cassandra.locator.InetAddressAndPort.FwdFrmSerializer
 
serializedSize(InetAddressAndPort, int) - Method in class org.apache.cassandra.locator.InetAddressAndPort.Serializer
 
serializedSize(int) - Method in class org.apache.cassandra.net.Message
Serialized size of the entire message, for the provided messaging version.
serializedSize(SyncNodePair, int) - Method in class org.apache.cassandra.repair.SyncNodePair.NodePairSerializer
 
serializedSize(IndexMetadata, int) - Method in class org.apache.cassandra.schema.IndexMetadata.Serializer
 
serializedSize(Collection<Mutation>, int) - Method in class org.apache.cassandra.schema.MigrationManager.MigrationsSerializer
 
serializedSize() - Method in class org.apache.cassandra.schema.TableId
 
serializedSize(ProtocolVersion) - Method in class org.apache.cassandra.service.pager.PagingState
 
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(StreamMessage, int) - Static method in class org.apache.cassandra.streaming.messages.StreamMessage
 
serializedSize(V, int) - Method in interface org.apache.cassandra.streaming.messages.StreamMessage.Serializer
 
serializedSize(StreamMessageHeader, int) - Method in class org.apache.cassandra.streaming.messages.StreamMessageHeader.FileMessageHeaderSerializer
 
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(ProtocolVersion) - Method in class org.apache.cassandra.transport.Event
 
serializedSize() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
 
serializedSize() - Method in class org.apache.cassandra.utils.BloomFilter
 
serializedSize(BloomFilter) - Static method in class org.apache.cassandra.utils.BloomFilterSerializer
Calculates a serialized size of the given Bloom Filter
serializedSize(Boolean, int) - Method in class org.apache.cassandra.utils.BooleanSerializer
 
serializedSize(EstimatedHistogram) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
serializedSize() - Method in interface org.apache.cassandra.utils.IFilter
 
serializedSize(IntervalTree<C, D, I>, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
 
serializedSize(int) - Method in class org.apache.cassandra.utils.MerkleTree
 
serializedSize(MerkleTrees, int) - Method in class org.apache.cassandra.utils.MerkleTrees.MerkleTreesSerializer
 
serializedSize() - Method in interface org.apache.cassandra.utils.obs.IBitSet
 
serializedSize() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
serializedSize(TombstoneHistogram) - Method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram.HistogramSerializer
 
serializedSize(UUID, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
 
serializedSizeEndOfPartition() - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
serializedSizeForMessaging(SerializationHeader, ColumnFilter, boolean) - Method in class org.apache.cassandra.db.SerializationHeader.Serializer
 
serializedSizeInternal(int) - Method in class org.apache.cassandra.db.filter.AbstractClusteringIndexFilter
 
serializedSizeInternal(int) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
 
serializedSizeInternal(int) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
 
serializedSizeWithLength(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
serializedSizeWithShortLength(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
serializedSizeWithVIntLength(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
serializedSubsetSize(Collection<ColumnMetadata>, Columns) - Method in class org.apache.cassandra.db.Columns.Serializer
 
serializedValues(Iterator<Cell<?>>) - Method in class org.apache.cassandra.db.marshal.CollectionType
 
serializedValues(Iterator<Cell<?>>) - Method in class org.apache.cassandra.db.marshal.ListType
 
serializedValues(Iterator<Cell<?>>) - Method in class org.apache.cassandra.db.marshal.MapType
 
serializedValues(Iterator<Cell<?>>) - Method in class org.apache.cassandra.db.marshal.SetType
 
serializedValueSize(Object, ProtocolVersion) - Method in enum org.apache.cassandra.transport.DataType
 
serializeEvent(ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.transport.Event.SchemaChange
 
serializeEvent(ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.transport.Event
 
serializeEvent(ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.transport.Event.StatusChange
 
serializeEvent(ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.transport.Event.TopologyChange
 
serializeField(T, int, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractTupleCodec
Serialize an individual field in an object, as part of serializing the whole object to a CQL tuple (see TypeCodec.AbstractTupleCodec.serialize(Object, ProtocolVersion)).
serializeField(T, String, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractUDTCodec
Serialize an individual field in an object, as part of serializing the whole object to a CQL UDT (see TypeCodec.AbstractUDTCodec.serialize(Object, ProtocolVersion)).
serializeForCache(RowIndexEntry<T>, DataOutputPlus) - Method in interface org.apache.cassandra.db.RowIndexEntry.IndexSerializer
 
serializeForCache(DataOutputPlus) - Method in class org.apache.cassandra.db.RowIndexEntry
 
serializeForCache(RowIndexEntry<IndexInfo>, DataOutputPlus) - Method in class org.apache.cassandra.db.RowIndexEntry.Serializer
 
serializeForMessaging(SerializationHeader, ColumnFilter, DataOutputPlus, boolean) - Method in class org.apache.cassandra.db.SerializationHeader.Serializer
 
serializeForNativeProtocol(Iterator<Cell<?>>, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.CollectionType
 
serializeForNativeProtocol(Iterator<Cell<?>>, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.UserType
 
serializeHeader(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
 
serializeInternal(DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.AbstractClusteringIndexFilter
 
serializeInternal(DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
 
serializeInternal(DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
 
serializeNoBoxing(boolean, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveBooleanCodec
 
serializeNoBoxing(byte, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveByteCodec
 
serializeNoBoxing(double, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveDoubleCodec
 
serializeNoBoxing(float, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveFloatCodec
 
serializeNoBoxing(int, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveIntCodec
 
serializeNoBoxing(long, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveLongCodec
 
serializeNoBoxing(short, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveShortCodec
 
serializeOffsets(DataOutputBuffer, int[], int) - Static method in class org.apache.cassandra.db.RowIndexEntry.Serializer
 
serializeOldBfFormat(DataOutputPlus) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
 
serializeOverflowCollisions(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf
 
serializer - Static variable in class org.apache.cassandra.batchlog.Batch
 
Serializer() - Constructor for class org.apache.cassandra.batchlog.Batch.Serializer
 
serializer - Static variable in class org.apache.cassandra.db.aggregation.AggregationSpecification
 
Serializer() - Constructor for class org.apache.cassandra.db.aggregation.AggregationSpecification.Serializer
 
serializer - Static variable in class org.apache.cassandra.db.aggregation.GroupingState
 
Serializer() - Constructor for class org.apache.cassandra.db.aggregation.GroupingState.Serializer
 
serializer - Static variable in interface org.apache.cassandra.db.Clustering
 
Serializer() - Constructor for class org.apache.cassandra.db.Clustering.Serializer
 
serializer - Static variable in interface org.apache.cassandra.db.ClusteringBoundOrBoundary
 
Serializer() - Constructor for class org.apache.cassandra.db.ClusteringBoundOrBoundary.Serializer
 
serializer - Static variable in interface org.apache.cassandra.db.ClusteringPrefix
 
Serializer() - Constructor for class org.apache.cassandra.db.ClusteringPrefix.Serializer
 
serializer - Static variable in class org.apache.cassandra.db.Columns
 
Serializer() - Constructor for class org.apache.cassandra.db.Columns.Serializer
 
serializer - Static variable in class org.apache.cassandra.db.commitlog.CommitLogPosition
 
serializer(ISerializer<T>) - Static method in class org.apache.cassandra.db.commitlog.IntervalSet
 
serializer - Static variable in class org.apache.cassandra.db.CounterMutation
 
serializer - Static variable in class org.apache.cassandra.db.DataRange
 
Serializer() - Constructor for class org.apache.cassandra.db.DataRange.Serializer
 
serializer - Static variable in class org.apache.cassandra.db.DeletionTime
 
Serializer() - Constructor for class org.apache.cassandra.db.DeletionTime.Serializer
 
serializer - Static variable in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
 
serializer - Static variable in class org.apache.cassandra.db.filter.ColumnFilter
 
Serializer() - Constructor for class org.apache.cassandra.db.filter.ColumnFilter.Serializer
 
serializer - Static variable in class org.apache.cassandra.db.filter.ColumnSubselection
 
Serializer() - Constructor for class org.apache.cassandra.db.filter.ColumnSubselection.Serializer
 
serializer - Static variable in class org.apache.cassandra.db.filter.DataLimits
 
Serializer() - Constructor for class org.apache.cassandra.db.filter.DataLimits.Serializer
 
serializer - Static variable in class org.apache.cassandra.db.filter.RowFilter
 
Serializer() - Constructor for class org.apache.cassandra.db.filter.RowFilter.Serializer
 
serializer - Variable in class org.apache.cassandra.db.marshal.ListType
 
serializer - Static variable in class org.apache.cassandra.db.Mutation
 
serializer - Static variable in interface org.apache.cassandra.db.PartitionPosition
 
serializer - Static variable in class org.apache.cassandra.db.partitions.PartitionUpdate
 
Serializer() - Constructor for class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators.Serializer
 
serializer - Static variable in class org.apache.cassandra.db.ReadCommand
 
Serializer() - Constructor for class org.apache.cassandra.db.ReadCommand.Serializer
 
Serializer(SchemaProvider) - Constructor for class org.apache.cassandra.db.ReadCommand.Serializer
 
serializer - Static variable in class org.apache.cassandra.db.ReadResponse
 
Serializer(Version, SerializationHeader) - Constructor for class org.apache.cassandra.db.RowIndexEntry.Serializer
 
serializer - Static variable in class org.apache.cassandra.db.rows.Cell
 
serializer - Static variable in class org.apache.cassandra.db.rows.EncodingStats
 
Serializer() - Constructor for class org.apache.cassandra.db.rows.EncodingStats.Serializer
 
serializer - Static variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
 
serializer - Static variable in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
serializer - Static variable in class org.apache.cassandra.db.SerializationHeader
 
Serializer() - Constructor for class org.apache.cassandra.db.SerializationHeader.Serializer
 
serializer - Static variable in class org.apache.cassandra.db.Slice
 
Serializer() - Constructor for class org.apache.cassandra.db.Slice.Serializer
 
serializer - Static variable in class org.apache.cassandra.db.Slices
 
Serializer() - Constructor for class org.apache.cassandra.db.Slices.Serializer
 
serializer - Static variable in class org.apache.cassandra.db.SnapshotCommand
 
serializer - Static variable in class org.apache.cassandra.db.streaming.CassandraStreamHeader
 
serializer - Static variable in class org.apache.cassandra.db.streaming.ComponentManifest
 
serializer - Static variable in class org.apache.cassandra.db.streaming.CompressionInfo
 
serializer - Static variable in class org.apache.cassandra.db.TruncateRequest
 
serializer - Static variable in class org.apache.cassandra.db.TruncateResponse
 
serializer - Static variable in class org.apache.cassandra.dht.Token
 
serializer - Static variable in enum org.apache.cassandra.exceptions.RequestFailureReason
 
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.HeartBeatState
 
serializer - Static variable in class org.apache.cassandra.gms.VersionedValue
 
serializer - Static variable in class org.apache.cassandra.hints.Hint
 
serializer - Static variable in class org.apache.cassandra.hints.HintMessage
 
Serializer() - Constructor for class org.apache.cassandra.hints.HintMessage.Serializer
 
serializer - Static variable in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
 
serializer(Version, SerializationHeader) - Static method in class org.apache.cassandra.io.sstable.IndexInfo
 
Serializer(Version, List<AbstractType<?>>) - Constructor for class org.apache.cassandra.io.sstable.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 - Static variable in class org.apache.cassandra.net.Message
 
serializer - Static variable in class org.apache.cassandra.net.NoPayload
 
serializer() - Method in enum org.apache.cassandra.net.Verb
 
serializer - Static variable in class org.apache.cassandra.repair.messages.CleanupMessage
 
serializer - Static variable in class org.apache.cassandra.repair.messages.FailSession
 
serializer - Static variable in class org.apache.cassandra.repair.messages.FinalizeCommit
 
serializer - Static variable in class org.apache.cassandra.repair.messages.FinalizePromise
 
serializer - Static variable in class org.apache.cassandra.repair.messages.FinalizePropose
 
serializer - Static variable in class org.apache.cassandra.repair.messages.PrepareConsistentRequest
 
serializer - Static variable in class org.apache.cassandra.repair.messages.PrepareConsistentResponse
 
serializer - Static variable in class org.apache.cassandra.repair.messages.PrepareMessage
 
serializer - Static variable in class org.apache.cassandra.repair.messages.SnapshotMessage
 
serializer - Static variable in class org.apache.cassandra.repair.messages.StatusRequest
 
serializer - Static variable in class org.apache.cassandra.repair.messages.StatusResponse
 
serializer - Static variable in class org.apache.cassandra.repair.messages.SyncRequest
 
serializer - Static variable in class org.apache.cassandra.repair.messages.SyncResponse
 
serializer - Static variable in class org.apache.cassandra.repair.messages.ValidationRequest
 
serializer - Static variable in class org.apache.cassandra.repair.messages.ValidationResponse
 
serializer - Static variable in class org.apache.cassandra.repair.RepairJobDesc
 
serializer - Static variable in class org.apache.cassandra.repair.SyncNodePair
 
serializer - Static variable in class org.apache.cassandra.schema.CompressionParams
 
serializer - Static variable in class org.apache.cassandra.schema.IndexMetadata
 
Serializer() - Constructor for class org.apache.cassandra.schema.IndexMetadata.Serializer
 
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.messages.CompleteMessage
 
serializer - Static variable in class org.apache.cassandra.streaming.messages.IncomingStreamMessage
 
serializer - Static variable in class org.apache.cassandra.streaming.messages.KeepAliveMessage
 
serializer - Static variable in class org.apache.cassandra.streaming.messages.OutgoingStreamMessage
 
serializer - Static variable in class org.apache.cassandra.streaming.messages.PrepareAckMessage
 
serializer - Static variable in class org.apache.cassandra.streaming.messages.PrepareSynAckMessage
 
serializer - Static variable in class org.apache.cassandra.streaming.messages.PrepareSynMessage
 
serializer - Static variable in class org.apache.cassandra.streaming.messages.ReceivedMessage
 
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.messages.StreamMessageHeader
 
serializer - Static variable in class org.apache.cassandra.streaming.SessionSummary
 
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.MerkleTrees
 
serializer - Static variable in class org.apache.cassandra.utils.streamhist.TombstoneHistogram
 
serializer - Static variable in class org.apache.cassandra.utils.UUIDSerializer
 
serializerForIntraNode() - Static method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators
 
serializeSelection(DataOutputPlus, int) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
serializeSelection(DataOutputPlus, int) - Method in class org.apache.cassandra.db.ReadCommand
 
serializeSelection(DataOutputPlus, int) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
serializeStaticRow(Row, SerializationHelper, DataOutputPlus, int) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
serializeSubset(Collection<ColumnMetadata>, Columns, DataOutputPlus) - Method in class org.apache.cassandra.db.Columns.Serializer
If both ends have a pre-shared superset of the columns we are serializing, we can send them much more efficiently.
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
 
SerializingCacheProvider.RowCacheSerializer - Class in org.apache.cassandra.cache
 
serialVersionUID - Static variable in class org.apache.cassandra.dht.Range
 
Server - Class in org.apache.cassandra.transport
 
Server.Builder - Class in org.apache.cassandra.transport
 
Server.ConnectionTracker - Class in org.apache.cassandra.transport
 
Server.EventNotifier - Class in org.apache.cassandra.transport
 
server_encryption_options - Variable in class org.apache.cassandra.config.Config
 
ServerConnection - Class in org.apache.cassandra.transport
 
serverEncOptions - Variable in class org.apache.cassandra.tools.LoaderOptions
 
ServerEncryptionOptions() - Constructor for class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
ServerEncryptionOptions(String, String, String, String, List<String>, String, List<String>, String, String, boolean, boolean, Boolean, EncryptionOptions.ServerEncryptionOptions.InternodeEncryption, boolean) - Constructor for class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
ServerEncryptionOptions(EncryptionOptions.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() - Method in class org.apache.cassandra.db.streaming.CassandraIncomingFile
 
session - Variable in class org.apache.cassandra.db.streaming.CassandraStreamReader
 
session - Variable in class org.apache.cassandra.db.streaming.CassandraStreamWriter
 
session() - Method in interface org.apache.cassandra.streaming.IncomingStream
 
session - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionPreparedEvent
 
session - Variable in exception org.apache.cassandra.streaming.StreamReceiveException
 
session - Variable in class org.apache.cassandra.streaming.StreamTask
StreamSession that this task belongs
SESSION_ID - Static variable in class org.apache.cassandra.repair.consistent.LocalSessionInfo
 
sessionCompleted(LocalSession) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
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
 
sessionExists(UUID) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
determines if a local session exists
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
 
sessionHasData(LocalSession) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
sessionID - Variable in class org.apache.cassandra.repair.consistent.ConsistentSession
 
sessionID - Variable in class org.apache.cassandra.repair.messages.FailSession
 
sessionID - Variable in class org.apache.cassandra.repair.messages.FinalizeCommit
 
sessionID - Variable in class org.apache.cassandra.repair.messages.FinalizePromise
 
sessionID - Variable in class org.apache.cassandra.repair.messages.FinalizePropose
 
sessionID - Variable in class org.apache.cassandra.repair.messages.StatusRequest
 
sessionID - Variable in class org.apache.cassandra.repair.messages.StatusResponse
 
sessionId - Variable in class org.apache.cassandra.repair.RepairJobDesc
RepairSession id
sessionId - Variable in class org.apache.cassandra.repair.RepairSessionResult
 
sessionId - Variable in class org.apache.cassandra.tracing.TraceState
 
sessionIdBytes - Variable in class org.apache.cassandra.tracing.TraceState
 
sessionIndex - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
 
sessionIndex - Variable in class org.apache.cassandra.streaming.messages.StreamMessageHeader
 
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(boolean, Set<Range<Token>>) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
SessionInfo - Class in org.apache.cassandra.streaming
Stream session info.
SessionInfo(InetAddressAndPort, int, InetAddressAndPort, 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.repair.consistent.admin.PendingStat.Builder
 
sessions - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStat
 
sessions - Variable in class org.apache.cassandra.streaming.StreamState
 
SESSIONS - Static variable in class org.apache.cassandra.tracing.TraceKeyspace
 
sessions - Variable in class org.apache.cassandra.tracing.Tracing
 
SessionSummary - Class in org.apache.cassandra.streaming
 
SessionSummary(InetAddressAndPort, InetAddressAndPort, Collection<StreamSummary>, Collection<StreamSummary>) - Constructor for class org.apache.cassandra.streaming.SessionSummary
 
set(T) - Method in interface org.apache.cassandra.concurrent.ExecutorLocal
Before a task has been run, this will be called with the value from the thread that scheduled the task, and after the task is finished, the value that was previously retrieved from this thread is restored.
set(ExecutorLocals) - Static method in class org.apache.cassandra.concurrent.ExecutorLocals
 
set(CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
set(DataType, boolean) - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the type of sets of elementType elements.
set(DataType) - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the type of "not frozen" sets of elementType elements.
set(int, V, Class<V>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided value of the provided Java class.
set(int, V, TypeToken<V>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided value of the provided Java type.
set(int, V, TypeCodec<V>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided value, converted using the given TypeCodec.
set(String, V, Class<V>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided value of the provided Java class.
set(String, V, TypeToken<V>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided value of the provided Java type.
set(String, V, TypeCodec<V>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided value, converted using the given TypeCodec.
set(TypeCodec<T>) - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return a newly-created codec for the CQL type set whose element type is determined by the given element codec.
set(InetAddressAndPort, int) - Method in class org.apache.cassandra.net.EndpointMessagingVersions
 
set(ClientWarn.State) - Method in class org.apache.cassandra.service.ClientWarn
 
set(TraceState) - Method in class org.apache.cassandra.tracing.Tracing
 
set(int, V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
set(T) - Method in class org.apache.cassandra.utils.DefaultValue
 
Set() - Constructor for class org.apache.cassandra.utils.IntegerInterval.Set
 
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(T) - Method in class org.apache.cassandra.utils.Wrapped
 
set(boolean) - Method in class org.apache.cassandra.utils.WrappedBoolean
 
setaccepted_protocols(List<String>) - Method in class org.apache.cassandra.config.EncryptionOptions
Sets accepted TLS protocols for this channel.
setAccess(String) - Method in class org.apache.cassandra.tools.JMXTool.Attribute
 
setAllTermsToLowerCase(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
setAllTermsToUpperCase(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
setAttachment(ByteBuffer, Object) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
setAttributes(JMXTool.Attribute[]) - Method in class org.apache.cassandra.tools.JMXTool.Info
 
setAuditLoggingOptions(AuditLogOptions) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setAuthenticator(IAuthenticator) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setAuthorizer(IAuthorizer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setAutomaticSSTableUpgradeEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setAutomaticSSTableUpgradeEnabled(boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
setAutomaticSSTableUpgradeEnabled(boolean) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Set if automatic sstable upgrade should be enabled
setAutoOptimiseFullRepairStreams(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setAutoOptimiseFullRepairStreams(boolean) - Method in class org.apache.cassandra.service.StorageService
 
setAutoOptimiseFullRepairStreams(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setAutoOptimiseIncRepairStreams(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setAutoOptimiseIncRepairStreams(boolean) - Method in class org.apache.cassandra.service.StorageService
 
setAutoOptimiseIncRepairStreams(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setAutoOptimisePreviewRepairStreams(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setAutoOptimisePreviewRepairStreams(boolean) - Method in class org.apache.cassandra.service.StorageService
 
setAutoOptimisePreviewRepairStreams(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setAutoSnapshot(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setBackPressureEnabled(boolean) - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Deprecated.
setBackPressureEnabled(boolean) - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
setBatch(UUID) - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
 
setBatchlogReplayThrottle(int) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetBatchlogReplayThrottle - Class in org.apache.cassandra.tools.nodetool
 
SetBatchlogReplayThrottle() - Constructor for class org.apache.cassandra.tools.nodetool.SetBatchlogReplayThrottle
 
setBatchlogReplayThrottleInKB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setBatchlogReplayThrottleInKB(int) - Method in class org.apache.cassandra.service.StorageService
 
setBatchlogReplayThrottleInKB(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setBatchSizeFailThresholdInKB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setBatchSizeFailureThreshold(int) - Method in class org.apache.cassandra.service.StorageService
 
setBatchSizeFailureThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Sets the threshold for rejecting queries due to a large batch size
setBatchSizeWarnThreshold(int) - Method in class org.apache.cassandra.service.StorageService
 
setBatchSizeWarnThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Sets the threshold for warning queries due to a large batch size
setBatchSizeWarnThresholdInKB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setBindVariables(List<ColumnIdentifier>) - Method in class org.apache.cassandra.cql3.CQLStatement.Raw
 
setBool(int, boolean) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided boolean.
setBool(String, boolean) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided boolean.
setBoolean(boolean) - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
Sets the value into system properties.
setBootstrapState(SystemKeyspace.BootstrapState) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
setBroadcastAddress(InetAddress) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setBroadcastInetAddress(InetAddress) - Static method in class org.apache.cassandra.utils.FBUtilities
THIS IS FOR TESTING ONLY!!
setBroadcastInetAddressAndPort(InetAddressAndPort) - Static method in class org.apache.cassandra.utils.FBUtilities
THIS IS FOR TESTING ONLY!!
setBroadcastRpcAddress(InetAddress) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setByte(int, byte) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Set the ith value to the provided byte.
setByte(String, byte) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided byte.
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
 
setByte(long, int, byte) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
setByteBuffer(ByteBuffer, long, int) - Method in class org.apache.cassandra.io.util.Memory
 
setByteBufferCapacity(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
setBytes(int, ByteBuffer) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided byte buffer.
setBytes(String, ByteBuffer) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided byte buffer.
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
 
setBytesUnsafe(int, ByteBuffer) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided byte buffer.
setBytesUnsafe(String, ByteBuffer) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided byte buffer.
setCacheCapacities(int, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetCacheCapacity - Class in org.apache.cassandra.tools.nodetool
 
SetCacheCapacity() - Constructor for class org.apache.cassandra.tools.nodetool.SetCacheCapacity
 
setCachedReplicaRowsFailThreshold(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCachedReplicaRowsFailThreshold(int) - Method in class org.apache.cassandra.service.StorageService
 
setCachedReplicaRowsFailThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Sets the number of rows cached at the coordinator before filtering/index queries fail outright.
setCachedReplicaRowsWarnThreshold(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCachedReplicaRowsWarnThreshold(int) - Method in class org.apache.cassandra.service.StorageService
 
setCachedReplicaRowsWarnThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Sets the number of rows cached at the coordinator before filtering/index queries log a warning.
setCacheKeysToSave(int, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetCacheKeysToSave - Class in org.apache.cassandra.tools.nodetool
 
SetCacheKeysToSave() - Constructor for class org.apache.cassandra.tools.nodetool.SetCacheKeysToSave
 
setCapacity(long) - Method in interface org.apache.cassandra.cache.CacheSize
 
setCapacity(long) - Method in class org.apache.cassandra.cache.CaffeineCache
 
setCapacity(long) - Method in class org.apache.cassandra.cache.ChunkCache
 
setCapacity(long) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
setCapacity(long) - Method in class org.apache.cassandra.cache.SerializingCache
 
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
 
setCasContentionTimeout(long) - Method in class org.apache.cassandra.service.StorageService
 
setCasContentionTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setCaseSensitive(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
 
setCaseSensitive(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
setCDCEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCDCSpaceInMB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCDCState(CommitLogSegment.CDCState) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
Change the current cdcState on this CommitLogSegment.
setCheckForDuplicateRowsDuringCompaction(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCheckForDuplicateRowsDuringReads(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setClientMode(boolean) - Static method in class org.apache.cassandra.config.Config
setClosed() - Method in class org.apache.cassandra.streaming.async.NettyStreamingMessageSender
For testing purposes only.
setColumnIndexCacheSize(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setColumnIndexCacheSize(int) - Method in class org.apache.cassandra.service.StorageService
 
setColumnIndexCacheSize(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Sets the threshold for skipping the column index when caching partition info
setColumnIndexSize(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCommitFailurePolicy(Config.CommitFailurePolicy) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCommitLogCompression(ParameterizedClass) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCommitLogLocation(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCommitLogMaxCompressionBuffersPerPool(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCommitLogSegmentMgrProvider(Function<CommitLog, AbstractCommitLogSegmentManager>) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCommitLogSegmentSize(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCommitLogSync(Config.CommitLogSync) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCommitLogSyncGroupWindow(double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCommitLogSyncPeriod(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCompactionParameters(Map<String, String>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setCompactionParameters(Map<String, String>) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Sets the compaction parameters locally for this node Note that this will be set until an ALTER with compaction = {..} is executed or the node is restarted
setCompactionParametersJson(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setCompactionParametersJson(String) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Sets the compaction parameters locally for this node Note that this will be set until an ALTER with compaction = {..} is executed or the node is restarted
setCompactionThreshold(String, String, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
Set the compaction threshold
SetCompactionThreshold - Class in org.apache.cassandra.tools.nodetool
 
SetCompactionThreshold() - Constructor for class org.apache.cassandra.tools.nodetool.SetCompactionThreshold
 
setCompactionThresholds(int, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setCompactionThresholds(int, int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Sets the maximum and maximum number of SSTables in queue before compaction kicks off
setCompactionThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetCompactionThroughput - Class in org.apache.cassandra.tools.nodetool
 
SetCompactionThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.SetCompactionThroughput
 
setCompactionThroughputMbPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCompactionThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
 
setCompactionThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setCompactionType(OperationType) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
setCompactStorage() - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
 
setComplexDeletionTime(ColumnMetadata) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
setComplexDeletionTimeForOverwrite(ColumnMetadata) - Method in class org.apache.cassandra.cql3.UpdateParameters
 
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 locally for this node
setCompressionParametersJson(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setCompressionParametersJson(String) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
setCompressor(Compressor) - Method in class org.apache.cassandra.transport.Connection
 
setConcurrency(String, int, int) - Method in class org.apache.cassandra.service.StorageService
 
setConcurrency(String, int, int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Sets the concurrency setting for processing stages
setConcurrency(String, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetConcurrency - Class in org.apache.cassandra.tools.nodetool
 
SetConcurrency() - Constructor for class org.apache.cassandra.tools.nodetool.SetConcurrency
 
setConcurrentCompactors(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setConcurrentCompactors(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
setConcurrentCompactors(int) - Method in class org.apache.cassandra.service.StorageService
 
setConcurrentCompactors(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setConcurrentCompactors(int) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetConcurrentCompactors - Class in org.apache.cassandra.tools.nodetool
 
SetConcurrentCompactors() - Constructor for class org.apache.cassandra.tools.nodetool.SetConcurrentCompactors
 
setConcurrentCounterWriters(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setConcurrentReaders(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setConcurrentValidations(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setConcurrentValidations() - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
setConcurrentValidators(int) - Method in class org.apache.cassandra.service.StorageService
 
setConcurrentValidators(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setConcurrentViewBuilders(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setConcurrentViewBuilders(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
setConcurrentViewBuilders(int) - Method in class org.apache.cassandra.service.StorageService
 
setConcurrentViewBuilders(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setConcurrentViewBuilders(int) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetConcurrentViewBuilders - Class in org.apache.cassandra.tools.nodetool
 
SetConcurrentViewBuilders() - Constructor for class org.apache.cassandra.tools.nodetool.SetConcurrentViewBuilders
 
setConcurrentViewWriters(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setConcurrentWriters(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setConnectionFactory(StreamConnectionFactory) - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
setConsecutiveMessageErrorsThreshold(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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 class org.apache.cassandra.concurrent.ImmediateExecutor
 
setCorePoolSize(int) - Method in interface org.apache.cassandra.concurrent.ResizableThreadPool
Allows user to resize maximum size of the thread pool.
setCorePoolSize(int) - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
setCorePoolSize(int) - Method in enum org.apache.cassandra.concurrent.Stage
Allows user to resize core thread pool size
setCoreThreads(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledSingleThreadExecutor
 
setCoreThreads(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
Deprecated.
setCoreThreads(int) - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
Deprecated.
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.
setCoreViewBuildThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
setCoreViewBuildThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Allows user to resize maximum size of the view build thread pool.
setCorruptedTombstoneStrategy(Config.CorruptedTombstoneStrategy) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCorruptedTombstoneStrategy(String) - Method in class org.apache.cassandra.service.StorageService
 
setCorruptedTombstoneStrategy(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
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
 
setCounterWriteRpcTimeout(long) - Method in class org.apache.cassandra.service.StorageService
 
setCounterWriteRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
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.sstable.format.SSTableReader
Set the value of CRC check chance.
setCrcCheckChance(double) - Method in class org.apache.cassandra.schema.CompressionParams
 
setCredentialsCacheMaxEntries(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCredentialsUpdateInterval(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCredentialsValidity(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCrossNodeTimeout(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCustomPayload(Map<String, ByteBuffer>) - Method in class org.apache.cassandra.transport.Message
 
setDate(int, LocalDate) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Set the ith value to the provided date (without time).
setDate(String, LocalDate) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided date (without time).
setDecimal(int, BigDecimal) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided big decimal.
setDecimal(String, BigDecimal) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided big decimal.
setDeleteSourceOnSuccess(Configuration, boolean) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
setDiagnosticEventsEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setDigestVersion(int) - Method in class org.apache.cassandra.db.ReadCommand
Sets the digest version, for when digest for that command is requested.
setDirectByteBuffer(ByteBuffer, long, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
setDisableSTCSInL0(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setDisableSTCSInL0(boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
setDisableSTCSInL0(boolean) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
 
setDiscarded() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
Indicate the memory and resources owned by this allocator are no longer referenced, and can be reclaimed/reused.
setDiscarded() - Method in class org.apache.cassandra.utils.memory.NativeAllocator
 
setDiscarded() - Method in class org.apache.cassandra.utils.memory.SlabAllocator
 
setDiscarding(OpOrder.Barrier, AtomicReference<CommitLogPosition>) - Method in class org.apache.cassandra.db.Memtable
 
setDiscarding() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
Mark this allocator reclaiming; this will permit any outstanding allocations to temporarily overshoot the maximum memory limit so that flushing can begin immediately
setDiskAccessMode(Config.DiskAccessMode) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setDiskFailurePolicy(Config.DiskFailurePolicy) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setDouble(int, double) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided double.
setDouble(String, double) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided double.
setDriverName(String) - Method in class org.apache.cassandra.service.ClientState
 
setDriverVersion(String) - Method in class org.apache.cassandra.service.ClientState
 
setDynamicBadnessThreshold(double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setDynamicResetInterval(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setDynamicUpdateInterval(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setDynamicUpdateInterval(int) - Method in class org.apache.cassandra.service.StorageService
 
setDynamicUpdateInterval(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
SetElement(Term.Raw, Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.SetElement
 
setEnabled(Boolean) - Method in class org.apache.cassandra.config.EncryptionOptions
Sets if encryption should be enabled for this channel.
setEnableDropCompactStorage(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setEnableMaterializedViews(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setEnableSASIIndexes(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setEncryptionContext(EncryptionContext) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setEndpointLimit(long) - Static method in class org.apache.cassandra.transport.ClientResourceLimits
 
setEndpointSnitch(IEndpointSnitch) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setEventHandler(SimpleClient.EventHandler) - Method in class org.apache.cassandra.transport.SimpleClient
 
setFailure(Throwable) - Method in class org.apache.cassandra.net.AsyncChannelPromise
 
setFailure(Throwable) - Method in class org.apache.cassandra.net.AsyncPromise
 
SetField(FieldIdentifier, Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.SetField
 
setFloat(int, float) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided float.
setFloat(String, float) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided float.
setFlushCompression(Config.FlushCompression) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setForSlice(Slice) - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
 
setFSErrorHandler(FSErrorHandler) - Static method in class org.apache.cassandra.io.util.FileUtils
 
setGcLogThresholdInMs(long) - Method in class org.apache.cassandra.service.GCInspector
 
setGcLogThresholdInMs(long) - Method in interface org.apache.cassandra.service.GCInspectorMXBean
 
setGcWarnThresholdInMs(long) - Method in class org.apache.cassandra.service.GCInspector
 
setGcWarnThresholdInMs(long) - Method in interface org.apache.cassandra.service.GCInspectorMXBean
 
setGlobalLimit(long) - Static method in class org.apache.cassandra.transport.ClientResourceLimits
 
setGlobalPrefix(String) - Static method in class org.apache.cassandra.concurrent.NamedThreadFactory
 
setGossipTokens(Collection<Token>) - Method in class org.apache.cassandra.service.StorageService
 
setHasMorePages(PagingState) - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
setHintedHandoffEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setHintedHandoffEnabled(boolean) - Method in class org.apache.cassandra.service.StorageProxy
 
setHintedHandoffEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
setHintedHandoffThrottleInKB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setHintedHandoffThrottleInKB(int) - Method in class org.apache.cassandra.service.StorageService
 
setHintedHandoffThrottleInKB(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Sets the hinted handoff throttle in kb per second, per delivery thread.
setHintedHandoffThrottleInKB(int) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetHintedHandoffThrottleInKB - Class in org.apache.cassandra.tools.nodetool
 
SetHintedHandoffThrottleInKB() - Constructor for class org.apache.cassandra.tools.nodetool.SetHintedHandoffThrottleInKB
 
setHintsCompression(ParameterizedClass) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
SetHostStat - Class in org.apache.cassandra.tools.nodetool
 
SetHostStat(boolean) - Constructor for class org.apache.cassandra.tools.nodetool.SetHostStat
 
SetHostStatWithPort - Class in org.apache.cassandra.tools.nodetool
 
SetHostStatWithPort(boolean) - Constructor for class org.apache.cassandra.tools.nodetool.SetHostStatWithPort
 
setIdealCLResponseHandler(AbstractWriteResponseHandler) - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
Set a delegate ideal CL write response handler.
setIdealConsistencyLevel(ConsistencyLevel) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setIdealConsistencyLevel(String) - Method in class org.apache.cassandra.service.StorageProxy
 
setIdealConsistencyLevel(String) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
setIgnoreHosts(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
Set the hosts to ignore as comma delimited values.
setIgnoreHosts(Configuration, String...) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
Set the hosts to ignore.
setIgnoreStopTerms(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
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
 
setIndexAccessMode(Config.DiskAccessMode) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setIndexBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
setIndexRemoved(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
setInet(int, InetAddress) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided inet address.
setInet(String, InetAddress) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided inet address.
setInitialized() - Static method in class org.apache.cassandra.db.Keyspace
 
setInitialRangeTombstoneListAllocationSize(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setInitialRangeTombstoneListAllocationSize(int) - Method in class org.apache.cassandra.service.StorageService
 
setInitialRangeTombstoneListAllocationSize(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Sets the initial allocation size of backing arrays for new RangeTombstoneList objects
setInputColumnFamily(Configuration, String, String, boolean) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the keyspace and column family for the input of this job.
setInputColumnFamily(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the keyspace and column family for the input of this job.
setInputColumns(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
Set the CQL columns for the input of this job.
setInputCoreConnections(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputCql(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputCQLPageRowSize(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
Set the CQL query Limit for the input of this job.
setInputInitialAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setInputKeyspacePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setInputKeyspaceUserName(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setInputKeyspaceUserNameAndPassword(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setInputMaxConnections(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputMaxSimultReqPerConnections(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeAuthProvider(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeConnectionTimeout(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeKeepAlive(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativePort(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeReadConnectionTimeout(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeReceiveBufferSize(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeReuseAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeSendBufferSize(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeSolinger(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeSSLCipherSuites(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeSSLKeystorePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeSSLKeystorePath(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeSSLTruststorePassword(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeSSLTruststorePath(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputNativeTcpNodelay(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setInputPartitioner(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setInputRange(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the KeyRange to limit the rows.
setInputSplitSize(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the size of the input split.
setInputSplitSizeInMb(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the size of the input split.
setInputWhereClauses(Configuration, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
Set the CQL user defined where clauses for the input of this job.
setInt(int) - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
Sets the value into system properties.
setInt(int, int) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Set the ith value to the provided integer.
setInt(String, int) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided integer.
setInt(long, int) - Method in class org.apache.cassandra.io.util.Memory
 
setInt(long, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
setInterDCStreamThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetInterDCStreamThroughput - Class in org.apache.cassandra.tools.nodetool
 
SetInterDCStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.SetInterDCStreamThroughput
 
setInterDCStreamThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
 
setInterDCStreamThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setInterDCStreamThroughputOutboundMegabitsPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setInternodeAuthenticator(IInternodeAuthenticator) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setInternodeCompression(Config.InternodeCompression) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setInternodeMaxMessageSizeInBytes(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setInternodeMessagingEncyptionOptions(EncryptionOptions.ServerEncryptionOptions) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setInternodeStreamingTcpUserTimeoutInMS(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setInternodeStreamingTcpUserTimeoutInMS(int) - Method in class org.apache.cassandra.service.StorageService
 
setInternodeStreamingTcpUserTimeoutInMS(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setInternodeTcpConnectTimeoutInMS(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setInternodeTcpConnectTimeoutInMS(int) - Method in class org.apache.cassandra.service.StorageService
 
setInternodeTcpConnectTimeoutInMS(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setInternodeTcpUserTimeoutInMS(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setInternodeTcpUserTimeoutInMS(int) - Method in class org.apache.cassandra.service.StorageService
 
setInternodeTcpUserTimeoutInMS(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setIsShutdownUnsafeForTests(boolean) - Method in class org.apache.cassandra.service.StorageService
for in-jvm dtest use - forces isShutdown to be set to whatever passed in.
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(QueryState, CQLStatement) - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
 
setKeyspace(String) - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
 
setKeyspace(CQLStatement) - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
 
setKeyspace(String, boolean) - Method in class org.apache.cassandra.cql3.QualifiedName
Sets the keyspace.
setKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement.Parsed
 
setKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.QualifiedStatement
 
setKeyspace(String) - Method in class org.apache.cassandra.cql3.statements.QualifiedStatement
 
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
 
setKeyspaceCountWarnThreshold(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setKeyspaceCountWarnThreshold(int) - Method in class org.apache.cassandra.service.StorageService
 
setKeyspaceCountWarnThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setLast(String, FilterPipelineTask<K, V>) - Method in class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineTask
 
setLastProcessedMessageAt(long) - Method in class org.apache.cassandra.gms.Gossiper
 
setLastUpdate() - Method in class org.apache.cassandra.repair.consistent.LocalSession
 
setLeft(Operation.Builder) - Method in class org.apache.cassandra.index.sasi.plan.Operation.Builder
 
setLimit(long) - Method in class org.apache.cassandra.net.ResourceLimits.Basic
 
setLimit(long) - Method in class org.apache.cassandra.net.ResourceLimits.Concurrent
 
setLimit(long) - Method in interface org.apache.cassandra.net.ResourceLimits.Limit
Sets the total amount of permits represented by this ResourceLimits.Limit - the capacity If the old limit has been reached and the new limit is large enough to allow for more permits to be aqcuired, subsequent calls to ResourceLimits.Limit.allocate(long) or ResourceLimits.Limit.tryAllocate(long) will succeed.
setList(int, List<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided list.
setList(int, List<E>, Class<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided list, which elements are of the provided Java class.
setList(int, List<E>, TypeToken<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided list, which elements are of the provided Java type.
setList(String, List<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided list.
setList(String, List<E>, Class<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided list, which elements are of the provided Java class.
setList(String, List<E>, TypeToken<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided list, which elements are of the provided Java type.
setListenAddress(InetAddress) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setListenOnBroadcastAddress(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setLocale(Locale) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
setLocalHostId(UUID) - Static method in class org.apache.cassandra.db.SystemKeyspace
Sets the local host ID explicitly.
setLocalOverrides(TableMetadata) - Method in class org.apache.cassandra.schema.TableMetadataRef
 
setLoggingLevel(String, String) - Method in class org.apache.cassandra.service.StorageService
 
setLoggingLevel(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
set the logging level at runtime

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

The logback configuration should have < jmxConfigurator /> set
setLoggingLevel(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetLoggingLevel - Class in org.apache.cassandra.tools.nodetool
 
SetLoggingLevel() - Constructor for class org.apache.cassandra.tools.nodetool.SetLoggingLevel
 
setLoggingLevel(String, String) - Method in class org.apache.cassandra.utils.logging.LogbackLoggingSupport
 
setLoggingLevel(String, String) - Method in interface org.apache.cassandra.utils.logging.LoggingSupport
Changes the given logger to the given log level.
setLoggingLevel(String, String) - Method in class org.apache.cassandra.utils.logging.NoOpFallbackLoggingSupport
 
setLong(int, long) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided long.
setLong(String, long) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided long.
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
 
setLower(Expression.Bound) - Method in class org.apache.cassandra.index.sasi.plan.Expression
 
setLowerCaseOutput(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
 
setMap(int, Map<K, V>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided map.
setMap(int, Map<K, V>, Class<K>, Class<V>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided map, which keys and values are of the provided Java classes.
setMap(int, Map<K, V>, TypeToken<K>, TypeToken<V>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided map, which keys and values are of the provided Java types.
setMap(String, Map<K, V>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided map.
setMap(String, Map<K, V>, Class<K>, Class<V>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided map, which keys and values are of the provided Java classes.
setMap(String, Map<K, V>, TypeToken<K>, TypeToken<V>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided map, which keys and values are of the provided Java types.
setMaxConcurrentAutoUpgradeTasks(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setMaxConcurrentAutoUpgradeTasks(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
setMaxConcurrentAutoUpgradeTasks(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Set the number of concurrent sstable upgrade tasks we should run when automatic sstable upgrades are enabled
setMaxDataAge(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
setMaxEntries(int) - Method in class org.apache.cassandra.auth.AuthCache
Set maximum number of entries in the cache.
setMaxEntries(int) - Method in interface org.apache.cassandra.auth.AuthCacheMBean
 
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
 
setMaxHintWindow(int) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetMaxHintWindow - Class in org.apache.cassandra.tools.nodetool
 
SetMaxHintWindow() - Constructor for class org.apache.cassandra.tools.nodetool.SetMaxHintWindow
 
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.
setMaximumPoolSize(int) - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
 
setMaximumPoolSize(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledSingleThreadExecutor
 
setMaximumPoolSize(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
setMaximumPoolSize(int) - Method in interface org.apache.cassandra.concurrent.ResizableThreadPool
Allows user to resize maximum size of the thread pool.
setMaximumPoolSize(int) - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
setMaximumPoolSize(int) - Method in enum org.apache.cassandra.concurrent.Stage
Allows user to resize maximum size of the thread pool.
setMaximumThreads(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledSingleThreadExecutor
 
setMaximumThreads(int) - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
Deprecated.
setMaximumThreads(int) - Method in interface org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutorMBean
Deprecated.
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.
setMaximumViewBuildThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
setMaximumViewBuildThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Allows user to resize maximum size of the view build thread pool.
setMaxTokenLength(int) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
setMaxValueSize(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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(KeyspaceMetadata) - Method in class org.apache.cassandra.db.Keyspace
 
setMetadataChanged() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
setMigrateKeycacheOnCompaction(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setMigrateKeycacheOnCompaction(boolean) - Method in class org.apache.cassandra.service.StorageService
 
setMigrateKeycacheOnCompaction(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
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
setMinTokenLength(int) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
setMonitoringTime(long, boolean, long, long) - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
This setter is ugly but the construction chain to ReadCommand is too complex, it would require passing new parameters to all serializers or specializing the serializers to accept these message properties.
setMovingModeUnsafe() - Method in class org.apache.cassandra.service.StorageService
 
setName(String, boolean) - Method in class org.apache.cassandra.cql3.QualifiedName
 
setName(String, boolean) - Method in class org.apache.cassandra.cql3.RoleName
 
setName(String) - Method in class org.apache.cassandra.tools.JMXTool.Attribute
 
setName(String) - Method in class org.apache.cassandra.tools.JMXTool.Operation
 
setName(String) - Method in class org.apache.cassandra.tools.JMXTool.Parameter
 
setNativeTransportAllowOlderProtocols(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setNativeTransportIdleTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
 
setNativeTransportMaxConcurrentRequestsInBytes(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setNativeTransportMaxConcurrentRequestsInBytes(long) - Method in class org.apache.cassandra.service.StorageService
 
setNativeTransportMaxConcurrentRequestsInBytes(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setNativeTransportMaxConcurrentRequestsInBytesPerIp(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setNativeTransportMaxConcurrentRequestsInBytesPerIp(long) - Method in class org.apache.cassandra.service.StorageService
 
setNativeTransportMaxConcurrentRequestsInBytesPerIp(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setNativeTransportMaxThreads(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setNativeTransportPort(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setNativeTransportPortSSL(Integer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setNativeTransportReceiveQueueCapacityInBytes(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setNetworkAuthorizer(INetworkAuthorizer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setNeverPurgeTombstones(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setNeverPurgeTombstones(boolean) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
setNewLocalCompactionStrategy(CompactionParams) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
setNormalModeUnsafe() - Method in class org.apache.cassandra.service.StorageService
Only used in jvm dtest when not using GOSSIP.
setOf(Class<T>) - Static method in class org.apache.cassandra.cql3.functions.types.TypeTokens
Create a TypeToken that represents a Set whose elements are of the given type.
setOf(TypeToken<T>) - Static method in class org.apache.cassandra.cql3.functions.types.TypeTokens
Create a TypeToken that represents a Set whose elements are of the given type.
setOp(Expression.Op) - Method in class org.apache.cassandra.index.sasi.plan.Expression
 
setOpenResult(boolean) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableZeroCopyWriter
 
setOpenResult(boolean) - Method in class org.apache.cassandra.io.sstable.format.RangeAwareSSTableWriter
 
setOpenResult(boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
setOpenResult(boolean) - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
 
setOpenResult(boolean) - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
 
setOperation(String) - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
 
setOperations(JMXTool.Operation[]) - Method in class org.apache.cassandra.tools.JMXTool.Info
 
setOption(IRoleManager.Option, Object) - Method in class org.apache.cassandra.auth.RoleOptions
Set a value for a specific option.
setOptional(boolean) - Method in class org.apache.cassandra.config.EncryptionOptions
Sets if encryption should be optional for this channel.
setOptions(QueryOptions) - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
 
setOrListToJsonString(ByteBuffer, AbstractType, ProtocolVersion) - Static method in class org.apache.cassandra.db.marshal.ListType
 
setOtcBacklogExpirationInterval(int) - Method in class org.apache.cassandra.service.StorageProxy
Deprecated.
setOtcBacklogExpirationInterval(int) - Method in interface org.apache.cassandra.service.StorageProxyMBean
Deprecated.
setOutput(PrintStream) - Method in class org.apache.cassandra.tools.AbstractJmxClient
 
setOutput(Output) - Method in class org.apache.cassandra.tools.NodeProbe
 
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
 
setOutputInitialPort(Configuration, Integer) - 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
 
setOverrideLoadConfig(Supplier<Config>) - Static method in class org.apache.cassandra.config.Config
 
setParameters(JMXTool.Parameter[]) - Method in class org.apache.cassandra.tools.JMXTool.Operation
 
setParticipantState(InetAddressAndPort, ConsistentSession.State) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
 
setPartitionerUnsafe(IPartitioner) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setPartitionerUnsafe(IPartitioner) - Method in class org.apache.cassandra.service.StorageService
 
setPartitionKeyColumn(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
 
setPartitionKeyColumns(List<ColumnIdentifier>) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
 
setPartitionKeyColumns(List<ColumnIdentifier>) - Method in class org.apache.cassandra.cql3.statements.schema.CreateViewStatement.Raw
 
setPermissionsCacheMaxEntries(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
 
setPosition(long) - Method in class org.apache.cassandra.security.EncryptionUtils.ChannelProxyReadChannel
 
setPostFlushListener(Runnable) - Method in class org.apache.cassandra.io.util.SequentialWriter
 
setPreviousReleaseVersionString(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
setProtocol(String) - Method in class org.apache.cassandra.config.EncryptionOptions
Sets accepted TLS protocol for this channel.
setQuickResolver(BTree.Builder.QuickResolver<V>) - Method in class org.apache.cassandra.utils.btree.BTree.Builder
 
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
 
setRangeRpcTimeout(long) - Method in class org.apache.cassandra.service.StorageService
 
setRangeRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setRangeTombstoneListGrowthFactor(double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRangeTombstoneListResizeGrowthFactor(double) - Method in class org.apache.cassandra.service.StorageService
 
setRangeTombstoneListResizeGrowthFactor(double) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Sets the resize factor to use when growing/resizing a RangeTombstoneList
setRate(int) - Method in class org.apache.cassandra.batchlog.BatchlogManager
Sets the rate for the current rate limiter.
setRate(double) - Method in class org.apache.cassandra.db.compaction.CompactionManager
Sets the rate for the rate limiter.
setReadConsistencyLevel(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setReadRpcTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setReadRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
 
setReadRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
setReadRpcTimeout(long) - Method in class org.apache.cassandra.service.StorageService
 
setReadRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setRecycleWhenFreeForCurrentThread(boolean) - Method in class org.apache.cassandra.utils.memory.BufferPool
 
setRepairedAt(long) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
setRepairedAt(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
setRepairedAt(long) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
setRepairedDataTrackingForPartitionReadsEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRepairedDataTrackingForRangeReadsEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRepairing() - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
 
setRepairPendingCompactionRejectThreshold(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRepairPendingCompactionRejectThreshold(int) - Method in class org.apache.cassandra.service.ActiveRepairService
 
setRepairPendingCompactionRejectThreshold(int) - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
 
setRepairSessionMaxTreeDepth(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRepairSessionMaxTreeDepth(int) - Method in class org.apache.cassandra.service.StorageService
 
setRepairSessionMaxTreeDepth(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setRepairSessionSpaceInMegabytes(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRepairSessionSpaceInMegabytes(int) - Method in class org.apache.cassandra.service.ActiveRepairService
 
setRepairSessionSpaceInMegabytes(int) - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
 
setReplaced() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
setResizeIntervalInMinutes(int) - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
 
setResizeIntervalInMinutes(int) - Method in interface org.apache.cassandra.io.sstable.IndexSummaryManagerMBean
 
setResult(PartitionIterator) - Method in class org.apache.cassandra.service.reads.AbstractReadExecutor
 
setReturnType(String) - Method in class org.apache.cassandra.tools.JMXTool.Operation
 
setReverseOrder(boolean) - Method in class org.apache.cassandra.db.partitions.PurgeFunction
 
setRight(Operation.Builder) - Method in class org.apache.cassandra.index.sasi.plan.Operation.Builder
 
setRoleDatacenters(RoleResource, DCPermissions) - Method in class org.apache.cassandra.auth.AllowAllNetworkAuthorizer
 
setRoleDatacenters(RoleResource, DCPermissions) - Method in class org.apache.cassandra.auth.CassandraNetworkAuthorizer
 
setRoleDatacenters(RoleResource, DCPermissions) - Method in interface org.apache.cassandra.auth.INetworkAuthorizer
 
setRoleManager(IRoleManager) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRolesCacheMaxEntries(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRolesUpdateInterval(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRolesValidity(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRowCacheCapacityInMB(long) - Method in class org.apache.cassandra.service.CacheService
 
setRowCacheCapacityInMB(long) - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
setRowCacheKeysToSave(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRowCacheKeysToSave(int) - Method in class org.apache.cassandra.service.CacheService
 
setRowCacheKeysToSave(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
setRowCacheSavePeriod(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRowCacheSavePeriodInSeconds(int) - Method in class org.apache.cassandra.service.CacheService
 
setRowCacheSavePeriodInSeconds(int) - Method in interface org.apache.cassandra.service.CacheServiceMBean
 
setRowCacheSizeInMB(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setRpcReady(boolean) - Method in class org.apache.cassandra.service.StorageService
Set the RPC status.
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
 
setRpcTimeout(long) - Method in class org.apache.cassandra.service.StorageService
 
setRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
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
 
setScope(CQLStatement) - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
 
setSeedProvider(SeedProvider) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
SetSerializer<T> - Class in org.apache.cassandra.serializers
 
SetSerializer(TypeSerializer<T>, ValueComparators) - Constructor for class org.apache.cassandra.serializers.SetSerializer
 
setSet(int, Set<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided set.
setSet(int, Set<E>, Class<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided set, which elements are of the provided Java class.
setSet(int, Set<E>, TypeToken<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided set, which elements are of the provided Java type.
setSet(String, Set<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided set.
setSet(String, Set<E>, Class<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided set, which elements are of the provided Java class.
setSet(String, Set<E>, TypeToken<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided set, which elements are of the provided Java type.
setSeverity(double) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
setSeverity(double) - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
Setting a Severity allows operators to inject preference information into the Dynamic Snitch replica selection.
setShort(int, short) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Set the ith value to the provided short.
setShort(String, short) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided short.
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
 
setShouldListenOnBroadcastAddress(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setSkipMetadata() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
setSnapshotLinksPerSecond(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setSnapshotLinksPerSecond(long) - Method in class org.apache.cassandra.service.StorageService
 
setSnapshotLinksPerSecond(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Set the current hardlink-per-second throttle for snapshots A setting of zero indicates no throttling
setSnapshotLinksPerSecond(long) - Method in class org.apache.cassandra.tools.NodeProbe
 
setSnapshotOnDuplicateRowDetection(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setSnapshotOnRepairedDataMismatch(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
SetSnapshotThrottle - Class in org.apache.cassandra.tools.nodetool
 
SetSnapshotThrottle() - Constructor for class org.apache.cassandra.tools.nodetool.SetSnapshotThrottle
 
setSource(Envelope) - Method in class org.apache.cassandra.transport.Message
 
setSSTablePreemptiveOpenIntervalInMB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setSSTablePreemptiveOpenIntervalInMB(int) - Method in class org.apache.cassandra.service.StorageService
 
setSSTablePreemptiveOpenIntervalInMB(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setState(ConsistentSession.State) - Method in class org.apache.cassandra.repair.consistent.ConsistentSession
 
setState(ConsistentSession.State) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
 
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
 
setStemTerms(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
setStrategyInternal(CompactionParams, int) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
 
setStrategyInternal(CompactionParams, int) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
setStrategyInternal(CompactionParams, int) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
setStreamFactory(AutoSavingCache.IStreamFactory) - Static method in class org.apache.cassandra.cache.AutoSavingCache
 
setStreamId(int) - Method in class org.apache.cassandra.transport.Message
 
setStreamThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetStreamThroughput - Class in org.apache.cassandra.tools.nodetool
 
SetStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.SetStreamThroughput
 
setStreamThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
 
setStreamThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setStreamThroughputOutboundMegabitsPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setString(String) - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
Sets the value into system properties.
setString(int, String) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided string.
setString(String, String) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided string.
setSuccess() - Method in class org.apache.cassandra.net.AsyncChannelPromise
 
setSuccess(Void) - Method in class org.apache.cassandra.net.AsyncChannelPromise
 
setSuccess(V) - Method in class org.apache.cassandra.net.AsyncPromise
 
setTableAlias(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
SettableByIndexData<T extends SettableByIndexData<T>> - Interface in org.apache.cassandra.cql3.functions.types
Collection of (typed) CQL values that can be set by index (starting at zero).
SettableByNameData<T extends SettableData<T>> - Interface in org.apache.cassandra.cql3.functions.types
Collection of (typed) CQL values that can set by name.
setTableCountWarnThreshold(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setTableCountWarnThreshold(int) - Method in class org.apache.cassandra.service.StorageService
 
setTableCountWarnThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
SettableData<T extends SettableData<T>> - Interface in org.apache.cassandra.cql3.functions.types
Collection of (typed) CQL values that can be set either by index (starting at zero) or by name.
setTableInsertStatement(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
setTableMetadata(TableMetadataRef) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
 
setTableMetadata(TableMetadataRef) - Method in class org.apache.cassandra.utils.NativeSSTableLoaderClient
 
setTableSchema(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat
 
Setter(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Setter
 
Setter(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Lists.Setter
 
Setter(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Maps.Setter
 
Setter(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Sets.Setter
 
Setter(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.UserTypes.Setter
 
SetterByField(ColumnMetadata, FieldIdentifier, Term) - Constructor for class org.apache.cassandra.cql3.UserTypes.SetterByField
 
SetterByIndex(ColumnMetadata, Term, Term) - Constructor for class org.apache.cassandra.cql3.Lists.SetterByIndex
 
SetterByKey(ColumnMetadata, Term, Term) - Constructor for class org.apache.cassandra.cql3.Maps.SetterByKey
 
setThreadFactory(ThreadFactory) - Method in class org.apache.cassandra.concurrent.JMXEnabledSingleThreadExecutor
 
setThrowOnOverload(boolean) - Method in class org.apache.cassandra.transport.Connection
 
setTime(int, long) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Set the ith value to the provided time as a long in nanoseconds since midnight.
setTime(String, long) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided time as a long in nanoseconds since midnight.
setTimeout(String, long) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetTimeout - Class in org.apache.cassandra.tools.nodetool
 
SetTimeout() - Constructor for class org.apache.cassandra.tools.nodetool.SetTimeout
 
setTimestamp(long) - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
 
setTimestamp(int, Date) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Set the ith value to the provided date.
setTimestamp(String, Date) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided date.
setToBlock(int) - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
 
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
setToNull(int) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to null.
setToNull(String) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to null.
setToString(List<?>) - Static method in class org.apache.cassandra.cql3.Sets
Create a String representation of the set containing the specified elements.
setToString(Iterable<T>, Function<T, String>) - Static method in class org.apache.cassandra.cql3.Sets
Create a String representation of the set from the specified items associated to the set elements.
setTraceProbability(double) - Method in class org.apache.cassandra.service.StorageService
 
setTraceProbability(double) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Enables/Disables tracing for the whole system.
setTraceProbability(double) - Method in class org.apache.cassandra.tools.NodeProbe
 
SetTraceProbability - Class in org.apache.cassandra.tools.nodetool
 
SetTraceProbability() - Constructor for class org.apache.cassandra.tools.nodetool.SetTraceProbability
 
setTransientReplicationEnabledUnsafe(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
 
setTruncateRpcTimeout(long) - Method in class org.apache.cassandra.service.StorageService
 
setTruncateRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setTupleValue(int, TupleValue) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided tuple value.
setTupleValue(String, TupleValue) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided tuple value.
setType(AuditLogEntryType) - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
 
SetType<T> - Class in org.apache.cassandra.db.marshal
 
SetType(AbstractType<T>, boolean) - Constructor for class org.apache.cassandra.db.marshal.SetType
 
setType(String) - Method in class org.apache.cassandra.tools.JMXTool.Attribute
 
setType(String) - Method in class org.apache.cassandra.tools.JMXTool.Parameter
 
setUDTValue(int, UDTValue) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided UDT value.
setUDTValue(String, UDTValue) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided UDT value.
setUncancellable() - Method in class org.apache.cassandra.net.AsyncPromise
 
setup() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
setup() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
 
setup() - Method in class org.apache.cassandra.auth.AllowAllNetworkAuthorizer
 
setup() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
setup() - Method in class org.apache.cassandra.auth.CassandraNetworkAuthorizer
 
setup() - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
setup() - Method in interface org.apache.cassandra.auth.IAuthenticator
Setup is called once upon system startup to initialize the IAuthenticator.
setup() - Method in interface org.apache.cassandra.auth.IAuthorizer
Setup is called once upon system startup to initialize the IAuthorizer.
setup() - Method in interface org.apache.cassandra.auth.INetworkAuthorizer
Setup is called once upon system startup to initialize the INetworkAuthorizer.
setup() - Method in interface org.apache.cassandra.auth.IRoleManager
Hook to perform implementation specific initialization, called once upon system startup.
setup() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
setup() - Method in class org.apache.cassandra.service.CassandraDaemon
This is a hook for concrete daemons to initialize themselves suitably.
setupCompleted() - Method in class org.apache.cassandra.service.CassandraDaemon
 
setUpdateInterval(int) - Method in class org.apache.cassandra.auth.AuthCache
Time in milliseconds after which an entry in the cache should be refreshed (it's load function called again)
setUpdateInterval(int) - Method in interface org.apache.cassandra.auth.AuthCacheMBean
 
setUpDistributedSystemKeyspaces() - Method in class org.apache.cassandra.service.StorageService
 
setupJob(JobContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
 
setupOnline() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
setUpper(Expression.Bound) - Method in class org.apache.cassandra.index.sasi.plan.Expression
 
setUpperCaseOutput(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
 
setupTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkOutputFormat.NullOutputCommitter
 
setUptimeFn(LongSupplier) - Static method in class org.apache.cassandra.schema.MigrationCoordinator
 
setUptimeFn(LongSupplier) - Static method in class org.apache.cassandra.schema.MigrationManager
 
setupVirtualKeyspaces() - Method in class org.apache.cassandra.service.CassandraDaemon
 
setUseOffheapMerkleTrees(boolean) - Method in class org.apache.cassandra.service.ActiveRepairService
 
setUseOffheapMerkleTrees(boolean) - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
 
setUser(String) - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
 
setUserDefined(boolean) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
setUserDefinedFunctionFailTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setUserDefinedFunctionWarnTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setUserFunctionTimeoutPolicy(Config.UserFunctionTimeoutPolicy) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setUserNameAndPassword(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.cql3.CqlConfigHelper
 
setUUID(int, UUID) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided UUID.
setUUID(String, UUID) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided UUID.
setValidity(int) - Method in class org.apache.cassandra.auth.AuthCache
Time in milliseconds that a value in the cache will expire after.
setValidity(int) - Method in interface org.apache.cassandra.auth.AuthCacheMBean
 
SetValue(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.SetValue
 
setValue(ByteBuffer) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.CounterMark
 
setValue(ColumnMetadata, CellPath, ByteBuffer) - Method in class org.apache.cassandra.db.rows.BTreeRow
 
setVarint(int, BigInteger) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
Sets the ith value to the provided big integer.
setVarint(String, BigInteger) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
Sets the value for (all occurrences of) variable name to the provided big integer.
setViewBuilt(String, String, boolean) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
setViewBuiltReplicated(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
setViewRemoved(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
setViewRemoved(String, String) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
setWarnings(List<String>) - Method in class org.apache.cassandra.transport.Message.Response
 
setWriteConsistencyLevel(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setWriteRpcTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setWriteRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
 
setWriteRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
setWriteRpcTimeout(long) - Method in class org.apache.cassandra.service.StorageService
 
setWriteRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
severity(double) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
shadowable(DeletionTime) - Static method in class org.apache.cassandra.db.rows.Row.Deletion
Deprecated.
shadowSources(DecoratedKey, boolean) - Method in class org.apache.cassandra.db.AbstractCompactionController
 
shadowSources(DecoratedKey, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionController
 
share() - Method in class org.apache.cassandra.net.ShareableBytes
Ensure this ShareableBytes will use atomic operations for updating its count from now on.
share(FileChannel) - Static method in class org.apache.cassandra.net.SharedDefaultFileRegion
 
ShareableBytes - Class in org.apache.cassandra.net
A wrapper for possibly sharing portions of a single, BufferPools.forNetworking() managed, ByteBuffer; optimised for the case where no sharing is necessary.
SHARED - Static variable in class org.apache.cassandra.concurrent.SharedExecutorPool
 
shared(ReplicaPlan.ForTokenRead) - Static method in class org.apache.cassandra.locator.ReplicaPlan
 
shared(ReplicaPlan.ForRangeRead) - Static method in class org.apache.cassandra.locator.ReplicaPlan
 
SHARED_HEADER_BYTES - Static variable in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
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.ChannelProxy
 
sharedCopy() - Method in class org.apache.cassandra.io.util.FileHandle
 
sharedCopy() - Method in class org.apache.cassandra.io.util.MmappedRegions
 
sharedCopy() - Method in class org.apache.cassandra.io.util.SafeMemory
 
sharedCopy() - Method in class org.apache.cassandra.utils.AlwaysPresentFilter
 
sharedCopy() - Method in class org.apache.cassandra.utils.BloomFilter
 
sharedCopy() - Method in interface org.apache.cassandra.utils.concurrent.SharedCloseable
 
sharedCopy() - Method in interface org.apache.cassandra.utils.IFilter
 
SharedDefaultFileRegion - Class in org.apache.cassandra.net
Netty's DefaultFileRegion closes the underlying FileChannel as soon as the refCnt() for the region drops to zero, this is an implementation of the DefaultFileRegion that doesn't close the FileChannel.
SharedDefaultFileRegion.SharedFileChannel - Class in org.apache.cassandra.net
 
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
 
SharedTable() - Constructor for class org.apache.cassandra.tools.nodetool.formatter.TableBuilder.SharedTable
 
SharedTable(char) - Constructor for class org.apache.cassandra.tools.nodetool.formatter.TableBuilder.SharedTable
 
SharedTable(String) - Constructor for class org.apache.cassandra.tools.nodetool.formatter.TableBuilder.SharedTable
 
sHeader - Variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer.Header
 
SHORT_SIZE - Static variable in class org.apache.cassandra.db.TypeSizes
 
ShortReadPartitionsProtection - Class in org.apache.cassandra.service.reads
 
ShortReadPartitionsProtection(ReadCommand, Replica, Runnable, DataLimits.Counter, DataLimits.Counter, long) - Constructor for class org.apache.cassandra.service.reads.ShortReadPartitionsProtection
 
ShortReadProtection - Class in org.apache.cassandra.service.reads
We have a potential short read if the result from a given node contains the requested number of rows (i.e.
ShortReadProtection() - Constructor for class org.apache.cassandra.service.reads.ShortReadProtection
 
shortReadProtectionRequests - Variable in class org.apache.cassandra.metrics.TableMetrics
 
ShortSerializer - Class in org.apache.cassandra.serializers
 
ShortSerializer() - Constructor for class org.apache.cassandra.serializers.ShortSerializer
 
ShortType - Class in org.apache.cassandra.db.marshal
 
shouldBeEnabled() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
shouldBuildBlocking() - Method in interface org.apache.cassandra.index.Index
Return true if this index can be built or rebuilt when the index manager determines it is necessary.
shouldBuildBlocking() - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
shouldBuildBlocking() - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
shouldCheckCrc() - Method in class org.apache.cassandra.schema.CompressionParams
 
shouldClearLocal(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.context.CounterContext
 
shouldEncrypt(InetAddressAndPort) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
shouldHint(Replica) - Static method in class org.apache.cassandra.service.StorageProxy
 
shouldIgnoreStopTerms() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
shouldInclude(SSTableReader) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
Whether the provided sstable may contain data that is selected by this filter (based on the sstable metadata).
shouldInclude(SSTableReader) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
 
shouldInclude(SSTableReader) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
 
shouldListenOnBroadcastAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
shouldLowerCaseOutput() - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
 
shouldLowerCaseTerms() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
shouldMigrateKeycacheOnCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
shouldPullFromEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.schema.MigrationCoordinator
 
shouldPullImmediately(InetAddressAndPort, UUID) - Method in class org.apache.cassandra.schema.MigrationCoordinator
 
shouldPullSchema(UUID) - Method in class org.apache.cassandra.schema.MigrationCoordinator
 
shouldPurge(long, int) - Method in interface org.apache.cassandra.db.DeletionPurger
 
shouldPurge(DeletionTime) - Method in interface org.apache.cassandra.db.DeletionPurger
 
shouldPurge(LivenessInfo, int) - Method in interface org.apache.cassandra.db.DeletionPurger
 
shouldSkipSegmentOnError(CommitLogReadHandler.CommitLogReadException) - Method in interface org.apache.cassandra.db.commitlog.CommitLogReadHandler
Handle an error during segment read, signaling whether or not you want the reader to skip the remainder of the current segment on error.
shouldSkipSegmentOnError(CommitLogReadHandler.CommitLogReadException) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
 
shouldStemTerms() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
shouldTraceProbablistically() - Method in class org.apache.cassandra.service.StorageService
 
shouldUpperCaseOutput() - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
 
shouldUpperCaseTerms() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
shutdown() - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
 
shutdown() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
shutdown() - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
shutdown() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogSegmentManager
Initiates the shutdown process for the management thread.
shutdown() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
 
shutdown() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerCDC
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.AbstractStrategyHolder
 
shutdown() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
shutdown() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
shutdown() - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
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(long, TimeUnit, boolean, boolean) - Method in class org.apache.cassandra.net.MessagingService
 
shutdown() - Static method in class org.apache.cassandra.streaming.async.StreamingInboundHandler
Shutdown for in-JVM tests.
shutdown() - Static method in class org.apache.cassandra.transport.Dispatcher
 
shutdown(Iterable<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
 
shutdown(boolean, Iterable<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
 
shutdown(ExecutorService...) - Static method in class org.apache.cassandra.utils.ExecutorUtils
 
shutdownAndWait(long, TimeUnit) - Method in class org.apache.cassandra.batchlog.BatchlogManager
 
shutdownAndWait(long, TimeUnit) - Static method in class org.apache.cassandra.concurrent.ScheduledExecutors
 
shutdownAndWait(long, TimeUnit) - Method in class org.apache.cassandra.concurrent.SharedExecutorPool
 
shutdownAndWait(long, TimeUnit) - Static method in enum org.apache.cassandra.concurrent.Stage
 
shutdownAndWait(long, TimeUnit) - Static method in class org.apache.cassandra.index.SecondaryIndexManager
 
shutdownAndWait(long, TimeUnit) - Method in class org.apache.cassandra.io.sstable.IndexSummaryManager
 
shutdownAndWait(long, TimeUnit) - Method in class org.apache.cassandra.service.PendingRangeCalculatorService
 
shutdownAndWait(long, TimeUnit) - Static method in class org.apache.cassandra.streaming.StreamReceiveTask
 
shutdownAndWait(long, TimeUnit) - Static method in class org.apache.cassandra.streaming.StreamTransferTask
 
shutdownAndWait(long, TimeUnit) - Method in class org.apache.cassandra.utils.DiagnosticSnapshotService
 
shutdownAndWait(long, TimeUnit, Collection<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
 
shutdownAndWait(long, TimeUnit, Object...) - Static method in class org.apache.cassandra.utils.ExecutorUtils
 
shutdownAndWait(long, TimeUnit) - Method in class org.apache.cassandra.utils.memory.MemtablePool
 
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.hints.HintsService
Gracefully and blockingly shut down the service.
shutdownBlocking(long, TimeUnit) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
shutdownExecutorsAndWait(long, TimeUnit) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
shutdownLocalCleaner(long, TimeUnit) - Method in class org.apache.cassandra.utils.memory.BufferPool
 
shutdownLocalCleaner(long, TimeUnit) - Static method in class org.apache.cassandra.utils.memory.BufferPools
 
shutdownNow() - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
 
shutdownNow() - Method in class org.apache.cassandra.concurrent.InfiniteLoopExecutor
 
shutdownNow() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
shutdownNow() - Method in class org.apache.cassandra.concurrent.SEPExecutor
 
shutdownNow() - Static method in enum org.apache.cassandra.concurrent.Stage
This method shuts down all registered stages.
shutdownNow() - Method in class org.apache.cassandra.net.SocketFactory
 
shutdownNow(Iterable<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
 
shutdownNow(ExecutorService...) - Static method in class org.apache.cassandra.utils.ExecutorUtils
 
shutdownNowAndWait(long, TimeUnit, Collection<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
 
shutdownNowAndWait(long, TimeUnit, Object...) - Static method in class org.apache.cassandra.utils.ExecutorUtils
 
shutdownPostFlushExecutor() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
shutdownReferenceReaper(long, TimeUnit) - Static method in class org.apache.cassandra.utils.concurrent.Ref
 
shutdownServer() - Method in class org.apache.cassandra.service.StorageService
 
SigarLibrary - Class in org.apache.cassandra.utils
 
signal() - Method in class org.apache.cassandra.net.AbstractMessageHandler.WaitQueue
 
signal() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
signal() - Method in class org.apache.cassandra.service.BatchlogResponseHandler
 
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
simple - Static variable in interface org.apache.cassandra.net.FrameEncoder.PayloadAllocator
 
simple(int) - Static method in class org.apache.cassandra.schema.KeyspaceParams
 
simple(String) - Static method in class org.apache.cassandra.schema.KeyspaceParams
 
simple(ReadCommand) - Static method in interface org.apache.cassandra.service.reads.repair.RepairedDataVerifier
 
Simple(BiFunction<V, V, V>) - Constructor for class org.apache.cassandra.utils.btree.UpdateFunction.Simple
 
simpleBuilder(String, DecoratedKey) - Static method in class org.apache.cassandra.db.Mutation
Creates a new simple mutuation builder.
simpleBuilder(TableMetadata, Object...) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
Creates a new simple partition update builder.
simpleBuilder(TableMetadata, Object...) - Static method in class org.apache.cassandra.db.rows.Rows
Creates a new simple row builder.
SimpleBuilders - Class in org.apache.cassandra.db
 
SimpleBuilders.MutationBuilder - Class in org.apache.cassandra.db
 
SimpleBuilders.PartitionUpdateBuilder - Class in org.apache.cassandra.db
 
SimpleBuilders.RowBuilder - Class in org.apache.cassandra.db
 
SimpleCachedBufferPool - Class in org.apache.cassandra.io.util
A very simple Bytebuffer pool with a fixed allocation size and a cached max allocation count.
SimpleCachedBufferPool(int, int, BufferType) - Constructor for class org.apache.cassandra.io.util.SimpleCachedBufferPool
 
SimpleClient - Class in org.apache.cassandra.transport
 
SimpleClient(String, int, ProtocolVersion, EncryptionOptions) - Constructor for class org.apache.cassandra.transport.SimpleClient
 
SimpleClient(String, int, EncryptionOptions) - Constructor for class org.apache.cassandra.transport.SimpleClient
 
SimpleClient(String, int, ProtocolVersion) - Constructor for class org.apache.cassandra.transport.SimpleClient
 
SimpleClient(String, int, ProtocolVersion, boolean, EncryptionOptions) - Constructor for class org.apache.cassandra.transport.SimpleClient
 
SimpleClient(String, int) - Constructor for class org.apache.cassandra.transport.SimpleClient
 
SimpleClient.Builder - Class in org.apache.cassandra.transport
 
SimpleClient.EventHandler - Interface in org.apache.cassandra.transport
 
SimpleClient.SimpleEventHandler - Class in org.apache.cassandra.transport
 
SimpleClient.SimpleFlusher - Class in org.apache.cassandra.transport
 
simpleColumnCount() - Method in class org.apache.cassandra.db.Columns
The number of simple columns in this object.
simpleColumns() - Method in class org.apache.cassandra.db.Columns
Iterator over the simple columns of this object.
simpleCondition(Term.Raw, Operator) - Static method in class org.apache.cassandra.cql3.conditions.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
 
SimpleDataSet - Class in org.apache.cassandra.db.virtual
A DataSet implementation that is filled on demand and has an easy to use API for adding rows.
SimpleDataSet(TableMetadata) - Constructor for class org.apache.cassandra.db.virtual.SimpleDataSet
 
SimpleDateSerializer - Class in org.apache.cassandra.serializers
 
SimpleDateSerializer() - Constructor for class org.apache.cassandra.serializers.SimpleDateSerializer
 
SimpleDateType - Class in org.apache.cassandra.db.marshal
 
SimpleEventHandler() - Constructor for class org.apache.cassandra.transport.SimpleClient.SimpleEventHandler
 
simpleIdx(ColumnMetadata) - Method in class org.apache.cassandra.db.Columns
The index of the provided simple column in this object (if it contains the provided column).
simpleInCondition(List<Term.Raw>) - Static method in class org.apache.cassandra.cql3.conditions.ColumnCondition.Raw
An IN condition on a column.
simpleInCondition(AbstractMarker.INRaw) - Static method in class org.apache.cassandra.cql3.conditions.ColumnCondition.Raw
An IN condition on a column with a single marker.
simpleIndexOn(ColumnIdentifier) - Static method in class org.apache.cassandra.cql3.statements.schema.IndexTarget.Raw
 
simpleIterator(FileDataInput, DecoratedKey, RowIndexEntry, boolean) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
 
simpleIterator(FileDataInput, DecoratedKey, RowIndexEntry, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
SimpleLeafEntry(long, long) - Constructor for class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf.SimpleLeafEntry
 
simpleMapping(Iterable<ColumnMetadata>) - Static method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
SimpleSeedProvider - Class in org.apache.cassandra.locator
 
SimpleSeedProvider(Map<String, String>) - Constructor for class org.apache.cassandra.locator.SimpleSeedProvider
 
SimpleSelector - Class in org.apache.cassandra.cql3.selection
 
SimpleSelector.SimpleSelectorFactory - Class in org.apache.cassandra.cql3.selection
The Factory for SimpleSelector.
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
 
SimpleSSTableMultiWriter - Class in org.apache.cassandra.io.sstable
 
SimpleSSTableMultiWriter(SSTableWriter, LifecycleNewTracker) - Constructor for class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
 
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
 
SimpleTable(TableMetadata, Supplier<AbstractVirtualTable.DataSet>) - Constructor for class org.apache.cassandra.db.virtual.AbstractVirtualTable.SimpleTable
 
simpleTransient(int) - Static method in class org.apache.cassandra.schema.KeyspaceParams
 
SINGLE_QUERY - Static variable in class org.apache.cassandra.fql.FullQueryLogger
 
singleCellRow(Clustering<?>, Cell<?>) - Static method in class org.apache.cassandra.db.rows.BTreeRow
 
SingleColumnRelation - Class in org.apache.cassandra.cql3
Relations encapsulate the relationship between an entity of some kind, and a value (term).
SingleColumnRelation(ColumnIdentifier, Term.Raw, Operator, Term.Raw) - Constructor for class org.apache.cassandra.cql3.SingleColumnRelation
Creates a new relation.
SingleColumnRelation(ColumnIdentifier, Operator, Term.Raw) - Constructor for class org.apache.cassandra.cql3.SingleColumnRelation
Creates a new relation.
SingleColumnRestriction - Class in org.apache.cassandra.cql3.restrictions
 
SingleColumnRestriction(ColumnMetadata) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
 
SingleColumnRestriction.ContainsRestriction - Class in org.apache.cassandra.cql3.restrictions
 
SingleColumnRestriction.EQRestriction - Class in org.apache.cassandra.cql3.restrictions
 
SingleColumnRestriction.INRestriction - Class in org.apache.cassandra.cql3.restrictions
 
SingleColumnRestriction.InRestrictionWithMarker - Class in org.apache.cassandra.cql3.restrictions
 
SingleColumnRestriction.InRestrictionWithValues - Class in org.apache.cassandra.cql3.restrictions
 
SingleColumnRestriction.IsNotNullRestriction - Class in org.apache.cassandra.cql3.restrictions
 
SingleColumnRestriction.LikeRestriction - Class in org.apache.cassandra.cql3.restrictions
 
SingleColumnRestriction.SliceRestriction - Class in org.apache.cassandra.cql3.restrictions
 
SingleDatacenterFilter(IEndpointSnitch, String) - Constructor for class org.apache.cassandra.dht.RangeStreamer.SingleDatacenterFilter
 
SinglePartitionBuilder(ColumnFamilyStore, DecoratedKey) - Constructor for class org.apache.cassandra.db.AbstractReadCommandBuilder.SinglePartitionBuilder
 
SinglePartitionPager - Class in org.apache.cassandra.service.pager
Common interface to single partition queries (by slice and by name).
SinglePartitionPager(SinglePartitionReadQuery, PagingState, ProtocolVersion) - Constructor for class org.apache.cassandra.service.pager.SinglePartitionPager
 
SinglePartitionReadCommand - Class in org.apache.cassandra.db
A read command that selects a (part of a) single partition.
SinglePartitionReadCommand(boolean, int, boolean, TableMetadata, int, ColumnFilter, RowFilter, DataLimits, DecoratedKey, ClusteringIndexFilter, IndexMetadata) - Constructor for class org.apache.cassandra.db.SinglePartitionReadCommand
 
SinglePartitionReadCommand.Group - Class in org.apache.cassandra.db
Groups multiple single partition read commands.
SinglePartitionReadQuery - Interface in org.apache.cassandra.db
A ReadQuery for a single partition.
SinglePartitionReadQuery.Group<T extends SinglePartitionReadQuery> - Class in org.apache.cassandra.db
Groups multiple single partition read queries.
SingleRestriction - Interface in org.apache.cassandra.cql3.restrictions
A single restriction/clause on one or multiple column.
singleRowUpdate(TableMetadata, DecoratedKey, Row, Row) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
Creates an immutable partition update that contains a single row update.
singleRowUpdate(TableMetadata, DecoratedKey, Row) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
Creates an immutable partition update that contains a single row update.
singleRowUpdate(TableMetadata, ByteBuffer, Row) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
Creates an immutable partition update that contains a single row update.
SingleSSTableLCSTask - Class in org.apache.cassandra.db.compaction
Special compaction task that does not do any compaction, instead it just mutates the level metadata on the sstable and notifies the compaction strategy.
SingleSSTableLCSTask(ColumnFamilyStore, LifecycleTransaction, int) - Constructor for class org.apache.cassandra.db.compaction.SingleSSTableLCSTask
 
singleton(Unfiltered, TableMetadata, DecoratedKey, DeletionTime, RegularAndStaticColumns, Row, boolean, EncodingStats) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
 
singleton(Object) - Static method in class org.apache.cassandra.utils.btree.BTree
 
singleton(T, Comparator<? super T>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
singletonIterator(RowIterator) - Static method in class org.apache.cassandra.db.partitions.PartitionIterators
 
SingletonUnfilteredPartitionIterator - Class in org.apache.cassandra.db.partitions
 
SingletonUnfilteredPartitionIterator(UnfilteredRowIterator) - Constructor for class org.apache.cassandra.db.partitions.SingletonUnfilteredPartitionIterator
 
sink - Static variable in class org.apache.cassandra.streaming.StreamSession
 
size() - Method in class org.apache.cassandra.batchlog.Batch
Count of the mutations in the batch.
size() - Method in interface org.apache.cassandra.cache.CacheSize
 
size() - Method in class org.apache.cassandra.cache.CaffeineCache
 
size() - Method in class org.apache.cassandra.cache.ChunkCache
 
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.functions.types.UserType
Returns the number of fields in this UDT.
size() - Method in interface org.apache.cassandra.cql3.restrictions.Restrictions
Returns the number of columns that have a restriction.
size() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
 
size() - Method in class org.apache.cassandra.cql3.ResultSet
 
size() - Method in class org.apache.cassandra.cql3.UntypedResultSet
 
size() - Method in class org.apache.cassandra.db.AbstractOnHeapClusteringPrefix
 
size() - Method in class org.apache.cassandra.db.ClusteringComparator
The number of clustering columns for the table this is the comparator of.
size() - Method in interface org.apache.cassandra.db.ClusteringPrefix
The number of values in this prefix.
size() - Method in class org.apache.cassandra.db.Columns
The total number of columns in this object.
size() - Method in class org.apache.cassandra.db.compaction.CompactionTasks
 
size(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
size(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
size() - Method in class org.apache.cassandra.db.marshal.TupleType
 
size(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
 
size - Variable in class org.apache.cassandra.db.MultiCBuilder
The number of clustering elements that have been added.
size() - Method in class org.apache.cassandra.db.NativeClustering
 
size() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
size() - Method in class org.apache.cassandra.db.RegularAndStaticColumns
Returns the total number of static and regular columns.
size() - Method in class org.apache.cassandra.db.rows.CellPath
 
size() - Method in class org.apache.cassandra.db.Slices.Builder
 
size() - Method in class org.apache.cassandra.db.Slices
The number of slice this object contains.
size() - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader
 
size() - Method in class org.apache.cassandra.db.view.TableViews
 
size(Token) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
size(Token) - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
size(Token) - Method in class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
 
size(Token) - Method in class org.apache.cassandra.dht.Token
Returns a measure for the token space covered between this token and next.
size - Variable in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.TermSize
 
size() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
size() - Method in class org.apache.cassandra.io.util.ChannelProxy
 
size - Variable in class org.apache.cassandra.io.util.Memory
 
size() - Method in class org.apache.cassandra.io.util.Memory
 
size() - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
 
size() - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaMap
 
size() - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
 
size() - Method in interface org.apache.cassandra.locator.ReplicaCollection
 
size - Variable in class org.apache.cassandra.metrics.BufferPoolMetrics
Total size of buffer pools, in bytes, including overflow allocation
size - Variable in class org.apache.cassandra.metrics.CacheMetrics
Total size of cache, in bytes
size() - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
Returns the logical number of buckets where recorded values are stored.
size - Variable in class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
 
size() - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
 
size() - Method in class org.apache.cassandra.schema.Functions
 
size() - Method in class org.apache.cassandra.schema.Indexes
 
size() - Method in class org.apache.cassandra.schema.Tables
 
size() - Method in class org.apache.cassandra.schema.Triggers
 
size() - Method in class org.apache.cassandra.schema.Views
 
size() - Method in class org.apache.cassandra.tools.nodetool.SetHostStat
 
size() - Method in class org.apache.cassandra.tools.nodetool.SetHostStatWithPort
 
size() - Method in class org.apache.cassandra.utils.BiMultiValMap
 
size(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
 
size() - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
size() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
size() - Method in class org.apache.cassandra.utils.concurrent.Accumulator
 
size() - Method in class org.apache.cassandra.utils.concurrent.Refs
 
size() - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
size() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
size - Variable in class org.apache.cassandra.utils.DirectorySizeCalculator
 
size() - Method in class org.apache.cassandra.utils.DynamicList
 
size() - Method in class org.apache.cassandra.utils.LockedDynamicList
 
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.MerkleTrees
 
size() - Method in class org.apache.cassandra.utils.SlidingTimeRate
 
size() - Method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram
 
sizeComparator - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
SizeEstimatesRecorder - Class in org.apache.cassandra.db
A very simplistic/crude partition count/size estimator.
sizeFromOffset(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
 
sizeInBytes() - Method in class org.apache.cassandra.utils.memory.BufferPool
 
sizeOf(Component) - Method in class org.apache.cassandra.db.streaming.ComponentManifest
 
sizeof(String) - Static method in class org.apache.cassandra.db.TypeSizes
assumes UTF8
sizeof(boolean) - Static method in class org.apache.cassandra.db.TypeSizes
 
sizeof(byte) - Static method in class org.apache.cassandra.db.TypeSizes
 
sizeof(short) - Static method in class org.apache.cassandra.db.TypeSizes
 
sizeof(int) - Static method in class org.apache.cassandra.db.TypeSizes
 
sizeof(long) - Static method in class org.apache.cassandra.db.TypeSizes
 
sizeof(float) - Static method in class org.apache.cassandra.db.TypeSizes
 
sizeof(double) - Static method in class org.apache.cassandra.db.TypeSizes
 
sizeof(UUID) - Static method in class org.apache.cassandra.db.TypeSizes
 
sizeOf(AbstractType<?>) - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.TermSize
 
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
sizeOfAsciiString(String) - Static method in class org.apache.cassandra.transport.CBUtil
Returns the ecoding size of a US-ASCII string.
sizeOfBytes(byte[]) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeOfBytesMap(Map<String, ByteBuffer>) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeOfCollectionSize(int, ProtocolVersion) - 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
 
sizeOfInetAddr(InetAddress) - 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
 
sizeOfStructureOnHeap(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
 
sizeofUnsignedVInt(long) - Static method in class org.apache.cassandra.db.TypeSizes
 
sizeOfUUID(UUID) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeOfValue(V, ValueAccessor<V>, ProtocolVersion) - 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
 
sizeOfValue(int) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeOfValueList(List<ByteBuffer>) - Static method in class org.apache.cassandra.transport.CBUtil
 
sizeofVInt(long) - Static method in class org.apache.cassandra.db.TypeSizes
 
sizeofWithLength(ByteBuffer) - Static method in class org.apache.cassandra.db.TypeSizes
 
sizeofWithShortLength(ByteBuffer) - Static method in class org.apache.cassandra.db.TypeSizes
 
sizeofWithVIntLength(ByteBuffer) - Static 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
sizeRatio() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
 
sizeString() - Method in class org.apache.cassandra.repair.consistent.admin.PendingStat
 
SizeTieredCompactionStrategy - Class in org.apache.cassandra.db.compaction
 
SizeTieredCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
SizeTieredCompactionStrategyOptions - Class in org.apache.cassandra.db.compaction
 
SizeTieredCompactionStrategyOptions(Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
SizeTieredCompactionStrategyOptions() - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
 
sizeTieredOptions - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
sizeWithShortLength(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
serialized size including a short length prefix
sizeWithVIntLength(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
serializes size including a vint length prefix
Sjk - Class in org.apache.cassandra.tools.nodetool
 
Sjk() - Constructor for class org.apache.cassandra.tools.nodetool.Sjk
 
Sjk.Wrapper - Class in org.apache.cassandra.tools.nodetool
Adopted copy of SJK from https://github.com/aragozin/jvm-tools.
skip(DataInputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Clustering.Serializer
 
skip(DataInputPlus, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.ClusteringPrefix.Serializer
 
skip(DataInputPlus) - Method in class org.apache.cassandra.db.DeletionTime.Serializer
 
skip(DataInputPlus, Version) - Static method in class org.apache.cassandra.db.RowIndexEntry.Serializer
 
skip(DataInputPlus) - Method in interface org.apache.cassandra.db.rows.CellPath.Serializer
 
skip(DataInputPlus) - Method in interface org.apache.cassandra.io.ISerializer
 
skip(DataInputPlus) - Method in class org.apache.cassandra.io.sstable.IndexInfo.Serializer
 
skip(long) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
 
skip(long) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
skip(long) - Method in class org.apache.cassandra.io.util.TrackedInputStream
 
SKIP_SYNC - Static variable in class org.apache.cassandra.utils.SyncUtil
 
skipBytes(int) - Method in interface org.apache.cassandra.io.util.DataInputPlus
Always skips the requested number of bytes, unless EOF is reached
skipBytes(int) - Method in class org.apache.cassandra.io.util.RandomAccessReader
 
skipBytes(int) - Method in class org.apache.cassandra.io.util.RebufferingInputStream
 
skipBytes(int) - Method in class org.apache.cassandra.io.util.RewindableDataInputStreamPlus
 
skipBytes(int) - Method in class org.apache.cassandra.io.util.SequentialWriter
 
skipBytes(int) - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
 
skipBytesFully(int) - Method in interface org.apache.cassandra.io.util.DataInputPlus
 
skipDeletionTime(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
 
skipForCache(DataInputPlus) - Static method in class org.apache.cassandra.db.RowIndexEntry.Serializer
 
SkipListMemIndex - Class in org.apache.cassandra.index.sasi.memory
 
SkipListMemIndex(AbstractType<?>, ColumnIndex) - Constructor for class org.apache.cassandra.index.sasi.memory.SkipListMemIndex
 
skipLocalDeletionTime(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
 
skipMarkerBody(DataInputPlus) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
skipMetadata() - Method in class org.apache.cassandra.cql3.QueryOptions
 
skipNext() - Method in class org.apache.cassandra.db.ClusteringPrefix.Deserializer
 
skipNext() - Method in class org.apache.cassandra.db.UnfilteredDeserializer
Skips the next atom.
skippedReplicas - Variable in class org.apache.cassandra.repair.RepairSessionResult
 
skipRowBody(DataInputPlus) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
skipShortLength(DataInputPlus) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
skipStaticRow(DataInputPlus, SerializationHeader, DeserializationHelper) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
skipTemporary(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
skipTimestamp(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
 
skipTo(K) - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator
When called, this iterators current position should be skipped forwards until finding either: 1) an element equal to or bigger than next 2) the end of the iterator
skipTTL(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
 
skipUnsignedVInt(DataInputPlus) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
 
skipValue(DataInputPlus) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
skipValue(ByteBuffer, ProtocolVersion) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
 
skipValue(V, ValueAccessor<V>, int, ProtocolVersion) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
 
skipValues(DataInputPlus, ClusteringPrefix.Kind, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.ClusteringBoundOrBoundary.Serializer
 
skipWithVIntLength(DataInputPlus) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
SlabAllocator - Class in org.apache.cassandra.utils.memory
+ * The SlabAllocator is a bump-the-pointer allocator that allocates + * large (1MB) global regions and then doles them out to threads that + * request smaller sized (up to 128kb) slices into the array.
SlabPool - Class in org.apache.cassandra.utils.memory
 
SlabPool(long, long, float, MemtableCleaner) - Constructor for class org.apache.cassandra.utils.memory.SlabPool
 
sleep(long, TimeUnit) - Method in class org.apache.cassandra.utils.SystemTimeSource
 
sleep(long, TimeUnit) - Method in interface org.apache.cassandra.utils.TimeSource
Sleep for the given amount of time.
sleepQuietly(long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
sleepUninterruptibly(long, TimeUnit) - Method in class org.apache.cassandra.utils.SystemTimeSource
 
sleepUninterruptibly(long, TimeUnit) - Method in interface org.apache.cassandra.utils.TimeSource
Sleep for the given amount of time uninterruptibly.
slice(ColumnMetadata, CellPath, CellPath) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Builder
 
slice(ColumnMetadata, CellPath, CellPath) - Static method in class org.apache.cassandra.db.filter.ColumnSubselection
 
slice(byte[], int, int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
slice(ByteBuffer, int, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
slice(V, int, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
Returns a value with the contents of from to .
Slice - Class in org.apache.cassandra.db
A slice represents the selection of a range of rows.
slice(Object[], Comparator<? super K>, BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
Returns an Iterator over the entire tree
slice(Object[], Comparator<? super K>, K, K, BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
 
slice(Object[], Comparator<? super K>, int, int, BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
 
slice(Object[], Comparator<? super K>, K, boolean, K, boolean, BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
 
slice(BTree.Dir) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
 
slice(BTree.Dir) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
slice(BTree.Dir) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
Slice.Serializer - Class in org.apache.cassandra.db
 
sliceAndConsume(int) - Method in class org.apache.cassandra.net.ShareableBytes
Create a slice over the next length bytes, consuming them from our buffer, and incrementing the owner count
sliceDirectByteBuffer(ByteBuffer, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
 
SliceRestriction(List<ColumnMetadata>, Bound, boolean, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
 
SliceRestriction(ColumnMetadata, Bound, boolean, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
 
SliceRestriction(TableMetadata, List<ColumnMetadata>, Bound, boolean, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.TokenRestriction.SliceRestriction
 
slices - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
Slices - Class in org.apache.cassandra.db
Represents the selection of multiple range of rows within a partition.
Slices() - Constructor for class org.apache.cassandra.db.Slices
 
Slices.Builder - Class in org.apache.cassandra.db
Builder to create Slices objects.
Slices.InOrderTester - Interface in org.apache.cassandra.db
In simple object that allows to test the inclusion of rows in those slices assuming those rows are passed (to Slices.InOrderTester.includes(org.apache.cassandra.db.Clustering<?>)) in clustering order (or reverse clustering ordered, depending of the argument passed to Slices.inOrderTester(boolean)).
Slices.Serializer - Class in org.apache.cassandra.db
 
sliceWithShortLength(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
same as ValueAccessor.slice(Object, int, int), except the length is taken from the first 2 bytes from the given offset (and not included in the return value)
SlidingTimeRate - Class in org.apache.cassandra.utils
Concurrent rate computation over a sliding time window.
SlidingTimeRate(TimeSource, long, long, TimeUnit) - Constructor for class org.apache.cassandra.utils.SlidingTimeRate
Creates a sliding rate whose time window is of the given size, with the given precision and time unit.
slow_query_log_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
slowTimeoutNanos() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
 
slowTimeoutNanos() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
 
small - Variable in class org.apache.cassandra.net.OutboundConnections
 
smallestGCGS() - Method in class org.apache.cassandra.db.Mutation
 
smallestToken() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
 
smallestToken() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
 
smallint() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the SMALLINT type.
smallInt() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type smallint.
smallMessageCompletedBytes - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Completed bytes for small message TCP Connections
smallMessageCompletedTasks - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Completed tasks for small message TCP Connections
smallMessageDroppedBytesDueToError - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped bytes because of error for small message TCP Connections
smallMessageDroppedBytesDueToOverload - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped bytes because of overload for small message TCP Connections
smallMessageDroppedBytesDueToTimeout - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped bytes because of timeout for small message TCP Connections
smallMessageDroppedTasks - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped tasks for small message TCP Connections
smallMessageDroppedTasksDueToError - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped tasks because of error for small message TCP Connections
smallMessageDroppedTasksDueToOverload - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped tasks because of overload for small message TCP Connections
smallMessageDroppedTasksDueToTimeout - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped tasks because of timeout for small message TCP Connections
smallMessagePendingBytes - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Pending bytes for small message TCP Connections
smallMessagePendingTasks - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Pending tasks for small message TCP Connections
snappy() - Static method in class org.apache.cassandra.schema.CompressionParams
 
snappy(int) - Static method in class org.apache.cassandra.schema.CompressionParams
 
snappy(int, double) - Static method in class org.apache.cassandra.schema.CompressionParams
 
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, boolean, RateLimiter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Take a snap shot of this columnfamily store.
snapshot(String, Predicate<SSTableReader>, boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
snapshot(String, Predicate<SSTableReader>, boolean, boolean, RateLimiter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
snapshot(String, String, boolean, RateLimiter) - 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(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(String, Collection<Range<Token>>, boolean) - Method in class org.apache.cassandra.db.repair.CassandraTableRepairManager
 
snapshot() - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
 
snapshot() - Method in class org.apache.cassandra.locator.EndpointsForRange.Builder
 
snapshot() - Method in class org.apache.cassandra.locator.EndpointsForRange
 
snapshot() - Method in class org.apache.cassandra.locator.EndpointsForToken.Builder
 
snapshot() - Method in class org.apache.cassandra.locator.EndpointsForToken
 
snapshot(AbstractReplicaCollection.ReplicaList) - Method in class org.apache.cassandra.locator.EndpointsForToken
 
snapshot() - Method in class org.apache.cassandra.locator.RangesAtEndpoint.Builder
 
snapshot(AbstractReplicaCollection.ReplicaList) - Method in class org.apache.cassandra.locator.RangesAtEndpoint
 
snapshot() - Method in class org.apache.cassandra.locator.RangesAtEndpoint
 
snapshot() - Method in interface org.apache.cassandra.locator.ReplicaCollection.Builder
 
snapshot() - Method in class org.apache.cassandra.metrics.ChunkCacheMetrics
 
snapshot(String, Collection<Range<Token>>, boolean) - Method in interface org.apache.cassandra.repair.TableRepairManager
For snapshot repairs.
snapshot() - Method in class org.apache.cassandra.schema.Schema
 
Snapshot - Class in org.apache.cassandra.tools.nodetool
 
Snapshot() - Constructor for class org.apache.cassandra.tools.nodetool.Snapshot
 
snapshot() - Method in class org.apache.cassandra.utils.concurrent.Accumulator
 
snapshot(SnapshotCommand, InetAddressAndPort) - Static method in class org.apache.cassandra.utils.DiagnosticSnapshotService
 
snapshot_before_compaction - Variable in class org.apache.cassandra.config.Config
 
SNAPSHOT_DROP_PREFIX - Static variable in class org.apache.cassandra.db.ColumnFamilyStore
 
snapshot_links_per_second - Variable in class org.apache.cassandra.config.Config
 
snapshot_name - Variable in class org.apache.cassandra.db.SnapshotCommand
 
snapshot_on_duplicate_row_detection - Variable in class org.apache.cassandra.config.Config
If true, when rows with duplicate clustering keys are detected during a read or compaction a snapshot will be taken.
snapshot_on_repaired_data_mismatch - Variable in class org.apache.cassandra.config.Config
 
SNAPSHOT_SUBDIR - Static variable in class org.apache.cassandra.db.Directories
 
SNAPSHOT_TRUNCATE_PREFIX - Static variable in class org.apache.cassandra.db.ColumnFamilyStore
 
SnapshotCommand - Class in org.apache.cassandra.db
 
SnapshotCommand(String, String, String, boolean) - Constructor for class org.apache.cassandra.db.SnapshotCommand
 
snapshotCreationTime(String) - Method in class org.apache.cassandra.db.Directories
 
SnapshotDeletingTask - Class in org.apache.cassandra.io.sstable
 
SnapshotDetailsTabularData - Class in org.apache.cassandra.db
 
SnapshotDetailsTabularData() - Constructor for class org.apache.cassandra.db.SnapshotDetailsTabularData
 
snapshotExists(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
snapshotExists(String) - Method in class org.apache.cassandra.db.Directories
 
snapshotExists(String) - Method in class org.apache.cassandra.db.Keyspace
Check whether snapshots already exists for a given name.
SnapshotMessage - Class in org.apache.cassandra.repair.messages
 
SnapshotMessage(RepairJobDesc) - Constructor for class org.apache.cassandra.repair.messages.SnapshotMessage
 
snapshotOnDuplicateRowDetection() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
snapshotOnRepairedDataMismatch() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
snapshotOnVersionChange() - Static method in class org.apache.cassandra.db.SystemKeyspace
Compare the release version in the system.local table with the one included in the distro.
snapshots(String) - Method in class org.apache.cassandra.db.Directories.SSTableLister
 
SnapshotTask - Class in org.apache.cassandra.repair
SnapshotTask is a task that sends snapshot request.
snapshotting(ReadCommand) - Static method in interface org.apache.cassandra.service.reads.repair.RepairedDataVerifier
 
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, RateLimiter) - 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.transport.Server
 
socketFactory - Variable in class org.apache.cassandra.net.InboundConnectionSettings
 
socketFactory - Variable in class org.apache.cassandra.net.MessagingService
 
socketFactory - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
socketFactory() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
SocketFactory - Class in org.apache.cassandra.net
A factory for building Netty Channels.
socketReceiveBufferSizeInBytes - Variable in class org.apache.cassandra.net.InboundConnectionSettings
 
socketSendBufferSizeInBytes - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
socketSendBufferSizeInBytes() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
SomeRepairFailedException - Exception in org.apache.cassandra.repair
This is a special exception which states "I know something failed but I don't have access to the failure".
SomeRepairFailedException() - Constructor for exception org.apache.cassandra.repair.SomeRepairFailedException
 
sort(Collection<Range<T>>) - Static method in class org.apache.cassandra.dht.Range
 
sort() - Method in class org.apache.cassandra.utils.btree.BTree.Builder
 
sort(long[], LongTimSort.LongComparator) - Static method in class org.apache.cassandra.utils.LongTimSort
 
sort(long[], int, int, LongTimSort.LongComparator) - Static method in class org.apache.cassandra.utils.LongTimSort
 
sorted() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
Creates a CQLSSTableWriter that expects sorted inputs.
sorted(Comparator<Replica>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
 
sorted(Comparator<Replica>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
sorted(Comparator<Replica>) - Method in interface org.apache.cassandra.locator.ReplicaCollection
 
SortedBiMultiValMap<K,V> - Class in org.apache.cassandra.utils
 
SortedBiMultiValMap(SortedMap<K, V>, SortedSetMultimap<V, K>) - Constructor for class org.apache.cassandra.utils.SortedBiMultiValMap
 
sortedBuilder() - Static method in class org.apache.cassandra.db.rows.BTreeRow
 
sortedByProximity(InetAddressAndPort, C) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
Sorts the Collection of node addresses by proximity to the given address
sortedByProximity(InetAddressAndPort, C) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
sortedByProximity(InetAddressAndPort, C) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
returns a new List sorted by proximity to the given endpoint
sortedByProximity(InetAddressAndPort, C) - Method in class org.apache.cassandra.locator.SimpleSnitch
 
sortedStream() - Method in class org.apache.cassandra.schema.Types
Returns a stream of user types sorted by dependencies
sortedTokens() - Method in class org.apache.cassandra.locator.TokenMetadata
 
sortKey - Variable in class org.apache.cassandra.tools.nodetool.stats.TableStatsHolder
 
sortSampledKeys(List<DecoratedKey>, Range<Token>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
source - Variable in class org.apache.cassandra.io.util.BufferManagingRebufferer
 
spaceUsedBySnapshotsTotal - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
spaceUsedLive - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
spaceUsedTotal - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
specForElementOrSlice(Selectable, ColumnSpecification, String) - Method in interface org.apache.cassandra.cql3.selection.Selectable
 
speculatedRead - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
 
speculatedWrite - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
 
SPECULATION_THRESHOLD_UPDATER - Static variable in class org.apache.cassandra.service.CassandraDaemon
 
speculativeFailedRetries - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Speculative retry occured but still timed out
speculativeFailedRetries - Variable in class org.apache.cassandra.metrics.TableMetrics
 
speculativeInsufficientReplicas - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Needed to speculate, but didn't have enough replicas
speculativeInsufficientReplicas - Variable in class org.apache.cassandra.metrics.TableMetrics
 
speculativeRetries - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Speculative retries
speculativeRetries - Variable in class org.apache.cassandra.metrics.TableMetrics
 
speculativeRetry(SpeculativeRetryPolicy) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
speculativeRetry(SpeculativeRetryPolicy) - Method in class org.apache.cassandra.schema.TableParams.Builder
 
speculativeRetry - Variable in class org.apache.cassandra.schema.TableParams
 
SpeculativeRetryPolicy - Interface in org.apache.cassandra.service.reads
 
SpeculativeRetryPolicy.Kind - Enum in org.apache.cassandra.service.reads
 
speculativeSampleLatencyNanos - Variable in class org.apache.cassandra.metrics.TableMetrics
 
SpinningDiskOptimizationStrategy - Class in org.apache.cassandra.io.util
 
SpinningDiskOptimizationStrategy() - Constructor for class org.apache.cassandra.io.util.SpinningDiskOptimizationStrategy
 
split() - Method in class org.apache.cassandra.db.compaction.SSTableSplitter
 
split(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
remove the provided readers from this Transaction, and return a new Transaction to manage them only permitted to be called if the current Transaction has never been used
split(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
Split a composite column names into it's components.
split(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
split(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TupleType
Split a tuple value into its component values.
split(T) - Method in class org.apache.cassandra.dht.AbstractBounds
Given token T and AbstractBounds ?L,R?, returns Pair(?L,T], (T,R?), where ? means that the same type of AbstractBounds is returned as the original.
split(T) - Method in class org.apache.cassandra.dht.Bounds
 
split(Token, Token, double) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
split(T) - Method in class org.apache.cassandra.dht.ExcludingBounds
 
split(T) - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
split(Token, Token, double) - Method in interface org.apache.cassandra.dht.IPartitioner
Calculate a Token which take approximate 0 <= ratioToLeft <= 1 ownership of the given range.
split(Token, Token, double) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
split(Token, Token, double) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
 
split(Token, Token, double) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
split(Token, Token, double) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
split(T) - Method in class org.apache.cassandra.dht.Range
 
split(Collection<Range<Token>>, int) - Method in class org.apache.cassandra.dht.Splitter
Splits the specified token ranges in at least parts subranges.
split() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
 
split(Token) - Method in class org.apache.cassandra.utils.MerkleTree
Splits the range containing the given token, if no tree limits would be violated.
split(Token) - Method in class org.apache.cassandra.utils.MerkleTrees
Split the MerkleTree responsible for the given token.
splitBlock() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
 
SplitController(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.SplitController
 
spliterator() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
splitName(V, ValueAccessor<V>) - Static method in class org.apache.cassandra.db.marshal.CompositeType
 
splitOwnedRanges(int, List<Splitter.WeightedRange>, boolean) - Method in class org.apache.cassandra.dht.Splitter
 
splitter() - Method in interface org.apache.cassandra.dht.IPartitioner
 
splitter() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
 
splitter() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
Splitter - Class in org.apache.cassandra.dht
Partition splitter.
Splitter(IPartitioner) - Constructor for class org.apache.cassandra.dht.Splitter
 
Splitter.WeightedRange - Class in org.apache.cassandra.dht
 
SplittingCompactionTask(ColumnFamilyStore, LifecycleTransaction, int) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.SplittingCompactionTask
 
SplittingSizeTieredCompactionWriter - Class in org.apache.cassandra.db.compaction.writers
CompactionAwareWriter that splits input in differently sized sstables Biggest sstable will be total_compaction_size / 2, second biggest total_compaction_size / 4 etc until the result would be sub 50MB, all those are put in the same
SplittingSizeTieredCompactionWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>) - Constructor for class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
 
SplittingSizeTieredCompactionWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, long) - Constructor for class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
 
splitValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.INRestriction
 
splitValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithMarker
 
splitValues(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithValues
 
spProxy - Variable in class org.apache.cassandra.tools.NodeProbe
 
src - Variable in class org.apache.cassandra.repair.messages.SyncRequest
 
SsdDiskOptimizationStrategy - Class in org.apache.cassandra.io.util
 
SsdDiskOptimizationStrategy(double) - Constructor for class org.apache.cassandra.io.util.SsdDiskOptimizationStrategy
 
SSL - Static variable in class org.apache.cassandra.transport.ConnectedClient
 
SSL_ALGORITHM - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
SSL_CIPHER_SUITES - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
SSL_KEYSTORE - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
SSL_KEYSTORE_PW - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
SSL_PROTOCOL - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
ssl_storage_port - Variable in class org.apache.cassandra.config.Config
 
SSL_STORAGE_PORT_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
SSL_STORE_TYPE - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
SSL_TRUSTSTORE - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
SSL_TRUSTSTORE_PW - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
sslCipherSuite() - Method in class org.apache.cassandra.transport.ConnectedClient
 
sslEnabled() - Method in class org.apache.cassandra.transport.ConnectedClient
 
SSLFactory - Class in org.apache.cassandra.security
A Factory for providing and setting up client SSLSockets.
SSLFactory() - Constructor for class org.apache.cassandra.security.SSLFactory
 
SSLFactory.LoggingCipherSuiteFilter - Class in org.apache.cassandra.security
 
SSLFactory.SocketType - Enum in org.apache.cassandra.security
Indicates if the process holds the inbound/listening end of the socket (SSLFactory.SocketType.SERVER)), or the outbound side (SSLFactory.SocketType.CLIENT).
sslProtocol() - Method in class org.apache.cassandra.transport.ConnectedClient
 
sslStoragePort - Variable in class org.apache.cassandra.tools.LoaderOptions
 
ssProxy - Variable in class org.apache.cassandra.tools.NodeProbe
 
sstable - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
sstable(SSTableReader) - Method in interface org.apache.cassandra.db.compaction.CompactionLogger.Strategy
 
sstable - Variable in class org.apache.cassandra.db.streaming.CassandraStreamWriter
 
sstable - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
SSTable - Class in org.apache.cassandra.io.sstable
This class is built on top of the SequenceFile.
SSTable(Descriptor, Set<Component>, TableMetadataRef, DiskOptimizationStrategy) - Constructor for class org.apache.cassandra.io.sstable.SSTable
 
sstable - Variable in class org.apache.cassandra.notifications.SSTableMetadataChanged
 
SSTABLE_ACTIVITY - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
SSTABLE_COMPRESSION - Static variable in class org.apache.cassandra.schema.CompressionParams
Deprecated.
sstable_preemptive_open_interval_in_mb - Variable in class org.apache.cassandra.config.Config
 
SSTableAddedNotification - Class in org.apache.cassandra.notifications
Notification sent after SSTables are added to their ColumnFamilyStore.
SSTableAddedNotification(Iterable<SSTableReader>, Memtable) - Constructor for class org.apache.cassandra.notifications.SSTableAddedNotification
Creates a new SSTableAddedNotification for the specified SSTables and optional memtable.
sstableComparator - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
sstableCompressionRatio - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
sstableCount - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
SSTableDeletingNotification - Class in org.apache.cassandra.notifications
Fired right before removing an SSTable.
SSTableDeletingNotification(SSTableReader) - Constructor for class org.apache.cassandra.notifications.SSTableDeletingNotification
 
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
 
SSTableFlushObserver - Interface in org.apache.cassandra.io.sstable.format
Observer for events in the lifecycle of writing out an sstable.
SSTableFormat - Interface in org.apache.cassandra.io.sstable.format
Provides the accessors to data on disk.
SSTableFormat.Type - Enum in org.apache.cassandra.io.sstable.format
 
SSTableHeaderFix - Class in org.apache.cassandra.io.sstable
Validates and fixes type issues in the serialization-header of sstables.
SSTableHeaderFix.Builder - Class in org.apache.cassandra.io.sstable
Builder to configure and construct an instance of SSTableHeaderFix.
SSTableIdentityIterator - Class in org.apache.cassandra.io.sstable
 
SSTableIdentityIterator(SSTableReader, DecoratedKey, DeletionTime, String, SSTableSimpleIterator) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
SSTableImporter - Class in org.apache.cassandra.db
 
SSTableImporter(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.SSTableImporter
 
SSTableImporter.Options - Class in org.apache.cassandra.db
 
SSTableIndex - Class in org.apache.cassandra.index.sasi
 
SSTableIndex(ColumnIndex, File, SSTableReader) - Constructor for class org.apache.cassandra.index.sasi.SSTableIndex
 
SSTableIntervalTree - Class in org.apache.cassandra.db.lifecycle
 
SSTableIterator - Class in org.apache.cassandra.db.columniterator
A Cell Iterator over SSTable
SSTableIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry, Slices, ColumnFilter, FileHandle) - Constructor for class org.apache.cassandra.db.columniterator.SSTableIterator
 
sstableLevel - Variable in class org.apache.cassandra.db.streaming.CassandraStreamHeader
 
sstableLevel - Variable in class org.apache.cassandra.db.streaming.CassandraStreamReader
 
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(Directories.OnTxnErr) - Method in class org.apache.cassandra.db.Directories
 
sstableLister(File, Directories.OnTxnErr) - Method in class org.apache.cassandra.db.Directories
 
SSTableLoader - Class in org.apache.cassandra.io.sstable
Cassandra SSTable bulk loader.
SSTableLoader(File, SSTableLoader.Client, OutputHandler) - Constructor for class org.apache.cassandra.io.sstable.SSTableLoader
 
SSTableLoader(File, SSTableLoader.Client, OutputHandler, int, String) - Constructor for class org.apache.cassandra.io.sstable.SSTableLoader
 
SSTableLoader.Client - Class in org.apache.cassandra.io.sstable
 
sstableMetadata - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
SSTableMetadataChanged - Class in org.apache.cassandra.notifications
 
SSTableMetadataChanged(SSTableReader, StatsMetadata) - Constructor for class org.apache.cassandra.notifications.SSTableMetadataChanged
 
SSTableMetadataViewer - Class in org.apache.cassandra.tools
Shows the contents of sstable metadata
SSTableMetadataViewer() - Constructor for class org.apache.cassandra.tools.SSTableMetadataViewer
 
SSTableMetadataViewer(boolean, boolean, int, TimeUnit, PrintStream) - Constructor for class org.apache.cassandra.tools.SSTableMetadataViewer
 
SSTableMultiWriter - Interface in org.apache.cassandra.io.sstable
 
SSTableOfflineRelevel - Class in org.apache.cassandra.tools
Create a decent leveling for the given keyspace/column family Approach is to sort the sstables by their last token given an original leveling like this (note that [ ] indicates token boundaries, not sstable size on disk, all sstables are the same size) L3 [][][][][][][][][][][] L2 [ ][ ][ ][ ] L1 [ ][ ] L0 [ ] Will look like this after being dropped to L0 and sorted by last token (and, to illustrate overlap, the overlapping ones are put on a new line): [][][] [ ][][][] [ ] [ ] ...
SSTableOfflineRelevel() - Constructor for class org.apache.cassandra.tools.SSTableOfflineRelevel
 
sstableOrdering - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
 
SSTableReader - Class in org.apache.cassandra.io.sstable.format
An SSTableReader can be constructed in a number of places, but typically is either read from disk at startup, or constructed from a flushed memtable, or after compaction to replace some existing sstables.
SSTableReader(SSTableReaderBuilder) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader
 
SSTableReader(Descriptor, Set<Component>, TableMetadataRef, long, StatsMetadata, SSTableReader.OpenReason, SerializationHeader, IndexSummary, FileHandle, FileHandle, IFilter) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader
 
SSTableReader.Factory - Class in org.apache.cassandra.io.sstable.format
 
SSTableReader.IndexesBounds - Class in org.apache.cassandra.io.sstable.format
 
SSTableReader.OpenReason - Enum in org.apache.cassandra.io.sstable.format
 
SSTableReader.Operator - Class in org.apache.cassandra.io.sstable.format
TODO: Move someplace reusable
SSTableReader.PartitionPositionBounds - Class in org.apache.cassandra.io.sstable.format
 
SSTableReader.UniqueIdentifier - Class in org.apache.cassandra.io.sstable.format
 
SSTableReaderBuilder - Class in org.apache.cassandra.io.sstable.format
 
SSTableReaderBuilder(Descriptor, TableMetadataRef, long, Set<Component>, StatsMetadata, SSTableReader.OpenReason, SerializationHeader) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
SSTableReaderBuilder.ForBatch - Class in org.apache.cassandra.io.sstable.format
 
SSTableReaderBuilder.ForRead - Class in org.apache.cassandra.io.sstable.format
 
SSTableReaderBuilder.ForWriter - Class in org.apache.cassandra.io.sstable.format
 
SSTableReadsListener - Interface in org.apache.cassandra.io.sstable.format
Listener for receiving notifications associated with reading SSTables.
SSTableReadsListener.SelectionReason - Enum in org.apache.cassandra.io.sstable.format
The reasons for selecting an SSTable
SSTableReadsListener.SkippingReason - Enum in org.apache.cassandra.io.sstable.format
The reasons for skipping an 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
 
SSTableReversedIterator - Class in org.apache.cassandra.db.columniterator
A Cell Iterator in reversed clustering order over SSTable
SSTableReversedIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry, Slices, ColumnFilter, FileHandle) - Constructor for class org.apache.cassandra.db.columniterator.SSTableReversedIterator
 
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(ILifecycleTransaction, long, long, boolean) - Constructor for class org.apache.cassandra.io.sstable.SSTableRewriter
Deprecated.
sstables - Variable in class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
 
SSTABLES - Static variable in class org.apache.cassandra.db.compaction.CompactionInfo
 
sstables - Variable in class org.apache.cassandra.db.compaction.LeveledManifest.CompactionCandidate
 
sstables - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
 
sstables(SSTableSet, Predicate<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.View
 
sstables - Variable in class org.apache.cassandra.db.streaming.CassandraStreamReceiver
 
sstables - Variable in class org.apache.cassandra.notifications.SSTableRepairStatusChanged
 
sstablesDropppedFromCompactions - Variable in class org.apache.cassandra.metrics.CompactionMetrics
Total number of sstables that have been dropped out
SSTableSet - Enum in org.apache.cassandra.db.lifecycle
 
SSTablesGlobalTracker - Class in org.apache.cassandra.service
Tracks all sstables in use on the local node.
SSTablesGlobalTracker(SSTableFormat.Type) - Constructor for class org.apache.cassandra.service.SSTablesGlobalTracker
 
SSTableSimpleIterator - Class in org.apache.cassandra.io.sstable
Utility class to handle deserializing atom from sstables.
sstablesInBounds(PartitionPosition, PartitionPosition, SSTableIntervalTree) - Static method in class org.apache.cassandra.db.lifecycle.View
 
sstablesInEachLevel - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
sstablesPerReadHistogram - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Histogram of the number of sstable data files accessed per read
sstablesPerReadHistogram - Variable in class org.apache.cassandra.metrics.TableMetrics
Histogram of the number of sstable data files accessed per read
SSTableSplitter - Class in org.apache.cassandra.db.compaction
 
SSTableSplitter(ColumnFamilyStore, LifecycleTransaction, int) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter
 
SSTableSplitter.SplitController - Class in org.apache.cassandra.db.compaction
 
SSTableSplitter.SplittingCompactionTask - Class in org.apache.cassandra.db.compaction
 
sstablesRewrite(boolean, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
sstablesTracker - Variable in class org.apache.cassandra.service.StorageService
 
SSTablesVersionsInUseChangeNotification - Class in org.apache.cassandra.service
Notification triggered by a SSTablesGlobalTracker when the set of sstables versions in use on this node changes.
SSTableTxnWriter - Class in org.apache.cassandra.io.sstable
A wrapper for SSTableWriter and LifecycleTransaction to be used when the writer is the only participant in the transaction and therefore it can safely own the transaction.
SSTableTxnWriter(LifecycleTransaction, SSTableMultiWriter) - Constructor for class org.apache.cassandra.io.sstable.SSTableTxnWriter
 
sstableVersions(Set<VersionAndType>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
sstableWindowSize - Variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
sstableWindowUnit - Variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
sstableWriter - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
SSTableWriter - Class in org.apache.cassandra.io.sstable.format
This is the API all table writers must implement.
SSTableWriter(Descriptor, long, long, UUID, boolean, TableMetadataRef, MetadataCollector, SerializationHeader, Collection<SSTableFlushObserver>) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableWriter
 
SSTableWriter.Factory - Class in org.apache.cassandra.io.sstable.format
 
SSTableWriter.TransactionalProxy - Class in org.apache.cassandra.io.sstable.format
 
Stage - Enum in org.apache.cassandra.concurrent
 
stage - Variable in enum org.apache.cassandra.net.Verb
 
stage() - Method in class org.apache.cassandra.transport.ConnectedClient
 
Stage.ExecutorServiceInitialiser - Interface in org.apache.cassandra.concurrent
 
StageConcurrency(int, int) - Constructor for class org.apache.cassandra.service.StorageServiceMBean.StageConcurrency
 
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
 
StandaloneSSTableUtil - Class in org.apache.cassandra.tools
 
StandaloneSSTableUtil() - Constructor for class org.apache.cassandra.tools.StandaloneSSTableUtil
 
StandaloneUpgrader - Class in org.apache.cassandra.tools
 
StandaloneUpgrader() - Constructor for class org.apache.cassandra.tools.StandaloneUpgrader
 
StandaloneVerifier - Class in org.apache.cassandra.tools
 
StandaloneVerifier() - Constructor for class org.apache.cassandra.tools.StandaloneVerifier
 
Standard(ChannelProxy, CompressionMetadata) - Constructor for class org.apache.cassandra.io.util.CompressedChunkReader.Standard
 
StandardAnalyzer - Class in org.apache.cassandra.index.sasi.analyzer
 
StandardAnalyzer() - Constructor for class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
 
StandardAnalyzer.TokenType - Enum in org.apache.cassandra.index.sasi.analyzer
 
StandardTokenizerInterface - Interface in org.apache.cassandra.index.sasi.analyzer
Internal interface for supporting versioned grammars.
StandardTokenizerOptions - Class in org.apache.cassandra.index.sasi.analyzer
Various options for controlling tokenization and enabling or disabling features
StandardTokenizerOptions() - Constructor for class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
StandardTokenizerOptions.OptionsBuilder - Class in org.apache.cassandra.index.sasi.analyzer
 
start() - Method in class org.apache.cassandra.batchlog.BatchlogManager
 
start() - Method in class org.apache.cassandra.concurrent.InfiniteLoopExecutor
 
start() - Method in class org.apache.cassandra.db.commitlog.CommitLog
Tries to start the CommitLog if not already started.
start(Object...) - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder.RangeTombstoneBuilder
Sets the start for the built range using the provided values.
start() - Method in class org.apache.cassandra.db.Slice
 
start() - Static method in class org.apache.cassandra.diag.DiagnosticEventPersistence
 
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 interface org.apache.cassandra.index.transactions.IndexTransaction
 
start - Variable in class org.apache.cassandra.repair.consistent.admin.RepairStats.Section
 
start() - Method in class org.apache.cassandra.repair.consistent.LocalSessions
Loads sessions out of the repairs table and sets state to started
start(ListeningExecutorService) - Method in class org.apache.cassandra.repair.RepairSession
Start RepairJob on given ColumnFamilies.
start() - Method in class org.apache.cassandra.schema.MigrationCoordinator
 
start() - Method in class org.apache.cassandra.service.ActiveRepairService
 
start() - Method in interface org.apache.cassandra.service.CassandraDaemon.Server
Start the server.
start() - Method in class org.apache.cassandra.service.CassandraDaemon
Start the Cassandra Daemon, assuming that it has already been initialized via CassandraDaemon.init(String[]) Hook for JSVC
start() - Method in class org.apache.cassandra.service.EmbeddedCassandraService
 
start() - Method in class org.apache.cassandra.service.NativeTransportService
Starts native transport servers.
start() - Method in class org.apache.cassandra.streaming.StreamSession
invoked by the node that begins the stream session (it may be sending files, receiving files, or both)
start(String[]) - Method in class org.apache.cassandra.tools.nodetool.Sjk.Wrapper
 
start() - Method in class org.apache.cassandra.transport.Server
 
start(ApproximateTime.Measurement) - Static method in class org.apache.cassandra.utils.ApproximateTime
 
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
 
startAt(OnDiskBlock<OnDiskIndex.DataTerm>, Expression) - Method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndex.IteratorOrder
 
startAt(OnDiskBlock.SearchResult<OnDiskIndex.DataTerm>, boolean) - Method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndex.IteratorOrder
 
startBatchlogReplay() - Method in class org.apache.cassandra.batchlog.BatchlogManager
 
startBootstrap(Collection<Token>) - Method in class org.apache.cassandra.service.StorageService
 
startBroadcasting() - Method in class org.apache.cassandra.service.LoadBroadcaster
 
startDeletionTime() - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
The deletion time for the range tombstone this boundary starts (in clustering order).
startDispatch() - Method in class org.apache.cassandra.hints.HintsService
 
STARTED - Static variable in class org.apache.cassandra.repair.consistent.LocalSessionInfo
 
startedAt - Variable in class org.apache.cassandra.repair.consistent.LocalSession
 
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
 
startingOffset(boolean) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
startingOffset(boolean) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
startingOffset(boolean) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
startingOffsetInternal(boolean) - Static method in class org.apache.cassandra.db.marshal.CompositeType
 
startKey() - Method in class org.apache.cassandra.db.DataRange
The start of the partition key range queried by this DataRange.
startNativeTransport() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
startNativeTransport() - Method in class org.apache.cassandra.service.CassandraDaemon
 
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
 
startOfComplexColumn(ColumnMetadata) - Method in class org.apache.cassandra.db.rows.DeserializationHelper
 
startParentRepair(UUID, String, String[], RepairOption) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
startPartition(DecoratedKey, long) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
 
startPartition(DecoratedKey, long) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFlushObserver
Called when a new partition in being written to the sstable, but before any cells are processed (see SSTableFlushObserver.nextUnfilteredCluster(Unfiltered)).
startRepair(DigestResolver<E, P>, Consumer<PartitionIterator>) - Method in class org.apache.cassandra.service.reads.repair.AbstractReadRepair
 
startRepair(DigestResolver<E, P>, Consumer<PartitionIterator>) - Method in class org.apache.cassandra.service.reads.repair.NoopReadRepair
 
startRepair(DigestResolver<E, P>, Consumer<PartitionIterator>) - Method in interface org.apache.cassandra.service.reads.repair.ReadRepair
Called when the digests from the initial read don't match.
startRepairs(UUID, UUID, String, String[], CommonRange) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
starts() - Method in class org.apache.cassandra.db.commitlog.IntervalSet
 
startsWith(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
startSync() - Method in class org.apache.cassandra.repair.AsymmetricRemoteSyncTask
 
startSync() - Method in class org.apache.cassandra.repair.LocalSyncTask
Starts sending/receiving our list of differences to/from the remote endpoint: creates a callback that will be called out of band once the streams complete.
startSync() - Method in class org.apache.cassandra.repair.SymmetricRemoteSyncTask
 
startSync() - Method in class org.apache.cassandra.repair.SyncTask
 
startTime - Variable in class org.apache.cassandra.repair.SyncTask
 
startTimerPeriod(int) - Static method in class org.apache.cassandra.utils.WindowsTimer
 
startTransfer() - Method in class org.apache.cassandra.streaming.messages.OutgoingStreamMessage
 
startup() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
Performs any extra initialization required
startup() - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
 
startup() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
 
startup() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
startup() - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
 
StartupCheck - Interface in org.apache.cassandra.service
A test to determine if the system is in a valid state to start up.
startupChecks - Variable in class org.apache.cassandra.service.CassandraDaemon
 
StartupChecks - Class in org.apache.cassandra.service
Verifies that the system and environment is in a fit state to be started.
StartupChecks() - Constructor for class org.apache.cassandra.service.StartupChecks
 
StartupClusterConnectivityChecker - Class in org.apache.cassandra.net
 
StartupException - Exception in org.apache.cassandra.exceptions
An exception thrown during system startup, indicating the environment or system is not in a valid state to startup.
StartupException(int, String) - Constructor for exception org.apache.cassandra.exceptions.StartupException
 
StartupException(int, String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.StartupException
 
StartupMessage - Class in org.apache.cassandra.transport.messages
The initial message of the protocol.
StartupMessage(Map<String, String>) - Constructor for class org.apache.cassandra.transport.messages.StartupMessage
 
startViewBuild(String, String, UUID) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
stat - Variable in class org.apache.cassandra.repair.SyncTask
 
state(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
state - Variable in class org.apache.cassandra.index.sasi.utils.AbstractIterator
 
STATE - Static variable in class org.apache.cassandra.repair.consistent.LocalSessionInfo
 
state - Variable in class org.apache.cassandra.repair.messages.StatusResponse
 
State() - Constructor for class org.apache.cassandra.service.ClientWarn.State
 
state() - Method in class org.apache.cassandra.service.pager.AggregationQueryPager
 
state() - Method in class org.apache.cassandra.service.pager.MultiPartitionPager
 
state() - Method in class org.apache.cassandra.service.pager.PartitionRangeQueryPager
 
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.SinglePartitionPager
 
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.utils.concurrent.Transactional.AbstractTransactional
 
stateFunction() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
statement - Variable in class org.apache.cassandra.cql3.QueryHandler.Prepared
 
statementId - Variable in class org.apache.cassandra.transport.messages.ExecuteMessage
 
statementId - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
 
StatementRestrictions - Class in org.apache.cassandra.cql3.restrictions
The restrictions corresponding to the relations specified on the where-clause of CQL query.
StatementRestrictions(StatementType, TableMetadata, WhereClause, VariableSpecifications, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
StatementRestrictions(StatementType, TableMetadata, WhereClause, VariableSpecifications, boolean, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
StatementType - Enum in org.apache.cassandra.cql3.statements
 
states() - Method in class org.apache.cassandra.gms.EndpointState
 
stateType() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
STATIC_BUILDER - Static variable in class org.apache.cassandra.db.CBuilder
 
STATIC_CLUSTERING - Static variable in interface org.apache.cassandra.db.Clustering
The special cased clustering used by all static rows.
staticColumn(TableMetadata, ByteBuffer, AbstractType<?>) - Static method in class org.apache.cassandra.schema.ColumnMetadata
 
staticColumn(String, String, String, AbstractType<?>) - Static method in class org.apache.cassandra.schema.ColumnMetadata
 
staticColumns() - Method in class org.apache.cassandra.schema.TableMetadata
 
staticOperations() - Method in class org.apache.cassandra.cql3.Operations
Returns the operation on static columns.
staticRow - Variable in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
staticRow() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
staticRow() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
staticRow() - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
 
staticRow - Variable in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
 
staticRow() - Method in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
 
staticRow() - Method in interface org.apache.cassandra.db.rows.BaseRowIterator
The static part corresponding to this partition (this can be an empty row but cannot be null).
staticRow() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
 
staticRow - Variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer.Header
 
staticRow() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
 
staticRow() - Method in class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
 
staticRow() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader.StreamDeserializer
 
staticRow() - Method in class org.apache.cassandra.db.transform.BaseRows
 
staticRow() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
statics - Variable in class org.apache.cassandra.db.RegularAndStaticColumns
 
StaticTokenTreeBuilder - Class in org.apache.cassandra.index.sasi.disk
Intended usage of this class is to be used in place of DynamicTokenTreeBuilder when multiple index segments produced by PerSSTableIndexWriter are stitched together by PerSSTableIndexWriter.complete().
StaticTokenTreeBuilder(CombinedTerm) - Constructor for class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
 
statistics - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
 
Statistics(RangeIterator.Builder.IteratorType) - Constructor for class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
 
stats() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator
 
stats() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
stats() - Method in interface org.apache.cassandra.db.partitions.Partition
 
stats() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
 
stats - Variable in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
 
stats() - Method in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
 
stats() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
 
stats() - Method in interface org.apache.cassandra.db.rows.UnfilteredRowIterator
Return "statistics" about what is returned by this iterator.
stats() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
 
stats() - Method in class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
 
stats() - Method in class org.apache.cassandra.db.SerializationHeader
 
stats() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader.StreamDeserializer
 
STATS - Static variable in class org.apache.cassandra.io.sstable.Component
 
stats() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
stats() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
Stats(long, long, List<RepairedState.Section>) - Constructor for class org.apache.cassandra.repair.consistent.RepairedState.Stats
 
stats - Variable in class org.apache.cassandra.repair.RepairResult
 
StatsHolder - Interface in org.apache.cassandra.tools.nodetool.stats
Interface for the Stats property bag
StatsKeyspace - Class in org.apache.cassandra.tools.nodetool.stats
 
StatsKeyspace(NodeProbe, String) - Constructor for class org.apache.cassandra.tools.nodetool.stats.StatsKeyspace
 
statsMetadata - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
statsMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
StatsMetadata - Class in org.apache.cassandra.io.sstable.metadata
SSTable metadata that always stay on heap.
StatsMetadata(EstimatedHistogram, EstimatedHistogram, IntervalSet<CommitLogPosition>, long, long, int, int, int, int, double, TombstoneHistogram, int, List<ByteBuffer>, List<ByteBuffer>, boolean, long, long, long, UUID, UUID, boolean) - 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
 
StatsPrinter<T extends StatsHolder> - Interface in org.apache.cassandra.tools.nodetool.stats
Interface for the Stats printer, that'd output statistics given the StatsHolder
StatsPrinter.JsonPrinter<T extends StatsHolder> - Class in org.apache.cassandra.tools.nodetool.stats
 
StatsPrinter.YamlPrinter<T extends StatsHolder> - Class in org.apache.cassandra.tools.nodetool.stats
 
StatsTable - Class in org.apache.cassandra.tools.nodetool.stats
 
StatsTable() - Constructor for class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
StatsTableComparator - Class in org.apache.cassandra.tools.nodetool.stats
Comparator to sort StatsTables by a named statistic.
StatsTableComparator(String, boolean) - Constructor for class org.apache.cassandra.tools.nodetool.stats.StatsTableComparator
 
StatsTableComparator(String, boolean, boolean) - Constructor for class org.apache.cassandra.tools.nodetool.stats.StatsTableComparator
 
Status - Class in org.apache.cassandra.tools.nodetool
 
Status() - Constructor for class org.apache.cassandra.tools.nodetool.Status
 
status - Variable in class org.apache.cassandra.transport.Event.StatusChange
 
STATUS_BOOTSTRAPPING - Static variable in class org.apache.cassandra.gms.VersionedValue
 
STATUS_BOOTSTRAPPING_REPLACE - Static variable in class org.apache.cassandra.gms.VersionedValue
 
STATUS_LEAVING - Static variable in class org.apache.cassandra.gms.VersionedValue
 
STATUS_LEFT - Static variable in class org.apache.cassandra.gms.VersionedValue
 
STATUS_MOVING - Static variable in class org.apache.cassandra.gms.VersionedValue
 
STATUS_NORMAL - Static variable in class org.apache.cassandra.gms.VersionedValue
 
StatusAutoCompaction - Class in org.apache.cassandra.tools.nodetool
 
StatusAutoCompaction() - Constructor for class org.apache.cassandra.tools.nodetool.StatusAutoCompaction
 
StatusBackup - Class in org.apache.cassandra.tools.nodetool
 
StatusBackup() - Constructor for class org.apache.cassandra.tools.nodetool.StatusBackup
 
StatusBinary - Class in org.apache.cassandra.tools.nodetool
 
StatusBinary() - Constructor for class org.apache.cassandra.tools.nodetool.StatusBinary
 
statusCode - Variable in enum org.apache.cassandra.db.compaction.CompactionManager.AllSSTableOpStatus
 
StatusGossip - Class in org.apache.cassandra.tools.nodetool
 
StatusGossip() - Constructor for class org.apache.cassandra.tools.nodetool.StatusGossip
 
StatusHandoff - Class in org.apache.cassandra.tools.nodetool
 
StatusHandoff() - Constructor for class org.apache.cassandra.tools.nodetool.StatusHandoff
 
StatusLogger - Class in org.apache.cassandra.utils
 
StatusLogger() - Constructor for class org.apache.cassandra.utils.StatusLogger
 
StatusRequest - Class in org.apache.cassandra.repair.messages
 
StatusRequest(UUID) - Constructor for class org.apache.cassandra.repair.messages.StatusRequest
 
StatusResponse - Class in org.apache.cassandra.repair.messages
 
StatusResponse(UUID, ConsistentSession.State) - Constructor for class org.apache.cassandra.repair.messages.StatusResponse
 
stcs(Map<String, String>) - Static method in class org.apache.cassandra.schema.CompactionParams
 
StemmerFactory - Class in org.apache.cassandra.index.sasi.analyzer.filter
Returns a SnowballStemmer instance appropriate for a given language
StemmerFactory() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.StemmerFactory
 
StemmingFilters - Class in org.apache.cassandra.index.sasi.analyzer.filter
Filters for performing Stemming on tokens
StemmingFilters() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.StemmingFilters
 
StemmingFilters.DefaultStemmingFilter - Class in org.apache.cassandra.index.sasi.analyzer.filter
 
stemTerms(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
 
step - Variable in enum org.apache.cassandra.index.sasi.disk.OnDiskIndex.IteratorOrder
 
stop() - Method in class org.apache.cassandra.audit.BinAuditLogger
Stop the audit log leaving behind any generated files.
stop() - Method in class org.apache.cassandra.audit.DiagnosticEventAuditLogger
 
stop() - Method in class org.apache.cassandra.audit.FileAuditLogger
 
stop() - Method in interface org.apache.cassandra.audit.IAuditLogger
Stop and cleanup any resources of IAuditLogger implementations.
stop() - Method in class org.apache.cassandra.audit.NoOpAuditLogger
 
stop() - Method in class org.apache.cassandra.db.compaction.CompactionInfo.Holder
 
stop() - Method in class org.apache.cassandra.db.transform.StoppingTransformation
If invoked by a subclass, any partitions iterator this transformation has been applied to will terminate after any currently-processing item is returned, as will any row/unfiltered iterator
stop() - Method in class org.apache.cassandra.db.view.ViewBuilderTask
 
stop() - Method in class org.apache.cassandra.fql.FullQueryLogger
 
stop() - Method in class org.apache.cassandra.gms.Gossiper
 
stop() - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
Stop the client.
stop() - Method in class org.apache.cassandra.repair.consistent.LocalSessions
 
stop() - Method in class org.apache.cassandra.service.ActiveRepairService
 
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.service.EmbeddedCassandraService
 
stop() - Method in class org.apache.cassandra.service.NativeTransportService
Stops currently running native transport servers.
stop(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
Stop - Class in org.apache.cassandra.tools.nodetool
 
Stop() - Constructor for class org.apache.cassandra.tools.nodetool.Stop
 
stop() - Method in class org.apache.cassandra.tracing.TraceState
 
stop() - Method in class org.apache.cassandra.transport.Server
 
stop(ApproximateTime.Measurement) - Static method in class org.apache.cassandra.utils.ApproximateTime
 
stop() - Method in class org.apache.cassandra.utils.binlog.BinLog
Stop the consumer thread that writes log records.
stop() - Method in interface org.apache.cassandra.utils.binlog.BinLogArchiver
 
stop() - Method in class org.apache.cassandra.utils.binlog.DeletingArchiver
 
stop() - Method in class org.apache.cassandra.utils.binlog.ExternalArchiver
Stops the archiver thread and tries to archive all existing files this handles the case where a user explicitly disables full/audit log and would expect all log files to be archived rolled or not
stopBuild() - Method in class org.apache.cassandra.db.view.TableViews
 
stopById(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
stopCassandraDaemon() - Method in class org.apache.cassandra.tools.NodeProbe
 
stopClient() - Method in class org.apache.cassandra.service.StorageService
 
stopCompaction(String) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
stopCompaction(String) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Stop all running compaction-like tasks having the provided type.
stopCompactionById(String) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
stopCompactionById(String) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
Stop an individual running compaction using the compactionId.
stopDaemon() - Method in class org.apache.cassandra.service.StorageService
 
stopDaemon() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
StopDaemon - Class in org.apache.cassandra.tools.nodetool
 
StopDaemon() - Constructor for class org.apache.cassandra.tools.nodetool.StopDaemon
 
stopFullQueryLogger() - Method in class org.apache.cassandra.service.StorageService
 
stopFullQueryLogger() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Stop logging queries but leave any generated files on disk.
stopFullQueryLogger() - Method in class org.apache.cassandra.tools.NodeProbe
 
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
 
stopInPartition() - Method in class org.apache.cassandra.db.transform.StoppingTransformation
If invoked by a subclass, any rows/unfiltered iterator this transformation has been applied to will terminate after any currently-processing item is returned
stopKey() - Method in class org.apache.cassandra.db.DataRange
The end of the partition key range queried by this DataRange.
stopNativeTransport() - Method in class org.apache.cassandra.service.CassandraDaemon
 
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
 
StoppingTransformation<I extends BaseRowIterator<?>> - Class in org.apache.cassandra.db.transform
 
StoppingTransformation() - Constructor for class org.apache.cassandra.db.transform.StoppingTransformation
 
stopSession() - Method in class org.apache.cassandra.tracing.Tracing
Stop the session and record its complete.
stopSessionImpl() - Method in class org.apache.cassandra.tracing.Tracing
 
stopShutdownAndWait(long, TimeUnit) - Method in class org.apache.cassandra.gms.Gossiper
 
stopTransports() - Method in class org.apache.cassandra.service.StorageService
 
stopUnsafe(boolean) - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogSegmentManager
Stops CL, for testing purposes.
stopUnsafe(boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLog
FOR TESTING PURPOSES
StopWordFactory - Class in org.apache.cassandra.index.sasi.analyzer.filter
Provides a list of Stop Words for a given language
StopWordFactory() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.StopWordFactory
 
StopWordFilters - Class in org.apache.cassandra.index.sasi.analyzer.filter
Filter implementations for input matching Stop Words
StopWordFilters() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.StopWordFilters
 
StopWordFilters.DefaultStopWordFilter - Class in org.apache.cassandra.index.sasi.analyzer.filter
 
storage_port - Variable in class org.apache.cassandra.config.Config
 
STORAGE_PORT_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
StorageHook - Interface in org.apache.cassandra.db
 
StorageMetrics - Class in org.apache.cassandra.metrics
Metrics related to Storage.
StorageMetrics() - Constructor for class org.apache.cassandra.metrics.StorageMetrics
 
storagePort - Variable in class org.apache.cassandra.tools.LoaderOptions
 
StorageProxy - Class in org.apache.cassandra.service
 
StorageProxy.LocalReadRunnable - 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
 
StorageServiceMBean.StageConcurrency - Class in org.apache.cassandra.service
Gets the concurrency settings for processing stages
store(Batch) - Static method in class org.apache.cassandra.batchlog.BatchlogManager
 
store(Batch, boolean) - Static method in class org.apache.cassandra.batchlog.BatchlogManager
 
store(DiagnosticEvent) - Method in class org.apache.cassandra.diag.store.DiagnosticEventMemoryStore
 
store(DiagnosticEvent) - Method in interface org.apache.cassandra.diag.store.DiagnosticEventStore
Stores provided event and returns the new associated store key for it.
store_type - Variable in class org.apache.cassandra.config.EncryptionOptions
 
storeKeyspaceInstance(Keyspace) - Method in class org.apache.cassandra.schema.Schema
Store given Keyspace instance to the schema
storeKeyspaceInstance(Keyspace) - Method in interface org.apache.cassandra.schema.SchemaProvider
 
strategyLogger() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
strategyLogger() - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
Deprecated.
 
strategyLogger() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
 
stream() - Method in class org.apache.cassandra.io.sstable.SSTableLoader
 
stream(Set<InetAddressAndPort>, StreamEventHandler...) - Method in class org.apache.cassandra.io.sstable.SSTableLoader
 
stream() - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
 
stream() - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
 
stream() - Method in interface org.apache.cassandra.locator.ReplicaCollection
 
stream() - Method in class org.apache.cassandra.schema.Functions
 
stream() - Method in class org.apache.cassandra.schema.Indexes
 
stream() - Method in class org.apache.cassandra.schema.Keyspaces
 
stream() - Method in class org.apache.cassandra.schema.Tables
 
stream() - Method in class org.apache.cassandra.schema.Types
 
stream() - Method in class org.apache.cassandra.schema.Views
 
stream(TableId) - Method in class org.apache.cassandra.schema.Views
 
stream() - Method in class org.apache.cassandra.service.RangeRelocator
 
stream - Variable in class org.apache.cassandra.streaming.messages.IncomingStreamMessage
 
stream - Variable in class org.apache.cassandra.streaming.messages.OutgoingStreamMessage
 
stream_entire_sstables - Variable in class org.apache.cassandra.config.Config
 
STREAM_THROTTLE_MBITS - Static variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
stream_throughput_outbound_megabits_per_sec - Variable in class org.apache.cassandra.config.Config
 
StreamCompressionInputStream - Class in org.apache.cassandra.streaming.compress
 
StreamCompressionInputStream(DataInputPlus, int) - Constructor for class org.apache.cassandra.streaming.compress.StreamCompressionInputStream
 
StreamCompressionSerializer - Class in org.apache.cassandra.streaming.async
A serialiazer for stream compressed files (see package-level documentation).
StreamCompressionSerializer(ByteBufAllocator) - Constructor for class org.apache.cassandra.streaming.async.StreamCompressionSerializer
 
StreamConnectionFactory - Interface in org.apache.cassandra.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(StreamOperation, int, StreamConnectionFactory, boolean, boolean, UUID, PreviewKind) - Constructor for class org.apache.cassandra.streaming.StreamCoordinator
 
StreamDeserializer(TableMetadata, DataInputPlus, Version, SerializationHeader) - Constructor for class org.apache.cassandra.db.streaming.CassandraStreamReader.StreamDeserializer
 
streamEntireSSTables() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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
 
StreamFromOptions - Class in org.apache.cassandra.repair.asymmetric
Keeps track of where a node needs to stream a given range from.
StreamFromOptions(DifferenceHolder, Range<Token>) - Constructor for class org.apache.cassandra.repair.asymmetric.StreamFromOptions
 
StreamHook - Interface in org.apache.cassandra.streaming
 
streamId - Variable in class org.apache.cassandra.transport.Envelope.Header
 
streaming_connections_per_host - Variable in class org.apache.cassandra.config.Config
 
streaming_keep_alive_period_in_secs - Variable in class org.apache.cassandra.config.Config
 
StreamingInboundHandler - Class in org.apache.cassandra.streaming.async
Handles the inbound side of streaming messages and stream data.
StreamingInboundHandler(InetAddressAndPort, int, StreamSession) - Constructor for class org.apache.cassandra.streaming.async.StreamingInboundHandler
 
StreamingMessageSender - Interface in org.apache.cassandra.streaming
 
StreamingMetrics - Class in org.apache.cassandra.metrics
Metrics for streaming.
StreamingMetrics(InetAddressAndPort) - Constructor for class org.apache.cassandra.metrics.StreamingMetrics
 
StreamingRepairTask - Class in org.apache.cassandra.repair
StreamingRepairTask performs data streaming between two remote replicas, neither of which is repair coordinator.
StreamingRepairTask(RepairJobDesc, InetAddressAndPort, InetAddressAndPort, InetAddressAndPort, Collection<Range<Token>>, UUID, PreviewKind, boolean) - Constructor for class org.apache.cassandra.repair.StreamingRepairTask
 
StreamingTombstoneHistogramBuilder - Class in org.apache.cassandra.utils.streamhist
Histogram that can be constructed from streaming of data.
StreamingTombstoneHistogramBuilder(int, int, int) - Constructor for class org.apache.cassandra.utils.streamhist.StreamingTombstoneHistogramBuilder
 
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(InetAddressAndPort, int, UUID, StreamOperation, UUID, PreviewKind) - Constructor for class org.apache.cassandra.streaming.messages.StreamInitMessage
 
StreamManager - Class in org.apache.cassandra.streaming
StreamManager manages currently running StreamResultFutures and provides status of all operation invoked.
StreamManager() - Constructor for class org.apache.cassandra.streaming.StreamManager
 
StreamManager.StreamRateLimiter - Class in org.apache.cassandra.streaming
 
StreamManagerMBean - Interface in org.apache.cassandra.streaming
 
StreamMessage - Class in org.apache.cassandra.streaming.messages
StreamMessage is an abstract base class that every messages in streaming protocol inherit.
StreamMessage(StreamMessage.Type) - Constructor for class org.apache.cassandra.streaming.messages.StreamMessage
 
StreamMessage.Serializer<V extends StreamMessage> - Interface in org.apache.cassandra.streaming.messages
StreamMessage serializer
StreamMessage.Type - Enum in org.apache.cassandra.streaming.messages
StreamMessage types
StreamMessageHeader - Class in org.apache.cassandra.streaming.messages
StreamMessageHeader is appended before sending actual data to describe what it's sending.
StreamMessageHeader(TableId, InetAddressAndPort, UUID, boolean, int, int, long, UUID) - Constructor for class org.apache.cassandra.streaming.messages.StreamMessageHeader
 
StreamMessageHeader.FileMessageHeaderSerializer - Class in org.apache.cassandra.streaming.messages
 
streamOperation - Variable in class org.apache.cassandra.streaming.messages.StreamInitMessage
 
streamOperation - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
 
StreamOperation - Enum in org.apache.cassandra.streaming
 
streamOperation - Variable in class org.apache.cassandra.streaming.StreamResultFuture
 
streamOperation() - Method in class org.apache.cassandra.streaming.StreamSession
 
streamOperation - Variable in class org.apache.cassandra.streaming.StreamState
 
StreamPlan - Class in org.apache.cassandra.streaming
StreamPlan is a helper class that builds StreamOperation of given configuration.
StreamPlan(StreamOperation) - Constructor for class org.apache.cassandra.streaming.StreamPlan
Start building stream plan.
StreamPlan(StreamOperation, boolean) - Constructor for class org.apache.cassandra.streaming.StreamPlan
 
StreamPlan(StreamOperation, int, boolean, UUID, PreviewKind) - Constructor for class org.apache.cassandra.streaming.StreamPlan
 
streamProxy - Variable in class org.apache.cassandra.tools.NodeProbe
 
StreamRateLimiter(InetAddressAndPort) - Constructor for class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
 
StreamReceiveException - Exception in org.apache.cassandra.streaming
 
StreamReceiveException(StreamSession, String) - Constructor for exception org.apache.cassandra.streaming.StreamReceiveException
 
StreamReceiveException(StreamSession, Throwable) - Constructor for exception org.apache.cassandra.streaming.StreamReceiveException
 
StreamReceiver - Interface in org.apache.cassandra.streaming
StreamReceiver acts as a staging area for incoming data.
StreamReceiveTask - Class in org.apache.cassandra.streaming
Task that manages receiving files for the session for certain ColumnFamily.
StreamReceiveTask(StreamSession, TableId, int, long) - Constructor for class org.apache.cassandra.streaming.StreamReceiveTask
 
StreamRequest - Class in org.apache.cassandra.streaming
 
StreamRequest(String, RangesAtEndpoint, RangesAtEndpoint, Collection<String>) - 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.
streams - Variable in class org.apache.cassandra.streaming.StreamTransferTask
 
streamSent(OutgoingStreamMessage) - Method in class org.apache.cassandra.streaming.StreamSession
Call back after sending StreamMessageHeader.
StreamSession - Class in org.apache.cassandra.streaming
Handles the streaming a one or more streams to and from a specific remote node.
StreamSession(StreamOperation, InetAddressAndPort, StreamConnectionFactory, boolean, int, UUID, PreviewKind) - Constructor for class org.apache.cassandra.streaming.StreamSession
Create new streaming session with the peer.
StreamSession.MessageStateSink - Interface in org.apache.cassandra.streaming
 
StreamSession.State - Enum in org.apache.cassandra.streaming
State Transition:
streamsNeeded() - Method in class org.apache.cassandra.service.RangeRelocator
 
StreamState - Class in org.apache.cassandra.streaming
Current snapshot of streaming progress.
StreamState(UUID, StreamOperation, Set<SessionInfo>) - Constructor for class org.apache.cassandra.streaming.StreamState
 
StreamStateCompositeData - Class in org.apache.cassandra.streaming.management
 
StreamStateCompositeData() - Constructor for class org.apache.cassandra.streaming.management.StreamStateCompositeData
 
StreamStateStore - Class in org.apache.cassandra.dht
Store and update available ranges (data already received) to system keyspace.
StreamStateStore() - Constructor for class org.apache.cassandra.dht.StreamStateStore
 
StreamSummary - Class in org.apache.cassandra.streaming
Summary of streaming.
StreamSummary(TableId, 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, TableId) - Constructor for class org.apache.cassandra.streaming.StreamTask
 
StreamTransferTask - Class in org.apache.cassandra.streaming
StreamTransferTask sends streams for a given table
StreamTransferTask(StreamSession, TableId) - Constructor for class org.apache.cassandra.streaming.StreamTransferTask
 
strictlyWrapsAround(T, T) - Static method in class org.apache.cassandra.dht.AbstractBounds
Whether left and right forms a wrapping interval, that is if unwrapping wouldn't be a no-op.
strictRuntimeChecks() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
string(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
 
string(byte[]) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
string(byte[], Charset) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
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.
stringAt(int, ClusteringComparator) - Method in interface org.apache.cassandra.db.ClusteringPrefix
 
stringify(ReplicaCollection<?>, boolean) - Static method in class org.apache.cassandra.locator.Replicas
 
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<FieldIdentifier>, List<AbstractType<?>>, boolean) - Static method in class org.apache.cassandra.db.marshal.TypeParser
 
StringToken(String) - Constructor for class org.apache.cassandra.dht.OrderPreservingPartitioner.StringToken
 
stripANSI(String) - Static method in class org.apache.cassandra.tools.Util
 
stripeCount() - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
stripedIndex(int, int) - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
SUB_RANGE_REPAIR_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
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
 
subList(int, int) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
 
subList(int, int) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
subList(int, int) - Method in interface org.apache.cassandra.locator.ReplicaCollection
 
subList(int, int) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
 
subList(int, int) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
subList(int, int) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
subMap(K, K) - Method in class org.apache.cassandra.index.sasi.utils.trie.PatriciaTrie
 
submit(Callable<T>) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
Task Submission / Creation / Objects
submit(Runnable) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
submit(Runnable, T) - Method in class org.apache.cassandra.concurrent.AbstractLocalAwareExecutorService
 
submit(Callable<T>) - Method in enum org.apache.cassandra.concurrent.Stage
 
submit(Runnable) - Method in enum org.apache.cassandra.concurrent.Stage
 
submit(Runnable, T) - Method in enum org.apache.cassandra.concurrent.Stage
 
submitBackground(ColumnFamilyStore) - Method in class org.apache.cassandra.db.compaction.CompactionManager
Call this whenever a compaction might be needed on the given columnfamily.
submitCacheWrite(AutoSavingCache.Writer) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
submitHint(Mutation, Replica, AbstractWriteResponseHandler<IMutation>) - Static method in class org.apache.cassandra.service.StorageProxy
 
submitHint(Mutation, EndpointsForToken, AbstractWriteResponseHandler<IMutation>) - Static method in class org.apache.cassandra.service.StorageProxy
 
submitIndexBuild(SecondaryIndexBuilder) - Method in class org.apache.cassandra.db.compaction.CompactionManager
Is not scheduled, because it is performing disjoint work from sstable compaction.
submitMaximal(ColumnFamilyStore, int, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
submitPendingAntiCompaction(ColumnFamilyStore, RangesAtEndpoint, Refs<SSTableReader>, LifecycleTransaction, UUID, BooleanSupplier) - Method in class org.apache.cassandra.db.compaction.CompactionManager
Splits the given token ranges of the given sstables into a pending repair silo
submitRepairSession(UUID, CommonRange, String, RepairParallelism, boolean, boolean, PreviewKind, boolean, ListeningExecutorService, String...) - Method in class org.apache.cassandra.service.ActiveRepairService
Requests repairs for the given keyspace and column families.
submittedCount() - Method in class org.apache.cassandra.net.OutboundConnection
 
submitUserDefined(ColumnFamilyStore, Collection<Descriptor>, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
submitValidation(Callable<Object>) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
submitValidation(Callable<Object>) - Method in class org.apache.cassandra.db.repair.CassandraTableRepairManager
 
submitValidation(Callable<Object>) - Method in interface org.apache.cassandra.repair.TableRepairManager
Begin execution of the given validation callable.
submitValidation(ColumnFamilyStore, Validator) - Method in class org.apache.cassandra.repair.ValidationManager
Does not mutate data, so is not scheduled.
submitViewBuilder(ViewBuilderTask) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
submitWrite(int) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
SubPool(long, float) - Constructor for class org.apache.cassandra.utils.memory.MemtablePool.SubPool
 
subscribe(INotificationConsumer) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
subscribe(Class<E>, Consumer<E>) - Method in class org.apache.cassandra.diag.DiagnosticEventService
Registers event handler for specified class of events.
subscribe(Class<E>, T, Consumer<E>) - Method in class org.apache.cassandra.diag.DiagnosticEventService
Registers event handler for specified class of events.
subscribe(LatencySubscribers.Subscriber) - Method in class org.apache.cassandra.net.LatencySubscribers
 
subscribeAll(Consumer<DiagnosticEvent>) - Method in class org.apache.cassandra.diag.DiagnosticEventService
Registers event handler for all DiagnosticEvents published from this point.
subSelections() - Method in class org.apache.cassandra.db.filter.ColumnFilter.SelectionColumnFilter
 
subSelections() - Method in class org.apache.cassandra.db.filter.ColumnFilter
Returns the sub-selections or null if there are none.
subSelections() - Method in class org.apache.cassandra.db.filter.ColumnFilter.WildCardColumnFilter
 
subset(Set<String>) - Static method in class org.apache.cassandra.auth.DCPermissions
 
subset(String...) - Static method in class org.apache.cassandra.auth.DCPermissions
 
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
 
substract(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteType
 
substract(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
substract(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
substract(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
substract(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
 
substract(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
substract(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
substract(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
 
substract(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.NumberType
Substracts the left argument from the right one.
substract(NumberType<?>, ByteBuffer, NumberType<?>, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ShortType
 
substractDuration(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TemporalType
Substract the duration from the specified value.
substractDuration(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
Substracter(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Constants.Substracter
 
substractFrom(long) - Method in class org.apache.cassandra.cql3.Duration
Substracts this duration from the specified time in milliseconds.
Substraction(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.Substraction
 
subtract(Range<T>) - Method in class org.apache.cassandra.dht.Range
 
subtract(Collection<Range<T>>, Collection<Range<T>>) - Static method in class org.apache.cassandra.dht.Range
 
subtract(InputPosition) - Method in interface org.apache.cassandra.hints.InputPosition
 
subtractAll(Collection<Range<T>>) - Method in class org.apache.cassandra.dht.Range
 
subtractAll(Collection<Map.Entry<Range<Token>, StreamFromOptions>>, Range<Token>) - Static method in class org.apache.cassandra.repair.asymmetric.RangeDenormalizer
copied from Range - need to iterate over the map entries
subtractIgnoreTransientStatus(Range<Token>) - Method in class org.apache.cassandra.locator.Replica
Don't use this method and ignore transient status unless you are explicitly handling it outside this method.
subtractSameReplication(RangesAtEndpoint) - Method in class org.apache.cassandra.locator.Replica
This is used exclusively in TokenMetadata to check if a portion of a range is already replicated by an endpoint so that we only mark as pending the portion that is either not replicated sufficiently (transient when we need full) or at all.
subtype(int) - Method in class org.apache.cassandra.db.ClusteringComparator
Returns the type of the ith clustering column of the table.
subtypes() - Method in class org.apache.cassandra.db.ClusteringComparator
The "subtypes" of this clustering comparator, that is the types of the clustering columns for the table this is a comparator of.
subTypes() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
subTypes() - Method in class org.apache.cassandra.db.marshal.ListType
 
subTypes() - Method in class org.apache.cassandra.db.marshal.MapType
 
subTypes() - Method in class org.apache.cassandra.db.marshal.SetType
 
subTypes() - Method in class org.apache.cassandra.db.marshal.TupleType
 
success - Variable in class org.apache.cassandra.db.TruncateResponse
 
success() - Method in class org.apache.cassandra.net.OutboundConnectionInitiator.Result
 
success - Variable in class org.apache.cassandra.repair.messages.PrepareConsistentResponse
 
success - Variable in class org.apache.cassandra.repair.messages.SyncResponse
true if sync success, false otherwise
success() - Method in class org.apache.cassandra.repair.messages.ValidationResponse
 
success - Variable in class org.apache.cassandra.schema.Schema.TransformationResult
 
success - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
 
successful - Variable in class org.apache.cassandra.repair.consistent.admin.CleanupSummary
 
successfulConnections() - Method in class org.apache.cassandra.net.OutboundConnection
 
successfulParentRepair(UUID, Collection<Range<Token>>) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
successfulRepairJob(UUID, String, String) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
successfulViewBuild(String, String, UUID) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
sufficientForStartupSafetyCheck(Map<InetAddressAndPort, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
 
SuffixSA - Class in org.apache.cassandra.index.sasi.sa
 
SuffixSA(AbstractType<?>, OnDiskIndexBuilder.Mode) - Constructor for class org.apache.cassandra.index.sasi.sa.SuffixSA
 
sum - Variable in class org.apache.cassandra.tools.Util.TermHistogram
 
sum(double) - Method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram
Calculates estimated number of points in interval [-inf,b].
sumFunctionForByte - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for byte values (tinyint).
sumFunctionForCounter - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for counter column values.
sumFunctionForDecimal - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for decimal values.
sumFunctionForDouble - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for double values.
sumFunctionForFloat - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for float values.
sumFunctionForInt32 - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for int32 values.
sumFunctionForLong - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for long values.
sumFunctionForShort - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for short values (smallint).
sumFunctionForVarint - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
The SUM function for varint values.
summaries - Variable in class org.apache.cassandra.repair.messages.SyncResponse
 
summaries - Variable in class org.apache.cassandra.repair.SyncStat
 
summaries - Variable in class org.apache.cassandra.streaming.messages.PrepareSynAckMessage
Summaries of streaming out
summaries - Variable in class org.apache.cassandra.streaming.messages.PrepareSynMessage
Summaries of streaming out
SummarizePendingCmd() - Constructor for class org.apache.cassandra.tools.nodetool.RepairAdmin.SummarizePendingCmd
 
SummarizeRepairedCmd() - Constructor for class org.apache.cassandra.tools.nodetool.RepairAdmin.SummarizeRepairedCmd
 
SUMMARY - Static variable in class org.apache.cassandra.io.sstable.Component
 
summary - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
summary(IndexSummary) - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderBuilder
 
summaryCount - Variable in class org.apache.cassandra.io.sstable.IndexSummaryBuilder.ReadableBoundary
 
SUPER_BLOCK_SIZE - Static variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
 
superBlockCnt - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataLevel
 
superBlocksOffset - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataLevel
 
supersedes(DeletionTime) - Method in class org.apache.cassandra.db.DeletionTime
 
supersedes(LivenessInfo) - Method in class org.apache.cassandra.db.LivenessInfo
Whether this liveness information supersedes another one (that is whether is has a greater timestamp than the other or not).
supersedes(DeletionTime) - Method in class org.apache.cassandra.db.rows.Row.Deletion
 
supersedes(Row.Deletion) - Method in class org.apache.cassandra.db.rows.Row.Deletion
 
SUPERUSER_SETUP_DELAY - Static variable in class org.apache.cassandra.auth.AuthKeyspace
 
supply(FrameDecoder.Frame) - Method in class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
Return true if this was the last frame of the large message.
supported - Variable in class org.apache.cassandra.transport.messages.SupportedMessage
 
SUPPORTED - Static variable in enum org.apache.cassandra.transport.ProtocolVersion
All supported versions, published as an enumset
SupportedMessage - Class in org.apache.cassandra.transport.messages
Message to indicate that the server is ready to receive requests.
SupportedMessage(Map<String, List<String>>) - Constructor for class org.apache.cassandra.transport.messages.SupportedMessage
 
supportedOptions() - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
supportedOptions() - Method in interface org.apache.cassandra.auth.IRoleManager
Set of options supported by CREATE ROLE and ALTER ROLE queries.
supportedOptions() - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
supportedOptions() - Method in interface org.apache.cassandra.io.compress.ICompressor
 
supportedOptions() - Method in class org.apache.cassandra.io.compress.LZ4Compressor
 
supportedOptions() - Method in class org.apache.cassandra.io.compress.NoopCompressor
 
supportedOptions() - Method in class org.apache.cassandra.io.compress.SnappyCompressor
 
supportedOptions() - Method in class org.apache.cassandra.io.compress.ZstdCompressor
Lists the supported options by this compressor
supportedSortKeys - Static variable in class org.apache.cassandra.tools.nodetool.stats.StatsTableComparator
Names of supported sort keys as they should be specified on the command line.
supportedVersions() - Static method in enum org.apache.cassandra.transport.ProtocolVersion
 
supportedVersionsStartingWith(ProtocolVersion) - Static method in enum org.apache.cassandra.transport.ProtocolVersion
 
supportExitOnOutOfMemory(String) - Static method in class org.apache.cassandra.utils.JavaUtils
Checks if the specified JRE support ExitOnOutOfMemory and CrashOnOutOfMemory.
supports(Operator) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
supports(Expression.Op) - Method in class org.apache.cassandra.index.sasi.conf.IndexMode
 
supports(Expression.Op) - Method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.Mode
 
supports(BufferType) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
supports(BufferType) - Method in interface org.apache.cassandra.io.compress.ICompressor
Checks if the given buffer would be supported by the compressor.
supports(BufferType) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
 
supports(BufferType) - Method in class org.apache.cassandra.io.compress.NoopCompressor
 
supports(BufferType) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
 
supports(BufferType) - Method in class org.apache.cassandra.io.compress.ZstdCompressor
Check whether the given BufferType is supported
supportsEarlyOpen() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
supportsEarlyOpen() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
supportsEarlyOpen() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
 
supportsExpression(ColumnMetadata, Operator) - Method in interface org.apache.cassandra.index.Index
Called to determine whether this index can provide a searcher to execute a query on the supplied column using the specified operator.
supportsExpression(ColumnMetadata, Operator) - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
supportsExpression(ColumnMetadata, Operator) - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
supportsFreezing() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
supportsOperator(ColumnMetadata, Operator) - Method in class org.apache.cassandra.index.internal.CassandraIndex
Returns true if an index of this type can support search predicates of the form [column] OPERATOR [value]
supportsOperator(ColumnMetadata, Operator) - Method in class org.apache.cassandra.index.internal.composites.CollectionKeyIndex
 
supportsOperator(ColumnMetadata, Operator) - Method in class org.apache.cassandra.index.internal.composites.CollectionValueIndex
 
supportsReads() - Method in enum org.apache.cassandra.index.Index.LoadType
 
supportsReplicaFilteringProtection(RowFilter) - Method in interface org.apache.cassandra.index.Index
Tells whether this index supports replica fitering protection or not.
supportsReplicaFilteringProtection(RowFilter) - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
supportsThresholdParams(Class<? extends AbstractCompactionStrategy>) - Static method in class org.apache.cassandra.schema.CompactionParams
 
supportsWrites() - Method in enum org.apache.cassandra.index.Index.LoadType
 
suppressSystemExit() - Method in class org.apache.cassandra.tools.nodetool.Sjk.Wrapper
 
switchCompactionLocation(Directories.DataDirectory) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
Implementations of this method should finish the current sstable writer and start writing to this directory.
switchCompactionLocation(Directories.DataDirectory) - Method in class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
 
switchCompactionLocation(Directories.DataDirectory) - Method in class org.apache.cassandra.db.compaction.writers.MajorLeveledCompactionWriter
 
switchCompactionLocation(Directories.DataDirectory) - Method in class org.apache.cassandra.db.compaction.writers.MaxSSTableSizeWriter
 
switchCompactionLocation(Directories.DataDirectory) - Method in class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
 
switchMemtable() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
switchMemtable(boolean, Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
Switch the current memtable.
switchMemtable() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
switchMemtable(Memtable) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
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
 
SymmetricRemoteSyncTask - Class in org.apache.cassandra.repair
SymmetricRemoteSyncTask sends SyncRequest to remote(non-coordinator) node to repair(stream) data with other replica.
SymmetricRemoteSyncTask(RepairJobDesc, InetAddressAndPort, InetAddressAndPort, List<Range<Token>>, PreviewKind) - Constructor for class org.apache.cassandra.repair.SymmetricRemoteSyncTask
 
sync(boolean) - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogSegmentManager
Requests commit log files sync themselves, if needed.
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.util.SequentialWriter
Synchronize file contents with disk.
sync() - Method in class org.apache.cassandra.net.AsyncChannelPromise
 
sync() - Method in class org.apache.cassandra.net.AsyncPromise
waits for completion; in case of failure rethrows the original exception without a new wrapping exception so may cause problems for reporting stack traces
sync(FileDescriptor) - Static method in class org.apache.cassandra.utils.SyncUtil
 
sync(RandomAccessFile) - Static method in class org.apache.cassandra.utils.SyncUtil
 
sync(FileOutputStream) - Static method in class org.apache.cassandra.utils.SyncUtil
 
syncBlocking() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
Request sync and wait until the current state is synced.
syncComplete - Variable in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
 
syncComplete(boolean, List<SessionSummary>) - Method in class org.apache.cassandra.repair.AsymmetricRemoteSyncTask
 
syncComplete(boolean, List<SessionSummary>) - Method in interface org.apache.cassandra.repair.CompletableRemoteSyncTask
 
syncComplete(RepairJobDesc, SyncNodePair, boolean, List<SessionSummary>) - Method in class org.apache.cassandra.repair.RepairSession
Notify this session that sync completed/failed with given SyncNodePair.
syncComplete(boolean, List<SessionSummary>) - Method in class org.apache.cassandra.repair.SymmetricRemoteSyncTask
 
syncDataOnlyInternal() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
syncInternal() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
SyncNodePair - Class in org.apache.cassandra.repair
SyncNodePair is used for repair message body to indicate the pair of nodes.
SyncNodePair(InetAddressAndPort, InetAddressAndPort) - Constructor for class org.apache.cassandra.repair.SyncNodePair
 
SyncNodePair.NodePairSerializer - Class in org.apache.cassandra.repair
 
SyncRequest - Class in org.apache.cassandra.repair.messages
Body part of SYNC_REQUEST repair message.
SyncRequest(RepairJobDesc, InetAddressAndPort, InetAddressAndPort, InetAddressAndPort, Collection<Range<Token>>, PreviewKind, boolean) - Constructor for class org.apache.cassandra.repair.messages.SyncRequest
 
SyncResponse - Class in org.apache.cassandra.repair.messages
 
SyncResponse(RepairJobDesc, SyncNodePair, boolean, List<SessionSummary>) - Constructor for class org.apache.cassandra.repair.messages.SyncResponse
 
SyncResponse(RepairJobDesc, InetAddressAndPort, InetAddressAndPort, boolean, List<SessionSummary>) - Constructor for class org.apache.cassandra.repair.messages.SyncResponse
 
SyncSegment(FileDataInput, int, int, int, boolean) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SyncSegment
 
SyncStat - Class in org.apache.cassandra.repair
Statistics about synchronizing two replica
SyncStat(SyncNodePair, long) - Constructor for class org.apache.cassandra.repair.SyncStat
 
SyncStat(SyncNodePair, long, List<SessionSummary>) - Constructor for class org.apache.cassandra.repair.SyncStat
 
SyncStatSummary - Class in org.apache.cassandra.repair.consistent
 
SyncStatSummary(boolean) - Constructor for class org.apache.cassandra.repair.consistent.SyncStatSummary
 
SyncTask - Class in org.apache.cassandra.repair
 
SyncTask(RepairJobDesc, InetAddressAndPort, InetAddressAndPort, List<Range<Token>>, PreviewKind) - Constructor for class org.apache.cassandra.repair.SyncTask
 
syncUninterruptibly() - Method in class org.apache.cassandra.net.AsyncChannelPromise
 
syncUninterruptibly() - Method in class org.apache.cassandra.net.AsyncPromise
waits for completion; in case of failure rethrows the original exception without a new wrapping exception so may cause problems for reporting stack traces
SyncUtil - Class in org.apache.cassandra.utils
 
SyncUtil() - Constructor for class org.apache.cassandra.utils.SyncUtil
 
syntaxError(BaseRecognizer, String[], RecognitionException) - Method in class org.apache.cassandra.cql3.ErrorCollector
Invoked when a syntax error occurs.
syntaxError(BaseRecognizer, String) - Method in class org.apache.cassandra.cql3.ErrorCollector
Invoked when a syntax error with a specified message occurs.
syntaxError(BaseRecognizer, String[], RecognitionException) - Method in interface org.apache.cassandra.cql3.ErrorListener
Invoked when a syntax error occurs.
syntaxError(BaseRecognizer, String) - Method in interface org.apache.cassandra.cql3.ErrorListener
Invoked when a syntax error with a specified message occurs.
SyntaxException - Exception in org.apache.cassandra.exceptions
 
SyntaxException(String) - Constructor for exception org.apache.cassandra.exceptions.SyntaxException
 
system() - Static method in class org.apache.cassandra.db.Keyspace
 
SYSTEM_KEYSPACE_NAME - Static variable in class org.apache.cassandra.schema.SchemaConstants
 
SYSTEM_USER - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
 
SYSTEM_USERNAME - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
 
SystemDistributedKeyspace - Class in org.apache.cassandra.repair
 
SystemKeyspace - Class in org.apache.cassandra.db
 
SystemKeyspace.AvailableRanges - Class in org.apache.cassandra.db
 
SystemKeyspace.BootstrapState - Enum in org.apache.cassandra.db
 
SystemKeyspaceMigrator40 - Class in org.apache.cassandra.db
Migrate 3.0 versions of some tables to 4.0.
SystemOutput(boolean, boolean) - Constructor for class org.apache.cassandra.utils.OutputHandler.SystemOutput
 
SystemOutput(boolean, boolean, boolean) - Constructor for class org.apache.cassandra.utils.OutputHandler.SystemOutput
 
SystemReplicas - Class in org.apache.cassandra.locator
 
SystemReplicas() - Constructor for class org.apache.cassandra.locator.SystemReplicas
 
SystemTimeSource - Class in org.apache.cassandra.utils
Time source backed by JVM clock.
SystemTimeSource() - Constructor for class org.apache.cassandra.utils.SystemTimeSource
 
SystemViewsKeyspace - Class in org.apache.cassandra.db.virtual
 

T

t - Variable in class org.apache.cassandra.cql3.Operation
 
table(String, String) - Static method in class org.apache.cassandra.auth.DataResource
Creates a DataResource instance representing a table.
table - Variable in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
The Column Family meta data
table(String, String) - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
Creates a DescribeStatement for DESCRIBE TABLE.
table() - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
 
table - Variable in class org.apache.cassandra.cql3.statements.SelectStatement
 
table - Variable in class org.apache.cassandra.db.TruncateRequest
 
table - Variable in class org.apache.cassandra.metrics.TableMetrics.TableMeter
 
table - Variable in class org.apache.cassandra.repair.consistent.admin.CleanupSummary
 
table - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStats
 
table - Variable in class org.apache.cassandra.repair.consistent.admin.RepairStats
 
table_count_warn_threshold - Variable in class org.apache.cassandra.config.Config
 
TABLE_ESTIMATES - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
TABLE_ESTIMATES_TYPE_LOCAL_PRIMARY - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
TABLE_ESTIMATES_TYPE_PRIMARY - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
TableAttributes - Class in org.apache.cassandra.cql3.statements.schema
 
TableAttributes() - Constructor for class org.apache.cassandra.cql3.statements.schema.TableAttributes
 
TableBuilder - Class in org.apache.cassandra.tools.nodetool.formatter
Build and print table.
TableBuilder() - Constructor for class org.apache.cassandra.tools.nodetool.formatter.TableBuilder
 
TableBuilder(char) - Constructor for class org.apache.cassandra.tools.nodetool.formatter.TableBuilder
 
TableBuilder(String) - Constructor for class org.apache.cassandra.tools.nodetool.formatter.TableBuilder
 
TableBuilder.SharedTable - Class in org.apache.cassandra.tools.nodetool.formatter
Share max offsets across multiple TableBuilders
tableCountWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
TableHistograms - Class in org.apache.cassandra.tools.nodetool
 
TableHistograms() - Constructor for class org.apache.cassandra.tools.nodetool.TableHistograms
 
tableId - Variable in class org.apache.cassandra.cache.CacheKey
 
tableId - Variable in class org.apache.cassandra.db.streaming.CassandraStreamHeader
 
tableId - Variable in class org.apache.cassandra.db.streaming.CassandraStreamReader
 
TableId - Class in org.apache.cassandra.schema
The unique identifier of a table.
tableId - Variable in class org.apache.cassandra.streaming.messages.ReceivedMessage
 
tableId - Variable in class org.apache.cassandra.streaming.messages.StreamMessageHeader
 
tableId - Variable in class org.apache.cassandra.streaming.StreamSummary
 
tableId - Variable in class org.apache.cassandra.streaming.StreamTask
 
tableIds - Variable in class org.apache.cassandra.repair.consistent.ConsistentSession
 
tableIds - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
 
TableMetadata - Class in org.apache.cassandra.schema
 
TableMetadata(TableMetadata.Builder) - Constructor for class org.apache.cassandra.schema.TableMetadata
 
TableMetadata.Builder - Class in org.apache.cassandra.schema
 
TableMetadata.CompactTableMetadata - Class in org.apache.cassandra.schema
 
TableMetadata.Flag - Enum in org.apache.cassandra.schema
 
TableMetadata.Kind - Enum in org.apache.cassandra.schema
 
TableMetadataRef - Class in org.apache.cassandra.schema
Encapsulates a volatile reference to an immutable TableMetadata instance.
TableMetrics - Class in org.apache.cassandra.metrics
Metrics for ColumnFamilyStore.
TableMetrics(ColumnFamilyStore) - Constructor for class org.apache.cassandra.metrics.TableMetrics
Creates metrics for given ColumnFamilyStore.
TableMetrics.ReleasableMetric - Interface in org.apache.cassandra.metrics
 
TableMetrics.TableHistogram - Class in org.apache.cassandra.metrics
 
TableMetrics.TableMeter - Class in org.apache.cassandra.metrics
 
TableMetrics.TableTimer - Class in org.apache.cassandra.metrics
 
TableMetrics.TableTimer.Context - Class in org.apache.cassandra.metrics
 
TableMetricTables - Class in org.apache.cassandra.db.virtual
Contains multiple the Table Metric virtual tables.
TableMetricTables() - Constructor for class org.apache.cassandra.db.virtual.TableMetricTables
 
tableName - Variable in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement
 
tableName - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
 
TableParams - Class in org.apache.cassandra.schema
 
TableParams.Builder - Class in org.apache.cassandra.schema
 
TableParams.Option - Enum in org.apache.cassandra.schema
 
TableRepairManager - Interface in org.apache.cassandra.repair
Table level hook for repair
tables() - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
Creates a DescribeStatement for DESCRIBE TABLES.
tables() - Method in class org.apache.cassandra.db.virtual.VirtualKeyspace
 
TABLES - Static variable in class org.apache.cassandra.repair.consistent.LocalSessionInfo
 
tables - Variable in class org.apache.cassandra.schema.KeyspaceMetadata.KeyspaceDiff
 
tables - Variable in class org.apache.cassandra.schema.KeyspaceMetadata
 
TABLES - Static variable in class org.apache.cassandra.schema.SchemaKeyspace
 
Tables - Class in org.apache.cassandra.schema
An immutable container for a keyspace's Tables.
tables - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsKeyspace
 
tables - Variable in class org.apache.cassandra.utils.NativeSSTableLoaderClient
 
Tables.Builder - Class in org.apache.cassandra.schema
 
Tables.TablesDiff - Class in org.apache.cassandra.schema
 
TABLES_SPLIT_ACROSS_MULTIPLE_DISKS - Static variable in class org.apache.cassandra.db.SystemKeyspace
By default the system keyspace tables should be stored in a single data directory to allow the server to handle more gracefully disk failures.
tablesAndViews() - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
TableStats - Class in org.apache.cassandra.tools.nodetool
 
TableStats() - Constructor for class org.apache.cassandra.tools.nodetool.TableStats
 
TableStatsHolder - Class in org.apache.cassandra.tools.nodetool.stats
 
TableStatsHolder(NodeProbe, boolean, boolean, List<String>, String, int, boolean) - Constructor for class org.apache.cassandra.tools.nodetool.stats.TableStatsHolder
 
TableStatsPrinter<T extends StatsHolder> - Class in org.apache.cassandra.tools.nodetool.stats
 
TableStatsPrinter() - Constructor for class org.apache.cassandra.tools.nodetool.stats.TableStatsPrinter
 
TableStreamManager - Interface in org.apache.cassandra.streaming
The main streaming hook for a storage implementation.
TableViews - Class in org.apache.cassandra.db.view
Groups all the views for a given table.
TableViews(TableId) - Constructor for class org.apache.cassandra.db.view.TableViews
 
TableWriteHandler - Interface in org.apache.cassandra.db
 
TABULAR_TYPE - Static variable in class org.apache.cassandra.db.SnapshotDetailsTabularData
 
tailMap(K) - Method in class org.apache.cassandra.index.sasi.utils.trie.PatriciaTrie
 
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
 
take() - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
takeMultipleTableSnapshot(String, String...) - Method in class org.apache.cassandra.service.StorageService
Takes the snapshot of a multiple column family from different keyspaces.
takeMultipleTableSnapshot(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
takeMultipleTableSnapshot(String, Map<String, String>, String...) - Method in class org.apache.cassandra.tools.NodeProbe
Take a snapshot of all column family from different keyspaces.
takeSnapshot(String, Map<String, String>, String...) - Method in class org.apache.cassandra.service.StorageService
Takes the snapshot of a multiple 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
takeSnapshot(String, Map<String, String>, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Takes the snapshot of a multiple column family from different keyspaces.
takeSnapshot(String, String, Map<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.
takeTableSnapshot(String, String, String) - Method in class org.apache.cassandra.service.StorageService
Takes the snapshot of a specific table.
takeTableSnapshot(String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
target - Variable in class org.apache.cassandra.transport.Event.SchemaChange
 
TARGET_KEYSPACE - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
TARGET_OPTION_NAME - Static variable in class org.apache.cassandra.cql3.statements.schema.IndexTarget
 
targetIndex - Variable in class org.apache.cassandra.cql3.restrictions.CustomIndexExpression
 
targetKeyspace - Variable in class org.apache.cassandra.tools.LoaderOptions
 
TargetParser - Class in org.apache.cassandra.index
 
TargetParser() - Constructor for class org.apache.cassandra.index.TargetParser
 
targets - Variable in class org.apache.cassandra.service.paxos.AbstractPaxosCallback
 
TASK_TYPE - Static variable in class org.apache.cassandra.db.compaction.CompactionInfo
 
taskCompleted(StreamReceiveTask) - Method in class org.apache.cassandra.streaming.StreamSession
 
taskCompleted(StreamTransferTask) - Method in class org.apache.cassandra.streaming.StreamSession
 
taskExecutor - Variable in class org.apache.cassandra.repair.RepairSession
 
tasks - Variable in class org.apache.cassandra.concurrent.SEPExecutor
 
tcpConnectTimeoutInMS - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
tcpConnectTimeoutInMS() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
tcpNoDelay - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
tcpNoDelay() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
tcpUserTimeoutInMS - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
tcpUserTimeoutInMS(ConnectionCategory) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
TemporalType<T> - Class in org.apache.cassandra.db.marshal
Base type for temporal types (timestamp, date ...).
TemporalType(AbstractType.ComparisonType) - Constructor for class org.apache.cassandra.db.marshal.TemporalType
 
temporaryAssertFull(Replica) - Static method in class org.apache.cassandra.locator.Replicas
A placeholder for areas of the code that cannot yet handle transient replicas, but should do so in future
temporaryAssertFull(Iterable<Replica>) - Static method in class org.apache.cassandra.locator.Replicas
A placeholder for areas of the code that cannot yet handle transient replicas, but should do so in future
Term - Interface in org.apache.cassandra.cql3
A CQL3 term, i.e.
Term(ByteBuffer, AbstractType<?>) - Constructor for class org.apache.cassandra.index.sasi.conf.view.RangeTermTree.Term
 
Term<T extends java.nio.Buffer> - Class in org.apache.cassandra.index.sasi.sa
 
Term(int, T, TokenTreeBuilder) - Constructor for class org.apache.cassandra.index.sasi.sa.Term
 
Term - Class in org.apache.cassandra.index.sasi
 
Term(MappedBuffer, OnDiskIndexBuilder.TermSize, boolean) - Constructor for class org.apache.cassandra.index.sasi.Term
 
Term.MultiColumnRaw - Class 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 - Class 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.
termCount() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
 
TermHistogram(Map<? extends Number, Long>, String, LongFunction<String>, LongFunction<String>) - Constructor for class org.apache.cassandra.tools.Util.TermHistogram
 
TermHistogram(TombstoneHistogram, String, LongFunction<String>, LongFunction<String>) - Constructor for class org.apache.cassandra.tools.Util.TermHistogram
 
TermHistogram(EstimatedHistogram, String, LongFunction<String>, LongFunction<String>) - Constructor for class org.apache.cassandra.tools.Util.TermHistogram
 
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
 
TermIterator - Class in org.apache.cassandra.index.sasi.sa
 
TermIterator() - Constructor for class org.apache.cassandra.index.sasi.sa.TermIterator
 
TermIterator - Class in org.apache.cassandra.index.sasi
 
Terms - Interface in org.apache.cassandra.cql3
A set of Terms
terms - Variable in class org.apache.cassandra.index.sasi.sa.SA
 
TermSelector - Class in org.apache.cassandra.cql3.selection
Selector representing a simple term (literals or bound variables).
termSize - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
 
termSize - Variable in class org.apache.cassandra.index.sasi.Term
 
TermTree - Interface in org.apache.cassandra.index.sasi.conf.view
 
TermTree.Builder - Class in org.apache.cassandra.index.sasi.conf.view
 
test(Token) - Method in class org.apache.cassandra.dht.Range.OrderedRangeContainmentChecker
Returns true if the ranges given in the constructor contains the token, false otherwise.
test(Function) - Method in enum org.apache.cassandra.schema.Functions.Filter
 
testAll(String, ColumnSpecification, Collection<? extends AssignmentTestable>) - Static method in enum org.apache.cassandra.cql3.AssignmentTestable.TestResult
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.AbstractMarker.MultiColumnRaw
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.AbstractMarker.Raw
 
testAssignment(String, ColumnSpecification) - Method in interface org.apache.cassandra.cql3.AssignmentTestable
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Constants.Literal
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Lists.Literal
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Maps.Literal
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.selection.Selectable.BetweenParenthesesOrWithTuple
 
testAssignment(String, ColumnSpecification) - Method in interface org.apache.cassandra.cql3.selection.Selectable
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithList
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithMapOrUdt
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithSet
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithTerm
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithTypeHint
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Sets.Literal
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Tuples.Literal
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.TypeCast
 
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.UserTypes.Literal
 
testAssignment(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.AbstractType
Tests whether a CQL value having this type can be assigned to the provided receiver.
testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
testListAssignment(ColumnSpecification, List<? extends AssignmentTestable>) - Static method in class org.apache.cassandra.cql3.Lists
Tests that the list with the specified elements can be assigned to the specified column.
testMapAssignment(ColumnSpecification, List<Pair<T, T>>) - Static method in class org.apache.cassandra.cql3.Maps
Tests that the map with the specified entries can be assigned to the specified column.
TestRateLimiter - Class in org.apache.cassandra.utils
Helper class to apply rate limiting during fault injection testing; for an example script, see test/resources/byteman/mutation_limiter.btm.
TestRateLimiter(Rule) - Constructor for class org.apache.cassandra.utils.TestRateLimiter
 
testSetAssignment(ColumnSpecification, List<? extends AssignmentTestable>) - Static method in class org.apache.cassandra.cql3.Sets
Tests that the set with the specified elements can be assigned to the specified column.
testTupleAssignment(ColumnSpecification, List<? extends AssignmentTestable>) - Static method in class org.apache.cassandra.cql3.Tuples
Tests that the tuple with the specified elements can be assigned to the specified column.
testUserTypeAssignment(ColumnSpecification, Map<FieldIdentifier, T>) - Static method in class org.apache.cassandra.cql3.UserTypes
Tests that the map with the specified entries can be assigned to the specified column.
text() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the TEXT type.
thisDatacenter() - Static method in class org.apache.cassandra.dht.Datacenters
 
ThreadAwareSecurityManager - Class in org.apache.cassandra.security
Custom SecurityManager and Policy implementation that only performs access checks if explicitly enabled.
ThreadLocalByteBufferHolder - Class in org.apache.cassandra.io.util
Utility class that allow buffers to be reused by storing them in a thread local instance.
ThreadLocalByteBufferHolder(BufferType) - Constructor for class org.apache.cassandra.io.util.ThreadLocalByteBufferHolder
 
threadLocalMD5Digest() - Static method in class org.apache.cassandra.utils.MD5Digest
 
threadName - Variable in class org.apache.cassandra.diag.DiagnosticEvent
Name of allocating thread.
ThreadPoolMetrics - Class in org.apache.cassandra.metrics
Metrics for ThreadPoolExecutor.
ThreadPoolMetrics(LocalAwareExecutorService, String, String) - Constructor for class org.apache.cassandra.metrics.ThreadPoolMetrics
Create metrics for given ThreadPoolExecutor.
throttle(UnfilteredPartitionIterator, int) - Static method in class org.apache.cassandra.db.rows.ThrottledUnfilteredIterator
Splits a UnfilteredPartitionIterator in UnfilteredRowIterator batches with size no higher than maxBatchSize
throttle - Variable in class org.apache.cassandra.tools.LoaderOptions
 
THROTTLE_MBITS - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
throttledCount - Variable in class org.apache.cassandra.net.AbstractMessageHandler
 
throttledCount() - Method in class org.apache.cassandra.net.InboundMessageHandlers
 
throttledNanos - Variable in class org.apache.cassandra.net.AbstractMessageHandler
 
throttledNanos() - Method in class org.apache.cassandra.net.InboundMessageHandlers
 
ThrottledUnfilteredIterator - Class in org.apache.cassandra.db.rows
A utility class to split the given into smaller chunks each having at most ThrottledUnfilteredIterator.throttle + 1 unfiltereds.
THROW_ON_OVERLOAD - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
 
Throwables - Class in org.apache.cassandra.utils
 
Throwables() - Constructor for class org.apache.cassandra.utils.Throwables
 
Throwables.DiscreteAction<E extends java.lang.Exception> - Interface in org.apache.cassandra.utils
 
Throwables.FileOpType - Enum in org.apache.cassandra.utils
 
throwAsUncheckedException(Throwable) - Static method in class org.apache.cassandra.utils.Throwables
throw the exception as a unchecked exception, wrapping if a checked exception, else rethroing as is.
throwDuringPrepare(boolean) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
throwFirstSyntaxError() - Method in class org.apache.cassandra.cql3.ErrorCollector
Throws the first syntax error found by the lexer or the parser if it exists.
tidy() - Method in class org.apache.cassandra.io.util.MmappedRegions.Tidier
 
tidy() - Method in interface org.apache.cassandra.utils.concurrent.RefCounted.Tidy
 
time() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the TIME type.
time() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type time.
time() - Method in class org.apache.cassandra.db.rows.Row.Deletion
The time of the row deletion.
time() - Method in class org.apache.cassandra.metrics.TableMetrics.TableTimer
 
time - Variable in class org.apache.cassandra.repair.consistent.admin.RepairStats.Section
 
TimeFcts - Class in org.apache.cassandra.cql3.functions
 
TimeFcts() - Constructor for class org.apache.cassandra.cql3.functions.TimeFcts
 
timeInMillisToDay(long) - Static method in class org.apache.cassandra.serializers.SimpleDateSerializer
 
TIMEOUT_TYPES - Static variable in class org.apache.cassandra.tools.nodetool.GetTimeout
 
timeoutNanos() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
 
timeoutNanos() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
 
timeouts - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
 
timePattern - Static variable in class org.apache.cassandra.serializers.TimeSerializer
 
TimeQuotaExceededException - Exception in org.apache.cassandra.index.sasi.exceptions
 
TimeQuotaExceededException(String) - Constructor for exception org.apache.cassandra.index.sasi.exceptions.TimeQuotaExceededException
 
timer(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
timer(CassandraMetricsRegistry.MetricName, CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
 
TimeSerializer - Class in org.apache.cassandra.serializers
 
TimeSerializer() - Constructor for class org.apache.cassandra.serializers.TimeSerializer
 
TimeSource - Interface in org.apache.cassandra.utils
 
timestamp - Variable in class org.apache.cassandra.cql3.Attributes.Raw
 
timestamp() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the TIMESTAMP type.
timestamp() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type timestamp.
timestamp(long) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
 
timestamp - Variable in class org.apache.cassandra.db.LivenessInfo
 
timestamp() - Method in class org.apache.cassandra.db.LivenessInfo
The timestamp for this liveness info.
timestamp(long) - Method in interface org.apache.cassandra.db.Mutation.SimpleBuilder
Sets the timestamp to use for the following additions to this builder or any derived (update or row) builder.
timestamp(long) - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder
Sets the timestamp to use for the following additions to this builder or any derived (row) builder.
timestamp() - Method in class org.apache.cassandra.db.rows.ArrayCell
 
timestamp() - Method in class org.apache.cassandra.db.rows.BufferCell
 
timestamp() - Method in class org.apache.cassandra.db.rows.Cell
The cell timestamp.
timestamp() - Method in class org.apache.cassandra.db.rows.NativeCell
 
timestamp(long) - Method in interface org.apache.cassandra.db.rows.Row.SimpleBuilder
Sets the timestamp to use for the following additions.
timestamp - Variable in class org.apache.cassandra.diag.DiagnosticEvent
Event creation time.
timestamp - Variable in class org.apache.cassandra.index.internal.IndexEntry
 
timestamp - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
 
TIMESTAMP_EPOCH - Static variable in class org.apache.cassandra.db.rows.EncodingStats
 
TIMESTAMP_RESOLUTION_KEY - Static variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
TIMESTAMP_RESOLUTION_KEY - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
timestampMicros() - Static method in class org.apache.cassandra.utils.FBUtilities
 
timestampResolution - Variable in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategyOptions
 
timestampResolution - Variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
timestampSerializedSize(long) - Method in class org.apache.cassandra.db.SerializationHeader
 
TimestampSerializer - Class in org.apache.cassandra.serializers
 
TimestampSerializer() - Constructor for class org.apache.cassandra.serializers.TimestampSerializer
 
timestampTracker - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
TimestampType - Class in org.apache.cassandra.db.marshal
Type for date-time values.
timeStringToLong(String) - Static method in class org.apache.cassandra.serializers.TimeSerializer
 
timeToLive - Variable in class org.apache.cassandra.cql3.Attributes.Raw
 
TimeType - Class in org.apache.cassandra.db.marshal
Nanosecond resolution time values
timeuuid() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the TIMEUUID type.
timeUUID() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type timeuuid.
TimeUUIDSerializer - Class in org.apache.cassandra.serializers
 
TimeUUIDSerializer() - Constructor for class org.apache.cassandra.serializers.TimeUUIDSerializer
 
TimeUUIDType - Class in org.apache.cassandra.db.marshal
 
TimeWindowCompactionController - Class in org.apache.cassandra.db.compaction
 
TimeWindowCompactionController(ColumnFamilyStore, Set<SSTableReader>, int, boolean) - Constructor for class org.apache.cassandra.db.compaction.TimeWindowCompactionController
 
TimeWindowCompactionStrategy - Class in org.apache.cassandra.db.compaction
 
TimeWindowCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
 
TimeWindowCompactionStrategyOptions - Class in org.apache.cassandra.db.compaction
 
TimeWindowCompactionStrategyOptions(Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
TimeWindowCompactionStrategyOptions() - Constructor for class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
TimeWindowCompactionTask - Class in org.apache.cassandra.db.compaction
 
TimeWindowCompactionTask(ColumnFamilyStore, LifecycleTransaction, int, boolean) - Constructor for class org.apache.cassandra.db.compaction.TimeWindowCompactionTask
 
TINY_ALLOCATION_LIMIT - Static variable in class org.apache.cassandra.utils.memory.BufferPool
 
TINY_ALLOCATION_UNIT - Static variable in class org.apache.cassandra.utils.memory.BufferPool
 
TINY_CHUNK_SIZE - Static variable in class org.apache.cassandra.utils.memory.BufferPool
 
tinyint() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the TINYINT type.
tinyInt() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type tinyint.
tlsEncryptionPolicy() - Method in class org.apache.cassandra.config.EncryptionOptions
 
tlsEncryptionPolicy - Variable in class org.apache.cassandra.transport.Server
 
tlsInstanceProtocolSubstitution() - Static method in class org.apache.cassandra.security.SSLFactory
Provides the list of protocols that would have been supported if "TLS" was selected as the protocol before the change for CASSANDRA-13325 that expects explicit protocol versions.
TMP_EXT - Static variable in class org.apache.cassandra.io.sstable.Descriptor
 
TMP_SUBDIR - Static variable in class org.apache.cassandra.db.Directories
 
tmpFilenameFor(Component) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
tmpFilenameForStreaming(Component) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
to - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithSliceSelection
 
to - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
 
toArray(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
toArray(byte[], int, int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
toArray(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
toArray(ByteBuffer, int, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
toArray(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
returns a byte[] with the contents of Depending on the accessor implementation, this method may: * allocate a new byte[] object and copy data into it * return the value, if the backing type is byte[]
toArray(V, int, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
returns a byte[] with bytes copied from the contents of starting at offset .
toArray(Object[], Object[], int) - Static method in class org.apache.cassandra.utils.btree.BTree
Fill the target array with the contents of the provided subtree, in ascending order, starting at targetOffset
toArray(Object[], int, int, Object[], int) - Static method in class org.apache.cassandra.utils.btree.BTree
 
toArray(T[], int) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
 
toArray(T[]) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
toArray(T[], int) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
toArray() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
toArray(T[]) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
toArray(T[], int) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
toArray() - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
toArray(T1[]) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
 
toBigDecimal(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
toBigDecimal(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
toBigDecimal(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.NumberType
Converts the specified value into a BigDecimal.
toBigInteger(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
toBigInteger(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
toBigInteger(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.NumberType
Converts the specified value into a BigInteger if allowed.
toBuffer(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
toBuffer(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
toBuffer(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
returns a ByteBuffer with the contents of Depending on the accessor implementation, this method may: * allocate a new ByteBuffer and copy data into it * return the value, if the backing type is a bytebuffer
toByte(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
toByte(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
toByte(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteType
 
toByte(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.NumberType
Converts the specified value into a byte if allowed.
toByte(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
returns a byte from offset 0
toByte(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Convert a byte buffer to a short.
toByteArray(Token) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
toByteArray() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
toByteBuffer(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
 
toBytes(PartitionUpdate, int) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
Serialize a partition update as a byte buffer.
toBytes() - Method in class org.apache.cassandra.gms.VersionedValue
 
toByteString(long) - Static method in class org.apache.cassandra.tools.SSTableMetadataViewer
 
TOC - Static variable in class org.apache.cassandra.io.sstable.Component
 
toComponent() - Method in class org.apache.cassandra.db.SerializationHeader
 
toComposite() - Method in class org.apache.cassandra.repair.consistent.admin.CleanupSummary
 
toComposite() - Method in class org.apache.cassandra.repair.consistent.admin.PendingStat
 
toComposite() - Method in class org.apache.cassandra.repair.consistent.admin.PendingStats
 
toComposite() - Method in class org.apache.cassandra.repair.consistent.admin.RepairStats
 
toCompositeData(FullQueryLoggerOptions) - Static method in class org.apache.cassandra.fql.FullQueryLoggerOptionsCompositeData
 
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
 
toCQLLiteral(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
 
toCQLLiteral(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
 
toCQLLiteral(ByteBuffer, ProtocolVersion) - Method in enum org.apache.cassandra.cql3.CQL3Type.Native
Delegate to TypeSerializer.toCQLLiteral(ByteBuffer) for native types as most CQL literal representations work fine with the default TypeSerializer.toString(Object) TypeSerializer.deserialize(ByteBuffer) implementations.
toCQLLiteral(ByteBuffer, ProtocolVersion) - Method in interface org.apache.cassandra.cql3.CQL3Type
Generates CQL literal from a binary value of this type.
toCQLLiteral(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.CQL3Type.Tuple
 
toCQLLiteral(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
 
toCQLLiteral(ByteBuffer) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
Generates CQL literal for TEXT/VARCHAR/ASCII types.
toCQLLiteral(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
 
toCQLLiteral(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimestampSerializer
Builds CQL literal for a timestamp using time zone UTC and fixed date format.
toCQLLiteral(ByteBuffer) - Method in class org.apache.cassandra.serializers.TypeSerializer
 
toCQLString() - Method in class org.apache.cassandra.cql3.ColumnIdentifier
Returns a string representation of the identifier that is safe to use directly in CQL queries.
toCqlString(AbstractType<?>) - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
Converts the specified type into its CQL representation.
toCqlString(boolean, boolean) - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
toCqlString(boolean, boolean) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
toCQLString() - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
toCQLString() - Method in class org.apache.cassandra.cql3.QualifiedName
Returns a string representation of the qualified name that is safe to use directly in CQL queries.
toCQLString() - Method in class org.apache.cassandra.cql3.Relation
Returns a CQL representation of this relation.
toCQLString() - Method in class org.apache.cassandra.cql3.restrictions.CustomIndexExpression
 
toCqlString(boolean, boolean) - Method in interface org.apache.cassandra.cql3.SchemaElement
Returns a CQL representation of this element
toCQLString() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
toCQLString() - Method in class org.apache.cassandra.cql3.TokenRelation
 
toCQLString() - Method in class org.apache.cassandra.cql3.WhereClause
Returns a CQL representation of this WHERE clause.
toCQLString(TableMetadata) - Method in interface org.apache.cassandra.db.Clustering
 
toCQLString(TableMetadata) - Method in class org.apache.cassandra.db.DataRange
 
toCQLString(TableMetadata) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
 
toCQLString(TableMetadata) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
 
toCQLString(TableMetadata) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
 
toCQLString() - Method in class org.apache.cassandra.db.filter.ColumnFilter.SelectionColumnFilter
 
toCQLString() - Method in class org.apache.cassandra.db.filter.ColumnFilter
Returns the CQL string corresponding to this ColumnFilter.
toCQLString() - Method in class org.apache.cassandra.db.filter.ColumnFilter.WildCardColumnFilter
 
toCqlString(boolean, boolean) - Method in class org.apache.cassandra.db.marshal.UserType
 
toCQLString() - Method in class org.apache.cassandra.db.ReadCommand
Recreate the CQL string corresponding to this query.
toCQLString(TableMetadata) - Method in class org.apache.cassandra.db.Slices
 
toCQLString(Iterable<ColumnMetadata>) - Static method in class org.apache.cassandra.schema.ColumnMetadata
 
toCQLString(Iterator<ColumnMetadata>) - Static method in class org.apache.cassandra.schema.ColumnMetadata
 
toCqlString(TableMetadata, boolean) - Method in class org.apache.cassandra.schema.IndexMetadata
 
toCqlString(boolean, boolean) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
toCqlString(boolean, boolean) - Method in class org.apache.cassandra.schema.TableMetadata
 
toCqlString(boolean, boolean, boolean) - Method in class org.apache.cassandra.schema.TableMetadata
 
toCqlString(boolean, boolean) - Method in class org.apache.cassandra.schema.ViewMetadata
 
toCqlType(AbstractType<?>) - Static method in class org.apache.cassandra.db.SchemaCQLHelper
Converts the type to a CQL type.
toCurrentTimeMillis(long) - Method in class org.apache.cassandra.utils.ApproximateTime.AlmostSameTime
 
toDate(TemporalType<?>) - Static method in class org.apache.cassandra.cql3.functions.TimeFcts
Creates a function that convert a value of the specified type into a DATE.
toDateString(long, TimeUnit) - Static method in class org.apache.cassandra.tools.SSTableMetadataViewer
 
toDebugString(ReadCommand, DecoratedKey) - Method in class org.apache.cassandra.db.ReadResponse
Creates a string of the requested partition in this read response suitable for debugging.
toDebugString() - Method in class org.apache.cassandra.schema.TableMetadata
 
TODELETEFILE - Static variable in class org.apache.cassandra.db.WindowsFailedSnapshotTracker
 
toDouble(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
toDouble(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
toDouble(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
toDouble(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
toDouble(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
 
toDouble(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
toDouble(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.NumberType
Converts the specified value into a double if allowed.
toDouble(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
returns a double from offset 0
toDouble(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
toDummyList(Collection<Range<Token>>) - Static method in class org.apache.cassandra.locator.RangesAtEndpoint
Use of this method to synthesize Replicas is almost always wrong.
toDurationString(long, TimeUnit) - Static method in class org.apache.cassandra.tools.SSTableMetadataViewer
 
toEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
toExcl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
toFatalException(ProtocolException) - Static method in exception org.apache.cassandra.transport.ProtocolException
 
toFieldIdentifier() - Method in class org.apache.cassandra.cql3.selection.Selectable.RawIdentifier
 
toFloat(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
toFloat(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
toFloat(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
toFloat(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
toFloat(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
 
toFloat(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
toFloat(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
toFloat(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
 
toFloat(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.NumberType
Converts the specified value into a float if allowed.
toFloat(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
returns a float from offset 0
toFloat(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
toHeader(TableMetadata) - Method in class org.apache.cassandra.db.SerializationHeader.Component
 
toHeaderParameters() - Method in class org.apache.cassandra.security.EncryptionContext
 
toHex(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
toHex(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
toHex(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
 
toHexString(ByteBuffer) - Static method in class org.apache.cassandra.cql3.functions.types.utils.Bytes
Converts a blob to its CQL hex string representation.
toHexString(byte[]) - Static method in class org.apache.cassandra.cql3.functions.types.utils.Bytes
Converts a blob to its CQL hex string representation.
toHexString() - Method in class org.apache.cassandra.schema.TableId
 
toIdentifiers(Collection<ColumnMetadata>) - Static method in class org.apache.cassandra.schema.ColumnMetadata
Converts the specified column definitions into column identifiers.
toImmutableList() - Static method in class org.apache.cassandra.utils.Collectors3
 
toImmutableSet() - Static method in class org.apache.cassandra.utils.Collectors3
 
toIncl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
toInt(String, String, Integer) - Static method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
toInt(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
toInt(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
toInt(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteType
 
toInt(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
toInt(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
toInt(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.FloatType
 
toInt(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
toInt(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
toInt(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
 
toInt(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.NumberType
Converts the specified value into an int if allowed.
toInt(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ShortType
 
toInt(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
returns an int from offset 0
toInt(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Convert a byte buffer to an integer.
toJson(ISSTableScanner, Stream<UnfilteredRowIterator>, boolean, TableMetadata, OutputStream) - Static method in class org.apache.cassandra.tools.JsonTransformer
 
ToJsonFct - Class in org.apache.cassandra.cql3.functions
 
toJsonLines(ISSTableScanner, Stream<UnfilteredRowIterator>, boolean, TableMetadata, OutputStream) - Static method in class org.apache.cassandra.tools.JsonTransformer
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.AbstractType
Converts the specified value into its JSON representation.
toJSONString(V, ValueAccessor<V>, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.BooleanType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.BytesType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.ByteType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.DateType
Deprecated.
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.EmptyType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.FloatType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.FrozenType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.InetAddressType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.Int32Type
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.ListType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.LongType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.MapType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.SetType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.ShortType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.TimestampType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.TimeType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.TupleType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.UserType
 
toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
Token - Class in org.apache.cassandra.dht
 
Token() - Constructor for class org.apache.cassandra.dht.Token
 
token - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf.LeafEntry
 
Token - Class in org.apache.cassandra.index.sasi.disk
 
Token(long) - Constructor for class org.apache.cassandra.index.sasi.disk.Token
 
token - Variable in class org.apache.cassandra.index.sasi.disk.Token
 
token() - Method in class org.apache.cassandra.locator.EndpointsForToken
 
token() - Method in interface org.apache.cassandra.locator.ReplicaLayout.ForToken
 
token() - Method in class org.apache.cassandra.locator.ReplicaLayout.ForTokenRead
 
token() - Method in class org.apache.cassandra.locator.ReplicaLayout.ForTokenWrite
 
token - Variable in class org.apache.cassandra.tools.nodetool.HostStat
 
token - Variable in class org.apache.cassandra.utils.MerkleTree.RowHash
 
Token.KeyBound - Class in org.apache.cassandra.dht
 
Token.TokenFactory - Class in org.apache.cassandra.dht
 
Token.TokenSerializer - Class in org.apache.cassandra.dht
 
TokenAllocation - Class in org.apache.cassandra.dht.tokenallocator
 
TokenAllocator<Unit> - Interface in org.apache.cassandra.dht.tokenallocator
 
TokenAllocatorBase<Unit> - Class in org.apache.cassandra.dht.tokenallocator
 
TokenAllocatorBase(NavigableMap<Token, Unit>, ReplicationStrategy<Unit>, IPartitioner) - Constructor for class org.apache.cassandra.dht.tokenallocator.TokenAllocatorBase
 
TokenAllocatorFactory - Class in org.apache.cassandra.dht.tokenallocator
 
TokenAllocatorFactory() - Constructor for class org.apache.cassandra.dht.tokenallocator.TokenAllocatorFactory
 
tokenCount() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
 
tokenCount() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
 
tokenCount - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
 
tokenCount - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
 
TokenFactory() - Constructor for class org.apache.cassandra.dht.Token.TokenFactory
 
TokenFct - Class in org.apache.cassandra.cql3.functions
 
TokenFct(TableMetadata) - Constructor for class org.apache.cassandra.cql3.functions.TokenFct
 
tokenForValue(BigInteger) - Method in class org.apache.cassandra.dht.Splitter
 
TOKENIZATION_ENABLE_STEMMING - Static variable in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
TOKENIZATION_LOCALE - Static variable in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
TOKENIZATION_NORMALIZE_LOWERCASE - Static variable in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
TOKENIZATION_NORMALIZE_UPPERCASE - Static variable in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
TOKENIZATION_SKIP_STOP_WORDS - Static variable in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
 
tokenLookup(Function<String, ? extends Collection<Range<Token>>>) - Method in class org.apache.cassandra.db.compaction.Verifier.Options.Builder
 
tokenLookup - Variable in class org.apache.cassandra.db.compaction.Verifier.Options
 
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(IEndpointSnitch) - 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.
TokenMetadataEvent - Class in org.apache.cassandra.locator
Events related to TokenMetadata changes.
TokenMetadataEvent.TokenMetadataEventType - Enum in org.apache.cassandra.locator
 
TokenRange - Class in org.apache.cassandra.service
Holds token range informations for the sake of StorageService.describeRing(java.lang.String).
TokenRange.EndpointDetails - Class in org.apache.cassandra.service
 
TokenRelation - Class in org.apache.cassandra.cql3
A relation using the token function.
TokenRelation(List<ColumnIdentifier>, Operator, Term.Raw) - Constructor for class org.apache.cassandra.cql3.TokenRelation
 
TokenRestriction - Class in org.apache.cassandra.cql3.restrictions
Restriction using the token function.
TokenRestriction(TableMetadata, List<ColumnMetadata>) - Constructor for class org.apache.cassandra.cql3.restrictions.TokenRestriction
Creates a new TokenRestriction that apply to the specified columns.
TokenRestriction.EQRestriction - Class in org.apache.cassandra.cql3.restrictions
 
TokenRestriction.SliceRestriction - Class in org.apache.cassandra.cql3.restrictions
 
tokens - Variable in class org.apache.cassandra.dht.BootStrapper
 
tokens() - Method in class org.apache.cassandra.dht.tokenallocator.OfflineTokenAllocator.FakeNode
 
tokens(Collection<Token>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
tokens - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
 
tokens - Variable in class org.apache.cassandra.index.sasi.sa.Term
 
TOKENS_PER_BLOCK - Static variable in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
tokenSerializer - Static variable in class org.apache.cassandra.dht.AbstractBounds
 
TokenSerializer() - Constructor for class org.apache.cassandra.dht.Token.TokenSerializer
 
TokenSerializer - Class in org.apache.cassandra.gms
 
TokenSerializer() - Constructor for class org.apache.cassandra.gms.TokenSerializer
 
tokensFromString(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
tokensInRange(Range<Token>) - Method in class org.apache.cassandra.dht.Splitter
 
TokenTree - Class in org.apache.cassandra.index.sasi.disk
 
TokenTree(MappedBuffer) - Constructor for class org.apache.cassandra.index.sasi.disk.TokenTree
 
TokenTree(Descriptor, MappedBuffer) - Constructor for class org.apache.cassandra.index.sasi.disk.TokenTree
 
TokenTree.OnDiskToken - Class in org.apache.cassandra.index.sasi.disk
 
TokenTree.TokenTreeIterator - Class in org.apache.cassandra.index.sasi.disk
 
TokenTreeBuilder - Interface in org.apache.cassandra.index.sasi.disk
 
TokenTreeBuilder.EntryType - Enum in org.apache.cassandra.index.sasi.disk
 
toKeyExcl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder.PartitionRangeBuilder
 
toKeyIncl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder.PartitionRangeBuilder
 
toleratesErrorsInSection - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SyncSegment
 
toLong(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
toLong(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
toLong(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
toLong(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DecimalType
 
toLong(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DoubleType
 
toLong(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
toLong(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
 
toLong(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.NumberType
Converts the specified value into a long if allowed.
toLong(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
returns a long from offset 0
toLong(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
toMap() - Method in class org.apache.cassandra.audit.AuditEvent
 
toMap() - Method in class org.apache.cassandra.diag.DiagnosticEvent
Returns map of key-value pairs containing relevant event details.
toMap() - Method in class org.apache.cassandra.gms.GossiperEvent
 
toMap() - Method in class org.apache.cassandra.locator.TokenMetadataEvent
 
toMap() - Method in class org.apache.cassandra.schema.SchemaEvent
 
tombstone(ColumnMetadata, long, int) - Static method in class org.apache.cassandra.db.rows.BufferCell
 
tombstone(ColumnMetadata, long, int, CellPath) - Static method in class org.apache.cassandra.db.rows.BufferCell
 
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_HISTOGRAM_SPOOL_SIZE - Static variable in class org.apache.cassandra.io.sstable.SSTable
 
TOMBSTONE_HISTOGRAM_TTL_ROUND_SECONDS - 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
 
tombstoneFailures - Variable in class org.apache.cassandra.metrics.TableMetrics
Number of tombstone read failures
TombstoneHistogram - Class in org.apache.cassandra.utils.streamhist
A snapshot or finished histrogram of tombstones for a sstable, as generated from StreamingTombstoneHistogramBuilder.
TombstoneHistogram.HistogramSerializer - Class in org.apache.cassandra.utils.streamhist
 
tombstoneOption - Variable in class org.apache.cassandra.db.AbstractCompactionController
 
tombstoneOption() - Method in class org.apache.cassandra.schema.CompactionParams
 
TombstoneOverwhelmingException - Exception in org.apache.cassandra.db.filter
 
TombstoneOverwhelmingException(int, String, TableMetadata, DecoratedKey, ClusteringPrefix<?>) - Constructor for exception org.apache.cassandra.db.filter.TombstoneOverwhelmingException
 
tombstoneScannedHistogram - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Tombstones scanned in queries on this Keyspace
tombstoneScannedHistogram - Variable in class org.apache.cassandra.metrics.TableMetrics
Tombstones scanned in queries on this CF
tombstoneThreshold - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
tombstoneWarnings - Variable in class org.apache.cassandra.metrics.TableMetrics
Number of tombstone read warnings
toMillisSinceEpoch(long) - Method in interface org.apache.cassandra.utils.MonotonicClockTranslation
accepts nanoTime in the related MonotinicClock, returns millis since epoch
toMutations() - Method in interface org.apache.cassandra.cql3.statements.UpdatesCollector
 
toNanoTime(long) - Method in class org.apache.cassandra.utils.ApproximateTime.AlmostSameTime
 
TOOL_NAME - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
toolInitialization() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
toolInitialization(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
Initializes this class as a tool, which means that the configuration is loaded using DatabaseDescriptor.loadConfig() and all non-daemon configuration parts will be setup.
TOP - Static variable in interface org.apache.cassandra.db.ClusteringBound
The biggest end bound, i.e.
TOP - Static variable in class org.apache.cassandra.db.rows.CellPath
 
top - Variable in class org.apache.cassandra.tools.nodetool.stats.TableStatsHolder
 
toParseableString() - Method in class org.apache.cassandra.locator.ReplicationFactor
 
topCasPartitionContention - Variable in class org.apache.cassandra.metrics.TableMetrics
When sampler activated, will track the most frequent partitions with cas contention
topLocalReadQueryTime - Variable in class org.apache.cassandra.metrics.TableMetrics
When sampler activated, will track the slowest local reads
TopPartitions - Class in org.apache.cassandra.tools.nodetool
Deprecated.
TopPartitions() - Constructor for class org.apache.cassandra.tools.nodetool.TopPartitions
Deprecated.
 
topReadPartitionFrequency - Variable in class org.apache.cassandra.metrics.TableMetrics
When sampler activated, will track the most frequently read partitions
topWritePartitionFrequency - Variable in class org.apache.cassandra.metrics.TableMetrics
When sampler activated, will track the most frequently written to partitions
topWritePartitionSize - Variable in class org.apache.cassandra.metrics.TableMetrics
When sampler activated, will track the largest mutations
toRestriction(TableMetadata, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Relation
Converts this Relation into a Restriction.
toRow(SchemaElement, boolean) - Method in class org.apache.cassandra.cql3.statements.DescribeStatement.Element
 
toRow(SchemaElement, boolean) - Method in class org.apache.cassandra.cql3.statements.DescribeStatement.Listing
 
toRow(T, boolean) - Method in class org.apache.cassandra.cql3.statements.DescribeStatement
 
toRowIterator(TableMetadata, ClusteringIndexFilter, ColumnFilter, long) - Method in interface org.apache.cassandra.db.virtual.AbstractVirtualTable.Partition
 
toSelectables(List<RawSelector>, TableMetadata) - Static method in class org.apache.cassandra.cql3.selection.RawSelector
Converts the specified list of RawSelectors into a list of Selectables.
toShort(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
toShort(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
toShort(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteType
 
toShort(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.NumberType
Converts the specified value into a short if allowed.
toShort(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ShortType
 
toShort(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
returns a short from offset 0
toShort(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Convert a byte buffer to a short.
toSilentException(ProtocolException) - Static method in exception org.apache.cassandra.transport.ProtocolException
 
toString() - Method in class org.apache.cassandra.audit.AuditLogOptions
 
toString() - Method in class org.apache.cassandra.auth.AuthenticatedUser
 
toString() - Method in class org.apache.cassandra.auth.CassandraPrincipal
Return a string representation of this CassPrincipal.
toString() - Method in class org.apache.cassandra.auth.DataResource
 
toString() - Method in class org.apache.cassandra.auth.FunctionResource
 
toString() - Method in class org.apache.cassandra.auth.JMXResource
 
toString() - Method in class org.apache.cassandra.auth.PermissionDetails
 
toString(List<Object>) - Static method in class org.apache.cassandra.auth.Resources
Deprecated.
toString() - Method in class org.apache.cassandra.auth.RoleOptions
 
toString() - Method in class org.apache.cassandra.auth.RoleResource
 
toString() - Method in class org.apache.cassandra.cache.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.ParameterizedClass
 
toString() - Method in class org.apache.cassandra.cql3.Attributes
 
toString() - Method in class org.apache.cassandra.cql3.BatchQueryOptions
 
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.conditions.ColumnCondition.Raw
 
toString() - Method in class org.apache.cassandra.cql3.conditions.ColumnConditions
 
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(boolean) - 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.CqlBuilder
 
toString() - Method in class org.apache.cassandra.cql3.Duration
 
toString() - Method in class org.apache.cassandra.cql3.FieldIdentifier
 
toString() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
 
toString() - Method in class org.apache.cassandra.cql3.functions.FunctionName
 
toString() - Method in class org.apache.cassandra.cql3.functions.types.DataType.CollectionType
 
toString() - Method in class org.apache.cassandra.cql3.functions.types.DataType.CustomType
 
toString() - Method in enum org.apache.cassandra.cql3.functions.types.DataType.Name
 
toString() - Method in class org.apache.cassandra.cql3.functions.types.DataType.NativeType
 
toString() - Method in class org.apache.cassandra.cql3.functions.types.Duration
 
toString() - Method in class org.apache.cassandra.cql3.functions.types.LocalDate
 
toString() - Method in class org.apache.cassandra.cql3.functions.types.TupleType
 
toString() - Method in class org.apache.cassandra.cql3.functions.types.TupleValue
 
toString() - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec
 
toString() - Method in class org.apache.cassandra.cql3.functions.types.UDTValue
 
toString() - Method in class org.apache.cassandra.cql3.functions.types.UserType.Field
 
toString() - Method in class org.apache.cassandra.cql3.functions.types.UserType
 
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.SetField
 
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.QualifiedName
 
toString() - Method in class org.apache.cassandra.cql3.QueryOptions
 
toString() - Method in class org.apache.cassandra.cql3.Relation
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.CustomIndexExpression
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithMarker
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithValues
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.NotNullRestriction
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQRestriction
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithMarker
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithValues
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IsNotNullRestriction
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
 
toString() - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.SliceRestriction
 
toString() - Method in class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
 
toString() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
toString() - Method in class org.apache.cassandra.cql3.ResultSet
 
toString() - Method in class org.apache.cassandra.cql3.RoleName
 
toString() - Method in enum org.apache.cassandra.cql3.SchemaElement.SchemaElementType
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.BetweenParenthesesOrWithTuple
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.RawIdentifier
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithCast
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithElementSelection.Raw
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithElementSelection
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithFunction
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithList
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithMapOrUdt
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithSet
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithSliceSelection.Raw
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithSliceSelection
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithTerm
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithToJSonFunction
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithTypeHint
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL
 
toString() - Method in class org.apache.cassandra.cql3.selection.Selection
 
toString() - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
 
toString() - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
 
toString() - Method in class org.apache.cassandra.cql3.statements.AlterRoleStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
 
toString() - Method in class org.apache.cassandra.cql3.statements.CreateRoleStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.DeleteStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.DropRoleStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.GrantRoleStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.ListRolesStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.ListUsersStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.QualifiedStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.RevokePermissionsStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.RevokeRoleStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.RoleManagementStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.AlterKeyspaceStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.AlterTypeStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.AlterViewStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.CreateAggregateStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.CreateFunctionStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.CreateKeyspaceStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.CreateTriggerStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.CreateTypeStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.CreateViewStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.DropAggregateStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.DropFunctionStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.DropIndexStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.DropKeyspaceStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.DropTableStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.DropTriggerStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.DropTypeStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.DropViewStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.schema.IndexTarget
 
toString() - Method in enum org.apache.cassandra.cql3.statements.schema.IndexTarget.Type
 
toString() - Method in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
 
toString() - Method in class org.apache.cassandra.cql3.statements.UseStatement
 
toString() - Method in class org.apache.cassandra.cql3.Term.Raw
 
toString() - Method in class org.apache.cassandra.cql3.Tuples.DelayedValue
 
toString() - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
 
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.cql3.WhereClause
 
toString() - Method in class org.apache.cassandra.db.ClockAndCount
 
toString(TableMetadata) - Method in interface org.apache.cassandra.db.Clustering
 
toString(TableMetadata) - Method in interface org.apache.cassandra.db.ClusteringBoundOrBoundary
 
toString(ClusteringComparator) - Method in interface org.apache.cassandra.db.ClusteringBoundOrBoundary
 
toString() - Method in class org.apache.cassandra.db.ClusteringComparator
 
toString(TableMetadata) - Method in interface org.apache.cassandra.db.ClusteringPrefix
Generates a proper string representation of the prefix.
toString() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
toString() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
 
toString() - Method in class org.apache.cassandra.db.Columns
 
toString() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
toString() - Method in class org.apache.cassandra.db.commitlog.CommitLogPosition
 
toString() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
toString() - Method in class org.apache.cassandra.db.commitlog.IntervalSet
 
toString() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
toString() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
 
toString() - Method in enum org.apache.cassandra.db.compaction.CompactionInfo.Unit
 
toString() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
 
toString() - Method in class org.apache.cassandra.db.compaction.DateTieredCompactionStrategy
Deprecated.
 
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.compaction.SizeTieredCompactionStrategyOptions
 
toString() - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
 
toString() - Method in class org.apache.cassandra.db.compaction.Verifier.Options
 
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(TableMetadata) - Method in class org.apache.cassandra.db.DataRange.Paging
 
toString(TableMetadata) - Method in class org.apache.cassandra.db.DataRange
 
toString() - Method in class org.apache.cassandra.db.DecoratedKey
 
toString() - Method in class org.apache.cassandra.db.DeletionTime
 
toString() - Method in class org.apache.cassandra.db.Directories.DataDirectories
 
toString() - Method in class org.apache.cassandra.db.Directories.DataDirectory
 
toString() - Method in class org.apache.cassandra.db.DiskBoundaries
 
toString(TableMetadata) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
 
toString(TableMetadata) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
 
toString(TableMetadata) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
 
toString() - Method in class org.apache.cassandra.db.filter.ColumnFilter.SelectionColumnFilter
 
toString() - Method in class org.apache.cassandra.db.filter.ColumnFilter.WildCardColumnFilter
 
toString() - Method in class org.apache.cassandra.db.filter.RowFilter.CustomExpression
 
toString() - Method in class org.apache.cassandra.db.filter.RowFilter.SimpleExpression
 
toString() - Method in class org.apache.cassandra.db.filter.RowFilter
 
toString(boolean) - Method in interface org.apache.cassandra.db.IMutation
 
toString() - Method in class org.apache.cassandra.db.Keyspace
 
toString() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState
 
toString() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
toString() - Method in class org.apache.cassandra.db.lifecycle.LogReplicaSet
 
toString() - Method in class org.apache.cassandra.db.lifecycle.View
 
toString() - Method in class org.apache.cassandra.db.LivenessInfo
 
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(byte[], Charset) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
toString(ByteBuffer, Charset) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
toString() - Method in class org.apache.cassandra.db.marshal.CollectionType
 
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.PartitionerDefinedOrder
 
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(boolean) - Method in class org.apache.cassandra.db.marshal.UserType
 
toString(V, Charset) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
 
toString(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
 
toString() - Method in class org.apache.cassandra.db.Memtable
 
toString() - Method in class org.apache.cassandra.db.MutableDeletionInfo
 
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.PartitionRangeReadCommand
 
toString() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
toString() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
 
toString(ClusteringComparator) - Method in class org.apache.cassandra.db.RangeTombstone
 
toString() - Method in class org.apache.cassandra.db.RegularAndStaticColumns
 
toString() - Method in class org.apache.cassandra.db.rows.AbstractCell
 
toString(TableMetadata, boolean) - Method in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
 
toString(TableMetadata, boolean, boolean) - Method in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
 
toString() - Method in class org.apache.cassandra.db.rows.AbstractRow
 
toString(TableMetadata) - Method in class org.apache.cassandra.db.rows.AbstractRow
 
toString(TableMetadata, boolean) - Method in class org.apache.cassandra.db.rows.AbstractRow
 
toString(TableMetadata, boolean, boolean) - Method in class org.apache.cassandra.db.rows.AbstractRow
 
toString() - Method in class org.apache.cassandra.db.rows.EncodingStats
 
toString(TableMetadata) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
toString(TableMetadata) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
toString() - Method in class org.apache.cassandra.db.rows.Row.Deletion
 
toString(TableMetadata, boolean) - Method in interface org.apache.cassandra.db.rows.Row
 
toString(TableMetadata) - Method in interface org.apache.cassandra.db.rows.Unfiltered
 
toString(TableMetadata, boolean) - Method in interface org.apache.cassandra.db.rows.Unfiltered
 
toString(TableMetadata, boolean, boolean) - Method in interface org.apache.cassandra.db.rows.Unfiltered
 
toString() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer.Header
 
toString() - Method in class org.apache.cassandra.db.SerializationHeader.Component
 
toString() - Method in class org.apache.cassandra.db.SerializationHeader
 
toString() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
toString() - Method in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
 
toString(ClusteringComparator) - Method in class org.apache.cassandra.db.Slice
 
toString() - Method in class org.apache.cassandra.db.SnapshotCommand
 
toString() - Method in class org.apache.cassandra.db.SSTableImporter.Options
 
toString() - Method in class org.apache.cassandra.db.streaming.CassandraIncomingFile
 
toString() - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
 
toString() - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader
 
toString() - Method in class org.apache.cassandra.db.TruncateRequest
 
toString(boolean) - Method in class org.apache.cassandra.db.virtual.VirtualMutation
 
toString() - Method in class org.apache.cassandra.dht.Bounds
 
toString() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
 
toString() - Method in class org.apache.cassandra.dht.ExcludingBounds
 
toString() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
toString() - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
 
toString() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
 
toString() - Method in class org.apache.cassandra.dht.Range
 
toString() - Method in class org.apache.cassandra.dht.RangeStreamer.FetchReplica
 
toString() - Method in class org.apache.cassandra.dht.Splitter.WeightedRange
 
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.dht.tokenallocator.NoReplicationTokenAllocator
 
toString() - Method in class org.apache.cassandra.fql.FullQueryLoggerOptions
 
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.HeartBeatState
 
toString() - Method in class org.apache.cassandra.gms.VersionedValue
 
toString() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
toString() - Method in class org.apache.cassandra.index.sasi.disk.Descriptor.Version
 
toString() - Method in class org.apache.cassandra.index.sasi.plan.Expression
 
toString() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
 
toString() - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
 
toString() - Method in error org.apache.cassandra.io.FSDiskFullWriteError
 
toString() - Method in error org.apache.cassandra.io.FSNoDiskAvailableForWriteError
 
toString() - Method in error org.apache.cassandra.io.FSReadError
 
toString() - Method in error org.apache.cassandra.io.FSWriteError
 
toString() - Method in class org.apache.cassandra.io.sstable.Component
 
toString() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
toString() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
 
toString() - Method in class org.apache.cassandra.io.sstable.format.Version
 
toString() - Method in class org.apache.cassandra.io.sstable.format.VersionAndType
 
toString() - Method in class org.apache.cassandra.io.sstable.SSTable
 
toString() - Method in class org.apache.cassandra.io.util.AbstractReaderFileProxy
 
toString() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
 
toString() - Method in class org.apache.cassandra.io.util.ChannelProxy
 
toString() - Method in class org.apache.cassandra.io.util.CompressedChunkReader
 
toString() - Method in class org.apache.cassandra.io.util.FileHandle
 
toString() - Method in class org.apache.cassandra.io.util.LimitingRebufferer
 
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.SimpleCachedBufferPool
 
toString() - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
 
toString() - Method in class org.apache.cassandra.locator.InetAddressAndPort
 
toString(boolean) - Method in class org.apache.cassandra.locator.InetAddressAndPort
 
toString(InetAddress, int) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
Format an InetAddressAndPort in the same style as InetAddress.toString.
toString() - Method in class org.apache.cassandra.locator.Replica
 
toString() - Method in interface org.apache.cassandra.locator.ReplicaCollection
 
toString() - Method in class org.apache.cassandra.locator.ReplicaLayout.ForWrite
 
toString() - Method in class org.apache.cassandra.locator.ReplicaLayout
 
toString() - Method in class org.apache.cassandra.locator.ReplicaMultimap
 
toString() - Method in class org.apache.cassandra.locator.ReplicaPlan.ForRead
 
toString() - Method in class org.apache.cassandra.locator.ReplicaPlan.ForWrite
 
toString() - Method in class org.apache.cassandra.locator.ReplicationFactor
 
toString() - Method in class org.apache.cassandra.locator.TokenMetadata
 
toString() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
 
toString() - Method in class org.apache.cassandra.metrics.Sampler.Sample
 
toString(T) - Method in class org.apache.cassandra.metrics.Sampler
 
toString() - Method in class org.apache.cassandra.net.AsyncPromise
 
toString() - Method in class org.apache.cassandra.net.InboundConnectionSettings
 
toString() - Method in class org.apache.cassandra.net.InboundMessageHandler
 
toString() - Method in class org.apache.cassandra.net.Message
 
toString() - Method in class org.apache.cassandra.net.OutboundConnection
 
toString() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
toString() - Method in class org.apache.cassandra.repair.asymmetric.DifferenceHolder
 
toString() - Method in class org.apache.cassandra.repair.asymmetric.HostDifferences
 
toString() - Method in class org.apache.cassandra.repair.asymmetric.IncomingRepairStreamTracker
 
toString() - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
 
toString() - Method in class org.apache.cassandra.repair.asymmetric.StreamFromOptions
 
toString() - Method in class org.apache.cassandra.repair.AsymmetricRemoteSyncTask
 
toString() - Method in class org.apache.cassandra.repair.CommonRange
 
toString() - Method in class org.apache.cassandra.repair.consistent.admin.RepairStats.Section
 
toString() - Method in class org.apache.cassandra.repair.consistent.ConsistentSession
 
toString() - Method in class org.apache.cassandra.repair.consistent.LocalSession
 
toString() - Method in class org.apache.cassandra.repair.consistent.RepairedState.Section
 
toString() - Method in class org.apache.cassandra.repair.consistent.SyncStatSummary
 
toString() - Method in class org.apache.cassandra.repair.LocalSyncTask
 
toString() - Method in class org.apache.cassandra.repair.messages.FinalizeCommit
 
toString() - Method in class org.apache.cassandra.repair.messages.FinalizePropose
 
toString() - Method in class org.apache.cassandra.repair.messages.PrepareConsistentRequest
 
toString() - Method in class org.apache.cassandra.repair.messages.PrepareMessage
 
toString() - Method in class org.apache.cassandra.repair.messages.RepairOption
 
toString() - Method in class org.apache.cassandra.repair.messages.StatusRequest
 
toString() - Method in class org.apache.cassandra.repair.messages.StatusResponse
 
toString() - Method in class org.apache.cassandra.repair.messages.SyncRequest
 
toString() - Method in class org.apache.cassandra.repair.messages.ValidationRequest
 
toString() - Method in class org.apache.cassandra.repair.RepairJobDesc
 
toString(PreviewKind) - Method in class org.apache.cassandra.repair.RepairJobDesc
 
toString() - Method in enum org.apache.cassandra.repair.RepairParallelism
 
toString() - Method in class org.apache.cassandra.repair.RepairSessionResult
 
toString() - Method in class org.apache.cassandra.repair.SymmetricRemoteSyncTask
 
toString() - Method in class org.apache.cassandra.repair.SyncNodePair
 
toString() - Method in enum org.apache.cassandra.schema.CachingParams.Option
 
toString() - Method in class org.apache.cassandra.schema.CachingParams
 
toString() - Method in class org.apache.cassandra.schema.ColumnMetadata
 
toString() - Method in enum org.apache.cassandra.schema.CompactionParams.Option
 
toString() - Method in class org.apache.cassandra.schema.CompactionParams
 
toString() - Method in class org.apache.cassandra.schema.Diff.Altered
 
toString() - Method in class org.apache.cassandra.schema.DroppedColumn
 
toString() - Method in class org.apache.cassandra.schema.Functions
 
toString() - Method in class org.apache.cassandra.schema.Indexes
 
toString() - Method in class org.apache.cassandra.schema.IndexMetadata
 
toString() - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
toString() - Method in enum org.apache.cassandra.schema.KeyspaceParams.Option
 
toString() - Method in class org.apache.cassandra.schema.KeyspaceParams
 
toString() - Method in class org.apache.cassandra.schema.Keyspaces
 
toString() - Method in class org.apache.cassandra.schema.ReplicationParams
 
toString() - Method in class org.apache.cassandra.schema.TableId
 
toString() - Method in class org.apache.cassandra.schema.TableMetadata
 
toString() - Method in class org.apache.cassandra.schema.TableMetadataRef
 
toString() - Method in enum org.apache.cassandra.schema.TableParams.Option
 
toString() - Method in class org.apache.cassandra.schema.TableParams
 
toString() - Method in class org.apache.cassandra.schema.Tables
 
toString() - Method in class org.apache.cassandra.schema.TriggerMetadata
 
toString() - Method in class org.apache.cassandra.schema.Triggers
 
toString() - Method in class org.apache.cassandra.schema.Types
 
toString() - Method in class org.apache.cassandra.schema.ViewMetadata
 
toString() - Method in class org.apache.cassandra.schema.Views
 
toString(String) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
 
toString(Boolean) - Method in class org.apache.cassandra.serializers.BooleanSerializer
 
toString(Byte) - Method in class org.apache.cassandra.serializers.ByteSerializer
 
toString(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
 
toString(BigDecimal) - Method in class org.apache.cassandra.serializers.DecimalSerializer
 
toString(Double) - Method in class org.apache.cassandra.serializers.DoubleSerializer
 
toString(Duration) - Method in class org.apache.cassandra.serializers.DurationSerializer
 
toString(Void) - Method in class org.apache.cassandra.serializers.EmptySerializer
 
toString(Float) - Method in class org.apache.cassandra.serializers.FloatSerializer
 
toString(InetAddress) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
 
toString(Integer) - Method in class org.apache.cassandra.serializers.Int32Serializer
 
toString(BigInteger) - Method in class org.apache.cassandra.serializers.IntegerSerializer
 
toString(List<T>) - Method in class org.apache.cassandra.serializers.ListSerializer
 
toString(Long) - Method in class org.apache.cassandra.serializers.LongSerializer
 
toString(Map<K, V>) - Method in class org.apache.cassandra.serializers.MapSerializer
 
toString(Set<T>) - Method in class org.apache.cassandra.serializers.SetSerializer
 
toString(Short) - Method in class org.apache.cassandra.serializers.ShortSerializer
 
toString(Integer) - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
 
toString(Long) - Method in class org.apache.cassandra.serializers.TimeSerializer
 
toString(Date) - Method in class org.apache.cassandra.serializers.TimestampSerializer
 
toString(T) - Method in class 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.RowMark
 
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.service.reads.AlwaysSpeculativeRetryPolicy
 
toString() - Method in class org.apache.cassandra.service.reads.FixedSpeculativeRetryPolicy
 
toString() - Method in class org.apache.cassandra.service.reads.HybridSpeculativeRetryPolicy
 
toString() - Method in class org.apache.cassandra.service.reads.NeverSpeculativeRetryPolicy
 
toString() - Method in class org.apache.cassandra.service.reads.PercentileSpeculativeRetryPolicy
 
toString() - Method in class org.apache.cassandra.service.reads.repair.RepairedDataTracker
 
toString() - Method in class org.apache.cassandra.service.SSTablesVersionsInUseChangeNotification
 
toString() - Method in class org.apache.cassandra.service.TokenRange.EndpointDetails
 
toString(boolean) - Method in class org.apache.cassandra.service.TokenRange.EndpointDetails
 
toString() - Method in class org.apache.cassandra.service.TokenRange
 
toString(boolean) - Method in class org.apache.cassandra.service.TokenRange
 
toString() - Method in class org.apache.cassandra.streaming.messages.CompleteMessage
 
toString() - Method in class org.apache.cassandra.streaming.messages.IncomingStreamMessage
 
toString() - Method in class org.apache.cassandra.streaming.messages.KeepAliveMessage
 
toString() - Method in class org.apache.cassandra.streaming.messages.OutgoingStreamMessage
 
toString() - Method in class org.apache.cassandra.streaming.messages.PrepareAckMessage
 
toString() - Method in class org.apache.cassandra.streaming.messages.PrepareSynAckMessage
 
toString() - Method in class org.apache.cassandra.streaming.messages.PrepareSynMessage
 
toString() - Method in class org.apache.cassandra.streaming.messages.ReceivedMessage
 
toString() - Method in class org.apache.cassandra.streaming.messages.SessionFailedMessage
 
toString() - Method in class org.apache.cassandra.streaming.messages.StreamInitMessage
 
toString() - Method in class org.apache.cassandra.streaming.messages.StreamMessageHeader
 
toString() - Method in class org.apache.cassandra.streaming.ProgressInfo
 
toString(boolean) - 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.tools.JMXTool.Attribute
 
toString() - Method in class org.apache.cassandra.tools.JMXTool.Operation
 
toString() - Method in class org.apache.cassandra.tools.JMXTool.Parameter
 
toString() - Method in class org.apache.cassandra.transport.ClientStat
 
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.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 enum org.apache.cassandra.transport.ProtocolVersion
 
toString() - Method in class org.apache.cassandra.utils.BloomCalculations.BloomSpecification
 
toString() - Method in class org.apache.cassandra.utils.BloomFilter
 
toString() - Method in class org.apache.cassandra.utils.CassandraVersion
 
toString() - Method in class org.apache.cassandra.utils.CounterId
 
toString() - Method in class org.apache.cassandra.utils.ExpiringMemoizingSupplier
 
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.IntegerInterval.Set
 
toString() - Method in class org.apache.cassandra.utils.IntegerInterval
 
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
 
toStringSet(Set<TableMetadata.Flag>) - Static method in enum org.apache.cassandra.schema.TableMetadata.Flag
 
toStringUTC(Date) - Method in class org.apache.cassandra.serializers.TimestampSerializer
 
TOTAL - Static variable in class org.apache.cassandra.db.compaction.CompactionInfo
 
total(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.context.CounterContext
Returns the aggregated count across all counter ids.
total(Cell<V>) - Method in class org.apache.cassandra.db.context.CounterContext
 
total - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStats
 
TOTAL_BLOCKED_TASKS - Static variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
 
totalBlocked - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
Number of tasks that had blocked before being accepted (or rejected).
totalBytes - Variable in class org.apache.cassandra.streaming.ProgressInfo
 
totalBytesCompacted - Static variable in class org.apache.cassandra.db.compaction.CompactionTask
 
totalColumnsSet - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
totalColumnsSet - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
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.KeyspaceMetrics
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.TableMetrics
Total disk space used by SSTables belonging to this table, including obsolete ones waiting to be GC'd
totalExpiredCallbacks - Static variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Total number of callbacks that were not completed successfully for messages that were sent to this node TODO this was always broken, as it never counted those messages without callbacks? So perhaps we can redefine it.
totalHints - Static variable in class org.apache.cassandra.metrics.StorageMetrics
 
totalHintsInProgress - Static variable in class org.apache.cassandra.metrics.StorageMetrics
 
totalIncomingBytes - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
 
totalLatency - Variable in class org.apache.cassandra.metrics.LatencyMetrics
Total latency in micro sec
totalOutgoingBytes - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
 
totalOutgoingRepairBytes - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
 
totalOutgoingRepairSSTables - Static variable in class org.apache.cassandra.metrics.StreamingMetrics
 
totalRows - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
totalRows - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
 
totalSize() - Method in class org.apache.cassandra.db.streaming.CassandraCompressedStreamReader
 
totalSize() - Method in class org.apache.cassandra.db.streaming.CassandraCompressedStreamWriter
 
totalSize() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader
 
totalSize() - Method in class org.apache.cassandra.db.streaming.CassandraStreamWriter
 
totalSize() - Method in class org.apache.cassandra.db.streaming.ComponentManifest
 
totalSize - Variable in class org.apache.cassandra.streaming.StreamSummary
 
totalTokens(Splitter) - Method in class org.apache.cassandra.dht.Splitter.WeightedRange
 
toTerm(List<? extends ColumnSpecification>, Term.Raw, String, VariableSpecifications) - Method in class org.apache.cassandra.cql3.MultiColumnRelation
 
toTerm(List<? extends ColumnSpecification>, Term.Raw, String, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Relation
Converts the specified Raw into a Term.
toTerm(List<? extends ColumnSpecification>, Term.Raw, String, VariableSpecifications) - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
toTerm(List<? extends ColumnSpecification>, Term.Raw, String, VariableSpecifications) - Method in class org.apache.cassandra.cql3.TokenRelation
 
toTerms(List<? extends ColumnSpecification>, List<? extends Term.Raw>, String, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Relation
Converts the specified Raw terms into a Terms.
toTimeInMillis(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
toTimeInMillis(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TemporalType
Converts this temporal in UNIX timestamp.
toTimeInMillis(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimestampType
 
toTimeInMillis(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
toTimestamp(TemporalType<?>) - Static method in class org.apache.cassandra.cql3.functions.TimeFcts
Creates a function that convert a value of the specified type into a TIMESTAMP.
toType(Pair<DataType, Object>) - Static method in enum org.apache.cassandra.transport.DataType
 
toUnixTimestamp(TemporalType<?>) - Static method in class org.apache.cassandra.cql3.functions.TimeFcts
Creates a function that convert a value of the specified type into an UNIX timestamp.
toUUID(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
toUUID(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
toUUID(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
returns a UUID from offset 0
toWriteUTFBytes(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
TpStats - Class in org.apache.cassandra.tools.nodetool
 
TpStats() - Constructor for class org.apache.cassandra.tools.nodetool.TpStats
 
TpStatsHolder - Class in org.apache.cassandra.tools.nodetool.stats
 
TpStatsHolder(NodeProbe) - Constructor for class org.apache.cassandra.tools.nodetool.stats.TpStatsHolder
 
TpStatsPrinter - Class in org.apache.cassandra.tools.nodetool.stats
 
TpStatsPrinter() - Constructor for class org.apache.cassandra.tools.nodetool.stats.TpStatsPrinter
 
TpStatsPrinter.DefaultPrinter - Class in org.apache.cassandra.tools.nodetool.stats
 
trace(String, Object) - Method in class org.apache.cassandra.tracing.TraceState
 
trace(String, Object, Object) - Method in class org.apache.cassandra.tracing.TraceState
 
trace(String, Object...) - Method in class org.apache.cassandra.tracing.TraceState
 
trace(String) - Method in class org.apache.cassandra.tracing.TraceState
 
trace(String) - Static method in class org.apache.cassandra.tracing.Tracing
 
trace(String, Object) - Static method in class org.apache.cassandra.tracing.Tracing
 
trace(String, Object, Object) - Static method in class org.apache.cassandra.tracing.Tracing
 
trace(String, Object...) - Static method in class org.apache.cassandra.tracing.Tracing
 
trace(ByteBuffer, String, int) - Method in class org.apache.cassandra.tracing.Tracing
Called for non-local traces (traces that are not initiated by local node == coordinator).
TRACE_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
 
TRACE_KEYSPACE_NAME - Static variable in class org.apache.cassandra.schema.SchemaConstants
 
traceImpl(String) - Method in class org.apache.cassandra.tracing.TraceState
 
traceImpl(String) - Method in class org.apache.cassandra.tracing.TraceStateImpl
 
TraceKeyspace - Class in org.apache.cassandra.tracing
 
traceOutgoingMessage(Message<?>, int, InetAddressAndPort) - Method in class org.apache.cassandra.tracing.Tracing
Record any tracing data, if enabled on this message.
traceRepair(String, Object...) - Static method in class org.apache.cassandra.tracing.Tracing
 
traceSession() - Method in class org.apache.cassandra.net.Message.Header
 
traceSession() - Method in class org.apache.cassandra.net.Message
 
traceState - Variable in class org.apache.cassandra.concurrent.ExecutorLocals
 
traceState - Variable in class org.apache.cassandra.service.reads.AbstractReadExecutor
 
TraceState - Class in org.apache.cassandra.tracing
ThreadLocal state for a tracing session.
TraceState(InetAddressAndPort, UUID, Tracing.TraceType) - Constructor for class org.apache.cassandra.tracing.TraceState
 
TraceState.Status - Enum in org.apache.cassandra.tracing
 
TraceStateImpl - Class in org.apache.cassandra.tracing
ThreadLocal state for a tracing session.
TraceStateImpl(InetAddressAndPort, UUID, Tracing.TraceType) - Constructor for class org.apache.cassandra.tracing.TraceStateImpl
 
traceType() - Method in class org.apache.cassandra.net.Message.Header
 
traceType() - Method in class org.apache.cassandra.net.Message
 
traceType - Variable in class org.apache.cassandra.tracing.TraceState
 
tracetype_query_ttl - Variable in class org.apache.cassandra.config.Config
 
tracetype_repair_ttl - Variable in class org.apache.cassandra.config.Config
 
traceTypeSerializer - Static variable in class org.apache.cassandra.tracing.Tracing
 
Tracing - Class in org.apache.cassandra.tracing
A trace session context.
Tracing() - Constructor for class org.apache.cassandra.tracing.Tracing
 
Tracing.TraceType - Enum in org.apache.cassandra.tracing
 
tracingId - Variable in class org.apache.cassandra.transport.Message.Response
 
trackedByCDC() - Method in class org.apache.cassandra.db.Mutation
 
TrackedDataInputPlus - Class in org.apache.cassandra.io.util
This class is to track bytes read from given DataInput
TrackedDataInputPlus(DataInput) - Constructor for class org.apache.cassandra.io.util.TrackedDataInputPlus
 
TrackedInputStream - Class in org.apache.cassandra.io.util
This class is to track bytes read from given DataInputStream
TrackedInputStream(InputStream) - Constructor for class org.apache.cassandra.io.util.TrackedInputStream
 
tracker - Variable in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
Tracker - Class in org.apache.cassandra.db.lifecycle
Tracker tracks live View of data store for a table.
Tracker(Memtable, boolean) - Constructor for class org.apache.cassandra.db.lifecycle.Tracker
 
tracker - Variable in class org.apache.cassandra.transport.SimpleClient
 
trackInboundHandlers() - Static method in class org.apache.cassandra.streaming.async.StreamingInboundHandler
 
trackLatencyForSnitch() - Method in interface org.apache.cassandra.net.RequestCallback
 
trackLatencyForSnitch() - Method in class org.apache.cassandra.service.reads.ReadCallback
 
trackNew(SSTable) - Method in interface org.apache.cassandra.db.lifecycle.LifecycleNewTracker
Called when a new table is about to be created, so that this table can be tracked by a transaction.
trackNew(SSTable) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
trackNew(SSTable) - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
 
trackRepairedData() - Method in class org.apache.cassandra.net.Message
See CASSANDRA-14145
trackSyncCompletion(Pair<RepairJobDesc, SyncNodePair>, CompletableRemoteSyncTask) - Method in class org.apache.cassandra.repair.RepairSession
 
trackValidationCompletion(Pair<RepairJobDesc, InetAddressAndPort>, ValidationTask) - Method in class org.apache.cassandra.repair.RepairSession
 
trans - Variable in class org.apache.cassandra.db.SystemKeyspace.AvailableRanges
 
transaction - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
 
Transactional - Interface in org.apache.cassandra.utils.concurrent
An abstraction for Transactional behaviour.
Transactional.AbstractTransactional - Class in org.apache.cassandra.utils.concurrent
A simple abstract implementation of Transactional behaviour.
Transactional.AbstractTransactional.State - Enum in org.apache.cassandra.utils.concurrent
 
TransactionalProxy() - Constructor for class org.apache.cassandra.io.compress.CompressedSequentialWriter.TransactionalProxy
 
TransactionalProxy() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableWriter.TransactionalProxy
 
TransactionalProxy() - Constructor for class org.apache.cassandra.io.util.ChecksummedSequentialWriter.TransactionalProxy
 
TransactionalProxy() - Constructor for class org.apache.cassandra.io.util.SequentialWriter.TransactionalProxy
 
transEndpoints - Variable in class org.apache.cassandra.repair.CommonRange
 
transferHints(Supplier<UUID>) - Method in class org.apache.cassandra.hints.HintsService
Transfer all local hints to the hostId supplied by hostIdSupplier Flushes the buffer to make sure all hints are on disk and closes the hint writers so we don't leave any hint files around.
transferRanges - Variable in class org.apache.cassandra.repair.LocalSyncTask
 
transferRanges(InetAddressAndPort, String, RangesAtEndpoint, String...) - Method in class org.apache.cassandra.streaming.StreamPlan
Add transfer task to send data of specific columnFamilies under keyspace and ranges.
TRANSFERRED_RANGES_V2 - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
transferredRangesPerKeyspace - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
 
transfers - Variable in class org.apache.cassandra.streaming.StreamSession
 
transferStreams(InetAddressAndPort, Collection<OutgoingStream>) - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
transferStreams(InetAddressAndPort, Collection<OutgoingStream>) - Method in class org.apache.cassandra.streaming.StreamPlan
Add transfer task to send given streams
transferTo(long, long, WritableByteChannel) - Method in class org.apache.cassandra.io.util.ChannelProxy
 
transform(SchemaTransformation, boolean, long) - Method in class org.apache.cassandra.schema.Schema
 
transformAndFilter(Object[], Function<? super V, ? extends V>) - Static method in class org.apache.cassandra.utils.btree.BTree
Takes a btree and transforms it using the provided function, filtering out any null results.
Transformation<I extends BaseRowIterator<?>> - Class in org.apache.cassandra.db.transform
We have a single common superclass for all Transformations to make implementation efficient.
Transformation() - Constructor for class org.apache.cassandra.db.transform.Transformation
 
transformIterator(Function<Replica, K>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
 
transientReplica(InetAddressAndPort, Range<Token>) - Static method in class org.apache.cassandra.locator.Replica
 
transientReplica(InetAddressAndPort, Token, Token) - Static method in class org.apache.cassandra.locator.Replica
 
transientReplicas() - Method in class org.apache.cassandra.locator.Replicas.ReplicaCount
 
transientReplicas() - Method in class org.apache.cassandra.locator.ReplicationFactor
 
transientReplicas - Variable in class org.apache.cassandra.streaming.StreamRequest
 
translate() - Method in class org.apache.cassandra.utils.MonotonicClock.AbstractEpochSamplingClock
 
translate() - Method in class org.apache.cassandra.utils.MonotonicClock.SampledClock
 
translate() - Method in interface org.apache.cassandra.utils.MonotonicClock
 
transparent_data_encryption_options - Variable in class org.apache.cassandra.config.Config
 
TransparentDataEncryptionOptions - Class in org.apache.cassandra.config
 
TransparentDataEncryptionOptions() - Constructor for class org.apache.cassandra.config.TransparentDataEncryptionOptions
 
TransparentDataEncryptionOptions(boolean) - Constructor for class org.apache.cassandra.config.TransparentDataEncryptionOptions
 
TransparentDataEncryptionOptions(String, String, ParameterizedClass) - Constructor for class org.apache.cassandra.config.TransparentDataEncryptionOptions
 
TransparentDataEncryptionOptions(boolean, String, String, ParameterizedClass) - Constructor for class org.apache.cassandra.config.TransparentDataEncryptionOptions
 
TransportException - Interface in org.apache.cassandra.exceptions
 
traverse(Cursor<? super K, ? super V>) - Method in interface org.apache.cassandra.index.sasi.utils.trie.Trie
Traverses the Trie in lexicographical order.
tree - Variable in class org.apache.cassandra.utils.btree.BTreeSet
 
tree() - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
treeIndexOfBranchKey(Object[], int) - Static method in class org.apache.cassandra.utils.btree.BTree
 
treeIndexOffsetOfChild(Object[], int) - Static method in class org.apache.cassandra.utils.btree.BTree
 
treeIndexOfKey(Object[], int) - Static method in class org.apache.cassandra.utils.btree.BTree
tree index => index of key wrt all items in the tree laid out serially This version of the method permits requesting out-of-bounds indexes, -1 and size
treeIndexOfLeafKey(int) - Static method in class org.apache.cassandra.utils.btree.BTree
 
treeMaxToken - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
 
treeMinToken - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
 
TreeResponse - Class in org.apache.cassandra.repair
Merkle tree response sent from given endpoint.
TreeResponse(InetAddressAndPort, MerkleTrees) - Constructor for class org.apache.cassandra.repair.TreeResponse
 
trees - Variable in class org.apache.cassandra.repair.messages.ValidationResponse
Merkle hash tree response.
trees - Variable in class org.apache.cassandra.repair.TreeResponse
 
treesReceived(MerkleTrees) - Method in class org.apache.cassandra.repair.ValidationTask
Receive MerkleTrees from replica node.
trickle_fsync - Variable in class org.apache.cassandra.config.Config
 
trickle_fsync_interval_in_kb - Variable in class org.apache.cassandra.config.Config
 
trickleFsync(boolean) - Method in class org.apache.cassandra.io.util.SequentialWriterOption.Builder
 
trickleFsync() - Method in class org.apache.cassandra.io.util.SequentialWriterOption
 
trickleFsyncByteInterval(int) - Method in class org.apache.cassandra.io.util.SequentialWriterOption.Builder
 
trickleFsyncByteInterval() - Method in class org.apache.cassandra.io.util.SequentialWriterOption
 
Trie<K,V> - Interface in org.apache.cassandra.index.sasi.utils.trie
Defines the interface for a prefix tree, an ordered tree data structure.
TrieMemIndex - Class in org.apache.cassandra.index.sasi.memory
 
TrieMemIndex(AbstractType<?>, ColumnIndex) - Constructor for class org.apache.cassandra.index.sasi.memory.TrieMemIndex
 
TrieMemIndex.ConcurrentPrefixTrie - Class in org.apache.cassandra.index.sasi.memory
 
TrieMemIndex.ConcurrentSuffixTrie - Class in org.apache.cassandra.index.sasi.memory
 
Tries - Class in org.apache.cassandra.index.sasi.utils.trie
A collection of Trie utilities
Tries() - Constructor for class org.apache.cassandra.index.sasi.utils.trie.Tries
 
trigger() - Method in class org.apache.cassandra.utils.memory.MemtableCleanerThread
 
TriggerExecutor - Class in org.apache.cassandra.triggers
 
TriggerMetadata - Class in org.apache.cassandra.schema
 
TriggerMetadata(String, String) - Constructor for class org.apache.cassandra.schema.TriggerMetadata
 
TRIGGERS - Static variable in class org.apache.cassandra.schema.SchemaKeyspace
 
triggers(Triggers) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
 
triggers - Variable in class org.apache.cassandra.schema.TableMetadata
 
Triggers - Class in org.apache.cassandra.schema
 
Triggers.Builder - Class in org.apache.cassandra.schema
 
trim(int) - Method in class org.apache.cassandra.cql3.ResultSet
 
trim() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
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.TableMetrics
Disk space used by snapshot files which
trueSnapshotsSize() - Method in class org.apache.cassandra.service.StorageService
 
trueSnapshotsSize() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Get the true size taken by all snapshots across all keyspaces.
trueSnapshotsSize() - Method in class org.apache.cassandra.tools.NodeProbe
 
truncate(String, long) - Static method in class org.apache.cassandra.io.util.FileUtils
 
truncate(long) - Method in class org.apache.cassandra.io.util.SequentialWriter
 
truncate() - Static method in class org.apache.cassandra.schema.SchemaKeyspace
 
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 table from the provided keyspace.
truncate(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
truncate_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
truncateAllIndexesBlocking(long) - Method in class org.apache.cassandra.index.SecondaryIndexManager
Truncate all indexes
truncateBlocking() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Truncate deletes the entire column family's data with no expensive tombstone creation
truncateBlocking(CommitLogPosition, long) - Method in class org.apache.cassandra.db.view.TableViews
 
truncateBlocking(String, String) - Static method in class org.apache.cassandra.service.StorageProxy
Performs the truncate operatoin, which effectively deletes all data from the column family cfname
truncatedAt - Variable in class org.apache.cassandra.notifications.TruncationNotification
 
TruncateException - Exception in org.apache.cassandra.exceptions
 
TruncateException(Throwable) - Constructor for exception org.apache.cassandra.exceptions.TruncateException
 
TruncateException(String) - Constructor for exception org.apache.cassandra.exceptions.TruncateException
 
truncateHints(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
truncateHints() - Method in class org.apache.cassandra.tools.NodeProbe
 
TruncateHints - Class in org.apache.cassandra.tools.nodetool
 
TruncateHints() - Constructor for class org.apache.cassandra.tools.nodetool.TruncateHints
 
TruncateRequest - Class in org.apache.cassandra.db
A truncate operation descriptor
TruncateRequest(String, String) - Constructor for class org.apache.cassandra.db.TruncateRequest
 
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 - Class in org.apache.cassandra.cql3.statements
 
TruncateStatement(QualifiedName) - Constructor for class org.apache.cassandra.cql3.statements.TruncateStatement
 
TruncateVerbHandler - Class in org.apache.cassandra.db
 
TruncateVerbHandler() - Constructor for class org.apache.cassandra.db.TruncateVerbHandler
 
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_password - Variable in class org.apache.cassandra.config.EncryptionOptions
 
tryAllocate(long) - Method in class org.apache.cassandra.net.ResourceLimits.Basic
 
tryAllocate(long) - Method in class org.apache.cassandra.net.ResourceLimits.Concurrent
 
tryAllocate(long) - Method in class org.apache.cassandra.net.ResourceLimits.EndpointAndGlobal
 
tryAllocate(long) - Method in interface org.apache.cassandra.net.ResourceLimits.Limit
Attempts to allocate an amount of permits from this limit.
tryAppend(UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
 
tryCloseFD(int) - Static method in class org.apache.cassandra.utils.NativeLibrary
 
tryComponentFromFilename(File) - Static method in class org.apache.cassandra.io.sstable.SSTable
Parse a sstable filename into both a Descriptor and Component object.
tryCreate(FunctionName, List<ColumnIdentifier>, List<AbstractType<?>>, AbstractType<?>, boolean, String, String) - Static method in class org.apache.cassandra.cql3.functions.UDFunction
 
tryDescriptorFromFilename(File) - Static method in class org.apache.cassandra.io.sstable.SSTable
Parse a sstable filename into a Descriptor object.
tryFailure(Throwable) - Method in class org.apache.cassandra.net.AsyncPromise
 
tryFcntl(int, int, int) - Static method in class org.apache.cassandra.utils.NativeLibrary
 
tryGet(int) - Method in class org.apache.cassandra.utils.memory.BufferPool
Unlike the get methods, this will return null if the pool is exhausted
tryGetAtLeast(int) - Method in class org.apache.cassandra.utils.memory.BufferPool
 
tryIntervalLock(long) - Method in class org.apache.cassandra.utils.concurrent.IntervalLock
Try acquiring a write lock if the given interval is passed since the last call to this method.
tryMlockall() - Static method in class org.apache.cassandra.utils.NativeLibrary
 
tryModify(SSTableReader, OperationType) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
tryModify(Iterable<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
tryMoveOffHeap() - Method in class org.apache.cassandra.repair.messages.ValidationResponse
 
tryMoveOffHeap() - Method in class org.apache.cassandra.utils.MerkleTrees
 
tryOpenDirectory(String) - Static method in class org.apache.cassandra.utils.NativeLibrary
 
tryRef() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
tryRef() - Method in class org.apache.cassandra.utils.concurrent.Ref
 
tryRef() - Method in interface org.apache.cassandra.utils.concurrent.RefCounted
 
tryRef(T) - Method in class org.apache.cassandra.utils.concurrent.Refs
Attempt to take a reference to the provided object; if it has already been released, null will be returned
tryRef(Iterable<T>) - Static method in class org.apache.cassandra.utils.concurrent.Refs
Acquire a reference to all of the provided objects, or none
trySkipCache(String, long, long) - Static method in class org.apache.cassandra.utils.NativeLibrary
 
trySkipCache(int, long, long, String) - Static method in class org.apache.cassandra.utils.NativeLibrary
 
trySkipCache(int, long, int, String) - Static method in class org.apache.cassandra.utils.NativeLibrary
 
trySuccess() - Method in class org.apache.cassandra.net.AsyncChannelPromise
 
trySuccess(V) - Method in class org.apache.cassandra.net.AsyncPromise
 
trySync(int) - Static method in class org.apache.cassandra.utils.NativeLibrary
 
trySync(int) - Static method in class org.apache.cassandra.utils.SyncUtil
 
trySyncDir(File) - Static method in class org.apache.cassandra.utils.SyncUtil
 
tryToComputeNext() - Method in class org.apache.cassandra.index.sasi.utils.AbstractIterator
 
tryToComputeNext() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator
 
tryUncacheRead() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
 
tryUpcast(ByteBuffer, AbstractType<?>) - Static method in class org.apache.cassandra.index.sasi.utils.TypeUtil
 
ttl() - Method in class org.apache.cassandra.db.LivenessInfo
The ttl (if any) on the row primary key columns or LivenessInfo.NO_TTL if it is not expiring.
ttl(int) - Method in interface org.apache.cassandra.db.Mutation.SimpleBuilder
Sets the ttl to use for the following additions to this builder or any derived (update or row) builder.
ttl(int) - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder
Sets the ttl to use for the following additions to this builder or any derived (row) builder.
ttl() - Method in class org.apache.cassandra.db.rows.ArrayCell
 
ttl() - Method in class org.apache.cassandra.db.rows.BufferCell
 
ttl() - Method in class org.apache.cassandra.db.rows.Cell
The cell ttl.
ttl() - Method in class org.apache.cassandra.db.rows.NativeCell
 
ttl(int) - Method in interface org.apache.cassandra.db.rows.Row.SimpleBuilder
Sets the ttl to use for the following additions.
ttl - Variable in class org.apache.cassandra.tracing.TraceState
 
ttlSerializedSize(int) - Method in class org.apache.cassandra.db.SerializationHeader
 
ttlTracker - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
tuple(List<CQL3Type.Raw>) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
tuple(TupleType) - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return a newly-created codec for the given CQL tuple type.
Tuples - Class in org.apache.cassandra.cql3
Static helper methods and classes for tuples.
Tuples.DelayedValue - Class in org.apache.cassandra.cql3
Similar to Value, but contains at least one NonTerminal, such as a non-pure functions or bind marker.
Tuples.InMarker - Class in org.apache.cassandra.cql3
Represents a marker for a set of IN values that are tuples, like "SELECT ...
Tuples.INRaw - Class in org.apache.cassandra.cql3
A raw marker for an IN list of tuples, like "SELECT ...
Tuples.InValue - Class in org.apache.cassandra.cql3
A terminal value for a list of IN values that are tuples.
Tuples.Literal - Class in org.apache.cassandra.cql3
A raw, literal tuple.
Tuples.Marker - Class in org.apache.cassandra.cql3
{@code Represents a marker for a single tuple, like "SELECT ...
Tuples.Raw - Class in org.apache.cassandra.cql3
A raw placeholder for a tuple of values for different multiple columns, each of which may have a different type.
Tuples.Value - Class in org.apache.cassandra.cql3
A tuple of terminal values (e.g (123, 'abc')).
TupleSerializer - Class in org.apache.cassandra.serializers
 
TupleSerializer(List<TypeSerializer<?>>) - Constructor for class org.apache.cassandra.serializers.TupleSerializer
 
tupleToString(List<?>) - Static method in class org.apache.cassandra.cql3.Tuples
Create a String representation of the tuple containing the specified elements.
tupleToString(Iterable<T>, Function<T, String>) - Static method in class org.apache.cassandra.cql3.Tuples
Create a String representation of the tuple from the specified items associated to the tuples elements.
TupleType - Class in org.apache.cassandra.cql3.functions.types
A tuple type.
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
 
TupleType(List<AbstractType<?>>, boolean) - Constructor for class org.apache.cassandra.db.marshal.TupleType
 
TupleValue - Class in org.apache.cassandra.cql3.functions.types
A value for a Tuple.
twcs(Map<String, String>) - Static method in class org.apache.cassandra.schema.CompactionParams
 
TWO - Static variable in class org.apache.cassandra.utils.FBUtilities
 
twoBitID() - Method in enum org.apache.cassandra.net.ConnectionType
 
twoHourRate() - Method in class org.apache.cassandra.metrics.RestorableMeter
Returns the two-hour rate in terms of events per second.
txn - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
 
txnProxy() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
 
txnProxy() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
 
txnProxy - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
txnProxy() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
 
txnProxy() - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter
 
txnProxy() - Method in class org.apache.cassandra.io.util.SequentialWriter
 
type() - Method in class org.apache.cassandra.audit.BinAuditLogger.Message
 
type - Variable in class org.apache.cassandra.cql3.ColumnSpecification
 
type - Variable in class org.apache.cassandra.cql3.statements.BatchStatement
 
type(String, String) - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
Creates a DescribeStatement for DESCRIBE TYPE.
type - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
 
type - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement
 
type - Variable in class org.apache.cassandra.cql3.statements.schema.IndexTarget
 
type - Variable in class org.apache.cassandra.cql3.Tuples.DelayedValue
 
type - Variable in enum org.apache.cassandra.db.compaction.OperationType
 
type(int) - Method in class org.apache.cassandra.db.marshal.TupleType
 
type() - Method in class org.apache.cassandra.fql.FullQueryLogger.Batch
 
type() - Method in class org.apache.cassandra.fql.FullQueryLogger.Query
 
TYPE - Static variable in class org.apache.cassandra.fql.FullQueryLogger
 
type - Variable in class org.apache.cassandra.gms.GossiperEvent
 
type() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf.LeafEntry
 
type() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf.SimpleLeafEntry
 
type - Variable in class org.apache.cassandra.io.sstable.Component
 
type() - Method in class org.apache.cassandra.net.OutboundConnection
 
type - Variable in class org.apache.cassandra.streaming.messages.StreamMessage
 
type - Variable in class org.apache.cassandra.transport.Envelope.Header
 
type - Variable in class org.apache.cassandra.transport.Event
 
type - Variable in class org.apache.cassandra.transport.Message
 
type() - Method in class org.apache.cassandra.utils.binlog.BinLog.ReleaseableWriteMarshallable
 
TYPE - Static variable in class org.apache.cassandra.utils.binlog.BinLog
 
TYPE_NAME - Static variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
 
TYPE_NAME - Static variable in class org.apache.cassandra.metrics.RepairMetrics
 
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
 
TypeCodec<T> - Class in org.apache.cassandra.cql3.functions.types
A Codec that can serialize and deserialize to and from a given CQL type and a given Java Type.
TypeCodec(DataType, Class<T>) - Constructor for class org.apache.cassandra.cql3.functions.types.TypeCodec
This constructor can only be used for non parameterized types.
TypeCodec(DataType, TypeToken<T>) - Constructor for class org.apache.cassandra.cql3.functions.types.TypeCodec
 
TypeCodec.AbstractCollectionCodec<E,C extends java.util.Collection<E>> - Class in org.apache.cassandra.cql3.functions.types
Base class for codecs mapping CQL lists and sets to Java collections.
TypeCodec.AbstractMapCodec<K,V> - Class in org.apache.cassandra.cql3.functions.types
Base class for codecs mapping CQL maps to a Java Map.
TypeCodec.AbstractTupleCodec<T> - Class in org.apache.cassandra.cql3.functions.types
Base class for codecs mapping CQL tuples to Java objects.
TypeCodec.AbstractUDTCodec<T> - Class in org.apache.cassandra.cql3.functions.types
Base class for codecs mapping CQL user-defined types (UDTs) to Java objects.
TypeCodec.PrimitiveBooleanCodec - Class in org.apache.cassandra.cql3.functions.types
A codec that is capable of handling primitive booleans, thus avoiding the overhead of boxing and unboxing such primitives.
TypeCodec.PrimitiveByteCodec - Class in org.apache.cassandra.cql3.functions.types
A codec that is capable of handling primitive bytes, thus avoiding the overhead of boxing and unboxing such primitives.
TypeCodec.PrimitiveDoubleCodec - Class in org.apache.cassandra.cql3.functions.types
A codec that is capable of handling primitive doubles, thus avoiding the overhead of boxing and unboxing such primitives.
TypeCodec.PrimitiveFloatCodec - Class in org.apache.cassandra.cql3.functions.types
A codec that is capable of handling primitive floats, thus avoiding the overhead of boxing and unboxing such primitives.
TypeCodec.PrimitiveIntCodec - Class in org.apache.cassandra.cql3.functions.types
A codec that is capable of handling primitive ints, thus avoiding the overhead of boxing and unboxing such primitives.
TypeCodec.PrimitiveLongCodec - Class in org.apache.cassandra.cql3.functions.types
A codec that is capable of handling primitive longs, thus avoiding the overhead of boxing and unboxing such primitives.
TypeCodec.PrimitiveShortCodec - Class in org.apache.cassandra.cql3.functions.types
A codec that is capable of handling primitive shorts, thus avoiding the overhead of boxing and unboxing such primitives.
typeHashCode(AbstractType<?>) - Static method in class org.apache.cassandra.schema.Functions
 
typeHashCode(List<AbstractType<?>>) - Static method in class org.apache.cassandra.schema.Functions
 
typeName - Variable in class org.apache.cassandra.cql3.statements.schema.AlterTypeStatement
 
typeOf(ByteBuffer) - Static method in enum org.apache.cassandra.io.compress.BufferType
 
TypeParser - Class in org.apache.cassandra.db.marshal
Parse a string containing an Type definition.
TypeParser(String) - Constructor for class org.apache.cassandra.db.marshal.TypeParser
 
types() - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
Creates a DescribeStatement for DESCRIBE TYPES.
types - Variable in class org.apache.cassandra.db.marshal.CompositeType
 
types - Variable in class org.apache.cassandra.db.marshal.TupleType
 
types - Variable in class org.apache.cassandra.schema.KeyspaceMetadata.KeyspaceDiff
 
types - Variable in class org.apache.cassandra.schema.KeyspaceMetadata
 
TYPES - Static variable in class org.apache.cassandra.schema.SchemaKeyspace
 
Types - Class in org.apache.cassandra.schema
An immutable container for a keyspace's UDTs.
Types.Builder - Class in org.apache.cassandra.schema
 
Types.RawBuilder - Class in org.apache.cassandra.schema
 
TypeSerializer<T> - Class in org.apache.cassandra.serializers
 
TypeSerializer() - Constructor for class org.apache.cassandra.serializers.TypeSerializer
 
TypeSizes - Class in org.apache.cassandra.db
 
typesMatch(List<AbstractType<?>>, List<AbstractType<?>>) - Static method in class org.apache.cassandra.schema.Functions
 
TypeTokens - Class in org.apache.cassandra.cql3.functions.types
Utility methods to create TypeToken instances.
typeTokens(TypeCodec<Object>[], boolean) - Static method in class org.apache.cassandra.cql3.functions.UDHelper
Construct an array containing the Java classes for the given DataTypes.
TypeUtil - Class in org.apache.cassandra.index.sasi.utils
 
TypeUtil() - Constructor for class org.apache.cassandra.index.sasi.utils.TypeUtil
 

U

UDAggregate - Class in org.apache.cassandra.cql3.functions
Base class for user-defined-aggregates.
UDAggregate(FunctionName, List<AbstractType<?>>, AbstractType<?>, ScalarFunction, ScalarFunction, ByteBuffer) - Constructor for class org.apache.cassandra.cql3.functions.UDAggregate
 
udas() - Method in class org.apache.cassandra.schema.Functions
 
udas - Variable in class org.apache.cassandra.schema.KeyspaceMetadata.KeyspaceDiff
 
UDFByteCodeVerifier - Class in org.apache.cassandra.cql3.functions
Verifies Java UDF byte code.
UDFByteCodeVerifier() - Constructor for class org.apache.cassandra.cql3.functions.UDFByteCodeVerifier
 
udfContext - Variable in class org.apache.cassandra.cql3.functions.JavaUDF
 
UDFContext - Interface in org.apache.cassandra.cql3.functions
Provides context information for a particular user defined function.
udfContext - Variable in class org.apache.cassandra.cql3.functions.UDFunction
 
UDFContextImpl - Class in org.apache.cassandra.cql3.functions
Package private implementation of UDFContext
udfs() - Method in class org.apache.cassandra.schema.Functions
 
udfs - Variable in class org.apache.cassandra.schema.KeyspaceMetadata.KeyspaceDiff
 
UDFunction - Class in org.apache.cassandra.cql3.functions
Base class for User Defined Functions.
UDFunction(FunctionName, List<ColumnIdentifier>, List<AbstractType<?>>, AbstractType<?>, boolean, String, String) - Constructor for class org.apache.cassandra.cql3.functions.UDFunction
 
UDFunction(FunctionName, List<ColumnIdentifier>, List<AbstractType<?>>, DataType[], AbstractType<?>, DataType, boolean, String, String) - Constructor for class org.apache.cassandra.cql3.functions.UDFunction
 
UDHelper - Class in org.apache.cassandra.cql3.functions
Helper class for User Defined Functions, Types and Aggregates.
UDHelper() - Constructor for class org.apache.cassandra.cql3.functions.UDHelper
 
udtFieldCondition(Term.Raw, FieldIdentifier, Operator) - Static method in class org.apache.cassandra.cql3.conditions.ColumnCondition.Raw
A condition on a UDT field.
udtFieldInCondition(FieldIdentifier, List<Term.Raw>) - Static method in class org.apache.cassandra.cql3.conditions.ColumnCondition.Raw
An IN condition on a collection element.
udtFieldInCondition(FieldIdentifier, AbstractMarker.INRaw) - Static method in class org.apache.cassandra.cql3.conditions.ColumnCondition.Raw
An IN condition on a collection element with a single marker.
UDTValue - Class in org.apache.cassandra.cql3.functions.types
A value for a User Defined Type.
Unaligned(ChunkReader) - Constructor for class org.apache.cassandra.io.util.BufferManagingRebufferer.Unaligned
 
UnauthorizedException - Exception in org.apache.cassandra.exceptions
 
UnauthorizedException(String) - Constructor for exception org.apache.cassandra.exceptions.UnauthorizedException
 
UnauthorizedException(String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.UnauthorizedException
 
UnavailableException - Exception in org.apache.cassandra.exceptions
 
UnavailableException(String, ConsistencyLevel, int, int) - Constructor for exception org.apache.cassandra.exceptions.UnavailableException
 
unavailables - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
 
UnbufferedDataOutputStreamPlus - Class in org.apache.cassandra.io.util
Base class for DataOutput implementations that does not have an optimized implementations of Plus methods and does no buffering.
UnbufferedDataOutputStreamPlus() - Constructor for class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
 
UnbufferedDataOutputStreamPlus(WritableByteChannel) - Constructor for class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
 
unbuild() - Method in class org.apache.cassandra.schema.TableMetadata
 
unbuild() - Method in class org.apache.cassandra.schema.TableParams
 
unbuild() - Method in class org.apache.cassandra.schema.Views
 
uncancellable(EventExecutor) - Static method in class org.apache.cassandra.net.AsyncPromise
 
uncancellable(EventExecutor, GenericFutureListener<? extends Future<? super V>>) - Static method in class org.apache.cassandra.net.AsyncPromise
 
uncaughtException(Thread, Throwable) - Static method in class org.apache.cassandra.service.CassandraDaemon
 
uncaughtExceptions - Static variable in class org.apache.cassandra.metrics.StorageMetrics
 
unchecked(Throwable) - Static method in class org.apache.cassandra.utils.Throwables
If the provided exception is unchecked, return it directly, otherwise wrap it into a RuntimeException to make it unchecked.
UNCHECKED_TOMBSTONE_COMPACTION_OPTION - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
uncheckedTombstoneCompaction - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
 
uncompress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
uncompress(byte[], int, int, byte[], int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
uncompress(byte[], int, int, byte[], int, int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
uncompress(byte[], int, int, byte[], int) - Method in interface org.apache.cassandra.io.compress.ICompressor
 
uncompress(ByteBuffer, ByteBuffer) - Method in interface org.apache.cassandra.io.compress.ICompressor
Decompression for DirectByteBuffers.
uncompress(byte[], int, int, byte[], int) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
 
uncompress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
 
uncompress(byte[], int, int, byte[], int) - Method in class org.apache.cassandra.io.compress.NoopCompressor
 
uncompress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.NoopCompressor
 
uncompress(byte[], int, int, byte[], int) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
 
uncompress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
 
uncompress(byte[], int, int, byte[], int) - Method in class org.apache.cassandra.io.compress.ZstdCompressor
Decompress data using arrays
uncompress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.ZstdCompressor
Decompress data via ByteBuffers
uncompress(ByteBuffer, ByteBuffer, boolean, ICompressor) - Static method in class org.apache.cassandra.security.EncryptionUtils
Uncompress the input data, as well as manage sizing of the outputBuffer; if the buffer is not big enough, deallocate current, and allocate a large enough buffer.
uncompress(byte[], int, int, byte[], int, ICompressor) - Static method in class org.apache.cassandra.security.EncryptionUtils
 
uncompressBuffer(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
 
uncompressedLength() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
unconfirmedRepairedInconsistencies - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Incremented where an inconsistency is detected, but there are pending & uncommitted repair sessions in play on at least one replica.
unconfirmedRepairedInconsistencies - Variable in class org.apache.cassandra.metrics.TableMetrics
 
Unfiltered - Interface in org.apache.cassandra.db.rows
Unfiltered is the common class for the main constituent of an unfiltered partition.
Unfiltered.Kind - Enum in org.apache.cassandra.db.rows
 
UnfilteredDeserializer - Class in org.apache.cassandra.db
Helper class to deserialize Unfiltered object from disk efficiently.
unfilteredIterator(ColumnFilter, NavigableSet<Clustering<?>>, boolean) - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
unfilteredIterator() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
unfilteredIterator(ColumnFilter, Slices, boolean) - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
unfilteredIterator(AbstractBTreePartition.Holder, ColumnFilter, Slices, boolean) - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
 
unfilteredIterator(ColumnFilter, Slices, boolean) - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
 
unfilteredIterator(ColumnFilter, NavigableSet<Clustering<?>>, boolean) - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
 
unfilteredIterator() - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
 
unfilteredIterator(AbstractBTreePartition.Holder, ColumnFilter, Slices, boolean) - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
 
unfilteredIterator() - Method in interface org.apache.cassandra.db.partitions.Partition
Returns an UnfilteredRowIterator over all the rows/RT contained by this partition.
unfilteredIterator(ColumnFilter, Slices, boolean) - Method in interface org.apache.cassandra.db.partitions.Partition
Returns an UnfilteredRowIterator over the rows/RT contained by this partition selected by the provided slices.
unfilteredIterator(ColumnFilter, NavigableSet<Clustering<?>>, boolean) - Method in interface org.apache.cassandra.db.partitions.Partition
Returns an UnfilteredRowIterator over the rows/RT contained by this partition selected by the provided clusterings.
unfilteredPartition(TableMetadata) - Static method in class org.apache.cassandra.db.EmptyIterators
 
UnfilteredPartitionIterator - Interface in org.apache.cassandra.db.partitions
An iterator over a number of unfiltered partitions (i.e.
UnfilteredPartitionIterators - Class in org.apache.cassandra.db.partitions
Static methods to work with partition iterators.
UnfilteredPartitionIterators.MergeListener - Interface in org.apache.cassandra.db.partitions
 
UnfilteredPartitionIterators.Serializer - Class in org.apache.cassandra.db.partitions
Serialize each UnfilteredSerializer one after the other, with an initial byte that indicates whether we're done or not.
unfilteredRow(TableMetadata, DecoratedKey, boolean, Row, DeletionTime) - Static method in class org.apache.cassandra.db.EmptyIterators
 
unfilteredRow(TableMetadata, DecoratedKey, boolean) - Static method in class org.apache.cassandra.db.EmptyIterators
 
UnfilteredRowIterator - Interface in org.apache.cassandra.db.rows
An iterator over the rows of a given partition that also includes deletion informations.
UnfilteredRowIterators - Class in org.apache.cassandra.db.rows
Static methods to work with atom iterators.
UnfilteredRowIterators.MergeListener - Interface in org.apache.cassandra.db.rows
Interface for a listener interested in the result of merging multiple versions of a given row.
UnfilteredRowIteratorSerializer - Class in org.apache.cassandra.db.rows
Serialize/Deserialize an unfiltered row iterator.
UnfilteredRowIteratorSerializer() - Constructor for class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
 
UnfilteredRowIteratorSerializer.Header - Class in org.apache.cassandra.db.rows
 
UnfilteredRowIteratorWithLowerBound - Class in org.apache.cassandra.db.rows
An unfiltered row iterator with a lower bound retrieved from either the global sstable statistics or the row index lower bounds (if available in the cache).
UnfilteredRowIteratorWithLowerBound(DecoratedKey, SSTableReader, ClusteringIndexFilter, ColumnFilter, SSTableReadsListener) - Constructor for class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
 
UnfilteredSerializer - Class in org.apache.cassandra.db.rows
Serialize/deserialize a single Unfiltered (both on-wire and on-disk).
UnfilteredSerializer() - Constructor for class org.apache.cassandra.db.rows.UnfilteredSerializer
 
UnfilteredValidation - Class in org.apache.cassandra.db
Handles unfiltered validation - if configured, it checks if the provided unfiltered has invalid deletions (if the local deletion time is negative or if the ttl is negative) and then either logs or throws an exception if so.
UnfilteredValidation() - Constructor for class org.apache.cassandra.db.UnfilteredValidation
 
unfinishedCommit - Variable in class org.apache.cassandra.metrics.CASClientRequestMetrics
 
union(OnDiskIndex...) - Static method in class org.apache.cassandra.index.sasi.utils.OnDiskIndexIterator
 
UniqueIdentifier() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader.UniqueIdentifier
 
UNIT - Static variable in class org.apache.cassandra.db.compaction.CompactionInfo
 
unixTimestamp(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
 
unixTimestampInSec(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
 
unixTimestampOfFct - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
Deprecated.
Replaced by the #timeUuidToUnixTimestamp function
UNKNOWN_RELEASE_VERSION - Static variable in class org.apache.cassandra.utils.FBUtilities
 
UnknownColumnException - Exception in org.apache.cassandra.exceptions
 
UnknownColumnException(String) - Constructor for exception org.apache.cassandra.exceptions.UnknownColumnException
 
UnknownIndexException - Exception in org.apache.cassandra.exceptions
Exception thrown when we read an index id from a serialized ReadCommand and no corresponding IndexMetadata can be found in the TableMetadata#indexes collection.
UnknownIndexException(TableMetadata, UUID) - Constructor for exception org.apache.cassandra.exceptions.UnknownIndexException
 
unknownResult - Variable in class org.apache.cassandra.metrics.CASClientRequestMetrics
 
UnknownTableException - Exception in org.apache.cassandra.exceptions
 
UnknownTableException(String, TableId) - Constructor for exception org.apache.cassandra.exceptions.UnknownTableException
 
unleveledSSTables - Variable in class org.apache.cassandra.metrics.TableMetrics
 
unlogged_batch_across_partitions_warn_threshold - Variable in class org.apache.cassandra.config.Config
 
unmarkSuspect() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
 
unpauseConnection() - Method in class org.apache.cassandra.metrics.ClientMetrics
 
UNREACHABLE - Static variable in class org.apache.cassandra.service.StorageProxy
 
UNREADABLE_VERSION - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
UnrecoverableIllegalStateException - Exception in org.apache.cassandra.exceptions
 
UnrecoverableIllegalStateException(String) - Constructor for exception org.apache.cassandra.exceptions.UnrecoverableIllegalStateException
 
unreference() - Method in class org.apache.cassandra.cache.RefCountedMemory
decrement reference count.
unregister(IEndpointStateChangeSubscriber) - Method in class org.apache.cassandra.gms.Gossiper
Unregister interest for state changes.
unregister(INotificationConsumer) - Method in class org.apache.cassandra.service.SSTablesGlobalTracker
Unregister a subscriber from this tracker.
unregister(IEndpointLifecycleSubscriber) - Method in class org.apache.cassandra.service.StorageService
 
unregisterFailureDetectionEventListener(IFailureDetectionEventListener) - Method in class org.apache.cassandra.gms.FailureDetector
 
unregisterFailureDetectionEventListener(IFailureDetectionEventListener) - Method in interface org.apache.cassandra.gms.IFailureDetector
Un-register interest for Failure Detector events.
unregisterIndex(Index) - Method in interface org.apache.cassandra.index.IndexRegistry
 
unregisterIndex(Index) - Method in class org.apache.cassandra.index.SecondaryIndexManager
 
unregisterListener(AuthEvents.Listener) - Method in class org.apache.cassandra.auth.AuthEvents
 
unregisterListener(QueryEvents.Listener) - Method in class org.apache.cassandra.cql3.QueryEvents
 
unregisterListener(LocalSessions.Listener) - Static method in class org.apache.cassandra.repair.consistent.LocalSessions
 
unregisterListener(SchemaChangeListener) - Method in class org.apache.cassandra.schema.Schema
 
unregisterMBean() - Method in class org.apache.cassandra.auth.AuthCache
 
unregisterMBean(ObjectName, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.NoOpMBeanWrapper
 
unregisterMBean(String, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.NoOpMBeanWrapper
 
unregisterMBean(ObjectName, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.PlatformMBeanWrapper
 
unregisterMBean(ObjectName, MBeanWrapper.OnException) - Method in interface org.apache.cassandra.utils.MBeanWrapper
 
unregisterMBean(ObjectName) - Method in interface org.apache.cassandra.utils.MBeanWrapper
 
unregisterMBean(String, MBeanWrapper.OnException) - Method in interface org.apache.cassandra.utils.MBeanWrapper
 
unregisterMBean(String) - Method in interface org.apache.cassandra.utils.MBeanWrapper
 
UNREPAIRED_SSTABLE - Static variable in class org.apache.cassandra.service.ActiveRepairService
 
UNSAFE_AGGRESSIVE_SSTABLE_EXPIRATION_KEY - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
unsafeAssassinateEndpoint(String) - Method in class org.apache.cassandra.gms.Gossiper
 
unsafeAssassinateEndpoint(String) - Method in interface org.apache.cassandra.gms.GossiperMBean
 
unsafeAvailable() - Method in class org.apache.cassandra.net.AsyncStreamingInputPlus
As long as this method is invoked on the consuming thread the returned value will be accurate.
unsafeClear() - Method in class org.apache.cassandra.net.RequestCallbacks
 
unsafeInitialize() - Method in class org.apache.cassandra.service.StorageService
 
unsafeMakeVersionedValue(String, int) - Static method in class org.apache.cassandra.gms.VersionedValue
 
UnsafeOperations() - Constructor for class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
 
unsafeReset() - Method in class org.apache.cassandra.utils.memory.BufferPool
This is not thread safe and should only be used for unit testing.
unsafeSetCodec(Message.Codec<?>) - Method in enum org.apache.cassandra.transport.Message.Type
 
unsafeSetSerializer(Supplier<? extends IVersionedAsymmetricSerializer<?, ?>>) - Method in enum org.apache.cassandra.net.Verb
 
UNSET_BYTE_BUFFER - Static variable in class org.apache.cassandra.utils.ByteBufferUtil
Represents an unset value in bound variables
UNSET_LIST - Static variable in interface org.apache.cassandra.cql3.Terms
The List returned when the list was not set.
UNSET_LITERAL - Static variable in class org.apache.cassandra.cql3.Constants
 
UNSET_VALUE - Static variable in class org.apache.cassandra.cql3.Constants
 
UNSET_VALUE - Static variable in class org.apache.cassandra.io.sstable.CQLSSTableWriter
 
unsharedHeapSize() - Method in class org.apache.cassandra.cache.CounterCacheKey
 
unsharedHeapSize() - Method in interface org.apache.cassandra.cache.IMeasurableMemory
 
unsharedHeapSize() - Method in class org.apache.cassandra.cache.KeyCacheKey
 
unsharedHeapSize() - Method in class org.apache.cassandra.cache.RowCacheKey
 
unsharedHeapSize() - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.ArrayClustering
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.ArrayClusteringBound
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.ArrayClusteringBoundary
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.BufferClustering
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.BufferClusteringBound
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.BufferClusteringBoundary
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.ClockAndCount
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.Columns
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.DeletionTime
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.LivenessInfo
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.MutableDeletionInfo
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.NativeClustering
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.RangeTombstoneList
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.RegularAndStaticColumns
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.RowIndexEntry
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.rows.EncodingStats
 
unsharedHeapSize() - Method in class org.apache.cassandra.db.rows.Row.Deletion
 
unsharedHeapSize() - Method in class org.apache.cassandra.io.sstable.IndexInfo
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.cql3.ColumnIdentifier
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.ArrayClustering
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.BufferClustering
 
unsharedHeapSizeExcludingData() - Method in interface org.apache.cassandra.db.Clustering
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.NativeClustering
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.rows.ArrayCell
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.rows.BTreeRow
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.rows.BufferCell
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.rows.CellPath
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.rows.ColumnData
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
unsharedHeapSizeExcludingData() - Method in class org.apache.cassandra.db.rows.NativeCell
 
unsharedHeapSizeExcludingData() - Method in interface org.apache.cassandra.db.rows.Row
 
unsortedBuilder() - Static method in class org.apache.cassandra.db.rows.BTreeRow
 
unsubscribe(INotificationConsumer) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
unsubscribe(Consumer<E>) - Method in class org.apache.cassandra.diag.DiagnosticEventService
De-registers event handler from receiving any further events.
unsubscribe(Class<E>, Consumer<E>) - Method in class org.apache.cassandra.diag.DiagnosticEventService
De-registers event handler from receiving any further events.
unsuccessful - Variable in class org.apache.cassandra.repair.consistent.admin.CleanupSummary
 
UNSUPPORTED - Static variable in enum org.apache.cassandra.transport.ProtocolVersion
Old unsupported versions, this is OK as long as we never add newer unsupported versions
UnsupportedMessageCodec<T extends Message> - Class in org.apache.cassandra.transport.messages
Catch-all codec for any unsupported legacy messages.
UnsupportedMessageCodec() - Constructor for class org.apache.cassandra.transport.messages.UnsupportedMessageCodec
 
untrackNew(SSTable) - Method in interface org.apache.cassandra.db.lifecycle.LifecycleNewTracker
Called when a new table is no longer required, so that this table can be untracked by a transaction.
untrackNew(SSTable) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
untrackNew(SSTable) - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
 
UntypedResultSet - Class in org.apache.cassandra.cql3
a utility for doing internal cql-based queries
UntypedResultSet() - Constructor for class org.apache.cassandra.cql3.UntypedResultSet
 
UntypedResultSet.Row - Class in org.apache.cassandra.cql3
 
unvoid() - Method in class org.apache.cassandra.net.AsyncChannelPromise
 
unwrap() - Method in class org.apache.cassandra.dht.AbstractBounds
 
unwrap() - Method in class org.apache.cassandra.dht.Bounds
 
unwrap() - Method in class org.apache.cassandra.dht.ExcludingBounds
 
unwrap() - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
unwrap() - Method in class org.apache.cassandra.dht.Range
 
unwrap() - Method in class org.apache.cassandra.locator.RangesAtEndpoint
 
unwrapped(Throwable) - Static method in class org.apache.cassandra.utils.Throwables
If the provided throwable is a "wrapping" exception (see below), return the cause of that throwable, otherwise return its argument untouched.
update(byte[], int, int) - Method in class org.apache.cassandra.db.Digest
 
update(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.Digest
 
update(ByteBuffer) - Method in class org.apache.cassandra.db.Digest
Update the digest with the bytes from the supplied buffer.
update(ByteBuffer, int, int) - Method in class org.apache.cassandra.db.Digest
Update the digest with the bytes sliced from the supplied buffer.
update(SSTableReader, boolean) - Method in interface org.apache.cassandra.db.lifecycle.ILifecycleTransaction
 
update(Collection<SSTableReader>, boolean) - Method in interface org.apache.cassandra.db.lifecycle.ILifecycleTransaction
 
update(SSTableReader, boolean) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
update a reader: if !original, this is a reader that is being introduced by this transaction; otherwise it must be in the originals() set, i.e.
update(Collection<SSTableReader>, boolean) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
 
update(SSTableReader, boolean) - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
 
update(Collection<SSTableReader>, boolean) - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
 
update(TableMetadata) - Method in interface org.apache.cassandra.db.Mutation.SimpleBuilder
Adds an update for table identified by the provided metadata and return a builder for that partition.
update(String) - Method in interface org.apache.cassandra.db.Mutation.SimpleBuilder
Adds an update for table identified by the provided name and return a builder for that partition.
update(LivenessInfo) - Method in interface org.apache.cassandra.db.partitions.PartitionStatisticsCollector
 
update(DeletionTime) - Method in interface org.apache.cassandra.db.partitions.PartitionStatisticsCollector
 
update(Cell<?>) - Method in interface org.apache.cassandra.db.partitions.PartitionStatisticsCollector
 
update(LivenessInfo) - Method in class org.apache.cassandra.db.rows.EncodingStats.Collector
 
update(Cell<?>) - Method in class org.apache.cassandra.db.rows.EncodingStats.Collector
 
update(DeletionTime) - Method in class org.apache.cassandra.db.rows.EncodingStats.Collector
 
update(TableMetadata) - Method in class org.apache.cassandra.db.SimpleBuilders.MutationBuilder
 
update(String) - Method in class org.apache.cassandra.db.SimpleBuilders.MutationBuilder
 
update(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
 
update(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.index.sasi.conf.DataTracker
Replaces old SSTables with new by creating new immutable tracker.
update(RangeIterator<K, D>) - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
Update statistics information with the given range.
update(int) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxIntTracker
 
update(long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector.MinMaxLongTracker
 
update(LivenessInfo) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
update(Cell<?>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
update(DeletionTime) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
update(long) - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
Increments the count of the bucket closest to n, rounding UP.
update(long) - Method in class org.apache.cassandra.metrics.TableMetrics.TableHistogram
 
update(long, TimeUnit) - Method in class org.apache.cassandra.metrics.TableMetrics.TableTimer
 
update - Variable in class org.apache.cassandra.service.paxos.Commit
 
update() - Method in class org.apache.cassandra.service.PendingRangeCalculatorService
 
update(Object[], Comparator<C>, Collection<K>, UpdateFunction<K, V>) - Static method in class org.apache.cassandra.utils.btree.BTree
 
update(Object[], Comparator<C>, Iterable<K>, int, UpdateFunction<K, V>) - Static method in class org.apache.cassandra.utils.btree.BTree
Returns a new BTree with the provided collection inserting/replacing as necessary any equal items
update(Collection<V>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
 
update(Checksum, ByteBuffer) - Method in enum org.apache.cassandra.utils.ChecksumType
 
update(I) - Method in class org.apache.cassandra.utils.OverlapIterator
 
update(int) - Method in class org.apache.cassandra.utils.SlidingTimeRate
Updates the rate.
update(int) - Method in class org.apache.cassandra.utils.streamhist.StreamingTombstoneHistogramBuilder
Adds new point to this histogram with a default value of 1.
update(int, int) - Method in class org.apache.cassandra.utils.streamhist.StreamingTombstoneHistogramBuilder
Adds new point with value to this histogram.
updateAllTimestamp(long) - Method in class org.apache.cassandra.db.MutableDeletionInfo
 
updateAllTimestamp(long) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
Modify this update to set every timestamp for live data to newTimestamp and every deletion timestamp to newTimestamp - 1.
updateAllTimestamp(long) - Method in class org.apache.cassandra.db.RangeTombstoneList
 
updateAllTimestamp(long) - Method in class org.apache.cassandra.db.rows.AbstractCell
 
updateAllTimestamp(long) - Method in class org.apache.cassandra.db.rows.BTreeRow
Returns a copy of the row where all timestamps for live data have replaced by newTimestamp and all deletion timestamp by newTimestamp - 1.
updateAllTimestamp(long) - Method in class org.apache.cassandra.db.rows.ColumnData
Returns a copy of the data where all timestamps for live data have replaced by newTimestamp and all deletion timestamp by newTimestamp - 1.
updateAllTimestamp(long) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
updateAllTimestamp(long) - Method in interface org.apache.cassandra.db.rows.Row
Returns a copy of this row where all live timestamp have been replaced by newTimestamp and every deletion timestamp by newTimestamp - 1.
updateAvailableRanges(String, Collection<Range<Token>>, Collection<Range<Token>>) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
updateBlock() - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.IndexState
 
updateBucket(AtomicLongArray, int, long) - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
 
updateCDCTotalSize() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerCDC
Only use for testing / validation that size tracker is working.
updateChecksum(CRC32, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.FBUtilities
Updates checksum with the provided ByteBuffer at the given offset + length.
updateChecksum(CRC32, ByteBuffer) - Static method in class org.apache.cassandra.utils.FBUtilities
Updates checksum with the provided ByteBuffer.
updateChecksumInt(Checksum, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
updateClusteringValues(ClusteringPrefix<?>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
updateColumnSetPerRow(long) - Method in interface org.apache.cassandra.db.partitions.PartitionStatisticsCollector
 
updateColumnSetPerRow(long) - Method in class org.apache.cassandra.db.rows.EncodingStats.Collector
 
updateColumnSetPerRow(long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
updateCompactionHistory(String, String, long[], long, long) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
 
updateCompactionHistory(String, String, long, long, long, Map<Integer, Long>) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
updatedColumns() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
updatedColumns - Variable in class org.apache.cassandra.cql3.UpdateParameters
 
updateDefinition(ViewMetadata) - Method in class org.apache.cassandra.db.view.View
This updates the columns stored which are dependent on the base TableMetadata.
updateDelayMetrics(InetAddressAndPort, long) - Static method in class org.apache.cassandra.metrics.HintsServiceMetrics
 
updatedViews(PartitionUpdate) - Method in class org.apache.cassandra.db.view.TableViews
Return the views that are potentially updated by the provided updates.
UpdateFunction<K,V> - Interface in org.apache.cassandra.utils.btree
An interface defining a function to be applied to both the object we are replacing in a BTree and the object that is intended to replace it, returning the object to actually replace it.
UpdateFunction.Simple<V> - Class in org.apache.cassandra.utils.btree
 
updateHasLegacyCounterShards(boolean) - Method in interface org.apache.cassandra.db.partitions.PartitionStatisticsCollector
 
updateHasLegacyCounterShards(boolean) - Method in class org.apache.cassandra.db.rows.EncodingStats.Collector
 
updateHasLegacyCounterShards(boolean) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
 
updateHintsDropped(InetAddressAndPort, UUID, int) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
updateHostId(UUID, InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
Store an end-point to host ID mapping.
updateIndexTableMetadata(TableParams) - Method in class org.apache.cassandra.schema.TableMetadata
 
updateInitialSSTableSize(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
 
updateLocalDeletionTime(int) - Method in class org.apache.cassandra.db.rows.EncodingStats.Collector
 
updateNativeProtocolEncryptionOptions(Function<EncryptionOptions, EncryptionOptions>) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
updateNormalToken(Token, InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
Update token map with a single token/endpoint pair in normal state.
updateNormalTokens(Collection<Token>, InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
 
updateNormalTokens(Multimap<InetAddressAndPort, Token>) - Method in class org.apache.cassandra.locator.TokenMetadata
Update token map with a set of token/endpoint pairs in normal state.
updateOpenMarker(RangeTombstoneMarker) - Method in class org.apache.cassandra.db.columniterator.AbstractSSTableIterator.Reader
 
updatePagerLimit(QueryPager, DataLimits, ByteBuffer, Clustering<?>) - Method in class org.apache.cassandra.service.pager.AggregationQueryPager.AggregationPartitionIterator
 
updatePagerLimit(QueryPager, DataLimits, ByteBuffer, Clustering<?>) - Method in class org.apache.cassandra.service.pager.AggregationQueryPager.GroupByPartitionIterator
Updates the pager with the new limits if needed.
UpdateParameters - Class in org.apache.cassandra.cql3
Groups the parameters of an update query, and make building updates easier.
UpdateParameters(TableMetadata, RegularAndStaticColumns, QueryOptions, long, int, int, Map<DecoratedKey, Partition>) - Constructor for class org.apache.cassandra.cql3.UpdateParameters
 
updatePeerInfo(InetAddressAndPort, String, Object) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
updatePeerNativeAddress(InetAddressAndPort, InetAddressAndPort) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
updatePreferredIP(InetAddressAndPort, InetAddressAndPort) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
updateProgress() - Method in class org.apache.cassandra.db.partitions.PurgeFunction
 
updateProgress(ProgressInfo) - Method in class org.apache.cassandra.streaming.SessionInfo
Update progress of receiving/sending stream.
updateProgress(ProgressInfo) - Method in class org.apache.cassandra.streaming.StreamCoordinator
 
updateRow(Row, Row) - Method in interface org.apache.cassandra.index.Index.Indexer
Notification of a modification to a row in the base table's Memtable.
updatesAffectView(Collection<? extends IMutation>, boolean) - Method in class org.apache.cassandra.db.view.ViewManager
 
updateSchemaVersion(UUID) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
UpdatesCollector - Interface in org.apache.cassandra.cql3.statements
 
updateSizeEstimates(String, String, Map<Range<Token>, Pair<Long, Long>>) - Static method in class org.apache.cassandra.db.SystemKeyspace
Writes the current partition count and size estimates into SIZE_ESTIMATES_CF
updateSnitch(String, Boolean, Integer, Integer, Double) - Method in class org.apache.cassandra.service.StorageService
 
updateSnitch(String, Boolean, Integer, Integer, Double) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Change endpointsnitch class and dynamic-ness (and dynamic attributes) at runtime.
updateSpeculationThreshold() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
updatesRegularRows() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
updateSSTableIterated(int) - Method in class org.apache.cassandra.metrics.TableMetrics
 
updatesStaticRow() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
UpdateStatement - Class in org.apache.cassandra.cql3.statements
An UPDATE statement parsed from a CQL query statement.
UpdateStatement.ParsedInsert - Class in org.apache.cassandra.cql3.statements
 
UpdateStatement.ParsedInsertJson - Class in org.apache.cassandra.cql3.statements
A parsed INSERT JSON statement.
UpdateStatement.ParsedUpdate - Class in org.apache.cassandra.cql3.statements
 
updateTableEstimates(String, String, String, Map<Range<Token>, Pair<Long, Long>>) - Static method in class org.apache.cassandra.db.SystemKeyspace
Writes the current partition count and size estimates into table_estimates
updateTimestamp(long) - Method in class org.apache.cassandra.db.rows.EncodingStats.Collector
 
updateTokenRange(long) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
 
updateTokens(InetAddressAndPort, Collection<Token>) - Static method in class org.apache.cassandra.db.SystemKeyspace
Record tokens being used by another node
updateTokens(Collection<Token>) - Static method in class org.apache.cassandra.db.SystemKeyspace
This method is used to update the System Keyspace with the new tokens for this node
updateTopology(InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
This is called when the snitch properties for this endpoint are updated, see CASSANDRA-10238.
updateTopology() - Method in class org.apache.cassandra.locator.TokenMetadata
This is called when the snitch properties for many endpoints are updated, it will update the topology mappings of any endpoints whose snitch has changed, see CASSANDRA-10238.
updateTopology(InetAddressAndPort) - Method in class org.apache.cassandra.service.StorageService
 
updateTopology() - Method in class org.apache.cassandra.service.StorageService
 
UpdateTransaction - Interface in org.apache.cassandra.index.transactions
Handling of index updates on the write path.
updateTransferredRanges(StreamOperation, InetAddressAndPort, String, Collection<Range<Token>>) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
updateTTL(int) - Method in class org.apache.cassandra.db.rows.EncodingStats.Collector
 
updateVersion() - Method in class org.apache.cassandra.schema.Schema
Read schema from system keyspace and calculate MD5 digest of every row, resulting digest will be converted into UUID which would act as content-based version of the schema.
updateVersionAndAnnounce() - Method in class org.apache.cassandra.schema.Schema
 
updateViewBuildStatus(String, String, Range<Token>, Token, long) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
updateWithBoolean(boolean) - Method in class org.apache.cassandra.db.Digest
 
updateWithByte(int) - Method in class org.apache.cassandra.db.Digest
 
updateWithCounterContext(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.Digest
Update the digest with the content of a counter context.
updateWithInt(int) - Method in class org.apache.cassandra.db.Digest
 
updateWithLong(long) - Method in class org.apache.cassandra.db.Digest
 
updateWithLong(Hasher, long) - Static method in class org.apache.cassandra.utils.UUIDGen
 
upgrade(boolean) - Method in class org.apache.cassandra.db.compaction.Upgrader
 
upgradeInput(ChecksummedDataInput, ICompressor) - Static method in class org.apache.cassandra.hints.CompressedChecksummedDataInput
 
upgradeInput(ChecksummedDataInput, Cipher, ICompressor) - Static method in class org.apache.cassandra.hints.EncryptedChecksummedDataInput
 
Upgrader - Class in org.apache.cassandra.db.compaction
 
Upgrader(ColumnFamilyStore, LifecycleTransaction, OutputHandler) - Constructor for class org.apache.cassandra.db.compaction.Upgrader
 
UpgradeSSTable - Class in org.apache.cassandra.tools.nodetool
 
UpgradeSSTable() - Constructor for class org.apache.cassandra.tools.nodetool.UpgradeSSTable
 
upgradeSSTables(String, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
 
upgradeSSTables(String, boolean, int, String...) - Method in class org.apache.cassandra.service.StorageService
 
upgradeSSTables(String, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Deprecated.
upgradeSSTables(String, boolean, int, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
upgradeSSTables(String, boolean, int, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
upgradeSSTables(PrintStream, String, boolean, int, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
upper - Variable in class org.apache.cassandra.index.sasi.plan.Expression
 
upper() - Method in class org.apache.cassandra.utils.IntegerInterval
 
upperBound() - Method in class org.apache.cassandra.db.commitlog.IntervalSet
 
upperBound - Variable in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
 
upperBound() - Method in class org.apache.cassandra.utils.IntegerInterval.Set
Returns an upper bound for the whole set.
UpperCase(Locale) - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.BasicResultFilters.UpperCase
 
UpperCase() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.BasicResultFilters.UpperCase
 
upperCaseOutput(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions.OptionsBuilder
 
upperPosition - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader.IndexesBounds
 
upperPosition - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader.PartitionPositionBounds
 
urgent - Variable in class org.apache.cassandra.net.OutboundConnections
 
urgentMessageCompletedBytes - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Completed bytes for urgent message TCP Connections
urgentMessageCompletedTasks - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Completed tasks for urgent message TCP Connections
urgentMessageDroppedBytesDueToError - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped bytes because of error for urgent message TCP Connections
urgentMessageDroppedBytesDueToOverload - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped bytes because of overload for urgent message TCP Connections
urgentMessageDroppedBytesDueToTimeout - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped bytes because of timeout for urgent message TCP Connections
urgentMessageDroppedTasks - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped tasks for urgent message TCP Connections
urgentMessageDroppedTasksDueToError - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped tasks because of error for urgent message TCP Connections
urgentMessageDroppedTasksDueToOverload - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped tasks because of overload for urgent message TCP Connections
urgentMessageDroppedTasksDueToTimeout - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Dropped tasks because of timeout for urgent message TCP Connections
urgentMessagePendingBytes - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Pending bytes for urgent message TCP Connections
urgentMessagePendingTasks - Variable in class org.apache.cassandra.metrics.InternodeOutboundMetrics
Pending tasks for small message TCP Connections
USAGE_WARNING - Static variable in class org.apache.cassandra.db.view.View
 
USAGE_WARNING - Static variable in class org.apache.cassandra.index.sasi.SASIIndex
 
USE_HEAP_ALLOCATOR - Static variable in class org.apache.cassandra.transport.CBUtil
 
use_offheap_merkle_trees - Variable in class org.apache.cassandra.config.Config
 
useBeta() - Method in class org.apache.cassandra.transport.SimpleClient.Builder
 
useCompression() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
Checks if the segments must be compressed.
used() - Method in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
 
usedRatio() - Method in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
 
usedSize - Variable in class org.apache.cassandra.metrics.BufferPoolMetrics
Total size, in bytes, of active buffered being used from the pool currently + overflow
usedSizeInBytes() - Method in class org.apache.cassandra.net.BufferPoolAllocator
 
usedSizeInBytes() - Method in class org.apache.cassandra.utils.memory.BufferPool
 
useEncryption() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
Checks if the segments must be encrypted.
useEpoll() - Static method in class org.apache.cassandra.service.NativeTransportService
 
useLocale(Locale) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
 
useLock() - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
 
useNativeTransportLegacyFlusher() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
useOffheapMerkleTrees() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
useOffheapMerkleTrees(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
user - Variable in class org.apache.cassandra.tools.LoaderOptions
 
USER - Static variable in class org.apache.cassandra.transport.ConnectedClient
 
user_defined_function_fail_timeout - Variable in class org.apache.cassandra.config.Config
Time in milliseconds after a fatal UDF run-time situation is detected and action according to user_function_timeout_policy will take place.
user_defined_function_warn_timeout - Variable in class org.apache.cassandra.config.Config
Time in milliseconds after a warning will be emitted to the log and to the client that a UDF runs too long.
user_function_timeout_policy - Variable in class org.apache.cassandra.config.Config
Defines what to do when a UDF ran longer than user_defined_function_fail_timeout.
USER_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
UserExpression(ColumnMetadata, Operator, ByteBuffer) - Constructor for class org.apache.cassandra.db.filter.RowFilter.UserExpression
 
userFunctionTimeout(Throwable) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
 
username - Variable in class org.apache.cassandra.tools.AbstractJmxClient
 
username() - Method in class org.apache.cassandra.transport.ConnectedClient
 
USERNAME_KEY - Static variable in class org.apache.cassandra.auth.PasswordAuthenticator
 
userType(UTName) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
 
userType(UserType) - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return a newly-created codec for the given user-defined CQL type.
UserType - Class in org.apache.cassandra.cql3.functions.types
A User Defined Type (UDT).
UserType - Class in org.apache.cassandra.db.marshal
A user defined type.
UserType(String, ByteBuffer, List<FieldIdentifier>, List<AbstractType<?>>, boolean) - Constructor for class org.apache.cassandra.db.marshal.UserType
 
UserType.Field - Class in org.apache.cassandra.cql3.functions.types
A UDT field.
UserTypes - Class in org.apache.cassandra.cql3
Static helper methods and classes for user types.
UserTypes.DelayedValue - Class in org.apache.cassandra.cql3
 
UserTypes.DeleterByField - Class in org.apache.cassandra.cql3
 
UserTypes.Literal - Class in org.apache.cassandra.cql3
 
UserTypes.Marker - Class in org.apache.cassandra.cql3
 
UserTypes.Setter - Class in org.apache.cassandra.cql3
 
UserTypes.SetterByField - Class in org.apache.cassandra.cql3
 
UserTypes.Value - Class in org.apache.cassandra.cql3
 
UserTypeSerializer - Class in org.apache.cassandra.serializers
 
UserTypeSerializer(LinkedHashMap<String, TypeSerializer<?>>) - Constructor for class org.apache.cassandra.serializers.UserTypeSerializer
 
userTypeToString(Map<FieldIdentifier, T>) - Static method in class org.apache.cassandra.cql3.UserTypes
Create a String representation of the user type from the specified items associated to the user type entries.
userTypeToString(Map<FieldIdentifier, T>, Function<T, String>) - Static method in class org.apache.cassandra.cql3.UserTypes
Create a String representation of the user type from the specified items associated to the user type entries.
useSameMessageID(long) - Method in class org.apache.cassandra.net.ForwardingInfo
 
useSpecificLocationForLocalSystemData() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
Checks if the local system data must be stored in a specific location which supports redundancy.
usesSecondaryIndexing() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
Checks if the secondary index need to be queried.
UseStatement - Class in org.apache.cassandra.cql3.statements
 
UseStatement(String) - Constructor for class org.apache.cassandra.cql3.statements.UseStatement
 
useStrictConsistency - Static variable in class org.apache.cassandra.service.StorageService
 
using(String) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
The INSERT or UPDATE statement defining the order of the values to add for a given CQL row.
using() - Method in class org.apache.cassandra.net.ResourceLimits.Basic
 
using() - Method in class org.apache.cassandra.net.ResourceLimits.Concurrent
 
using() - Method in interface org.apache.cassandra.net.ResourceLimits.Limit
 
usingCapacity() - Method in class org.apache.cassandra.net.InboundMessageHandlers
 
usingEndpointReserveCapacity() - Method in class org.apache.cassandra.net.InboundMessageHandlers
 
usingReserveBytes() - Method in class org.apache.cassandra.net.OutboundConnections
 
UTF8Serializer - Class in org.apache.cassandra.serializers
 
UTF8Type - Class in org.apache.cassandra.db.marshal
 
Util - Class in org.apache.cassandra.tools
 
Util.TermHistogram - Class in org.apache.cassandra.tools
 
UTName - Class in org.apache.cassandra.cql3
 
UTName(ColumnIdentifier, ColumnIdentifier) - Constructor for class org.apache.cassandra.cql3.UTName
 
uuid(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
 
uuid() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the UUID type.
uuid() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type uuid.
UUID_LEN - Static variable in class org.apache.cassandra.utils.UUIDGen
 
UUID_SIZE - Static variable in class org.apache.cassandra.db.TypeSizes
 
uuidFct - Static variable in class org.apache.cassandra.cql3.functions.UuidFcts
 
UuidFcts - Class in org.apache.cassandra.cql3.functions
 
UuidFcts() - Constructor for class org.apache.cassandra.cql3.functions.UuidFcts
 
UUIDGen - Class in org.apache.cassandra.utils
The goods are here: www.ietf.org/rfc/rfc4122.txt.
UUIDSerializer - Class in org.apache.cassandra.serializers
 
UUIDSerializer() - Constructor for class org.apache.cassandra.serializers.UUIDSerializer
 
UUIDSerializer - Class in org.apache.cassandra.utils
 
UUIDSerializer() - Constructor for class org.apache.cassandra.utils.UUIDSerializer
 
UUIDType - Class in org.apache.cassandra.db.marshal
Compares UUIDs using the following criteria:
- if count of supplied bytes is less than 16, compare counts
- compare UUID version fields
- nil UUID is always lesser
- compare timestamps if both are time-based
- compare lexically, unsigned msb-to-lsb comparison

V

validate() - Method in class org.apache.cassandra.auth.DCPermissions
 
validate() - Method in class org.apache.cassandra.auth.RoleOptions
Validate the contents of the options in two ways: - Ensure that only a subset of the options supported by the configured IRoleManager are set - Validate the type of any option values present.
validate(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.AlterRoleStatement
 
validate() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateRoleStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DescribeStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropRoleStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListPermissionsStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ListRolesStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
 
validate(Set<String>, Set<String>) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
 
validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.RoleManagementStatement
 
validate() - Method in class org.apache.cassandra.cql3.statements.schema.IndexAttributes
 
validate() - Method in class org.apache.cassandra.cql3.statements.schema.KeyspaceAttributes
 
validate() - Method in class org.apache.cassandra.cql3.statements.schema.TableAttributes
 
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(ClusteringPrefix<T>) - Method in class org.apache.cassandra.db.ClusteringComparator
Validates the provided prefix for corrupted data.
validate(int, ClusteringComparator) - Method in interface org.apache.cassandra.db.ClusteringPrefix
 
validate(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.Verifier.RangeOwnHelper
check if the given key is contained in any of the given ranges Must be called in sorted order - key should be increasing
validate() - Method in class org.apache.cassandra.db.DeletionTime
check if this deletion time is valid - localDeletionTime can never be negative
validate() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
 
validate() - Method in class org.apache.cassandra.db.LivenessInfo
Validate the data contained by this liveness information.
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
 
validate() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
Validates the data contained in this update.
validate() - Method in class org.apache.cassandra.db.rows.AbstractCell
 
validate() - Method in class org.apache.cassandra.db.rows.ColumnData
Validate the column data.
validate() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
validate(UnfilteredPartitionIterator, RTBoundValidator.Stage, boolean) - Static method in class org.apache.cassandra.db.transform.RTBoundValidator
 
validate(UnfilteredRowIterator, RTBoundValidator.Stage, boolean) - Static method in class org.apache.cassandra.db.transform.RTBoundValidator
 
validate(Collection<? extends AbstractBounds<?>>) - Static method in interface org.apache.cassandra.dht.IPartitioner
 
validate(AbstractBounds<?>) - Static method in interface org.apache.cassandra.dht.IPartitioner
 
validate(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
validate(PartitionUpdate) - Method in interface org.apache.cassandra.index.Index
Called at write time to ensure that values present in the update are valid according to the rules of all registered indexes which will process it.
validate(ReadCommand) - Method in interface org.apache.cassandra.index.Index
Used to validate the various parameters of a supplied ReadCommand, this is called prior to execution.
validate(PartitionUpdate) - Method in interface org.apache.cassandra.index.IndexRegistry
Called at write time to ensure that values present in the update are valid according to the rules of all registered indexes which will process it.
validate(ReadCommand) - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
validate(PartitionUpdate) - Method in class org.apache.cassandra.index.internal.CassandraIndex
 
validate(Map<String, String>, ColumnMetadata) - Method in class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
 
validate(Map<String, String>, ColumnMetadata) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingAnalyzer
 
validate(PartitionUpdate) - Method in class org.apache.cassandra.index.sasi.SASIIndex
 
validate(PartitionUpdate) - Method in class org.apache.cassandra.index.SecondaryIndexManager
Called at write time to ensure that values present in the update are valid according to the rules of all registered indexes which will process it.
validate(String) - Static method in enum org.apache.cassandra.io.sstable.format.SSTableFormat.Type
 
validate(String) - Static method in class org.apache.cassandra.io.sstable.format.Version
 
validate(byte[], int, int) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
 
validate(ByteBuffer) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
validates the checksum with the bytes from the specified buffer.
validate() - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.FileDigestValidator
 
validate(Set<String>, Set<String>) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
validate(Set<String>, Set<String>) - Method in class org.apache.cassandra.locator.Ec2Snitch
 
validate(Set<String>, Set<String>) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
Determine if the datacenter or rack values in the current node's snitch conflict with those passed in parameters.
validate() - Method in class org.apache.cassandra.schema.CompactionParams
 
validate() - Method in class org.apache.cassandra.schema.CompressionParams
 
validate(TableMetadata) - Method in class org.apache.cassandra.schema.Indexes
 
validate(TableMetadata) - Method in class org.apache.cassandra.schema.IndexMetadata
 
validate() - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
validate(String) - Method in class org.apache.cassandra.schema.KeyspaceParams
 
validate() - Method in class org.apache.cassandra.schema.Keyspaces
 
validate(String) - Method in class org.apache.cassandra.schema.ReplicationParams
 
validate() - Method in class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
 
validate() - Method in class org.apache.cassandra.schema.TableMetadata
 
validate() - Method in class org.apache.cassandra.schema.TableParams
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.AsciiSerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.BooleanSerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.ByteSerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.BytesSerializer
 
validate(T1, ValueAccessor<T1>) - Method in class org.apache.cassandra.serializers.CollectionSerializer
 
validate(T, ValueAccessor<T>) - Method in class org.apache.cassandra.serializers.DecimalSerializer
 
validate(T, ValueAccessor<T>) - Method in class org.apache.cassandra.serializers.DoubleSerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.DurationSerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.EmptySerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.FloatSerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.Int32Serializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.IntegerSerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.LongSerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.ShortSerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.TimeSerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.TimestampSerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.TimeUUIDSerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.TupleSerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.TypeSerializer
 
validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TypeSerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.UserTypeSerializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.UTF8Serializer
 
validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.UUIDSerializer
 
validateAnalyzer(Map<String, String>, ColumnMetadata) - Static method in class org.apache.cassandra.index.sasi.conf.IndexMode
 
validateCell(Cell<V>) - Method in class org.apache.cassandra.db.marshal.UserType
 
validateCell(Cell<V>) - Method in class org.apache.cassandra.schema.ColumnMetadata
 
validateCellValue(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.AbstractType
Validate cell value.
validateCellValue(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.CollectionType
 
validateCellValue(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
validateCollectionMember(V, V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
validateComparator(int, V, ValueAccessor<V>, int) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
Like getComparator, but validates that @param i does not exceed the defined range
validateComparator(int, V, ValueAccessor<V>, int) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
validateComparator(int, V, ValueAccessor<V>, int) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
validateCompressionLevel(String) - Static method in class org.apache.cassandra.io.compress.LZ4Compressor
 
validateCompressorType(String) - Static method in class org.apache.cassandra.io.compress.LZ4Compressor
 
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.AllowAllNetworkAuthorizer
 
validateConfiguration() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
 
validateConfiguration() - Method in class org.apache.cassandra.auth.CassandraNetworkAuthorizer
 
validateConfiguration() - Method in class org.apache.cassandra.auth.CassandraRoleManager
 
validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthenticator
Validates configuration of IAuthenticator implementation (if configurable).
validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthorizer
Validates configuration of IAuthorizer implementation (if configurable).
validateConfiguration() - Method in interface org.apache.cassandra.auth.IInternodeAuthenticator
Validates configuration of IInternodeAuthenticator implementation (if configurable).
validateConfiguration() - Method in interface org.apache.cassandra.auth.INetworkAuthorizer
Validates configuration of IAuthorizer implementation (if configurable).
validateConfiguration() - Method in interface org.apache.cassandra.auth.IRoleManager
Hook to perform validation of an implementation's configuration (if supported).
validateConfiguration() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
 
validateConfiguration(Configuration) - Method in class org.apache.cassandra.hadoop.cql3.CqlInputFormat
 
validateContext(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.context.CounterContext
 
validateCounterForWrite(TableMetadata) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
validateData(TableMetadata) - Method in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
 
validateData(TableMetadata) - Method in class org.apache.cassandra.db.rows.AbstractRow
 
validateData(TableMetadata) - Method in interface org.apache.cassandra.db.rows.Unfiltered
Validate the data of this atom.
validateDuration(Duration) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
 
validateDuration(Duration) - Method in class org.apache.cassandra.db.marshal.TemporalType
Validates that the duration has the correct precision.
validateDuration(Duration) - Method in class org.apache.cassandra.db.marshal.TimestampType
 
validateExpectedOptions() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
validateExpectedOptions() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
validateForCas() - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
validateForCasCommit(AbstractReplicationStrategy) - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
validateForIndexing() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
Deprecated.
validateForNativeProtocol(V, ValueAccessor<V>, ProtocolVersion) - Method in class org.apache.cassandra.serializers.CollectionSerializer
 
validateForNativeProtocol(V, ValueAccessor<V>, ProtocolVersion) - Method in class org.apache.cassandra.serializers.ListSerializer
 
validateForNativeProtocol(T, ValueAccessor<T>, ProtocolVersion) - Method in class org.apache.cassandra.serializers.MapSerializer
 
validateForNativeProtocol(V, ValueAccessor<V>, ProtocolVersion) - Method in class org.apache.cassandra.serializers.SetSerializer
 
validateForRead() - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
validateForWrite() - Method in enum org.apache.cassandra.db.ConsistencyLevel
 
validateIndexedColumns() - Method in interface org.apache.cassandra.db.IMutation
 
validateIndexedColumns() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
 
validateIndexedColumns() - Method in class org.apache.cassandra.db.virtual.VirtualMutation
 
validateKey(ByteBuffer) - Static method in class org.apache.cassandra.cql3.QueryProcessor
 
validateKey(TableMetadata, ByteBuffer) - Static method in class org.apache.cassandra.cql3.Validation
Validates a (full serialized) partition key.
validateLogin() - Method in class org.apache.cassandra.service.ClientState
 
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
Deprecated.
 
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(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
 
validateOptions(Map<String, String>, Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
validateOptions(Map<String, String>, TableMetadata) - Static method in class org.apache.cassandra.index.sasi.SASIIndex
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.SimpleStrategy
 
validateReallocation(long) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
 
validateRepairedMetadata(long, UUID, boolean) - Static method in class org.apache.cassandra.io.sstable.SSTable
 
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
 
validateSize(int, int) - Method in class org.apache.cassandra.db.CounterMutation
 
validateSize(int, int) - Method in interface org.apache.cassandra.db.IMutation
Validates size of mutation does not exceed DatabaseDescriptor.getMaxMutationSize().
validateSize(int, int) - Method in class org.apache.cassandra.db.Mutation
 
validateSize(int, int) - Method in class org.apache.cassandra.db.virtual.VirtualMutation
 
validateSslCerts(EncryptionOptions.ServerEncryptionOptions, EncryptionOptions) - Static method in class org.apache.cassandra.security.SSLFactory
Sanity checks all certificates to ensure we can actually load them
validateSslContext(String, EncryptionOptions, boolean, boolean) - Static method in class org.apache.cassandra.security.SSLFactory
 
validateTable(String, String) - Method in class org.apache.cassandra.schema.Schema
 
validateTransportsCanStart() - Method in class org.apache.cassandra.service.CassandraDaemon
 
validateTupleAssignableTo(ColumnSpecification, List<? extends AssignmentTestable>) - Static method in class org.apache.cassandra.cql3.Tuples
Checks if the tuple with the specified elements can be assigned to the specified column.
validateUserTypeAssignableTo(ColumnSpecification, Map<FieldIdentifier, T>) - Static method in class org.apache.cassandra.cql3.UserTypes
 
Validation - Class in org.apache.cassandra.cql3
A collection of static validation functions reused across statements.
Validation() - Constructor for class org.apache.cassandra.cql3.Validation
 
validation_preview_purge_head_start_in_sec - Variable in class org.apache.cassandra.config.Config
number of seconds to set nowInSec into the future when performing validation previews against repaired data this (attempts) to prevent a race where validations on different machines are started on different sides of a tombstone being compacted away
validationComplete(RepairJobDesc, InetAddressAndPort, MerkleTrees) - Method in class org.apache.cassandra.repair.RepairSession
Receive merkle tree response or failed response from endpoint for current repair job.
ValidationExecutor() - Constructor for class org.apache.cassandra.db.compaction.CompactionManager.ValidationExecutor
 
ValidationManager - Class in org.apache.cassandra.repair
 
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
 
ValidationPartitionIterator - Class in org.apache.cassandra.repair
 
ValidationPartitionIterator() - Constructor for class org.apache.cassandra.repair.ValidationPartitionIterator
 
ValidationRequest - Class in org.apache.cassandra.repair.messages
ValidationRequest
ValidationRequest(RepairJobDesc, int) - Constructor for class org.apache.cassandra.repair.messages.ValidationRequest
 
ValidationResponse - Class in org.apache.cassandra.repair.messages
ValidationComplete message is sent when validation compaction completed successfully.
ValidationResponse(RepairJobDesc) - Constructor for class org.apache.cassandra.repair.messages.ValidationResponse
 
ValidationResponse(RepairJobDesc, MerkleTrees) - Constructor for class org.apache.cassandra.repair.messages.ValidationResponse
 
ValidationTask - Class in org.apache.cassandra.repair
ValidationTask sends ValidationRequest to a replica.
ValidationTask(RepairJobDesc, InetAddressAndPort, int, PreviewKind) - Constructor for class org.apache.cassandra.repair.ValidationTask
 
validationTime - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
total time spent creating merkle trees
validationTime - Variable in class org.apache.cassandra.metrics.TableMetrics
time spent creating merkle trees
validator - Variable in class org.apache.cassandra.index.sasi.plan.Expression
 
Validator - Class in org.apache.cassandra.repair
Handles the building of a merkle tree for a column family.
Validator(RepairJobDesc, InetAddressAndPort, int, PreviewKind) - Constructor for class org.apache.cassandra.repair.Validator
 
Validator(RepairJobDesc, InetAddressAndPort, int, boolean, PreviewKind) - Constructor for class org.apache.cassandra.repair.Validator
 
Validator(RepairJobDesc, InetAddressAndPort, int, boolean, boolean, PreviewKind) - Constructor for class org.apache.cassandra.repair.Validator
 
validTimestampTimeUnits - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
validWindowTimeUnits - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
 
Value(ByteBuffer) - Constructor for class org.apache.cassandra.cql3.Constants.Value
 
Value(List<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Lists.Value
 
Value(Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Maps.Value
 
value - Variable in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
 
Value(SortedSet<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Sets.Value
 
Value(ByteBuffer[]) - Constructor for class org.apache.cassandra.cql3.Tuples.Value
 
Value(UserType, ByteBuffer[]) - Constructor for class org.apache.cassandra.cql3.UserTypes.Value
 
value - Variable in class org.apache.cassandra.db.filter.RowFilter.Expression
 
value() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.CounterMark
 
value() - Method in class org.apache.cassandra.db.rows.ArrayCell
 
value() - Method in class org.apache.cassandra.db.rows.BufferCell
 
value() - Method in class org.apache.cassandra.db.rows.Cell
 
value() - Method in class org.apache.cassandra.db.rows.NativeCell
 
value - Variable in enum org.apache.cassandra.exceptions.ExceptionCode
 
value - Variable in class org.apache.cassandra.gms.VersionedValue
 
value - Variable in enum org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer.TokenType
 
value - Variable in class org.apache.cassandra.index.sasi.plan.Expression.Bound
 
value - Variable in class org.apache.cassandra.index.sasi.sa.Term
 
value - Variable in class org.apache.cassandra.metrics.Sampler.Sample
 
value - Variable in enum org.apache.cassandra.net.MessagingService.Version
 
value() - Method in class org.apache.cassandra.utils.DefaultValue
 
value - Variable in class org.apache.cassandra.utils.ExpiringMemoizingSupplier.ReturnValue
 
value() - Method in class org.apache.cassandra.utils.ExpiringMemoizingSupplier.ReturnValue
 
ValueAccessor<V> - Interface in org.apache.cassandra.db.marshal
ValueAccessor allows serializers and other code dealing with raw bytes to operate on different backing types (ie: byte arrays, byte buffers, etc) without requiring that the supported backing types share a common type ancestor and without incuring the allocation cost of a wrapper object.
ValueAccessor.ObjectFactory<V> - Interface in org.apache.cassandra.db.marshal
Creates db objects using the given accessors value type.
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
 
ValueComparators - Class in org.apache.cassandra.db.marshal
 
ValueComparators(Comparator<byte[]>, Comparator<ByteBuffer>) - Constructor for class org.apache.cassandra.db.marshal.ValueComparators
 
valueCount() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
 
valueEqual(Cell<L>, Cell<R>) - Static method in class org.apache.cassandra.db.rows.Cells
 
valueFactory - Variable in class org.apache.cassandra.service.StorageService
 
valueForToken(Token) - Method in class org.apache.cassandra.dht.Splitter
 
valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.AbstractType
The length of values for this type if all values are of fixed length, -1 otherwise.
valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.BooleanType
 
valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.DateType
Deprecated.
 
valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.DoubleType
 
valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.EmptyType
 
valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.FloatType
 
valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.Int32Type
 
valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.LongType
 
valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.ReversedType
 
valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.TimestampType
 
valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.UUIDType
 
valueOf(String) - Static method in enum org.apache.cassandra.audit.AuditLogEntryCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.audit.AuditLogEntryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.auth.IRoleManager.Option
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.auth.Permission
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.concurrent.SEPExecutor.TakeTaskPermitResult
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.CassandraRelevantEnv
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.CassandraRelevantProperties
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.CorruptedTombstoneStrategy
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.DiskOptimizationStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.Config.FlushCompression
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.RepairCommandPoolFullStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.Config.UserFunctionTimeoutPolicy
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.EncryptionOptions.TlsEncryptionPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cql3.AssignmentTestable.TestResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cql3.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.functions.types.DataType.Name
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.SchemaElement.SchemaElementType
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.schema.IndexTarget.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cql3.statements.StatementType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.aggregation.AggregationSpecification.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.commitlog.CommitLogReadHandler.CommitLogReadErrorReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.commitlog.CommitLogSegment.CDCState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.compaction.CompactionInfo.Unit
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.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.Directories.FileType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.Directories.OnTxnErr
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.ExpirationDateOverflowHandling.ExpirationDateOverflowPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.filter.ClusteringIndexFilter.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.filter.DataLimits.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.filter.RowFilter.Expression.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState.Action
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.lifecycle.SSTableSet
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.marshal.AbstractType.ComparisonType
Returns the enum constant of this type with the specified name.
valueOf(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
valueOf(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
valueOf(String, Charset) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
valueOf(UUID) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
valueOf(boolean) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
valueOf(byte) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
valueOf(short) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
valueOf(int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
valueOf(long) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
valueOf(float) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
valueOf(double) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
valueOf(UUID) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
valueOf(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
valueOf(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
valueOf(String, Charset) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
valueOf(boolean) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
valueOf(byte) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
valueOf(short) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
valueOf(int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
valueOf(long) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
valueOf(float) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
valueOf(double) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
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(byte[]) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
return a value containing the Caller should assume that modifying the returned value will also modify the contents of
valueOf(ByteBuffer) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
return a value containing the and the returned value may share a common byte array instance, so caller should assume that modifying the returned value will also modify the contents of
valueOf(String, Charset) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
return a value containing the bytes for the given string and charset
valueOf(UUID) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
return a value with the bytes from
valueOf(boolean) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
return a value with the bytes from
valueOf(byte) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
return a value with the bytes from
valueOf(short) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
return a value with the bytes from
valueOf(int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
return a value with the bytes from
valueOf(long) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
return a value with the bytes from
valueOf(float) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
return a value with the bytes from
valueOf(double) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
return a value with the bytes from
valueOf(String) - Static method in enum org.apache.cassandra.db.monitoring.MonitoringState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.PartitionPosition.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.ReadCommand.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.rows.DeserializationHelper.Flag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.rows.Unfiltered.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.transform.RTBoundValidator.Stage
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.exceptions.RequestFailureReason
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.gms.GossiperEvent.GossiperEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.index.Index.LoadType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer.TokenType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskBlock.BlockType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndex.IteratorOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.TermSize
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.disk.TokenTreeBuilder.EntryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.plan.Expression.Op
Returns the enum constant of this type with the specified name.
valueOf(Operator) - Static method in enum org.apache.cassandra.index.sasi.plan.Expression.Op
 
valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.plan.Operation.OperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.utils.AbstractIterator.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator.Strategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.IteratorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.index.sasi.utils.trie.Cursor.Decision
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.index.transactions.IndexTransaction.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.io.compress.BufferType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.io.compress.ICompressor.Uses
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.format.SSTableFormat.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.format.SSTableReader.OpenReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.format.SSTableReadsListener.SelectionReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.format.SSTableReadsListener.SkippingReason
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.locator.ReplicaCollection.Builder.Conflict
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.locator.TokenMetadataEvent.TokenMetadataEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.metrics.Sampler.SamplerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.net.ConnectionCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.net.ConnectionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.net.MessageFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.net.MessagingService.Version
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.net.OutboundConnectionSettings.Framing
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.net.ParamType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.net.ResourceLimits.Outcome
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.net.Verb.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.net.Verb.Priority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.net.Verb
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.repair.consistent.ConsistentSession.State
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.apache.cassandra.repair.consistent.ConsistentSession.State
 
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.schema.CachingParams.Option
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.schema.ColumnMetadata.ClusteringOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.schema.ColumnMetadata.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.schema.CompactionParams.Option
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.schema.CompactionParams.TombstoneOption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.schema.Difference
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.schema.Functions.Filter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.schema.IndexMetadata.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.schema.KeyspaceMetadata.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.schema.KeyspaceParams.Option
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.schema.SchemaEvent.SchemaEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.schema.TableMetadata.Flag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.schema.TableMetadata.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.schema.TableParams.Option
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.security.SSLFactory.SocketType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.service.ActiveRepairService.ParentRepairStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.service.CacheService.CacheType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.service.reads.HybridSpeculativeRetryPolicy.Function
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.service.reads.repair.ReadRepairStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.service.reads.SpeculativeRetryPolicy.Kind
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.PreviewKind
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.StreamOperation
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.tools.JMXTool.Diff.Format
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.tools.JMXTool.Dump.Format
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.tools.NodeTool.NodeToolCmd.KeyspaceSet
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.tracing.TraceState.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.tracing.Tracing.TraceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.transport.ConnectionStage
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.Envelope.Header.Flag
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.Message.Direction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.transport.Message.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.transport.ProtocolVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.utils.ApproximateTime.Measurement
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.utils.AsymmetricOrdering.Op
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.utils.btree.BTree.Dir
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.utils.ChecksumType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.utils.MBeanWrapper.OnException
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.utils.NativeLibrary.OSType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.utils.NoSpamLogger.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.utils.progress.ProgressEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.utils.Throwables.FileOpType
Returns the enum constant of this type with the specified name.
valueRaw - Variable in class org.apache.cassandra.cql3.restrictions.CustomIndexExpression
 
values() - Static method in enum org.apache.cassandra.audit.AuditLogEntryCategory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.audit.AuditLogEntryType
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.IRoleManager.Option
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.auth.Permission
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.concurrent.SEPExecutor.TakeTaskPermitResult
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.CassandraRelevantEnv
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.CassandraRelevantProperties
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.CorruptedTombstoneStrategy
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.DiskOptimizationStrategy
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.FlushCompression
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.RepairCommandPoolFullStrategy
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.UserFunctionTimeoutPolicy
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.EncryptionOptions.TlsEncryptionPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.cql3.AssignmentTestable.TestResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.cql3.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.functions.types.DataType.Name
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.cql3.Operator
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithValues
 
values - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithValues
 
values(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQRestriction
 
values(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.SliceRestriction
 
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.SchemaElement.SchemaElementType
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.schema.IndexTarget.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.StatementType
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.apache.cassandra.db.AbstractOnHeapClusteringPrefix
 
values() - Static method in enum org.apache.cassandra.db.aggregation.AggregationSpecification.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.ClusteringPrefix.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.commitlog.CommitLogReadHandler.CommitLogReadErrorReason
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.commitlog.CommitLogSegment.CDCState
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.CompactionInfo.Unit
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.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.Directories.FileType
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.OnTxnErr
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.ExpirationDateOverflowHandling.ExpirationDateOverflowPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.db.filter.ClusteringIndexFilter.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.filter.DataLimits.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.filter.RowFilter.Expression.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.lifecycle.LifecycleTransaction.ReaderState.Action
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.db.lifecycle.SSTableSet
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.AbstractType.ComparisonType
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.monitoring.MonitoringState
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.PartitionPosition.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.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.rows.DeserializationHelper.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.rows.Unfiltered.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.transform.RTBoundValidator.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.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.exceptions.RequestFailureReason
Returns an array containing the constants of this enum type, in the order they are declared.
VALUES - Static variable in class org.apache.cassandra.fql.FullQueryLogger
 
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.gms.GossiperEvent.GossiperEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.index.Index.LoadType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer.TokenType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskBlock.BlockType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndex.IteratorOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.TermSize
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.index.sasi.disk.TokenTreeBuilder.EntryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.index.sasi.plan.Expression.Op
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.index.sasi.plan.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.index.sasi.utils.AbstractIterator.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.index.sasi.utils.RangeIntersectionIterator.Strategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.IteratorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.index.sasi.utils.trie.Cursor.Decision
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.index.transactions.IndexTransaction.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.compress.BufferType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.io.compress.ICompressor.Uses
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.format.SSTableFormat.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.io.sstable.format.SSTableReader.OpenReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.io.sstable.format.SSTableReadsListener.SelectionReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.io.sstable.format.SSTableReadsListener.SkippingReason
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.locator.ReplicaCollection.Builder.Conflict
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.locator.TokenMetadataEvent.TokenMetadataEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
 
values() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
 
values() - Static method in enum org.apache.cassandra.metrics.Sampler.SamplerType
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.ConnectionCategory
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.ConnectionType
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.MessageFlag
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.Version
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.OutboundConnectionSettings.Framing
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.ParamType
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.ResourceLimits.Outcome
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.Verb.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.net.Verb.Priority
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.Verb
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
 
values() - Static method in enum org.apache.cassandra.repair.consistent.ConsistentSession.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.repair.RepairParallelism
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.schema.CachingParams.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.schema.ColumnMetadata.ClusteringOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.schema.ColumnMetadata.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.schema.CompactionParams.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.schema.CompactionParams.TombstoneOption
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.schema.Difference
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.schema.Functions.Filter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.schema.IndexMetadata.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.schema.KeyspaceMetadata.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.schema.KeyspaceParams.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.schema.SchemaEvent.SchemaEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.schema.TableMetadata.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.schema.TableMetadata.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.schema.TableParams.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.security.SSLFactory.SocketType
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.ParentRepairStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.service.CacheService.CacheType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.service.reads.HybridSpeculativeRetryPolicy.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.service.reads.repair.ReadRepairStrategy
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.reads.SpeculativeRetryPolicy.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.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.PreviewKind
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.StreamOperation
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.tools.JMXTool.Diff.Format
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.tools.JMXTool.Dump.Format
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.tools.NodeTool.NodeToolCmd.KeyspaceSet
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.tracing.TraceState.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.tracing.Tracing.TraceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.transport.ConnectionStage
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.Envelope.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.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.Message.Direction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.transport.Message.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.apache.cassandra.transport.messages.BatchMessage
 
values() - Static method in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.transport.ProtocolVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.utils.ApproximateTime.Measurement
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.utils.AsymmetricOrdering.Op
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.cassandra.utils.BiMultiValMap
 
values() - Static method in enum org.apache.cassandra.utils.btree.BTree.Dir
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.utils.ChecksumType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.cassandra.utils.ConcurrentBiMap
 
values() - Static method in enum org.apache.cassandra.utils.MBeanWrapper.OnException
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.utils.NativeLibrary.OSType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.utils.NoSpamLogger.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.utils.progress.ProgressEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.utils.Throwables.FileOpType
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
 
valueSize() - Method in class org.apache.cassandra.db.rows.Cell
 
valuesOf(ColumnIdentifier) - Static method in class org.apache.cassandra.cql3.statements.schema.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
 
valueString(Cell<V>, AbstractType<?>) - Static method in class org.apache.cassandra.db.rows.Cells
 
valueString(Cell<V>) - Static method in class org.apache.cassandra.db.rows.Cells
 
varchar() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the VARCHAR type.
varchar() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type varchar.
VarcharAsBlobFct - Static variable in class org.apache.cassandra.cql3.functions.BytesConversionFcts
 
VariableSpecifications - Class in org.apache.cassandra.cql3
 
VariableSpecifications(List<ColumnIdentifier>) - Constructor for class org.apache.cassandra.cql3.VariableSpecifications
 
varint() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
Returns the VARINT type.
varint() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
Return the default codec for the CQL type varint.
verb() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
verb() - Method in class org.apache.cassandra.db.ReadCommand
 
verb() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
verb - Variable in class org.apache.cassandra.net.Message.Header
 
verb() - Method in class org.apache.cassandra.net.Message
 
Verb - Enum in org.apache.cassandra.net
Note that priorities except P0 are presently unused.
Verb.Kind - Enum in org.apache.cassandra.net
 
Verb.Priority - Enum in org.apache.cassandra.net
 
verbose - Variable in class org.apache.cassandra.tools.LoaderOptions
 
VERBOSE_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
 
VERBS - Static variable in enum org.apache.cassandra.net.Verb
 
Verifier - Class in org.apache.cassandra.db.compaction
 
Verifier(ColumnFamilyStore, SSTableReader, boolean, Verifier.Options) - Constructor for class org.apache.cassandra.db.compaction.Verifier
 
Verifier(ColumnFamilyStore, SSTableReader, OutputHandler, boolean, Verifier.Options) - Constructor for class org.apache.cassandra.db.compaction.Verifier
 
verifier(ReadCommand) - Static method in interface org.apache.cassandra.service.reads.repair.RepairedDataVerifier
 
Verifier.Options - Class in org.apache.cassandra.db.compaction
 
Verifier.Options.Builder - Class in org.apache.cassandra.db.compaction
 
Verifier.RangeOwnHelper - Class in org.apache.cassandra.db.compaction
Use the fact that check(..) is called with sorted tokens - we keep a pointer in to the normalized ranges and only bump the pointer if the key given is out of range.
verify(String, byte[]) - Method in class org.apache.cassandra.cql3.functions.UDFByteCodeVerifier
 
verify(Verifier.Options) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
verify() - Method in class org.apache.cassandra.db.compaction.Verifier
 
verify() - Method in class org.apache.cassandra.service.reads.repair.RepairedDataTracker
 
verify(RepairedDataTracker) - Method in class org.apache.cassandra.service.reads.repair.RepairedDataVerifier.SimpleVerifier
 
verify(RepairedDataTracker) - Method in class org.apache.cassandra.service.reads.repair.RepairedDataVerifier.SnapshottingVerifier
 
verify(RepairedDataTracker) - Method in interface org.apache.cassandra.service.reads.repair.RepairedDataVerifier
 
verify() - Method in class org.apache.cassandra.service.StartupChecks
Run the configured tests and return a report detailing the results.
verify(boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
Deprecated.
verify(boolean, boolean, boolean, boolean, boolean, boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
verify(boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Verify (checksums of) the given keyspace.
verify(boolean, boolean, boolean, boolean, boolean, boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
verify(boolean, boolean, boolean, boolean, boolean, boolean, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
verify(PrintStream, boolean, boolean, boolean, boolean, boolean, boolean, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
Verify - Class in org.apache.cassandra.tools.nodetool
 
Verify() - Constructor for class org.apache.cassandra.tools.nodetool.Verify
 
verifyCompactionsPendingThreshold(UUID, PreviewKind) - Static method in class org.apache.cassandra.service.ActiveRepairService
 
verifyCompressionInfoExistenceIfApplicable(Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
Best-effort checking to verify the expected compression info component exists, according to the TOC file.
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() - Method in class org.apache.cassandra.audit.BinAuditLogger.Message
 
version - Variable in class org.apache.cassandra.db.rows.DeserializationHelper
 
version - Variable in class org.apache.cassandra.db.streaming.CassandraStreamHeader
SSTable version
VERSION - Static variable in class org.apache.cassandra.fql.FullQueryLogger
 
version - Variable in class org.apache.cassandra.gms.VersionedValue
 
version - Variable in class org.apache.cassandra.index.sasi.disk.Descriptor
 
Version(String) - Constructor for class org.apache.cassandra.index.sasi.disk.Descriptor.Version
 
version - Variable in class org.apache.cassandra.index.sasi.disk.Descriptor.Version
 
version - Variable in class org.apache.cassandra.io.sstable.Descriptor
version has the following format: [a-z]+
Version - Class in org.apache.cassandra.io.sstable.format
A set of feature flags associated with a SSTable format versions are denoted as [major][minor].
Version(SSTableFormat, String) - Constructor for class org.apache.cassandra.io.sstable.format.Version
 
version - Variable in class org.apache.cassandra.io.sstable.format.Version
 
version() - Method in class org.apache.cassandra.io.sstable.format.VersionAndType
 
Version - Class in org.apache.cassandra.tools.nodetool
 
Version() - Constructor for class org.apache.cassandra.tools.nodetool.Version
 
VERSION - Static variable in class org.apache.cassandra.transport.ConnectedClient
 
version - Variable in class org.apache.cassandra.transport.Envelope.Header
 
version - Variable in class org.apache.cassandra.transport.SimpleClient
 
version() - Method in class org.apache.cassandra.utils.binlog.BinLog.ReleaseableWriteMarshallable
 
VERSION - Static variable in class org.apache.cassandra.utils.binlog.BinLog
 
VERSION_30 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
VERSION_30 - Static variable in class org.apache.cassandra.net.MessagingService
 
VERSION_3014 - Static variable in class org.apache.cassandra.net.MessagingService
 
VERSION_40 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
VERSION_40 - Static variable in class org.apache.cassandra.net.MessagingService
 
VERSION_AA - Static variable in class org.apache.cassandra.index.sasi.disk.Descriptor
 
VERSION_AB - Static variable in class org.apache.cassandra.index.sasi.disk.Descriptor
 
VersionAndType - Class in org.apache.cassandra.io.sstable.format
Groups a sstable Version with a SSTableFormat.Type.
VersionAndType(Version, SSTableFormat.Type) - Constructor for class org.apache.cassandra.io.sstable.format.VersionAndType
 
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
 
versions - Variable in class org.apache.cassandra.net.MessagingServiceMBeanImpl
 
versionsInUse() - Method in class org.apache.cassandra.service.SSTablesGlobalTracker
The set of all sstable versions currently in use on this node.
versionsInUse - Variable in class org.apache.cassandra.service.SSTablesVersionsInUseChangeNotification
The set of all sstable versions in use on this node at the time of this notification.
view(String, String) - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
Creates a DescribeStatement for DESCRIBE MATERIALIZED VIEW.
View - Class in org.apache.cassandra.db.lifecycle
An immutable structure holding the current memtable, the memtables pending flush, the sstables for a column family, and the sstables that are active in compaction (a subset of the sstables).
View - Class in org.apache.cassandra.db.view
A View copies data from a base table into a view table which can be queried independently from the base.
View(ViewMetadata, ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.view.View
 
View - Class in org.apache.cassandra.index.sasi.conf.view
 
View(ColumnIndex, Set<SSTableIndex>) - Constructor for class org.apache.cassandra.index.sasi.conf.view.View
 
View(ColumnIndex, Collection<SSTableIndex>, Collection<SSTableReader>, Set<SSTableIndex>) - Constructor for class org.apache.cassandra.index.sasi.conf.view.View
 
VIEW_BUILD_STATUS - Static variable in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
VIEW_BUILDS_IN_PROGRESS - Static variable in class org.apache.cassandra.db.SystemKeyspace
 
ViewBuilderTask - Class in org.apache.cassandra.db.view
 
ViewBuilderTask(ColumnFamilyStore, View, Range<Token>, Token, long) - Constructor for class org.apache.cassandra.db.view.ViewBuilderTask
 
ViewBuildStatus - Class in org.apache.cassandra.tools.nodetool
 
ViewBuildStatus() - Constructor for class org.apache.cassandra.tools.nodetool.ViewBuildStatus
 
ViewFragment(List<SSTableReader>, Iterable<Memtable>) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
 
viewLockAcquireTime - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
time taken acquiring the partition lock for materialized view updates on this keyspace
viewLockAcquireTime - Variable in class org.apache.cassandra.metrics.TableMetrics
time taken acquiring the partition lock for materialized view updates for this table
viewManager - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
viewManager - Variable in class org.apache.cassandra.db.Keyspace
 
ViewManager - Class in org.apache.cassandra.db.view
Manages View's for a single ColumnFamilyStore.
ViewManager(Keyspace) - Constructor for class org.apache.cassandra.db.view.ViewManager
 
ViewMetadata - Class in org.apache.cassandra.schema
 
ViewMetadata(TableId, String, boolean, WhereClause, TableMetadata) - Constructor for class org.apache.cassandra.schema.ViewMetadata
 
viewReadTime - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
time taken during the local read of a materialized view update
viewReadTime - Variable in class org.apache.cassandra.metrics.TableMetrics
time taken during the local read of a materialized view update
viewReplicasAttempted - Variable in class org.apache.cassandra.metrics.ViewWriteMetrics
 
viewReplicasSuccess - Variable in class org.apache.cassandra.metrics.ViewWriteMetrics
 
views - Variable in class org.apache.cassandra.schema.KeyspaceMetadata.KeyspaceDiff
 
views - Variable in class org.apache.cassandra.schema.KeyspaceMetadata
 
VIEWS - Static variable in class org.apache.cassandra.schema.SchemaKeyspace
 
Views - Class in org.apache.cassandra.schema
 
Views.Builder - Class in org.apache.cassandra.schema
 
viewStatus(String, String) - Static method in class org.apache.cassandra.repair.SystemDistributedKeyspace
 
ViewUpdateGenerator - Class in org.apache.cassandra.db.view
Creates the updates to apply to a view given the existing rows in the base table and the updates that we're applying to them (this handles updates on a single partition only).
ViewUpdateGenerator(View, DecoratedKey, int) - Constructor for class org.apache.cassandra.db.view.ViewUpdateGenerator
Creates a new ViewUpdateBuilder.
ViewUtils - Class in org.apache.cassandra.db.view
 
viewWriteLatency - Variable in class org.apache.cassandra.metrics.ViewWriteMetrics
 
ViewWriteMetrics - Class in org.apache.cassandra.metrics
 
ViewWriteMetrics(String) - Constructor for class org.apache.cassandra.metrics.ViewWriteMetrics
 
VIntCoding - Class in org.apache.cassandra.utils.vint
Borrows idea from https://developers.google.com/protocol-buffers/docs/encoding#varints
VIntCoding() - Constructor for class org.apache.cassandra.utils.vint.VIntCoding
 
virtual(String, Tables) - Static method in class org.apache.cassandra.schema.KeyspaceMetadata
 
VIRTUAL_SCHEMA - Static variable in class org.apache.cassandra.schema.SchemaConstants
 
VIRTUAL_VIEWS - Static variable in class org.apache.cassandra.schema.SchemaConstants
 
VirtualKeyspace - Class in org.apache.cassandra.db.virtual
 
VirtualKeyspace(String, Collection<VirtualTable>) - Constructor for class org.apache.cassandra.db.virtual.VirtualKeyspace
 
VirtualKeyspaceRegistry - Class in org.apache.cassandra.db.virtual
 
virtualKeyspacesMetadata() - Method in class org.apache.cassandra.db.virtual.VirtualKeyspaceRegistry
 
VirtualMutation - Class in org.apache.cassandra.db.virtual
A specialised IMutation implementation for virtual keyspaces.
VirtualMutation(PartitionUpdate) - Constructor for class org.apache.cassandra.db.virtual.VirtualMutation
 
VirtualMutation(String, DecoratedKey, ImmutableMap<TableId, PartitionUpdate>) - Constructor for class org.apache.cassandra.db.virtual.VirtualMutation
 
VirtualSchemaKeyspace - Class in org.apache.cassandra.db.virtual
 
VirtualTable - Interface in org.apache.cassandra.db.virtual
A system view used to expose system information.
VirtualTablePartitionRangeReadQuery - Class in org.apache.cassandra.db
A read query that selects a (part of a) range of partitions of a virtual table.
VirtualTableReadQuery - Class in org.apache.cassandra.db
Base class for the ReadQuery implementations use to query virtual tables.
VirtualTableReadQuery(TableMetadata, int, ColumnFilter, RowFilter, DataLimits) - Constructor for class org.apache.cassandra.db.VirtualTableReadQuery
 
VirtualTableSinglePartitionReadQuery - Class in org.apache.cassandra.db
A read query that selects a (part of a) single partition of a virtual table.
VirtualTableSinglePartitionReadQuery.Group - Class in org.apache.cassandra.db
Groups multiple single partition read queries.
visible(SSTableReader, Predicate<SSTableReader>, Collection<SSTableReader>...) - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState
 
visitFile(Path, BasicFileAttributes) - Method in class org.apache.cassandra.utils.DirectorySizeCalculator
 
visitFileFailed(Path, IOException) - Method in class org.apache.cassandra.utils.DirectorySizeCalculator
 
vnodeCount() - Method in class org.apache.cassandra.locator.ReplicaPlan.ForRangeRead
 
Void() - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.Void
 

W

WAIT_FOR_PENDING_EVENTS_TIMEOUT_SECS - Static variable in class org.apache.cassandra.tracing.TraceStateImpl
 
waitActivity(long) - Method in class org.apache.cassandra.tracing.TraceState
 
waitForCessation(Iterable<ColumnFamilyStore>, Predicate<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionManager
 
waitForDeletions() - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
Deletions run on the nonPeriodicTasks executor, (both failedDeletions or global tidiers in SSTableReader) so by scheduling a new empty task and waiting for it we ensure any prior deletion has completed.
waitForPendingEvents() - Method in class org.apache.cassandra.tracing.TraceState
 
waitForPendingEvents() - Method in class org.apache.cassandra.tracing.TraceStateImpl
Wait on submitted futures
waitForSchema(long) - Method in class org.apache.cassandra.service.StorageService
 
waitForSchemaAgreement(long, TimeUnit, BooleanSupplier) - Method in class org.apache.cassandra.gms.Gossiper
Blockingly wait for all live nodes to agree on the current schema version.
waitingFor(InetAddressAndPort) - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
waitingFor(InetAddressAndPort) - Method in class org.apache.cassandra.service.BatchlogResponseHandler
 
waitingFor(InetAddressAndPort) - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
waitingOnCommit - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
The time spent waiting on CL sync; for Periodic this is only occurs when the sync is lagging its sync interval
waitingOnFreeMemtableSpace - Variable in class org.apache.cassandra.metrics.TableMetrics
Time spent waiting for free memtable space, either on- or off-heap
waitingOnSegmentAllocation - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
Time spent waiting for a CLS to be allocated - under normal conditions this should be zero
waitOnCondition(BooleanSupplier, WaitQueue) - Static method in class org.apache.cassandra.utils.concurrent.WaitQueue
Loops waiting on the supplied condition and WaitQueue and will not return until the condition is true
waitOnFirstFuture(Iterable<? extends Future<? extends T>>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
waitOnFirstFuture(Iterable<? extends Future<? extends T>>, long) - Static method in class org.apache.cassandra.utils.FBUtilities
Only wait for the first future to finish from a list of futures.
waitOnFuture(Future<T>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
waitOnFutures(Iterable<? extends Future<? extends T>>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
waitOnFutures(Iterable<? extends Future<? extends T>>, long, TimeUnit) - Static method in class org.apache.cassandra.utils.FBUtilities
Block for a collection of futures, with optional timeout.
WaitQueue - Class in org.apache.cassandra.utils.concurrent
A relatively easy to use utility for general purpose thread signalling.
WaitQueue() - Constructor for class org.apache.cassandra.utils.concurrent.WaitQueue
 
WaitQueue.AbstractSignal - Class in org.apache.cassandra.utils.concurrent
An abstract signal implementation
WaitQueue.Signal - Interface in org.apache.cassandra.utils.concurrent
A Signal is a one-time-use mechanism for a thread to wait for notification that some condition state has transitioned that it may be interested in (and hence should check if it is).
waitToSettle() - Static method in class org.apache.cassandra.gms.Gossiper
 
waitUntilListening() - Method in class org.apache.cassandra.net.MessagingService
 
warn(String) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter.NullOutputHandler
 
warn(String, Throwable) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter.NullOutputHandler
 
warn(Consumer<String>) - Method in class org.apache.cassandra.io.sstable.SSTableHeaderFix.Builder
 
warn - Variable in class org.apache.cassandra.io.sstable.SSTableHeaderFix
 
warn(String) - Method in class org.apache.cassandra.service.ClientWarn
 
warn(long, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
 
warn(Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
 
warn(long, String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
warn(String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
 
warn(String) - Method in class org.apache.cassandra.utils.OutputHandler.LogOutput
 
warn(String, Throwable) - Method in class org.apache.cassandra.utils.OutputHandler.LogOutput
 
warn(String) - Method in class org.apache.cassandra.utils.OutputHandler.SystemOutput
 
warn(String, Throwable) - Method in class org.apache.cassandra.utils.OutputHandler.SystemOutput
 
warn(String) - Method in interface org.apache.cassandra.utils.OutputHandler
 
warn(String, Throwable) - Method in interface org.apache.cassandra.utils.OutputHandler
 
warn(Throwable) - Method in interface org.apache.cassandra.utils.OutputHandler
 
WARN_STDEV_GROWTH - Static variable in class org.apache.cassandra.dht.tokenallocator.TokenAllocation
 
warnIfRunningInDegradedMode() - Method in class org.apache.cassandra.utils.SigarLibrary
 
warnings - Variable in class org.apache.cassandra.transport.Message.Response
 
warnOut - Variable in class org.apache.cassandra.utils.OutputHandler.SystemOutput
 
wasDecommissioned() - Static method in class org.apache.cassandra.db.SystemKeyspace
 
watch - Variable in class org.apache.cassandra.tracing.TraceState
 
watch(String, Runnable, int) - Static method in class org.apache.cassandra.utils.ResourceWatcher
 
WatchedResource(String, Runnable) - Constructor for class org.apache.cassandra.utils.ResourceWatcher.WatchedResource
 
weigh(T) - Method in interface org.apache.cassandra.utils.concurrent.WeightedQueue.Weigher
 
weight() - Method in class org.apache.cassandra.audit.BinAuditLogger.Message
 
weight() - Method in class org.apache.cassandra.fql.FullQueryLogger.Batch
 
weight() - Method in class org.apache.cassandra.fql.FullQueryLogger.Query
 
weight() - Method in interface org.apache.cassandra.utils.concurrent.WeightedQueue.Weighable
 
WeightedQueue<T> - Class in org.apache.cassandra.utils.concurrent
Weighted queue is a wrapper around any blocking queue that turns it into a blocking weighted queue.
WeightedQueue(int) - Constructor for class org.apache.cassandra.utils.concurrent.WeightedQueue
 
WeightedQueue(int, BlockingQueue<T>, WeightedQueue.Weigher<T>) - Constructor for class org.apache.cassandra.utils.concurrent.WeightedQueue
 
WeightedQueue.Weighable - Interface in org.apache.cassandra.utils.concurrent
 
WeightedQueue.Weigher<T> - Interface in org.apache.cassandra.utils.concurrent
 
WeightedRange(double, Range<Token>) - Constructor for class org.apache.cassandra.dht.Splitter.WeightedRange
 
weightedSize() - Method in interface org.apache.cassandra.cache.CacheSize
 
weightedSize() - Method in class org.apache.cassandra.cache.CaffeineCache
 
weightedSize() - Method in class org.apache.cassandra.cache.ChunkCache
 
weightedSize() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
weightedSize() - Method in class org.apache.cassandra.cache.SerializingCache
 
whereClause - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
 
WhereClause - Class in org.apache.cassandra.cql3
 
whereClause - Variable in class org.apache.cassandra.schema.ViewMetadata
 
WhereClause.Builder - Class in org.apache.cassandra.cql3
 
width - Variable in class org.apache.cassandra.io.sstable.IndexInfo
 
WIDTH_BASE - Static variable in class org.apache.cassandra.io.sstable.IndexInfo.Serializer
 
wildcard(TableMetadata, boolean, boolean) - Static method in class org.apache.cassandra.cql3.selection.Selection
 
wildcardWithGroupBy(TableMetadata, VariableSpecifications, boolean, boolean) - Static method in class org.apache.cassandra.cql3.selection.Selection
 
windows_timer_interval - Variable in class org.apache.cassandra.config.Config
 
WindowsFailedSnapshotTracker - Class in org.apache.cassandra.db
 
WindowsFailedSnapshotTracker() - Constructor for class org.apache.cassandra.db.WindowsFailedSnapshotTracker
 
WindowsTimer - Class in org.apache.cassandra.utils
 
with(ClusteringComparator, Slice) - Static method in class org.apache.cassandra.db.Slices
Creates a Slices object that contains a single slice.
with(Function) - Method in class org.apache.cassandra.schema.Functions
Create a Functions instance with the provided function added
with(IndexMetadata) - Method in class org.apache.cassandra.schema.Indexes
Create a SecondaryIndexes instance with the provided index added
with(TableMetadata) - Method in class org.apache.cassandra.schema.Tables
Create a Tables instance with the provided table added
with(TriggerMetadata) - Method in class org.apache.cassandra.schema.Triggers
Create a Triggers instance with the provided trigger added
with(UserType) - Method in class org.apache.cassandra.schema.Types
Create a Types instance with the provided type added
with(ViewMetadata) - Method in class org.apache.cassandra.schema.Views
Create a MaterializedViews instance with the provided materialized view added
with(ByteBuf) - Method in class org.apache.cassandra.transport.Envelope
 
withAcceptedProtocols(List<String>) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
withAcceptedProtocols(List<String>) - Method in class org.apache.cassandra.config.EncryptionOptions
 
withAcceptMessaging(AcceptVersions) - Method in class org.apache.cassandra.net.InboundConnectionSettings
 
withAcceptStreaming(AcceptVersions) - Method in class org.apache.cassandra.net.InboundConnectionSettings
 
withAcceptVersions(AcceptVersions) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
withAddedOrUpdated(Function) - Method in class org.apache.cassandra.schema.Functions
 
withAddedOrUpdated(KeyspaceMetadata) - Method in class org.apache.cassandra.schema.Keyspaces
 
withAddedRegularColumn(ColumnMetadata) - Method in class org.apache.cassandra.schema.ViewMetadata
 
withAlgorithm(String) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
withAlgorithm(String) - Method in class org.apache.cassandra.config.EncryptionOptions
 
withAlias(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.ColumnSpecification
Returns a new ColumnSpecification for the same column but with the specified alias.
withApplicationReceiveQueueCapacityInBytes(int) - Method in class org.apache.cassandra.net.InboundConnectionSettings
 
withApplicationReserveSendQueueCapacityInBytes(Integer, ResourceLimits.Limit) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
withApplicationSendQueueCapacityInBytes(int) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
withAuthenticator(IInternodeAuthenticator) - Method in class org.apache.cassandra.net.InboundConnectionSettings
 
withAuthenticator(IInternodeAuthenticator) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
withBindAddress(InetAddressAndPort) - Method in class org.apache.cassandra.net.InboundConnectionSettings
 
withBufferSizeInMB(int) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
The size of the buffer to use.
withCallbacks(OutboundMessageCallbacks) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
WithCast(Selectable, CQL3Type) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithCast
 
withChunkCache(ChunkCache) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
Set ChunkCache to use.
withCipherSuites(List<String>) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
withCipherSuites(String...) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
withCipherSuites(List<String>) - Method in class org.apache.cassandra.config.EncryptionOptions
 
withCipherSuites(String...) - Method in class org.apache.cassandra.config.EncryptionOptions
 
withComponentManifest(ComponentManifest) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.Builder
 
withCompressionInfo(CompressionInfo) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.Builder
 
withCompressionMetadata(CompressionMetadata) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
Provide CompressionMetadata to use when reading compressed file.
withConnectTo(InetAddressAndPort) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
withContact(EndpointsForToken) - Method in class org.apache.cassandra.locator.ReplicaPlan.ForTokenWrite
 
withCreatedAt(long) - Method in class org.apache.cassandra.net.Message.Builder
 
withDebugCallbacks(OutboundDebugCallbacks) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
withDefaultReserveLimits() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
withDefaults() - Method in class org.apache.cassandra.net.InboundConnectionSettings
 
withDefaults(ConnectionCategory) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
withDefaultTests() - Method in class org.apache.cassandra.service.StartupChecks
 
withDescriptor(Descriptor) - Method in class org.apache.cassandra.io.sstable.SSTableHeaderFix.Builder
 
withEnabled(boolean) - Method in class org.apache.cassandra.config.EncryptionOptions
 
withEncryption(EncryptionOptions.ServerEncryptionOptions) - Method in class org.apache.cassandra.net.InboundConnectionSettings
 
withEncryption() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
withEncryption(EncryptionOptions.ServerEncryptionOptions) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
withEstimatedKeys(long) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.Builder
 
withEventLoopGroup(EventLoopGroup) - Method in class org.apache.cassandra.transport.Server.Builder
 
withEventNotifier(Server.EventNotifier) - Method in class org.apache.cassandra.transport.Server.Builder
 
withExpirationTime(long, int, int) - Static method in class org.apache.cassandra.db.LivenessInfo
 
withExpiresAt(long) - Method in class org.apache.cassandra.net.Message.Builder
 
WithFieldSelection(Selectable, FieldIdentifier) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection
 
withFirstKey(DecoratedKey) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.Builder
 
withFlag(MessageFlag) - Method in class org.apache.cassandra.net.Message.Builder
 
withFlags(int) - Method in class org.apache.cassandra.net.Message.Builder
 
withFormatType(SSTableFormat.Type) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
withForwardTo(ForwardingInfo) - Method in class org.apache.cassandra.net.Message
 
withFraming(OutboundConnectionSettings.Framing) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
withFrom(InetAddressAndPort) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
WithFunction(Function, List<Selectable>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithFunction
 
withGeneration(int) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
withHandlers(Function<InetAddressAndPort, InboundMessageHandlers>) - Method in class org.apache.cassandra.net.InboundConnectionSettings
 
withHost(InetAddress) - Method in class org.apache.cassandra.transport.Server.Builder
 
withId(long) - Method in class org.apache.cassandra.net.Message.Builder
 
withInternalDetails() - Method in class org.apache.cassandra.cql3.statements.DescribeStatement
 
withInternodeEncryption(EncryptionOptions.ServerEncryptionOptions.InternodeEncryption) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
withKeyStore(String) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
withKeyStore(String) - Method in class org.apache.cassandra.config.EncryptionOptions
 
withKeyStorePassword(String) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
withKeyStorePassword(String) - Method in class org.apache.cassandra.config.EncryptionOptions
 
withLastUpdate(int) - Method in class org.apache.cassandra.repair.consistent.LocalSession.Builder
 
withLegacyPortIfNecessary(int) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
withLegacySslStoragePort(boolean) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
withLegacySslStoragePortDefaults() - Method in class org.apache.cassandra.net.InboundConnectionSettings
 
withLimit(int) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
WithList(List<Selectable>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithList
 
withListener(ChannelHandlerContext, GenericFutureListener<? extends Future<? super Void>>) - Static method in class org.apache.cassandra.net.AsyncChannelPromise
 
withListener(Channel, GenericFutureListener<? extends Future<? super Void>>) - Static method in class org.apache.cassandra.net.AsyncChannelPromise
 
WithMapOrUdt(TableMetadata, List<Pair<Selectable.Raw, Selectable.Raw>>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithMapOrUdt
 
withNettyBufferBounds(WriteBufferWaterMark) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
withNewExpressions(List<RowFilter.Expression>) - Method in class org.apache.cassandra.db.filter.RowFilter
 
withNewName(ColumnIdentifier) - Method in class org.apache.cassandra.schema.ColumnMetadata
 
withNewOpeningDeletionTime(boolean, DeletionTime) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
 
withNewOpeningDeletionTime(boolean, DeletionTime) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
 
withNewOpeningDeletionTime(boolean, DeletionTime) - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
 
withNewRight(T) - Method in class org.apache.cassandra.dht.AbstractBounds
 
withNewRight(T) - Method in class org.apache.cassandra.dht.Bounds
 
withNewRight(T) - Method in class org.apache.cassandra.dht.ExcludingBounds
 
withNewRight(T) - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
 
withNewRight(T) - Method in class org.apache.cassandra.dht.Range
 
withNewType(AbstractType<?>) - Method in class org.apache.cassandra.schema.ColumnMetadata
 
withNonStrictOperator() - Method in class org.apache.cassandra.cql3.SingleColumnRelation
 
withNowInSeconds(int) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
withOnlyQueriedData(ColumnFilter) - Method in class org.apache.cassandra.db.rows.BTreeRow
 
withOnlyQueriedData(ColumnFilter) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
 
withOnlyQueriedData(ColumnFilter) - Method in interface org.apache.cassandra.db.rows.Row
Returns a copy of this row which only include the data queried by filter, excluding anything _fetched_ for internal reasons but not queried by the user (see ColumnFilter for details).
withOnlyQueriedData(RowIterator, ColumnFilter) - Static method in class org.apache.cassandra.db.rows.RowIterators
Filter the provided iterator to only include cells that are selected by the user.
withOnlyQueriedData(UnfilteredRowIterator, ColumnFilter) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
Filter the provided iterator to exclude cells that have been fetched but are not queried by the user (see ColumnFilter for detailes).
WithOnlyQueriedData<I extends BaseRowIterator<?>> - Class in org.apache.cassandra.db.rows
Function to skip cells (from an iterator) that are not part of those queried by the user according to the provided ColumnFilter.
WithOnlyQueriedData(ColumnFilter) - Constructor for class org.apache.cassandra.db.rows.WithOnlyQueriedData
 
withOptional(boolean) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
withOptional(Boolean) - Method in class org.apache.cassandra.config.EncryptionOptions
 
without(ColumnMetadata) - Method in class org.apache.cassandra.db.Columns
Returns the equivalent of those columns but with the provided column removed.
without(RowFilter.Expression) - Method in class org.apache.cassandra.db.filter.RowFilter
Returns this filter but without the provided expression.
without(Set<TableId>) - Method in class org.apache.cassandra.db.Mutation
 
without(TableId) - Method in class org.apache.cassandra.db.Mutation
 
without(ColumnMetadata) - Method in class org.apache.cassandra.db.RegularAndStaticColumns
 
without(Set<InetAddressAndPort>) - Method in class org.apache.cassandra.locator.Endpoints
 
without(FunctionName, List<AbstractType<?>>) - Method in class org.apache.cassandra.schema.Functions
Creates a Functions instance with the function with the provided name and argument types removed
without(Function) - Method in class org.apache.cassandra.schema.Functions
 
without(String) - Method in class org.apache.cassandra.schema.Indexes
Creates a SecondaryIndexes instance with the index with the provided name removed
without(String) - Method in class org.apache.cassandra.schema.Keyspaces
Creates a Keyspaces instance with the keyspace with the provided name removed
without(String) - Method in class org.apache.cassandra.schema.Tables
Creates a Tables instance with the table with the provided name removed
without(TableMetadata) - Method in class org.apache.cassandra.schema.Tables
 
without(String) - Method in class org.apache.cassandra.schema.Triggers
Creates a Triggers instance with the trigger with the provided name removed
without(ByteBuffer) - Method in class org.apache.cassandra.schema.Types
Creates a Types instance with the type with the provided name removed
without(UserType) - Method in class org.apache.cassandra.schema.Types
 
without(String) - Method in class org.apache.cassandra.schema.Views
Creates a MaterializedViews instance with the materializedView with the provided name removed
withoutExpressions() - Method in class org.apache.cassandra.db.filter.RowFilter
 
withoutParam(ParamType) - Method in class org.apache.cassandra.net.Message.Builder
 
withoutPerStatementVariables(QueryOptions) - Static method in class org.apache.cassandra.cql3.BatchQueryOptions
 
withoutPurgeableTombstones(UnfilteredPartitionIterator, ColumnFamilyStore, ReadExecutionController) - Method in class org.apache.cassandra.db.ReadCommand
 
withoutSelf() - Method in class org.apache.cassandra.locator.Endpoints
 
withoutSSTables(TableMetadata, OperationType, long, long, CompactionInfo.Unit, UUID) - Static method in class org.apache.cassandra.db.compaction.CompactionInfo
Special compaction info where we always need to cancel the compaction - for example ViewBuilderTask and AutoSavingCache where we don't know the sstables at construction
withoutState() - Method in class org.apache.cassandra.db.filter.DataLimits
Returns equivalent limits but where any internal state kept to track where we are of paging and/or grouping is discarded.
withPagingLimit(int) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
 
withParam(ParamType, Object) - Method in class org.apache.cassandra.net.Message.Builder
 
withParams(Map<ParamType, Object>) - Method in class org.apache.cassandra.net.Message.Builder
 
withPartitioner(IPartitioner) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
The partitioner to use.
withPath(Path) - Method in class org.apache.cassandra.io.sstable.SSTableHeaderFix.Builder
Manually provide an individual sstable or directory containing sstables.
withPayload(T) - Method in class org.apache.cassandra.net.Message.Builder
 
withPerStatementVariables(QueryOptions, List<List<ByteBuffer>>, List<Object>) - Static method in class org.apache.cassandra.cql3.BatchQueryOptions
 
withPipelineConfigurator(PipelineConfigurator) - Method in class org.apache.cassandra.transport.Server.Builder
 
withPort(int) - Method in class org.apache.cassandra.locator.InetAddressAndPort
 
withPort(int) - Method in class org.apache.cassandra.transport.Server.Builder
 
withProtocol(String) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
withProtocol(String) - Method in class org.apache.cassandra.config.EncryptionOptions
 
withRenamedPrimaryKeyColumn(ColumnIdentifier, ColumnIdentifier) - Method in class org.apache.cassandra.schema.ViewMetadata
 
withRequireClientAuth(boolean) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
withRequireClientAuth(boolean) - Method in class org.apache.cassandra.config.EncryptionOptions
 
withRequireEndpointVerification(boolean) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
withRequireEndpointVerification(boolean) - Method in class org.apache.cassandra.config.EncryptionOptions
 
withResultMetadata(ResultSet.ResultMetadata) - Method in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
 
withRowDeletion(DeletionTime) - Method in class org.apache.cassandra.db.rows.BTreeRow
 
withRowDeletion(DeletionTime) - Method in interface org.apache.cassandra.db.rows.Row
Returns a copy of this row with the new deletion as row deletion if it is more recent than the current row deletion.
withSections(List<SSTableReader.PartitionPositionBounds>) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.Builder
 
withSerializationHeader(SerializationHeader.Component) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.Builder
 
WithSet(List<Selectable>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithSet
 
withSkippedValue() - Method in class org.apache.cassandra.db.rows.ArrayCell
 
withSkippedValue() - Method in class org.apache.cassandra.db.rows.BufferCell
 
withSkippedValue() - Method in class org.apache.cassandra.db.rows.Cell
Used to apply the same optimization as in Cell.Serializer.deserialize(org.apache.cassandra.io.util.DataInputPlus, org.apache.cassandra.db.LivenessInfo, org.apache.cassandra.schema.ColumnMetadata, org.apache.cassandra.db.SerializationHeader, org.apache.cassandra.db.rows.DeserializationHelper, org.apache.cassandra.db.marshal.ValueAccessor<V>) when the column is not queried but eventhough it's used for digest calculation.
withSkippedValue() - Method in class org.apache.cassandra.db.rows.NativeCell
 
withSocketFactory(SocketFactory) - Method in class org.apache.cassandra.net.InboundConnectionSettings
 
withSocketFactory(SocketFactory) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
withSocketReceiveBufferSizeInBytes(int) - Method in class org.apache.cassandra.net.InboundConnectionSettings
 
withSocketSendBufferSizeInBytes(int) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
withSSTableFormat(SSTableFormat.Type) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.Builder
 
withSSTableLevel(int) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.Builder
 
withSSTableVersion(Version) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.Builder
 
withStartedAt(int) - Method in class org.apache.cassandra.repair.consistent.LocalSession.Builder
 
withStateTracking(UnfilteredPartitionIterator) - Method in class org.apache.cassandra.db.ReadCommand
 
withStoreType(String) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
withStoreType(String) - Method in class org.apache.cassandra.config.EncryptionOptions
 
withSummaries(List<SessionSummary>) - Method in class org.apache.cassandra.repair.SyncStat
 
withSwapped(KeyspaceParams) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
withSwapped(Tables) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
withSwapped(Views) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
withSwapped(Types) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
withSwapped(Functions) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
 
withSwapped(TableParams) - Method in class org.apache.cassandra.schema.TableMetadata
 
withSwapped(Set<TableMetadata.Flag>) - Method in class org.apache.cassandra.schema.TableMetadata
 
withSwapped(Triggers) - Method in class org.apache.cassandra.schema.TableMetadata
 
withSwapped(Indexes) - Method in class org.apache.cassandra.schema.TableMetadata
 
withSwapped(TableMetadata) - Method in class org.apache.cassandra.schema.Tables
 
withSwapped(ViewMetadata) - Method in class org.apache.cassandra.schema.Views
 
withTableId(TableId) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.Builder
 
withTcpConnectTimeoutInMS(int) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
withTcpNoDelay(boolean) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
withTcpUserTimeoutInMS(int) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
 
WithTerm(Term.Raw) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithTerm
 
withTest(StartupCheck) - Method in class org.apache.cassandra.service.StartupChecks
Add system test to be run before schema is loaded during startup
withTlsEncryptionPolicy(EncryptionOptions.TlsEncryptionPolicy) - Method in class org.apache.cassandra.transport.Server.Builder
 
withTracingParams() - Method in class org.apache.cassandra.net.Message.Builder
A shortcut to add tracing params.
withTransient(int, int) - Static method in class org.apache.cassandra.locator.ReplicationFactor
 
withTrustStore(String) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
withTrustStore(String) - Method in class org.apache.cassandra.config.EncryptionOptions
 
withTrustStorePassword(String) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
 
withTrustStorePassword(String) - Method in class org.apache.cassandra.config.EncryptionOptions
 
withType(String) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
 
WithTypeHint(String, AbstractType<?>, Selectable) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithTypeHint
 
withUpdatedColumn(ColumnMetadata) - Method in class org.apache.cassandra.db.rows.ArrayCell
 
withUpdatedColumn(ColumnMetadata) - Method in class org.apache.cassandra.db.rows.BufferCell
 
withUpdatedColumn(ColumnMetadata) - Method in class org.apache.cassandra.db.rows.Cell
 
withUpdatedColumn(ColumnMetadata) - Method in class org.apache.cassandra.db.rows.NativeCell
 
withUpdatedLimit(DataLimits) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
withUpdatedLimit(DataLimits) - Method in interface org.apache.cassandra.db.PartitionRangeReadQuery
Creates a new PartitionRangeReadQuery with the updated limits.
withUpdatedLimit(DataLimits) - Method in class org.apache.cassandra.db.ReadCommand
Creates a new ReadCommand instance with new limits.
withUpdatedLimit(DataLimits) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
 
withUpdatedLimit(DataLimits) - Method in interface org.apache.cassandra.db.SinglePartitionReadQuery
Creates a new SinglePartitionReadQuery with the specified limits.
withUpdatedLimit(DataLimits) - Method in class org.apache.cassandra.db.VirtualTablePartitionRangeReadQuery
 
withUpdatedLimit(DataLimits) - Method in class org.apache.cassandra.db.VirtualTableSinglePartitionReadQuery
 
withUpdatedLimit(DataLimits) - Method in class org.apache.cassandra.service.pager.AggregationQueryPager
 
withUpdatedLimit(DataLimits) - Method in class org.apache.cassandra.service.pager.MultiPartitionPager
 
withUpdatedLimit(DataLimits) - Method in class org.apache.cassandra.service.pager.PartitionRangeQueryPager
 
withUpdatedLimit(DataLimits) - Method in interface org.apache.cassandra.service.pager.QueryPager
Creates a new QueryPager that use the new limits.
withUpdatedLimit(DataLimits) - Method in class org.apache.cassandra.service.pager.SinglePartitionPager
 
withUpdatedLimitsAndDataRange(DataLimits, DataRange) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
 
withUpdatedLimitsAndDataRange(DataLimits, DataRange) - Method in interface org.apache.cassandra.db.PartitionRangeReadQuery
Creates a new PartitionRangeReadQuery with the updated limits and data range.
withUpdatedLimitsAndDataRange(DataLimits, DataRange) - Method in class org.apache.cassandra.db.VirtualTablePartitionRangeReadQuery
 
withUpdatedTimestamp(long) - Method in class org.apache.cassandra.db.LivenessInfo
Returns a copy of this liveness info updated with the provided timestamp.
withUpdatedTimestampAndLocalDeletionTime(long, int) - Method in class org.apache.cassandra.db.LivenessInfo
 
withUpdatedTimestampAndLocalDeletionTime(long, int) - Method in class org.apache.cassandra.db.rows.ArrayCell
 
withUpdatedTimestampAndLocalDeletionTime(long, int) - Method in class org.apache.cassandra.db.rows.BufferCell
 
withUpdatedTimestampAndLocalDeletionTime(long, int) - Method in class org.apache.cassandra.db.rows.Cell
 
withUpdatedTimestampAndLocalDeletionTime(long, int) - Method in class org.apache.cassandra.db.rows.NativeCell
 
withUpdatedUserType(Collection<UDFunction>, UserType) - Method in class org.apache.cassandra.cql3.functions.UDAggregate
 
withUpdatedUserType(UserType) - Method in class org.apache.cassandra.cql3.functions.UDFunction
 
withUpdatedUserType(UserType) - Method in class org.apache.cassandra.db.marshal.AbstractType
Returns an instance of this type with all references to the provided user type recursively replaced with its new definition.
withUpdatedUserType(UserType) - Method in class org.apache.cassandra.db.marshal.CompositeType
 
withUpdatedUserType(UserType) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
 
withUpdatedUserType(UserType) - Method in class org.apache.cassandra.db.marshal.ListType
 
withUpdatedUserType(UserType) - Method in class org.apache.cassandra.db.marshal.MapType
 
withUpdatedUserType(UserType) - Method in class org.apache.cassandra.db.marshal.ReversedType
 
withUpdatedUserType(UserType) - Method in class org.apache.cassandra.db.marshal.SetType
 
withUpdatedUserType(UserType) - Method in class org.apache.cassandra.db.marshal.TupleType
 
withUpdatedUserType(UserType) - Method in class org.apache.cassandra.db.marshal.UserType
 
withUpdatedUserType(UserType) - Method in class org.apache.cassandra.schema.Functions
 
withUpdatedUserType(UserType) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
Returns a new KeyspaceMetadata with all instances of old UDT replaced with the updated version.
withUpdatedUserType(UserType) - Method in class org.apache.cassandra.schema.TableMetadata
 
withUpdatedUserType(UserType) - Method in class org.apache.cassandra.schema.Tables
 
withUpdatedUserType(UserType) - Method in class org.apache.cassandra.schema.Types
 
withUpdatedUserType(UserType) - Method in class org.apache.cassandra.schema.ViewMetadata
 
withUpdatedValue(ByteBuffer) - Method in class org.apache.cassandra.db.rows.ArrayCell
 
withUpdatedValue(ByteBuffer) - Method in class org.apache.cassandra.db.rows.BufferCell
 
withUpdatedValue(ByteBuffer) - Method in class org.apache.cassandra.db.rows.Cell
 
withUpdatedValue(ByteBuffer) - Method in class org.apache.cassandra.db.rows.NativeCell
 
withValidation(UnfilteredRowIterator, String) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
Validate that the data of the provided iterator is valid, that is that the values it contains are valid for the type they represent, and more generally that the infos stored are sensible.
worthDroppingTombstones(SSTableReader, int) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
Check if given sstable is worth dropping tombstones at gcBefore.
wrap(ByteBuffer) - Static method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
wrap(ByteBuffer) - Static method in class org.apache.cassandra.net.ShareableBytes
 
wrap(Throwable, int) - Static method in class org.apache.cassandra.transport.messages.ErrorMessage
 
wrap(Object[], Comparator<V>) - Static method in class org.apache.cassandra.utils.btree.BTreeSet
 
wrap(ByteBuffer) - Static method in class org.apache.cassandra.utils.CounterId
 
wrap(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.CounterId
 
wrap(byte[]) - Static method in class org.apache.cassandra.utils.MD5Digest
 
wrapCharArray(char[]) - Static method in class org.apache.cassandra.utils.Hex
Create a String from a char array with zero-copy (if available), using reflection to access a package-protected constructor of String.
wrapped - Variable in class org.apache.cassandra.cql3.BatchQueryOptions
 
wrapped - Variable in class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
 
Wrapped<T> - Class in org.apache.cassandra.utils
Simple wrapper class to be used when a lambda function needs to modify a variable outside it's scope.
WrappedBoolean - Class in org.apache.cassandra.utils
Simple wrapper for native boolean type
WrappedBoolean(boolean) - Constructor for class org.apache.cassandra.utils.WrappedBoolean
 
WrappedDataOutputStreamPlus - Class in org.apache.cassandra.io.util
When possible use WrappedDataOutputStreamPlus instead of this class, as it will be more efficient when using Plus methods.
WrappedDataOutputStreamPlus(OutputStream) - Constructor for class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
 
WrappedDataOutputStreamPlus(OutputStream, WritableByteChannel) - Constructor for class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
 
WrappedException(Throwable, int) - Constructor for exception org.apache.cassandra.transport.messages.ErrorMessage.WrappedException
 
WrappedException - Exception in org.apache.cassandra.utils
Wrapped runtime exception for lambda functions
WrappedException(Exception) - Constructor for exception org.apache.cassandra.utils.WrappedException
 
WrappedLifecycleTransaction - Class in org.apache.cassandra.db.lifecycle
 
WrappedLifecycleTransaction(ILifecycleTransaction) - Constructor for class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
 
WrappedRunnable - Class in org.apache.cassandra.utils
 
WrappedRunnable() - Constructor for class org.apache.cassandra.utils.WrappedRunnable
 
WrappedSharedCloseable - Class in org.apache.cassandra.utils.concurrent
An implementation of SharedCloseable that wraps a normal AutoCloseable, ensuring its close method is only called when all instances of SharedCloseable have been
WrappedSharedCloseable(AutoCloseable) - Constructor for class org.apache.cassandra.utils.concurrent.WrappedSharedCloseable
 
WrappedSharedCloseable(AutoCloseable[]) - Constructor for class org.apache.cassandra.utils.concurrent.WrappedSharedCloseable
 
WrappedSharedCloseable(WrappedSharedCloseable) - Constructor for class org.apache.cassandra.utils.concurrent.WrappedSharedCloseable
 
Wrapper() - Constructor for class org.apache.cassandra.tools.nodetool.Sjk.Wrapper
 
WrappingUnfilteredRowIterator - Class in org.apache.cassandra.db.rows
Abstract class to make writing unfiltered iterators that wrap another iterator easier.
WrappingUnfilteredRowIterator(UnfilteredRowIterator) - Constructor for class org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
 
wrapQuiet(String, boolean) - Static method in class org.apache.cassandra.tools.Util
 
write(DataOutputPlus) - Method in class org.apache.cassandra.cache.CounterCacheKey
 
write(PartitionUpdate, WriteContext, UpdateTransaction) - Method in class org.apache.cassandra.db.CassandraTableWriteHandler
 
write(JsonNode, CompactionLogger.StrategySummary, Object) - Method in interface org.apache.cassandra.db.compaction.CompactionLogger.Writer
 
write(byte[], DataOutputPlus) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
write(byte[], ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
 
write(ByteBuffer, DataOutputPlus) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
write(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
 
write(V, DataOutputPlus) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
Write the contents of the given value into the a DataOutputPlus
write(V, ByteBuffer) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
Write the contents of the given value into the ByteBuffer
write(DataOutputStreamPlus) - Method in class org.apache.cassandra.db.streaming.CassandraCompressedStreamWriter
 
write(AsyncStreamingOutputPlus) - Method in class org.apache.cassandra.db.streaming.CassandraEntireSSTableStreamWriter
Stream the entire file to given channel.
write(StreamSession, DataOutputStreamPlus, int) - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
 
write(DataOutputStreamPlus) - Method in class org.apache.cassandra.db.streaming.CassandraStreamWriter
Stream file of specified sections to given channel.
write(ChannelProxy, DataIntegrityMetadata.ChecksumValidator, AsyncStreamingOutputPlus, long, int, int, int) - Method in class org.apache.cassandra.db.streaming.CassandraStreamWriter
Sequentially read bytes from the file and write them to the output stream
write(PartitionUpdate, WriteContext, UpdateTransaction) - Method in interface org.apache.cassandra.db.TableWriteHandler
 
write(DataOutput) - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
write(Object, List<ByteBuffer>) - Method in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
The column values must correspond to the order in which they appear in the insert stored procedure.
write(Collection<UUID>, Hint) - Method in class org.apache.cassandra.hints.HintsService
Write a hint for a iterable of nodes.
write(UUID, Hint) - Method in class org.apache.cassandra.hints.HintsService
Write a hint for a single node.
write(DataOutputPlus) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
 
write(DataOutputPlus) - Method in class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
 
write(DataOutputPlus) - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
 
write(byte[]) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
write(byte[], int, int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
write(ByteBuffer) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
write(int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
write(ByteBuffer) - Method in interface org.apache.cassandra.io.util.DataOutputPlus
 
write(Memory, long, long) - Method in interface org.apache.cassandra.io.util.DataOutputPlus
 
write(File, List<String>, StandardOpenOption...) - Static method in class org.apache.cassandra.io.util.FileUtils
Write lines to a file adding a newline to the end of each supplied line using the provided open options.
write(int) - Method in class org.apache.cassandra.io.util.MemoryOutputStream
 
write(byte[], int, int) - Method in class org.apache.cassandra.io.util.MemoryOutputStream
 
write(byte[]) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes the entire contents of the byte array buffer to this RandomAccessFile starting at the current file pointer.
write(byte[], int, int) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes count bytes from the byte array buffer starting at offset to this RandomAccessFile starting at the current file pointer..
write(int) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes the specified byte oneByte to this RandomAccessFile starting at the current file pointer.
write(ByteBuffer) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
 
write(byte[], int, int) - Method in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
 
write(int) - Method in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
 
write(AsyncStreamingOutputPlus.BufferSupplier) - Method in interface org.apache.cassandra.net.AsyncStreamingOutputPlus.Write
Write to a buffer, and flush its contents to the channel.
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.apache.cassandra.net.FrameEncoder
 
write(StreamSession, DataOutputStreamPlus, int) - Method in interface org.apache.cassandra.streaming.OutgoingStream
Write the streams data into the socket
write(String) - Method in class org.apache.cassandra.tools.AbstractJmxClient
 
write(String, Object...) - Method in class org.apache.cassandra.tools.AbstractJmxClient
 
write_request_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
writeAll - Static variable in class org.apache.cassandra.locator.ReplicaPlans
Select all nodes, transient or otherwise, as targets for the operation.
writeAndFlush(ChannelHandlerContext, Object, GenericFutureListener<? extends Future<? super Void>>) - Static method in class org.apache.cassandra.net.AsyncChannelPromise
 
writeAndFlush(Channel, Object, GenericFutureListener<? extends Future<? super Void>>) - Static method in class org.apache.cassandra.net.AsyncChannelPromise
 
writeAndFlush(ChannelHandlerContext, Object) - Static method in class org.apache.cassandra.net.AsyncChannelPromise
 
writeAndFlush(Channel, Object) - Static method in class org.apache.cassandra.net.AsyncChannelPromise
 
writeAsciiString(String, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
Write US-ASCII strings.
writeBoolean(boolean) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeBoolean(boolean) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes a boolean to this output stream.
writeBuffer(ByteBuffer) - Method in class org.apache.cassandra.hints.CompressedHintsWriter
 
writeBuffer(ByteBuffer) - Method in class org.apache.cassandra.hints.EncryptedHintsWriter
 
writeByte(int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeByte(int) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes a 8-bit byte to this output stream.
writeBytes(String) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeBytes(String) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes the low order 8-bit bytes from a String to this output stream.
writeBytes(byte[], ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeBytesMap(Map<String, ByteBuffer>, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeCDCIndexFile(CommitLogDescriptor, int, boolean) - Static method in class org.apache.cassandra.db.commitlog.CommitLogSegment
We persist the offset of the last data synced to disk so clients can parse only durable data if they choose.
writeChar(int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeChar(int) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes the specified 16-bit character to the OutputStream.
writeChars(String) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeChars(String) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes the specified 16-bit characters contained in str to the OutputStream.
writeChunkSize(int) - Method in class org.apache.cassandra.io.util.ChecksumWriter
 
writeCollectionSize(ByteBuffer, int, ProtocolVersion) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
 
writeComponent(Component.Type, DataInputPlus, long) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableZeroCopyWriter
 
writeConsistencyLevel(ConsistencyLevel, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
WriteContext - Interface in org.apache.cassandra.db
Issued by the keyspace write handler and used in the write path (as expected), as well as the read path and some async index building code.
writeCount - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsKeyspace
 
writeDeletionTime(DeletionTime, DataOutputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
 
writeDirectlyToChannel(ByteBuffer) - Method in class org.apache.cassandra.io.util.SequentialWriter
 
writeDouble(double) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeDouble(double) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes a 64-bit double to this output stream.
writeEndOfPartition(DataOutputPlus) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
 
writeEnumValue(T, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeFailedIdealCL - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
Writes failed ideal consistency
WriteFailureException - Exception in org.apache.cassandra.exceptions
 
WriteFailureException(ConsistencyLevel, int, int, WriteType, Map<InetAddressAndPort, RequestFailureReason>) - Constructor for exception org.apache.cassandra.exceptions.WriteFailureException
 
writeFileToChannel(FileChannel, StreamManager.StreamRateLimiter) - Method in class org.apache.cassandra.net.AsyncStreamingOutputPlus
Writes all data in file channel to stream:
* For zero-copy-streaming, 1MiB at a time, with at most 2MiB in flight at once.
writeFloat(float) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeFloat(float) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes a 32-bit float to this output stream.
writeFullChecksum(File) - Method in class org.apache.cassandra.io.util.ChecksumWriter
 
writeGlobal(CounterId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
writeHeader(ByteBuffer, CommitLogDescriptor) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
writeHeader(ByteBuffer, CommitLogDescriptor, Map<String, String>) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
 
writeInet(InetSocketAddress, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeInetAddr(InetAddress, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeInt(int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeInt(int) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes a 32-bit int to this output stream.
writeLatency - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
(Local) write metrics
writeLatency - Variable in class org.apache.cassandra.metrics.TableMetrics
(Local) write metrics
writeLatency() - Method in class org.apache.cassandra.tools.nodetool.stats.StatsKeyspace
 
writeln(Throwable) - Method in class org.apache.cassandra.tools.AbstractJmxClient
 
writeln(String) - Method in class org.apache.cassandra.tools.AbstractJmxClient
 
writeln(String, Object...) - Method in class org.apache.cassandra.tools.AbstractJmxClient
 
writeLocal(CounterId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
writeLocalDeletionTime(int, DataOutputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
 
writeLong(long) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeLong(long) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes a 64-bit long to this output stream.
writeLongString(String, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeMarshallable(WireOut) - Method in class org.apache.cassandra.utils.binlog.BinLog.ReleaseableWriteMarshallable
 
writeMarshallablePayload(WireOut) - Method in class org.apache.cassandra.audit.BinAuditLogger.Message
 
writeMarshallablePayload(WireOut) - Method in class org.apache.cassandra.fql.FullQueryLogger.Batch
 
writeMarshallablePayload(WireOut) - Method in class org.apache.cassandra.fql.FullQueryLogger.Query
 
writeMarshallablePayload(WireOut) - Method in class org.apache.cassandra.utils.binlog.BinLog.ReleaseableWriteMarshallable
 
writeNormal - Static variable in class org.apache.cassandra.locator.ReplicaPlans
Select all full nodes, live or down, as write targets.
writeOne(Pair<DataType, Object>, ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.transport.DataType.Codec
 
writeOrder - Static variable in class org.apache.cassandra.db.Keyspace
 
writePartition(CassandraStreamReader.StreamDeserializer, SSTableMultiWriter) - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader
 
writePreparedStatement(String, MD5Digest, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
 
Writer(int) - Constructor for class org.apache.cassandra.cache.AutoSavingCache.Writer
 
writer - Variable in class org.apache.cassandra.hadoop.cql3.CqlBulkRecordWriter
 
writeReadRepair(ReplicaPlan.ForRead<?>) - Static method in class org.apache.cassandra.locator.ReplicaPlans
TODO: Transient Replication C-14404/C-14665 TODO: We employ this even when there is no monotonicity to guarantee, e.g.
writeRemote(CounterId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
WriteResponseHandler<T> - Class in org.apache.cassandra.service
Handles blocking writes for ONE, ANY, TWO, THREE, QUORUM, and ALL consistency levels.
WriteResponseHandler(ReplicaPlan.ForTokenWrite, Runnable, WriteType, long) - Constructor for class org.apache.cassandra.service.WriteResponseHandler
 
WriteResponseHandler(ReplicaPlan.ForTokenWrite, WriteType, long) - Constructor for class org.apache.cassandra.service.WriteResponseHandler
 
writeShort(int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeShort(int) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes the specified 16-bit short to the OutputStream.
writeShortLength(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
writeStart(JsonNode, Object) - Method in interface org.apache.cassandra.db.compaction.CompactionLogger.Writer
This is used when we are already trying to write out the start of a
writeString(String, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeStringList(List<String>, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeStringMap(Map<String, String>, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeStringToStringListMap(Map<String, List<String>>, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeSyncMarker(long, ByteBuffer, int, int, int) - Static method in class org.apache.cassandra.db.commitlog.CommitLogSegment
Create a sync marker to delineate sections of the commit log, typically created on each sync of the file.
WritetimeOrTTL(ColumnMetadata, boolean) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL
 
WriteTimeoutException - Exception in org.apache.cassandra.exceptions
 
WriteTimeoutException(WriteType, ConsistencyLevel, int, int) - Constructor for exception org.apache.cassandra.exceptions.WriteTimeoutException
 
WriteTimeoutException(WriteType, ConsistencyLevel, int, int, String) - Constructor for exception org.apache.cassandra.exceptions.WriteTimeoutException
 
writeTimestamp(long, DataOutputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
 
writeTo(DataOutput) - Method in enum org.apache.cassandra.cql3.Operator
Write the serialized version of this Operator to the specified output.
writeToChannel(AsyncStreamingOutputPlus.Write, StreamManager.StreamRateLimiter) - Method in class org.apache.cassandra.net.AsyncStreamingOutputPlus
Provide a lambda that can request a buffer of suitable size, then fill the buffer and have that buffer written and flushed to the underlying channel, without having to handle buffer allocation, lifetime or cleanup, including in case of exceptions.
writeTTL(int, DataOutputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
 
WriteType - Enum in org.apache.cassandra.db
 
writeType - Variable in exception org.apache.cassandra.exceptions.WriteFailureException
 
writeType - Variable in exception org.apache.cassandra.exceptions.WriteTimeoutException
 
writeType - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
writeUnsignedVInt(long) - Method in interface org.apache.cassandra.io.util.DataOutputPlus
This is more efficient for storing unsigned values, both in storage and CPU burden.
writeUnsignedVInt(long, DataOutput) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
 
writeUnsignedVInt(long, ByteBuffer) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
 
writeUTF(String) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
 
writeUTF(String, DataOutput) - Static method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes the specified String out in UTF format to the provided DataOutput
writeUTF(String) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
Writes the specified String out in UTF format.
writeUUID(UUID, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeValue(ByteBuffer, ByteBuffer, ProtocolVersion) - Static method in class org.apache.cassandra.cql3.functions.types.CodecUtils
Utility method that writes a value.
writeValue(ByteBuffer, DataOutputPlus) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
writeValue(V, ValueAccessor<V>, DataOutputPlus) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
writeValue(ByteBuffer, DataOutputPlus) - Method in class org.apache.cassandra.db.marshal.EmptyType
 
writeValue(ByteBuffer, V, ValueAccessor<V>, ProtocolVersion) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
 
writeValue(byte[], ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeValue(ByteBuffer, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeValue(Object, ByteBuf, ProtocolVersion) - Method in enum org.apache.cassandra.transport.DataType
 
writeValueList(List<ByteBuffer>, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
 
writeVInt(long) - Method in interface org.apache.cassandra.io.util.DataOutputPlus
 
writeVInt(long, DataOutput) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
 
writeWithLength(byte[], DataOutput) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
writeWithLength(ByteBuffer, DataOutputPlus) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
writeWithShortLength(byte[], DataOutput) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
 
writeWithShortLength(ByteBuffer, DataOutputPlus) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
writeWithVIntLength(V, DataOutputPlus) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
 
writeWithVIntLength(ByteBuffer, DataOutputPlus) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
writeZeroes(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
writtenLength(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
writtenLength(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
writtenLength(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.EmptyType
 

Y

YamlConfigurationLoader - Class in org.apache.cassandra.config
 
YamlConfigurationLoader() - Constructor for class org.apache.cassandra.config.YamlConfigurationLoader
 
YamlPrinter() - Constructor for class org.apache.cassandra.tools.nodetool.stats.StatsPrinter.YamlPrinter
 
yychar() - Method in interface org.apache.cassandra.index.sasi.analyzer.StandardTokenizerInterface
Returns the current position.
yylength() - Method in interface org.apache.cassandra.index.sasi.analyzer.StandardTokenizerInterface
Returns the length of the matched text region.
yyreset(Reader) - Method in interface org.apache.cassandra.index.sasi.analyzer.StandardTokenizerInterface
Resets the scanner to read from a new input stream.

Z

ZERO - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 
ZERO - Static variable in class org.apache.cassandra.locator.ReplicationFactor
 
ZERO - Static variable in class org.apache.cassandra.utils.HistogramBuilder
 
ZONE_NAME_QUERY_URI - Static variable in class org.apache.cassandra.locator.CloudstackSnitch
 
ZONE_NAME_QUERY_URL - Static variable in class org.apache.cassandra.locator.AlibabaCloudSnitch
 
ZONE_NAME_QUERY_URL - Static variable in class org.apache.cassandra.locator.GoogleCloudSnitch
 
zstd() - Static method in class org.apache.cassandra.schema.CompressionParams
 
zstd(Integer) - Static method in class org.apache.cassandra.schema.CompressionParams
 
ZstdCompressor - Class in org.apache.cassandra.io.compress
ZSTD Compressor
A B C D E F G H I J K L M N O P Q R S T U V W Y Z 
Skip navigation links

Copyright © 2009-2021 The Apache Software Foundation