A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- AA - Static variable in class org.apache.cassandra.index.sai.disk.format.Version
- 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() - 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() - Method in interface org.apache.cassandra.index.sai.disk.PerSSTableIndexWriter
- abort() - Method in class org.apache.cassandra.index.sai.disk.v1.SSTableComponentsWriter
- abort() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
- abort() - Method in class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
- 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.StreamSession
- abort() - Method in class org.apache.cassandra.streaming.StreamTask
-
Abort the task.
- abort() - Method in class org.apache.cassandra.streaming.StreamTransferTask
- abort() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
- abort(Throwable) - Method in class org.apache.cassandra.db.compaction.unified.ShardedMultiWriter
- abort(Throwable) - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
- abort(Throwable) - Method in interface org.apache.cassandra.index.sai.disk.PerColumnIndexWriter
-
Aborts accumulating data.
- abort(Throwable) - Method in class org.apache.cassandra.index.sai.disk.StorageAttachedIndexWriter
-
Aborts all column index writers and, only if they have not yet completed, SSTable-level component writers.
- abort(Throwable) - Method in class org.apache.cassandra.index.sai.disk.v1.MemtableIndexWriter
- abort(Throwable) - Method in class org.apache.cassandra.index.sai.disk.v1.SSTableIndexWriter
- abort(Throwable) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
- abort(Throwable) - Method in class org.apache.cassandra.io.sstable.RangeAwareSSTableWriter
- abort(Throwable) - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
- abort(Throwable) - Method in interface org.apache.cassandra.io.sstable.SSTableFlushObserver
-
Clean up resources on error.
- abort(Throwable) - Method in class org.apache.cassandra.io.sstable.SSTableZeroCopyWriter
- abort(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter
- abort(Throwable) - Method in class org.apache.cassandra.repair.LocalSyncTask
- abort(Throwable) - Method in class org.apache.cassandra.repair.RepairJob
- abort(Throwable) - Method in class org.apache.cassandra.repair.SyncTask
- abort(Throwable) - Method in class org.apache.cassandra.repair.ValidationTask
-
Release any trees already received by this task, and place it a state where any trees received subsequently will be properly discarded.
- abort(Throwable) - Method in interface org.apache.cassandra.service.paxos.uncommitted.UncommittedTableData.FlushWriter
- 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(Throwable, boolean) - Method in class org.apache.cassandra.index.sai.disk.StorageAttachedIndexWriter
- abort(Predicate<ActiveRepairService.ParentRepairSession>, String) - Method in class org.apache.cassandra.service.ActiveRepairService
-
Remove any parent repair sessions matching predicate
- ABORT - org.apache.cassandra.utils.progress.ProgressEventType
-
When observing process is aborted by user, this is sent once before COMPLETE.
- ABORTED - org.apache.cassandra.db.compaction.CompactionManager.AllSSTableOpStatus
- ABORTED - org.apache.cassandra.db.monitoring.MonitoringState
- ABORTED - org.apache.cassandra.streaming.StreamSession.State
- ABORTED - org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional.State
- abortOrDie(SSTableMultiWriter) - Static method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
- abortRunnables(List<Flushing.FlushRunnable>, Throwable) - Static method in class org.apache.cassandra.db.memtable.Flushing
- aborts - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
- aborts - Variable in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Warnings
- ABOVE_LIMIT - org.apache.cassandra.net.ResourceLimits.Outcome
- abs(long) - Static method in class org.apache.cassandra.utils.FBUtilities
- abs(Number) - Method in class org.apache.cassandra.db.marshal.ByteType
- abs(Number) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
- abs(Number) - Method in class org.apache.cassandra.db.marshal.DecimalType
- abs(Number) - Method in class org.apache.cassandra.db.marshal.DoubleType
- abs(Number) - Method in class org.apache.cassandra.db.marshal.FloatType
- abs(Number) - Method in class org.apache.cassandra.db.marshal.Int32Type
- abs(Number) - Method in class org.apache.cassandra.db.marshal.IntegerType
- abs(Number) - Method in class org.apache.cassandra.db.marshal.LongType
- abs(Number) - Method in class org.apache.cassandra.db.marshal.NumberType
-
Takes the absolute value of the argument.
- abs(Number) - Method in class org.apache.cassandra.db.marshal.ShortType
- absFct(NumberType<?>) - Static method in class org.apache.cassandra.cql3.functions.MathFcts
- absolutePath() - Method in class org.apache.cassandra.io.util.File
- AbstractAllocatorMemtable - Class in org.apache.cassandra.db.memtable
-
A memtable that uses memory tracked and maybe allocated via a MemtableAllocator from a MemtablePool.
- AbstractAllocatorMemtable(AtomicReference<CommitLogPosition>, TableMetadataRef, Memtable.Owner) - Constructor for class org.apache.cassandra.db.memtable.AbstractAllocatorMemtable
- AbstractAnalyzer - Class in org.apache.cassandra.index.sai.analyzer
- AbstractAnalyzer - Class in org.apache.cassandra.index.sasi.analyzer
- AbstractAnalyzer() - Constructor for class org.apache.cassandra.index.sai.analyzer.AbstractAnalyzer
- AbstractAnalyzer() - Constructor for class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
- AbstractAnalyzer.AnalyzerFactory - Interface in org.apache.cassandra.index.sai.analyzer
- AbstractArrayClusteringPrefix - Class in org.apache.cassandra.db
- AbstractArrayClusteringPrefix(ClusteringPrefix.Kind, byte[][]) - Constructor for class org.apache.cassandra.db.AbstractArrayClusteringPrefix
- AbstractAwaitable() - Constructor for class org.apache.cassandra.utils.concurrent.Awaitable.AbstractAwaitable
- AbstractBlockPackedReader - Class in org.apache.cassandra.index.sai.disk.v1.bitpack
- AbstractBlockPackedWriter - Class in org.apache.cassandra.index.sai.disk.v1.bitpack
-
Modified copy of
org.apache.lucene.util.packed.AbstractBlockPackedWriter
to useDirectWriter
for optimised reads that doesn't require seeking through the whole file to open a thread-exclusive reader. - 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
- 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
- AbstractCIDRAuthorizer - Class in org.apache.cassandra.auth
-
Abstract CIDR authorizer, contains code common to all implementations of ICIDRAuthorizer
- AbstractCIDRAuthorizer() - Constructor for class org.apache.cassandra.auth.AbstractCIDRAuthorizer
- 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, long, 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
- AbstractCompletable<I> - Class in org.apache.cassandra.repair.state
- AbstractCompletable(Clock, I) - Constructor for class org.apache.cassandra.repair.state.AbstractCompletable
- AbstractCompletable.BasePhase - Class in org.apache.cassandra.repair.state
- AbstractCompletable.BaseSkipPhase - Class in org.apache.cassandra.repair.state
- AbstractCompletable.Status - Enum in org.apache.cassandra.repair.state
- 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
- AbstractCryptoProvider - Class in org.apache.cassandra.security
- AbstractCryptoProvider(Map<String, String>) - Constructor for class org.apache.cassandra.security.AbstractCryptoProvider
- 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
- AbstractFlushablePartitionSet() - Constructor for class org.apache.cassandra.db.memtable.AbstractMemtable.AbstractFlushablePartitionSet
- 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
- AbstractFuture<V> - Class in org.apache.cassandra.utils.concurrent
-
Our default
Future
implementation, with all state being managed without locks (except those used by the JVM). - AbstractFuture() - Constructor for class org.apache.cassandra.utils.concurrent.AbstractFuture
- AbstractFuture(GenericFutureListener<? extends Future<? super V>>) - Constructor for class org.apache.cassandra.utils.concurrent.AbstractFuture
- AbstractFuture(Throwable) - Constructor for class org.apache.cassandra.utils.concurrent.AbstractFuture
- AbstractFuture(AbstractFuture.FailureHolder) - Constructor for class org.apache.cassandra.utils.concurrent.AbstractFuture
- AbstractFuture(AbstractFuture.FailureHolder, GenericFutureListener<? extends Future<? super V>>) - Constructor for class org.apache.cassandra.utils.concurrent.AbstractFuture
- AbstractFuture(V) - Constructor for class org.apache.cassandra.utils.concurrent.AbstractFuture
- AbstractGettableData - Class in org.apache.cassandra.cql3.functions.types
- AbstractGuavaIterator<T> - Class in org.apache.cassandra.utils
-
This is fork of the Guava AbstractIterator, the only difference is that the next variable is now protected so that the KeyRangeIterator.skipTo method can avoid early state changed.
- AbstractGuavaIterator() - Constructor for class org.apache.cassandra.utils.AbstractGuavaIterator
-
Constructor for use by subclasses.
- AbstractGuavaIterator.State - Enum in org.apache.cassandra.utils
- AbstractIndexWriter(SortedTableWriter.Builder<?, ?, ?, ?>) - Constructor for class org.apache.cassandra.io.sstable.format.SortedTableWriter.AbstractIndexWriter
- AbstractIterator<V> - Class in org.apache.cassandra.utils
- AbstractIterator() - Constructor for class org.apache.cassandra.utils.AbstractIterator
- AbstractJmxClient - Class in org.apache.cassandra.tools
- AbstractJmxClient(String, Integer, String, String) - Constructor for class org.apache.cassandra.tools.AbstractJmxClient
- AbstractMarker - Class in org.apache.cassandra.cql3
-
A single bind marker.
- AbstractMarker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.AbstractMarker
- AbstractMarker.INRaw - Class in org.apache.cassandra.cql3
-
A raw placeholder for multiple values of the same type for a single column.
- AbstractMarker.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.
- AbstractMemtable - Class in org.apache.cassandra.db.memtable
- AbstractMemtable(TableMetadataRef) - Constructor for class org.apache.cassandra.db.memtable.AbstractMemtable
- AbstractMemtable(TableMetadataRef, long) - Constructor for class org.apache.cassandra.db.memtable.AbstractMemtable
- AbstractMemtable.AbstractFlushablePartitionSet<P extends Partition> - Class in org.apache.cassandra.db.memtable
- AbstractMemtable.ColumnsCollector - Class in org.apache.cassandra.db.memtable
- AbstractMemtable.StatsCollector - Class in org.apache.cassandra.db.memtable
- AbstractMemtableWithCommitlog - Class in org.apache.cassandra.db.memtable
-
Memtable that uses a commit log for persistence.
- AbstractMemtableWithCommitlog(TableMetadataRef, AtomicReference<CommitLogPosition>) - Constructor for class org.apache.cassandra.db.memtable.AbstractMemtableWithCommitlog
- 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.
- AbstractMetrics - Class in org.apache.cassandra.index.sai.metrics
- AbstractMetricsProviders<R extends SSTableReader> - Class in org.apache.cassandra.io.sstable
- AbstractMetricsProviders() - Constructor for class org.apache.cassandra.io.sstable.AbstractMetricsProviders
- AbstractMutableVirtualTable - Class in org.apache.cassandra.db.virtual
-
An abstract virtual table implementation that builds the resultset on demand and allows fine-grained source modification via INSERT/UPDATE, DELETE and TRUNCATE operations.
- AbstractMutableVirtualTable(TableMetadata) - Constructor for class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable
- AbstractMutableVirtualTable.ColumnValue - Class in org.apache.cassandra.db.virtual
-
A regular column value.
- AbstractMutableVirtualTable.ColumnValues - Class in org.apache.cassandra.db.virtual
-
A set of partition key or clustering column values.
- 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.v1
- AbstractPaxosCallback(int, ConsistencyLevel, Dispatcher.RequestTime) - Constructor for class org.apache.cassandra.service.paxos.v1.AbstractPaxosCallback
- AbstractPaxosRepair - Class in org.apache.cassandra.service.paxos
- AbstractPaxosRepair(DecoratedKey, Ballot) - Constructor for class org.apache.cassandra.service.paxos.AbstractPaxosRepair
- AbstractPaxosRepair.Failure - Class in org.apache.cassandra.service.paxos
- AbstractPaxosRepair.Listener - Interface in org.apache.cassandra.service.paxos
- AbstractPaxosRepair.Result - Class in org.apache.cassandra.service.paxos
- AbstractPaxosRepair.State - Class in org.apache.cassandra.service.paxos
- AbstractPaxosRepair.StateUpdater<S,I,T extends java.lang.Throwable> - Interface in org.apache.cassandra.service.paxos
- 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
- AbstractReader(FileDataInput, boolean) - Constructor for class org.apache.cassandra.io.sstable.AbstractSSTableIterator.AbstractReader
- 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,P>> - Class in org.apache.cassandra.service.reads.repair
- AbstractReadRepair(ReadCommand, ReplicaPlan.Shared<E, P>, Dispatcher.RequestTime) - Constructor for class org.apache.cassandra.service.reads.repair.AbstractReadRepair
- AbstractRepairTask - Class in org.apache.cassandra.repair
- AbstractRepairTask(RepairCoordinator) - Constructor for class org.apache.cassandra.repair.AbstractRepairTask
- 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 TODO flatten into AbstractReplicaCollection?
- 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
- AbstractRowIndexEntry - Class in org.apache.cassandra.io.sstable
-
The base RowIndexEntry is not stored on disk, only specifies a position in the data file
- AbstractRowIndexEntry(long) - Constructor for class org.apache.cassandra.io.sstable.AbstractRowIndexEntry
- AbstractSerializer() - Constructor for class org.apache.cassandra.utils.TimeUUID.AbstractSerializer
- AbstractShardedMemtable - Class in org.apache.cassandra.db.memtable
- AbstractSignal() - Constructor for class org.apache.cassandra.utils.concurrent.WaitQueue.Standard.AbstractSignal
- AbstractSslContextFactory - Class in org.apache.cassandra.security
-
Abstract class implementing
ISslContextFacotry
to provide most of the functionality that any implementation might need. - AbstractSslContextFactory() - Constructor for class org.apache.cassandra.security.AbstractSslContextFactory
- AbstractSslContextFactory(Map<String, Object>) - Constructor for class org.apache.cassandra.security.AbstractSslContextFactory
- AbstractSSTableFormat<R extends SSTableReader,W extends SSTableWriter> - Class in org.apache.cassandra.io.sstable.format
- AbstractSSTableFormat(String, Map<String, String>) - Constructor for class org.apache.cassandra.io.sstable.format.AbstractSSTableFormat
- AbstractSSTableIterator<RIE extends AbstractRowIndexEntry> - Class in org.apache.cassandra.io.sstable
- AbstractSSTableIterator(SSTableReader, FileDataInput, DecoratedKey, RIE, Slices, ColumnFilter, FileHandle) - Constructor for class org.apache.cassandra.io.sstable.AbstractSSTableIterator
- AbstractSSTableIterator.AbstractReader - Class in org.apache.cassandra.io.sstable
- AbstractSSTableIterator.ForwardReader - Class in org.apache.cassandra.io.sstable
- AbstractSSTableIterator.Reader - Interface in org.apache.cassandra.io.sstable
- AbstractState<T extends java.lang.Enum<T>,I> - Class in org.apache.cassandra.repair.state
- AbstractState(Clock, I, Class<T>) - Constructor for class org.apache.cassandra.repair.state.AbstractState
- AbstractState.UpdateType - Enum in org.apache.cassandra.repair.state
- 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
- AbstractTimeUUIDType<T> - Class in org.apache.cassandra.db.marshal
- 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
- AbstractType.DefaultArgumentDeserializer - Class in org.apache.cassandra.db.marshal
-
ArgumentDeserializer
that uses the type deserialization. - AbstractTypeSerializer - Class in org.apache.cassandra.serializers
- AbstractTypeSerializer() - Constructor for class org.apache.cassandra.serializers.AbstractTypeSerializer
- 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.ForWrite, Runnable, WriteType, Supplier<Mutation>, Dispatcher.RequestTime) - Constructor for class org.apache.cassandra.service.AbstractWriteResponseHandler
- accept() - Method in class org.apache.cassandra.repair.state.ParticipateState.Phase
- accept() - Method in class org.apache.cassandra.repair.state.SyncState.Phase
- accept() - Method in class org.apache.cassandra.repair.state.ValidationState.Phase
- accept(long, boolean, ArgType) - Method in interface org.apache.cassandra.io.sstable.format.bti.PartitionIndex.Acceptor
- accept(long, String) - Method in interface org.apache.cassandra.utils.memory.HeapPool.Logged.Listener
- accept(long, TimeUnit) - Method in class org.apache.cassandra.metrics.MessagingMetrics.DCLatencyRecorder
- accept(long, TimeUnit) - Method in interface org.apache.cassandra.net.LatencyConsumer
- accept(A, B) - Method in interface org.apache.cassandra.utils.FailingBiConsumer
- accept(A, B, C) - Method in interface org.apache.cassandra.db.SystemKeyspace.TriFunction
- accept(ByteBuffer) - Method in interface org.apache.cassandra.net.AsyncStreamingInputPlus.Consumer
- accept(Path) - Method in interface org.apache.cassandra.io.util.PathUtils.IOConsumer
- accept(Message<?>) - Method in class org.apache.cassandra.net.InboundSink
- 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.concurrent.ConditionAsConsumer
- accept(T) - Method in interface org.apache.cassandra.utils.FailingConsumer
- ACCEPT - org.apache.cassandra.repair.state.ParticipateState.Job.State
- ACCEPT - org.apache.cassandra.repair.state.SyncState.State
- ACCEPT - org.apache.cassandra.repair.state.ValidationState.State
- ACCEPT_INCREMENT - Static variable in class org.apache.cassandra.service.paxos.PaxosPropose
- accepted - Variable in class org.apache.cassandra.service.paxos.PaxosState.Snapshot
- accepted() - Method in class org.apache.cassandra.service.paxos.Commit.Proposal
- Accepted(Ballot, PartitionUpdate) - Constructor for class org.apache.cassandra.service.paxos.Commit.Accepted
- Accepted(Commit) - Constructor for class org.apache.cassandra.service.paxos.Commit.Accepted
- ACCEPTED - org.apache.cassandra.repair.state.AbstractCompletable.Status
- ACCEPTED - org.apache.cassandra.repair.state.AbstractState.UpdateType
- ACCEPTED - org.apache.cassandra.repair.state.ParticipateState.RegisterStatus
- accepted_protocols - Variable in class org.apache.cassandra.config.EncryptionOptions
- accepted_protocols - Variable in class org.apache.cassandra.security.AbstractSslContextFactory
- ACCEPTED_PROTOCOLS - org.apache.cassandra.config.EncryptionOptions.ConfigKey
- acceptedCidrAccessCount - Variable in class org.apache.cassandra.metrics.CIDRAuthorizerMetrics
- acceptedProtocolsArray() - Method in class org.apache.cassandra.config.EncryptionOptions
- AcceptedWithTTL(Ballot, PartitionUpdate, long) - Constructor for class org.apache.cassandra.service.paxos.Commit.AcceptedWithTTL
- AcceptedWithTTL(Commit, long) - Constructor for class org.apache.cassandra.service.paxos.Commit.AcceptedWithTTL
- acceptIfLatest(Commit.Proposal) - Method in class org.apache.cassandra.service.paxos.PaxosState
-
Record an acceptance of the proposal if there is no newer promise; otherwise inform the caller of the newer ballot
- acceptMessaging - Variable in class org.apache.cassandra.net.InboundConnectionSettings
- acceptOrFail(A, B) - Method in interface org.apache.cassandra.utils.FailingBiConsumer
- accepts(TypeToken<?>) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec
-
Return
true
if this codec is capable of serializing the givenjavaType
. - accepts(Class<?>) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec
-
Return
true
if this codec is capable of serializing the givenjavaType
. - 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(Object) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec
-
Return
true
if this codec is capable of serializing the given object. - accepts(DataType) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractTupleCodec
- accepts(DataType) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec
-
Return
true
if this codec is capable of deserializing the givencqlType
. - accepts(OpOrder.Group, CommitLogPosition) - Method in class org.apache.cassandra.db.memtable.AbstractMemtableWithCommitlog
- accepts(OpOrder.Group, CommitLogPosition) - Method in interface org.apache.cassandra.db.memtable.Memtable
-
Decide if this memtable should take a write with the given parameters, or if the write should go to the next 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(Object[], BiLongAccumulator<A, V>, A, long) - Static method in class org.apache.cassandra.utils.btree.BTree
- 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>, long) - Static method in class org.apache.cassandra.utils.btree.BTree
- accumulate(Object[], LongAccumulator<V>, Comparator<V>, V, long) - Static method in class org.apache.cassandra.utils.btree.BTree
- accumulate(BiLongAccumulator<A, Cell<?>>, A, long) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
- accumulate(BiLongAccumulator<A, ColumnData>, A, long) - Method in class org.apache.cassandra.db.rows.BTreeRow
- 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 class org.apache.cassandra.db.rows.BTreeRow
- accumulate(BiLongAccumulator<A, ColumnData>, A, Comparator<ColumnData>, ColumnData, long) - Method in interface org.apache.cassandra.db.rows.Row
- accumulate(LongAccumulator<Cell<?>>, long) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
- accumulate(LongAccumulator<ColumnData>, long) - Method in class org.apache.cassandra.db.rows.BTreeRow
- 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 class org.apache.cassandra.db.rows.BTreeRow
- accumulate(LongAccumulator<ColumnData>, Comparator<ColumnData>, ColumnData, long) - Method in interface org.apache.cassandra.db.rows.Row
- accumulate(T, LongAccumulator<T>, long) - Static method in class org.apache.cassandra.utils.concurrent.IntrusiveStack
- accumulator() - Method in class org.apache.cassandra.utils.concurrent.Threads.StackTraceCombiner
- 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
- ACK - org.apache.cassandra.streaming.StreamSession.PrepareDirection
- 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 interface org.apache.cassandra.streaming.StreamingDataOutputPlus.RateLimiter
- acquire(int) - Method in class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
- acquire(int) - Method in interface org.apache.cassandra.utils.concurrent.Semaphore
-
Take permits, waiting indefinitely until available
- ACQUIRE_RETRY_SECONDS - org.apache.cassandra.config.CassandraRelevantProperties
- ACQUIRE_SLEEP_MS - org.apache.cassandra.config.CassandraRelevantProperties
- acquireCapacity(ResourceLimits.Limit, ResourceLimits.Limit, int) - Method in class org.apache.cassandra.net.AbstractMessageHandler
- acquireCapacity(ResourceLimits.Limit, ResourceLimits.Limit, int, long, long) - Method in class org.apache.cassandra.net.AbstractMessageHandler
-
Try to acquire permits for the inbound message.
- acquireLockFor(int) - Static method in class org.apache.cassandra.db.view.ViewManager
- acquireOut() - Method in class org.apache.cassandra.streaming.async.NettyStreamingChannel
- acquireOut() - Method in interface org.apache.cassandra.streaming.StreamingChannel
-
until closed, cannot invoke
StreamingChannel.send(Send)
- acquireReference() - Method in class org.apache.cassandra.tracing.TraceState
- acquireSSTables() - Method in class org.apache.cassandra.db.repair.PendingAntiCompaction.AcquisitionCallable
- acquireThrowUncheckedOnInterrupt(int) - Method in interface org.apache.cassandra.utils.concurrent.Semaphore
-
Take permits, waiting indefinitely until available
- acquireThrowUncheckedOnInterrupt(int) - Method in class org.apache.cassandra.utils.concurrent.Semaphore.Standard
- AcquisitionCallable(ColumnFamilyStore, Collection<Range<Token>>, TimeUUID, int, int) - Constructor for class org.apache.cassandra.db.repair.PendingAntiCompaction.AcquisitionCallable
- activate() - Method in class org.apache.cassandra.service.CassandraDaemon
-
A convenience method to initialize and start the daemon in one shot.
- 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.
- active - Variable in class org.apache.cassandra.db.compaction.CompactionManager
- ACTIVE - org.apache.cassandra.tracing.TraceState.Status
- ACTIVE - Static variable in class org.apache.cassandra.service.paxos.PaxosState
- 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
- activeMemtables() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
- ActiveRepairService - Class in org.apache.cassandra.service
-
ActiveRepairService is the starting point for manual "active" repairs.
- ActiveRepairService() - Constructor for class org.apache.cassandra.service.ActiveRepairService
- ActiveRepairService(SharedContext) - 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.See CASSANDRA-11174
- activeTasks - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
Number of active tasks.
- ADAPTIVE - org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator.Strategy
- add(int) - Method in class org.apache.cassandra.io.tries.Walker.TransitionBytesCollector
- add(int, float[]) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.ConcurrentVectorValues
-
return approximate bytes used by the new vector
- 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 givenCalendar
field, based on the calendar's rules. - add(int, int) - Method in class org.apache.cassandra.utils.IntegerInterval.Set
-
Adds an interval to the set, performing the necessary normalization.
- add(int, ByteBuffer) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.CompactionVectorValues
-
return approximate bytes used by the new vector
- add(int, ColumnSpecification) - Method in class org.apache.cassandra.cql3.VariableSpecifications
- 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(int, V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
- add(long) - Method in class org.apache.cassandra.index.sai.disk.v1.bitpack.AbstractBlockPackedWriter
-
Append a new long.
- add(long) - Method in class org.apache.cassandra.index.sai.disk.v1.bitpack.MonotonicBlockPackedWriter
- add(long) - Method in class org.apache.cassandra.index.sai.disk.v1.bitpack.NumericValuesWriter
- add(long) - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
Increments the count of the bucket closest to n, rounding UP.
- add(long) - Method in class org.apache.cassandra.utils.HistogramBuilder
- add(long, long) - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
Increments the count of the bucket closest to n, rounding UP by delta
- add(LoggingEvent) - Method in class org.apache.cassandra.db.virtual.LogMessagesTable
- add(E) - Method in class org.apache.cassandra.utils.concurrent.Accumulator
-
Adds an item to the collection.
- add(Iterable<? extends UserFunction>) - Method in class org.apache.cassandra.schema.UserFunctions.Builder
- add(Iterable<UserType>) - Method in class org.apache.cassandra.schema.Types.Builder
- add(Iterable<KeyRangeIterator>) - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator.Builder
- add(Iterable<IndexMetadata>) - Method in class org.apache.cassandra.schema.Indexes.Builder
- add(Iterable<KeyspaceMetadata>) - Method in class org.apache.cassandra.schema.Keyspaces.Builder
- add(Iterable<TableMetadata>) - Method in class org.apache.cassandra.schema.Tables.Builder
- add(Iterable<TriggerMetadata>) - Method in class org.apache.cassandra.schema.Triggers.Builder
- add(Long, long) - Method in class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
- add(Long, long) - Method in class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
- add(Long, long) - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
- add(Long, AbstractTokenTreeBuilder.InteriorNode, AbstractTokenTreeBuilder.InteriorNode) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
- add(Number, Number) - Method in class org.apache.cassandra.db.marshal.ByteType
- add(Number, Number) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
- add(Number, Number) - Method in class org.apache.cassandra.db.marshal.DecimalType
- add(Number, Number) - Method in class org.apache.cassandra.db.marshal.DoubleType
- add(Number, Number) - Method in class org.apache.cassandra.db.marshal.FloatType
- add(Number, Number) - Method in class org.apache.cassandra.db.marshal.Int32Type
- add(Number, Number) - Method in class org.apache.cassandra.db.marshal.IntegerType
- add(Number, Number) - Method in class org.apache.cassandra.db.marshal.LongType
- add(Number, Number) - Method in class org.apache.cassandra.db.marshal.NumberType
-
Adds the left argument to the right one.
- add(Number, Number) - Method in class org.apache.cassandra.db.marshal.ShortType
- add(Object) - Method in class org.apache.cassandra.db.CBuilder
- add(Object[], int, int) - Method in class org.apache.cassandra.utils.btree.BTree.FastBuilder
- add(String) - Method in class org.apache.cassandra.auth.CIDRPermissions.Builder
- add(String) - Method in class org.apache.cassandra.auth.DCPermissions.Builder
- add(String...) - Method in class org.apache.cassandra.tools.nodetool.formatter.TableBuilder
- 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(String, String) - Method in class org.apache.cassandra.locator.SnitchProperties
- add(String, String, Map<String, Float>) - Method in class org.apache.cassandra.tools.nodetool.SetHostStatWithPort
- add(String, String, Map<InetAddress, Float>) - Method in class org.apache.cassandra.tools.nodetool.SetHostStat
- add(String, List<String>, List<String>) - Method in class org.apache.cassandra.schema.Types.RawBuilder
- add(String, FilterPipeline.Task) - Method in class org.apache.cassandra.index.sai.analyzer.filter.FilterPipeline
- add(String, FilterPipelineTask<?, ?>) - Method in class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineBuilder
- add(ByteBuffer) - Method in class org.apache.cassandra.cql3.selection.ResultSetBuilder
- add(ByteBuffer) - Method in class org.apache.cassandra.cql3.selection.Selector.InputRow
- add(ByteBuffer) - Method in class org.apache.cassandra.db.CBuilder
- 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(ByteBuffer, PrimaryKey, long) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder
- add(ByteBuffer, TokenTreeBuilder) - Method in class org.apache.cassandra.index.sasi.sa.SA
- add(ByteBuffer, T, OnHeapGraph.InvalidVectorBehavior) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.OnHeapGraph
- add(Collection<RowFilter.Expression>) - Method in class org.apache.cassandra.index.sasi.plan.Operation.Builder
- add(Collection<Range<Token>>, long) - Method in class org.apache.cassandra.repair.consistent.RepairedState
- add(Collection<Range<Token>>, Ballot, boolean) - Method in class org.apache.cassandra.service.paxos.TablePaxosRepairHistory
- add(BiPredicate<Message<?>, InetAddressAndPort>) - Method in class org.apache.cassandra.net.OutboundSink
- add(Predicate<Message<?>>) - Method in class org.apache.cassandra.net.InboundSink
- add(Iterator<Pair<Long, LongSet>>) - Method in class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
- add(Iterator<Pair<Long, LongSet>>) - Method in class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
- add(Iterator<Pair<Long, LongSet>>) - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
- add(List<String>) - Method in class org.apache.cassandra.tools.nodetool.formatter.TableBuilder
- add(List<RangeIterator<K, D>>) - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
- add(SortedMap<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.StaticTokenTreeBuilder
- add(SortedMap<Long, LongSet>) - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
- add(CIDR, V) - Method in class org.apache.cassandra.auth.CIDRGroupsMappingTable.Builder
- add(ColumnIdentifier, CQL3Type.Raw, boolean, ColumnMask.Raw) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
- add(ColumnCondition) - Method in class org.apache.cassandra.cql3.conditions.ColumnConditions.Builder
-
Adds the specified
ColumnCondition
to this set of conditions. - add(FieldIdentifier, CQL3Type.Raw) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTypeStatement.Raw
- add(FunctionFactory) - Method in class org.apache.cassandra.cql3.functions.NativeFunctions
- add(NativeFunction) - Method in class org.apache.cassandra.cql3.functions.NativeFunctions
- add(UserFunction) - Method in class org.apache.cassandra.schema.UserFunctions.Builder
- add(UserFunction...) - Method in class org.apache.cassandra.schema.UserFunctions.Builder
- add(Operation) - Method in class org.apache.cassandra.cql3.Operations
-
Adds the specified
Operation
to this set of operations. - add(Operator, ByteBuffer) - Method in class org.apache.cassandra.index.sai.plan.Expression
-
This adds an operation to the current
Expression
instance and returns the current instance. - add(Operator, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.plan.Expression
- add(Relation) - Method in class org.apache.cassandra.cql3.WhereClause.Builder
- add(CustomIndexExpression) - Method in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
- add(CustomIndexExpression) - Method in class org.apache.cassandra.cql3.WhereClause.Builder
- add(Restrictions) - Method in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
- add(ClusteringBound<?>, ClusteringBound<?>) - Method in class org.apache.cassandra.db.Slices.Builder
- add(ClusteringPrefix<V>, int) - Method in class org.apache.cassandra.db.CBuilder
- add(ColumnFamilyStoreMBean) - Method in class org.apache.cassandra.tools.nodetool.stats.StatsKeyspace
- 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(DecoratedKey, Clustering<?>, ByteBuffer) - Method in class org.apache.cassandra.index.sai.memory.MemoryIndex
- add(DecoratedKey, Clustering<?>, ByteBuffer) - Method in class org.apache.cassandra.index.sai.memory.TrieMemoryIndex
-
Adds an index value to the in-memory index
- add(DecoratedKey, Clustering<?>, ByteBuffer) - Method in class org.apache.cassandra.index.sai.memory.VectorMemoryIndex
- add(DeletionInfo) - Method in class org.apache.cassandra.db.MutableDeletionInfo
-
Combines another DeletionInfo with this one and returns the result.
- 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(RowFilter.Expression) - Method in class org.apache.cassandra.index.sasi.plan.Operation.Builder
- add(UserType) - Method in class org.apache.cassandra.schema.Types.Builder
- add(UserType...) - Method in class org.apache.cassandra.schema.Types.Builder
- add(Mutation) - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Add a Mutation to the commit log.
- add(PartitionUpdate) - Method in class org.apache.cassandra.db.Mutation.PartitionUpdateCollector
- add(RangeTombstone) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
- add(RangeTombstone) - Method in class org.apache.cassandra.db.RangeTombstoneList
- add(RangeTombstone, ClusteringComparator) - Method in class org.apache.cassandra.db.MutableDeletionInfo
- add(Cell<?>, long) - Method in class org.apache.cassandra.cql3.selection.ResultSetBuilder
- add(ColumnData, long) - Method in class org.apache.cassandra.cql3.selection.ResultSetBuilder
- add(ColumnData, long) - Method in class org.apache.cassandra.cql3.selection.Selector.InputRow
- add(RangeTombstoneMarker) - Method in class org.apache.cassandra.db.MutableDeletionInfo.Builder
- add(Row) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
-
Adds a row to this update.
- add(UnfilteredRowIterator) - Method in class org.apache.cassandra.repair.Validator
-
Called (in order) for every row present in the CF.
- add(Slice) - Method in class org.apache.cassandra.db.Slices.Builder
- add(View) - Method in class org.apache.cassandra.db.view.TableViews
- add(KeyRangeIterator) - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeConcatIterator.Builder
- add(KeyRangeIterator) - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIntersectionIterator.Builder
- add(KeyRangeIterator) - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator.Builder
- add(KeyRangeIterator) - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeUnionIterator.Builder
- add(PrimaryKey) - Method in class org.apache.cassandra.index.sai.utils.PrimaryKeys
-
Adds a
PrimaryKey
and returns the on-heap memory used if the key was added - add(PrimaryKey, long) - Method in class org.apache.cassandra.index.sai.disk.RowMapping
-
Include PrimaryKey to RowId mapping
- add(AbstractTokenTreeBuilder.Leaf) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
- add(TokenTreeBuilder) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
- add(TokenTreeBuilder) - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
- add(SSTableIndex) - Method in class org.apache.cassandra.index.sasi.conf.view.TermTree.Builder
- add(RangeIterator<K, D>) - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
- add(Memory) - Method in class org.apache.cassandra.utils.concurrent.Ref.IdentityCollection
- 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(InetAddressAndPort, long, TimeUnit) - Method in class org.apache.cassandra.net.LatencySubscribers
- 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(Replica) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
- add(Replica) - Method in class org.apache.cassandra.locator.RangesAtEndpoint.Builder
- add(Replica) - Method in interface org.apache.cassandra.locator.ReplicaCollection.Builder
- 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, 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(ParamType, Object) - Static method in class org.apache.cassandra.db.MessageParams
- add(CleanupSummary, CleanupSummary) - Static method in class org.apache.cassandra.repair.consistent.admin.CleanupSummary
- add(ColumnMetadata) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Builder
- add(ColumnMetadata) - Method in class org.apache.cassandra.db.RegularAndStaticColumns.Builder
- add(ColumnMetadata, Operator, ByteBuffer) - Method in class org.apache.cassandra.db.filter.RowFilter
- add(IndexMetadata) - Method in class org.apache.cassandra.schema.Indexes.Builder
- add(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(TableMetadata) - Method in class org.apache.cassandra.schema.Tables.Builder
- add(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(PaxosRepairHistory, Collection<Range<Token>>, Ballot) - Static method in class org.apache.cassandra.service.paxos.PaxosRepairHistory
- add(ByteComparable) - Method in class org.apache.cassandra.index.sai.disk.v1.keystore.KeyStoreWriter
-
Appends a key at the end of the sequence.
- add(ByteComparable, int, int) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentTrieBuffer
- add(ByteComparable, long) - Method in class org.apache.cassandra.index.sai.disk.v1.trie.TrieTermsDictionaryWriter
- add(ByteComparable, VALUE) - Method in interface org.apache.cassandra.io.tries.IncrementalTrieWriter
-
Add an entry to the trie with the associated value.
- add(ByteComparable, VALUE) - Method in class org.apache.cassandra.io.tries.IncrementalTrieWriterBase
- 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(IFilter.FilterKey) - Method in class org.apache.cassandra.utils.BloomFilter
- add(IFilter.FilterKey) - Method in interface org.apache.cassandra.utils.IFilter
- add(T) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.VectorPostings
- add(T) - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- add(T) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
- add(T, T) - Method in class org.apache.cassandra.db.commitlog.IntervalSet.Builder
-
Add an interval to the set and perform normalization.
- add(V) - Method in class org.apache.cassandra.utils.btree.BTree.Builder
- add(V) - Method in class org.apache.cassandra.utils.btree.BTree.FastBuilder
- add(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
- add(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet.Builder
- add(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.CBuilder
- addAll(int, Collection<? extends V>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
- addAll(Iterable<Replica>) - Method in interface org.apache.cassandra.locator.ReplicaCollection.Builder
- addAll(Iterable<Replica>, ReplicaCollection.Builder.Conflict) - Method in interface org.apache.cassandra.locator.ReplicaCollection.Builder
- addAll(Iterable<ColumnMetadata>) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Builder
- addAll(Iterable<ColumnMetadata>) - Method in class org.apache.cassandra.db.RegularAndStaticColumns.Builder
- addAll(Collection<? extends T>) - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- addAll(Collection<? extends T>) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
- addAll(Collection<? extends V>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
- addAll(Collection<V>) - Method in class org.apache.cassandra.utils.btree.BTree.Builder
- addAll(Collection<V>) - Method in class org.apache.cassandra.utils.btree.BTreeSet.Builder
- addAll(Iterator<MerkleTree.RowHash>) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
- addAll(List<RepairedState.Level>) - Method in class org.apache.cassandra.repair.consistent.RepairedState
- addAll(NativeFunction...) - Method in class org.apache.cassandra.cql3.functions.NativeFunctions
- addAll(IntervalSet<T>) - Method in class org.apache.cassandra.db.commitlog.IntervalSet.Builder
- addAll(PartitionUpdate, Cloner, OpOrder.Group, UpdateTransaction) - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
-
Adds a given update to this in-memtable partition.
- addAll(RangeTombstoneList) - Method in class org.apache.cassandra.db.RangeTombstoneList
-
Adds all the range tombstones of
tombstones
to this RangeTombstoneList. - addAll(RegularAndStaticColumns) - Method in class org.apache.cassandra.db.RegularAndStaticColumns.Builder
- addAll(Slices) - Method in class org.apache.cassandra.db.Slices.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
- 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.
- 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.
- addBootstrapTokens(Collection<Token>, InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
- addBytes(ByteBuffer, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
- addCallback(FutureCallback<? super V>) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
-
Support
Futures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)
natively SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics. - addCallback(FutureCallback<? super V>) - Method in class org.apache.cassandra.utils.concurrent.AsyncPromise
- addCallback(FutureCallback<? super V>) - Method in interface org.apache.cassandra.utils.concurrent.Future
-
Support
Futures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)
natively - addCallback(FutureCallback<? super V>) - Method in interface org.apache.cassandra.utils.concurrent.Promise
- addCallback(FutureCallback<? super V>) - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
- addCallback(FutureCallback<? super V>, Executor) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
-
Support
Futures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)
natively SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics. - addCallback(FutureCallback<? super V>, Executor) - Method in class org.apache.cassandra.utils.concurrent.AsyncPromise
- addCallback(FutureCallback<? super V>, Executor) - Method in interface org.apache.cassandra.utils.concurrent.Future
-
Support
Futures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)
natively - addCallback(FutureCallback<? super V>, Executor) - Method in interface org.apache.cassandra.utils.concurrent.Promise
- addCallback(FutureCallback<? super V>, Executor) - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
- addCallback(BiConsumer<? super V, Throwable>) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
-
Support
Futures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)
natively SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics. - addCallback(BiConsumer<? super V, Throwable>) - Method in interface org.apache.cassandra.utils.concurrent.Future
-
Support
Futures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)
natively - addCallback(BiConsumer<? super V, Throwable>, Executor) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- addCallback(BiConsumer<? super V, Throwable>, Executor) - Method in interface org.apache.cassandra.utils.concurrent.Future
-
Support
Futures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)
natively - addCallback(Consumer<? super V>, Consumer<? super Throwable>) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
-
Support more fluid version of
Futures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)
SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics. - addCallback(Consumer<? super V>, Consumer<? super Throwable>) - Method in class org.apache.cassandra.utils.concurrent.AsyncPromise
- addCallback(Consumer<? super V>, Consumer<? super Throwable>) - Method in interface org.apache.cassandra.utils.concurrent.Future
-
Support
Futures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)
natively - addCallback(Consumer<? super V>, Consumer<? super Throwable>) - Method in interface org.apache.cassandra.utils.concurrent.Promise
- addCallback(Consumer<? super V>, Consumer<? super Throwable>) - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
- addCallback(Consumer<? super V>, Consumer<? super Throwable>, Executor) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
-
Support more fluid version of
Futures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)
SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics. - addCallback(Consumer<? super V>, Consumer<? super Throwable>, Executor) - Method in interface org.apache.cassandra.utils.concurrent.Future
-
Support
Futures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)
natively - 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(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.
- addCell(ColumnMetadata, ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
- addCell(ColumnMetadata, CellPath, ByteBuffer) - Method in class org.apache.cassandra.cql3.UpdateParameters
- addCellPerPartitionCount() - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- addCellPerPartitionCount(long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- addClassPath(File) - Method in class org.apache.cassandra.triggers.CustomClassLoader
- addCleanupHistory(Message<PaxosCleanupHistory>) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosRepairState
- addClusteringColumn(String, AbstractType<?>) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- addClusteringColumn(String, AbstractType<?>, ColumnMask) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- addClusteringColumn(ColumnIdentifier, AbstractType<?>) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- addClusteringColumn(ColumnIdentifier, AbstractType<?>, ColumnMask) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- addCmdOption(String, String, boolean, String) - Static method in class org.apache.cassandra.tools.AbstractJmxClient
- addColumn(String, String) - Method in class org.apache.cassandra.metrics.SamplingManager.ResultBuilder
- addColumn(ColumnIdentifier, CQL3Type.Raw, boolean, ColumnMask.Raw) - 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(DeletionTime) - Method in class org.apache.cassandra.db.rows.ComplexColumnData.Builder
- addComplexDeletion(ColumnMetadata, DeletionTime) - Method in class org.apache.cassandra.db.rows.BTreeRow.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.
- addComponents(Collection<Component>) - Method in class org.apache.cassandra.io.sstable.SSTable.Builder
- 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
- addDefaultComponents(Collection<Index.Group>) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter.Builder
- addDefaultComponents(Collection<Index.Group>) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter.Builder
- addDefaultComponents(Collection<Index.Group>) - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter.Builder
- addDefaultComponents(Collection<Index.Group>) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- 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(Number, Duration) - Method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- addDuration(Number, Duration) - Method in class org.apache.cassandra.db.marshal.TemporalType
-
Adds the duration to the specified value.
- 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 theColumnFamilyStore
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
- addFalsePositive() - Method in class org.apache.cassandra.io.sstable.filter.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
- addFetchedColumns(ColumnFilter.Builder) - Method in class org.apache.cassandra.cql3.selection.VectorSelector
- 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.AnnRestriction
- 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
- addFunctionsTo(List<Function>) - Method in class org.apache.cassandra.cql3.Vectors.DelayedValue
- addFunctionsTo(List<Function>) - Method in interface org.apache.cassandra.db.aggregation.AggregationSpecification.Factory
- addFunctionsTo(NativeFunctions) - Static method in class org.apache.cassandra.cql3.functions.AggregateFcts
- addFunctionsTo(NativeFunctions) - Static method in class org.apache.cassandra.cql3.functions.BytesConversionFcts
- addFunctionsTo(NativeFunctions) - Static method in class org.apache.cassandra.cql3.functions.CastFcts
- addFunctionsTo(NativeFunctions) - Static method in class org.apache.cassandra.cql3.functions.CollectionFcts
- addFunctionsTo(NativeFunctions) - Static method in class org.apache.cassandra.cql3.functions.FromJsonFct
- addFunctionsTo(NativeFunctions) - Static method in class org.apache.cassandra.cql3.functions.masking.MaskingFcts
-
Adds all the available native data masking functions to the specified native functions.
- addFunctionsTo(NativeFunctions) - Static method in class org.apache.cassandra.cql3.functions.MathFcts
- addFunctionsTo(NativeFunctions) - Static method in class org.apache.cassandra.cql3.functions.OperationFcts
- addFunctionsTo(NativeFunctions) - Static method in class org.apache.cassandra.cql3.functions.TimeFcts
- addFunctionsTo(NativeFunctions) - Static method in class org.apache.cassandra.cql3.functions.ToJsonFct
- addFunctionsTo(NativeFunctions) - Static method in class org.apache.cassandra.cql3.functions.TokenFct
- addFunctionsTo(NativeFunctions) - Static method in class org.apache.cassandra.cql3.functions.UuidFcts
- addFunctionsTo(NativeFunctions) - Static method in class org.apache.cassandra.cql3.functions.VectorFcts
- addHash(MerkleTree.RowHash) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
- addHistogram(long[], long[]) - Static method in class org.apache.cassandra.metrics.TableMetrics
- addIdentity(String, String) - Method in class org.apache.cassandra.auth.CassandraRoleManager
- addIdentity(String, String) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Adds a row (identity, role) to the identity_to_role table
- AddIdentityStatement - Class in org.apache.cassandra.cql3.statements
-
Cqlsh statement to add identity into roles_to_identity table for storing authorized identities for mTLS connections.
- AddIdentityStatement(String, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.AddIdentityStatement
- 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(Index) - Method in interface org.apache.cassandra.index.Index.Group
-
Adds the specified
Index
as a member of this group. - addIndex(Index) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- 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, TableMetadataRef, ColumnMetadata) - Method in class org.apache.cassandra.index.internal.keys.KeysIndex
- 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.
- 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(Arguments) - Method in interface org.apache.cassandra.cql3.functions.AggregateFunction.Aggregate
-
Adds the specified input to this aggregate.
- addInput(Selector.InputRow) - Method in class org.apache.cassandra.cql3.selection.Selector
-
Add the current value from the specified
ResultSetBuilder
. - addInput(Selector.InputRow) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
- addInput(Selector.InputRow) - Method in class org.apache.cassandra.cql3.selection.TermSelector
- addInput(Selector.InputRow) - Method in class org.apache.cassandra.cql3.selection.VectorSelector
- addInputRow(Selector.InputRow) - Method in interface org.apache.cassandra.cql3.selection.Selection.Selectors
-
Adds the current row of the specified
ResultSetBuilder
. - addInternal(ByteBuffer, int) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder
- addInternal(ByteBuffer, int) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder.TrieSegmentBuilder
- addInternal(ByteBuffer, int) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder.VectorSegmentBuilder
- Addition(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.Addition
- ADDITIONAL_WRITE_POLICY - org.apache.cassandra.schema.TableParams.Option
- 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
- additionalWriteLatencyMicros - Variable in class org.apache.cassandra.db.ColumnFamilyStore
- additionalWriteLatencyNanos - Variable in class org.apache.cassandra.metrics.TableMetrics
- additionalWritePolicy - Variable in class org.apache.cassandra.schema.TableParams
- additionalWritePolicy(SpeculativeRetryPolicy) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- 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
- addKeyspace(KeyspaceMetadata, boolean) - Static method in class org.apache.cassandra.schema.SchemaTransformations
-
Creates a schema transformation that adds the provided keyspace.
- addKeyToDenylist(String, String, ByteBuffer) - Method in class org.apache.cassandra.schema.PartitionDenylist
-
We expect the caller to confirm that we are working with a valid keyspace and table.
- 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.FutureDelegate
- addListener(GenericFutureListener<? extends Future<? super V>>) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
-
Add a listener to be invoked once this future completes.
- addListener(GenericFutureListener<? extends Future<? super V>>) - Method in class org.apache.cassandra.utils.concurrent.AsyncPromise
- addListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface org.apache.cassandra.utils.concurrent.Future
- addListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface org.apache.cassandra.utils.concurrent.Promise
- addListener(GenericFutureListener<? extends Future<? super V>>) - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
- addListener(Runnable) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
-
Add a listener to be invoked once this future completes.
- addListener(Runnable) - Method in interface org.apache.cassandra.utils.concurrent.Future
-
Invoke
runnable
on completion. - addListener(Runnable, Executor) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
-
Add a listener to be invoked once this future completes.
- addListener(Runnable, Executor) - Method in interface org.apache.cassandra.utils.concurrent.Future
-
Invoke
runnable
on completion, usingexecutor
. - addListener(Consumer<AbstractPaxosRepair.Result>) - Method in class org.apache.cassandra.service.paxos.AbstractPaxosRepair
- addListener(AbstractPaxosRepair.Listener) - Method in class org.apache.cassandra.service.paxos.AbstractPaxosRepair
-
add a listener to this repair, or if the repair has already completed, call the listener with the result
- addListener(StreamManager.StreamListener) - Method in class org.apache.cassandra.streaming.StreamManager
- 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.FutureDelegate
- addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class org.apache.cassandra.utils.concurrent.AsyncPromise
- addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface org.apache.cassandra.utils.concurrent.Future
- addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface org.apache.cassandra.utils.concurrent.Promise
- addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
- 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, Iterable<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
- addMapping(ColumnSpecification, ColumnMetadata) - Method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
- addMemoryUsageTo(Memtable.MemoryUsage) - Method in class org.apache.cassandra.db.memtable.AbstractAllocatorMemtable
- addMemoryUsageTo(Memtable.MemoryUsage) - Method in interface org.apache.cassandra.db.memtable.Memtable
-
Add this memtable's used memory to the given usage object.
- addMerkleTree(int, byte, Range<Token>) - Method in class org.apache.cassandra.utils.MerkleTrees
- addMerkleTree(int, Range<Token>) - Method in class org.apache.cassandra.utils.MerkleTrees
-
Add a MerkleTree with the defined size and range.
- 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.service.StorageService
- 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) - Method in class org.apache.cassandra.tools.BulkLoader.CmdLineOptions
-
Add option without argument
- addOption(String, String, String, String) - Method in class org.apache.cassandra.tools.BulkLoader.CmdLineOptions
-
Add option with argument and argument name
- 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(String, AbstractType<?>, ColumnMask) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- addPartitionKeyColumn(ColumnIdentifier, AbstractType<?>) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- addPartitionKeyColumn(ColumnIdentifier, AbstractType<?>, ColumnMask) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- addPartitionSizeInBytes(long) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- addPathByte(int) - Method in interface org.apache.cassandra.db.tries.Trie.TransitionsReceiver
-
Add a single byte to the path.
- addPathByte(int) - Method in interface org.apache.cassandra.db.tries.Trie.ValueConsumer
- addPathByte(int) - Method in class org.apache.cassandra.db.tries.TriePathReconstructor
- addPathBytes(DirectBuffer, int, int) - Method in interface org.apache.cassandra.db.tries.Trie.TransitionsReceiver
-
Add the count bytes from position pos in the given buffer.
- addPathBytes(DirectBuffer, int, int) - Method in interface org.apache.cassandra.db.tries.Trie.ValueConsumer
- addPathBytes(DirectBuffer, int, int) - Method in class org.apache.cassandra.db.tries.TriePathReconstructor
- 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.RepairCoordinator
- 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() - Method in class org.apache.cassandra.db.SimpleBuilders.PartitionUpdateBuilder
- addRangeTombstone(RangeTombstone) - Method in interface org.apache.cassandra.db.partitions.PartitionUpdate.SimpleBuilder
-
Adds a new range tombstone to this update
- addRangeTombstone(RangeTombstone) - Method in class org.apache.cassandra.db.SimpleBuilders.PartitionUpdateBuilder
- addRegularColumn(String, AbstractType<?>) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- addRegularColumn(String, AbstractType<?>, ColumnMask) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- addRegularColumn(ColumnIdentifier, AbstractType<?>) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- addRegularColumn(ColumnIdentifier, AbstractType<?>, ColumnMask) - 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.metrics.InternodeOutboundMetrics
- address() - Method in class org.apache.cassandra.utils.concurrent.Ref.DirectBufferRef
- ADDRESS - Static variable in class org.apache.cassandra.transport.ConnectedClient
- addressBytes - Variable in class org.apache.cassandra.locator.InetAddressAndPort
- 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(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.ResultSet
- addRow(Map<String, Object>) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
Adds a new row to the writer.
- addRow(PrimaryKey, Row, long) - Method in interface org.apache.cassandra.index.sai.disk.PerColumnIndexWriter
-
Adds a row to this index.
- addRow(PrimaryKey, Row, long) - Method in class org.apache.cassandra.index.sai.disk.v1.MemtableIndexWriter
- addRow(PrimaryKey, Row, long) - Method in class org.apache.cassandra.index.sai.disk.v1.SSTableIndexWriter
- 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.
- 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(SessionInfo) - Method in class org.apache.cassandra.streaming.StreamCoordinator
- addSessionInfo(StreamSession) - Method in class org.apache.cassandra.streaming.messages.StreamMessageHeader
- addSeverity(double) - Static method in class org.apache.cassandra.locator.DynamicEndpointSnitch
- addSingleRange(InetAddressAndPort, Range<Token>) - Method in class org.apache.cassandra.repair.asymmetric.HostDifferences
- addSnapshot(TableSnapshot) - Method in class org.apache.cassandra.service.snapshot.SnapshotManager
- addSnapshot(TableSnapshot) - Method in class org.apache.cassandra.service.StorageService
- addSnapshots(Collection<TableSnapshot>) - Method in class org.apache.cassandra.service.snapshot.SnapshotManager
- 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.AbstractStrategyHolder
- addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
- addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
- addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
- 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.db.compaction.UnifiedCompactionStrategy
- addSSTable(SSTableReader) - Method in class org.apache.cassandra.repair.consistent.admin.PendingStat.Builder
- 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(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
- addSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
- addSSTables(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
- addSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- 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(AbstractStrategyHolder.GroupedSSTableContainer) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
- 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(String, AbstractType<?>, ColumnMask) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- addStaticColumn(ColumnIdentifier, AbstractType<?>) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- addStaticColumn(ColumnIdentifier, AbstractType<?>, ColumnMask) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- addStaticRow(Row) - Method in class org.apache.cassandra.io.sstable.format.SortedTablePartitionWriter
- addStreamingStateAgain(StreamingState) - Method in class org.apache.cassandra.streaming.StreamManager
- addStreamRequest(String, RangesAtEndpoint, RangesAtEndpoint, Collection<String>) - Method in class org.apache.cassandra.streaming.StreamSession
-
Request data fetch task to this session.
- addTable(TableMetadata, boolean) - Static method in class org.apache.cassandra.schema.SchemaTransformations
-
Creates a schema transformation that adds the provided table.
- addTask(T) - 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.bti.PartitionIndex
- 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.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.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
- addToMessage(Message<T>) - Static method in class org.apache.cassandra.db.MessageParams
- addToRawBuilder(Types.RawBuilder) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTypeStatement.Raw
- addToRowFilter(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
- addToRowFilter(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.INRestriction
- addToRowFilter(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.NotNullRestriction
- addToRowFilter(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
- addToRowFilter(RowFilter, IndexRegistry, QueryOptions) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
Adds to the specified row filter the expressions corresponding to this
Restriction
. - addToRowFilter(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.AnnRestriction
- addToRowFilter(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
- addToRowFilter(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.EQRestriction
- addToRowFilter(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.INRestriction
- addToRowFilter(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.IsNotNullRestriction
- addToRowFilter(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
- addToRowFilter(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.SliceRestriction
- addToRowFilter(RowFilter, IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
- 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.filter.BloomFilterTracker
- addTruePositive() - Method in class org.apache.cassandra.io.sstable.filter.BloomFilterTracker
- addTypes(Types, boolean) - Static method in class org.apache.cassandra.schema.SchemaTransformations
- addUnfiltered(Unfiltered) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormatPartitionWriter
- addUnfiltered(Unfiltered) - Method in class org.apache.cassandra.io.sstable.format.SortedTablePartitionWriter
- 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, Clustering<?>, 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.DeleteStatement
- addUpdateForKey(PartitionUpdate.Builder, Slice, UpdateParameters) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- addUpdateForKey(PartitionUpdate.Builder, Slice, UpdateParameters) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement
- addView(ViewMetadata) - Method in class org.apache.cassandra.db.view.ViewManager
- addView(ViewMetadata, boolean) - Static method in class org.apache.cassandra.schema.SchemaTransformations
-
Creates a schema transformation that adds the provided view.
- addWithExpiration(RequestCallback<?>, Message<?>, InetAddressAndPort) - Method in class org.apache.cassandra.net.RequestCallbacks
-
Register the provided
RequestCallback
, inferring expiry and id from the providedMessage
. - addWithExpiration(AbstractWriteResponseHandler<?>, Message<?>, Replica) - 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
- ADLER32 - org.apache.cassandra.utils.ChecksumType
- adopt() - Method in class org.apache.cassandra.net.BufferPoolAllocator.Wrapped
- advance() - Method in interface org.apache.cassandra.db.tries.Trie.Cursor
-
Advance one position to the node whose associated path is next lexicographically.
- advance() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableKeyReader
- advance() - Method in class org.apache.cassandra.io.sstable.format.bti.ScrubIterator
- advance() - Method in interface org.apache.cassandra.io.sstable.format.bti.ScrubPartitionIterator
-
Move to the next position in the index file.
- advance() - Method in interface org.apache.cassandra.io.sstable.KeyReader
-
Moves the iterator forward.
- advance() - Method in class org.apache.cassandra.utils.MergeIterator.Candidate
- advance(long) - Method in class org.apache.cassandra.index.sai.disk.v1.postings.FilteringPostingList
- advance(long) - Method in class org.apache.cassandra.index.sai.disk.v1.postings.MergePostingList
- advance(long) - Method in class org.apache.cassandra.index.sai.disk.v1.postings.PackedLongsPostingList
- advance(long) - Method in class org.apache.cassandra.index.sai.disk.v1.postings.PostingsReader
-
Advances to the first row ID beyond the current that is greater than or equal to the target, and returns that row ID.
- advance(long) - Method in class org.apache.cassandra.index.sai.disk.v1.postings.VectorPostingList
- advance(long) - Method in class org.apache.cassandra.index.sai.postings.IntArrayPostingList
- advance(long) - Method in class org.apache.cassandra.index.sai.postings.PeekablePostingList
- advance(long) - Method in interface org.apache.cassandra.index.sai.postings.PostingList
-
Advances to the first row ID beyond the current that is greater than or equal to the target, and returns that row ID.
- advance(long) - Method in class org.apache.cassandra.index.sai.postings.PostingList.EmptyPostingList
- advanceMultiple(Trie.TransitionsReceiver) - Method in interface org.apache.cassandra.db.tries.Trie.Cursor
-
Advance, descending multiple levels if the cursor can do this for the current position without extra work (e.g.
- advanceNode() - Method in class org.apache.cassandra.io.tries.ValueIterator
- advanceTo(Token) - Method in class org.apache.cassandra.db.compaction.ShardManagerDiskAware.BoundaryTrackerDiskAware
-
Advance to the given token (e.g.
- advanceTo(Token) - Method in class org.apache.cassandra.db.compaction.ShardManagerNoDisks.BoundaryTracker
- advanceTo(Token) - Method in interface org.apache.cassandra.db.compaction.ShardTracker
-
Advance to the given token (e.g.
- advanceToContent(Trie.ResettingTransitionsReceiver) - Method in interface org.apache.cassandra.db.tries.Trie.Cursor
-
Advance all the way to the next node with non-null content.
- advanceWithoutConsuming(long) - Method in class org.apache.cassandra.index.sai.postings.PeekablePostingList
- 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.
- affectedColumnCount() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
- affectedRowCount() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
- after - Variable in class org.apache.cassandra.schema.Diff.Altered
- after - Variable in class org.apache.cassandra.schema.KeyspaceMetadata.KeyspaceDiff
- after - Variable in class org.apache.cassandra.schema.SchemaTransformation.SchemaTransformationResult
- aggregate(String, String) - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
-
Creates a
DescribeStatement
forDESCRIBE FUNCTION
. - AGGREGATE - org.apache.cassandra.cql3.SchemaElement.SchemaElementType
- AGGREGATE - org.apache.cassandra.transport.Event.SchemaChange.Target
- AGGREGATE_BY_PK_PREFIX - org.apache.cassandra.db.aggregation.AggregationSpecification.Kind
- AGGREGATE_BY_PK_PREFIX_WITH_SELECTOR - org.apache.cassandra.db.aggregation.AggregationSpecification.Kind
- AGGREGATE_EVERYTHING - org.apache.cassandra.db.aggregation.AggregationSpecification.Kind
- AGGREGATE_EVERYTHING - Static variable in class org.apache.cassandra.db.aggregation.AggregationSpecification
-
AggregationSpecification
that group all the row together. - AGGREGATE_EVERYTHING_FACTORY - Static variable in class org.apache.cassandra.db.aggregation.AggregationSpecification
-
Factory for
AggregationSpecification
that group all the row together. - AGGREGATE_FUNCTION_SELECTOR - org.apache.cassandra.cql3.selection.Selector.Kind
- AggregateFcts - Class in org.apache.cassandra.cql3.functions
-
Factory methods for aggregate functions.
- AggregateFcts() - Constructor for class org.apache.cassandra.cql3.functions.AggregateFcts
- AggregateFcts.CountRowsFunction - Class in org.apache.cassandra.cql3.functions
- 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.
- aggregatePkPrefixFactory(ClusteringComparator, int) - Static method in class org.apache.cassandra.db.aggregation.AggregationSpecification
-
Creates a new
Factory
instance to createAggregationSpecification
that will build aggregates based on primary key columns. - aggregatePkPrefixFactoryWithSelector(ClusteringComparator, int, Selector.Factory, List<ColumnMetadata>) - Static method in class org.apache.cassandra.db.aggregation.AggregationSpecification
- aggregates() - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
-
Creates a
DescribeStatement
forDESCRIBE AGGREGATES
. - AGGREGATES - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
- aggregatesMultiCell() - Method in enum org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL.Kind
- aggregatesUsingFunction(Function) - Method in class org.apache.cassandra.schema.UserFunctions
- AggregationPartitionIterator(int, ConsistencyLevel, ClientState, Dispatcher.RequestTime) - Constructor for class org.apache.cassandra.service.pager.AggregationQueryPager.AggregationPartitionIterator
- AggregationPartitionIterator(int, ReadExecutionController, Dispatcher.RequestTime) - 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.Factory - Interface in org.apache.cassandra.db.aggregation
-
Factory for
AggregationSpecification
. - AggregationSpecification.Kind - Enum in org.apache.cassandra.db.aggregation
-
The
AggregationSpecification
kinds. - AggregationSpecification.Serializer - Class in org.apache.cassandra.db.aggregation
- agreed() - Method in class org.apache.cassandra.service.paxos.Commit.Proposal
- Agreed(Ballot, PartitionUpdate) - Constructor for class org.apache.cassandra.service.paxos.Commit.Agreed
- Agreed(Commit) - Constructor for class org.apache.cassandra.service.paxos.Commit.Agreed
- AIX - org.apache.cassandra.utils.NativeLibrary.OSType
- algorithm - Variable in class org.apache.cassandra.config.EncryptionOptions
- algorithm - Variable in class org.apache.cassandra.security.AbstractSslContextFactory
- ALGORITHM - org.apache.cassandra.config.EncryptionOptions.ConfigKey
- alias - Variable in class org.apache.cassandra.cql3.selection.RawSelector
- aliases - Variable in class org.apache.cassandra.db.marshal.DynamicCompositeType
- 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
- AlibabaCloudSnitch(AbstractCloudMetadataServiceConnector) - Constructor for class org.apache.cassandra.locator.AlibabaCloudSnitch
- AlibabaCloudSnitch(SnitchProperties) - 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 - org.apache.cassandra.config.Config.InternodeCompression
- all - org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions.InternodeEncryption
- all - Static variable in class org.apache.cassandra.io.sstable.Component.Type
- 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 method in class org.apache.cassandra.auth.CIDRPermissions
-
Generates CIDR permissions object which allows from all CIDR groups
- all() - Method in class org.apache.cassandra.auth.CIDRPermissions.Builder
- all() - Static method in class org.apache.cassandra.auth.DCPermissions
- all() - Method in class org.apache.cassandra.auth.DCPermissions.Builder
- all() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
- all() - Static method in class org.apache.cassandra.db.Keyspace
- 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(TableMetadata) - Static method in class org.apache.cassandra.db.filter.ColumnFilter
-
A filter that includes all columns for the provided table.
- ALL - org.apache.cassandra.db.ConsistencyLevel
- ALL - org.apache.cassandra.index.Index.LoadType
- ALL - org.apache.cassandra.locator.ReplicaCollection.Builder.Conflict
-
ignore all conflicts (the first occurrence and position wins)
- ALL - org.apache.cassandra.schema.UserFunctions.Filter
- ALL - org.apache.cassandra.streaming.PreviewKind
- ALL - org.apache.cassandra.tools.NodeTool.NodeToolCmd.KeyspaceSet
- ALL - org.apache.cassandra.utils.Shared.Recursive
- ALL - Static variable in enum org.apache.cassandra.auth.Permission
- 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 - Static variable in class org.apache.cassandra.index.sai.disk.format.Version
- ALL - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
-
The order in this list matters.
- ALL_MUTATIONS - Static variable in class org.apache.cassandra.db.commitlog.CommitLogReader
- ALL_TABLE_NAMES - Static variable in class org.apache.cassandra.db.SystemKeyspace
- 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
- allComponents() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- allComponents() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- allComponents() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
All the components that the writter can produce when saving an sstable, as well as all the components that the reader can read.
- 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, long) - 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 returnfalse
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
- allFileStores(Function<File, FileStore>) - Method in class org.apache.cassandra.db.Directories
- allInSameTable(Collection<ColumnSpecification>) - Static method in class org.apache.cassandra.cql3.ColumnSpecification
-
Returns true if all ColumnSpecifications are in the same table, false otherwise.
- allJobs() - Method in class org.apache.cassandra.metrics.SamplingManager
- allKeysIterator() - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex
- allKeywords() - Static method in class org.apache.cassandra.cql3.statements.schema.TableAttributes
- 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(boolean, int) - Method in interface org.apache.cassandra.net.FrameEncoder.PayloadAllocator
- 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 {@param
} instance of {@param size} bytes on the heap. - allocate(int) - Method in enum org.apache.cassandra.io.compress.BufferType
- allocate(int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
- allocate(int) - Method in class org.apache.cassandra.utils.memory.ByteBufferCloner
-
Allocate a slice of the given length.
- allocate(int) - Method in class org.apache.cassandra.utils.memory.HeapCloner
- allocate(int) - Method in class org.apache.cassandra.utils.memory.SlabAllocator
- 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, int, int[], OutputHandler, IPartitioner) - Static method in class org.apache.cassandra.dht.tokenallocator.OfflineTokenAllocator
- allocate(int, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.HeapPool.Allocator
- 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, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.SlabAllocator
- allocate(long) - Static method in class org.apache.cassandra.io.util.Memory
- 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(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(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_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_KEYSPACE - org.apache.cassandra.config.CassandraRelevantProperties
- 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.
- allocateDirect(int) - Method in class org.apache.cassandra.net.BufferPoolAllocator.Wrapped
- allocateTokens(TokenMetadata, int, InetAddressAndPort, int) - Static method in class org.apache.cassandra.dht.tokenallocator.TokenAllocation
- allocateTokens(TokenMetadata, AbstractReplicationStrategy, InetAddressAndPort, int) - Static method in class org.apache.cassandra.dht.tokenallocator.TokenAllocation
- allocator - Variable in class org.apache.cassandra.db.memtable.AbstractAllocatorMemtable
- allocator - Variable in class org.apache.cassandra.net.FrameDecoder
- allocator - Variable in class org.apache.cassandra.net.OutboundConnectionInitiator.Result.MessagingSuccess
- allocator - Static variable in class org.apache.cassandra.transport.CBUtil
- allocator() - Method in class org.apache.cassandra.net.FrameEncoder
- allocator() - Method in class org.apache.cassandra.net.FrameEncoderCrc
- allocator(OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableBufferAllocator
- Allocator(HeapPool) - Constructor for class org.apache.cassandra.utils.memory.HeapPool.Allocator
- allOf(Collection<? extends Future<? extends V>>) - Static method in class org.apache.cassandra.utils.concurrent.FutureCombiner
-
Waits only until the first failure, or until all have succeeded.
- allOf(Collection<? extends Future<? extends T>>) - 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.See CASSANDRA-15066
- ALLOW_ALTER_RF_DURING_RANGE_MOVEMENT - org.apache.cassandra.config.CassandraRelevantProperties
- ALLOW_AUTO_SNAPSHOT - org.apache.cassandra.schema.TableParams.Option
- ALLOW_DUPLICATE_CONFIG_KEYS - org.apache.cassandra.config.CassandraRelevantProperties
-
If we should allow having duplicate keys in the config file, default to true for legacy reasons
- allow_extra_insecure_udfs - Variable in class org.apache.cassandra.config.Config
-
Set this to allow UDFs accessing java.lang.System.* methods, which basically allows UDFs to execute any arbitrary code on the system.
- allow_filtering_enabled - Variable in class org.apache.cassandra.config.Config
- allow_insecure_udfs - Variable in class org.apache.cassandra.config.Config
-
Set this to true to allow running insecure UDFs.
- ALLOW_NEW_OLD_CONFIG_KEYS - org.apache.cassandra.config.CassandraRelevantProperties
-
If we should allow having both new (post CASSANDRA-15234) and old config keys for the same config item in the yaml
- allow_nodetool_archive_command - Variable in class org.apache.cassandra.utils.binlog.BinLogOptions
-
enable if a user should be able to set the archive command via nodetool/jmx do not make this a hotprop.
- ALLOW_UNLIMITED_CONCURRENT_VALIDATIONS - org.apache.cassandra.config.CassandraRelevantProperties
- ALLOW_UNSAFE_AGGRESSIVE_SSTABLE_EXPIRATION - org.apache.cassandra.config.CassandraRelevantProperties
- ALLOW_UNSAFE_JOIN - org.apache.cassandra.config.CassandraRelevantProperties
- ALLOW_UNSAFE_REPLACE - org.apache.cassandra.config.CassandraRelevantProperties
- ALLOW_UNSAFE_TRANSIENT_CHANGES - org.apache.cassandra.config.CassandraRelevantProperties
- 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
- AllowAllCIDRAuthorizer - Class in org.apache.cassandra.auth
-
AllowAllCIDRAuthorizer allows any user to access from any CIDR i.e, disables CIDR authorization
- AllowAllCIDRAuthorizer() - Constructor for class org.apache.cassandra.auth.AllowAllCIDRAuthorizer
- 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
- allowAutoSnapshot - Variable in class org.apache.cassandra.schema.TableParams
- allowAutoSnapshot(boolean) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- allowAutoSnapshot(boolean) - Method in class org.apache.cassandra.schema.TableParams.Builder
- allowClusteringColumnSlices() - Method in enum org.apache.cassandra.cql3.statements.StatementType
-
Checks this type of statement allow the where clause to contains clustering column slices.
- allowedCIDRGroups() - Method in class org.apache.cassandra.auth.CIDRPermissions
-
Returns CIDR permissions allowed by this object
- allowedDCs() - Method in class org.apache.cassandra.auth.DCPermissions
- AllowedSourcesFilter(Set<InetAddressAndPort>) - Constructor for class org.apache.cassandra.dht.RangeStreamer.AllowedSourcesFilter
- allowExtraInsecureUDFs() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- allowFiltering - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
- allowFilteringEnabled - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail disabling ALLOW FILTERING statement within a query
- allowFilteringImplicitly() - Method in class org.apache.cassandra.db.virtual.LogMessagesTable
- allowFilteringImplicitly() - Method in interface org.apache.cassandra.db.virtual.VirtualTable
-
Tells whether
ALLOW FILTERING
is implicitly added to select statement which requires it. - allowInsecureUDFs() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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.
- ALLOWS_RETRY - Static variable in class org.apache.cassandra.repair.messages.RepairMessage
- allowsEmpty() - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
- allowsEmpty() - Method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- allowsEmpty() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Defines if the type allows an empty set of bytes (
new byte[0]
) as valid input. - allowsEmpty() - Method in class org.apache.cassandra.db.marshal.BooleanType
- allowsEmpty() - Method in class org.apache.cassandra.db.marshal.BytesType
- allowsEmpty() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
- allowsEmpty() - Method in class org.apache.cassandra.db.marshal.DecimalType
- allowsEmpty() - Method in class org.apache.cassandra.db.marshal.DoubleType
- allowsEmpty() - Method in class org.apache.cassandra.db.marshal.FloatType
- allowsEmpty() - Method in class org.apache.cassandra.db.marshal.InetAddressType
- allowsEmpty() - Method in class org.apache.cassandra.db.marshal.Int32Type
- allowsEmpty() - Method in class org.apache.cassandra.db.marshal.IntegerType
- allowsEmpty() - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
- allowsEmpty() - Method in class org.apache.cassandra.db.marshal.LongType
- allowsEmpty() - Method in class org.apache.cassandra.db.marshal.StringType
- allowsEmpty() - Method in class org.apache.cassandra.db.marshal.TimestampType
- allowsEmpty() - Method in class org.apache.cassandra.db.marshal.TupleType
- allowsEmpty() - Method in class org.apache.cassandra.db.marshal.UUIDType
- 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 - Variable in class org.apache.cassandra.locator.ReplicationFactor
- allReplicas() - Method in class org.apache.cassandra.locator.Replicas.ReplicaCount
- 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
- allTables(String) - Static method in class org.apache.cassandra.auth.DataResource
-
Creates a DataResource representing all tables of a keyspace.
- 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
- AlmostSameTime(long, long, long) - Constructor for class org.apache.cassandra.utils.MonotonicClock.AbstractEpochSamplingClock.AlmostSameTime
- almProxy - Variable in class org.apache.cassandra.tools.NodeProbe
- ALPHANUM - org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer.TokenType
- ALREADY_COMPLETED - org.apache.cassandra.repair.state.AbstractState.UpdateType
- ALREADY_COMPLETED - org.apache.cassandra.repair.state.ParticipateState.RegisterStatus
- ALREADY_EXISTS - org.apache.cassandra.exceptions.ExceptionCode
- AlreadyExistsException - Exception in org.apache.cassandra.exceptions
- AlreadyExistsException(String) - Constructor for exception org.apache.cassandra.exceptions.AlreadyExistsException
- AlreadyExistsException(String, 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
- ALTER - org.apache.cassandra.auth.Permission
- ALTER_KEYSPACE - org.apache.cassandra.audit.AuditLogEntryType
- ALTER_ROLE - org.apache.cassandra.audit.AuditLogEntryType
- ALTER_TABLE - org.apache.cassandra.audit.AuditLogEntryType
- alter_table_enabled - Variable in class org.apache.cassandra.config.Config
- ALTER_TYPE - org.apache.cassandra.audit.AuditLogEntryType
- ALTER_VIEW - org.apache.cassandra.audit.AuditLogEntryType
- 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].
- alterColumnMask(ColumnIdentifier, ColumnMask) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- 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, boolean) - 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, CIDRPermissions, boolean) - Constructor for class org.apache.cassandra.cql3.statements.AlterRoleStatement
- AlterSchemaStatement - Class in org.apache.cassandra.cql3.statements.schema
- AlterSchemaStatement(String) - Constructor for class org.apache.cassandra.cql3.statements.schema.AlterSchemaStatement
- alterTableEnabled - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail disabling ALTER TABLE column mutation access.
- AlterTableStatement - Class in org.apache.cassandra.cql3.statements.schema
- AlterTableStatement(String, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.AlterTableStatement
- AlterTableStatement.AlterColumn - Class in org.apache.cassandra.cql3.statements.schema
-
ALTER TABLE [IF EXISTS] <table> ALTER <column> TYPE <newtype>;
No longer supported. - AlterTableStatement.MaskColumn - Class in org.apache.cassandra.cql3.statements.schema
-
ALTER TABLE [IF EXISTS] <table> ALTER [IF EXISTS] <column> ( MASKED WITH <newMask> | DROP MASKED )
- AlterTableStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
- AlterTypeStatement - Class in org.apache.cassandra.cql3.statements.schema
- AlterTypeStatement(String, String, boolean) - 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, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.AlterViewStatement
- AlterViewStatement.Raw - Class in org.apache.cassandra.cql3.statements.schema
- always() - Static method in class org.apache.cassandra.repair.messages.RepairMessage
- ALWAYS - org.apache.cassandra.service.reads.SpeculativeRetryPolicy.Kind
- alwaysGreaterThan - Static variable in class org.apache.cassandra.db.marshal.DynamicCompositeType.FixedValueComparator
- alwaysLesserThan - Static variable in class org.apache.cassandra.db.marshal.DynamicCompositeType.FixedValueComparator
- alwaysLowerCaseTerms(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
- AlwaysPresent - Static variable in class org.apache.cassandra.utils.FilterFactory
- AlwaysSpeculativeRetryPolicy - Class in org.apache.cassandra.service.reads
- alwaysUpperCaseTerms(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions.OptionsBuilder
- ANALYSIS_ON_KEY_COLUMNS_MESSAGE - Static variable in class org.apache.cassandra.index.sai.StorageAttachedIndex
- 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
- analyzer() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
-
Returns an
AbstractAnalyzer
for use by write and query paths to transform literal values. - analyzerClass - Variable in class org.apache.cassandra.index.sasi.conf.IndexMode
- ancestors() - Method in annotation type org.apache.cassandra.utils.Shared
- and(WithResources) - Method in interface org.apache.cassandra.utils.WithResources
- and(WithResources, WithResources) - Static method in interface org.apache.cassandra.utils.WithResources
- AND - org.apache.cassandra.index.sai.plan.Operation.BooleanOperator
- AND - org.apache.cassandra.index.sasi.plan.Operation.OperationType
- andThen(Property, Property) - Static method in class org.apache.cassandra.config.Properties
-
Given two properties (root, leaf), calls first go through root and passed to leaf.
- andThen(Property, Property, String) - Static method in class org.apache.cassandra.config.Properties
-
Given two properties (root, leaf), calls first go through root and passed to leaf.
- Ann(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Ordering.Ann
- ANN - org.apache.cassandra.cql3.Operator
- ANN - org.apache.cassandra.index.sai.plan.Expression.IndexOperator
- ANN_LIMIT_ERROR - Static variable in class org.apache.cassandra.index.sai.StorageAttachedIndex
- ANN_ONLY_SUPPORTED_ON_VECTOR_MESSAGE - Static variable in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
- ANN_REQUIRES_INDEX_MESSAGE - Static variable in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
- ANN_REQUIRES_INDEXED_FILTERING_MESSAGE - Static variable in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
- AnnRestriction(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.AnnRestriction
- ANONYMOUS_USER - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
- ANONYMOUS_USERNAME - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
- ANTI_ENTROPY - org.apache.cassandra.concurrent.Stage
- ANTICOMPACTION - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- ANTICOMPACTION - org.apache.cassandra.db.compaction.OperationType
- 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 - org.apache.cassandra.db.ConsistencyLevel
- ANY - org.apache.cassandra.utils.Shared.Scope
- anyCauseMatches(Throwable, Predicate<Throwable>) - Static method in class org.apache.cassandra.utils.Throwables
- anyCollection() - Static method in interface org.apache.cassandra.cql3.functions.FunctionParameter
- anyMap() - Static method in interface org.apache.cassandra.cql3.functions.FunctionParameter
- anyMatch(ByteBuffer, Predicate<ByteBuffer>) - Method in class org.apache.cassandra.serializers.ListSerializer
- anyMatch(Predicate<? super Replica>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
- anyMatch(Predicate<? super Replica>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
- anyMatch(V, ValueAccessor<V>, Predicate<V>) - Method in class org.apache.cassandra.serializers.ListSerializer
- anyType(boolean) - Static method in interface org.apache.cassandra.cql3.functions.FunctionParameter
- append(boolean) - Method in class org.apache.cassandra.cql3.CqlBuilder
- append(char) - Method in class org.apache.cassandra.cql3.CqlBuilder
- append(double) - Method in class org.apache.cassandra.cql3.CqlBuilder
- append(float) - 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(LoggingEvent) - Method in class org.apache.cassandra.utils.logging.VirtualTableAppender
- 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
- 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(String) - 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(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.CqlBuilder
- append(FunctionName) - Method in class org.apache.cassandra.cql3.CqlBuilder
- append(DecoratedKey, AbstractRowIndexEntry) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter.IndexWriter
- append(DecoratedKey, RowIndexEntry, long, ByteBuffer) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter.IndexWriter
- append(AbstractType<?>) - Method in class org.apache.cassandra.cql3.CqlBuilder
- append(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.compaction.unified.ShardedMultiWriter
- 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.SortedTableWriter
-
Appends partition data to this writer.
- 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.RangeAwareSSTableWriter
- 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(UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.SSTableZeroCopyWriter
- append(File, String...) - Static method in class org.apache.cassandra.io.util.FileUtils
- append(PaxosKeyState) - Method in interface org.apache.cassandra.service.paxos.uncommitted.UncommittedTableData.FlushWriter
- APPEND - org.apache.cassandra.io.util.File.WriteMode
- appendAll(Iterable<PaxosKeyState>) - Method in interface org.apache.cassandra.service.paxos.uncommitted.UncommittedTableData.FlushWriter
- 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.cql3.functions.masking.ColumnMask
- appendCqlTo(CqlBuilder) - Method in class org.apache.cassandra.schema.ColumnMetadata
- appendCqlTo(CqlBuilder) - Method in class org.apache.cassandra.schema.ReplicationParams
- appendCqlTo(CqlBuilder, boolean) - Method in class org.apache.cassandra.schema.TableParams
- appendCqlTo(CqlBuilder, boolean, boolean) - Method in class org.apache.cassandra.schema.ViewMetadata
- 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, TableMetadata, boolean) - Method in class org.apache.cassandra.schema.IndexMetadata
-
Appends to the specified builder the CQL used to create this index.
- 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
- appendDirect(ByteBuffer, boolean) - Method in class org.apache.cassandra.io.util.ChecksumWriter
- Appender(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Lists.Appender
- APPENDER_NAME - Static variable in class org.apache.cassandra.utils.logging.VirtualTableAppender
- 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.AnnRestriction
- 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.format.TOCComponent
-
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.
- appliedAt() - Method in class org.apache.cassandra.transport.QueueBackpressure.Incident
- 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(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.
- appliesTo(Row) - Method in class org.apache.cassandra.cql3.conditions.ColumnCondition.Bound
-
Validates whether this condition applies to
current
. - 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() - Method in class org.apache.cassandra.db.CounterMutation
- apply() - Method in interface org.apache.cassandra.db.IMutation
- apply() - Method in class org.apache.cassandra.db.Mutation
- apply() - Method in class org.apache.cassandra.db.virtual.VirtualMutation
- apply(boolean) - Method in class org.apache.cassandra.db.Mutation
- apply(boolean, boolean) - Method in class org.apache.cassandra.db.Mutation
- apply(boolean, boolean) - Method in enum org.apache.cassandra.index.sai.plan.Operation.BooleanOperator
- 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(long) - Method in interface org.apache.cassandra.metrics.ScalingReservoir.ScaleFunction
- 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
- 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
- apply(StringBuilder) - Method in class org.apache.cassandra.utils.concurrent.Threads.StackTraceCombiner
- apply(BiConsumer<A, ColumnData>, A) - Method in class org.apache.cassandra.db.rows.BTreeRow
- apply(BiConsumer<A, ColumnData>, A) - Method in interface org.apache.cassandra.db.rows.Row
-
Apply a function to every column in a row
- apply(Consumer<ColumnData>) - 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(Consumer<ColumnMetadata>) - Method in class org.apache.cassandra.db.Columns
-
Apply a function to each column definition in forwards or reversed order.
- apply(IMutation, ReplicaPlan.ForWrite, AbstractWriteResponseHandler<IMutation>, String, Dispatcher.RequestTime) - Method in interface org.apache.cassandra.service.StorageProxy.WritePerformer
- apply(Mutation, boolean) - Method in class org.apache.cassandra.db.Keyspace
- apply(Mutation, boolean, 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(PartitionIterator, Transformation<? super RowIterator>) - Static method in class org.apache.cassandra.db.transform.Transformation
- apply(PartitionUpdate) - Method in class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable
- apply(PartitionUpdate) - Method in class org.apache.cassandra.db.virtual.AbstractVirtualTable
- apply(PartitionUpdate) - Method in interface org.apache.cassandra.db.virtual.VirtualTable
-
Applies the specified update, if supported.
- apply(PartitionUpdate) - Method in class org.apache.cassandra.index.sai.virtual.ColumnIndexesSystemView
- apply(PartitionUpdate, CassandraWriteContext, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Insert/Update the column family for this key.
- apply(UnfilteredPartitionIterator, Transformation<? super UnfilteredRowIterator>) - Static method in class org.apache.cassandra.db.transform.Transformation
- apply(RowIterator, Transformation<?>) - Static method in class org.apache.cassandra.db.transform.Transformation
- apply(UnfilteredRowIterator, Transformation<?>) - Static method in class org.apache.cassandra.db.transform.Transformation
- apply(Trie<U>, InMemoryTrie.UpsertTransformer<T, U>) - Method in class org.apache.cassandra.db.tries.InMemoryTrie
-
Modify this trie to apply the mutation given in the form of a trie.
- apply(InetAddressAndPort, Set<InetAddressAndPort>) - Method in interface org.apache.cassandra.repair.asymmetric.PreferedNodeFilter
- apply(Replica) - Method in class org.apache.cassandra.dht.RangeStreamer.AllowedSourcesFilter
- apply(Replica) - Method in class org.apache.cassandra.dht.RangeStreamer.ExcludeLocalDatacenterFilter
- 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(KeyspaceMetadata, TableMetadata) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.AlterColumn
- apply(KeyspaceMetadata, TableMetadata) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.MaskColumn
- apply(Keyspaces) - Method in class org.apache.cassandra.cql3.statements.schema.AlterKeyspaceStatement
- 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(Keyspaces) - Method in interface org.apache.cassandra.schema.SchemaTransformation
-
Apply a statement transformation to a schema snapshot.
- apply(SchemaTransformation, boolean) - Method in class org.apache.cassandra.schema.DefaultSchemaUpdateHandler
- apply(SchemaTransformation, boolean) - Method in class org.apache.cassandra.schema.OfflineSchemaUpdateHandler
- apply(SchemaTransformation, boolean) - Method in interface org.apache.cassandra.schema.SchemaUpdateHandler
-
Applies schema transformation in the underlying storage and synchronizes with other nodes.
- apply(S, I) - Method in interface org.apache.cassandra.service.paxos.AbstractPaxosRepair.StateUpdater
- apply(T) - Method in interface org.apache.cassandra.io.util.CheckedFunction
- apply(T, long) - Method in interface org.apache.cassandra.utils.LongAccumulator
- apply(T, A, long) - Method in interface org.apache.cassandra.utils.BiLongAccumulator
- apply(T, U) - Method in interface org.apache.cassandra.db.tries.InMemoryTrie.UpsertTransformer
-
Called when there's content in the updating trie.
- apply(V) - Method in interface org.apache.cassandra.io.util.PathUtils.IOToLongFunction
- applyAddressConfig() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- applyAddressConfig(Config) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- applyAsLong(double) - Method in class org.apache.cassandra.utils.EstimatedHistogram
- applyAuth() - Static method in class org.apache.cassandra.auth.AuthConfig
- applyColumnDeletion(AbstractMutableVirtualTable.ColumnValues, AbstractMutableVirtualTable.ColumnValues, String) - Method in class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable
- applyColumnUpdate(AbstractMutableVirtualTable.ColumnValues, AbstractMutableVirtualTable.ColumnValues, Optional<AbstractMutableVirtualTable.ColumnValue>) - Method in class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable
- 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, Dispatcher.RequestTime) - Static method in class org.apache.cassandra.service.StorageProxy
- applyCounterMutationOnLeader(CounterMutation, String, Runnable, Dispatcher.RequestTime) - Static method in class org.apache.cassandra.service.StorageProxy
- applyCryptoProvider() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- applyEncryptionContext() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- applyFuture() - Method in class org.apache.cassandra.db.Mutation
- 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
- 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
- applyPartitionDeletion(AbstractMutableVirtualTable.ColumnValues) - Method in class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable
- applyPartitioner() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- applyPartitioner(Config) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- applyRangeTombstone(AbstractMutableVirtualTable.ColumnValues, Range<AbstractMutableVirtualTable.ColumnValues>) - Method in class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable
- applyRowDeletion(AbstractMutableVirtualTable.ColumnValues, AbstractMutableVirtualTable.ColumnValues) - Method in class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable
- 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
- applyStateLocally(Map<InetAddressAndPort, EndpointState>) - Method in interface org.apache.cassandra.gms.IGossiper
- 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(RowIterator) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
- applyTo(UnfilteredRowIterator) - 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
- applyTokenSpaceCoverage(SSTableWriter) - Method in interface org.apache.cassandra.db.compaction.ShardTracker
- 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.metrics.TopPartitionTracker.TombstoneCounter
- applyToMarker(RangeTombstoneMarker) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
- applyToPartition(I) - Method in class org.apache.cassandra.db.transform.Transformation
-
Applied to any rows iterator (partition) we encounter in a partitions iterator
- applyToPartition(Iterator<Row>) - Method in class org.apache.cassandra.utils.memory.EnsureOnHeap
- applyToPartition(DecoratedKey, Row) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
- applyToPartition(BaseRowIterator) - Method in class org.apache.cassandra.db.transform.EmptyPartitionsDiscarder
- applyToPartition(BaseRowIterator) - Method in class org.apache.cassandra.db.transform.Filter
- applyToPartition(BaseRowIterator<?>) - 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.transform.RTBoundCloser
- applyToPartition(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.transform.RTBoundValidator
- applyToPartition(UnfilteredRowIterator) - Method in class org.apache.cassandra.metrics.TopPartitionTracker.TombstoneCounter
- 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
- 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.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.metrics.TopPartitionTracker.TombstoneCounter
- 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
- APPROXIMATE_TIME_PRECISION_MS - org.apache.cassandra.config.CassandraRelevantProperties
- approxTime - Static variable in class org.apache.cassandra.utils.MonotonicClock.Global
- Architecture - Class in org.apache.cassandra.utils
- archive_command - Variable in class org.apache.cassandra.utils.binlog.BinLogOptions
- ARCHIVE_COMMAND - Static variable in class org.apache.cassandra.audit.AuditLogOptionsCompositeData.AuditLogOption
- 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
- areMutationExecutorsTerminated() - Static method in enum org.apache.cassandra.concurrent.Stage
- 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
- argTypes - Variable in class org.apache.cassandra.cql3.functions.AbstractFunction
- argTypes - Variable in exception org.apache.cassandra.exceptions.FunctionExecutionException
- argTypes - Variable in class org.apache.cassandra.transport.Event.SchemaChange
- argTypes() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
- argTypes() - Method in interface org.apache.cassandra.cql3.functions.Function
- ArgumentDeserializer - Interface in org.apache.cassandra.cql3.functions
-
Utility used to deserialize function arguments.
- Arguments - Interface in org.apache.cassandra.cql3.functions
-
The input arguments to a function.
- argumentsList() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
- argumentTypes - Variable in class org.apache.cassandra.cql3.functions.UDFunction
- 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
- ArrayCell(ColumnMetadata, long, int, long, 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
- ArrayLiteral - Class in org.apache.cassandra.cql3
-
Represents
[a, b, c, d]
in CQL. - ArrayLiteral(List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.ArrayLiteral
- arsProxy - Variable in class org.apache.cassandra.tools.NodeProbe
- ArtificialBoundMarker - Class in org.apache.cassandra.db.rows
- ArtificialBoundMarker(ClusteringBound<?>) - Constructor for class org.apache.cassandra.db.rows.ArtificialBoundMarker
- artificialLowerBound(boolean) - Method in interface org.apache.cassandra.db.ClusteringBound
- asByteBuffer(long, int) - Method in class org.apache.cassandra.io.util.Memory
- asByteBuffers(long, long) - Method in class org.apache.cassandra.io.util.Memory
- asByteBuffers(long, long) - Method in interface org.apache.cassandra.io.util.ReadableMemory
- asByteComparable - Variable in enum org.apache.cassandra.db.ClusteringPrefix.Kind
- asByteComparable(ClusteringPrefix<V>) - Method in class org.apache.cassandra.db.ClusteringComparator
-
Produce a prefix-free byte-comparable representation of the given value, i.e.
- asByteComparableValue(ByteComparable.Version) - Method in enum org.apache.cassandra.db.ClusteringPrefix.Kind
- asBytes() - Method in class org.apache.cassandra.io.sstable.SequenceBasedSSTableId
- asBytes() - Method in interface org.apache.cassandra.io.sstable.SSTableId
-
Creates a byte format of the identifier that can be parsed by
SSTableId.Builder.fromBytes(ByteBuffer)
- asBytes() - Method in class org.apache.cassandra.io.sstable.UUIDBasedSSTableId
- asBytes(String, String, AbstractType) - Static method in interface org.apache.cassandra.cql3.Terms
- ASC - org.apache.cassandra.cql3.Ordering.Direction
- ASC - org.apache.cassandra.index.sasi.disk.OnDiskIndex.IteratorOrder
- ASC - org.apache.cassandra.schema.ColumnMetadata.ClusteringOrder
- ASC - 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
. - Ascii() - Constructor for class org.apache.cassandra.index.sai.analyzer.filter.BasicFilters.Ascii
- ASCII - org.apache.cassandra.cql3.CQL3Type.Native
- ASCII - org.apache.cassandra.cql3.functions.types.DataType.Name
- ASCII - org.apache.cassandra.transport.DataType
- ASCII - Static variable in class org.apache.cassandra.index.sai.analyzer.NonTokenizingOptions
- AsciiSerializer - Class in org.apache.cassandra.serializers
- AsciiType - Class in org.apache.cassandra.db.marshal
- asComparableBound(boolean) - Method in class org.apache.cassandra.db.DecoratedKey
- asComparableBound(boolean) - Method in interface org.apache.cassandra.db.PartitionPosition
-
Produce a byte-comparable representation for the position before or after the key.
- asComparableBound(boolean) - Method in class org.apache.cassandra.dht.Token.KeyBound
- asComparableBytes(ByteBuffer, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.AbstractType
- asComparableBytes(ByteBuffer, ByteComparable.Version) - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
- asComparableBytes(ValueAccessor<T>, T, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.MapType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Produce a byte-comparable representation of the given value, i.e.
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.BooleanType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.ByteType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.CompositeType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.DecimalType
-
Constructs a byte-comparable representation.
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.DoubleType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.EmptyType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.FloatType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.Int32Type
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.IntegerType
-
Constructs a byte-comparable representation of the number.
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.ListType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.LongType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.ReversedType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.SetType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.ShortType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.TimestampType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.TimeType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.TupleType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.UUIDType
- asComparableBytes(ValueAccessor<V>, V, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.VectorType
- asComparableBytes(Token, ByteComparable.Version) - Method in class org.apache.cassandra.dht.Token.TokenFactory
-
Produce a byte-comparable representation of the token.
- asComparableBytes(ByteComparable.Version) - Method in class org.apache.cassandra.db.DecoratedKey
- asComparableBytes(ByteComparable.Version) - Method in interface org.apache.cassandra.db.PartitionPosition
-
Produce a prefix-free byte-comparable representation of the key, i.e.
- asComparableBytes(ByteComparable.Version) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
- asComparableBytes(ByteComparable.Version) - Method in class org.apache.cassandra.dht.LocalPartitioner.LocalToken
- asComparableBytes(ByteComparable.Version) - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
- asComparableBytes(ByteComparable.Version) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner.StringToken
- asComparableBytes(ByteComparable.Version) - Method in class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
- asComparableBytes(ByteComparable.Version) - Method in class org.apache.cassandra.dht.Token
-
Produce a weakly prefix-free byte-comparable representation of the token, i.e.
- asComparableBytes(ByteComparable.Version) - Method in class org.apache.cassandra.dht.Token.KeyBound
- asComparableBytes(ByteComparable.Version) - Method in interface org.apache.cassandra.index.sai.utils.PrimaryKey
-
Returns the
PrimaryKey
as aByteSource
byte comparable representation. - asComparableBytes(ByteComparable.Version) - Method in interface org.apache.cassandra.utils.bytecomparable.ByteComparable
-
Returns a source that generates the byte-comparable representation of the value byte by byte.
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- 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.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
- asCQL3Type() - Method in class org.apache.cassandra.db.marshal.VectorType
- asCQL3Type() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
- asCqlString() - Method in class org.apache.cassandra.cql3.statements.schema.IndexTarget
- asCqlTupleString() - Method in class org.apache.cassandra.cql3.CIDR
- asCQLTypeStringList(List<AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.AbstractType
- asEndBound() - Method in interface org.apache.cassandra.db.Clustering
- asEndBound() - Method in interface org.apache.cassandra.db.ClusteringBound
- asEndBound() - Method in interface org.apache.cassandra.db.ClusteringBoundary
- asEndBound() - Method in interface org.apache.cassandra.db.ClusteringPrefix
-
Returns this prefix as an end bound.
- 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
- asIndexBytes(ByteBuffer) - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Translates the external value of specific types into a format used by the index.
- asInt() - Method in enum org.apache.cassandra.transport.ProtocolVersion
- asList() - Method in class org.apache.cassandra.dht.Range
- asList(Function<Replica, T>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
- ASM_BYTECODE_VERSION - Static variable in class org.apache.cassandra.utils.FBUtilities
- asMap() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
- asMap() - Method in class org.apache.cassandra.hints.PendingHintsInfo
- asMap() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata.ComponentMetadata
- asMap() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata.ComponentMetadataMap
- 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
- asSequentialWriter() - Method in class org.apache.cassandra.index.sai.disk.io.IndexOutputWriter
-
Returns
SequentialWriter
associated with this writer. - assertAnyCause(Throwable, Class<? extends Throwable>) - Static method in class org.apache.cassandra.utils.Throwables
- assertBoundSize(ClusteringPrefix<?>, SSTable) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
- 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
- assignOverlapsIntoBuckets(int, Overlaps.InclusionMethod, List<Set<E>>, Overlaps.BucketMaker<E, B>) - Static method in class org.apache.cassandra.utils.Overlaps
-
Assign overlap sections into buckets.
- asStartBound() - Method in interface org.apache.cassandra.db.Clustering
- asStartBound() - Method in interface org.apache.cassandra.db.ClusteringBound
- asStartBound() - Method in interface org.apache.cassandra.db.ClusteringBoundary
- asStartBound() - Method in interface org.apache.cassandra.db.ClusteringPrefix
-
Returns this prefix as a start bound.
- asString() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
- asString(ByteBuffer) - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Allows overriding the default getString method for
CompositeType
. - assumeLiveData - Variable in class org.apache.cassandra.db.filter.DataLimits.Counter
- asUUID() - Method in class org.apache.cassandra.schema.TableId
- asUUID() - Method in class org.apache.cassandra.utils.TimeUUID
- 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(SharedContext, RepairJobDesc, InetAddressAndPort, InetAddressAndPort, List<Range<Token>>, PreviewKind) - Constructor for class org.apache.cassandra.repair.AsymmetricRemoteSyncTask
- Async() - Constructor for class org.apache.cassandra.utils.concurrent.Condition.Async
- Async() - Constructor for class org.apache.cassandra.utils.concurrent.ConditionAsConsumer.Async
- Async(int) - Constructor for class org.apache.cassandra.utils.concurrent.CountDownLatch.Async
- AsyncAwaitable() - Constructor for class org.apache.cassandra.utils.concurrent.Awaitable.AsyncAwaitable
- 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
andChannelPromise
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
- AsyncFuture<V> - Class in org.apache.cassandra.utils.concurrent
-
Our default
Future
implementation, with all state being managed without locks (except those used by the JVM). - AsyncFuture() - Constructor for class org.apache.cassandra.utils.concurrent.AsyncFuture
- AsyncFuture(GenericFutureListener<? extends Future<? super V>>) - Constructor for class org.apache.cassandra.utils.concurrent.AsyncFuture
- AsyncFuture(Throwable) - Constructor for class org.apache.cassandra.utils.concurrent.AsyncFuture
- AsyncFuture(AbstractFuture.FailureHolder) - Constructor for class org.apache.cassandra.utils.concurrent.AsyncFuture
- AsyncFuture(AbstractFuture.FailureHolder, GenericFutureListener<? extends Future<? super V>>) - Constructor for class org.apache.cassandra.utils.concurrent.AsyncFuture
- AsyncFuture(V) - Constructor for class org.apache.cassandra.utils.concurrent.AsyncFuture
- 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.utils.concurrent
-
Extends
AsyncFuture
to implement thePromise
interface. - AsyncPromise() - Constructor for class org.apache.cassandra.utils.concurrent.AsyncPromise
- AsyncPromise(GenericFutureListener<? extends Future<? super V>>) - Constructor for class org.apache.cassandra.utils.concurrent.AsyncPromise
- AsyncPromise.WithExecutor<V> - Class in org.apache.cassandra.utils.concurrent
- 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
- 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
- at(ByteBuffer, int) - Static method in class org.apache.cassandra.io.tries.TrieNode
-
Returns the type of node stored at this position.
- AtLeastOnce(SequentialExecutorPlus, Runnable) - Constructor for class org.apache.cassandra.concurrent.SingleThreadExecutorPlus.AtLeastOnce
- atLeastOnceTrigger(Runnable) - Method in interface org.apache.cassandra.concurrent.SequentialExecutorPlus
-
Return an object for orchestrating the execution of this task at least once (in its entirety) after the trigger is invoked, i.e.
- atLeastOnceTrigger(Runnable) - Method in class org.apache.cassandra.concurrent.SingleThreadExecutorPlus
- 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
- AtomicRatio - Class in org.apache.cassandra.index.sai.utils
-
AtomicRatio provides thread safe operations to maintain a
AtomicRatio.Ratio
of a numerator and denominator. - AtomicRatio() - Constructor for class org.apache.cassandra.index.sai.utils.AtomicRatio
- attach(AbstractCommitLogService, AbstractCommitLogSegmentManager) - Method in class org.apache.cassandra.metrics.CommitLogMetrics
- attach(Connection) - Method in class org.apache.cassandra.transport.Message
- attachInbound(StreamingChannel) - Method in class org.apache.cassandra.streaming.StreamSession
-
Attach a channel to this session upon receiving the first inbound message.
- attachment() - Method in class org.apache.cassandra.utils.concurrent.Ref.DirectBufferRef
- attachOutbound(StreamingChannel) - 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(BasePartitions) - Method in class org.apache.cassandra.db.transform.StoppingTransformation
- attachTo(BaseRows) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
- attachTo(BaseRows) - Method in class org.apache.cassandra.db.transform.StoppingTransformation
- attempted - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
-
Deprecated.See CASSANDRA-13910
- 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 - Variable in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata.ComponentMetadata
- 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 - Variable in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
- attrs - Variable in class org.apache.cassandra.cql3.statements.schema.CreateViewStatement.Raw
- attrs() - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
- atUnixMicros(long, Ballot.Flag) - Method in interface org.apache.cassandra.service.paxos.BallotGenerator
- atUnixMicros(long, Ballot.Flag) - Method in class org.apache.cassandra.service.paxos.BallotGenerator.Default
- atUnixMicros(long, Ballot.Flag) - Static method in class org.apache.cassandra.service.paxos.BallotGenerator.Global
- atUnixMicrosWithLsb(long, long) - Static method in class org.apache.cassandra.utils.TimeUUID
- atUnixMicrosWithLsb(long, long, Ballot.Flag) - Static method in class org.apache.cassandra.service.paxos.Ballot
- atUnixMicrosWithLsbAsUUID(long, long) - Static method in class org.apache.cassandra.utils.TimeUUID
- atUnixMillis(long) - Static method in class org.apache.cassandra.utils.TimeUUID.Generator
- atUnixMillis(long, long) - Static method in class org.apache.cassandra.utils.TimeUUID.Generator
- atUnixMillisAsBytes(long) - Static method in class org.apache.cassandra.utils.TimeUUID.Generator
- atUnixMillisAsBytes(long, long) - Static method in class org.apache.cassandra.utils.TimeUUID.Generator
- audit_logging_options - Variable in class org.apache.cassandra.config.Config
- audit_logs_dir - Variable in class org.apache.cassandra.audit.AuditLogOptions
- AUDIT_LOGS_DIR - Static variable in class org.apache.cassandra.audit.AuditLogOptionsCompositeData.AuditLogOption
- AuditEvent - Class in org.apache.cassandra.audit
-
wrapper to expose audit events as
DiagnosticEvent
s. - 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
- 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).
- AuditLogManagerMBean - Interface in org.apache.cassandra.audit
- AuditLogOption(String, String, OpenType<?>, Function<AuditLogOptions, Object>, BiConsumer<AuditLogOptions, Object>) - Constructor for class org.apache.cassandra.audit.AuditLogOptionsCompositeData.AuditLogOption
- AuditLogOptions - Class in org.apache.cassandra.audit
- AuditLogOptions() - Constructor for class org.apache.cassandra.audit.AuditLogOptions
- AuditLogOptions.Builder - Class in org.apache.cassandra.audit
- AuditLogOptionsCompositeData - Class in org.apache.cassandra.audit
- AuditLogOptionsCompositeData() - Constructor for class org.apache.cassandra.audit.AuditLogOptionsCompositeData
- AuditLogOptionsCompositeData.AuditLogOption - Class in org.apache.cassandra.audit
- 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 - org.apache.cassandra.audit.AuditLogEntryCategory
- AUTH_BCRYPT_GENSALT_LOG2_ROUNDS - org.apache.cassandra.config.CassandraRelevantProperties
-
2 ** GENSALT_LOG2_ROUNDS rounds of hashing will be performed.
- auth_cache_warming_enabled - Variable in class org.apache.cassandra.config.Config
- AUTH_CACHE_WARMING_MAX_RETRIES - org.apache.cassandra.config.CassandraRelevantProperties
-
We expect default values on cache retries and interval to be sufficient for everyone but have this escape hatch just in case.
- AUTH_CACHE_WARMING_RETRY_INTERVAL_MS - org.apache.cassandra.config.CassandraRelevantProperties
- AUTH_CHALLENGE - org.apache.cassandra.transport.Message.Type
- AUTH_KEYSPACE_NAME - Static variable in class org.apache.cassandra.schema.SchemaConstants
- AUTH_PROVIDER_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
- auth_read_consistency_level - Variable in class org.apache.cassandra.config.Config
- AUTH_RESPONSE - org.apache.cassandra.transport.Message.Type
- AUTH_SUCCESS - org.apache.cassandra.transport.Message.Type
- auth_write_consistency_level - Variable in class org.apache.cassandra.config.Config
- AuthCache<K,V> - Class in org.apache.cassandra.auth
- AuthCache(String, IntConsumer, IntSupplier, IntConsumer, IntSupplier, IntConsumer, IntSupplier, Consumer<Boolean>, BooleanSupplier, Function<K, V>, Supplier<Map<K, V>>, BooleanSupplier) - Constructor for class org.apache.cassandra.auth.AuthCache
- AuthCache(String, IntConsumer, IntSupplier, IntConsumer, IntSupplier, IntConsumer, IntSupplier, Consumer<Boolean>, BooleanSupplier, Function<K, V>, Supplier<Map<K, V>>, BooleanSupplier, BiPredicate<K, V>) - Constructor for class org.apache.cassandra.auth.AuthCache
- AuthCache.BulkLoader<K,V> - Interface in org.apache.cassandra.auth
- AuthCacheMBean - Interface in org.apache.cassandra.auth
- AuthCacheService - Class in org.apache.cassandra.auth
- AuthCacheService() - Constructor for class org.apache.cassandra.auth.AuthCacheService
- 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(Object) - Method in class org.apache.cassandra.auth.jmx.AuthenticationProxy
-
Perform authentication of the client opening the MBeanServerConnection
- authenticate(InetAddress, int) - Method in interface org.apache.cassandra.auth.IInternodeAuthenticator
-
Deprecated.See CASSANDRA-17661
- authenticate(InetAddress, int) - Method in class org.apache.cassandra.auth.MutualTlsInternodeAuthenticator
- authenticate(InetAddress, int, Certificate[], IInternodeAuthenticator.InternodeConnectionDirection) - Method in class org.apache.cassandra.auth.AllowAllInternodeAuthenticator
- authenticate(InetAddress, int, Certificate[], IInternodeAuthenticator.InternodeConnectionDirection) - Method in interface org.apache.cassandra.auth.IInternodeAuthenticator
-
Decides whether a peer is allowed to connect to this node.
- authenticate(InetAddress, int, Certificate[], IInternodeAuthenticator.InternodeConnectionDirection) - Method in class org.apache.cassandra.auth.MutualTlsInternodeAuthenticator
- AUTHENTICATE - org.apache.cassandra.transport.Message.Type
- 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
- authenticateInternodeWithMtls(InetAddress, int, Certificate[], IInternodeAuthenticator.InternodeConnectionDirection) - Method in class org.apache.cassandra.auth.MutualTlsInternodeAuthenticator
- 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
- AUTHENTICATING - org.apache.cassandra.transport.ConnectionStage
- 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 aLoginContext
. - 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 - Variable in class org.apache.cassandra.transport.messages.AuthenticateMessage
- authenticator() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
- 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
- AuthorizationProxy.JmxPermissionsCache - Class in org.apache.cassandra.auth.jmx
- AuthorizationProxy.JmxPermissionsCacheMBean - Interface in org.apache.cassandra.auth.jmx
- AuthorizationStatement - Class in org.apache.cassandra.cql3.statements
- AuthorizationStatement() - Constructor for class org.apache.cassandra.cql3.statements.AuthorizationStatement
- authorize(Subject, String, Object[]) - Method in class org.apache.cassandra.auth.jmx.AuthorizationProxy
-
Performs the actual authorization of an identified subject to execute a remote method invocation.
- authorize(AuthenticatedUser, IResource) - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
- authorize(AuthenticatedUser, IResource) - Method in class org.apache.cassandra.auth.CassandraAuthorizer
- authorize(AuthenticatedUser, IResource) - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Returns a set of permissions of a user on a resource.
- authorize(RoleResource) - Method in class org.apache.cassandra.auth.AllowAllNetworkAuthorizer
- authorize(RoleResource) - Method in class org.apache.cassandra.auth.CassandraNetworkAuthorizer
- 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.AddIdentityStatement
- 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.DropIdentityStatement
- 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
- AUTHORIZE - org.apache.cassandra.auth.Permission
- authorizedIdentities() - Method in class org.apache.cassandra.auth.CassandraRoleManager
- authorizedIdentities() - Method in interface org.apache.cassandra.auth.IRoleManager
-
Returns all the authorized identities from the identity_to_role table
- authorizer - Variable in class org.apache.cassandra.config.Config
- AuthProperties - Class in org.apache.cassandra.auth
- AuthProperties(ConsistencyLevel, ConsistencyLevel, boolean) - Constructor for class org.apache.cassandra.auth.AuthProperties
- AuthPropertiesMXBean - Interface in org.apache.cassandra.auth
- authProvider - Variable in class org.apache.cassandra.tools.LoaderOptions
- authReadConsistencyLevel() - Static method in class org.apache.cassandra.auth.CassandraAuthorizer
- 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
- authSetupCalled() - Method in class org.apache.cassandra.service.StorageService
- 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
- authWriteConsistencyLevel() - Static method in class org.apache.cassandra.auth.CassandraAuthorizer
- auto - org.apache.cassandra.config.Config.DiskAccessMode
- auto(boolean) - Method in class org.apache.cassandra.utils.btree.BTree.Builder
- auto_bootstrap - Variable in class org.apache.cassandra.config.Config
- AUTO_BOOTSTRAP - org.apache.cassandra.config.CassandraRelevantProperties
- auto_hints_cleanup_enabled - 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_REPAIR_FREQUENCY_SECONDS - org.apache.cassandra.config.CassandraRelevantProperties
- auto_snapshot - Variable in class org.apache.cassandra.config.Config
- auto_snapshot_ttl - Variable in class org.apache.cassandra.config.Config
-
When auto_snapshot is true and this property is set, snapshots created by truncation or drop use this TTL.
- autocompaction_on_startup_enabled - Variable in class org.apache.cassandra.config.Config
- AUTOCOMPACTION_ON_STARTUP_ENABLED - org.apache.cassandra.config.CassandraRelevantProperties
- 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
- autoRepairPaxos(TableId) - Method in class org.apache.cassandra.service.StorageService
- 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> - Class in org.apache.cassandra.cache
-
A base cache serializer that is used to serialize/deserialize a cache to/from disk.
- 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 interface org.apache.cassandra.utils.concurrent.LightweightRecycler
- available_processors - Variable in class org.apache.cassandra.config.Config
- 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.FutureDelegate
- await() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosRepair
- await() - Method in class org.apache.cassandra.service.paxos.v1.AbstractPaxosCallback
- await() - Method in class org.apache.cassandra.utils.concurrent.AsyncFuture
-
Wait for this future to complete
Awaitable.await()
- await() - Method in class org.apache.cassandra.utils.concurrent.AsyncPromise
-
Wait for this promise to complete
- await() - Method in class org.apache.cassandra.utils.concurrent.Awaitable.AsyncAwaitable
- await() - Method in interface org.apache.cassandra.utils.concurrent.Awaitable
-
Await indefinitely, throwing any interrupt.
- await() - Method in class org.apache.cassandra.utils.concurrent.Awaitable.SyncAwaitable
- await() - Method in interface org.apache.cassandra.utils.concurrent.Future
-
Wait indefinitely for this future to complete, throwing any interrupt
- 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 interface org.apache.cassandra.utils.concurrent.Promise
-
Wait indefinitely for this promise to complete, throwing any interrupt
- await() - Method in class org.apache.cassandra.utils.concurrent.SyncFuture
- await() - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
-
Wait for this promise to complete
- await() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue.Standard.AbstractSignal
- await(long) - Method in class org.apache.cassandra.net.FutureDelegate
- await(long) - Method in interface org.apache.cassandra.utils.concurrent.Future
-
Deprecated.See CASSANDRA-16924
- await(long, TimeUnit) - Method in class org.apache.cassandra.net.FutureDelegate
- await(long, TimeUnit) - Method in class org.apache.cassandra.service.reads.ReadCallback
- await(long, TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- await(long, TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.Awaitable.AbstractAwaitable
- await(long, TimeUnit) - Method in interface org.apache.cassandra.utils.concurrent.Awaitable
-
Await for the specified period, throwing any interrupt.
- await(Awaitable, long, TimeUnit) - Static method in class org.apache.cassandra.utils.concurrent.Awaitable.Defaults
- Awaitable - Interface in org.apache.cassandra.utils.concurrent
-
A generic signal consumer, supporting all of the typical patterns used in Cassandra.
- Awaitable.AbstractAwaitable - Class in org.apache.cassandra.utils.concurrent
- Awaitable.AsyncAwaitable - Class in org.apache.cassandra.utils.concurrent
-
A barebones asynchronous
Awaitable
. - Awaitable.Defaults - Class in org.apache.cassandra.utils.concurrent
- Awaitable.SyncAwaitable - Class in org.apache.cassandra.utils.concurrent
-
A barebones
Awaitable
that uses mutual exclusion. - 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.
- 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
-
Block on the reads (or timeout) sent out in
ReadRepair.startRepair(org.apache.cassandra.service.reads.DigestResolver<E, P>, java.util.function.Consumer<org.apache.cassandra.db.partitions.PartitionIterator>)
- 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 {@param timeoutAt} is a past time, the method returns immediately with the repair result.
- awaitResponses() - Method in class org.apache.cassandra.service.reads.AbstractReadExecutor
- awaitResponses(boolean) - 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
- awaitTermination() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
- awaitTermination(long, TimeUnit) - Method in class org.apache.cassandra.auth.AuthCache
- 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(long, TimeUnit) - Method in interface org.apache.cassandra.concurrent.Shutdownable
-
Await termination of this object, i.e.
- awaitTermination(long, TimeUnit) - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- awaitTermination(long, TimeUnit) - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogSegmentManager
-
Returns when the management thread terminates.
- awaitTermination(long, TimeUnit) - Method in class org.apache.cassandra.utils.memory.MemtableCleanerThread
- awaitTermination(long, TimeUnit, Collection<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
- awaitTermination(long, TimeUnit, ExecutorService...) - Static method in class org.apache.cassandra.utils.ExecutorUtils
- awaitTerminationUntil(long, Collection<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
- awaitThrowUncheckedOnInterrupt() - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
-
Wait for this future to complete
Awaitable.awaitThrowUncheckedOnInterrupt()
- awaitThrowUncheckedOnInterrupt() - Method in class org.apache.cassandra.utils.concurrent.AsyncPromise
-
Wait for this promise to complete, throwing any interrupt as an UncheckedInterruptedException
- awaitThrowUncheckedOnInterrupt() - Method in class org.apache.cassandra.utils.concurrent.Awaitable.AbstractAwaitable
- awaitThrowUncheckedOnInterrupt() - Method in interface org.apache.cassandra.utils.concurrent.Awaitable
-
Await indefinitely, throwing any interrupt as an unchecked exception.
- awaitThrowUncheckedOnInterrupt() - Method in interface org.apache.cassandra.utils.concurrent.Future
-
Wait indefinitely for this promise to complete, throwing any interrupt as an UncheckedInterruptedException
- awaitThrowUncheckedOnInterrupt() - Method in interface org.apache.cassandra.utils.concurrent.Promise
-
Wait indefinitely for this promise to complete, throwing any interrupt as an UncheckedInterruptedException
- awaitThrowUncheckedOnInterrupt() - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
-
Wait for this promise to complete, throwing any interrupt as an UncheckedInterruptedException
- awaitThrowUncheckedOnInterrupt(long, TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- awaitThrowUncheckedOnInterrupt(long, TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.Awaitable.AbstractAwaitable
- awaitThrowUncheckedOnInterrupt(long, TimeUnit) - Method in interface org.apache.cassandra.utils.concurrent.Awaitable
-
Await for the specified period, throwing any interrupt as an unchecked exception.
- awaitThrowUncheckedOnInterrupt(A) - Static method in class org.apache.cassandra.utils.concurrent.Awaitable.Defaults
- awaitThrowUncheckedOnInterrupt(Awaitable, long, TimeUnit) - Static method in class org.apache.cassandra.utils.concurrent.Awaitable.Defaults
- awaitUninterruptibly() - Method in class org.apache.cassandra.net.AsyncChannelPromise
- awaitUninterruptibly() - Method in class org.apache.cassandra.net.FutureDelegate
- awaitUninterruptibly() - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
-
Wait for this future to complete
Awaitable.awaitUninterruptibly()
- awaitUninterruptibly() - Method in class org.apache.cassandra.utils.concurrent.AsyncPromise
-
Wait uninterruptibly for this promise to complete
- awaitUninterruptibly() - Method in class org.apache.cassandra.utils.concurrent.Awaitable.AbstractAwaitable
- awaitUninterruptibly() - Method in interface org.apache.cassandra.utils.concurrent.Awaitable
-
Await indefinitely, ignoring interrupts (but maintaining the interrupt flag on exit).
- awaitUninterruptibly() - Method in interface org.apache.cassandra.utils.concurrent.Future
-
Wait indefinitely for this future to complete
- awaitUninterruptibly() - Method in interface org.apache.cassandra.utils.concurrent.Promise
-
Wait indefinitely for this promise to complete
- awaitUninterruptibly() - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
-
Wait uninterruptibly for this promise to complete
- awaitUninterruptibly(long) - Method in class org.apache.cassandra.net.FutureDelegate
- awaitUninterruptibly(long) - Method in interface org.apache.cassandra.utils.concurrent.Future
-
Deprecated.See CASSANDRA-16924
- awaitUninterruptibly(long, TimeUnit) - Method in class org.apache.cassandra.net.FutureDelegate
- awaitUninterruptibly(long, TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- awaitUninterruptibly(long, TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.Awaitable.AbstractAwaitable
- awaitUninterruptibly(long, TimeUnit) - Method in interface org.apache.cassandra.utils.concurrent.Awaitable
-
Await until the deadline (in nanoTime), ignoring interrupts (but maintaining the interrupt flag on exit).
- awaitUninterruptibly(A) - Static method in class org.apache.cassandra.utils.concurrent.Awaitable.Defaults
- awaitUninterruptibly(Awaitable, long, TimeUnit) - Static method in class org.apache.cassandra.utils.concurrent.Awaitable.Defaults
- awaitUntil(long) - Method in interface org.apache.cassandra.service.paxos.Paxos.Async
- awaitUntil(long) - Method in class org.apache.cassandra.service.paxos.PaxosPrepare
- awaitUntil(long) - Method in class org.apache.cassandra.service.reads.ReadCallback
-
In case of speculation, we want to time out the request immediately if we have _also_ hit a deadline.
- awaitUntil(long) - Method in class org.apache.cassandra.utils.concurrent.AsyncFuture
- awaitUntil(long) - Method in class org.apache.cassandra.utils.concurrent.Awaitable.AsyncAwaitable
- awaitUntil(long) - Method in interface org.apache.cassandra.utils.concurrent.Awaitable
-
Await until the deadline (in nanoTime), throwing any interrupt.
- awaitUntil(long) - Method in class org.apache.cassandra.utils.concurrent.Awaitable.SyncAwaitable
- awaitUntil(long) - Method in class org.apache.cassandra.utils.concurrent.SyncFuture
- awaitUntil(long) - Method in class org.apache.cassandra.utils.concurrent.WaitQueue.Standard.AbstractSignal
- awaitUntilThrowUncheckedOnInterrupt(long) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- awaitUntilThrowUncheckedOnInterrupt(long) - Method in class org.apache.cassandra.utils.concurrent.Awaitable.AbstractAwaitable
- awaitUntilThrowUncheckedOnInterrupt(long) - Method in interface org.apache.cassandra.utils.concurrent.Awaitable
-
Await until the deadline (in nanoTime), throwing any interrupt as an unchecked exception.
- awaitUntilThrowUncheckedOnInterrupt(Awaitable, long) - Static method in class org.apache.cassandra.utils.concurrent.Awaitable.Defaults
- awaitUntilUninterruptibly(long) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- awaitUntilUninterruptibly(long) - Method in class org.apache.cassandra.utils.concurrent.Awaitable.AbstractAwaitable
- awaitUntilUninterruptibly(long) - Method in interface org.apache.cassandra.utils.concurrent.Awaitable
-
Await until the deadline (in nanoTime), ignoring interrupts (but maintaining the interrupt flag on exit).
- awaitUntilUninterruptibly(Awaitable, long) - Static method in class org.apache.cassandra.utils.concurrent.Awaitable.Defaults
- 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
-
Block on any mutations (or timeout) we sent out to repair replicas in
ReadRepair.repairPartition(org.apache.cassandra.db.DecoratedKey, java.util.Map<org.apache.cassandra.locator.Replica, org.apache.cassandra.db.Mutation>, org.apache.cassandra.locator.ReplicaPlan.ForWrite)
- AzureSnitch - Class in org.apache.cassandra.locator
-
AzureSnitch will resolve datacenter and rack by calling
/metadata/instance/compute
endpoint returning the response in JSON format for API version2021-12-13
. - AzureSnitch() - Constructor for class org.apache.cassandra.locator.AzureSnitch
- AzureSnitch(AbstractCloudMetadataServiceConnector) - Constructor for class org.apache.cassandra.locator.AzureSnitch
- AzureSnitch(SnitchProperties) - Constructor for class org.apache.cassandra.locator.AzureSnitch
B
- back_pressure_enabled - Variable in class org.apache.cassandra.config.Config
-
Deprecated.See CASSANDRA-15375
- back_pressure_strategy - Variable in class org.apache.cassandra.config.Config
-
Deprecated.See CASSANDRA-15375
- Backoff - Interface in org.apache.cassandra.utils
- Backoff.ExponentialBackoff - Class in org.apache.cassandra.utils
- Backoff.None - Enum in org.apache.cassandra.utils
- BACKUPS_SUBDIR - Static variable in class org.apache.cassandra.db.Directories
- BAD_CREDENTIALS - org.apache.cassandra.exceptions.ExceptionCode
- badPartitions - Variable in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- badPartitions - Variable in class org.apache.cassandra.io.sstable.IScrubber.ScrubResult
- badUse(Exception) - Method in class org.apache.cassandra.tools.NodeTool
- BALANCED_TREE - org.apache.cassandra.index.sai.disk.format.IndexComponent
-
Balanced tree written by
BlockBalancedTreeWriter
indexes mappings of term to one or more segment row IDs (segment row ID = SSTable row ID - segment row ID offset). - balancedTree() - Method in class org.apache.cassandra.index.sai.disk.v1.PerColumnIndexFiles
- BalancedTreeIndexMetrics(IndexIdentifier) - Constructor for class org.apache.cassandra.index.sai.metrics.ColumnQueryMetrics.BalancedTreeIndexMetrics
- balancedTreePostingListsHit - Variable in class org.apache.cassandra.index.sai.QueryContext
- balancedTreePostingsDecodes - Variable in class org.apache.cassandra.index.sai.QueryContext
- balancedTreePostingsSkips - Variable in class org.apache.cassandra.index.sai.QueryContext
- balancedTreeQueryFrom(Expression, int) - Static method in class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeQueries
- balancedTreeSegmentsHit - Variable in class org.apache.cassandra.index.sai.QueryContext
- ballot - Variable in class org.apache.cassandra.service.paxos.Commit
- ballot() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosKeyState
- ballot() - Method in interface org.apache.cassandra.service.paxos.uncommitted.UncommittedPaxosKey
- Ballot - Class in org.apache.cassandra.service.paxos
- Ballot.Flag - Enum in org.apache.cassandra.service.paxos
- Ballot.Serializer - Class in org.apache.cassandra.service.paxos
- ballotForConsistency(long, ConsistencyLevel) - Static method in class org.apache.cassandra.service.paxos.Paxos
-
Create a ballot uuid with the consistency level encoded in the timestamp.
- ballotForToken(Token) - Method in class org.apache.cassandra.service.paxos.PaxosRepairHistory
- ballotForToken(Token) - Method in class org.apache.cassandra.service.paxos.PaxosRepairHistory.Searcher
- BallotGenerator - Interface in org.apache.cassandra.service.paxos
- BallotGenerator.Default - Class in org.apache.cassandra.service.paxos
- BallotGenerator.Global - Class in org.apache.cassandra.service.paxos
- ballots() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosStateTracker
- ballotTracker() - Static method in class org.apache.cassandra.service.paxos.PaxosState
- 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.
- 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
- baseCfs - Variable in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- baseCfs() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- baseFile() - Method in class org.apache.cassandra.io.sstable.Descriptor
- BaseKeyScanningIterator() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableScanner.BaseKeyScanningIterator
- baseNonPKColumnsInViewPK - Variable in class org.apache.cassandra.db.view.View
- baseOperator - Variable in class org.apache.cassandra.index.sai.plan.FilterTree
- 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
- BasePhase() - Constructor for class org.apache.cassandra.repair.state.AbstractCompletable.BasePhase
- 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
- baseShardCount - Variable in class org.apache.cassandra.db.compaction.unified.Controller
- BaseSkipPhase() - Constructor for class org.apache.cassandra.repair.state.AbstractCompletable.BaseSkipPhase
- baseSleepTime - Variable in class org.apache.cassandra.config.RetrySpec
- 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
- baseTimeNanos() - Method in class org.apache.cassandra.transport.Dispatcher.RequestTime
-
Base time is used by timeouts, and can be set to either when the request was added to the queue, or when the processing has started, which is controlled by
DatabaseDescriptor.getCQLStartTime()
Since client read/write timeouts are usually aligned with server-side timeouts, it is desireable to use enqueue time as a base. - baseType - Variable in class org.apache.cassandra.db.marshal.ReversedType
- Basic(long) - Constructor for class org.apache.cassandra.net.ResourceLimits.Basic
- BasicFilters - Class in org.apache.cassandra.index.sai.analyzer.filter
- BasicFilters() - Constructor for class org.apache.cassandra.index.sai.analyzer.filter.BasicFilters
- BasicFilters.Ascii - Class in org.apache.cassandra.index.sai.analyzer.filter
- BasicFilters.LowerCase - Class in org.apache.cassandra.index.sai.analyzer.filter
- BasicFilters.NoOperation - Class in org.apache.cassandra.index.sai.analyzer.filter
- BasicFilters.Normalize - Class in org.apache.cassandra.index.sai.analyzer.filter
- 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 - org.apache.cassandra.config.Config.CommitLogSync
- Batch - Class in org.apache.cassandra.batchlog
- Batch(BatchStatement.Type, List<String>, List<List<ByteBuffer>>, QueryOptions, QueryState, long) - Constructor for class org.apache.cassandra.fql.FullQueryLogger.Batch
- BATCH - org.apache.cassandra.audit.AuditLogEntryType
- BATCH - org.apache.cassandra.db.WriteType
- BATCH - org.apache.cassandra.transport.Message.Type
- BATCH - Static variable in class org.apache.cassandra.fql.FullQueryLogger
- BATCH_COMMIT_LOG_SYNC_INTERVAL - org.apache.cassandra.config.CassandraRelevantProperties
- BATCH_LOG - org.apache.cassandra.db.WriteType
- BATCH_REMOVE_REQ - org.apache.cassandra.net.Verb
- BATCH_REMOVE_RSP - org.apache.cassandra.net.Verb
- batch_size_fail_threshold - Variable in class org.apache.cassandra.config.Config
- batch_size_warn_threshold - Variable in class org.apache.cassandra.config.Config
- BATCH_STORE_REQ - org.apache.cassandra.net.Verb
- BATCH_STORE_RSP - org.apache.cassandra.net.Verb
- BATCH_TYPE - Static variable in class org.apache.cassandra.fql.FullQueryLogger
- Batch.Serializer - Class in org.apache.cassandra.batchlog
- batchComponents() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- batchComponents() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- batchComponents() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
Returns components required by offline compaction tasks - like splitting sstables.
- 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 - Variable in class org.apache.cassandra.config.Config
- BATCHLOG_REPLAY_TIMEOUT - Static variable in class org.apache.cassandra.batchlog.BatchlogManager
- BATCHLOG_REPLAY_TIMEOUT_IN_MS - org.apache.cassandra.config.CassandraRelevantProperties
- 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, Dispatcher.RequestTime) - 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
- BatchMetricsTable - Class in org.apache.cassandra.db.virtual
- 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
- before - Variable in class org.apache.cassandra.schema.SchemaTransformation.SchemaTransformationResult
- 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.schema.DefaultSchemaUpdateHandler
- 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.disk.usage.DiskUsageBroadcaster
- beforeChange(InetAddressAndPort, EndpointState, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupSession
- beforeChange(InetAddressAndPort, EndpointState, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.StorageService
- beforeExecution() - Method in class org.apache.cassandra.cql3.functions.TimeFcts.TemporalConversionFunction
- 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.sai.disk.StorageAttachedIndexWriter
- begin() - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
- begin() - Method in interface org.apache.cassandra.io.sstable.SSTableFlushObserver
-
Called before writing any data to the sstable.
- begin(String, InetAddress, Map<String, String>) - Method in class org.apache.cassandra.tracing.Tracing
- begin(String, 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(long, long, long) - 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, long) - Method in class org.apache.cassandra.metrics.FrequencySampler
-
Start to record samples
- beginSampling(int, long) - Method in class org.apache.cassandra.metrics.MaxSampler
- beginSampling(int, long) - Method in class org.apache.cassandra.metrics.Sampler
-
Begin sampling with the configured capacity and duration
- beginWrite(Mutation, boolean) - Method in class org.apache.cassandra.db.CassandraKeyspaceWriteHandler
- beginWrite(Mutation, boolean) - Method in interface org.apache.cassandra.db.KeyspaceWriteHandler
- BELOW_LIMIT - org.apache.cassandra.net.ResourceLimits.Outcome
- BEST_COMPRESSION_LEVEL - Static variable in class org.apache.cassandra.io.compress.ZstdCompressor
- best_effort - org.apache.cassandra.config.Config.DiskFailurePolicy
- 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.SortedTableWriter.AbstractIndexWriter
- BIG_ENDIAN - Static variable in class org.apache.cassandra.utils.Architecture
- BigFormat - Class in org.apache.cassandra.io.sstable.format.big
-
Legacy bigtable format
- BigFormat(Map<String, String>) - Constructor for class org.apache.cassandra.io.sstable.format.big.BigFormat
- BigFormat.BigFormatFactory - Class in org.apache.cassandra.io.sstable.format.big
- BigFormat.Components - Class in org.apache.cassandra.io.sstable.format.big
- BigFormat.Components.Types - Class in org.apache.cassandra.io.sstable.format.big
- BigFormatFactory() - Constructor for class org.apache.cassandra.io.sstable.format.big.BigFormat.BigFormatFactory
- BigFormatPartitionWriter - Class in org.apache.cassandra.io.sstable.format.big
-
Column index builder used by
BigTableWriter
. - 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
. - BIGINT - org.apache.cassandra.cql3.CQL3Type.Native
- BIGINT - org.apache.cassandra.cql3.functions.types.DataType.Name
- BIGINT - org.apache.cassandra.transport.DataType
- BigIntegerToken(String) - Constructor for class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
- BigIntegerToken(BigInteger) - Constructor for class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
- BigScanningIterator() - Constructor for class org.apache.cassandra.io.sstable.format.big.BigTableScanner.BigScanningIterator
- BigSSTableReaderLoadingBuilder - Class in org.apache.cassandra.io.sstable.format.big
- BigSSTableReaderLoadingBuilder(SSTable.Builder<?, ?>) - Constructor for class org.apache.cassandra.io.sstable.format.big.BigSSTableReaderLoadingBuilder
- BigTableKeyReader - Class in org.apache.cassandra.io.sstable.format.big
- 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.
- BigTableReader(BigTableReader.Builder, SSTable.Owner) - Constructor for class org.apache.cassandra.io.sstable.format.big.BigTableReader
- BigTableReader.Builder - Class in org.apache.cassandra.io.sstable.format.big
- BigTableScanner - Class in org.apache.cassandra.io.sstable.format.big
- BigTableScanner.BigScanningIterator - Class in org.apache.cassandra.io.sstable.format.big
- BigTableScrubber - Class in org.apache.cassandra.io.sstable.format.big
- BigTableScrubber(ColumnFamilyStore, LifecycleTransaction, OutputHandler, IScrubber.Options) - Constructor for class org.apache.cassandra.io.sstable.format.big.BigTableScrubber
- BigTableVerifier - Class in org.apache.cassandra.io.sstable.format.big
- BigTableVerifier(ColumnFamilyStore, BigTableReader, OutputHandler, boolean, IVerifier.Options) - Constructor for class org.apache.cassandra.io.sstable.format.big.BigTableVerifier
- BigTableWriter - Class in org.apache.cassandra.io.sstable.format.big
- BigTableWriter(BigTableWriter.Builder, LifecycleNewTracker, SSTable.Owner) - Constructor for class org.apache.cassandra.io.sstable.format.big.BigTableWriter
- BigTableWriter.Builder - Class in org.apache.cassandra.io.sstable.format.big
- BigTableWriter.IndexWriter - Class in org.apache.cassandra.io.sstable.format.big
-
Encapsulates writing the index and filter for an SSTable.
- 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.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(AuditLogOptions) - Constructor for class org.apache.cassandra.audit.BinAuditLogger
- BinAuditLogger.Message - Class in org.apache.cassandra.audit
- bind(String, Remote) - Method in class org.apache.cassandra.utils.JMXServerUtils.JmxRegistry
- 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(QueryOptions) - Method in class org.apache.cassandra.cql3.Vectors.DelayedValue
- bind(InboundConnectionSettings, ChannelGroup, Consumer<ChannelPipeline>) - Static method in class org.apache.cassandra.net.InboundConnectionInitiator
- bind(TableMetadata, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Ordering.Raw.Ann
- bind(TableMetadata, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Ordering.Raw
-
Resolves column identifiers against the table schema.
- bind(TableMetadata, VariableSpecifications) - Method in interface org.apache.cassandra.cql3.Ordering.Raw.Expression
- bind(TableMetadata, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Ordering.Raw.SingleColumn
- 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
- bitsetForShadowedPrimaryKeys(SegmentMetadata, PrimaryKeyMap, DiskAnn) - Method in class org.apache.cassandra.index.sai.VectorQueryContext
- bitsetForShadowedPrimaryKeys(OnHeapGraph<PrimaryKey>) - Method in class org.apache.cassandra.index.sai.VectorQueryContext
- bitsIgnoringDeleted(Bits, Set<Integer>) - Static method in class org.apache.cassandra.index.sai.disk.v1.vector.BitsUtil
- bitsIgnoringDeleted(Bits, NonBlockingHashMapLong<VectorPostings<T>>) - Static method in class org.apache.cassandra.index.sai.disk.v1.vector.BitsUtil
- BitsUtil - Class in org.apache.cassandra.index.sai.disk.v1.vector
- BitsUtil() - Constructor for class org.apache.cassandra.index.sai.disk.v1.vector.BitsUtil
- 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
. - BLOB - org.apache.cassandra.cql3.CQL3Type.Native
- BLOB - org.apache.cassandra.cql3.functions.types.DataType.Name
- BLOB - org.apache.cassandra.transport.DataType
- 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 - Static variable in class org.apache.cassandra.audit.AuditLogOptionsCompositeData.AuditLogOption
- 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.sai.disk.v1.bitpack.NumericValuesWriter
- BLOCK_SIZE - Static variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
- BlockBalancedTreePostingsWriter - Class in org.apache.cassandra.index.sai.disk.v1.bbtree
-
Writes leaf postings and auxiliary posting lists for bbtree nodes.
- BlockBalancedTreePostingsWriter() - Constructor for class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreePostingsWriter
- BlockBalancedTreeQueries - Class in org.apache.cassandra.index.sai.disk.v1.bbtree
- BlockBalancedTreeQueries() - Constructor for class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeQueries
- BlockBalancedTreeReader - Class in org.apache.cassandra.index.sai.disk.v1.bbtree
-
Handles intersection of a point or point range with a block balanced tree previously written with
BlockBalancedTreeWriter
. - BlockBalancedTreeReader(IndexIdentifier, FileHandle, long, FileHandle, long) - Constructor for class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeReader
-
Performs a blocking read.
- BlockBalancedTreeReader.IntersectVisitor - Interface in org.apache.cassandra.index.sai.disk.v1.bbtree
-
We recurse the balanced tree, using a provided instance of this to guide the recursion.
- BlockBalancedTreeWalker - Class in org.apache.cassandra.index.sai.disk.v1.bbtree
-
Base reader for a block balanced tree previously written with
BlockBalancedTreeWriter
. - BlockBalancedTreeWalker(DataInput, long) - Constructor for class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeWalker
- BlockBalancedTreeWriter - Class in org.apache.cassandra.index.sai.disk.v1.bbtree
-
This is a specialisation of the Lucene
BKDWriter
that only writes a single dimension balanced tree. - BlockBalancedTreeWriter(int, int) - Constructor for class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeWriter
- blockCount - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.Level
- blockCount() - Method in class org.apache.cassandra.io.sstable.AbstractRowIndexEntry
- blockCount() - Method in class org.apache.cassandra.io.sstable.format.big.RowIndexEntry
- blockedOnAllocating - Variable in class org.apache.cassandra.utils.memory.MemtablePool
- blockedTimerContext() - Method in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
- 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.service.AbstractWriteResponseHandler
- blockFor() - Method in class org.apache.cassandra.service.BatchlogResponseHandler
- blockFor() - Method in class org.apache.cassandra.service.reads.ReadCallback
- blockFor(AbstractReplicationStrategy) - Method in enum org.apache.cassandra.db.ConsistencyLevel
- 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.sai.disk.v1.bitpack.AbstractBlockPackedWriter
- 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
- BLOCKING - org.apache.cassandra.service.reads.repair.ReadRepairStrategy
- blockingExecutionHandler - Static variable in class org.apache.cassandra.concurrent.ThreadPoolExecutorBase
- blockingLoadIfAbsent(K, Supplier<? extends V>) - Method in class org.apache.cassandra.utils.concurrent.LoadingMap
-
If the value for the given key is missing, execute a load function to obtain a value and put it into the map.
- BlockingPartitionRepair - Class in org.apache.cassandra.service.reads.repair
- BlockingPartitionRepair(DecoratedKey, Map<Replica, Mutation>, ReplicaPlan.ForWrite) - Constructor for class org.apache.cassandra.service.reads.repair.BlockingPartitionRepair
- BlockingQueues - Class in org.apache.cassandra.utils.concurrent
- BlockingQueues() - Constructor for class org.apache.cassandra.utils.concurrent.BlockingQueues
- BlockingQueues.Sync<T> - Class in org.apache.cassandra.utils.concurrent
- BlockingReadRepair<E extends Endpoints<E>,P extends ReplicaPlan.ForRead<E,P>> - 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
- blockingUnloadIfPresent(K, Consumer<? super V>) - Method in class org.apache.cassandra.utils.concurrent.LoadingMap
-
If a value for the given key is present, unload function is run and the value is removed from the map.
- blockMetaOffset - Variable in class org.apache.cassandra.index.sai.disk.v1.bitpack.NumericValuesMeta
- blockMetaWriter - Variable in class org.apache.cassandra.index.sai.disk.v1.bitpack.AbstractBlockPackedWriter
- blockOffsetAt(int) - Method in class org.apache.cassandra.index.sai.disk.v1.bitpack.AbstractBlockPackedReader
- blockOffsets - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.Level
- BlockPackedReader - Class in org.apache.cassandra.index.sai.disk.v1.bitpack
-
Provides non-blocking, random access to a stream written with
BlockPackedWriter
. - BlockPackedReader(FileHandle, NumericValuesMeta) - Constructor for class org.apache.cassandra.index.sai.disk.v1.bitpack.BlockPackedReader
- BlockPackedWriter - Class in org.apache.cassandra.index.sai.disk.v1.bitpack
-
A writer for large sequences of longs.
- BlockPackedWriter(IndexOutput, int) - Constructor for class org.apache.cassandra.index.sai.disk.v1.bitpack.BlockPackedWriter
- blocksCount() - Method in class org.apache.cassandra.io.sstable.format.big.IndexState
- blockSize - Variable in class org.apache.cassandra.index.sai.disk.v1.bitpack.NumericValuesMeta
- BlocksSummary(IndexInput, long) - Constructor for class org.apache.cassandra.index.sai.disk.v1.postings.PostingsReader.BlocksSummary
- blockUntilFinished() - Method in class org.apache.cassandra.service.PendingRangeCalculatorService
- blockValues - Variable in class org.apache.cassandra.index.sai.disk.v1.bitpack.AbstractBlockPackedWriter
- BLOOM_FILTER - org.apache.cassandra.io.sstable.SSTableReadsListener.SkippingReason
- BLOOM_FILTER_FP_CHANCE - org.apache.cassandra.schema.TableParams.Option
- 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.io.sstable.filter.BloomFilterMetrics
-
Disk space used by bloom filter
- bloomFilterFalsePositives - Variable in class org.apache.cassandra.io.sstable.filter.BloomFilterMetrics
-
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.io.sstable.filter.BloomFilterMetrics
-
False positive ratio of bloom filter
- bloomFilterFalseRatio - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- bloomFilterFpChance - Variable in class org.apache.cassandra.schema.TableParams
- bloomFilterFpChance(double) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- bloomFilterFpChance(double) - Method in class org.apache.cassandra.schema.TableParams.Builder
- bloomFilterFPChance - Variable in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
- BloomFilterMetrics<R extends SSTableReaderWithFilter> - Class in org.apache.cassandra.io.sstable.filter
- BloomFilterMetrics() - Constructor for class org.apache.cassandra.io.sstable.filter.BloomFilterMetrics
- bloomFilterOffHeapMemoryUsed - Variable in class org.apache.cassandra.io.sstable.filter.BloomFilterMetrics
-
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.filter
- BloomFilterTracker() - Constructor for class org.apache.cassandra.io.sstable.filter.BloomFilterTracker
- 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 - Variable in class org.apache.cassandra.transport.Envelope
- body() - Method in class org.apache.cassandra.cql3.functions.UDFunction
- 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
- BOOLEAN - org.apache.cassandra.cql3.Constants.Type
- BOOLEAN - org.apache.cassandra.cql3.CQL3Type.Native
- BOOLEAN - org.apache.cassandra.cql3.functions.types.DataType.Name
- BOOLEAN - org.apache.cassandra.transport.DataType
- BooleanSerializer - Class in org.apache.cassandra.serializers
- BooleanSerializer - Class in org.apache.cassandra.utils
- BooleanSerializer() - Constructor for class org.apache.cassandra.serializers.BooleanSerializer
- 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.See CASSANDRA-7544
- bootReplacingWithPort(InetAddressAndPort) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- bootstrap - Variable in class org.apache.cassandra.transport.SimpleClient
- bootstrap(Collection<Token>, long) - Method in class org.apache.cassandra.service.StorageService
-
Bootstrap node by fetching data from other nodes.
- bootstrap(StreamStateStore, boolean) - Method in class org.apache.cassandra.dht.BootStrapper
- BOOTSTRAP - org.apache.cassandra.streaming.StreamOperation
- BOOTSTRAP_SCHEMA_DELAY_MS - org.apache.cassandra.config.CassandraRelevantProperties
-
When bootstraping how long to wait for schema versions to be seen.
- BOOTSTRAP_SKIP_SCHEMA_CHECK - org.apache.cassandra.config.CassandraRelevantProperties
-
When bootstraping we wait for all schema versions found in gossip to be seen, and if not seen in time we fail the bootstrap; this property will avoid failing and allow bootstrap to continue if set to true.
- 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
- BOOTSTRAPPING_STATUS - Static variable in class org.apache.cassandra.gms.VersionedValue
- 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
- BOUNCE - org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator.Strategy
- bound - Variable in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
- bound(ClusteringPrefix.Kind) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor.ObjectFactory
- bound(ClusteringPrefix.Kind, V...) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor.ObjectFactory
- Bound - Enum in org.apache.cassandra.cql3.statements
- Bound(ByteBuffer, boolean) - Constructor for class org.apache.cassandra.index.sasi.plan.Expression.Bound
- Bound(ByteBuffer, IndexTermType, boolean) - Constructor for class org.apache.cassandra.index.sai.plan.Expression.Bound
- Bound(ColumnMetadata, Operator) - Constructor for class org.apache.cassandra.cql3.conditions.ColumnCondition.Bound
- boundaries - Variable in class org.apache.cassandra.db.memtable.AbstractShardedMemtable
- boundaries(int) - Method in interface org.apache.cassandra.db.compaction.ShardManager
-
Construct a boundary/shard iterator for the given number of shards.
- boundaries(int) - Method in class org.apache.cassandra.db.compaction.ShardManagerDiskAware
-
Construct a boundary/shard iterator for the given number of shards.
- boundaries(int) - Method in class org.apache.cassandra.db.compaction.ShardManagerNoDisks
- boundaries(int) - Method in class org.apache.cassandra.db.compaction.ShardManagerTrivial
- boundary - Variable in class org.apache.cassandra.dht.AbstractBounds.Boundary
- 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
- boundaryFromByteComparable(ValueAccessor<V>, ByteComparable) - Method in class org.apache.cassandra.db.ClusteringComparator
-
Produces a clustering boundary from the given byte-comparable value.
- BoundaryTracker(int) - Constructor for class org.apache.cassandra.db.compaction.ShardManagerNoDisks.BoundaryTracker
- BoundaryTrackerDiskAware(int) - Constructor for class org.apache.cassandra.db.compaction.ShardManagerDiskAware.BoundaryTrackerDiskAware
- boundFromByteComparable(ValueAccessor<V>, ByteComparable, boolean) - Method in class org.apache.cassandra.db.ClusteringComparator
-
Produces a clustering bound from the given byte-comparable value.
- 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 - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
- bounds() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
-
Returns the key bounds of the index.
- bounds() - Method in class org.apache.cassandra.index.sai.disk.v1.V1SSTableIndex
- 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
- boundStackTrace(Throwable, int, int, Set<Throwable>, StringBuilder) - Static method in class org.apache.cassandra.streaming.StreamSession
- boundStackTrace(Throwable, int, StringBuilder) - Static method in class org.apache.cassandra.streaming.StreamSession
- BRANCH_SHIFT - Static variable in class org.apache.cassandra.utils.btree.BTree
-
The
BRANCH_FACTOR
is defined as the maximum number of children of each branch, with between BRANCH_FACTOR/2-1 and BRANCH_FACTOR-1 keys being stored in every node. - BreaksJMX - Annotation Type in org.apache.cassandra.utils
-
Annotation to have JMX breaking APIs not trigger test failures, each example must explain why it is ok to expose a JMX breaking API
- broadcast_address - Variable in class org.apache.cassandra.config.Config
- BROADCAST_INTERVAL_MS - org.apache.cassandra.config.CassandraRelevantProperties
- broadcast_rpc_address - Variable in class org.apache.cassandra.config.Config
- broadcastAddressAndPort - Variable in class org.apache.cassandra.repair.AbstractRepairTask
- broadcastAddressAndPort() - Method in interface org.apache.cassandra.repair.SharedContext
- broadcastAddressAndPort() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- broadcastAddressAndPort() - Method in class org.apache.cassandra.repair.SharedContext.Global
- BtiFormat - Class in org.apache.cassandra.io.sstable.format.bti
-
Bigtable format with trie indices.
- BtiFormat(Map<String, String>) - Constructor for class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- BtiFormat.BtiFormatFactory - Class in org.apache.cassandra.io.sstable.format.bti
- BtiFormat.Components - Class in org.apache.cassandra.io.sstable.format.bti
- BtiFormat.Components.Types - Class in org.apache.cassandra.io.sstable.format.bti
- BtiFormatFactory() - Constructor for class org.apache.cassandra.io.sstable.format.bti.BtiFormat.BtiFormatFactory
- BtiScanningIterator() - Constructor for class org.apache.cassandra.io.sstable.format.bti.BtiTableScanner.BtiScanningIterator
- BtiTableReader - Class in org.apache.cassandra.io.sstable.format.bti
-
Reader of SSTable files in BTI format (see
BtiFormat
), written byBtiTableWriter
. - BtiTableReader(BtiTableReader.Builder, SSTable.Owner) - Constructor for class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- BtiTableReader.Builder - Class in org.apache.cassandra.io.sstable.format.bti
- BtiTableReaderLoadingBuilder - Class in org.apache.cassandra.io.sstable.format.bti
- BtiTableReaderLoadingBuilder(SSTable.Builder<?, ?>) - Constructor for class org.apache.cassandra.io.sstable.format.bti.BtiTableReaderLoadingBuilder
- BtiTableScanner - Class in org.apache.cassandra.io.sstable.format.bti
- BtiTableScanner.BtiScanningIterator - Class in org.apache.cassandra.io.sstable.format.bti
- BtiTableScrubber - Class in org.apache.cassandra.io.sstable.format.bti
- BtiTableScrubber(ColumnFamilyStore, LifecycleTransaction, OutputHandler, IScrubber.Options) - Constructor for class org.apache.cassandra.io.sstable.format.bti.BtiTableScrubber
- BtiTableVerifier - Class in org.apache.cassandra.io.sstable.format.bti
- BtiTableVerifier(ColumnFamilyStore, BtiTableReader, OutputHandler, boolean, IVerifier.Options) - Constructor for class org.apache.cassandra.io.sstable.format.bti.BtiTableVerifier
- BtiTableWriter - Class in org.apache.cassandra.io.sstable.format.bti
-
Writes SSTables in BTI format (see
BtiFormat
), which can be read byBtiTableReader
. - BtiTableWriter(BtiTableWriter.Builder, LifecycleNewTracker, SSTable.Owner) - Constructor for class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter
- BtiTableWriter.Builder - Class in org.apache.cassandra.io.sstable.format.bti
- BtiTableWriter.IndexWriter - Class in org.apache.cassandra.io.sstable.format.bti
-
Encapsulates writing the index and filter for an SSTable.
- BTree - Class in org.apache.cassandra.utils.btree
- BTree() - Constructor for class org.apache.cassandra.utils.btree.BTree
- BTREE_BRANCH_SHIFT - org.apache.cassandra.config.CassandraRelevantProperties
- BTREE_FAN_FACTOR - org.apache.cassandra.config.CassandraRelevantProperties
- 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
-
Represents the direction of iteration.
- BTree.FastBuilder<V> - Class in org.apache.cassandra.utils.btree
-
A pooled builder for constructing a tree in-order, and without needing any reconciliation.
- BTreePartitionData - Class in org.apache.cassandra.db.partitions
-
Holder of the content of a partition, see
AbstractBTreePartition
. - BTreePartitionUpdater - Class in org.apache.cassandra.db.partitions
-
the function we provide to the trie and btree utilities to perform any row and column replacements
- BTreePartitionUpdater(MemtableAllocator, Cloner, OpOrder.Group, UpdateTransaction) - Constructor for class org.apache.cassandra.db.partitions.BTreePartitionUpdater
- 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
- buf - Variable in class org.apache.cassandra.io.tries.Walker
- buffer - Variable in class org.apache.cassandra.db.marshal.ValueComparators
- buffer - Variable in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
- buffer - Variable in class org.apache.cassandra.io.util.BufferManagingRebufferer
- buffer - Variable in class org.apache.cassandra.io.util.MmappedRegions.Region
- buffer - Variable in class org.apache.cassandra.io.util.RebufferingInputStream
- buffer - Variable in class org.apache.cassandra.io.util.WrappingRebufferer
- buffer - Variable in class org.apache.cassandra.net.FrameEncoder.Payload
- buffer() - Method in class org.apache.cassandra.db.rows.Cell
- buffer() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormatPartitionWriter
- buffer() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
- buffer() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
- 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() - Method in class org.apache.cassandra.io.util.WrappingRebufferer
- buffer(boolean) - Method in class org.apache.cassandra.io.util.DataOutputBuffer
- buffer_pool_use_heap_if_exhausted - Variable in class org.apache.cassandra.config.Config
-
Deprecated.See CASSANDRA-15358
- BUFFER_TYPE - Static variable in class org.apache.cassandra.db.memtable.TrieMemtable
-
Buffer type to use for memtable tries (on- vs off-heap)
- 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
- BufferCell(ColumnMetadata, long, int, long, 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(int) - Constructor for class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
- BufferedDataOutputStreamPlus(ByteBuffer) - 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
- BufferedFileWriterMark(long) - Constructor for class org.apache.cassandra.io.util.SequentialWriter.BufferedFileWriterMark
- bufferHolder - Variable in class org.apache.cassandra.io.util.RandomAccessReader
- bufferHolder - Variable in class org.apache.cassandra.io.util.WrappingRebufferer
- 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.DebugLeaks - Interface in org.apache.cassandra.utils.memory
- 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() - Method in class org.apache.cassandra.io.util.SequentialWriterOption
- bufferSize(int) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
-
Set the buffer size to use (if appropriate).
- bufferSize(int) - Method in class org.apache.cassandra.io.util.SequentialWriterOption.Builder
- bufferSize(long) - Method in interface org.apache.cassandra.io.util.DiskOptimizationStrategy
- 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() - Method in class org.apache.cassandra.io.util.SequentialWriterOption
- 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(BufferType) - Method in class org.apache.cassandra.io.util.SequentialWriterOption.Builder
- BufferType - Enum in org.apache.cassandra.io.compress
- build() - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
- build() - Method in class org.apache.cassandra.audit.AuditLogOptions.Builder
- build() - Method in class org.apache.cassandra.auth.CIDRGroupsMappingTable.Builder
-
Provides an instance of algorithm implementing CIDR to CIDR groups mappings
- build() - Method in class org.apache.cassandra.auth.CIDRPermissions.Builder
- build() - Method in class org.apache.cassandra.auth.DCPermissions.Builder
- build() - Method in interface org.apache.cassandra.concurrent.ExecutorBuilder
-
Build the configured executor
- build() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBuilder
- 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.CommitLogSegment.Builder
- build() - Method in class org.apache.cassandra.db.commitlog.CompressedSegment.CompressedSegmentBuilder
- build() - Method in class org.apache.cassandra.db.commitlog.DirectIOSegment.DirectIOSegmentBuilder
- build() - Method in class org.apache.cassandra.db.commitlog.EncryptedSegment.EncryptedSegmentBuilder
- build() - Method in class org.apache.cassandra.db.commitlog.IntervalSet.Builder
- build() - Method in class org.apache.cassandra.db.commitlog.MemoryMappedSegment.MemoryMappedSegmentBuilder
- build() - Method in class org.apache.cassandra.db.filter.ColumnFilter.Builder
- 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() - 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.sai.analyzer.NonTokenizingOptions.OptionsBuilder
- build() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator.Builder
- build() - Method in class org.apache.cassandra.index.sai.plan.QueryViewBuilder
- build() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexBuilder
- 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() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
- 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.IScrubber.Options.Builder
- build() - Method in class org.apache.cassandra.io.sstable.IVerifier.Options.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.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.UserFunctions.Builder
- build() - Method in class org.apache.cassandra.schema.Views.Builder
- build() - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Builder
- build() - Method in class org.apache.cassandra.transport.Server.Builder
- build() - Method in class org.apache.cassandra.transport.SimpleClient.Builder
- build() - Method in class org.apache.cassandra.utils.btree.BTree.Builder
- build() - Method in class org.apache.cassandra.utils.btree.BTree.FastBuilder
- build() - Method in class org.apache.cassandra.utils.btree.BTreeSet.Builder
- 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.
- build(boolean) - Method in class org.apache.cassandra.utils.binlog.BinLog.Builder
- build(int) - Static method in interface org.apache.cassandra.repair.Scheduler
- build(long, long) - Static method in class org.apache.cassandra.db.DeletionTime
- build(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.lifecycle.SSTableIntervalTree
- build(String) - Static method in interface org.apache.cassandra.db.guardrails.GuardrailsConfigProvider
-
Creates an instance of the custom guardrails config provider of the given class.
- build(Collection<I>) - Static method in class org.apache.cassandra.utils.IntervalTree
- build(Collection<K>) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Deprecated.See CASSANDRA-15510
- build(Collection<K>, UpdateFunction<K, V>) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Deprecated.See CASSANDRA-15510
- build(List<String>, List<ByteBuffer>) - Static method in class org.apache.cassandra.db.marshal.DynamicCompositeType
- build(List<KeyRangeIterator>) - Static method in class org.apache.cassandra.index.sai.iterators.KeyRangeUnionIterator
- build(List<KeyRangeIterator>, Runnable) - Static method in class org.apache.cassandra.index.sai.iterators.KeyRangeUnionIterator
- build(List<KeyRangeIterator>, KeyRangeIterator, Set<SSTableIndex>, QueryContext, Runnable) - Static method in class org.apache.cassandra.index.sai.disk.IndexSearchResultIterator
- build(List<RangeIterator<K, D>>) - Static method in class org.apache.cassandra.index.sasi.utils.RangeUnionIterator
- build(Map<Byte, Object>) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
- build(LifecycleNewTracker, SSTable.Owner) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- build(ValueAccessor<V>, boolean, V...) - Static method in class org.apache.cassandra.db.marshal.CompositeType
- build(ValueAccessor<V>, boolean, V[], byte) - Static method in class org.apache.cassandra.db.marshal.CompositeType
- build(ValueAccessor<V>, List<AbstractType<?>>, Map<AbstractType<?>, Byte>, List<V>, byte) - Static method in class org.apache.cassandra.db.marshal.DynamicCompositeType
- build(ValueAccessor<V>, V...) - Static method in class org.apache.cassandra.db.marshal.CompositeType
- build(RowIterator, DeletionInfo, boolean) - Static method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
- 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(IPartitioner) - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryBuilder
- build(IPartitioner, IndexSummaryBuilder.ReadableBoundary) - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryBuilder
- build(Expression, Collection<SSTableIndex>, AbstractBounds<PartitionPosition>, QueryContext, boolean, Runnable) - Static method in class org.apache.cassandra.index.sai.disk.IndexSearchResultIterator
-
Builds a new
IndexSearchResultIterator
that wraps aKeyRangeUnionIterator
over the results of searching theMemtableIndex
and theSSTableIndex
es. - build(Expression, Set<SSTableIndex>) - Static method in class org.apache.cassandra.index.sasi.TermIterator
- build(SSTable.Owner, boolean, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- build(SSTable.Owner, boolean, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderLoadingBuilder
- build(BulkIterator<I>, int, UpdateFunction<I, O>) - Static method in class org.apache.cassandra.utils.btree.BTree
- BUILD_FAILED - org.apache.cassandra.index.Index.Status
- BUILD_SUCCEEDED - org.apache.cassandra.index.Index.Status
- 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
ClusteringBound
s - buildBoundForSlice(boolean, boolean, boolean, List<ColumnMetadata>) - Method in class org.apache.cassandra.db.MultiCBuilder
-
Builds the
ClusteringBound
s for slice restrictions. - buildBoundWith(List<ByteBuffer>, boolean, boolean) - Method in class org.apache.cassandra.db.CBuilder
- buildCompactionCandidatesForAvailableDiskSpace(Set<SSTableReader>, TimeUUID) - Method in class org.apache.cassandra.db.compaction.CompactionTask
- builder() - Static method in class org.apache.cassandra.auth.CIDRPermissions
-
Builder object to generate CIDR permissions
- builder() - Static method in class org.apache.cassandra.auth.DCPermissions
- builder() - Static method in class org.apache.cassandra.db.RegularAndStaticColumns
- builder() - Static method in class org.apache.cassandra.db.rows.ComplexColumnData
- builder() - Static method in class org.apache.cassandra.db.streaming.CassandraStreamHeader
- builder() - Static method in class org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator
- builder() - Static method in class org.apache.cassandra.index.sasi.utils.RangeUnionIterator
- builder() - Static method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
Returns a new builder for a CQLSSTableWriter.
- builder() - Static method in class org.apache.cassandra.schema.Indexes
- builder() - Static method in class org.apache.cassandra.schema.Keyspaces
- builder() - Static method in class org.apache.cassandra.schema.TableParams
- 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.UserFunctions
- builder() - Static method in class org.apache.cassandra.schema.Views
- builder() - Static method in class org.apache.cassandra.tools.LoaderOptions
- builder(boolean) - Static method in interface org.apache.cassandra.auth.CIDRGroupsMappingTable
- builder(int) - Static method in class org.apache.cassandra.index.sai.iterators.KeyRangeConcatIterator
- builder(int) - Static method in class org.apache.cassandra.index.sai.iterators.KeyRangeUnionIterator
- builder(int, int) - Static method in class org.apache.cassandra.index.sai.iterators.KeyRangeIntersectionIterator
- builder(int, int, Runnable) - Static method in class org.apache.cassandra.index.sai.iterators.KeyRangeIntersectionIterator
- builder(int, Runnable) - Static method in class org.apache.cassandra.index.sai.iterators.KeyRangeConcatIterator
- builder(int, Runnable) - Static method in class org.apache.cassandra.index.sai.iterators.KeyRangeIntersectionIterator
- builder(int, Runnable) - Static method in class org.apache.cassandra.index.sai.iterators.KeyRangeUnionIterator
- builder(String) - Method in class org.apache.cassandra.index.sai.disk.v1.MetadataWriter
- builder(String, int) - Static method in class org.apache.cassandra.transport.SimpleClient
- 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(Comparator<? super V>) - Static method in class org.apache.cassandra.utils.btree.BTree
- builder(Comparator<? super V>) - Static method in class org.apache.cassandra.utils.btree.BTreeSet
- builder(Comparator<? super V>, int) - Static method in class org.apache.cassandra.utils.btree.BTree
- builder(Comparator<? super V>, int) - Static method in class org.apache.cassandra.utils.btree.BTreeSet
-
if you know the precise size of the resultant set use
perfectBuilder
instead. - builder(DeletionTime, ClusteringComparator, boolean) - Static method in class org.apache.cassandra.db.MutableDeletionInfo
- 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(Token) - Static method in class org.apache.cassandra.locator.EndpointsForToken
- builder(Token, int) - Static method in class org.apache.cassandra.locator.EndpointsForToken
- builder(RangeIntersectionIterator.Strategy) - Static method in class org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator
- builder(Descriptor) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat.SSTableReaderFactory
-
A simple builder which creates an instnace of
SSTableReader
with the provided parameters. - builder(Descriptor) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat.SSTableWriterFactory
-
Returns a new builder which can create instance of
SSTableWriter
with the provided parameters. - builder(InetAddressAndPort) - Static method in class org.apache.cassandra.locator.RangesAtEndpoint
- builder(InetAddressAndPort, int) - Static method in class org.apache.cassandra.locator.RangesAtEndpoint
- 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(SharedContext) - Static method in class org.apache.cassandra.repair.consistent.CoordinatorSession
- builder(SharedContext) - Static method in class org.apache.cassandra.repair.consistent.LocalSession
- builder(TableParams) - Static method in class org.apache.cassandra.schema.TableParams
- builder(Types) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement
- Builder() - Constructor for class org.apache.cassandra.audit.AuditLogOptions.Builder
- Builder() - Constructor for class org.apache.cassandra.auth.CIDRPermissions.Builder
- Builder() - Constructor for class org.apache.cassandra.auth.DCPermissions.Builder
- Builder() - Constructor for class org.apache.cassandra.cql3.WhereClause.Builder
- Builder() - Constructor for class org.apache.cassandra.db.commitlog.IntervalSet.Builder
- Builder() - Constructor for class org.apache.cassandra.db.RegularAndStaticColumns.Builder
- Builder() - Constructor for class org.apache.cassandra.db.rows.ComplexColumnData.Builder
- Builder() - Constructor for class org.apache.cassandra.db.streaming.CassandraStreamHeader.Builder
- Builder() - Constructor for class org.apache.cassandra.index.sasi.utils.RangeUnionIterator.Builder
- Builder() - Constructor for class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
- Builder() - Constructor for class org.apache.cassandra.io.sstable.IScrubber.Options.Builder
- Builder() - Constructor for class org.apache.cassandra.io.sstable.IVerifier.Options.Builder
- Builder() - Constructor for class org.apache.cassandra.io.sstable.SequenceBasedSSTableId.Builder
- Builder() - Constructor for class org.apache.cassandra.io.sstable.UUIDBasedSSTableId.Builder
- Builder() - Constructor for class org.apache.cassandra.locator.EndpointsByRange.Builder
- Builder() - Constructor for class org.apache.cassandra.locator.EndpointsByReplica.Builder
- Builder() - Constructor for class org.apache.cassandra.locator.RangesByEndpoint.Builder
- Builder() - Constructor for class org.apache.cassandra.repair.consistent.admin.PendingStat.Builder
- Builder() - Constructor for class org.apache.cassandra.schema.TableParams.Builder
- Builder() - Constructor for class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Builder
- Builder() - Constructor for class org.apache.cassandra.transport.Server.Builder
- Builder() - Constructor for class org.apache.cassandra.utils.binlog.BinLog.Builder
- Builder() - Constructor for class org.apache.cassandra.utils.btree.BTree.Builder
- Builder(boolean) - Constructor for class org.apache.cassandra.db.rows.BTreeRow.Builder
- Builder(Comparator<? super V>) - Constructor for class org.apache.cassandra.utils.btree.BTree.Builder
- Builder(Comparator<? super V>) - Constructor for class org.apache.cassandra.utils.btree.BTreeSet.Builder
- Builder(Comparator<? super V>, int) - Constructor for class org.apache.cassandra.utils.btree.BTree.Builder
- Builder(Comparator<? super V>, int) - Constructor for class org.apache.cassandra.utils.btree.BTreeSet.Builder
- Builder(AuditLogEntry) - Constructor for class org.apache.cassandra.audit.AuditLogEntry.Builder
- Builder(AuditLogEntryType) - Constructor for class org.apache.cassandra.audit.AuditLogEntry.Builder
- Builder(AuditLogOptions) - Constructor for class org.apache.cassandra.audit.AuditLogOptions.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(AbstractCommitLogSegmentManager) - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegment.Builder
- Builder(PartitionUpdate, int) - Constructor for class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
- Builder(BTreeRow.Builder) - Constructor for class org.apache.cassandra.db.rows.BTreeRow.Builder
- 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) - Constructor for class org.apache.cassandra.locator.EndpointsForToken.Builder
- Builder(Token, int) - Constructor for class org.apache.cassandra.locator.EndpointsForToken.Builder
- Builder(KeyRangeIterator.Builder.Statistics, Runnable) - Constructor for class org.apache.cassandra.index.sai.iterators.KeyRangeIterator.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(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(Descriptor) - Constructor for class org.apache.cassandra.io.sstable.format.big.BigTableReader.Builder
- Builder(Descriptor) - Constructor for class org.apache.cassandra.io.sstable.format.big.BigTableWriter.Builder
- Builder(Descriptor) - Constructor for class org.apache.cassandra.io.sstable.format.bti.BtiTableReader.Builder
- Builder(Descriptor) - Constructor for class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter.Builder
- Builder(Descriptor) - Constructor for class org.apache.cassandra.io.sstable.format.SortedTableWriter.Builder
- Builder(Descriptor) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- Builder(Descriptor) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReaderWithFilter.Builder
- Builder(Descriptor) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- Builder(Descriptor) - Constructor for class org.apache.cassandra.io.sstable.SSTable.Builder
- Builder(File) - Constructor for class org.apache.cassandra.io.util.FileHandle.Builder
- Builder(InetAddressAndPort) - Constructor for class org.apache.cassandra.locator.RangesAtEndpoint.Builder
- Builder(InetAddressAndPort, int) - Constructor for class org.apache.cassandra.locator.RangesAtEndpoint.Builder
- Builder(SharedContext) - Constructor for class org.apache.cassandra.repair.consistent.CoordinatorSession.Builder
- Builder(SharedContext) - Constructor for class org.apache.cassandra.repair.consistent.LocalSession.Builder
- Builder(TableMetadata, ByteBuffer, RegularAndStaticColumns, int) - 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(TableMetadata, DecoratedKey, RegularAndStaticColumns, int, boolean) - Constructor for class org.apache.cassandra.db.partitions.PartitionUpdate.Builder
- Builder(QueryState) - Constructor for class org.apache.cassandra.audit.AuditLogEntry.Builder
- Builder(T, T) - Constructor for class org.apache.cassandra.db.commitlog.IntervalSet.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
- buildIndex(Index) - Method in class org.apache.cassandra.index.SecondaryIndexManager
- 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
- buildIndexExpressions(QueryController, List<RowFilter.Expression>) - Static method in class org.apache.cassandra.index.sai.plan.Operation
- buildInternal(LifecycleNewTracker, SSTable.Owner) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter.Builder
- buildInternal(LifecycleNewTracker, SSTable.Owner) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter.Builder
- buildInternal(LifecycleNewTracker, SSTable.Owner) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- buildInternal(SSTable.Owner) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader.Builder
- buildInternal(SSTable.Owner) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader.Builder
- buildInternal(SSTable.Owner) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- buildIntervals(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.lifecycle.SSTableIntervalTree
- buildIterator() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeConcatIterator.Builder
- buildIterator() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIntersectionIterator.Builder
- buildIterator() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator.Builder
- buildIterator() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeUnionIterator.Builder
- 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
- buildKeyManagerFactory() - Method in class org.apache.cassandra.security.AbstractSslContextFactory
- buildKeyManagerFactory() - Method in class org.apache.cassandra.security.DisableSslContextFactory
- buildKeyManagerFactory() - Method in class org.apache.cassandra.security.FileBasedSslContextFactory
-
Builds required KeyManagerFactory from the file based keystore.
- buildKeyManagerFactory() - Method in class org.apache.cassandra.security.PEMBasedSslContextFactory
-
Builds required KeyManagerFactory from the PEM based keystore.
- buildKeyReader(TableMetrics) - Method in class org.apache.cassandra.io.sstable.format.big.BigSSTableReaderLoadingBuilder
- buildKeyReader(TableMetrics) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReaderLoadingBuilder
- buildKeyReader(TableMetrics) - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderLoadingBuilder
- buildOutboundKeyManagerFactory() - Method in class org.apache.cassandra.security.AbstractSslContextFactory
-
Create a
KeyManagerFactory
for outbound connections. - buildOutboundKeyManagerFactory() - Method in class org.apache.cassandra.security.DisableSslContextFactory
- buildOutboundKeyManagerFactory() - Method in class org.apache.cassandra.security.FileBasedSslContextFactory
- buildOutboundKeyManagerFactory() - Method in class org.apache.cassandra.security.PEMBasedSslContextFactory
- buildOverloadedException(Supplier<String>, NonBlockingRateLimiter, ClientResourceLimits.Overload) - Static method in class org.apache.cassandra.transport.CQLMessageHandler
- buildOverloadedException(ResourceLimits.Limit, ResourceLimits.Limit, NonBlockingRateLimiter, ClientResourceLimits.Overload) - Static method in class org.apache.cassandra.transport.CQLMessageHandler
- buildPartial(long, Consumer<PartitionIndex>) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter.IndexWriter
- buildPartitionKeyNames(QueryOptions, ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- buildReverse() - Method in class org.apache.cassandra.utils.btree.BTree.FastBuilder
- buildRow() - Method in class org.apache.cassandra.cql3.UpdateParameters
- buildSession(CoordinatorSession.Builder) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSessions
- buildSession(LocalSession.Builder) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
- buildSize() - Method in class org.apache.cassandra.db.MultiCBuilder
-
Returns the current number of results when
MultiCBuilder.build()
is called - buildSnapshotId(String, String, UUID, String) - Static method in class org.apache.cassandra.service.snapshot.TableSnapshot
- buildSSTableAttachedIndexesBlocking(Collection<SSTableReader>) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Incrementally builds indexes for the specified SSTables in a blocking fashion.
- buildTrustManagerFactory() - Method in class org.apache.cassandra.security.AbstractSslContextFactory
- buildTrustManagerFactory() - Method in class org.apache.cassandra.security.DisableSslContextFactory
- buildTrustManagerFactory() - Method in class org.apache.cassandra.security.FileBasedSslContextFactory
-
Builds TrustManagerFactory from the file based truststore.
- buildTrustManagerFactory() - Method in class org.apache.cassandra.security.PEMBasedSslContextFactory
-
Builds TrustManagerFactory from the PEM based truststore.
- buildValue(ByteBuffer...) - Static method in class org.apache.cassandra.db.marshal.TupleType
- buildValue(ValueAccessor<V>, V...) - 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. - buildWriter(Descriptor, TableMetadata, SequentialWriterOption, MetadataCollector, OperationType, Config.FlushCompression) - Static method in class org.apache.cassandra.io.sstable.format.DataComponent
- 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
- BULK_LOAD - org.apache.cassandra.streaming.StreamOperation
- BulkIterator<V> - Interface in org.apache.cassandra.utils
- BulkIterator.Adapter<V> - Class in org.apache.cassandra.utils
- BulkIterator.FromArray<V> - Class in org.apache.cassandra.utils
- 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(EncryptionOptions.ServerEncryptionOptions, int) - Constructor for class org.apache.cassandra.tools.BulkLoadConnectionFactory
- bulkLoader() - Method in interface org.apache.cassandra.auth.AuthCache.BulkLoader
- bulkLoader() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
-
Get an initial set of permissions to load into the PermissionsCache at startup
- bulkLoader() - Method in class org.apache.cassandra.auth.CassandraNetworkAuthorizer
- bulkLoader() - Method in class org.apache.cassandra.auth.CassandraRoleManager
- bulkLoader() - Method in class org.apache.cassandra.auth.CIDRPermissionsManager
-
Function to bulk load role to cidr permissions cache This gets called when cache warmup is enabled in the config
- bulkLoader() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
- 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 - org.apache.cassandra.transport.DataType
- BYTE_COMPARABLE_VERSION - Static variable in class org.apache.cassandra.db.memtable.TrieMemtable
-
The byte-ordering conversion version to use for memtables.
- BYTE_COMPARABLE_VERSION - Static variable in class org.apache.cassandra.db.tries.Trie
- BYTE_COMPARABLE_VERSION - Static variable in class org.apache.cassandra.io.tries.Walker
- BYTE_MASK - Static variable in class org.apache.cassandra.dht.ByteOrderedPartitioner
- BYTE_ORDER - org.apache.cassandra.db.marshal.AbstractType.ComparisonType
-
This type is always compared by its sequence of unsigned bytes
- 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
- ByteBufDiscardHandler() - Constructor for class org.apache.cassandra.net.InternodeConnectionUtils.ByteBufDiscardHandler
- byteBuffer() - Method in class org.apache.cassandra.utils.MD5Digest
- ByteBufferAccessor - Class in org.apache.cassandra.db.marshal
-
Accessor for ByteBuffer values.
- ByteBufferCloner - Class in org.apache.cassandra.utils.memory
-
Cloner class that can be use to clone partition elements using on-heap or off-heap buffers.
- ByteBufferCloner() - Constructor for class org.apache.cassandra.utils.memory.ByteBufferCloner
- 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
- ByteComparable - Interface in org.apache.cassandra.utils.bytecomparable
-
Interface indicating a value can be represented/identified by a comparable
ByteSource
. - ByteComparable.Version - Enum in org.apache.cassandra.utils.bytecomparable
- byteComparableAsString(ByteComparable.Version) - Method in interface org.apache.cassandra.utils.bytecomparable.ByteComparable
-
Construct a human-readable string from the byte-comparable representation.
- 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 - Variable in class org.apache.cassandra.io.tries.Walker.TransitionBytesCollector
- bytes - Variable in class org.apache.cassandra.utils.MD5Digest
- bytes() - Method in class org.apache.cassandra.utils.CounterId
- bytes(byte) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- bytes(byte) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- bytes(double) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- bytes(double) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- bytes(float) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- bytes(float) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- bytes(int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- bytes(int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- bytes(long) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- bytes(long) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- bytes(short) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- bytes(short) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- bytes(String) - 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.ByteArrayUtil
- bytes(String, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Encode a String in a ByteBuffer using the provided charset.
- bytes(InetAddress) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- bytes(UUID) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- bytes(TimeUUID) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- Bytes - Class in org.apache.cassandra.cql3.functions.types.utils
-
Simple utility methods to make working with bytes (blob) easier.
- BYTES - org.apache.cassandra.config.DataStorageSpec.DataStorageUnit
- BYTES - org.apache.cassandra.db.compaction.CompactionInfo.Unit
- BYTES_CUSTOM_DATASTORAGE - org.apache.cassandra.config.Converters
-
This converter is used to support backward compatibility for parameters where in the past negative number was used as a value Example: native_transport_max_concurrent_requests_in_bytes_per_ip = -1 and native_transport_max_request_data_in_flight_per_ip = null are equal.
- BYTES_DATASTORAGE - org.apache.cassandra.config.Converters
- BYTES_IN_FLIGHT - org.apache.cassandra.transport.ClientResourceLimits.Overload
- BYTES_LEN - Static variable in class org.apache.cassandra.io.sstable.UUIDBasedSSTableId
- BYTES_PER_MEBIBYTE - Static variable in class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
- BYTES_PER_SECOND - org.apache.cassandra.config.DataRateSpec.DataRateUnit
- 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
- BytesConversionFcts.FromBlobFunction - Class in org.apache.cassandra.cql3.functions
- BytesConversionFcts.ToBlobFunction - Class in org.apache.cassandra.cql3.functions
- 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
- bytesLeftInPage() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
- bytesLeftInPage() - Method in interface org.apache.cassandra.io.util.DataOutputPlus
-
Returns how many bytes are left in the page.
- bytesLeftInPage() - Method in class org.apache.cassandra.io.util.SequentialWriter
- bytesLeftInPage(long) - Static method in class org.apache.cassandra.io.util.PageAware
-
Calculate the number of bytes left in this page.
- 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.format.SSTableReader
- ByteSource - Interface in org.apache.cassandra.utils.bytecomparable
-
A stream of bytes, used for byte-order-comparable representations of data, and utilities to convert various values to their byte-ordered translation.
- ByteSource.AbstractEscaper - Class in org.apache.cassandra.utils.bytecomparable
-
Variable-length encoding.
- ByteSource.AccessorEscaper<V> - Class in org.apache.cassandra.utils.bytecomparable
- ByteSource.ArrayEscaper - Class in org.apache.cassandra.utils.bytecomparable
- ByteSource.BufferEscaper - Class in org.apache.cassandra.utils.bytecomparable
- ByteSource.MemoryEscaper - Class in org.apache.cassandra.utils.bytecomparable
- ByteSource.Multi - Class in org.apache.cassandra.utils.bytecomparable
-
Combination of multiple byte sources.
- ByteSource.Number - Class in org.apache.cassandra.utils.bytecomparable
- ByteSource.Peekable - Class in org.apache.cassandra.utils.bytecomparable
- ByteSource.Separator - Class in org.apache.cassandra.utils.bytecomparable
-
Construct the shortest common prefix of prevMax and currMin that separates those two byte streams.
- ByteSource.SignedFixedLengthFloat<V> - Class in org.apache.cassandra.utils.bytecomparable
-
Fixed length signed floating point number encoding.
- ByteSource.SignedFixedLengthNumber<V> - Class in org.apache.cassandra.utils.bytecomparable
-
Fixed length signed number encoding.
- ByteSource.VariableLengthInteger - Class in org.apache.cassandra.utils.bytecomparable
-
Variable-length encoding for signed integers.
- ByteSource.VariableLengthUnsignedInteger - Class in org.apache.cassandra.utils.bytecomparable
-
Variable-length encoding for unsigned integers.
- ByteSourceInverse - Class in org.apache.cassandra.utils.bytecomparable
-
Contains inverse transformation utilities for
ByteSource
s. - ByteSourceInverse() - Constructor for class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
- bytesPastLimit() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
- bytesPastMark() - Method in class org.apache.cassandra.io.util.RandomAccessReader
- bytesPastMark(DataPosition) - Method in class org.apache.cassandra.db.commitlog.EncryptedFileSegmentInputStream
- bytesPastMark(DataPosition) - Method in class org.apache.cassandra.io.util.FileSegmentInputStream
- bytesPastMark(DataPosition) - Method in class org.apache.cassandra.io.util.RandomAccessReader
- bytesPastMark(DataPosition) - Method in interface org.apache.cassandra.io.util.RewindableDataInput
- bytesPendingRepair - Variable in class org.apache.cassandra.metrics.TableMetrics
- bytesPendingRepair - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- bytesPerPosting() - Static method in class org.apache.cassandra.index.sai.disk.v1.vector.VectorPostings
- bytesRead - Variable in class org.apache.cassandra.repair.state.ValidationState
- BytesReadTracker - Interface in org.apache.cassandra.io.util
- bytesReceived - Static variable in class org.apache.cassandra.metrics.ClientMessageSizeMetrics
- bytesReceived - Variable in class org.apache.cassandra.streaming.StreamingState.Sessions
- 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
- bytesScanned - Variable in class org.apache.cassandra.io.sstable.format.SSTableScanner
- bytesSent - Static variable in class org.apache.cassandra.metrics.ClientMessageSizeMetrics
- bytesSent - Variable in class org.apache.cassandra.streaming.StreamingState.Sessions
- 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(byte...) - Static method in class org.apache.cassandra.utils.Hex
- bytesToHex(byte[], int, int) - Static method in class org.apache.cassandra.utils.Hex
- bytesToHex(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- BytesToken(byte[]) - Constructor for class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
- BytesToken(ByteBuffer) - Constructor for class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
- bytesToReceive - Variable in class org.apache.cassandra.streaming.StreamingState.Sessions
- bytesToSend - Variable in class org.apache.cassandra.streaming.StreamingState.Sessions
- 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
- bytesWritten() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
- 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 - Static variable in class org.apache.cassandra.auth.Roles
- CACHE_EVERYTHING - Static variable in class org.apache.cassandra.schema.CachingParams
- CACHE_KEYS - Static variable in class org.apache.cassandra.schema.CachingParams
- cache_load_timeout - Variable in class org.apache.cassandra.config.Config
- CACHE_NAME - Static variable in class org.apache.cassandra.auth.CIDRPermissionsCache
- CACHE_NAME - Static variable in interface org.apache.cassandra.auth.jmx.AuthorizationProxy.JmxPermissionsCacheMBean
- CACHE_NAME - Static variable in interface org.apache.cassandra.auth.NetworkPermissionsCacheMBean
- CACHE_NAME - Static variable in interface org.apache.cassandra.auth.PasswordAuthenticator.CredentialsCacheMBean
- CACHE_NAME - Static variable in interface org.apache.cassandra.auth.PermissionsCacheMBean
- CACHE_NAME - Static variable in interface org.apache.cassandra.auth.RolesCacheMBean
- CACHE_NOTHING - Static variable in class org.apache.cassandra.schema.CachingParams
- CACHEABLE_MUTATION_SIZE_LIMIT - org.apache.cassandra.config.CassandraRelevantProperties
-
Represents the maximum size (in bytes) of a serialized mutation that can be cached
- 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(DecoratedKey, AbstractRowIndexEntry) - Method in interface org.apache.cassandra.io.sstable.keycache.KeyCacheSupport
-
Caches a key only if cache is available.
- 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
- 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
- CacheRefresher<K,V> - Class in org.apache.cassandra.auth
- cacheReloadCount - Variable in class org.apache.cassandra.metrics.CIDRAuthorizerMetrics
- cacheReloadLatency - Variable in class org.apache.cassandra.metrics.CIDRAuthorizerMetrics
- cacheRows() - Method in class org.apache.cassandra.schema.CachingParams
- cacheSerializer - Static variable in interface org.apache.cassandra.db.partitions.CachedPartition
- CacheSerializer() - Constructor for class org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
- cacheService - Variable in class org.apache.cassandra.tools.NodeProbe
- CacheService - Class in org.apache.cassandra.service
- CacheService.CacheType - Enum in org.apache.cassandra.service
- CacheService.CounterCacheSerializer - Class in org.apache.cassandra.service
- CacheService.KeyCacheSerializer - Class in org.apache.cassandra.service
- CacheService.RowCacheSerializer - Class in org.apache.cassandra.service
- CacheServiceMBean - Interface in org.apache.cassandra.service
- cacheSize - Static variable in class org.apache.cassandra.cache.ChunkCache
- CacheSize - Interface in org.apache.cassandra.cache
- cacheType - Variable in class org.apache.cassandra.cache.AutoSavingCache
- cacheType() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
- caching - Variable in class org.apache.cassandra.schema.TableParams
- caching(CachingParams) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- caching(CachingParams) - Method in class org.apache.cassandra.schema.TableParams.Builder
- CACHING - org.apache.cassandra.schema.TableParams.Option
- 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.
- calculateCombinedDensity(Set<? extends SSTableReader>) - Method in interface org.apache.cassandra.db.compaction.ShardManager
-
Estimate the density of the sstable that will be the result of compacting the given sources.
- calculateCombinedDensity(Set<? extends SSTableReader>) - Method in class org.apache.cassandra.db.compaction.ShardManagerTrivial
- 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
- calculateSchemaDigest() - Static method in class org.apache.cassandra.schema.SchemaKeyspace
-
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.
- 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.PercentileSpeculativeRetryPolicy
- calculateThreshold(SnapshottingTimer, long) - Method in class org.apache.cassandra.service.reads.AlwaysSpeculativeRetryPolicy
- calculateThreshold(SnapshottingTimer, long) - Method in class org.apache.cassandra.service.reads.FixedSpeculativeRetryPolicy
- calculateThreshold(SnapshottingTimer, long) - Method in class org.apache.cassandra.service.reads.HybridSpeculativeRetryPolicy
- calculateThreshold(SnapshottingTimer, long) - Method in class org.apache.cassandra.service.reads.NeverSpeculativeRetryPolicy
- calculateThreshold(SnapshottingTimer, long) - Method in class org.apache.cassandra.service.reads.PercentileSpeculativeRetryPolicy
- calculateThreshold(SnapshottingTimer, long) - Method in interface org.apache.cassandra.service.reads.SpeculativeRetryPolicy
-
Calculate the delay in microseconds after which speculation takes place
- calculateToFromStreams() - Method in class org.apache.cassandra.service.RangeRelocator
- call() - Method in class org.apache.cassandra.db.memtable.Flushing.FlushRunnable
- call() - Method in class org.apache.cassandra.db.repair.PendingAntiCompaction.AcquisitionCallable
- call() - Method in class org.apache.cassandra.db.view.ViewBuilderTask
- call() - Method in class org.apache.cassandra.tools.JMXTool.Diff
- call() - Method in class org.apache.cassandra.tools.JMXTool.Dump
- call(AbstractMessageHandler) - Method in interface org.apache.cassandra.net.AbstractMessageHandler.OnHandlerClosed
- CALL_BACK_ON_FAILURE - org.apache.cassandra.net.MessageFlag
-
a failure response should be sent back in case of failure
- callable(Object, Runnable) - Static method in class org.apache.cassandra.concurrent.FutureTask
- callable(Object, Runnable, T) - Static method in class org.apache.cassandra.concurrent.FutureTask
- callable(Runnable) - Static method in class org.apache.cassandra.concurrent.FutureTask
- callable(Runnable, T) - Static method in class org.apache.cassandra.concurrent.FutureTask
- callback - Variable in class org.apache.cassandra.net.RequestCallbacks.CallbackInfo
- 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 interface org.apache.cassandra.utils.NativeLibraryWrapper
- 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 interface org.apache.cassandra.utils.NativeLibraryWrapper
- callFsync(int) - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
- callFsync(int) - Method in class org.apache.cassandra.utils.NativeLibraryLinux
- callFsync(int) - Method in interface org.apache.cassandra.utils.NativeLibraryWrapper
- callGetpid() - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
- callGetpid() - Method in class org.apache.cassandra.utils.NativeLibraryLinux
- callGetpid() - Method in interface org.apache.cassandra.utils.NativeLibraryWrapper
- callMlockall(int) - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
- callMlockall(int) - Method in class org.apache.cassandra.utils.NativeLibraryLinux
- callMlockall(int) - Method in interface org.apache.cassandra.utils.NativeLibraryWrapper
- callMunlockall() - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
- callMunlockall() - Method in class org.apache.cassandra.utils.NativeLibraryLinux
- callMunlockall() - Method in interface org.apache.cassandra.utils.NativeLibraryWrapper
- 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 interface org.apache.cassandra.utils.NativeLibraryWrapper
- 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 interface org.apache.cassandra.utils.NativeLibraryWrapper
- callStrerror(int) - Method in class org.apache.cassandra.utils.NativeLibraryDarwin
- callStrerror(int) - Method in class org.apache.cassandra.utils.NativeLibraryLinux
- callStrerror(int) - Method in interface org.apache.cassandra.utils.NativeLibraryWrapper
- camelToSnake(String) - Static method in class org.apache.cassandra.utils.FBUtilities
- canAccess(String) - Method in class org.apache.cassandra.auth.DCPermissions
-
returns true if the user can access the given dc
- canAccessFrom(Set<String>) - Method in class org.apache.cassandra.auth.CIDRPermissions
-
Determines whether this permissions object allows access from given cidr group(s)
- canBeConvertedToMultiColumnRestriction() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.LikeRestriction
- cancel() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosRepair
- cancel() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue.Signal
-
Should only be called by the owning thread.
- cancel(boolean) - Method in class org.apache.cassandra.net.FutureDelegate
- cancel(boolean) - Method in class org.apache.cassandra.net.FutureResult
- cancel(boolean) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- cancel(boolean) - Method in class org.apache.cassandra.utils.concurrent.FutureCombiner
- cancel(boolean) - Method in class org.apache.cassandra.utils.concurrent.NotScheduledFuture
- cancel(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
remove the readers from the set we're modifying
- cancel(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
remove the reader from the set we're modifying
- CancelCmd() - Constructor for class org.apache.cassandra.tools.nodetool.RepairAdmin.CancelCmd
- cancelled() - Static method in class org.apache.cassandra.utils.concurrent.ImmediateFuture
- CANCELLED - Static variable in class org.apache.cassandra.service.paxos.AbstractPaxosRepair
- CANCELLED - Static variable in class org.apache.cassandra.utils.concurrent.AbstractFuture
- cancelSession(TimeUUID, 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.
- cancelUnexceptionally() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosRepair
- 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 aware of which nodes are live/down
- candidateReplicaCount() - Method in class org.apache.cassandra.service.BatchlogResponseHandler
- 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 - Variable in class org.apache.cassandra.auth.Role
- 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(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
- canMemoize() - Method in class org.apache.cassandra.utils.ExpiringMemoizingSupplier.ReturnValue
- canMinimize(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- canMinimize(ByteBuffer[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- CANNOT_USE_ALLOW_FILTERING_MESSAGE - Static variable in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
- CANONICAL - org.apache.cassandra.db.lifecycle.SSTableSet
- canonicalPath() - Method in class org.apache.cassandra.io.util.File
- canRecyclePartially() - Method in class org.apache.cassandra.utils.memory.BufferPool.LocalPool
- canSkipValue(CellPath) - Method in class org.apache.cassandra.db.rows.DeserializationHelper
- canSkipValue(ColumnMetadata) - Method in class org.apache.cassandra.db.rows.DeserializationHelper
- canTransitionTo(ConsistentSession.State) - Method in enum org.apache.cassandra.repair.consistent.ConsistentSession.State
- CAP - org.apache.cassandra.db.ExpirationDateOverflowHandling.ExpirationDateOverflowPolicy
- CAP_NOWARN - org.apache.cassandra.db.ExpirationDateOverflowHandling.ExpirationDateOverflowPolicy
- capacity - Variable in class org.apache.cassandra.metrics.BufferPoolMetrics
-
Total threshold for a certain type of buffer pool
- capacity - Variable in class org.apache.cassandra.metrics.CacheMetrics
-
Cache capacity in bytes
- 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() - Method in class org.apache.cassandra.utils.concurrent.Accumulator
- capacity() - Method in interface org.apache.cassandra.utils.concurrent.LightweightRecycler
- capacity() - Method in interface org.apache.cassandra.utils.obs.IBitSet
- capacity() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
- capacity(int) - Method in class org.apache.cassandra.net.BufferPoolAllocator.Wrapped
- 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, long, Dispatcher.RequestTime) - 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(DecoratedKey, CASRequest, ConsistencyLevel, ConsistencyLevel, ClientState) - Static method in class org.apache.cassandra.service.paxos.Paxos
-
Apply @param updates if and only if the current values in the row for @param key match the provided @param conditions.
- cas(DecoratedKey, CASRequest, ConsistencyLevel, ConsistencyLevel, ClientState, long, long) - Static method in class org.apache.cassandra.service.paxos.Paxos
- CAS - org.apache.cassandra.db.WriteType
- cas_contention_timeout - Variable in class org.apache.cassandra.config.Config
- CAS_CONTENTIONS - org.apache.cassandra.metrics.Sampler.SamplerType
- CAS_WRITE_UNKNOWN - org.apache.cassandra.exceptions.ExceptionCode
- 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.sai.analyzer.NonTokenizingOptions
- 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
- casReadMetrics - Static variable in class org.apache.cassandra.metrics.ClientRequestsMetricsHolder
- 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 - org.apache.cassandra.utils.StorageCompatibilityMode
-
Stay compatible with Cassandra 4.x, opting out from any new features that will prevent a rollback to 4.x.
- 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
- CASSANDRA_4_1 - Static variable in class org.apache.cassandra.utils.CassandraVersion
- CASSANDRA_5_0 - Static variable in class org.apache.cassandra.utils.CassandraVersion
- CASSANDRA_ALLOW_SIMPLE_STRATEGY - org.apache.cassandra.config.CassandraRelevantProperties
- CASSANDRA_AVAILABLE_PROCESSORS - org.apache.cassandra.config.CassandraRelevantProperties
- CASSANDRA_CONFIG - org.apache.cassandra.config.CassandraRelevantProperties
-
The classpath storage configuration file.
- CASSANDRA_FOREGROUND - org.apache.cassandra.config.CassandraRelevantProperties
-
The cassandra-foreground option will tell CassandraDaemon whether to close stdout/stderr, but it's up to us not to background.
- CASSANDRA_JMX_AUTHORIZER - org.apache.cassandra.config.CassandraRelevantProperties
- CASSANDRA_JMX_LOCAL_PORT - org.apache.cassandra.config.CassandraRelevantProperties
- CASSANDRA_JMX_REMOTE_LOGIN_CONFIG - org.apache.cassandra.config.CassandraRelevantProperties
- CASSANDRA_JMX_REMOTE_PORT - org.apache.cassandra.config.CassandraRelevantProperties
-
Cassandra jmx remote and local port
- CASSANDRA_MAX_HINT_TTL - org.apache.cassandra.config.CassandraRelevantProperties
- CASSANDRA_MINIMUM_REPLICATION_FACTOR - org.apache.cassandra.config.CassandraRelevantProperties
- CASSANDRA_NETTY_USE_HEAP_ALLOCATOR - org.apache.cassandra.config.CassandraRelevantProperties
- CASSANDRA_PID_FILE - org.apache.cassandra.config.CassandraRelevantProperties
- CASSANDRA_RACKDC_PROPERTIES - org.apache.cassandra.config.CassandraRelevantProperties
- CASSANDRA_SKIP_AUTOMATIC_UDT_FIX - org.apache.cassandra.config.CassandraRelevantProperties
- CASSANDRA_SKIP_SYNC - org.apache.cassandra.config.CassandraRelevantEnv
- CASSANDRA_STREAMING_DEBUG_STACKTRACE_LIMIT - org.apache.cassandra.config.CassandraRelevantProperties
- CASSANDRA_UNSAFE_TIME_UUID_NODE - org.apache.cassandra.config.CassandraRelevantProperties
- CASSANDRA_VERSION - org.apache.cassandra.config.CassandraRelevantProperties
- 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
- CassandraCIDRAuthorizer - Class in org.apache.cassandra.auth
-
CassandraCIDRAuthorizer is backend for CIDR authorization checks 1, Provides functionality to populate Role to CIDR permisssions cache and 2, Uses CIDR groups mapping cache as backend to lookup CIDR groups of an IP
- CassandraCIDRAuthorizer() - Constructor for class org.apache.cassandra.auth.CassandraCIDRAuthorizer
- 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 (seeCassandraDaemon.setup()
,CassandraDaemon.start()
,CassandraDaemon.stop()
andCassandraDaemon.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.
- CassandraRelevantProperties.PropertyConverter<T> - Interface in org.apache.cassandra.config
- 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
- CassandraTableRepairManager(ColumnFamilyStore, SharedContext) - 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
- CassandraUInt - Class in org.apache.cassandra.utils
-
This class packages several UInt utility methods so we can easily change it's implementation when needed.
- CassandraUInt() - Constructor for class org.apache.cassandra.utils.CassandraUInt
- CassandraValidationIterator - Class in org.apache.cassandra.db.repair
- CassandraValidationIterator(ColumnFamilyStore, SharedContext, Collection<Range<Token>>, TimeUUID, TimeUUID, boolean, long, TopPartitionTracker.Collector) - 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
- castToSegmentRowId(long, long) - Static method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder
- casWriteMetrics - Static variable in class org.apache.cassandra.metrics.ClientRequestsMetricsHolder
- 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.FutureDelegate
- cause() - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- 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.
- ccProxy - Variable in class org.apache.cassandra.tools.NodeProbe
- cdc - Variable in class org.apache.cassandra.schema.TableParams
- cdc(boolean) - Method in class org.apache.cassandra.schema.TableParams.Builder
- CDC - org.apache.cassandra.db.WriteType
- CDC - org.apache.cassandra.schema.TableParams.Option
- cdc_block_writes - Variable in class org.apache.cassandra.config.Config
- cdc_enabled - Variable in class org.apache.cassandra.config.Config
- cdc_free_space_check_interval - Variable in class org.apache.cassandra.config.Config
- cdc_on_repair_enabled - Variable in class org.apache.cassandra.config.Config
- cdc_raw_directory - Variable in class org.apache.cassandra.config.Config
- cdc_total_space - Variable in class org.apache.cassandra.config.Config
- CDC_WRITE_FAILURE - org.apache.cassandra.exceptions.ExceptionCode
- 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
- CEIL - org.apache.cassandra.utils.AsymmetricOrdering.Op
- ceilIndex(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
- ceiling(PartitionPosition, PartitionIndex.Acceptor<PartitionPosition, ResultType>) - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex.Reader
- ceiling(Token) - Method in interface org.apache.cassandra.index.sai.disk.PrimaryKeyMap
- ceiling(Token) - Method in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap
- 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, long, 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 - org.apache.cassandra.schema.CompactionParams.TombstoneOption
- CELL_COUNT - Static variable in class org.apache.cassandra.index.sai.virtual.SegmentsSystemView
- Cell.Factory<V> - Interface in org.apache.cassandra.db.rows
- cellComparator() - Method in class org.apache.cassandra.schema.ColumnMetadata
- cellCount() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- 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() - Method in interface org.apache.cassandra.db.rows.Row
-
An iterable over the cells of this row.
- Cells - Class in org.apache.cassandra.db.rows
-
Static methods to work on cells.
- 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.
- certificates(Channel) - Static method in class org.apache.cassandra.net.InternodeConnectionUtils
- cf - Variable in class org.apache.cassandra.metrics.TableMetrics.TableHistogram
- cf - Variable in class org.apache.cassandra.metrics.TableMetrics.TableTimer
- 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
. - cfmProxy - Variable in class org.apache.cassandra.tools.NodeProbe
- cfname - Variable in class org.apache.cassandra.io.sstable.Descriptor
- cfName - Variable in class org.apache.cassandra.cql3.ColumnSpecification
- cfName - Variable in exception org.apache.cassandra.exceptions.AlreadyExistsException
- cfnames - Variable in class org.apache.cassandra.repair.state.SessionState
- 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.unified.Controller
- cfs - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
- cfs - Variable in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- cfs - Variable in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- cfs - Variable in class org.apache.cassandra.io.sstable.RangeAwareSSTableWriter
- cfs - Variable in class org.apache.cassandra.service.reads.AbstractReadExecutor
- cfs - Variable in class org.apache.cassandra.service.reads.repair.AbstractReadRepair
- 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 - Variable in class org.apache.cassandra.hints.ChecksummedDataInput
- channel - Variable in class org.apache.cassandra.io.util.AbstractReaderFileProxy
- channel - Variable in class org.apache.cassandra.io.util.DataOutputStreamPlus
- channel - Variable in class org.apache.cassandra.io.util.FileHandle
- channel - Variable in class org.apache.cassandra.io.util.NIODataInputStream
- channel - Variable in class org.apache.cassandra.net.AbstractMessageHandler
- channel - Variable in class org.apache.cassandra.net.OutboundConnectionInitiator.Result.Success
- channel - Variable in class org.apache.cassandra.transport.SimpleClient
- channel() - Method in class org.apache.cassandra.io.util.AbstractReaderFileProxy
- channel() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
- channel() - Method in class org.apache.cassandra.io.util.EmptyRebufferer
- channel() - Method in interface org.apache.cassandra.io.util.ReaderFileProxy
- channel() - Method in class org.apache.cassandra.io.util.WrappingRebufferer
- channel() - Method in class org.apache.cassandra.net.AsyncChannelPromise
- channel() - Method in class org.apache.cassandra.transport.Connection
- channel(Descriptor, Component, long) - Method in class org.apache.cassandra.db.streaming.ComponentContext
- 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.NettyStreamingChannel
- 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(ChannelProxy) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
- ChannelProxy(File) - Constructor for class org.apache.cassandra.io.util.ChannelProxy
- ChannelProxy(File, FileChannel) - 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
orBufferPoolAllocator.Wrapped
. - channelRead(ChannelHandlerContext, Object) - Method in class org.apache.cassandra.net.InternodeConnectionUtils.ByteBufDiscardHandler
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.cassandra.streaming.async.NettyStreamingChannel
- 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
- CHAR_SIZE - Static variable in class org.apache.cassandra.db.TypeSizes
- characteristics() - Method in class org.apache.cassandra.utils.concurrent.Threads.StackTraceCombiner
- 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.io.sstable.format.SortedTableVerifier.RangeOwnHelper
-
check if the given key is contained in any of the given ranges
- check_data_resurrection - org.apache.cassandra.service.StartupChecks.StartupCheckType
- CHECK_DATA_RESURRECTION_HEARTBEAT_PERIOD - org.apache.cassandra.config.CassandraRelevantProperties
-
default heartbeating period is 1 minute
- check_dc - org.apache.cassandra.service.StartupChecks.StartupCheckType
- check_filesystem_ownership - org.apache.cassandra.service.StartupChecks.StartupCheckType
- 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
- check_rack - org.apache.cassandra.service.StartupChecks.StartupCheckType
- 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()
- checkAvailableDiskSpaceAndCompactions(Collection<StreamSummary>, TimeUUID, String, boolean) - Static method in class org.apache.cassandra.streaming.StreamSession
-
Makes sure that we expect to have enough disk space available for the new streams, taking into consideration the ongoing compactions and streams.
- 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.
- checkBitsPerValue(int, IndexInput, Supplier<String>) - Static method in class org.apache.cassandra.index.sai.disk.v1.DirectReaders
- checkBlockSize(int, int, int) - Static method in class org.apache.cassandra.index.sai.disk.v1.SAICodecUtils
- 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() - 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
- checkData - Variable in class org.apache.cassandra.io.sstable.IScrubber.Options
- checkData() - Method in class org.apache.cassandra.io.sstable.IScrubber.Options.Builder
- checkData(boolean) - Method in class org.apache.cassandra.io.sstable.IScrubber.Options.Builder
- checkDatacenter - Static variable in class org.apache.cassandra.service.StartupChecks
- checkDataDirs - Static variable in class org.apache.cassandra.service.StartupChecks
- checkedCast(long) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- checkedExpiry - Variable in class org.apache.cassandra.security.FileBasedSslContextFactory.FileBasedStoreContext
- CheckedFunction<T,R,E extends java.lang.Exception> - Interface in org.apache.cassandra.io.util
- checkExpiredCerts(KeyStore) - Method in class org.apache.cassandra.security.FileBasedSslContextFactory
- checkFalse(boolean, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified expression is
false
. - checkFalse(boolean, String, Object) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified expression is
false
. - checkFalse(boolean, String, Object, Object) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified expression is
false
. - checkFalse(boolean, String, Object, Object, Object) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified expression is
false
. - checkFooter(ChecksumIndexInput) - Static method in class org.apache.cassandra.index.sai.disk.v1.SAICodecUtils
- 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>, long) - Static method in class org.apache.cassandra.tools.SSTableExpiredBlockers
- checkHeader(DataInput) - Static method in class org.apache.cassandra.index.sai.disk.v1.SAICodecUtils
- 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
- checkInBounds(float[]) - Static method in class org.apache.cassandra.index.sai.disk.v1.vector.OnHeapGraph
- 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
- checkKernelBug1057843 - 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
. - checkNotEmpty(T, String, Object, Object) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified collections is NOT
empty
. - checkNotNull(T, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified object is NOT
null
. - checkNotNull(T, String, Object) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified object is NOT
null
. - checkNotNull(T, String, Object, Object) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified object is NOT
null
. - checkNull(Object, String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified object is
null
. - checkNull(Object, String, Object) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified object is
null
. - checkOwnsTokens - Variable in class org.apache.cassandra.io.sstable.IVerifier.Options
- checkOwnsTokens(boolean) - Method in class org.apache.cassandra.io.sstable.IVerifier.Options.Builder
- checkPackageAccess(String) - Method in class org.apache.cassandra.security.ThreadAwareSecurityManager
- checkPermission(Permission) - Method in class org.apache.cassandra.security.ThreadAwareSecurityManager
- checkPermission(Permission, Object) - Method in class org.apache.cassandra.security.ThreadAwareSecurityManager
- checkPermission(ClientState, Permission, RoleResource) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
- 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.sai.QueryContext
- 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
- checkQueryability(Index.QueryPlan) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Throws an
IndexNotAvailableException
if any of the indexes in the specifiedIndex.QueryPlan
is not queryable, as it's defined bySecondaryIndexManager.isIndexQueryable(Index)
. - checkRack - Static variable in class org.apache.cassandra.service.StartupChecks
- checkReadAheadKbSetting - Static variable in class org.apache.cassandra.service.StartupChecks
- checkSSTablesFormat - Static variable in class org.apache.cassandra.service.StartupChecks
- CHECKSUM - org.apache.cassandra.index.sai.IndexValidation
-
Full validation with checksumming data (slow)
- 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(File, File) - Constructor for class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
- ChecksumValidator(ChecksumType, RandomAccessReader, String) - 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
. - checkTrue(boolean, String, Object, Object) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Checks that the specified expression is
true
. - checkTrue(boolean, String, Object, Object, 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 - Variable in class org.apache.cassandra.io.sstable.IVerifier.Options
- checkVersion(boolean) - Method in class org.apache.cassandra.io.sstable.IVerifier.Options.Builder
- 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
- childCount() - Method in interface org.apache.cassandra.io.tries.SerializationNode
-
The number of children of the node.
- children - Variable in class org.apache.cassandra.index.sai.plan.FilterTree
- 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.
- CHRONICLE_ANALYTICS_DISABLE - org.apache.cassandra.config.CassandraRelevantProperties
- CHRONICLE_ANNOUNCER_DISABLE - org.apache.cassandra.config.CassandraRelevantProperties
- 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
- chunkCache - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderLoadingBuilder
- chunkCache - Variable in class org.apache.cassandra.io.sstable.SSTable
- 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.
- chunksIndexFile - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
- chunkSize - Variable in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
- 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
- chunkStart(long) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
- CIDR - Class in org.apache.cassandra.cql3
-
Contains a CIDR, and operations on it
- CIDR(InetAddress, short) - Constructor for class org.apache.cassandra.cql3.CIDR
-
Generates a CIDR from given IP and netmask
- CIDR_ACCESSES_ACCEPTED_COUNT_NAME_PREFIX - Static variable in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsCountsTable
- CIDR_ACCESSES_ACCEPTED_COUNT_PREFIX - Static variable in class org.apache.cassandra.metrics.CIDRAuthorizerMetrics
- CIDR_ACCESSES_REJECTED_COUNT_NAME_PREFIX - Static variable in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsCountsTable
- CIDR_ACCESSES_REJECTED_COUNT_PREFIX - Static variable in class org.apache.cassandra.metrics.CIDRAuthorizerMetrics
- cidr_authorizer - Variable in class org.apache.cassandra.config.Config
- CIDR_CHECKS_LATENCY - Static variable in class org.apache.cassandra.metrics.CIDRAuthorizerMetrics
- CIDR_CHECKS_LATENCY_NAME - Static variable in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsLatenciesTable
- CIDR_GROUPS - Static variable in class org.apache.cassandra.auth.AuthKeyspace
- CIDR_GROUPS_CACHE_RELOAD_COUNT - Static variable in class org.apache.cassandra.metrics.CIDRAuthorizerMetrics
- CIDR_GROUPS_CACHE_RELOAD_COUNT_NAME - Static variable in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsCountsTable
- CIDR_GROUPS_CACHE_RELOAD_LATENCY - Static variable in class org.apache.cassandra.metrics.CIDRAuthorizerMetrics
- CIDR_GROUPS_CACHE_RELOAD_LATENCY_NAME - Static variable in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsLatenciesTable
- CIDR_GROUPS_TBL_CIDR_GROUP_COL_NAME - Static variable in class org.apache.cassandra.auth.AuthKeyspace
- CIDR_GROUPS_TBL_CIDRS_COL_NAME - Static variable in class org.apache.cassandra.auth.AuthKeyspace
- CIDR_PERMISSIONS - Static variable in class org.apache.cassandra.auth.AuthKeyspace
- CIDR_PERMISSIONS_TBL_CIDR_GROUPS_COL_NAME - Static variable in class org.apache.cassandra.auth.AuthKeyspace
- CIDR_PERMISSIONS_TBL_ROLE_COL_NAME - Static variable in class org.apache.cassandra.auth.AuthKeyspace
- cidrAuthorizerMetrics - Static variable in class org.apache.cassandra.auth.AbstractCIDRAuthorizer
- CIDRAuthorizerMetrics - Class in org.apache.cassandra.metrics
-
Captures metrics of CIDR authorizer
- CIDRAuthorizerMetrics() - Constructor for class org.apache.cassandra.metrics.CIDRAuthorizerMetrics
- cidrChecksLatency - Variable in class org.apache.cassandra.metrics.CIDRAuthorizerMetrics
- CIDRFilteringMetricsTable - Class in org.apache.cassandra.db.virtual
-
Virtual tables capturing metrics related to CIDR filtering
- CIDRFilteringMetricsTable.CIDRFilteringMetricsCountsTable - Class in org.apache.cassandra.db.virtual
-
Virtual table capturing counts i.e, non-latency metrics related to CIDR filtering
- CIDRFilteringMetricsTable.CIDRFilteringMetricsLatenciesTable - Class in org.apache.cassandra.db.virtual
-
Virtual table capturing latency metrics related to CIDR filtering
- CIDRFilteringMetricsTableMBean - Interface in org.apache.cassandra.db.virtual
-
mbean to expose CIDR filtering metrics virtual table to JMX/nodetool
- CIDRFilteringStats - Class in org.apache.cassandra.tools.nodetool
-
Nodetool command to view stats related to CIDR filtering
- CIDRFilteringStats() - Constructor for class org.apache.cassandra.tools.nodetool.CIDRFilteringStats
- cidrGroupsMappingCache - Static variable in class org.apache.cassandra.auth.CassandraCIDRAuthorizer
- CIDRGroupsMappingCache - Class in org.apache.cassandra.auth
-
CIDR groups mapping cache.
- CIDRGroupsMappingCache(CIDRGroupsMappingManager, CIDRAuthorizerMetrics) - Constructor for class org.apache.cassandra.auth.CIDRGroupsMappingCache
- CIDRGroupsMappingIntervalTree<V> - Class in org.apache.cassandra.auth
-
This class implements CIDR Interval tree and the ability to find longest matching CIDR for the given IP.
- CIDRGroupsMappingIntervalTree(boolean, Map<CIDR, Set<V>>) - Constructor for class org.apache.cassandra.auth.CIDRGroupsMappingIntervalTree
-
Build an interval tree for given CIDRs
- CIDRGroupsMappingLoader - Class in org.apache.cassandra.auth
-
Reads the table
AuthKeyspace.CIDR_GROUPS
and populates CIDR groups mapping data structures. - CIDRGroupsMappingLoader(CIDRGroupsMappingManager) - Constructor for class org.apache.cassandra.auth.CIDRGroupsMappingLoader
- cidrGroupsMappingManager - Static variable in class org.apache.cassandra.auth.AbstractCIDRAuthorizer
- cidrGroupsMappingManager - Variable in class org.apache.cassandra.auth.CIDRGroupsMappingLoader
- CIDRGroupsMappingManager - Class in org.apache.cassandra.auth
- CIDRGroupsMappingManager() - Constructor for class org.apache.cassandra.auth.CIDRGroupsMappingManager
- CIDRGroupsMappingManagerMBean - Interface in org.apache.cassandra.auth
-
This class provides utility functions to list/update/drop CIDR groups mappings.
- CIDRGroupsMappingTable<V> - Interface in org.apache.cassandra.auth
-
This interface defines functionality to be provided by algorithm(s) implementing CIDR to CIDR groups mappings, to facilitate the efficient way to find the longest matching CIDR for a given IP
- CIDRGroupsMappingTable.Builder<V> - Class in org.apache.cassandra.auth
-
Builder to add CIDR to CIDR groups mappings and construct a mapping table with them
- CIDRPermissions - Class in org.apache.cassandra.auth
-
Contains CIDR permissions of a role
- CIDRPermissions() - Constructor for class org.apache.cassandra.auth.CIDRPermissions
- CIDRPermissions.Builder - Class in org.apache.cassandra.auth
-
Builder to generate CIDR Permissions
- cidrPermissionsCache - Static variable in class org.apache.cassandra.auth.CassandraCIDRAuthorizer
- CIDRPermissionsCache - Class in org.apache.cassandra.auth
- CIDRPermissionsCache(Function<RoleResource, CIDRPermissions>, Supplier<Map<RoleResource, CIDRPermissions>>, BooleanSupplier) - Constructor for class org.apache.cassandra.auth.CIDRPermissionsCache
- cidrPermissionsManager - Static variable in class org.apache.cassandra.auth.AbstractCIDRAuthorizer
- CIDRPermissionsManager - Class in org.apache.cassandra.auth
-
Provides functionality to list/update/drop CIDR permissions of a role Backend to build Role to CIDR permissions cache
- CIDRPermissionsManager() - Constructor for class org.apache.cassandra.auth.CIDRPermissionsManager
- CIDRPermissionsManagerMBean - Interface in org.apache.cassandra.auth
-
JMX functions related to CIDR permissions cache and table
- 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
- cipher_suites - Variable in class org.apache.cassandra.security.AbstractSslContextFactory
- CIPHER_SUITES - org.apache.cassandra.config.EncryptionOptions.ConfigKey
- 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
- CIRCLECI - org.apache.cassandra.config.CassandraRelevantEnv
- CLASS - org.apache.cassandra.schema.CompactionParams.Option
- 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 - Variable in class org.apache.cassandra.config.ParameterizedClass
- CLASS_NAME - Static 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() - Method in interface org.apache.cassandra.utils.memory.MemtableCleaner
-
This is a function that schedules a cleaning task, normally flushing of the largest sstable.
- clean(ByteBuffer) - Static method in class org.apache.cassandra.io.util.FileUtils
- 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))
. - cleaner() - Method in class org.apache.cassandra.utils.concurrent.Ref.DirectBufferRef
- 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() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeConcatIterator.Builder
- cleanup() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIntersectionIterator.Builder
- cleanup() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator.Builder
- cleanup() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeUnionIterator.Builder
- 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() - Method in interface org.apache.cassandra.streaming.StreamReceiver
-
Called after finished has returned and we've sent any messages to other nodes.
- cleanup(SharedContext, Collection<InetAddressAndPort>, TableMetadata, Collection<Range<Token>>, boolean, Executor) - Static method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanup
- cleanup(TableId, Collection<Range<Token>>, boolean) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
- cleanUp(TimeUUID, Set<InetAddressAndPort>) - Method in class org.apache.cassandra.service.ActiveRepairService
-
Send Verb.CLEANUP_MSG to the given endpoints.
- Cleanup - Class in org.apache.cassandra.tools.nodetool
- Cleanup() - Constructor for class org.apache.cassandra.tools.nodetool.Cleanup
- CLEANUP - org.apache.cassandra.db.compaction.OperationType
- CLEANUP - org.apache.cassandra.index.transactions.IndexTransaction.Type
- CLEANUP_INTERVAL - Static variable in class org.apache.cassandra.repair.consistent.LocalSessions
-
How often LocalSessions.cleanup is run
- CLEANUP_MSG - org.apache.cassandra.net.Verb
- cleanupAfterDeserialize() - Method in class org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
- cleanupAfterDeserialize() - Method in class org.apache.cassandra.service.CacheService.KeyCacheSerializer
- cleanupAfterSerialize() - Method in class org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
- cleanupAfterSerialize() - Method in class org.apache.cassandra.service.CacheService.KeyCacheSerializer
- cleanupCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- CleanupDataCmd() - Constructor for class org.apache.cassandra.tools.nodetool.RepairAdmin.CleanupDataCmd
- CleanupMessage - Class in org.apache.cassandra.repair.messages
-
Message to cleanup repair resources on replica nodes.
- CleanupMessage(TimeUUID) - 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<TimeUUID>, Set<TimeUUID>) - Constructor for class org.apache.cassandra.repair.consistent.admin.CleanupSummary
- CleanupSummary(ColumnFamilyStore, Set<TimeUUID>, Set<TimeUUID>) - Constructor for class org.apache.cassandra.repair.consistent.admin.CleanupSummary
- cleanupTaskFuture - Variable in class org.apache.cassandra.service.snapshot.SnapshotManager
- 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() - Static method in class org.apache.cassandra.concurrent.ExecutorLocals
- 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.index.sai.SSTableContextManager
- 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.DefaultSchemaUpdateHandler
-
When clear is called the update handler will flag that the clear was requested.
- clear() - Method in class org.apache.cassandra.schema.OfflineSchemaUpdateHandler
- clear() - Method in interface org.apache.cassandra.schema.SchemaUpdateHandler
-
Marks the local schema to be cleared and refreshed.
- clear() - Method in class org.apache.cassandra.transport.ProtocolVersionTracker
- 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.BlockingQueues.Sync
- 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() - Method in interface org.apache.cassandra.utils.obs.IBitSet
- clear() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
- clear(long) - Method in interface org.apache.cassandra.utils.obs.IBitSet
-
clears the bit.
- clear(long) - 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
- 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)
- clearExpiredSnapshots() - Method in class org.apache.cassandra.service.snapshot.SnapshotManager
- clearInternalStatementsCache() - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
Clear our internal statmeent cache for test purposes.
- clearLocalRepairState() - Method in class org.apache.cassandra.service.ActiveRepairService
- clearMapField(Class<?>, Object, String, Predicate<Map.Entry<K, V>>) - Static method in class org.apache.cassandra.utils.ReflectionUtils
-
Used by the in-jvm dtest framework to remove entries from private map fields that otherwise would prevent collection of classloaders (which causes metaspace OOMs) or otherwise interfere with instance restart.
- clearOnExitThreads() - Static method in class org.apache.cassandra.io.util.PathUtils
- clearOverflow() - Method in class org.apache.cassandra.utils.EstimatedHistogram
-
Resets the count in the overflow bucket to zero.
- clearPaxosRepairs() - Method in class org.apache.cassandra.service.StorageService
- clearPaxosRepairs() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- clearPreparedStatements(boolean) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
Clears the prepared statement cache.
- clearPreparedStatementsCache() - Static method in class org.apache.cassandra.cql3.QueryProcessor
- clearRepairs() - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosRepairState
- clearSnapshot(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Clear all the snapshots for a given column family.
- 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
-
Deprecated.See CASSANDRA-16860
- clearSnapshot(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
Deprecated.See CASSANDRA-16860
- clearSnapshot(String, List<File>, RateLimiter) - Static method in class org.apache.cassandra.db.Directories
- clearSnapshot(Map<String, Object>, String, String...) - Method in class org.apache.cassandra.service.StorageService
- clearSnapshot(Map<String, Object>, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Remove the snapshot with the given name from the given keyspaces.
- clearSnapshot(Map<String, Object>, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
-
Remove all the existing snapshots of given tag for provided keyspaces.
- clearSnapshot(TableSnapshot) - Method in class org.apache.cassandra.service.snapshot.SnapshotManager
-
Deletes snapshot and remove it from manager
- ClearSnapshot - Class in org.apache.cassandra.tools.nodetool
- ClearSnapshot() - Constructor for class org.apache.cassandra.tools.nodetool.ClearSnapshot
- clearSslContextCache() - Static method in class org.apache.cassandra.security.SSLFactory
-
This clears the cache of Netty's SslContext objects for Client and Server sockets.
- clearSSTableReadMeter(String, String, SSTableId) - 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.
- clearStates() - Method in class org.apache.cassandra.streaming.StreamManager
- 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.
- clearValue() - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
-
Clears the value set in the system property.
- Client - Class in org.apache.cassandra.transport
- Client() - Constructor for class org.apache.cassandra.io.sstable.SSTableLoader.Client
- Client(String, int, ProtocolVersion, EncryptionOptions) - Constructor for class org.apache.cassandra.transport.Client
- CLIENT - org.apache.cassandra.security.ISslContextFactory.SocketType
- client_encryption_options - Variable in class org.apache.cassandra.config.Config
- client_error_reporting_exclusions - Variable in class org.apache.cassandra.config.Config
- CLIENT_OPTIONS - Static variable in class org.apache.cassandra.transport.ConnectedClient
- client_request_size_metrics_enabled - Variable in class org.apache.cassandra.config.Config
- clientDeadline() - Method in class org.apache.cassandra.transport.Dispatcher.RequestTime
- clientEncOptions - Variable in class org.apache.cassandra.tools.LoaderOptions
- clientInitialization() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
Equivalent to
clientInitialization(true)
. - clientInitialization(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
Equivalent to
clientInitialization(true, Config::new)
. - clientInitialization(boolean, Supplier<Config>) - 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
- clientOptions() - Method in class org.apache.cassandra.transport.ConnectedClient
- ClientRangeRequestMetrics - Class in org.apache.cassandra.metrics
-
Metrics for tracking information about range requests.
- ClientRangeRequestMetrics(String) - Constructor for class org.apache.cassandra.metrics.ClientRangeRequestMetrics
- ClientRequestMetrics - Class in org.apache.cassandra.metrics
- ClientRequestMetrics(String) - Constructor for class org.apache.cassandra.metrics.ClientRequestMetrics
- ClientRequestSizeMetrics - Class in org.apache.cassandra.metrics
- ClientRequestSizeMetrics() - Constructor for class org.apache.cassandra.metrics.ClientRequestSizeMetrics
- ClientRequestsMetricsHolder - Class in org.apache.cassandra.metrics
- ClientRequestsMetricsHolder() - Constructor for class org.apache.cassandra.metrics.ClientRequestsMetricsHolder
- ClientResourceLimits - Class in org.apache.cassandra.transport
- ClientResourceLimits() - Constructor for class org.apache.cassandra.transport.ClientResourceLimits
- ClientResourceLimits.Overload - Enum in org.apache.cassandra.transport
- ClientStat - Class in org.apache.cassandra.transport
- clientState - Variable in class org.apache.cassandra.cql3.UpdateParameters
- 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
- clientTombstoneAborts - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
- clientTombstoneAborts - Variable in class org.apache.cassandra.metrics.TableMetrics
- clientTombstoneWarnings - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
- clientTombstoneWarnings - Variable in class org.apache.cassandra.metrics.TableMetrics
- ClientWarn - Class in org.apache.cassandra.service
- ClientWarn.State - Class in org.apache.cassandra.service
- 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
- clock - Variable in class org.apache.cassandra.db.compaction.unified.Controller
- clock - Variable in class org.apache.cassandra.repair.state.AbstractCompletable
- clock() - Method in interface org.apache.cassandra.repair.SharedContext
- clock() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- clock() - Method in class org.apache.cassandra.repair.SharedContext.Global
- clock() - Static method in class org.apache.cassandra.utils.Clock.Global
- Clock - 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.
- CLOCK_GLOBAL - org.apache.cassandra.config.CassandraRelevantProperties
- CLOCK_MONOTONIC_APPROX - org.apache.cassandra.config.CassandraRelevantProperties
- CLOCK_MONOTONIC_PRECISE - org.apache.cassandra.config.CassandraRelevantProperties
- Clock.Default - Class in org.apache.cassandra.utils
- Clock.Global - Class in org.apache.cassandra.utils
- ClockAndCount - Class in org.apache.cassandra.db
- clone() - Method in class org.apache.cassandra.db.commitlog.CommitLogPosition
- clone() - Method in class org.apache.cassandra.transport.Envelope
- clone(byte[]) - Method in class org.apache.cassandra.utils.memory.ByteBufferCloner
- clone(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- clone(ByteBuffer) - Method in class org.apache.cassandra.utils.memory.ByteBufferCloner
- clone(Clustering<?>) - Method in class org.apache.cassandra.utils.memory.ByteBufferCloner
- clone(Clustering<?>) - Method in interface org.apache.cassandra.utils.memory.Cloner
-
Clones the specified clustering.
- clone(DecoratedKey) - Method in class org.apache.cassandra.utils.memory.ByteBufferCloner
- clone(DecoratedKey) - Method in interface org.apache.cassandra.utils.memory.Cloner
-
Clones the specified key.
- clone(DecoratedKey, OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
- clone(Cell<?>) - Method in class org.apache.cassandra.utils.memory.ByteBufferCloner
- clone(Cell<?>) - Method in interface org.apache.cassandra.utils.memory.Cloner
-
Clones the specified cell.
- clone(ByteBufferCloner) - Method in class org.apache.cassandra.cql3.ColumnIdentifier
- clone(ByteBufferCloner) - Method in class org.apache.cassandra.db.ArrayClusteringBound
- clone(ByteBufferCloner) - Method in class org.apache.cassandra.db.BufferClusteringBound
- clone(ByteBufferCloner) - Method in class org.apache.cassandra.db.BufferClusteringBoundary
- clone(ByteBufferCloner) - Method in interface org.apache.cassandra.db.Clustering
- clone(ByteBufferCloner) - Method in interface org.apache.cassandra.db.ClusteringBound
- clone(ByteBufferCloner) - Method in interface org.apache.cassandra.db.ClusteringBoundOrBoundary
- clone(ByteBufferCloner) - Method in interface org.apache.cassandra.db.DeletionInfo
- clone(ByteBufferCloner) - Method in class org.apache.cassandra.db.MutableDeletionInfo
- clone(ByteBufferCloner) - Method in class org.apache.cassandra.db.RangeTombstoneList
- clone(ByteBufferCloner) - Method in class org.apache.cassandra.db.rows.AbstractCell
- clone(ByteBufferCloner) - Method in class org.apache.cassandra.db.rows.ArrayCell
- clone(ByteBufferCloner) - Method in class org.apache.cassandra.db.rows.BufferCell
- clone(ByteBufferCloner) - Method in class org.apache.cassandra.db.rows.Cell
- clone(ByteBufferCloner) - Method in class org.apache.cassandra.db.rows.CellPath
- clone(ByteBufferCloner) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
- clone(ByteBufferCloner) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
- clone(ByteBufferCloner) - Method in interface org.apache.cassandra.db.rows.RangeTombstoneMarker
- clone(Cloner) - Method in class org.apache.cassandra.db.rows.BTreeRow
- clone(Cloner) - Method in class org.apache.cassandra.db.rows.Cell
- clone(Cloner) - Method in class org.apache.cassandra.db.rows.ColumnData
- clone(Cloner) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
- clone(Cloner) - Method in interface org.apache.cassandra.db.rows.Row
- clone(V, ValueAccessor<V>) - Method in class org.apache.cassandra.utils.memory.ByteBufferCloner
- 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.big.BigTableReader
- cloneAndReplace(IFilter) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- cloneAndReplace(IFilter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderWithFilter
- cloneOnlyTokenMap() - Method in class org.apache.cassandra.locator.TokenMetadata
-
Create a copy of TokenMetadata with only tokenToEndpointMap.
- cloner(OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.HeapPool.Allocator
- cloner(OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
- cloner(OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
- cloner(OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.SlabAllocator
- Cloner - Interface in org.apache.cassandra.utils.memory
-
Allow cloning of partition elements
- 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
-
To be used by tests only (via
StorageService.setPartitionerUnsafe(org.apache.cassandra.dht.IPartitioner)
). - cloneWithNewStart(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- cloneWithNewStart(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- cloneWithNewStart(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- cloneWithNewSummarySamplingLevel(ColumnFamilyStore, int) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
Returns a new SSTableReader with the same properties as this SSTableReader except that a new IndexSummary will be built at the target samplingLevel.
- cloneWithNewSummarySamplingLevel(ColumnFamilyStore, int) - Method in interface org.apache.cassandra.io.sstable.indexsummary.IndexSummarySupport
- cloneWithRestoredStart(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- cloneWithRestoredStart(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- cloneWithRestoredStart(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- 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.concurrent.ExecutorLocals
- close() - Method in class org.apache.cassandra.concurrent.NamedThreadFactory
- 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.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.unified.ShardedMultiWriter
- 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 class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
- close() - Method in class org.apache.cassandra.db.rows.ColumnData.Reconciler
- 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 interface org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
- 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() - Method in interface org.apache.cassandra.db.WriteContext
- close() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
- close() - Method in class org.apache.cassandra.hints.CompressedChecksummedDataInput
- close() - Method in interface org.apache.cassandra.index.sai.analyzer.AbstractAnalyzer.AnalyzerFactory
- close() - Method in class org.apache.cassandra.index.sai.disk.IndexSearchResultIterator
- close() - Method in class org.apache.cassandra.index.sai.disk.io.IndexInputReader
- close() - Method in class org.apache.cassandra.index.sai.disk.io.IndexOutputWriter
- close() - Method in interface org.apache.cassandra.index.sai.disk.PrimaryKeyMap
- close() - Method in interface org.apache.cassandra.index.sai.disk.PrimaryKeyMap.Factory
- close() - Method in class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeReader
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeWalker
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.bitpack.NumericValuesWriter
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.keystore.KeyLookup.Cursor
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.keystore.KeyStoreWriter
-
Flushes any in-memory buffers to the output streams.
- close() - Method in interface org.apache.cassandra.index.sai.disk.v1.LongArray
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.LongArray.DeferredLongArray
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.MetadataWriter.Builder
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.MetadataWriter
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.PerColumnIndexFiles
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.FilteringPostingList
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.MergePostingList
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.PostingListRangeIterator
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.PostingsReader
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.PostingsWriter
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.LiteralIndexSegmentSearcher
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.LiteralIndexSegmentTermsReader
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.NumericIndexSegmentSearcher
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.Segment
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.VectorIndexSegmentSearcher
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap.Factory
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.trie.TrieTermsDictionaryWriter
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.DiskAnn
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.OnDiskOrdinalsMap
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.OnDiskOrdinalsMap.OrdinalsView
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.OnDiskOrdinalsMap.RowIdsView
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.WidePrimaryKeyMap
- close() - Method in class org.apache.cassandra.index.sai.disk.v1.WidePrimaryKeyMap.Factory
- close() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeConcatIterator
- close() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIntersectionIterator
- close() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator
- close() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeListIterator
- close() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeOrderingIterator
- close() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeUnionIterator
- close() - Method in class org.apache.cassandra.index.sai.memory.InMemoryKeyRangeIterator
- close() - Method in class org.apache.cassandra.index.sai.memory.MemtableTermsIterator
- close() - Method in class org.apache.cassandra.index.sai.postings.PeekablePostingList
- close() - Method in interface org.apache.cassandra.index.sai.postings.PostingList
- close() - Method in class org.apache.cassandra.index.sai.utils.InMemoryPartitionIterator
- close() - Method in class org.apache.cassandra.index.sai.utils.InMemoryUnfilteredPartitionIterator
- 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.sstable.AbstractSSTableIterator.AbstractReader
- close() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator
- close() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter
-
Close this writer.
- close() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormatPartitionWriter
- close() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableKeyReader
- close() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScrubber
- close() - Method in class org.apache.cassandra.io.sstable.format.big.IndexState
- close() - Method in interface org.apache.cassandra.io.sstable.format.big.RowIndexEntry.IndexInfoRetriever
- close() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableScanner.BtiScanningIterator
- close() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableScrubber
- close() - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex
- close() - Method in class org.apache.cassandra.io.sstable.format.bti.ScrubIterator
- close() - Method in interface org.apache.cassandra.io.sstable.format.bti.ScrubPartitionIterator
- close() - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- close() - Method in class org.apache.cassandra.io.sstable.format.SSTableScanner
- close() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
- close() - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryBuilder
- close() - Method in interface org.apache.cassandra.io.sstable.IScrubber
- close() - Method in interface org.apache.cassandra.io.sstable.IVerifier
- close() - Method in class org.apache.cassandra.io.sstable.KeyIterator
- close() - Method in interface org.apache.cassandra.io.sstable.KeyReader
-
Closes the iterator quietly
- close() - Method in class org.apache.cassandra.io.sstable.RangeAwareSSTableWriter
- 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.sstable.SSTableZeroCopyWriter
- close() - Method in interface org.apache.cassandra.io.tries.IncrementalTrieWriter
- close() - Method in class org.apache.cassandra.io.tries.IncrementalTrieWriterBase
- close() - Method in class org.apache.cassandra.io.tries.Walker
- 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.DataOutputBuffer
- close() - Method in class org.apache.cassandra.io.util.EmptyRebufferer
- close() - Method in class org.apache.cassandra.io.util.FileInputStreamPlus
- close() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
- close() - Method in class org.apache.cassandra.io.util.Memory
- close() - Method in class org.apache.cassandra.io.util.MmappedRegionsCache
- 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.SafeMemory
- close() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
- close() - Method in class org.apache.cassandra.io.util.SequentialWriter
- close() - Method in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
- close() - Method in class org.apache.cassandra.io.util.WrappingRebufferer
- 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.metrics.TopPartitionTracker
- 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() - Method in class org.apache.cassandra.security.EncryptionUtils.ChannelProxyReadChannel
- close() - Method in class org.apache.cassandra.service.pager.AggregationQueryPager.GroupByPartitionIterator
- close() - Method in interface org.apache.cassandra.service.paxos.PaxosOperationLock
- close() - Method in class org.apache.cassandra.service.paxos.PaxosState
- close() - Method in class org.apache.cassandra.service.reads.range.RangeCommandIterator
- 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.NettyStreamingChannel
- close() - Method in class org.apache.cassandra.streaming.async.StreamingMultiplexedChannel
- 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.StreamingChannel
- close() - Method in interface org.apache.cassandra.streaming.StreamingDataInputPlus
- 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.btree.BTree.FastBuilder
- close() - Method in interface org.apache.cassandra.utils.BulkIterator
- close() - Method in class org.apache.cassandra.utils.BulkIterator.FromArray
- close() - Method in interface org.apache.cassandra.utils.Closeable
- 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
-
See
Refs.release()
- close() - 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.JMXServerUtils.JmxRegistry
-
Closes the underlying JMX registry by unexporting this instance.
- close() - Method in class org.apache.cassandra.utils.MBeanWrapper.InstanceMBeanWrapper
- close() - Method in class org.apache.cassandra.utils.MergeIterator
- close() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
-
May be overridden by implementations that require cleaning up after use
- close() - Method in interface org.apache.cassandra.utils.obs.IBitSet
- close() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
- close() - Method in class org.apache.cassandra.utils.RMIClientSocketFactoryImpl
- close(boolean) - Method in class org.apache.cassandra.db.Slice
- close(boolean) - Method in class org.apache.cassandra.net.OutboundConnection
-
Permanently close this connection.
- 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(Throwable) - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex
- close(Throwable) - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryBuilder
- close(Throwable) - Method in class org.apache.cassandra.io.util.SafeMemory
- close(Throwable) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
- close(Throwable) - Method in interface org.apache.cassandra.utils.concurrent.SharedCloseable
- close(Throwable) - Method in class org.apache.cassandra.utils.concurrent.SharedCloseableImpl
- close(Throwable, AutoCloseable...) - Static method in class org.apache.cassandra.utils.Throwables
- close(Throwable, Iterable<? extends AutoCloseable>) - Static method in class org.apache.cassandra.utils.Throwables
-
Closes all the resources in the provided collections and accumulates the possible exceptions thrown when closing.
- close(UnfilteredPartitionIterator) - Static method in class org.apache.cassandra.db.transform.RTBoundCloser
- close(UnfilteredRowIterator) - Static method in class org.apache.cassandra.db.transform.RTBoundCloser
- Closeable - Interface in org.apache.cassandra.utils
- closeableIterator(Iterator<T>) - Static method in class org.apache.cassandra.utils.FBUtilities
- CloseableIterator<T> - Interface in org.apache.cassandra.utils
- 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
- closeAndAddSuppressed(Throwable, AutoCloseable...) - Static method in class org.apache.cassandra.utils.Throwables
- closeAndAddSuppressed(Throwable, Iterable<AutoCloseable>) - Static method in class org.apache.cassandra.utils.Throwables
-
Closes all closables in the provided collections and accumulates the possible exceptions thrown when closing.
- 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
- closeInternalComponent(AutoCloseable) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
All the resources which should be released upon closing this sstable reader are registered with in
SSTableReader.GlobalTidy
. - 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
- closeNonNullAndAddSuppressed(Throwable, AutoCloseable...) - Static method in class org.apache.cassandra.utils.Throwables
-
Do what
Throwables.closeAndAddSuppressed(Throwable, Iterable)
does, additionally filtering out all null closables. - 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() - Method in class org.apache.cassandra.io.util.MmappedRegions
- 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(Object) - Static method in class org.apache.cassandra.utils.FBUtilities
- closeReader() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
- closeReader() - Method in class org.apache.cassandra.io.util.EmptyRebufferer
- closeReader() - Method in interface org.apache.cassandra.io.util.Rebufferer
-
Called when a reader is closed.
- closeReader() - Method in class org.apache.cassandra.io.util.WrappingRebufferer
- CloudstackSnitch - Class in org.apache.cassandra.locator
-
Deprecated.See CASSANDRA-18438
- CloudstackSnitch() - Constructor for class org.apache.cassandra.locator.CloudstackSnitch
-
Deprecated.
- CloudstackSnitch(AbstractCloudMetadataServiceConnector) - Constructor for class org.apache.cassandra.locator.CloudstackSnitch
-
Deprecated.
- CloudstackSnitch(SnitchProperties) - Constructor for class org.apache.cassandra.locator.CloudstackSnitch
-
Deprecated.
- cluster() - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
-
Creates a
DescribeStatement
forDESCRIBE 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
. - clusteredSeekToKey(ByteComparable, long, long) - Method in class org.apache.cassandra.index.sai.disk.v1.keystore.KeyLookup.Cursor
-
Finds the pointId for a clustering key within a range of pointIds.
- clustering - Variable in class org.apache.cassandra.db.rows.BTreeRow.Builder
- 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() - 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() - 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() - Method in interface org.apache.cassandra.index.sai.utils.PrimaryKey
-
Returns the
Clustering
representing the clustering component of thePrimaryKey
. - clustering(TableMetadata) - Method in class org.apache.cassandra.service.pager.PagingState.RowMark
- clustering(V...) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor.ObjectFactory
- Clustering<V> - Interface in org.apache.cassandra.db
- CLUSTERING - org.apache.cassandra.db.ClusteringPrefix.Kind
- CLUSTERING - org.apache.cassandra.schema.ColumnMetadata.Kind
- CLUSTERING_COLUMN_INDEX_FUNCTIONS - Static variable in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
- CLUSTERING_KEY_BLOCK_OFFSETS - org.apache.cassandra.index.sai.disk.format.IndexComponent
-
Encoded sequence of offsets to clustering key blocks
- CLUSTERING_KEY_BLOCKS - org.apache.cassandra.index.sai.disk.format.IndexComponent
-
Prefix-compressed blocks of clustering keys used for rowId to clustering key lookups
- Clustering.Serializer - Class in org.apache.cassandra.db
-
Serializer for Clustering object.
- 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(String, String, String, AbstractType<?>, int) - Static method in class org.apache.cassandra.schema.ColumnMetadata
- clusteringColumn(TableMetadata, ByteBuffer, 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 - Variable in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- ClusteringComparator - Class in org.apache.cassandra.db
-
A comparator of clustering prefixes (or more generally of
Clusterable
}. - ClusteringComparator(Iterable<AbstractType<?>>) - Constructor for class org.apache.cassandra.db.ClusteringComparator
- ClusteringComparator(AbstractType<?>...) - Constructor for class org.apache.cassandra.db.ClusteringComparator
- clusteringFromByteComparable(ValueAccessor<V>, ByteComparable) - Method in class org.apache.cassandra.db.ClusteringComparator
-
Produces a clustering from the given byte-comparable value.
- clusteringFromByteComparable(ByteSource) - Method in class org.apache.cassandra.index.sai.utils.PrimaryKey.Factory
-
Create a
Clustering
from aByteSource
. - clusteringIndexFilter - Variable in class org.apache.cassandra.db.DataRange
- clusteringIndexFilter - Variable in class org.apache.cassandra.db.SinglePartitionReadCommand
- clusteringIndexFilter() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
- clusteringIndexFilter() - Method in interface org.apache.cassandra.db.SinglePartitionReadQuery
- 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(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(DecoratedKey) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
- 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.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
- clusteringString(List<AbstractType<?>>) - Method in interface org.apache.cassandra.db.ClusteringPrefix
-
Produce a human-readable representation of the clustering given the list of types.
- clusteringTypes() - Method in class org.apache.cassandra.db.SerializationHeader
- cmbProxy - Variable in class org.apache.cassandra.tools.NodeProbe
- cmd - Variable in class org.apache.cassandra.repair.state.CoordinatorState
- 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 - Variable in enum org.apache.cassandra.exceptions.RequestFailureReason
- code - Variable in enum org.apache.cassandra.streaming.ProgressInfo.Direction
- code() - Method in exception org.apache.cassandra.exceptions.CassandraException
- code() - Method in interface org.apache.cassandra.exceptions.TransportException
-
The exception code.
- code() - Method in exception org.apache.cassandra.transport.ProtocolException
- code() - Method in exception org.apache.cassandra.transport.ServerError
- codec - Static variable in class org.apache.cassandra.cql3.QueryOptions
- codec - Static variable in class org.apache.cassandra.cql3.ResultSet
- codec - Static variable in class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
- codec - Static variable in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
- codec - Static variable in enum org.apache.cassandra.transport.DataType
- codec - Variable in enum org.apache.cassandra.transport.Message.Type
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthChallenge
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthenticateMessage
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthResponse
- codec - Static variable in class org.apache.cassandra.transport.messages.AuthSuccess
- codec - Static variable in class org.apache.cassandra.transport.messages.BatchMessage
- codec - Static variable in class org.apache.cassandra.transport.messages.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
- Codec() - Constructor for class org.apache.cassandra.cql3.ResultSet.Codec
- Codec() - Constructor for class org.apache.cassandra.transport.DataType.Codec
- codecFor(DataType) - Method in class org.apache.cassandra.cql3.functions.types.CodecRegistry
- codecFor(DataType) - Static method in class org.apache.cassandra.utils.JavaDriverUtils
- codecFor(DataType, TypeToken<T>) - Method in class org.apache.cassandra.cql3.functions.types.CodecRegistry
- codecFor(DataType, Class<T>) - Method in class org.apache.cassandra.cql3.functions.types.CodecRegistry
- codecFor(DataType, T) - Method in class org.apache.cassandra.cql3.functions.types.CodecRegistry
- codecFor(AbstractType<?>) - Static method in class org.apache.cassandra.utils.JavaDriverUtils
- codecFor(T) - Method in class org.apache.cassandra.cql3.functions.types.CodecRegistry
-
Returns a
codec
that accepts the given value. - CodecNotFoundException - Exception in org.apache.cassandra.cql3.functions.types.exceptions
-
Thrown when a suitable
TypeCodec
cannot be found byCodecRegistry
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
TypeCodec
s. - 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_size_fail_threshold - Variable in class org.apache.cassandra.config.Config
- collection_size_warn_threshold - Variable in class org.apache.cassandra.config.Config
- 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
- CollectionFcts - Class in org.apache.cassandra.cql3.functions
-
Native CQL functions for collections (sets, list and maps).
- CollectionFcts() - Constructor for class org.apache.cassandra.cql3.functions.CollectionFcts
- 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
- COLLECTIONS_WITH_DURATIONS_NOT_SUPPORTED - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- CollectionSerializer<T> - Class in org.apache.cassandra.serializers
- CollectionSerializer - Class in org.apache.cassandra.utils
- CollectionSerializer() - Constructor for class org.apache.cassandra.serializers.CollectionSerializer
- CollectionSerializer() - Constructor for class org.apache.cassandra.utils.CollectionSerializer
- collectionSize - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the size of a collection.
- 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
- collectMarkerSpecification(VariableSpecifications) - Method in class org.apache.cassandra.cql3.Vectors.DelayedValue
- 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
- Collector() - Constructor for class org.apache.cassandra.db.rows.EncodingStats.Collector
- Collector(Collection<Range<Token>>) - Constructor for class org.apache.cassandra.metrics.TopPartitionTracker.Collector
- Collectors3 - Class in org.apache.cassandra.utils
-
Some extra Collector implementations.
- Collectors3() - Constructor for class org.apache.cassandra.utils.Collectors3
- collectStats(Cell<?>, PartitionStatisticsCollector) - Static method in class org.apache.cassandra.db.rows.Cells
-
Collect statistics ont a given cell.
- 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(Row, PartitionStatisticsCollector) - Static method in class org.apache.cassandra.db.rows.Rows
-
Collect statistics on a given row.
- collectTTLs() - Method in interface org.apache.cassandra.cql3.selection.Selection.Selectors
-
Checks if one of the selectors collect TTLs.
- collectWritetimes() - Method in interface org.apache.cassandra.cql3.selection.Selection.Selectors
-
Checks if one of the selectors collects write timestamps.
- 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 - Variable in class org.apache.cassandra.db.filter.RowFilter.Expression
- column - Variable in class org.apache.cassandra.db.rows.ColumnData
- column - Variable in class org.apache.cassandra.schema.DroppedColumn
- column() - Method in class org.apache.cassandra.db.filter.ColumnSubselection
- column() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
- column() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.CounterMark
- 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_COMPLETION_MARKER - org.apache.cassandra.index.sai.disk.format.IndexComponent
-
If present indicates that the column index build completed successfully
- COLUMN_DOES_NOT_EXIST - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- column_family - Variable in class org.apache.cassandra.db.SnapshotCommand
- column_index_cache_size - Variable in class org.apache.cassandra.config.Config
- column_index_size - Variable in class org.apache.cassandra.config.Config
- COLUMN_MASKS - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
- COLUMN_NAME - Static variable in class org.apache.cassandra.index.sai.virtual.SegmentsSystemView
- column_value_size_fail_threshold - Variable in class org.apache.cassandra.config.Config
- column_value_size_warn_threshold - Variable in class org.apache.cassandra.config.Config
- ColumnCompletionMarkerUtil - Class in org.apache.cassandra.index.sai.disk.v1
-
Utility class for creating and reading the column completion marker,
IndexComponent.COLUMN_COMPLETION_MARKER
. - ColumnCompletionMarkerUtil() - Constructor for class org.apache.cassandra.index.sai.disk.v1.ColumnCompletionMarkerUtil
- 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
ColumnCondition
s. - ColumnConditions.Builder - Class in org.apache.cassandra.cql3.conditions
-
A
Builder
forColumnConditions
. - 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() - 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
- 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.PostReconciliationFunction - Interface in org.apache.cassandra.db.rows
- ColumnData.Reconciler - Class in org.apache.cassandra.db.rows
- 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 - Variable in class org.apache.cassandra.db.TruncateResponse
- columnFamily - Variable in class org.apache.cassandra.repair.RepairJobDesc
- COLUMNFAMILY - Static variable in class org.apache.cassandra.db.compaction.CompactionInfo
- ColumnFamilyStore - Class in org.apache.cassandra.db
- ColumnFamilyStore(Keyspace, String, Supplier<? extends SSTableId>, TableMetadataRef, Directories, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore
- ColumnFamilyStore.FlushReason - Enum in org.apache.cassandra.db
-
Reason for initiating a memtable flush.
- ColumnFamilyStore.RefViewFragment - Class in org.apache.cassandra.db
- ColumnFamilyStore.VersionedLocalRanges - 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() - 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 - 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.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, String) - Constructor for class org.apache.cassandra.cql3.ColumnIdentifier
- ColumnIdentifier(ByteBuffer, AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.ColumnIdentifier
- columnIndex - Variable in class org.apache.cassandra.index.sasi.memory.MemIndex
- ColumnIndex - Class in org.apache.cassandra.index.sasi.conf
- ColumnIndex(AbstractType<?>, ColumnMetadata, IndexMetadata) - Constructor for class org.apache.cassandra.index.sasi.conf.ColumnIndex
- ColumnIndexesSystemView - Class in org.apache.cassandra.index.sai.virtual
-
A
VirtualTable
providing a system view of per-column storage-attached index metadata. - ColumnIndexesSystemView(String) - Constructor for class org.apache.cassandra.index.sai.virtual.ColumnIndexesSystemView
- ColumnMask - Class in org.apache.cassandra.cql3.functions.masking
-
Dynamic data mask that can be applied to a schema column.
- ColumnMask(ScalarFunction, ByteBuffer...) - Constructor for class org.apache.cassandra.cql3.functions.masking.ColumnMask
- ColumnMask.Masker - Class in org.apache.cassandra.cql3.functions.masking
- ColumnMask.Raw - Class in org.apache.cassandra.cql3.functions.masking
-
A parsed but not prepared column mask.
- columnMetadata - Variable in class org.apache.cassandra.cql3.Ordering.Expression
- columnMetadata() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
- columnMetadata(TableMetadata) - Method in class org.apache.cassandra.cql3.selection.Selectable.RawIdentifier
- ColumnMetadata - Class in org.apache.cassandra.schema
- ColumnMetadata(String, String, ColumnIdentifier, AbstractType<?>, int, ColumnMetadata.Kind, ColumnMask) - Constructor for class org.apache.cassandra.schema.ColumnMetadata
- ColumnMetadata(TableMetadata, ByteBuffer, AbstractType<?>, int, ColumnMetadata.Kind, ColumnMask) - 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() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
- columnName(List<String>) - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
- columnName(List<String>) - Method in class org.apache.cassandra.cql3.functions.AggregateFcts.CountRowsFunction
- 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
- columnQueryMetrics() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- ColumnQueryMetrics - Class in org.apache.cassandra.index.sai.metrics
- ColumnQueryMetrics(IndexIdentifier) - Constructor for class org.apache.cassandra.index.sai.metrics.ColumnQueryMetrics
- ColumnQueryMetrics.BalancedTreeIndexMetrics - Class in org.apache.cassandra.index.sai.metrics
- ColumnQueryMetrics.TrieIndexMetrics - Class in org.apache.cassandra.index.sai.metrics
- columns - Variable in class org.apache.cassandra.db.AbstractReadCommandBuilder
- columns - Variable in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
- columns - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableIterator
- columns - Variable in class org.apache.cassandra.io.sstable.format.SSTableScanner
- columns() - Method in class org.apache.cassandra.db.memtable.AbstractMemtable.AbstractFlushablePartitionSet
- columns() - Method in interface org.apache.cassandra.db.memtable.Memtable.FlushablePartitionSet
-
The set of all columns that have been written
- 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() - 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 interface org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
- columns() - 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.AbstractSSTableIterator
- columns() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
- columns() - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- columns() - Method in class org.apache.cassandra.schema.TableMetadata
- columns() - Static method in class org.apache.cassandra.streaming.StreamingState.Sessions
- columns(boolean) - Method in class org.apache.cassandra.db.RegularAndStaticColumns
- columns(boolean) - Method in class org.apache.cassandra.db.SerializationHeader
- columns(String...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
- columns(List<UnfilteredRowIterator>) - Method in class org.apache.cassandra.service.reads.repair.PartitionIteratorMergeListener
- Columns - Class in org.apache.cassandra.db
-
An immutable and sorted list of (non-PK) columns for a given table.
- COLUMNS - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
- columns_per_table_fail_threshold - Variable in class org.apache.cassandra.config.Config
- columns_per_table_warn_threshold - Variable in class org.apache.cassandra.config.Config
- Columns.Serializer - Class in org.apache.cassandra.db
- columnsCollector - Variable in class org.apache.cassandra.db.memtable.AbstractMemtable
- columnsIndex(int) - Method in interface org.apache.cassandra.io.sstable.format.big.RowIndexEntry.IndexInfoRetriever
- ColumnSpecification - Class in org.apache.cassandra.cql3
- ColumnSpecification(String, String, ColumnIdentifier, AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.ColumnSpecification
- columnsPerTable - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the number of columns per table.
- 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
- ColumnValues(List<ColumnMetadata>, Object...) - Constructor for class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable.ColumnValues
-
Create a
ColumnValues
for the specified set of columns. - columnValueSize - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the size of a collection.
- colUpdateTimeDelta - Variable in class org.apache.cassandra.db.partitions.BTreePartitionUpdater
- 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
- COM_SUN_MANAGEMENT_JMXREMOTE_ACCESS_FILE - org.apache.cassandra.config.CassandraRelevantProperties
-
This property indicates the location for the access file.
- COM_SUN_MANAGEMENT_JMXREMOTE_AUTHENTICATE - org.apache.cassandra.config.CassandraRelevantProperties
-
This property indicates whether password authentication for remote monitoring is enabled.
- COM_SUN_MANAGEMENT_JMXREMOTE_PASSWORD_FILE - org.apache.cassandra.config.CassandraRelevantProperties
-
This property indicates the path to the password file - com.sun.management.jmxremote.password.file
- COM_SUN_MANAGEMENT_JMXREMOTE_PORT - org.apache.cassandra.config.CassandraRelevantProperties
-
Port number to enable JMX RMI connections - com.sun.management.jmxremote.port
- COM_SUN_MANAGEMENT_JMXREMOTE_RMI_PORT - org.apache.cassandra.config.CassandraRelevantProperties
-
The port number to which the RMI connector will be bound - com.sun.management.jmxremote.rmi.port.
- COM_SUN_MANAGEMENT_JMXREMOTE_SSL - org.apache.cassandra.config.CassandraRelevantProperties
-
This property indicates whether SSL is enabled for monitoring remotely.
- COM_SUN_MANAGEMENT_JMXREMOTE_SSL_ENABLED_CIPHER_SUITES - org.apache.cassandra.config.CassandraRelevantProperties
-
A comma-delimited list of SSL/TLS cipher suites to enable.
- COM_SUN_MANAGEMENT_JMXREMOTE_SSL_ENABLED_PROTOCOLS - org.apache.cassandra.config.CassandraRelevantProperties
-
A comma-delimited list of SSL/TLS protocol versions to enable.
- COM_SUN_MANAGEMENT_JMXREMOTE_SSL_NEED_CLIENT_AUTH - org.apache.cassandra.config.CassandraRelevantProperties
-
This property indicates whether SSL client authentication is enabled - com.sun.management.jmxremote.ssl.need.client.auth.
- 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(Descriptor, OnDiskIndex...) - Constructor for class org.apache.cassandra.index.sasi.utils.CombinedTermIterator
- CombinedTermIterator(OnDiskIndex...) - Constructor for class org.apache.cassandra.index.sasi.utils.CombinedTermIterator
- CombinedValue<V> - Interface in org.apache.cassandra.index.sasi.utils
- combiner() - Method in class org.apache.cassandra.utils.concurrent.Threads.StackTraceCombiner
- 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
- command() - Method in interface org.apache.cassandra.index.Index.Searcher
-
Returns the
ReadCommand
for which this searcher has been created. - command() - Method in class org.apache.cassandra.index.internal.CassandraIndexSearcher
- command() - Method in class org.apache.cassandra.index.sai.plan.StorageAttachedIndexSearcher
- command() - Method in class org.apache.cassandra.index.sasi.plan.SASIIndexSearcher
- comment - Variable in class org.apache.cassandra.schema.TableParams
- comment(String) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- comment(String) - Method in class org.apache.cassandra.schema.TableParams.Builder
- COMMENT - org.apache.cassandra.schema.TableParams.Option
- 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() - Method in interface org.apache.cassandra.index.transactions.IndexTransaction
- commit() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
- commit(Throwable) - Method in class org.apache.cassandra.db.compaction.unified.ShardedMultiWriter
- commit(Throwable) - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
- commit(Throwable) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
- commit(Throwable) - Method in class org.apache.cassandra.io.sstable.RangeAwareSSTableWriter
- commit(Throwable) - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
- commit(Throwable) - Method in class org.apache.cassandra.io.sstable.SSTableZeroCopyWriter
- commit(Throwable) - Method in class org.apache.cassandra.io.util.SequentialWriter
- 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(Throwable) - Method in interface org.apache.cassandra.utils.concurrent.Transactional
- commit(Commit.Agreed) - Method in class org.apache.cassandra.service.paxos.PaxosState
- Commit - Class in org.apache.cassandra.service.paxos
- Commit(Ballot, PartitionUpdate) - Constructor for class org.apache.cassandra.service.paxos.Commit
- commit_failure_policy - Variable in class org.apache.cassandra.config.Config
- COMMIT_LOG_REPLAY_LIST - org.apache.cassandra.config.CassandraRelevantProperties
-
Entities to replay mutations for upon commit log replay, property is meant to contain comma-separated entities which are either names of keyspaces or keyspaces and tables or their mix.
- Commit.Accepted - Class in org.apache.cassandra.service.paxos
- Commit.AcceptedWithTTL - Class in org.apache.cassandra.service.paxos
- Commit.Agreed - Class in org.apache.cassandra.service.paxos
- Commit.CommitSerializer<T extends Commit> - Class in org.apache.cassandra.service.paxos
- Commit.Committed - Class in org.apache.cassandra.service.paxos
- Commit.CommittedWithTTL - Class in org.apache.cassandra.service.paxos
- Commit.Proposal - Class in org.apache.cassandra.service.paxos
- commitDirect(Commit) - Static method in class org.apache.cassandra.service.paxos.PaxosState
- CommitLog - Class in org.apache.cassandra.db.commitlog
- COMMITLOG_ALLOW_IGNORE_SYNC_CRC - org.apache.cassandra.config.CassandraRelevantProperties
- commitlog_compression - Variable in class org.apache.cassandra.config.Config
- commitlog_directory - Variable in class org.apache.cassandra.config.Config
- COMMITLOG_DIRTY - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- commitlog_disk_access_mode - Variable in class org.apache.cassandra.config.Config
- COMMITLOG_IGNORE_REPLAY_ERRORS - org.apache.cassandra.config.CassandraRelevantProperties
- commitlog_max_compression_buffers_in_pool - Variable in class org.apache.cassandra.config.Config
- COMMITLOG_MAX_OUTSTANDING_REPLAY_BYTES - org.apache.cassandra.config.CassandraRelevantProperties
- COMMITLOG_MAX_OUTSTANDING_REPLAY_COUNT - org.apache.cassandra.config.CassandraRelevantProperties
- commitlog_segment_size - Variable in class org.apache.cassandra.config.Config
- COMMITLOG_STOP_ON_ERRORS - org.apache.cassandra.config.CassandraRelevantProperties
- commitlog_sync - Variable in class org.apache.cassandra.config.Config
- commitlog_sync_group_window - Variable in class org.apache.cassandra.config.Config
- commitlog_sync_period - Variable in class org.apache.cassandra.config.Config
- commitlog_total_space - Variable in class org.apache.cassandra.config.Config
- CommitLog.Configuration - Class in org.apache.cassandra.db.commitlog
- CommitLogArchiver - Class in org.apache.cassandra.db.commitlog
- CommitLogArchiver(String, String, String, long, CommitLogPosition, 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 - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
- commitLogIntervals(IntervalSet<CommitLogPosition>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- commitLogLowerBound() - Method in class org.apache.cassandra.db.memtable.AbstractMemtable.AbstractFlushablePartitionSet
- commitLogLowerBound() - Method in interface org.apache.cassandra.db.memtable.Memtable.FlushablePartitionSet
-
The commit log position at the time that this memtable was created
- 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 - Variable in class org.apache.cassandra.db.commitlog.CommitLogReplayer
- CommitLogReader - Class in org.apache.cassandra.db.commitlog
- CommitLogReader() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogReader
- 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) - Constructor for exception org.apache.cassandra.db.commitlog.CommitLogReplayer.CommitLogReplayException
- CommitLogReplayException(String, Throwable) - 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.Builder - Class in org.apache.cassandra.db.commitlog
- 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
- commitLogUpperBound() - Method in class org.apache.cassandra.db.memtable.AbstractMemtable.AbstractFlushablePartitionSet
- commitLogUpperBound() - Method in interface org.apache.cassandra.db.memtable.Memtable.FlushablePartitionSet
-
The commit log position at the time that this memtable was switched out
- CommitSerializer(BiFunction<Ballot, PartitionUpdate, T>) - Constructor for class org.apache.cassandra.service.paxos.Commit.CommitSerializer
- committed - Variable in class org.apache.cassandra.service.paxos.PaxosState.Snapshot
- Committed(Ballot, PartitionUpdate) - Constructor for class org.apache.cassandra.service.paxos.Commit.Committed
- Committed(Commit) - Constructor for class org.apache.cassandra.service.paxos.Commit.Committed
- COMMITTED - org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional.State
- CommittedWithTTL(Ballot, PartitionUpdate, long) - Constructor for class org.apache.cassandra.service.paxos.Commit.CommittedWithTTL
- CommittedWithTTL(Commit, long) - Constructor for class org.apache.cassandra.service.paxos.Commit.CommittedWithTTL
- commonRange - Variable in class org.apache.cassandra.repair.state.SessionState
- 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
- commonRanges - Variable in class org.apache.cassandra.repair.RepairCoordinator.NeighborsAndRanges
- commonSetup() - Method in class org.apache.cassandra.auth.AbstractCIDRAuthorizer
- Compact - Class in org.apache.cassandra.tools.nodetool
- Compact() - Constructor for class org.apache.cassandra.tools.nodetool.Compact
- COMPACT_COLUMN_IN_COMPACT_STORAGE - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- compact_tables_enabled - Variable in class org.apache.cassandra.config.Config
- 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 - Variable in class org.apache.cassandra.schema.TableParams
- 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 - org.apache.cassandra.db.compaction.OperationType
- COMPACTION - org.apache.cassandra.index.transactions.IndexTransaction.Type
- COMPACTION - org.apache.cassandra.io.sstable.metadata.MetadataType
-
Metadata only used at compaction
- COMPACTION - org.apache.cassandra.schema.TableParams.Option
- 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_throughput - Variable in class org.apache.cassandra.config.Config
- COMPACTION_TYPE_PROPERTY - Static variable in class org.apache.cassandra.db.compaction.CompactionHistoryTabularData
- 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, long) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
- CompactionController(ColumnFamilyStore, Set<SSTableReader>, long) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
- CompactionController(ColumnFamilyStore, Set<SSTableReader>, long, RateLimiter, CompactionParams.TombstoneOption) - Constructor for class org.apache.cassandra.db.compaction.CompactionController
- compactionCount - Variable in class org.apache.cassandra.index.sai.metrics.IndexMetrics
- 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, CompactionInfo.Unit, TimeUUID, Collection<? extends SSTableReader>, String) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
- CompactionInfo(TableMetadata, OperationType, long, long, TimeUUID, Collection<? extends SSTableReader>) - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo
- CompactionInfo(TableMetadata, OperationType, long, long, TimeUUID, Collection<SSTableReader>, String) - 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(Object) - 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, long, TimeUUID) - Constructor for class org.apache.cassandra.db.compaction.CompactionIterator
- CompactionIterator(OperationType, List<ISSTableScanner>, AbstractCompactionController, long, TimeUUID, ActiveCompactionsTracker, TopPartitionTracker.Collector) - Constructor for class org.apache.cassandra.db.compaction.CompactionIterator
- compactionLogger - Variable in class org.apache.cassandra.db.compaction.CompactionStrategyManager
- CompactionLogger - Class in org.apache.cassandra.db.compaction
- CompactionLogger(ColumnFamilyStore, CompactionStrategyManager) - Constructor for class org.apache.cassandra.db.compaction.CompactionLogger
- 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() - Method in interface org.apache.cassandra.repair.SharedContext
- compactionManager() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- compactionManager() - Method in class org.apache.cassandra.repair.SharedContext.Global
- 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() - Method in class org.apache.cassandra.io.sstable.format.StatsComponent
- 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(ExecutorPlus...) - 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
- compactionSegmentBytesPerSecond - Variable in class org.apache.cassandra.index.sai.metrics.IndexMetrics
- compactionSegmentCellsPerSecond - Variable in class org.apache.cassandra.index.sai.metrics.IndexMetrics
- 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, long) - Constructor for class org.apache.cassandra.db.compaction.CompactionTask
- CompactionTask(ColumnFamilyStore, LifecycleTransaction, long, 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
- CompactionVectorValues - Class in org.apache.cassandra.index.sai.disk.v1.vector
- CompactionVectorValues(VectorType<Float>) - Constructor for class org.apache.cassandra.index.sai.disk.v1.vector.CompactionVectorValues
- CompactTableMetadata(TableMetadata.Builder) - Constructor for class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
- compactTablesEnabled - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail disabling the creation of new COMPACT STORAGE tables
- compactValueColumn - Variable in class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
- Comparables - Class in org.apache.cassandra.utils
-
Utility methods linked to comparing comparable values.
- Comparables() - Constructor for class org.apache.cassandra.utils.Comparables
- 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 - 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 - Variable in class org.apache.cassandra.schema.TableMetadata
- comparator - Variable in class org.apache.cassandra.utils.btree.BTreeSet
- comparator() - Method in class org.apache.cassandra.db.CBuilder
- comparator() - Method in class org.apache.cassandra.db.RangeTombstoneList
- comparator() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
- comparator() - Method in class org.apache.cassandra.index.sasi.utils.trie.PatriciaTrie
- comparator() - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
- comparator() - Method in class org.apache.cassandra.utils.btree.BTreeSet
- COMPARATOR - Static variable in class org.apache.cassandra.index.sai.disk.SSTableIndex
- COMPARATOR - Static variable in class org.apache.cassandra.io.sstable.SSTableIdFactory
-
Compare sstable identifiers so that UUID based identifier is always greater than sequence based identifier
- comparatorSet - Variable in class org.apache.cassandra.db.marshal.AbstractType
- compare(byte[], byte[]) - Method in interface org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeReader.IntersectVisitor
-
Called for non-leaf cells to test how the cell relates to the query, to determine how to further recurse down the tree.
- compare(byte[], int, int, byte[], int, int) - 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(byte[], int, int, byte[], int, int) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
- compare(byte[], ByteBuffer) - 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[], V2, ValueAccessor<V2>) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- compare(int, int) - Static method in class org.apache.cassandra.utils.CassandraUInt
-
Compare 2 Uints
- compare(long, long) - Method in class org.apache.cassandra.db.guardrails.MaxThreshold
- compare(long, long) - Method in class org.apache.cassandra.db.guardrails.MinThreshold
- compare(long, long) - Method in class org.apache.cassandra.db.guardrails.Threshold
- compare(long, long) - Method in interface org.apache.cassandra.utils.LongTimSort.LongComparator
- compare(ByteBuffer, byte[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- compare(ByteBuffer, byte[], int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
- compare(ByteBuffer, 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.UnsafeOperations
- compare(ByteBuffer, int, int, byte[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- compare(ByteBuffer, int, int, byte[], int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
- compare(ByteBuffer, 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.UnsafeOperations
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Compare two terms based on their type.
- compare(ByteBuffer, ByteBuffer) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
- compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
- compare(ByteBuffer, V2, ValueAccessor<V2>) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- compare(L, ValueAccessor<L>, R, ValueAccessor<R>) - Static method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
lexicographically compare {@param left} to {@param right}
- 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(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(ClusteringPrefix<V1>, ClusteringPrefix<V2>) - Method in class org.apache.cassandra.db.ClusteringComparator
- compare(UserType) - Method in class org.apache.cassandra.db.marshal.UserType
- compare(File, File) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment.CommitLogSegmentFileComparator
- compare(StatsTable, StatsTable) - Method in class org.apache.cassandra.tools.nodetool.stats.StatsTableComparator
-
Compare StatsTable instances based on this instance's sortKey.
- compare(ByteComparable, ByteComparable, ByteComparable.Version) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteComparable
-
Compare two byte-comparable values by their byte-comparable representation.
- compare(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.AbstractType
- compare(V, VR, ValueAccessor<VR>) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
lexicographically compare {@param left} to {@param right}
- compareAndSet(O, T, T) - Method in interface org.apache.cassandra.utils.concurrent.IntrusiveStack.Setter
- compareAsymmetric(T1, T2) - Method in class org.apache.cassandra.utils.AsymmetricOrdering
- compareByDensity(SSTableReader, SSTableReader) - Method in interface org.apache.cassandra.db.compaction.ShardManager
- 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 {@param
} 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 {@param
} 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, ClusteringPrefix<V1>, ClusteringPrefix<V2>) - Method in class org.apache.cassandra.db.ClusteringComparator
- compareComponent(int, V1, ValueAccessor<V1>, V2, ValueAccessor<V2>) - Method in class org.apache.cassandra.db.ClusteringComparator
- 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.AbstractCompositeType
- compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- 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.DynamicCompositeType.FixedValueComparator
- 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(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.TupleType
- compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.UUIDType
- compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.VectorType
- compareCustom(VL, ValueAccessor<VL>, VR, ValueAccessor<VR>) - Method in class org.apache.cassandra.db.marshal.VectorType.VectorSerializer
- 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
- compareIPs(InetAddress, InetAddress) - Static method in class org.apache.cassandra.cql3.CIDR
-
Compare 2 IpAddresses objects lexicographically
- 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(ClusteringBound<?>) - Method in class org.apache.cassandra.db.UnfilteredDeserializer
-
Compare the provided bound to the next atom to read on disk.
- compareNextTo(ClusteringBoundOrBoundary<T>) - Method in class org.apache.cassandra.db.ClusteringPrefix.Deserializer
- comparePageTo(long, int, AbstractType<?>, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
- comparePostFilter(Expression.Value, Expression.Value) - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
This is used for value comparison in post-filtering -
Expression.isSatisfiedBy(ByteBuffer)
. - compareSubArrays(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Compare two ByteBuffer at specified offsets for length.
- compareTo(Object, long, int, Object, long, int) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
-
Lexicographically compare two arrays.
- compareTo(Object, long, int, ByteBuffer) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
- compareTo(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
- compareTo(Delayed) - Method in class org.apache.cassandra.utils.concurrent.NotScheduledFuture
- 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(CommitLogPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogPosition
- compareTo(AbstractStrategyHolder.TaskSupplier) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder.TaskSupplier
- compareTo(DeletionTime) - Method in class org.apache.cassandra.db.DeletionTime
- compareTo(ColumnSubselection) - Method in class org.apache.cassandra.db.filter.ColumnSubselection
- 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(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(Memtable) - Method in interface org.apache.cassandra.db.memtable.Memtable
-
Order memtables by time as reflected in the commit log position at time of construction
- compareTo(PartitionPosition) - Method in class org.apache.cassandra.db.DecoratedKey
- compareTo(PartitionPosition) - Method in class org.apache.cassandra.dht.Token.KeyBound
- compareTo(AbstractMutableVirtualTable.ColumnValues) - Method in class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable.ColumnValues
- compareTo(IPartitioner, ByteBuffer, PartitionPosition) - Static method in class org.apache.cassandra.db.DecoratedKey
- compareTo(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
Note: this class has a natural ordering that is inconsistent with equals
- 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(GossipDigest) - Method in class org.apache.cassandra.gms.GossipDigest
- compareTo(VersionedValue) - Method in class org.apache.cassandra.gms.VersionedValue
- compareTo(Index.QueryPlan) - Method in interface org.apache.cassandra.index.Index.QueryPlan
- compareTo(Version) - Method in class org.apache.cassandra.index.sai.disk.format.Version
- compareTo(RangeTermTree.Term) - Method in class org.apache.cassandra.index.sai.view.RangeTermTree.Term
- 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(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(SequenceBasedSSTableId) - Method in class org.apache.cassandra.io.sstable.SequenceBasedSSTableId
- compareTo(SSTableIdentityIterator) - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
- compareTo(UUIDBasedSSTableId) - Method in class org.apache.cassandra.io.sstable.UUIDBasedSSTableId
- compareTo(File) - Method in class org.apache.cassandra.io.util.File
- 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(TopPartitionTracker.TopPartition) - Method in class org.apache.cassandra.metrics.TopPartitionTracker.TopPartition
- 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(CassandraVersion, boolean) - 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(MergeIterator.Candidate<In>) - Method in class org.apache.cassandra.utils.MergeIterator.Candidate
- compareTo(TimeUUID) - Method in class org.apache.cassandra.utils.TimeUUID
- compareToStrict(PrimaryKey) - Method in interface org.apache.cassandra.index.sai.utils.PrimaryKey
- compareUnsigned(byte[], byte[]) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- compareUnsigned(byte[], byte[]) - Static method in class org.apache.cassandra.utils.FastByteOperations
- compareUnsigned(byte[], byte[]) - Static method in class org.apache.cassandra.utils.FBUtilities
- compareUnsigned(byte[], byte[], int, int, int, int) - Static method in class org.apache.cassandra.utils.FBUtilities
- compareUnsigned(byte[], int, byte[], int, int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- compareUnsigned(byte[], int, int, byte[], int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
-
Lexicographically compare two byte arrays.
- compareUnsigned(byte[], int, int, ByteBuffer) - 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, byte[], int, int) - 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(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- compareUnsigned(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.FastByteOperations
- compareWith(Commit) - Method in class org.apache.cassandra.service.paxos.Commit
- 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
- Completable<I> - Interface in org.apache.cassandra.repair.state
- Completable.Result - Class in org.apache.cassandra.repair.state
- Completable.Result.Kind - Enum in org.apache.cassandra.repair.state
- 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 interface org.apache.cassandra.db.tries.Trie.ValueConsumer
- complete() - Method in interface org.apache.cassandra.db.tries.Trie.Walker
-
Called at the completion of the walk.
- complete() - Method in interface org.apache.cassandra.index.sai.disk.PerSSTableIndexWriter
- complete() - Method in class org.apache.cassandra.index.sai.disk.RowMapping
-
Complete building in memory RowMapping, mark it as immutable.
- complete() - Method in class org.apache.cassandra.index.sai.disk.StorageAttachedIndexWriter
- complete() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.PostingsWriter
-
write footer to the postings
- complete() - Method in class org.apache.cassandra.index.sai.disk.v1.SSTableComponentsWriter
- complete() - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
- complete() - Method in class org.apache.cassandra.index.sasi.plan.Operation.Builder
- complete() - Method in interface org.apache.cassandra.io.sstable.SSTableFlushObserver
-
Called when all data is written to the file and it's ready to be finished up.
- complete() - Method in interface org.apache.cassandra.io.tries.IncrementalTrieWriter
-
Complete the process and return the position in the file of the root node.
- complete() - Method in class org.apache.cassandra.io.tries.IncrementalTrieWriterBase
- complete() - Method in class org.apache.cassandra.io.util.FileHandle.Builder
-
Complete building
FileHandle
. - 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() - Method in class org.apache.cassandra.tools.nodetool.formatter.TableBuilder.SharedTable
- complete(int) - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
Received ACK for stream at
sequenceNumber
. - complete(Stopwatch) - Method in interface org.apache.cassandra.index.sai.disk.PerColumnIndexWriter
-
Builds on-disk index data structures from accumulated data, moves them all to the filesystem, and fsync created files.
- complete(Stopwatch) - Method in class org.apache.cassandra.index.sai.disk.v1.MemtableIndexWriter
- complete(Stopwatch) - Method in class org.apache.cassandra.index.sai.disk.v1.SSTableIndexWriter
- complete(Function<File, ChannelProxy>) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
- complete(IncrementalTrieWriterSimple.Node<VALUE>) - Method in class org.apache.cassandra.io.tries.IncrementalTrieWriterSimple
- complete(CountDownLatch) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
- complete(MutableLong) - Method in class org.apache.cassandra.index.sai.disk.v1.trie.TrieTermsDictionaryWriter
-
complete trie index and write footer
- COMPLETE - org.apache.cassandra.streaming.messages.StreamMessage.Type
- COMPLETE - org.apache.cassandra.streaming.StreamSession.State
- COMPLETE - org.apache.cassandra.utils.progress.ProgressEventType
-
Fire when progress complete.
- COMPLETE - Static variable in class org.apache.cassandra.repair.state.AbstractState
- COMPLETED - org.apache.cassandra.db.monitoring.MonitoringState
- COMPLETED - org.apache.cassandra.db.SystemKeyspace.BootstrapState
- COMPLETED - org.apache.cassandra.repair.state.AbstractCompletable.Status
- COMPLETED - org.apache.cassandra.service.ActiveRepairService.ParentRepairStatus
- 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.
- completeInitialization() - Method in class org.apache.cassandra.service.StorageService
- completeLast() - Method in class org.apache.cassandra.io.tries.IncrementalTrieWriterBase
- completeMessage() - Method in class org.apache.cassandra.streaming.StreamingState
- 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_METADATA - Static variable in class org.apache.cassandra.index.sai.virtual.SegmentsSystemView
- Component.Type - Class 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
- componentFromFile(File) - Static method in class org.apache.cassandra.io.sstable.Descriptor
- 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
- ComponentMetadataMap() - Constructor for class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata.ComponentMetadataMap
- componentMetadatas - Variable in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata
-
Root, offset, length for each index structure in the segment.
- componentName(IndexComponent) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- components - Variable in class org.apache.cassandra.io.sstable.format.SortedTableWriter.AbstractIndexWriter
- components - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderLoadingBuilder
- components - Variable in class org.apache.cassandra.io.sstable.SSTable
- components() - Method in class org.apache.cassandra.db.streaming.ComponentManifest
- Components() - Constructor for class org.apache.cassandra.io.sstable.format.big.BigFormat.Components
- Components() - Constructor for class org.apache.cassandra.io.sstable.format.bti.BtiFormat.Components
- Components() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableFormat.Components
- componentSpecOf(ColumnSpecification, int) - Static method in class org.apache.cassandra.cql3.Tuples
- compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
- compose(ProtocolVersion, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.UDFDataType
-
Deserializes the specified oject.
- 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.DynamicCompositeType.FixedValueComparator
- compose(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
- composeAsFloat(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.VectorType
- composeAsFloat(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.VectorType
- composeValue(Cell<V>, AbstractType<T>) - Static method in class org.apache.cassandra.db.rows.Cells
- COMPOSITE_TYPE - Static variable in class org.apache.cassandra.audit.AuditLogOptionsCompositeData
- 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
- COMPOSITES - org.apache.cassandra.schema.IndexMetadata.Kind
- 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
- CompositeType.Serializer - Class in org.apache.cassandra.db.marshal
- COMPOUND - org.apache.cassandra.schema.TableMetadata.Flag
- 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 - org.apache.cassandra.transport.Envelope.Header.Flag
- COMPRESSED_BLOCK_HEADER_SIZE - Static variable in class org.apache.cassandra.security.EncryptionUtils
- COMPRESSED_VECTORS - org.apache.cassandra.index.sai.disk.format.IndexComponent
-
Product Quantization store used to store compressed vectors for the vector index
- 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, Supplier<Double>) - 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.
- CompressedSegment.CompressedSegmentBuilder - Class in org.apache.cassandra.db.commitlog
- CompressedSegmentBuilder(AbstractCommitLogSegmentManager) - Constructor for class org.apache.cassandra.db.commitlog.CompressedSegment.CompressedSegmentBuilder
- CompressedSequentialWriter - Class in org.apache.cassandra.io.compress
- CompressedSequentialWriter(File, File, 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
- compressedVectors() - Method in class org.apache.cassandra.index.sai.disk.v1.PerColumnIndexFiles
- compression - Variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
- compression - Variable in class org.apache.cassandra.io.sstable.SSTable
- compression - Variable in class org.apache.cassandra.schema.TableParams
- compression - Variable in class org.apache.cassandra.transport.SimpleClient
- compression(CompressionParams) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- compression(CompressionParams) - Method in class org.apache.cassandra.schema.TableParams.Builder
- COMPRESSION - org.apache.cassandra.schema.TableParams.Option
- COMPRESSION - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
- COMPRESSION_INFO - Static variable in class org.apache.cassandra.io.sstable.format.SSTableFormat.Components
- COMPRESSION_INFO - Static variable in class org.apache.cassandra.io.sstable.format.SSTableFormat.Components.Types
- 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
- CompressionInfoComponent - Class in org.apache.cassandra.io.sstable.format
- CompressionInfoComponent() - Constructor for class org.apache.cassandra.io.sstable.format.CompressionInfoComponent
- compressionMetadata() - Method in class org.apache.cassandra.io.util.FileHandle
- CompressionMetadata - Class in org.apache.cassandra.io.compress
-
Holds metadata about compressed file TODO extract interface ICompressionMetadata which will just provide non-resource properties
- CompressionMetadata(File, CompressionParams, Memory, long, long, long) - Constructor for class org.apache.cassandra.io.compress.CompressionMetadata
- 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, int, int, Map<String, String>) - Constructor for class org.apache.cassandra.schema.CompressionParams
- CompressionParams(String, Map<String, String>, int, double) - 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(byte[]) - Static method in class org.apache.cassandra.utils.MD5Digest
- compute(String) - Static method in class org.apache.cassandra.utils.MD5Digest
- compute(ProtocolVersion) - Method in interface org.apache.cassandra.cql3.functions.AggregateFunction.Aggregate
-
Computes and returns the aggregate current value.
- 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
- computeDeadline(long) - Method in class org.apache.cassandra.transport.Dispatcher.RequestTime
-
Given the current time and a base timeout for the verb return a request's expiration deadline, the time at which it becomes eligible for load shedding.
- computeExpireTime() - Static method in class org.apache.cassandra.gms.Gossiper
- computeLocalExpirationTime(long, int) - Static method in class org.apache.cassandra.db.ExpirationDateOverflowHandling
-
This method computes the
Cell.localDeletionTime()
, maybe capping to the maximum representable value which isCell.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.sai.disk.IndexSearchResultIterator
- computeNext() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.PostingListRangeIterator
- computeNext() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeConcatIterator
- computeNext() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIntersectionIterator
- computeNext() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeListIterator
- computeNext() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeOrderingIterator
- computeNext() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeUnionIterator
- computeNext() - Method in class org.apache.cassandra.index.sai.memory.FilteringInMemoryKeyRangeIterator
- computeNext() - Method in class org.apache.cassandra.index.sai.memory.InMemoryKeyRangeIterator
- 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.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.AbstractSSTableIterator.ForwardReader
- computeNext() - Method in class org.apache.cassandra.io.sstable.format.SSTableScanner.BaseKeyScanningIterator
- computeNext() - Method in class org.apache.cassandra.io.sstable.KeyIterator
- computeNext() - Method in class org.apache.cassandra.service.reads.range.RangeCommandIterator
- computeNext() - Method in class org.apache.cassandra.utils.AbstractGuavaIterator
-
Returns the next element.
- 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
- computeNextKey() - Method in class org.apache.cassandra.index.sai.memory.InMemoryKeyRangeIterator
- computeRowIds(Function<T, Integer>) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.VectorPostings
-
Compute the rowIds corresponding to the
<T>
keys in this postings list. - computeShouldStreamEntireSSTables() - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
- computeSizeOnDiskBytes() - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
- 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.
- computeTimeout(long, long) - Method in class org.apache.cassandra.transport.Dispatcher.RequestTime
- computeTrueSizeBytes() - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
- 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.
- 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
- 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.
- computeWaitTime(int) - Method in interface org.apache.cassandra.utils.Backoff
- computeWaitTime(int) - Method in class org.apache.cassandra.utils.Backoff.ExponentialBackoff
- computeWaitTime(int) - Method in enum org.apache.cassandra.utils.Backoff.None
- 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(String, String) - Method in class org.apache.cassandra.db.marshal.StringType
- 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(Unfiltered, UnfilteredRowIterator) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
-
Returns an iterator that concatenate the specified atom with the iterator.
- concat(UnfilteredRowIterator, UnfilteredRowIterator) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
-
Returns an iterator that concatenate two atom iterators.
- 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_index_builders - 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_merkle_tree_requests - Variable in class org.apache.cassandra.config.Config
- concurrent_reads - Variable in class org.apache.cassandra.config.Config
- 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
- concurrentHashMapRamUsed(int) - Static method in class org.apache.cassandra.index.sai.disk.v1.vector.RamEstimation
- ConcurrentVectorValues - Class in org.apache.cassandra.index.sai.disk.v1.vector
- ConcurrentVectorValues(int) - Constructor for class org.apache.cassandra.index.sai.disk.v1.vector.ConcurrentVectorValues
- condition - Variable in class org.apache.cassandra.service.TruncateResponseHandler
- condition(ColumnMetadata, FieldIdentifier, Operator, Terms) - Static method in class org.apache.cassandra.cql3.conditions.ColumnCondition
-
A UDT column, simple condition.
- 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 - Interface in org.apache.cassandra.utils.concurrent
-
Simpler API than java.util.concurrent.Condition; would be nice to extend it, but also nice to share API with Future, for which Netty's API is incompatible with java.util.concurrent.Condition
Awaitable
for explicit external signals. - Condition.Async - Class in org.apache.cassandra.utils.concurrent
-
An asynchronous
Condition
. - Condition.Sync - Class in org.apache.cassandra.utils.concurrent
-
A
Condition
based on its object monitor. - ConditionAsConsumer<T> - Interface in org.apache.cassandra.utils.concurrent
- ConditionAsConsumer.Async<T> - Class in org.apache.cassandra.utils.concurrent
- 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.
- 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_ALLOW_SYSTEM_PROPERTIES - org.apache.cassandra.config.CassandraRelevantProperties
-
Defaults to false for 4.1 but plan to switch to true in a later release the thinking is that environments may not work right off the bat so safer to add this feature disabled by default
- CONFIG_ERROR - org.apache.cassandra.exceptions.ExceptionCode
- CONFIG_LOADER - org.apache.cassandra.config.CassandraRelevantProperties
- CONFIG_PATH - Static variable in class org.apache.cassandra.tools.LoaderOptions
- CONFIG_PROVIDER - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
- 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.CQLStartTime - Enum in org.apache.cassandra.config
-
Which timestamp should be used to represent a base for replica-side timeouts.
- 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.MemtableOptions - Class in org.apache.cassandra.config
- Config.PaxosOnLinearizabilityViolation - Enum in org.apache.cassandra.config
-
A safety mechanism for detecting incorrect paxos state, that may be down either to a bug or incorrect usage of LWTs (most likely due to unsafe mixing of SERIAL and LOCAL_SERIAL operations), and rejecting
- Config.PaxosStatePurging - Enum in org.apache.cassandra.config
-
Select the kind of paxos state purging to use.
- Config.PaxosVariant - Enum in org.apache.cassandra.config
-
The variants of paxos implementation and semantics supported by Cassandra.
- Config.RepairCommandPoolFullStrategy - Enum in org.apache.cassandra.config
- Config.SSTableConfig - Class in org.apache.cassandra.config
- Config.UserFunctionTimeoutPolicy - Enum in org.apache.cassandra.config
- configOptions - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
- Configuration(ParameterizedClass, EncryptionContext, Config.DiskAccessMode) - Constructor for class org.apache.cassandra.db.commitlog.CommitLog.Configuration
- CONFIGURATION - Static variable in class org.apache.cassandra.db.memtable.SkipListMemtableFactory
- 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
- configurationKey() - Method in class org.apache.cassandra.schema.MemtableParams
- ConfigurationLoader - Interface in org.apache.cassandra.config
- configurations - Variable in class org.apache.cassandra.config.Config.MemtableOptions
- 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
- configurePooled(String, int) - Method in interface org.apache.cassandra.concurrent.ExecutorBuilderFactory
-
Configure a pooled executor with the requested number of threads
- configurePooled(String, int) - Method in class org.apache.cassandra.concurrent.ExecutorFactory.Default
- configureSequential(String) - Method in interface org.apache.cassandra.concurrent.ExecutorBuilderFactory
-
Configure a sequential (single threaded) executor
- configureSequential(String) - Method in class org.apache.cassandra.concurrent.ExecutorFactory.Default
- 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() - 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
- connect(OutboundConnectionSettings, int, StreamingChannel.Kind) - Static method in class org.apache.cassandra.streaming.async.NettyStreamingConnectionFactory
- connect(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamCoordinator
- connected() - Method in class org.apache.cassandra.streaming.async.NettyStreamingChannel
- connected() - Method in class org.apache.cassandra.streaming.async.StreamingMultiplexedChannel
- connected() - Method in interface org.apache.cassandra.streaming.StreamingChannel
- ConnectedClient - Class in org.apache.cassandra.transport
- connectedTo() - Method in class org.apache.cassandra.streaming.async.NettyStreamingChannel
- connectedTo() - Method in class org.apache.cassandra.streaming.async.StreamingMultiplexedChannel
- connectedTo() - Method in interface org.apache.cassandra.streaming.StreamingChannel
- connecting - Variable in class org.apache.cassandra.streaming.SessionInfo
- connection - Variable in class org.apache.cassandra.transport.Message
- connection - Variable in class org.apache.cassandra.transport.SimpleClient
- connection() - Method in class org.apache.cassandra.transport.Message
- Connection - Class in org.apache.cassandra.transport
- Connection(Channel, ProtocolVersion, Connection.Tracker) - Constructor for class org.apache.cassandra.transport.Connection
- 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(StreamingChannel.Factory) - 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
- 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 - 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
- consistency() - Method in class org.apache.cassandra.db.CounterMutation
- consistency(Ballot) - Static method in class org.apache.cassandra.service.paxos.Paxos
- consistencyForRoleRead(String) - Static method in class org.apache.cassandra.auth.CassandraRoleManager
- consistencyForRoleWrite(String) - Static method in class org.apache.cassandra.auth.CassandraRoleManager
-
Allows selective overriding of the consistency level for specific roles.
- consistencyLevel - Variable in class org.apache.cassandra.locator.ReplicaPlan.AbstractReplicaPlan
- consistencyLevel() - Method in class org.apache.cassandra.locator.ReplicaPlan.AbstractReplicaPlan
- consistencyLevel() - Method in interface org.apache.cassandra.locator.ReplicaPlan
- consistencyLevel() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
- ConsistencyLevel - Enum in org.apache.cassandra.db
- consistent - Variable in class org.apache.cassandra.service.ActiveRepairService
- CONSISTENT_DIRECTORY_LISTINGS - org.apache.cassandra.config.CassandraRelevantProperties
- CONSISTENT_RANGE_MOVEMENT - org.apache.cassandra.config.CassandraRelevantProperties
- CONSISTENT_SIMULTANEOUS_MOVES_ALLOW - org.apache.cassandra.config.CassandraRelevantProperties
- ConsistentSession - Class in org.apache.cassandra.repair.consistent
-
Base class for consistent Local and Coordinator sessions
- ConsistentSession.State - Enum in org.apache.cassandra.repair.consistent
-
The possible states of a
ConsistentSession
. - ConsistentSessions(SharedContext) - Constructor for class org.apache.cassandra.service.ActiveRepairService.ConsistentSessions
- console - org.apache.cassandra.tools.JMXTool.Dump.Format
- 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(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.
- construct(ColumnFamilyStore, ILifecycleTransaction, boolean, long) - Static method in class org.apache.cassandra.io.sstable.SSTableRewriter
- construct(CommitLog, UUID) - Static method in class org.apache.cassandra.db.commitlog.CommitLogReplayer
- CONSTRUCTION_BEAM_WIDTH - Static variable in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- constructKeepingOriginals(ILifecycleTransaction, boolean, long) - Static method in class org.apache.cassandra.io.sstable.SSTableRewriter
- constructOverlapSets(List<E>, BiPredicate<E, E>, Comparator<E>, Comparator<E>) - Static method in class org.apache.cassandra.utils.Overlaps
-
Construct a minimal list of overlap sets, i.e.
- constructTokenFromProperties(Map<String, Object>) - Method in class org.apache.cassandra.service.FileSystemOwnershipCheck
-
In version 1, we check and return the ownership token.
- 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() - Method in class org.apache.cassandra.net.FrameDecoder.IntactFrame
- consume(long, int) - Method in interface org.apache.cassandra.utils.streamhist.HistogramDataConsumer
- 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(MergeIterator.Reducer<In, Out>) - Method in class org.apache.cassandra.utils.MergeIterator.Candidate
- 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(Optional<List<RepairSessionResult>>) - Method in class org.apache.cassandra.repair.consistent.SyncStatSummary
- contacts() - Method in class org.apache.cassandra.locator.ReplicaPlan.AbstractReplicaPlan
- contacts() - Method in interface org.apache.cassandra.locator.ReplicaPlan
- contained(List<SSTableReader.PartitionPositionBounds>, SSTableReader) - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
- contains(byte[]) - Method in interface org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeReader.IntersectVisitor
-
Called for all values in a leaf cell that crosses the query.
- contains(Object) - Method in class org.apache.cassandra.utils.btree.BTreeSet
- contains(Object) - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- contains(Object) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
- contains(String) - Method in class org.apache.cassandra.cql3.functions.types.UserType
-
Returns whether this UDT contains a given field.
- contains(String) - Method in class org.apache.cassandra.db.view.TableViews
- contains(String) - Method in class org.apache.cassandra.locator.SnitchProperties
- contains(InetAddress) - Method in class org.apache.cassandra.config.SubnetGroups
- contains(SocketAddress) - Method in class org.apache.cassandra.config.SubnetGroups
- contains(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Check is the given buffer contains a given sub-buffer.
- contains(TupleType) - Method in class org.apache.cassandra.cql3.functions.types.TupleType
-
Return
true
if this tuple type contains the given tuple type, andfalse
otherwise. - 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(PartitionPosition) - Method in class org.apache.cassandra.db.DataRange
-
Whether the provided ring position is covered by this
DataRange
. - contains(Range<Token>) - Method in class org.apache.cassandra.locator.Replica
- contains(Range<Token>, boolean) - Method in class org.apache.cassandra.locator.RangesAtEndpoint
- contains(Range<T>) - Method in class org.apache.cassandra.dht.Range
- contains(InetAddressAndPort) - Method in class org.apache.cassandra.locator.Endpoints
- contains(Replica) - Method in class org.apache.cassandra.locator.Endpoints
- contains(Replica) - Method in class org.apache.cassandra.locator.RangesAtEndpoint
- contains(Replica) - Method in interface org.apache.cassandra.locator.ReplicaCollection
- contains(INotificationConsumer) - Method in class org.apache.cassandra.db.lifecycle.Tracker
- contains(ColumnMetadata) - Method in class org.apache.cassandra.db.Columns
-
Whether the provided column is contained by this object.
- contains(ColumnMetadata) - Method in class org.apache.cassandra.db.RegularAndStaticColumns
- contains(T) - Method in class org.apache.cassandra.db.commitlog.IntervalSet
- 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) - 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(T, T, T) - Static method in class org.apache.cassandra.dht.Range
- CONTAINS - org.apache.cassandra.cql3.Operator
- CONTAINS - org.apache.cassandra.db.commitlog.CommitLogSegment.CDCState
- CONTAINS - org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.Mode
- CONTAINS - org.apache.cassandra.index.sasi.plan.Expression.Op
- CONTAINS_KEY - org.apache.cassandra.cql3.Operator
- CONTAINS_KEY - org.apache.cassandra.index.sai.plan.Expression.IndexOperator
- CONTAINS_VALUE - org.apache.cassandra.index.sai.plan.Expression.IndexOperator
- 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.BlockingQueues.Sync
- 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
- containsBindMarker() - Method in class org.apache.cassandra.cql3.Vectors.DelayedValue
- containsCachedParition(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- containsCustomExpressions() - Method in class org.apache.cassandra.cql3.WhereClause
- containsIndex(Index) - Method in interface org.apache.cassandra.index.Index.Group
-
Returns if this group contains the specified
Index
. - containsIndex(Index) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- containsIndex(Index) - Method in class org.apache.cassandra.index.SingletonIndexGroup
- 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
- 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
- containsKeyspace(String) - Method in class org.apache.cassandra.schema.Keyspaces
- containsNull - Variable in class org.apache.cassandra.db.MultiCBuilder
-
true
if the clusterings contains somenull
elements. - containsNull() - Method in class org.apache.cassandra.db.MultiCBuilder
-
Checks if the clusterings contains null elements.
- containsNulls() - Method in interface org.apache.cassandra.cql3.functions.Arguments
-
Checks if at least one of the arguments is null.
- containsNulls() - Method in class org.apache.cassandra.cql3.functions.FunctionArguments
- 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
- containsShadowedPrimaryKey(PrimaryKey) - Method in class org.apache.cassandra.index.sai.VectorQueryContext
- 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
- containsSSTable(SSTableReader) - Method in class org.apache.cassandra.index.sai.view.View
- 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 someunset
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
- contendedPuts - Variable in class org.apache.cassandra.metrics.TrieMemtableMetricsView
- content - Variable in class org.apache.cassandra.index.sasi.Term
- content() - Method in interface org.apache.cassandra.db.tries.Trie.Cursor
- content(T) - Method in interface org.apache.cassandra.db.tries.Trie.ValueConsumer
- content(T) - Method in interface org.apache.cassandra.db.tries.Trie.Walker
-
Called when content is found.
- content(T) - Method in class org.apache.cassandra.db.tries.TrieEntriesWalker
- content(T, byte[], int) - Method in class org.apache.cassandra.db.tries.TrieEntriesWalker
- contention - Variable in class org.apache.cassandra.metrics.CASClientRequestMetrics
- contentions - Variable in exception org.apache.cassandra.exceptions.CasWriteTimeoutException
- ContentionStrategy - Class in org.apache.cassandra.service.paxos
-
A strategy for making back-off decisions for Paxos operations that fail to make progress because of other paxos operations.
- ContentionStrategy(String, String, String, String, int) - Constructor for class org.apache.cassandra.service.paxos.ContentionStrategy
- ContentionStrategy.Type - Enum in org.apache.cassandra.service.paxos
- contentionTime - Variable in class org.apache.cassandra.metrics.TrieMemtableMetricsView
- 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.index.sai.disk.v1.segment.IndexSegmentSearcherContext
- contextClassLoader - Variable in class org.apache.cassandra.concurrent.NamedThreadFactory.MetaFactory
- CONTINUE - org.apache.cassandra.index.sasi.utils.trie.Cursor.Decision
-
Continue with the traverse operation
- CONTROL - org.apache.cassandra.streaming.StreamingChannel.Kind
- Controller - Class in org.apache.cassandra.db.compaction.unified
-
The controller provides compaction parameters to the unified compaction strategy
- convert(double, DataRateSpec.DataRateUnit) - Method in enum org.apache.cassandra.config.DataRateSpec.DataRateUnit
- convert(long, DataStorageSpec.DataStorageUnit) - Method in enum org.apache.cassandra.config.DataStorageSpec.DataStorageUnit
- convert(Object) - Method in enum org.apache.cassandra.config.Converters
- convert(String) - Method in interface org.apache.cassandra.config.CassandraRelevantProperties.PropertyConverter
- convert(CassandraRelevantProperties.PropertyConverter<T>) - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
- 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 {@param src} to {@param
} {@param src} 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 {@param src} - convert2Map() - Method in class org.apache.cassandra.tools.nodetool.stats.CompactionHistoryHolder
- convert2Map() - Method in class org.apache.cassandra.tools.nodetool.stats.DataPathsHolder
- 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
- convertArgument(long) - Method in class org.apache.cassandra.cql3.functions.TimeFcts.TemporalConversionFunction
- converter - Variable in class org.apache.cassandra.config.Replacement
-
Converter to be used according to the old default unit which was provided as a suffix of the configuration parameter
- converter() - Method in annotation type org.apache.cassandra.config.Replaces
- Converters - Enum in org.apache.cassandra.config
-
Converters for backward compatibility with the old cassandra.yaml where duration, data rate and data storage configuration parameters were provided only by value and the expected unit was part of the configuration parameter name(suffix).
- 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
- convertToString(Object) - Static method in enum org.apache.cassandra.config.CassandraRelevantProperties
- 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.
- convict(InetAddressAndPort, double) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupSession
- CONVICTED - org.apache.cassandra.gms.GossiperEvent.GossiperEventType
- coordinated - Variable in class org.apache.cassandra.service.ActiveRepairService.ConsistentSessions
- CoordinatedRepairResult - Class in org.apache.cassandra.repair
- CoordinatedRepairResult(Collection<Range<Token>>, Collection<Range<Token>>, Collection<Range<Token>>, List<RepairSessionResult>) - Constructor for class org.apache.cassandra.repair.CoordinatedRepairResult
- coordinator - Variable in class org.apache.cassandra.repair.AbstractRepairTask
- coordinator - Variable in class org.apache.cassandra.repair.consistent.ConsistentSession
- 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
- coordinator(TimeUUID) - Method in class org.apache.cassandra.service.ActiveRepairService
- COORDINATOR - Static variable in class org.apache.cassandra.repair.consistent.LocalSessionInfo
- coordinator_read_size_fail_threshold - Variable in class org.apache.cassandra.config.Config
- coordinator_read_size_warn_threshold - Variable in class org.apache.cassandra.config.Config
- coordinatorReadLatency - Variable in class org.apache.cassandra.metrics.TableMetrics
- coordinatorReadSize - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
- coordinatorReadSize - Variable in class org.apache.cassandra.metrics.TableMetrics
- coordinatorReadSizeAborts - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
- coordinatorReadSizeAborts - Variable in class org.apache.cassandra.metrics.TableMetrics
- coordinatorReadSizeWarnings - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
- coordinatorReadSizeWarnings - Variable in class org.apache.cassandra.metrics.TableMetrics
- coordinators() - Method in class org.apache.cassandra.service.ActiveRepairService
- 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(SharedContext) - Constructor for class org.apache.cassandra.repair.consistent.CoordinatorSessions
- CoordinatorState - Class in org.apache.cassandra.repair.state
- CoordinatorState(Clock, int, String, RepairOption) - Constructor for class org.apache.cassandra.repair.state.CoordinatorState
- CoordinatorState.Phase - Class in org.apache.cassandra.repair.state
- CoordinatorState.State - Enum in org.apache.cassandra.repair.state
- CoordinatorWarnings - Class in org.apache.cassandra.service.reads.thresholds
- coordinatorWriteLatency - Variable in class org.apache.cassandra.metrics.TableMetrics
- copy() - Method in class org.apache.cassandra.cql3.ResultSet.PreparedMetadata
- copy() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
- copy() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
- copy() - Method in class org.apache.cassandra.db.RangeTombstoneList
- copy() - Method in class org.apache.cassandra.db.ReadCommand
-
Returns a copy of this command.
- copy() - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
- copy() - Method in interface org.apache.cassandra.db.rows.Row.Builder
-
Creates a copy of this
Builder
. - copy() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
- copy() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.CompactionVectorValues
- copy() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.ConcurrentVectorValues
- copy() - Method in class org.apache.cassandra.schema.ColumnMetadata
- copy() - Method in class org.apache.cassandra.schema.CompressionParams
- copy() - Method in class org.apache.cassandra.utils.btree.BTree.Builder
-
Creates a copy of this
Builder
. - copy(boolean) - Method in class org.apache.cassandra.cql3.functions.types.UserType
- copy(byte[], int, byte[], 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(byte[], int, byte[], 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(byte[], int, ByteBuffer, int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
- copy(byte[], int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
- copy(byte[], int, ByteBuffer, 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.UnsafeOperations
- copy(long) - Method in class org.apache.cassandra.cache.RefCountedMemory
- copy(long) - Method in class org.apache.cassandra.io.util.Memory
- copy(long) - Method in class org.apache.cassandra.io.util.SafeMemory
- copy(InputStream, OutputStream, long) - Static method in class org.apache.cassandra.utils.FBUtilities
- 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(Object, long, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
- copy(ByteBuffer, int, byte[], int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
- copy(ByteBuffer, int, byte[], int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
- copy(ByteBuffer, int, 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.UnsafeOperations
- copy(ByteBuffer, int, ByteBuffer, int, int) - Method in interface org.apache.cassandra.utils.FastByteOperations.ByteOperations
- copy(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.FastByteOperations
- copy(ByteBuffer, 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.UnsafeOperations
- copy(SortedSet<? extends V>, Comparator<? super V>) - Static method in class org.apache.cassandra.utils.btree.BTreeSet
- copy(Range<Token>) - Method in class org.apache.cassandra.repair.asymmetric.StreamFromOptions
- copy(Descriptor, Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.SSTable
- copy(TableMetadata) - Method in class org.apache.cassandra.schema.ViewMetadata
- copyAsDigestQuery() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
- copyAsDigestQuery() - Method in class org.apache.cassandra.db.ReadCommand
- copyAsDigestQuery() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
- copyAsDigestQuery(Iterable<Replica>) - Method in class org.apache.cassandra.db.ReadCommand
-
Returns a copy of this command with isDigestQuery set to true.
- copyAsDigestQuery(Replica) - Method in class org.apache.cassandra.db.ReadCommand
-
Returns a copy of this command with isDigestQuery set to true.
- copyAsNewCollection(ByteBuffer, int, int, int) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
Creates a new serialized map composed from the data from
input
betweenstartPos
(inclusive) andendPos
(exclusive), assuming that data holdscount
elements. - copyAsTransientQuery() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
- copyAsTransientQuery() - Method in class org.apache.cassandra.db.ReadCommand
- copyAsTransientQuery() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
- copyAsTransientQuery(Iterable<Replica>) - Method in class org.apache.cassandra.db.ReadCommand
-
Returns a copy of this command with acceptsTransient set to true.
- copyAsTransientQuery(Replica) - Method in class org.apache.cassandra.db.ReadCommand
-
Returns a copy of this command with acceptsTransient set to true.
- 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
-
Transfer bytes from a ByteBuffer to byte array.
- copyBytes(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Transfer bytes from one ByteBuffer to another.
- copyBytes(ByteSource, byte[]) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
- copyBytes(DataInput, long) - Method in class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- copyEndpointStateForEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
- copyOf(Collection<Replica>) - Static method in class org.apache.cassandra.locator.EndpointsForRange
- copyOf(List<Replica>) - Static method in class org.apache.cassandra.locator.RangesAtEndpoint
- copyOf(Token, Collection<Replica>) - Static method in class org.apache.cassandra.locator.EndpointsForToken
- 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(CounterContext.ContextState) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
- copyTo(IndexOutput) - Method in class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- copyTo(V, int, V2, ValueAccessor<V2>, int, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
copy the {@param size} bytes from the {@param src} value, starting at the offset {@param srcOffset} into the {@param dst} value, starting at the offset {@param dstOffset}, using the accessor {@param dstAccessor}
- 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
- copyWithOutConfirm(File, File) - 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, 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
- 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
- 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, String) - Constructor for exception org.apache.cassandra.io.sstable.CorruptSSTableException
- CorruptSSTableException(Throwable, File) - Constructor for exception org.apache.cassandra.io.sstable.CorruptSSTableException
- count - Variable in class org.apache.cassandra.db.ClockAndCount
- count - Variable in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator.Builder.Statistics
- count - Variable in class org.apache.cassandra.metrics.Sampler.Sample
- count() - Method in class org.apache.cassandra.db.CBuilder
- count() - Method in class org.apache.cassandra.db.compaction.ShardManagerDiskAware.BoundaryTrackerDiskAware
- count() - Method in class org.apache.cassandra.db.compaction.ShardManagerNoDisks.BoundaryTracker
- count() - Method in interface org.apache.cassandra.db.compaction.ShardTracker
- count() - Method in class org.apache.cassandra.db.filter.DataLimits
-
The max number of results this limits enforces.
- count() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.IndexSegmentSearcherContext
- count() - Method in interface org.apache.cassandra.io.tries.IncrementalTrieWriter
-
Return the number of added entries.
- count() - Method in interface org.apache.cassandra.io.tries.IncrementalTrieWriter.PartialTail
-
Number of keys written
- count() - Method in class org.apache.cassandra.io.tries.IncrementalTrieWriterBase
- count() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics.DifferencingCounter
- count() - Method in class org.apache.cassandra.metrics.RestorableMeter
-
The total number of events that have occurred since this object was created.
- count() - Method in class org.apache.cassandra.net.InboundMessageHandlers
- count() - Method in class org.apache.cassandra.utils.concurrent.CountDownLatch.Async
- count() - Method in interface org.apache.cassandra.utils.concurrent.CountDownLatch
- count() - Method in class org.apache.cassandra.utils.concurrent.CountDownLatch.Sync
- count() - Method in class org.apache.cassandra.utils.EstimatedHistogram
- count(Predicate<? super Replica>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
- count(Predicate<? super Replica>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
- count(Predicate<? super Replica>) - Method in interface org.apache.cassandra.locator.ReplicaCollection
- 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
- CountDownLatch - Interface in org.apache.cassandra.utils.concurrent
- CountDownLatch.Async - Class in org.apache.cassandra.utils.concurrent
- CountDownLatch.Sync - Class in org.apache.cassandra.utils.concurrent
- 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(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
- counter(CassandraMetricsRegistry.MetricName, CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
- Counter(long, boolean, boolean) - Constructor for class org.apache.cassandra.db.filter.DataLimits.Counter
- COUNTER - org.apache.cassandra.cql3.CQL3Type.Native
- COUNTER - org.apache.cassandra.cql3.functions.types.DataType.Name
- COUNTER - org.apache.cassandra.cql3.statements.BatchStatement.Type
- COUNTER - org.apache.cassandra.db.WriteType
- COUNTER - org.apache.cassandra.schema.TableMetadata.Flag
- COUNTER - org.apache.cassandra.transport.DataType
- COUNTER_CACHE - org.apache.cassandra.service.CacheService.CacheType
- counter_cache_keys_to_save - Variable in class org.apache.cassandra.config.Config
- COUNTER_CACHE_SAVE - org.apache.cassandra.db.compaction.OperationType
- counter_cache_save_period - Variable in class org.apache.cassandra.config.Config
- counter_cache_size - Variable in class org.apache.cassandra.config.Config
- COUNTER_MUTATION - org.apache.cassandra.concurrent.Stage
- COUNTER_MUTATION_REQ - org.apache.cassandra.net.Verb
- COUNTER_MUTATION_RSP - org.apache.cassandra.net.Verb
- COUNTER_TABLES_NOT_SUPPORTED - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- counter_write_request_timeout - 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.
- countStreamedIn(boolean) - Method in class org.apache.cassandra.metrics.StreamingMetrics
- countStreamedIn(boolean) - Method in class org.apache.cassandra.streaming.StreamSession
- coveredClustering - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
- coveringRange(PartitionPosition, PartitionPosition) - Static method in interface org.apache.cassandra.db.compaction.ShardManager
- coveringRange(SSTableReader) - Static method in interface org.apache.cassandra.db.compaction.ShardManager
- coverInMap(ConcurrentMap<K, IntegerInterval>, K, int) - Static method in class org.apache.cassandra.db.commitlog.CommitLogSegment
- covers(int, int) - Method in class org.apache.cassandra.utils.IntegerInterval.Set
-
Returns true if the set completely covers the given interval.
- covers(IntegerInterval) - Method in class org.apache.cassandra.utils.IntegerInterval.Set
-
Returns true if the set completely covers the given interval.
- coversFullRing(AbstractBounds<PartitionPosition>) - Static method in class org.apache.cassandra.index.sai.utils.RangeUtil
- cpbProxy - Variable in class org.apache.cassandra.tools.NodeProbe
- CQL_GROUP_BY_LIMIT - org.apache.cassandra.db.filter.DataLimits.Kind
- CQL_GROUP_BY_PAGING_LIMIT - org.apache.cassandra.db.filter.DataLimits.Kind
- CQL_LIMIT - org.apache.cassandra.db.filter.DataLimits.Kind
- CQL_PAGING_LIMIT - org.apache.cassandra.db.filter.DataLimits.Kind
- cql_start_time - Variable in class org.apache.cassandra.config.Config
- CQL_VERSION - Static variable in class org.apache.cassandra.cql3.QueryProcessor
- CQL_VERSION - Static variable in class org.apache.cassandra.transport.messages.StartupMessage
- 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
- CQL3Type.Vector - Class in org.apache.cassandra.cql3
- 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
- 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
- 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 aMessage
wrapped in anEnvelope
. - CQLMetrics - Class in org.apache.cassandra.metrics
- CQLMetrics() - Constructor for class org.apache.cassandra.metrics.CQLMetrics
- 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
- CQLStatement.SingleKeyspaceCqlStatement - Interface in org.apache.cassandra.cql3
- CQLTypeParser - Class in org.apache.cassandra.schema
- CQLTypeParser() - Constructor for class org.apache.cassandra.schema.CQLTypeParser
- Crc - Class in org.apache.cassandra.net
- Crc() - Constructor for class org.apache.cassandra.net.Crc
- CRC - org.apache.cassandra.net.OutboundConnectionSettings.Framing
- CRC - Static variable in class org.apache.cassandra.io.sstable.format.SSTableFormat.Components
- CRC - Static variable in class org.apache.cassandra.io.sstable.format.SSTableFormat.Components.Types
- CRC_CHECK_CHANCE - org.apache.cassandra.schema.TableParams.Option
- Crc.InvalidCrc - Exception in org.apache.cassandra.net
- crc32() - Static method in class org.apache.cassandra.net.Crc
- CRC32 - org.apache.cassandra.utils.ChecksumType
- crcCheckChance - Variable in class org.apache.cassandra.schema.TableParams
- crcCheckChance(double) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- crcCheckChance(double) - Method in class org.apache.cassandra.schema.TableParams.Builder
- create() - Method in interface org.apache.cassandra.cache.CacheProvider
- create() - Method in class org.apache.cassandra.cache.NopCacheProvider
- create() - Method in class org.apache.cassandra.cache.OHCProvider
- create() - Method in class org.apache.cassandra.cache.SerializingCacheProvider
- create() - Method in interface org.apache.cassandra.index.sai.analyzer.AbstractAnalyzer.AnalyzerFactory
- create() - Static method in class org.apache.cassandra.locator.EndpointSnitchInfo
- create() - Static method in interface org.apache.cassandra.utils.MBeanWrapper
- create() - Method in class org.apache.cassandra.utils.memory.BufferPool
- create() - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
- create(boolean) - Static method in class org.apache.cassandra.db.filter.RowFilter
- create(boolean, Map<String, String>) - Static method in class org.apache.cassandra.schema.KeyspaceParams
- create(char, List<AbstractType<?>>, Exception) - Static method in exception org.apache.cassandra.exceptions.OperationExecutionException
-
Creates a new
OperationExecutionException
for the specified operation. - create(long) - Static method in class org.apache.cassandra.cache.CaffeineCache
- create(long, boolean) - Static method in class org.apache.cassandra.net.StartupClusterConnectivityChecker
- create(long, int, long) - Static method in class org.apache.cassandra.db.LivenessInfo
- create(long, long) - Static method in class org.apache.cassandra.db.ClockAndCount
- create(long, long) - Static method in class org.apache.cassandra.db.LivenessInfo
- create(long, long, DeletionTime, long, int, int, List<IndexInfo>, int[], ISerializer<IndexInfo>, Version) - Static method in class org.apache.cassandra.io.sstable.format.big.RowIndexEntry
- create(long, Weigher<K, RefCountedMemory>, ISerializer<V>) - Static method in class org.apache.cassandra.cache.SerializingCache
- create(long, Weigher<K, V>) - Static method in class org.apache.cassandra.cache.CaffeineCache
-
Initialize a cache with initial capacity with weightedCapacity
- create(long, ISerializer<V>) - Static method in class org.apache.cassandra.cache.SerializingCache
- 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(Class<? extends AbstractCompactionStrategy>, Map<String, String>) - Static method in class org.apache.cassandra.schema.CompactionParams
- 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(String, LoadingCache<K, V>, BiPredicate<K, V>) - Static method in class org.apache.cassandra.auth.CacheRefresher
- create(String, LoadingCache<K, V>, BiPredicate<K, V>, BooleanSupplier) - Static method in class org.apache.cassandra.auth.CacheRefresher
- create(String, String) - Static method in class org.apache.cassandra.schema.TriggerMetadata
- create(String, String, boolean, Class<? extends SSTableFormat<?, ?>>) - Static method in class org.apache.cassandra.io.sstable.Component.Type
-
Creates a new non-singleton type and registers it a global type registry - see
Component.Type.registerType(Type)
. - 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, UserFunctions) - Static method in class org.apache.cassandra.schema.KeyspaceMetadata
- create(String, MBeanWrapper.OnException) - Static method in interface org.apache.cassandra.utils.MBeanWrapper
- create(InetSocketAddress, int, StreamingChannel.Kind) - Method in class org.apache.cassandra.streaming.async.NettyStreamingConnectionFactory
- create(InetSocketAddress, int, StreamingChannel.Kind) - Method in interface org.apache.cassandra.streaming.StreamingChannel.Factory
- create(InetSocketAddress, int, StreamingChannel.Kind) - Method in class org.apache.cassandra.tools.BulkLoadConnectionFactory
- create(InetSocketAddress, InetSocketAddress, int, StreamingChannel.Kind) - Method in class org.apache.cassandra.streaming.async.NettyStreamingConnectionFactory
- create(InetSocketAddress, InetSocketAddress, int, StreamingChannel.Kind) - Method in interface org.apache.cassandra.streaming.StreamingChannel.Factory
- create(InetSocketAddress, InetSocketAddress, int, StreamingChannel.Kind) - Method in class org.apache.cassandra.tools.BulkLoadConnectionFactory
- create(ByteBuffer) - Static method in class org.apache.cassandra.db.rows.CellPath
- create(Collection<UDFunction>, FunctionName, List<AbstractType<?>>, AbstractType<?>, FunctionName, FunctionName, AbstractType<?>, ByteBuffer) - Static method in class org.apache.cassandra.cql3.functions.UDAggregate
- create(Collection<AbstractCompactionTask>) - Static method in class org.apache.cassandra.db.compaction.CompactionTasks
- create(AtomicReference<CommitLogPosition>, TableMetadataRef, Memtable.Owner) - Method in interface org.apache.cassandra.db.memtable.Memtable.Factory
-
Create a memtable.
- create(AtomicReference<CommitLogPosition>, TableMetadataRef, Memtable.Owner) - Method in class org.apache.cassandra.db.memtable.SkipListMemtableFactory
- create(List<Collection<Range<Token>>>, List<RepairSessionResult>) - Static method in class org.apache.cassandra.repair.CoordinatedRepairResult
- create(List<Map<String, ByteBuffer>>) - Static method in class org.apache.cassandra.cql3.UntypedResultSet
- create(List<SinglePartitionReadCommand>, DataLimits) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand.Group
- 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(Set<InetAddressAndPort>, AtomicLong) - Static method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Counter
- create(FunctionName, List<String>, String) - Static method in exception org.apache.cassandra.exceptions.FunctionExecutionException
- create(FunctionName, List<ColumnIdentifier>, List<AbstractType<?>>, AbstractType<?>, boolean, String, String) - Static method in class org.apache.cassandra.cql3.functions.UDFunction
- create(Function, Throwable) - Static method in exception org.apache.cassandra.exceptions.FunctionExecutionException
- create(ResultSet) - 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(SelectStatement, QueryPager, int) - Static method in class org.apache.cassandra.cql3.UntypedResultSet
- create(Clustering<?>, LivenessInfo, Row.Deletion, Object[]) - Static method in class org.apache.cassandra.db.rows.BTreeRow
- create(Clustering<?>, LivenessInfo, Row.Deletion, Object[], long) - Static method in class org.apache.cassandra.db.rows.BTreeRow
- create(ClusteringComparator) - Static method in class org.apache.cassandra.db.CBuilder
- create(ClusteringComparator, boolean) - Static method in class org.apache.cassandra.db.MultiCBuilder
-
Creates a new empty
MultiCBuilder
. - create(ClusteringComparator, boolean, boolean, Object...) - Static method in interface org.apache.cassandra.db.ClusteringBound
- 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(ClusteringPrefix.Kind, ClusteringPrefix<V>) - Static method in interface org.apache.cassandra.db.ClusteringBound
- create(ClusteringPrefix.Kind, ClusteringPrefix<V>) - Static method in interface org.apache.cassandra.db.ClusteringBoundary
- create(ColumnFamilyStore) - Static method in interface org.apache.cassandra.db.compaction.ShardManager
- create(ColumnFamilyStore, int, int, Iterable<SSTableReader>, SizeTieredCompactionStrategyOptions) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
- create(ColumnFamilyStore, int, int, List<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
- create(ColumnFamilyStore, TableQueryMetrics, Set<StorageAttachedIndex>, RowFilter) - Static method in class org.apache.cassandra.index.sai.plan.StorageAttachedIndexQueryPlan
- create(ColumnFamilyStore, Descriptor, long, long, TimeUUID, boolean, SerializationHeader) - Static method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
- create(OperationType) - Static method in class org.apache.cassandra.index.sai.disk.RowMapping
-
Create row mapping for FLUSH operation only.
- 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(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, long) - Static method in class org.apache.cassandra.cql3.QueryOptions
- create(ConsistencyLevel, DecoratedKey, Ballot, TableMetadata) - Static method in class org.apache.cassandra.service.paxos.PaxosRepair
- create(DecoratedKey) - Method in class org.apache.cassandra.index.sai.utils.PrimaryKey.Factory
-
Create a
PrimaryKey
for tables without clustering columns - create(DecoratedKey, Clustering<?>) - Method in class org.apache.cassandra.index.sai.utils.PrimaryKey.Factory
-
Creates a
PrimaryKey
that is fully represented by partition key and clustering. - create(Directories.DataDirectories) - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosStateTracker
- 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(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(ReadCommand, ReplicaPlan.Shared<E, P>, Dispatcher.RequestTime) - Static method in interface org.apache.cassandra.service.reads.repair.ReadRepair
- create(ReadCommand, ReplicaPlan.Shared<E, P>, Dispatcher.RequestTime) - Method in interface org.apache.cassandra.service.reads.repair.ReadRepair.Factory
- 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(UnfilteredRowIterator, int, long) - Static method in class org.apache.cassandra.db.partitions.CachedBTreePartition
-
Creates an
ArrayBackedCachedPartition
holding all the data of the provided iterator. - create(UnfilteredRowIterator, long) - Static method in class org.apache.cassandra.db.partitions.CachedBTreePartition
-
Creates an
ArrayBackedCachedPartition
holding all the data of the provided iterator. - create(Token) - Method in class org.apache.cassandra.index.sai.utils.PrimaryKey.Factory
-
Creates a
PrimaryKey
that is represented by aToken
. - create(Token.TokenFactory, Range<Token>, List<InetAddressAndPort>, boolean) - Static method in class org.apache.cassandra.service.TokenRange
- create(Index, RowFilter) - Static method in class org.apache.cassandra.index.SingletonIndexQueryPlan
- create(IndexDescriptor, IndexIdentifier, boolean) - Static method in class org.apache.cassandra.index.sai.disk.v1.ColumnCompletionMarkerUtil
-
Creates a column index completion marker for the specified column index, storing in it whether the index is empty.
- create(StorageAttachedIndex) - Static method in class org.apache.cassandra.index.sai.plan.Expression
- create(IndexTermType) - Static method in class org.apache.cassandra.index.sai.plan.Expression
- create(SASIIndex, RowFilter) - Static method in class org.apache.cassandra.index.sasi.plan.SASIIndexQueryPlan
- create(Descriptor, long, long, TimeUUID, boolean, TableMetadataRef, IntervalSet<CommitLogPosition>, int, SerializationHeader, Collection<Index.Group>, LifecycleNewTracker, SSTable.Owner) - Static method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
- create(Descriptor, IPartitioner, ClusteringComparator) - Static method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- create(SSTableReader) - Static method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- create(SSTableReader) - Static method in class org.apache.cassandra.index.sai.SSTableContext
- create(SSTableReader, FileDataInput, long, DecoratedKey, boolean) - Static method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
- create(SSTableReader, RandomAccessReader, DecoratedKey) - Static method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
- create(SSTable) - Static method in class org.apache.cassandra.db.streaming.ComponentContext
- create(SSTable) - Static method in class org.apache.cassandra.db.streaming.ComponentManifest
- create(File[]) - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosStateTracker
- create(FileHandle) - Static method in class org.apache.cassandra.index.sai.disk.io.IndexInputReader
- create(FileHandle, RowIndexEntry.IndexSerializer) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableKeyReader
- create(RandomAccessReader) - Static method in class org.apache.cassandra.index.sai.disk.io.IndexInputReader
- create(RandomAccessReader, Runnable) - Static method in class org.apache.cassandra.index.sai.disk.io.IndexInputReader
- create(RandomAccessReader, RowIndexEntry.IndexSerializer) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableKeyReader
- create(BufferPoolAllocator) - Static method in class org.apache.cassandra.net.FrameDecoderCrc
- create(SharedContext, PaxosCleanupRequest) - Static method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupLocalCoordinator
- create(ColumnMetadata, long, int, long, V, CellPath) - Method in interface org.apache.cassandra.db.rows.Cell.Factory
- create(ColumnMetadata, List<ColumnMetadata>, IndexTarget.Type) - Static method in class org.apache.cassandra.index.sai.utils.IndexTermType
- create(TableId, File, File, long) - Static method in class org.apache.cassandra.service.paxos.uncommitted.UncommittedDataFile
- create(TableMetadata, long, ByteBuffer, Slices) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Creates a new single partition slice command for the provided slices.
- create(TableMetadata, long, 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, long, DecoratedKey, Clustering<?>) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Creates a new single partition name command for the provided row.
- create(TableMetadata, long, DecoratedKey, ColumnFilter, ClusteringIndexFilter) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Creates a new read command on a single partition.
- create(TableMetadata, long, DecoratedKey, ColumnFilter, ClusteringIndexFilter) - Static method in interface org.apache.cassandra.db.SinglePartitionReadQuery
-
Creates a new read query on a single partition.
- create(TableMetadata, long, 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, long, DecoratedKey, Slices) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Creates a new single partition slice command for the provided slices.
- create(TableMetadata, long, ColumnFilter, RowFilter, DataLimits, List<DecoratedKey>, ClusteringIndexFilter) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand.Group
- create(TableMetadata, long, ColumnFilter, RowFilter, DataLimits, DataRange) - Static method in class org.apache.cassandra.db.PartitionRangeReadCommand
- create(TableMetadata, long, ColumnFilter, RowFilter, DataLimits, DataRange) - Static method in interface org.apache.cassandra.db.PartitionRangeReadQuery
- create(TableMetadata, long, 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, long, ColumnFilter, RowFilter, DataLimits, DecoratedKey, ClusteringIndexFilter) - Static method in interface org.apache.cassandra.db.SinglePartitionReadQuery
-
Creates a new read query on a single partition.
- create(TableMetadata, long, ColumnFilter, RowFilter, DataLimits, DecoratedKey, ClusteringIndexFilter, Index.QueryPlan) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Creates a new read command on a single partition.
- create(TableMetadataRef, Descriptor, long, long, TimeUUID, boolean, SerializationHeader, Collection<Index.Group>, SSTable.Owner) - Static method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
- create(TableMetadata, ByteBuffer, Clustering<?>, ColumnMetadata, CellPath) - Static method in class org.apache.cassandra.cache.CounterCacheKey
- create(TableMetadata, Row, ProtocolVersion) - Static method in class org.apache.cassandra.service.pager.PagingState.RowMark
- create(TableMetadata, DataInputPlus, SerializationHeader, DeserializationHelper) - Static method in class org.apache.cassandra.db.UnfilteredDeserializer
- create(TableMetadata, DataInputPlus, SerializationHeader, DeserializationHelper, DeletionTime) - Static method in class org.apache.cassandra.io.sstable.SSTableSimpleIterator
- create(WarningsSnapshot.Counter, WarningsSnapshot.Counter) - Static method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Warnings
- create(WarningsSnapshot.Warnings, WarningsSnapshot.Warnings, WarningsSnapshot.Warnings, WarningsSnapshot.Warnings) - Static method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- create(TraceState) - Static method in class org.apache.cassandra.concurrent.ExecutorLocals
- create(Message.Type, int, ProtocolVersion, EnumSet<Envelope.Header.Flag>, ByteBuf) - Static method in class org.apache.cassandra.transport.Envelope
- create(BiMultiValMap<K, V>) - Static method in class org.apache.cassandra.utils.SortedBiMultiValMap
- create(ByteComparable, PostingList) - Static method in class org.apache.cassandra.index.sai.utils.IndexEntry
- create(R) - Static method in class org.apache.cassandra.index.sai.utils.PartitionInfo
- create(V) - Static method in class org.apache.cassandra.utils.Wrapped
- create(X, Y) - Static method in class org.apache.cassandra.utils.Pair
- CREATE - org.apache.cassandra.auth.Permission
- CREATE_AGGREGATE - org.apache.cassandra.audit.AuditLogEntryType
- CREATE_FUNCTION - org.apache.cassandra.audit.AuditLogEntryType
- CREATE_IDENTITY - org.apache.cassandra.audit.AuditLogEntryType
- CREATE_INDEX - org.apache.cassandra.audit.AuditLogEntryType
- CREATE_KEYSPACE - org.apache.cassandra.audit.AuditLogEntryType
- CREATE_ON_FROZEN_COLUMN - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- CREATE_ON_NON_FROZEN_UDT - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- CREATE_ROLE - org.apache.cassandra.audit.AuditLogEntryType
- CREATE_TABLE - org.apache.cassandra.audit.AuditLogEntryType
- CREATE_TRIGGER - org.apache.cassandra.audit.AuditLogEntryType
- CREATE_TYPE - org.apache.cassandra.audit.AuditLogEntryType
- CREATE_VIEW - org.apache.cassandra.audit.AuditLogEntryType
- CREATE_WITH_NON_MAP_TYPE - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- 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.
- createAnonymousThread(Runnable) - Static method in class org.apache.cassandra.concurrent.NamedThreadFactory
- 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.db.commitlog.CommitLogSegment
- createBuffer() - Method in class org.apache.cassandra.db.commitlog.MemoryMappedSegment
- createBuffer() - Method in class org.apache.cassandra.io.util.SimpleCachedBufferPool
- createBufferPool() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment.Builder
- createBufferPool() - Method in class org.apache.cassandra.db.commitlog.CompressedSegment.CompressedSegmentBuilder
- createBufferPool() - Method in class org.apache.cassandra.db.commitlog.DirectIOSegment.DirectIOSegmentBuilder
- createBufferPool() - Method in class org.apache.cassandra.db.commitlog.EncryptedSegment.EncryptedSegmentBuilder
- createBufferPool() - Method in class org.apache.cassandra.db.commitlog.MemoryMappedSegment.MemoryMappedSegmentBuilder
- createBuilderWriter(IndexDescriptor, Collection<StorageAttachedIndex>, LifecycleNewTracker, boolean) - Static method in class org.apache.cassandra.index.sai.disk.StorageAttachedIndexWriter
- createClustering(QueryOptions, ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- 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
- createColumnFamilyStore(Keyspace, TableMetadataRef, boolean) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
- createColumnFromRow(UntypedResultSet.Row, Types, UserFunctions) - Static method in class org.apache.cassandra.schema.SchemaKeyspace
- createCompactionStrategyInstance(CompactionParams) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- createComponent(String) - Method in class org.apache.cassandra.io.sstable.Component.Type
- createComponent(String, SSTableFormat<?, ?>) - Static method in class org.apache.cassandra.io.sstable.Component.Type
- createComponentOnDisk(IndexComponent) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- createComponentOnDisk(IndexComponent, IndexIdentifier) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- createCompressor(ParameterizedClass) - Static method in class org.apache.cassandra.schema.CompressionParams
- createConnection(OutboundConnectionSettings, int) - Method in interface org.apache.cassandra.streaming.StreamConnectionFactory
- 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
- CREATED - org.apache.cassandra.transport.Event.SchemaChange.Change
- createdAt - Variable in class org.apache.cassandra.service.snapshot.SnapshotManifest
- createDataResponse(UnfilteredPartitionIterator, ReadCommand, RepairedDataInfo) - Static method in class org.apache.cassandra.db.ReadResponse
- createdAtNanos - Variable in class org.apache.cassandra.net.Message.Header
- createdAtNanos - Variable in class org.apache.cassandra.transport.Message.Request
- createdAtNanos() - Method in class org.apache.cassandra.net.Message
-
Creation time of the message.
- createDefault() - Static method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram
- createDefaultMBeanName(String, String, String) - Static method in class org.apache.cassandra.metrics.DefaultNameFactory
- createDefaultRoleQuery() - Static method in class org.apache.cassandra.auth.CassandraRoleManager
- 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
- createDirectoriesIfNotExists() - Method in class org.apache.cassandra.io.util.File
- createDirectoriesIfNotExists(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- createDirectory(String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Deprecated.See CASSANDRA-16926
- createDirectory(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Deprecated.See CASSANDRA-16926
- createDirectoryIfNotExists(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- createEmptyResponse() - Method in class org.apache.cassandra.db.ReadCommand
- 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(SharedContext) - Method in class org.apache.cassandra.repair.RepairSession
- createFileIfNotExists() - Method in class org.apache.cassandra.io.util.File
-
Try to create a new regular file at this path.
- createFileIfNotExists(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- createFlushObserverWriter(IndexDescriptor, Collection<StorageAttachedIndex>, LifecycleNewTracker) - Static method in class org.apache.cassandra.index.sai.disk.StorageAttachedIndexWriter
- createFlushWriter(ColumnFamilyStore, Memtable.FlushablePartitionSet<?>, LifecycleTransaction, Descriptor, long) - Static method in class org.apache.cassandra.db.memtable.Flushing
- createFollower(int, TimeUUID, StreamOperation, InetAddressAndPort, StreamingChannel, int, TimeUUID, PreviewKind) - Static method in class org.apache.cassandra.streaming.StreamResultFuture
- createForAutoRepair(SharedContext, TableId, Collection<Range<Token>>) - Static method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupLocalCoordinator
- 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-wideencryptionContext
. - 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, long, 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(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
- createHardLinkWithConfirm(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
- createHardLinkWithoutConfirm(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
- createHardLinkWithoutConfirm(File, File) - 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(TimeUUID, 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, boolean) - Static method in class org.apache.cassandra.utils.JMXServerUtils
- createJMXServer(int, String, boolean) - Static method in class org.apache.cassandra.utils.JMXServerUtils
-
Creates a server programmatically.
- createJSSESslContext(boolean) - Method in class org.apache.cassandra.security.AbstractSslContextFactory
- createJSSESslContext(boolean) - Method in interface org.apache.cassandra.security.ISslContextFactory
-
Creates JSSE SSLContext.
- 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
- createLightweightRecycler(int) - Static method in class org.apache.cassandra.utils.concurrent.ThreadLocals
- createLinks(String) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- createLinks(String, RateLimiter) - 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
- createLinks(Descriptor, Set<Component>, String, RateLimiter) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
- createLocal(long) - Method in class org.apache.cassandra.db.context.CounterContext
-
Creates a counter context with a single local shard.
- createLocal(TimeUUID, 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)
- createLogTag(StreamSession) - Static method in class org.apache.cassandra.streaming.StreamSession
- createLogTag(StreamSession, Channel) - Static method in class org.apache.cassandra.streaming.StreamSession
- createLogTag(StreamSession, Object) - Static method in class org.apache.cassandra.streaming.StreamSession
- createLogTag(StreamSession, StreamingChannel) - Static method in class org.apache.cassandra.streaming.StreamSession
- createMemtable(AtomicReference<CommitLogPosition>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- createMemtableAllocatorPoolInternal(Config.MemtableAllocationType, long, long, float, MemtableCleaner) - Static method in class org.apache.cassandra.db.memtable.AbstractAllocatorMemtable
- createMemtableMetrics(TableMetadataRef) - Method in interface org.apache.cassandra.db.memtable.Memtable.Factory
-
Override this method to include implementation-specific memtable metrics in the table metrics.
- createMessage(boolean, Dispatcher.RequestTime) - Method in class org.apache.cassandra.db.ReadCommand
-
Creates a message for this command.
- createMessage(boolean, T) - Method in interface org.apache.cassandra.db.guardrails.Predicates.MessageProvider
-
Called when the guardrail is triggered to build the corresponding message.
- createMessageForRetry(int) - Method in class org.apache.cassandra.streaming.StreamTransferTask
- createMetricName(String) - Method in class org.apache.cassandra.index.sai.metrics.AbstractMetrics
- createMetricName(String) - 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.
- createMetricName(String, String) - Method in class org.apache.cassandra.index.sai.metrics.AbstractMetrics
- createMetricName(String, String, String) - Static method in class org.apache.cassandra.metrics.DefaultNameFactory
- createNettySslContext(boolean, ISslContextFactory.SocketType, CipherSuiteFilter) - Method in class org.apache.cassandra.security.AbstractSslContextFactory
- createNettySslContext(boolean, ISslContextFactory.SocketType, CipherSuiteFilter) - Method in interface org.apache.cassandra.security.ISslContextFactory
-
Creates Netty's SslContext object.
- 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, TimeUUID, PreviewKind) - Method in class org.apache.cassandra.db.streaming.CassandraStreamManager
- createOutgoingStreams(StreamSession, RangesAtEndpoint, TimeUUID, PreviewKind) - Method in interface org.apache.cassandra.streaming.TableStreamManager
-
Returns a collection of
OutgoingStream
s that contains the data selected by the given replicas, pendingRepair, and preview. - createPerIndexFileHandle(IndexComponent, IndexIdentifier) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- createPerIndexFileHandle(IndexComponent, IndexIdentifier, Throwables.DiscreteAction<?>) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- createPerSSTableFileHandle(IndexComponent, Throwables.DiscreteAction<?>) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- createRangeAware(TableMetadataRef, long, long, TimeUUID, boolean, SSTableFormat<?, ?>, 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(long) - Method in class org.apache.cassandra.io.util.FileHandle
- createReader(RateLimiter) - Method in class org.apache.cassandra.io.util.FileHandle
-
Create
RandomAccessReader
with configured method of reading content of the file. - createReaderInternal(RowIndexEntry, FileDataInput, boolean, Version) - Method in class org.apache.cassandra.io.sstable.format.big.SSTableIterator
- createReaderInternal(RowIndexEntry, FileDataInput, boolean, Version) - Method in class org.apache.cassandra.io.sstable.format.big.SSTableReversedIterator
- createReaderInternal(RIE, FileDataInput, boolean, Version) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator
- createRemote(CounterId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext
-
Creates a counter context with a single remote shard.
- createRemote(TimeUUID, 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.
- 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() - Method in class org.apache.cassandra.schema.KeyspaceMetadata
- createReplicationStrategy(String, Class<? extends AbstractReplicationStrategy>, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
- createReservoir(TimeUnit) - Static method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
- 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, CIDRPermissions, boolean) - Constructor for class org.apache.cassandra.cql3.statements.CreateRoleStatement
- createRowIndexEntry(DecoratedKey, DeletionTime, long) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
- createRowIndexEntry(DecoratedKey, DeletionTime, long) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter
- createRowIndexEntry(DecoratedKey, DeletionTime, long) - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter
- createSecondaryIndexesEnabled - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail disabling user's ability to create secondary indexes
- createSegment() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogSegmentManager
-
Hook to allow segment managers to track state surrounding creation of new segments.
- 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 Synchronized on this
- createSegment() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerStandard
- createServerSocket(int) - Method in class org.apache.cassandra.utils.RMIServerSocketFactoryImpl
- createSimpleDataResponse(UnfilteredPartitionIterator, ColumnFilter) - Static method in class org.apache.cassandra.db.ReadResponse
- 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.
- createSingleton(String, String, boolean, Class<? extends SSTableFormat<?, ?>>) - Static method in class org.apache.cassandra.io.sstable.Component.Type
-
Creates a new singleton type and registers it in a global type registry - see
Component.Type.registerType(Type)
. - createSlices(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- createSnapshot(String, boolean, DurationSpec.IntSecondsBound, Set<SSTableReader>, Instant) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- createSocket(String, int) - Method in class org.apache.cassandra.utils.RMIClientSocketFactoryImpl
- 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
- createSSTableMultiWriter(Descriptor, long, long, TimeUUID, boolean, IntervalSet<CommitLogPosition>, int, SerializationHeader, Collection<Index.Group>, LifecycleNewTracker) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
- createSSTableMultiWriter(Descriptor, long, long, TimeUUID, boolean, IntervalSet<CommitLogPosition>, int, SerializationHeader, Collection<Index.Group>, LifecycleNewTracker) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
- createSSTableMultiWriter(Descriptor, long, long, TimeUUID, boolean, IntervalSet<CommitLogPosition>, int, SerializationHeader, Collection<Index.Group>, LifecycleNewTracker) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
- createSSTableMultiWriter(Descriptor, long, long, TimeUUID, boolean, IntervalSet<CommitLogPosition>, int, SerializationHeader, Collection<Index.Group>, LifecycleNewTracker) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
- createSSTableMultiWriter(Descriptor, long, long, TimeUUID, boolean, IntervalSet<CommitLogPosition>, int, SerializationHeader, Collection<Index.Group>, LifecycleNewTracker) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
- createSSTableMultiWriter(Descriptor, long, long, TimeUUID, boolean, IntervalSet<CommitLogPosition>, int, SerializationHeader, Collection<Index.Group>, LifecycleNewTracker) - Method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
-
Create the sstable writer used for flushing.
- createSSTableMultiWriter(Descriptor, long, long, TimeUUID, boolean, IntervalSet<CommitLogPosition>, int, SerializationHeader, LifecycleNewTracker) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- createSSTableMultiWriter(Descriptor, long, long, TimeUUID, boolean, IntervalSet<CommitLogPosition>, SerializationHeader, LifecycleNewTracker) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- createSSTableMultiWriter(Descriptor, long, long, TimeUUID, boolean, SerializationHeader, LifecycleNewTracker) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- 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 tableGauge
. - createTableHistogram(String, boolean) - Method in class org.apache.cassandra.metrics.TableMetrics
- 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, boolean) - Method in class org.apache.cassandra.metrics.TableMetrics
- createTableHistogram(String, String, Histogram, 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, CreateTableStatement.ColumnProperties.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) - Method in class org.apache.cassandra.metrics.TableMetrics
- createTableTimer(String, Timer) - Method in class org.apache.cassandra.metrics.TableMetrics
- createTempFile(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
- createTempFile(String, String, File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Pretty much like
File.createTempFile(String, String, java.io.File)
, but with the guarantee that the "random" part of the generated file name betweenprefix
andsuffix
is a positive, increasinglong
value. - createThread(Runnable, String) - Static method in class org.apache.cassandra.concurrent.NamedThreadFactory
- createThread(Runnable, String, boolean) - 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
- createThread(ThreadGroup, Runnable, String, int, ClassLoader, Thread.UncaughtExceptionHandler) - 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.
- createVerbHandler(SharedContext) - Static method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupComplete
- createVerbHandler(SharedContext) - Static method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupRequest
- createVerbHandler(SharedContext) - Static method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupResponse
- createVerbHandler(SharedContext) - Static method in class org.apache.cassandra.service.paxos.cleanup.PaxosFinishPrepareCleanup
- createVerbHandler(SharedContext) - Static method in class org.apache.cassandra.service.paxos.cleanup.PaxosStartPrepareCleanup
- 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
- createWriter(ColumnFamilyStore, long, long, TimeUUID, SSTableFormat<?, ?>) - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader
- createWriter(ColumnFamilyStore, long, Collection<Component>) - Method in class org.apache.cassandra.db.streaming.CassandraEntireSSTableStreamReader
- createWriter(ColumnFamilyStore, File, long, long, TimeUUID, boolean, SSTableReader, LifecycleTransaction) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
- createWriterForAntiCompaction(ColumnFamilyStore, File, int, long, TimeUUID, boolean, Collection<SSTableReader>, ILifecycleTransaction) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
- createZeroCopyWriter(LifecycleNewTracker, SSTable.Owner) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- 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.concurrent.DebuggableTask
- creationTimeNanos() - Method in class org.apache.cassandra.concurrent.DebuggableTask.RunningDebuggableTask
- creationTimeNanos() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
- creationTimeNanos() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
- creationTimeNanos() - Method in class org.apache.cassandra.service.StorageProxy.LocalReadRunnable
- creationTimeNanos() - Method in class org.apache.cassandra.transport.Dispatcher.RequestProcessor
- CREDENTIALS - org.apache.cassandra.transport.Message.Type
- credentials_cache_active_update - Variable in class org.apache.cassandra.config.Config
- credentials_cache_max_entries - Variable in class org.apache.cassandra.config.Config
- credentials_update_interval - Variable in class org.apache.cassandra.config.Config
- credentials_validity - Variable in class org.apache.cassandra.config.Config
- crossNodeDroppedLatency - Variable in class org.apache.cassandra.metrics.DroppedMessageMetrics
-
The cross node dropped latency
- crypto_provider - Variable in class org.apache.cassandra.config.Config
- CRYPTO_PROVIDER_CLASS_NAME - org.apache.cassandra.config.CassandraRelevantProperties
- CSLM_OVERHEAD - Static variable in class org.apache.cassandra.index.sasi.memory.SkipListMemIndex
- CTOR_SIG - Static variable in class org.apache.cassandra.cql3.functions.UDFByteCodeVerifier
- ctx - Variable in class org.apache.cassandra.repair.consistent.ConsistentSession
- ctx - Variable in class org.apache.cassandra.repair.RepairSession
- ctx - Variable in class org.apache.cassandra.repair.SyncTask
- ctx - Variable in class org.apache.cassandra.repair.Validator
- ctx - Variable in class org.apache.cassandra.service.ActiveRepairService
- current() - Static method in class org.apache.cassandra.concurrent.ExecutorLocals
- current() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
returns the currently visible readers managed by this transaction
- current() - Method in class org.apache.cassandra.io.util.RandomAccessReader
- current() - Method in class org.apache.cassandra.io.util.SequentialWriter
- 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() - Static method in enum org.apache.cassandra.utils.StorageCompatibilityMode
- current(SSTableReader) - Method in interface org.apache.cassandra.db.lifecycle.ILifecycleTransaction
- 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 variable in enum org.apache.cassandra.transport.ProtocolVersion
-
The preferred version.
- current_version - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
Increment this number if there is a changes in the commit log disc layout or MessagingVersion changes.
- current_version - Static variable in class org.apache.cassandra.net.MessagingService
- CURRENT_VERSION - Static variable in class org.apache.cassandra.audit.BinAuditLogger
- 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
- 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.io.sstable.format.big.IndexState
- currentBuffer() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
- currentBytes - Variable in class org.apache.cassandra.streaming.ProgressInfo
- currentBytesUsed() - Method in class org.apache.cassandra.index.sai.utils.NamedMemoryLimiter
- currentClustering() - Method in class org.apache.cassandra.cql3.UpdateParameters
- currentDirectory - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
- currentEntry - Variable in class org.apache.cassandra.io.sstable.format.SSTableScanner.BaseKeyScanningIterator
- currentFlushSize - Variable in class org.apache.cassandra.db.compaction.unified.Controller
- currentIndex() - Method in class org.apache.cassandra.io.sstable.format.big.IndexState
- currentKey - Variable in class org.apache.cassandra.io.sstable.format.SSTableScanner.BaseKeyScanningIterator
- CURRENTLY_BLOCKED_TASKS - Static variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
- currentlyBackgroundUpgrading - Variable in class org.apache.cassandra.db.compaction.CompactionManager
- currentOperations - Variable in class org.apache.cassandra.db.memtable.AbstractMemtable
- currentPosition() - Method in class org.apache.cassandra.io.sstable.format.SortedTablePartitionWriter
- currentSnapshot() - Method in class org.apache.cassandra.service.paxos.PaxosState
- currentState - Variable in class org.apache.cassandra.repair.state.AbstractState
- currentTimeMillis() - Method in interface org.apache.cassandra.utils.Clock
-
Semantically equivalent to
System.currentTimeMillis()
- currentTimeMillis() - Method in class org.apache.cassandra.utils.Clock.Default
-
System.currentTimeMillis()
- currentTimeMillis() - Static method in class org.apache.cassandra.utils.Clock.Global
-
Semantically equivalent to
System.currentTimeMillis()
- currentTimeoutNanos() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
- currentWriter() - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
- cursor() - Method in class org.apache.cassandra.db.tries.InMemoryReadTrie
- cursor() - Method in class org.apache.cassandra.db.tries.SlicedTrie
- cursor() - Method in class org.apache.cassandra.db.tries.Trie
- Cursor<K,V> - Interface in org.apache.cassandra.index.sasi.utils.trie
-
A
Cursor
can be used to traverse aTrie
, visit each node step by step and makeCursor.Decision
s on each step how to continue with traversing theTrie
. - Cursor.Decision - Enum in org.apache.cassandra.index.sasi.utils.trie
- 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(String) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Custom
- Custom(AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Custom
- CUSTOM - org.apache.cassandra.cql3.functions.types.DataType.Name
- CUSTOM - org.apache.cassandra.db.filter.RowFilter.Expression.Kind
- CUSTOM - org.apache.cassandra.db.marshal.AbstractType.ComparisonType
-
This type can only be compared by calling the type's compareCustom() method, which may be expensive.
- CUSTOM - org.apache.cassandra.net.Verb.Kind
- CUSTOM - org.apache.cassandra.schema.IndexMetadata.Kind
- CUSTOM - org.apache.cassandra.transport.DataType
- CUSTOM - Static variable in class org.apache.cassandra.io.sstable.format.SSTableFormat.Components.Types
- CUSTOM_CREATE_WITHOUT_COLUMN - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- 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_GUARDRAILS_CONFIG_PROVIDER_CLASS - org.apache.cassandra.config.CassandraRelevantProperties
- CUSTOM_IMPLEMENTATION_PROPERTY - Static variable in interface org.apache.cassandra.db.guardrails.GuardrailsConfigProvider
-
Deprecated.CUSTOM_GUARDRAILS_CONFIG_PROVIDER_CLASS.getKey() must be used instead. See CASSANDRA-17797
- CUSTOM_INDEX_OPTION_NAME - Static variable in class org.apache.cassandra.cql3.statements.schema.IndexTarget
- CUSTOM_MAP - org.apache.cassandra.net.ParamType
- CUSTOM_MULTIPLE_COLUMNS - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- CUSTOM_PAYLOAD - org.apache.cassandra.transport.Envelope.Header.Flag
- CUSTOM_QUERY_HANDLER_CLASS - org.apache.cassandra.config.CassandraRelevantProperties
- CUSTOM_TRACING_CLASS - org.apache.cassandra.config.CassandraRelevantProperties
- 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 URL first, if it cannot find the required class it will let the parent class loader do 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.sai.StorageAttachedIndex
- customExpressionValueType() - Method in class org.apache.cassandra.index.sasi.SASIIndex
- customExpressionValueType() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- CustomIndexExpression - Class in org.apache.cassandra.cql3.restrictions
- CustomIndexExpression(QualifiedName, Term.Raw) - Constructor for class org.apache.cassandra.cql3.restrictions.CustomIndexExpression
- customParams() - Method in class org.apache.cassandra.net.Message.Header
- 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
- cut(ByteComparable, int) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteComparable
- cut(ByteSource, int) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- cutoff() - Method in interface org.apache.cassandra.io.tries.IncrementalTrieWriter.PartialTail
-
Cutoff point.
- cutOrRightPad(ByteSource, int, int) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
Wrap a ByteSource in a length-fixing facade.
D
- DAEMON - org.apache.cassandra.concurrent.InfiniteLoopExecutor.Daemon
- daemonInitialization() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- daemonInitialization(Supplier<Config>) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- data - Variable in class org.apache.cassandra.utils.Interval
- 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() - Method in class org.apache.cassandra.db.virtual.AbstractVirtualTable.SimpleTable
- data() - Method in class org.apache.cassandra.db.virtual.BatchMetricsTable
- data() - Method in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsCountsTable
- data() - Method in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsLatenciesTable
- data() - Method in class org.apache.cassandra.db.virtual.InternodeInboundTable
- data() - Method in class org.apache.cassandra.db.virtual.InternodeOutboundTable
- data() - Method in class org.apache.cassandra.db.virtual.LogMessagesTable
- data() - Method in class org.apache.cassandra.db.virtual.SnapshotsTable
- data() - Method in class org.apache.cassandra.db.virtual.StreamingVirtualTable
- data() - Method in class org.apache.cassandra.index.sai.virtual.ColumnIndexesSystemView
- data() - Method in class org.apache.cassandra.index.sai.virtual.SegmentsSystemView
- data() - Method in class org.apache.cassandra.index.sai.virtual.SSTableIndexesSystemView
- 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(DecoratedKey) - Method in class org.apache.cassandra.db.virtual.InternodeInboundTable
- data(DecoratedKey) - Method in class org.apache.cassandra.db.virtual.InternodeOutboundTable
- data(DecoratedKey) - Method in class org.apache.cassandra.db.virtual.StreamingVirtualTable
- DATA - org.apache.cassandra.index.sasi.disk.OnDiskBlock.BlockType
- DATA - Static variable in class org.apache.cassandra.io.sstable.format.SSTableFormat.Components
- DATA - Static variable in class org.apache.cassandra.io.sstable.format.SSTableFormat.Components.Types
- DATA_CENTER_NAME - Static variable in class org.apache.cassandra.locator.SimpleSnitch
- data_disk_usage_max_disk_size - Variable in class org.apache.cassandra.config.Config
- data_disk_usage_percentage_fail_threshold - Variable in class org.apache.cassandra.config.Config
- data_disk_usage_percentage_warn_threshold - Variable in class org.apache.cassandra.config.Config
- data_file_directories - Variable in class org.apache.cassandra.config.Config
- DATA_OUTPUT_BUFFER_ALLOCATE_TYPE - org.apache.cassandra.config.CassandraRelevantProperties
-
Controls the type of bufffer (heap/direct) used for shared scratch buffers
- DATA_OUTPUT_STREAM_PLUS_TEMP_BUFFER_SIZE - org.apache.cassandra.config.CassandraRelevantProperties
- 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 - Variable in class org.apache.cassandra.service.TokenRange.EndpointDetails
- datacenter(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- DATACENTER_AWARE - org.apache.cassandra.repair.RepairParallelism
-
One node per data center at a time
- 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.ForWrite, Runnable, WriteType, Supplier<Mutation>, Dispatcher.RequestTime) - 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.ForWrite, Runnable, WriteType, Supplier<Mutation>, Dispatcher.RequestTime) - Constructor for class org.apache.cassandra.service.DatacenterWriteResponseHandler
- DataComponent - Class in org.apache.cassandra.io.sstable.format
- DataComponent() - Constructor for class org.apache.cassandra.io.sstable.format.DataComponent
- 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(Path) - 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.SortedTableScrubber
- dataFile - Variable in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- dataFileBuilder(StatsMetadata) - Method in class org.apache.cassandra.io.sstable.format.SortedTableReaderLoadingBuilder
- DataInputBuffer - Class in org.apache.cassandra.io.util
-
Input stream around a single ByteBuffer.
- DataInputBuffer(byte[]) - Constructor for class org.apache.cassandra.io.util.DataInputBuffer
- DataInputBuffer(byte[], int, int) - Constructor for class org.apache.cassandra.io.util.DataInputBuffer
- DataInputBuffer(ByteBuffer, boolean) - 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() - 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
- dataKeys - Variable in class org.apache.cassandra.metrics.SamplingManager.ResultBuilder
- dataLength - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
- dataLength - Variable in class org.apache.cassandra.io.sstable.indexsummary.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
- DataPaths - Class in org.apache.cassandra.tools.nodetool
- DataPaths() - Constructor for class org.apache.cassandra.tools.nodetool.DataPaths
- DataPathsHolder - Class in org.apache.cassandra.tools.nodetool.stats
- DataPathsHolder(NodeProbe, List<String>) - Constructor for class org.apache.cassandra.tools.nodetool.stats.DataPathsHolder
- DataPathsPrinter<T extends StatsHolder> - Class in org.apache.cassandra.tools.nodetool.stats
- DataPathsPrinter() - Constructor for class org.apache.cassandra.tools.nodetool.stats.DataPathsPrinter
- DataPathsPrinter.DefaultPrinter - Class in org.apache.cassandra.tools.nodetool.stats
- dataPosition() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableKeyReader
- dataPosition() - Method in class org.apache.cassandra.io.sstable.format.bti.ScrubIterator
- dataPosition() - Method in interface org.apache.cassandra.io.sstable.format.bti.ScrubPartitionIterator
-
Key position in data file or -1 if the iterator reached the end of the index.
- dataPosition() - Method in interface org.apache.cassandra.io.sstable.KeyReader
-
Position in the data file where the associated content resides
- 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 - Variable in class org.apache.cassandra.db.PartitionRangeReadCommand
- dataRange - Variable in class org.apache.cassandra.io.sstable.format.SSTableScanner
- 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.index.sasi.plan.QueryController
- 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.Paging - Class in org.apache.cassandra.db
-
Specialized
DataRange
used for the paging case. - DataRange.Serializer - Class in org.apache.cassandra.db
- dataRanges() - Method in class org.apache.cassandra.index.sai.plan.QueryController
- DataRateSpec - Class in org.apache.cassandra.config
-
Represents a data rate type used for cassandra configuration.
- DataRateSpec.DataRateUnit - Enum in org.apache.cassandra.config
- DataRateSpec.LongBytesPerSecondBound - Class in org.apache.cassandra.config
-
Represents a data rate used for Cassandra configuration.
- DataResolver<E extends Endpoints<E>,P extends ReplicaPlan.ForRead<E,P>> - Class in org.apache.cassandra.service.reads
- DataResolver(ReadCommand, Supplier<? extends P>, ReadRepair<E, P>, Dispatcher.RequestTime) - Constructor for class org.apache.cassandra.service.reads.DataResolver
- DataResolver(ReadCommand, Supplier<? extends P>, ReadRepair<E, P>, Dispatcher.RequestTime, boolean) - Constructor for class org.apache.cassandra.service.reads.DataResolver
- DataResource - Class in org.apache.cassandra.auth
-
The primary type of resource in Cassandra.
- DataResurrectionCheck - Class in org.apache.cassandra.service
- DataResurrectionCheck() - Constructor for class org.apache.cassandra.service.DataResurrectionCheck
- DataResurrectionCheck.Heartbeat - Class in org.apache.cassandra.service
- dataSize - Variable in class org.apache.cassandra.db.partitions.BTreePartitionUpdater
- dataSize - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStat.Builder
- dataSize - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStat
- 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() - 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.memtable.AbstractMemtable.AbstractFlushablePartitionSet
- 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() - Method in interface org.apache.cassandra.io.sstable.format.SSTableWriter.SSTableSizeParameters
- dataSize(Collection<? extends IMutation>) - Static method in interface org.apache.cassandra.db.IMutation
-
Computes the total data size of the specified mutations.
- DataStorageSpec - Class in org.apache.cassandra.config
-
Represents an amount of data storage.
- DataStorageSpec.DataStorageUnit - Enum in org.apache.cassandra.config
- DataStorageSpec.IntBytesBound - Class in org.apache.cassandra.config
-
Represents a data storage quantity used for Cassandra configuration.
- DataStorageSpec.IntKibibytesBound - Class in org.apache.cassandra.config
-
Represents a data storage quantity used for Cassandra configuration.
- DataStorageSpec.IntMebibytesBound - Class in org.apache.cassandra.config
-
Represents a data storage quantity used for Cassandra configuration.
- DataStorageSpec.LongBytesBound - Class in org.apache.cassandra.config
-
Represents a data storage quantity used for Cassandra configuration.
- DataStorageSpec.LongMebibytesBound - Class in org.apache.cassandra.config
-
Represents a data storage quantity used for Cassandra configuration.
- 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 - Enum in org.apache.cassandra.transport
- DataType(DataType.Name) - Constructor for class org.apache.cassandra.cql3.functions.types.DataType
- 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
- dataWriter - Variable in class org.apache.cassandra.io.sstable.format.SortedTableWriter
- 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
. - DATE - org.apache.cassandra.cql3.CQL3Type.Native
- DATE - org.apache.cassandra.cql3.functions.types.DataType.Name
- DATE - org.apache.cassandra.transport.DataType
- dateStringToDays(String) - Static method in class org.apache.cassandra.serializers.SimpleDateSerializer
- dateStringToTimestamp(String) - Static method in class org.apache.cassandra.serializers.TimestampSerializer
- DateType - Class in org.apache.cassandra.db.marshal
-
Deprecated.This is the old version of TimestampType, but has been replaced as it wasn't comparing pre-epoch timestamps correctly. This is kept for backward compatibility but shouldn't be used in new code.
- DAYS_PER_WEEK - Static variable in class org.apache.cassandra.cql3.Duration
- dayToTimeInMillis(int) - Static method in class org.apache.cassandra.serializers.SimpleDateSerializer
- dc - org.apache.cassandra.config.Config.InternodeCompression
- dc - org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions.InternodeEncryption
- DC - org.apache.cassandra.gms.ApplicationState
- DCL - org.apache.cassandra.audit.AuditLogEntryCategory
- 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
- DDL - org.apache.cassandra.audit.AuditLogEntryCategory
- 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 - Variable in class org.apache.cassandra.net.OutboundConnectionSettings
- debug - Variable in class org.apache.cassandra.tools.LoaderOptions
- debug - Variable in class org.apache.cassandra.utils.OutputHandler.SystemOutput
- debug() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
- debug(String) - Method in interface org.apache.cassandra.utils.OutputHandler
- debug(String) - Method in class org.apache.cassandra.utils.OutputHandler.LogOutput
- debug(String) - Method in class org.apache.cassandra.utils.OutputHandler.SystemOutput
- debug(String, Object...) - Method in interface org.apache.cassandra.utils.OutputHandler
- debug(BufferPool.Debug, BufferPool.DebugLeaks) - Method in class org.apache.cassandra.utils.memory.BufferPool
- DEBUG - Static variable in class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeWriter
- DEBUG_ENABLED - Static variable in class org.apache.cassandra.utils.concurrent.Ref
- DebuggableTask - Interface in org.apache.cassandra.concurrent
-
Interface to include on a Runnable or Callable submitted to the
SharedExecutorPool
to provide more detailed diagnostics. - DebuggableTask.CallableDebuggableTask<T> - Interface in org.apache.cassandra.concurrent
- DebuggableTask.RunnableDebuggableTask - Interface in org.apache.cassandra.concurrent
- DebuggableTask.RunningDebuggableTask - Class in org.apache.cassandra.concurrent
-
Wraps a
DebuggableTask
to include the name of the thread running it. - debugString() - Method in class org.apache.cassandra.schema.ColumnMetadata
- decayBy10() - Static method in class org.apache.cassandra.utils.ExpMovingAverage
-
Create a
ExpMovingAverage
where older values have less than 1% effect after 10 samples. - decayBy100() - Static method in class org.apache.cassandra.utils.ExpMovingAverage
-
Create a
ExpMovingAverage
where older values have less than 1% effect after 100 samples. - decayBy1000() - Static method in class org.apache.cassandra.utils.ExpMovingAverage
-
Create a
ExpMovingAverage
where older values have less than 1% effect after 1000 samples. - DECAYING_ESTIMATED_HISTOGRAM_RESERVOIR_STRIPE_COUNT - org.apache.cassandra.config.CassandraRelevantProperties
- 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(MonotonicClock) - 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
. - DECIMAL - org.apache.cassandra.cql3.CQL3Type.Native
- DECIMAL - org.apache.cassandra.cql3.functions.types.DataType.Name
- DECIMAL - org.apache.cassandra.transport.DataType
- 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(int, boolean) - Static method in enum org.apache.cassandra.transport.ProtocolVersion
- decode(ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.cql3.ResultSet.Codec
- decode(ByteBuf, ProtocolVersion) - Method in interface org.apache.cassandra.transport.CBCodec
- decode(ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.transport.messages.UnsupportedMessageCodec
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.cassandra.transport.Envelope.Decoder
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.cassandra.transport.InitialConnectionHandler
- decode(ChannelHandlerContext, Envelope, List<Object>) - Method in class org.apache.cassandra.transport.Envelope.Decompressor
- decode(ChannelHandlerContext, Envelope, List<Object>) - Method in class org.apache.cassandra.transport.PreV5Handlers.ProtocolDecoder
- 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(byte[]) - Static method in class org.apache.cassandra.utils.JsonUtils
- decodeJson(String) - Static method in class org.apache.cassandra.utils.JsonUtils
- decodeLocalDeletionTime(long, int, DeserializationHelper) - Static method in class org.apache.cassandra.db.rows.Cell
-
Handle unsigned encoding and potentially invalid localDeletionTime.
- 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
- DECOMMISSION - org.apache.cassandra.streaming.StreamOperation
- DECOMMISSION_FAILED - org.apache.cassandra.service.StorageService.Mode
- DECOMMISSIONED - org.apache.cassandra.db.SystemKeyspace.BootstrapState
- DECOMMISSIONED - org.apache.cassandra.service.StorageService.Mode
- decompose(Long) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
- decompose(Object...) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
- decompose(Object...) - Method in class org.apache.cassandra.db.marshal.CompositeType
- decompose(Object...) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
- decompose(Void) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType.FixedValueComparator
- 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.
- decompose(ProtocolVersion, byte) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
- decompose(ProtocolVersion, byte) - Method in class org.apache.cassandra.cql3.functions.UDFDataType
-
Serialized the specified byte.
- decompose(ProtocolVersion, double) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
- decompose(ProtocolVersion, double) - Method in class org.apache.cassandra.cql3.functions.UDFDataType
-
Serialized the specified byte.
- decompose(ProtocolVersion, float) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
- decompose(ProtocolVersion, float) - Method in class org.apache.cassandra.cql3.functions.UDFDataType
-
Serialized the specified byte.
- decompose(ProtocolVersion, int) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
- decompose(ProtocolVersion, int) - Method in class org.apache.cassandra.cql3.functions.UDFDataType
-
Serialized the specified byte.
- decompose(ProtocolVersion, long) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
- decompose(ProtocolVersion, long) - Method in class org.apache.cassandra.cql3.functions.UDFDataType
-
Serialized the specified byte.
- decompose(ProtocolVersion, short) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
- decompose(ProtocolVersion, short) - Method in class org.apache.cassandra.cql3.functions.UDFDataType
-
Serialized the specified byte.
- decompose(ProtocolVersion, Object) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
- decompose(ProtocolVersion, Object) - Method in class org.apache.cassandra.cql3.functions.UDFDataType
-
Serialized the specified oject.
- decompose(ProtocolVersion, Object) - Method in class org.apache.cassandra.cql3.functions.UDFunction
-
Used by UDF implementations (both Java code generated by
JavaBasedUDFunction
) to convert the Java object representation for the return value to the C* serialized representation. - decompose(T) - Method in class org.apache.cassandra.db.marshal.AbstractType
- decompose(T...) - Method in class org.apache.cassandra.db.marshal.VectorType
- decomposeAsFloat(float[]) - Method in class org.apache.cassandra.db.marshal.VectorType
- decomposeAsFloat(ValueAccessor<V>, float[]) - Method in class org.apache.cassandra.db.marshal.VectorType
- decomposeRaw(List<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.VectorType
- decomposeRaw(List<V>, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.VectorType
- decomposeUntyped(Object) - Method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- decomposeUntyped(Object) - Method in class org.apache.cassandra.db.marshal.AbstractType
- decomposeVector(ByteBuffer) - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
- 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
- decreaseSlightly() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
- decrement() - Method in class org.apache.cassandra.service.BatchlogResponseHandler.BatchlogCleanup
- decrement() - Method in class org.apache.cassandra.utils.concurrent.CountDownLatch.Async
- decrement() - Method in interface org.apache.cassandra.utils.concurrent.CountDownLatch
-
Count down by 1, signalling waiters if we have reached zero
- decrement() - Method in class org.apache.cassandra.utils.concurrent.CountDownLatch.Sync
- decrement(long) - Method in class org.apache.cassandra.index.sai.utils.NamedMemoryLimiter
- 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
- DEEP - org.apache.cassandra.schema.Difference
-
Two schema objects are considered to differ DEEP-ly if one or more of their nested schema objects differ.
- Default() - Constructor for class org.apache.cassandra.db.guardrails.GuardrailsConfigProvider.Default
- Default() - Constructor for class org.apache.cassandra.service.paxos.BallotGenerator.Default
- Default() - Constructor for class org.apache.cassandra.utils.Clock.Default
- Default(ClassLoader, ThreadGroup, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.cassandra.concurrent.ExecutorFactory.Default
- 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 - Static variable in class org.apache.cassandra.schema.MemtableParams
- DEFAULT - Static variable in interface org.apache.cassandra.transport.QueueBackpressure
- DEFAULT_ALGORITHM - Static variable in class org.apache.cassandra.cql3.functions.masking.HashMaskingFunction
-
The default hashing algorithm to be used if no other algorithm is specified in the call to the function.
- DEFAULT_BASE_SHARD_COUNT - Static variable in class org.apache.cassandra.db.compaction.unified.Controller
-
Default base shard count, used when a base count is not explicitly supplied.
- DEFAULT_BASE_SLEEP - Static variable in class org.apache.cassandra.config.RetrySpec
- DEFAULT_BUCKET_COUNT - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
-
The default number of decayingBuckets.
- DEFAULT_BUCKET_COUNT - Static variable in class org.apache.cassandra.utils.EstimatedHistogram
- 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 - Variable in class org.apache.cassandra.config.Config
-
Default compaction configuration, used if a table does not specify any.
- 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_CONSTRUCTION_BEAM_WIDTH - Static variable in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- 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.TimeWindowCompactionStrategyOptions
- DEFAULT_FAIL_THRESHOLD - Static variable in class org.apache.cassandra.config.ReplicaFilteringProtectionOptions
- DEFAULT_FS_OWNERSHIP_FILENAME - Static variable in class org.apache.cassandra.service.FileSystemOwnershipCheck
- DEFAULT_GRANULARITY - Static variable in class org.apache.cassandra.io.sstable.format.big.BigFormatPartitionWriter
- DEFAULT_HEARTBEAT_FILE - Static variable in class org.apache.cassandra.service.DataResurrectionCheck
- 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_keyspace_rf - Variable in class org.apache.cassandra.config.Config
- 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
andSchemaConstants.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_ATTEMPTS - Static variable in class org.apache.cassandra.config.RetrySpec
- DEFAULT_MAX_POINTS_IN_LEAF_NODE - Static variable in class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeWriter
- DEFAULT_MAX_SLEEP - Static variable in class org.apache.cassandra.config.RetrySpec
- 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_MAXIMUM_NODE_CONNECTIONS - Static variable in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- 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_PADDING_CHAR - Static variable in class org.apache.cassandra.cql3.functions.masking.PartialMaskingFunction
-
The character to be used as padding if no other character is supplied when calling the function.
- 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 - org.apache.cassandra.config.CassandraRelevantProperties
- DEFAULT_PROVIDE_OVERLAPPING_TOMBSTONES_PROPERTY_VALUE - Static variable in class org.apache.cassandra.schema.CompactionParams
- default_secondary_index - Variable in class org.apache.cassandra.config.Config
- default_secondary_index_enabled - Variable in class org.apache.cassandra.config.Config
- DEFAULT_SEGMENT_BUFFER_MB - Static variable in class org.apache.cassandra.config.StorageAttachedIndexOptions
- DEFAULT_SIMILARITY_FUNCTION - Static variable in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- 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_SUPERUSER_NAME - Static variable in class org.apache.cassandra.auth.CassandraRoleManager
- DEFAULT_SUPERUSER_PASSWORD - Static variable in class org.apache.cassandra.auth.CassandraRoleManager
- DEFAULT_TARGET_SSTABLE_SIZE - Static variable in class org.apache.cassandra.db.compaction.unified.Controller
- DEFAULT_TARGET_STORETYPE - Static variable in class org.apache.cassandra.security.PEMBasedSslContextFactory
- DEFAULT_THRESHOLDS - Static variable in class org.apache.cassandra.schema.CompactionParams
- DEFAULT_TIME_TO_LIVE - org.apache.cassandra.schema.TableParams.Option
- DEFAULT_TIMER_UNIT - Static variable in class org.apache.cassandra.metrics.CassandraMetricsRegistry
- 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_WRITER_OPTION - Static variable in class org.apache.cassandra.index.sai.disk.io.IndexFileUtils
- DEFAULT_ZERO_CONSIDERATION - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
- DefaultArgumentDeserializer(AbstractType<?>) - Constructor for class org.apache.cassandra.db.marshal.AbstractType.DefaultArgumentDeserializer
- defaultBuilder() - Method in class org.apache.cassandra.io.sstable.SSTableIdFactory
-
Returns default identifiers builder.
- 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, int) - Constructor for class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
- DefaultCryptoProvider - Class in org.apache.cassandra.security
-
Default crypto provider tries to install AmazonCorrettoCryptoProvider.
- DefaultCryptoProvider(Map<String, String>) - Constructor for class org.apache.cassandra.security.DefaultCryptoProvider
- defaultDiskAccessMode - Variable in class org.apache.cassandra.io.sstable.IOOptions
- defaultExpirationInterval() - Static method in class org.apache.cassandra.net.RequestCallbacks
- DefaultFSErrorHandler - Class in org.apache.cassandra.service
- DefaultFSErrorHandler() - Constructor for class org.apache.cassandra.service.DefaultFSErrorHandler
- defaultLoader() - Static method in class org.apache.cassandra.config.Properties
- DefaultLoader - Class in org.apache.cassandra.config
- DefaultLoader() - Constructor for class org.apache.cassandra.config.DefaultLoader
- DefaultMaskingFunction - Class in org.apache.cassandra.cql3.functions.masking
-
A
MaskingFunction
that returns a fixed replacement value for the data type of its single argument. - 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.DataPathsPrinter.DefaultPrinter
- DefaultPrinter() - Constructor for class org.apache.cassandra.tools.nodetool.stats.TpStatsPrinter.DefaultPrinter
- Defaults() - Constructor for class org.apache.cassandra.utils.concurrent.Awaitable.Defaults
- DefaultSchemaUpdateHandler - Class in org.apache.cassandra.schema
- DefaultSchemaUpdateHandler(BiConsumer<SchemaTransformation.SchemaTransformationResult, Boolean>) - Constructor for class org.apache.cassandra.schema.DefaultSchemaUpdateHandler
- DefaultSchemaUpdateHandler(MigrationCoordinator, MessagingService, boolean, BiConsumer<SchemaTransformation.SchemaTransformationResult, Boolean>) - Constructor for class org.apache.cassandra.schema.DefaultSchemaUpdateHandler
- DefaultSchemaUpdateHandlerFactory - Class in org.apache.cassandra.schema
- DefaultSchemaUpdateHandlerFactory() - Constructor for class org.apache.cassandra.schema.DefaultSchemaUpdateHandlerFactory
- DefaultSslContextFactory - Class in org.apache.cassandra.security
-
Cassandra's default implementation class for the configuration key
ssl_context_factory
. - DefaultSslContextFactory(Map<String, Object>) - Constructor for class org.apache.cassandra.security.DefaultSslContextFactory
- 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 - Variable in class org.apache.cassandra.schema.TableParams
- defaultTimeToLive(int) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- defaultTimeToLive(int) - Method in class org.apache.cassandra.schema.TableParams.Builder
- DefaultValue<T> - Class in org.apache.cassandra.utils
- DefaultValue(T) - Constructor for class org.apache.cassandra.utils.DefaultValue
- DeferredLongArray(Supplier<LongArray>) - Constructor for class org.apache.cassandra.index.sai.disk.v1.LongArray.DeferredLongArray
- 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
- delay(TimeUnit) - Method in class org.apache.cassandra.transport.QueueBackpressure.Incident
- 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(List<Term>) - Constructor for class org.apache.cassandra.cql3.Lists.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
- DelayedValue(VectorType<T>, List<Term>) - Constructor for class org.apache.cassandra.cql3.Vectors.DelayedValue
- delegate() - Method in class org.apache.cassandra.config.ForwardingProperty
- delegate() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- DelegatingMbeanWrapper(MBeanWrapper) - Constructor for class org.apache.cassandra.utils.MBeanWrapper.DelegatingMbeanWrapper
- 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() - Method in class org.apache.cassandra.db.SimpleBuilders.PartitionUpdateBuilder
- delete() - Method in class org.apache.cassandra.db.SimpleBuilders.RowBuilder
- delete() - Method in class org.apache.cassandra.io.util.File
-
This file will be deleted, with any failures being reported with an FSError
- delete(RateLimiter) - Method in class org.apache.cassandra.io.util.File
-
This file will be deleted, obeying the provided rate limiter.
- delete(String) - Method in interface org.apache.cassandra.db.rows.Row.SimpleBuilder
-
Removes the value for a given column (creating a tombstone).
- delete(String) - Method in class org.apache.cassandra.db.SimpleBuilders.RowBuilder
- delete(String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Deprecated.See CASSANDRA-16926
- delete(Throwable) - Method in class org.apache.cassandra.io.util.File
-
This file will be deleted, and any exceptions encountered merged with
accumulate
to the return value - delete(Throwable, RateLimiter) - Method in class org.apache.cassandra.io.util.File
-
This file will be deleted, obeying the provided rate limiter.
- delete(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- delete(Path, RateLimiter) - Static method in class org.apache.cassandra.io.util.PathUtils
- delete(Path, Throwable) - Static method in class org.apache.cassandra.io.util.PathUtils
- delete(Path, Throwable, RateLimiter) - Static method in class org.apache.cassandra.io.util.PathUtils
- delete(ColumnData) - Method in class org.apache.cassandra.db.partitions.BTreePartitionUpdater
- delete(ColumnData) - Method in interface org.apache.cassandra.db.rows.ColumnData.PostReconciliationFunction
- delete(Descriptor) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- delete(Descriptor) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- delete(Descriptor) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
Deletes the existing components of the sstables represented by the provided descriptor.
- delete(File...) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Deprecated.See CASSANDRA-16926
- DELETE - org.apache.cassandra.audit.AuditLogEntryType
- DELETE - org.apache.cassandra.cql3.statements.StatementType
- 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(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).
- deleteAllHintsForEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.hints.HintsService
-
Deletes all hints for the provided destination.
- deleteColumnIndex(IndexTermType, IndexIdentifier) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- 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.
- deleteIfExists() - Method in class org.apache.cassandra.io.util.File
-
This file will be deleted, with any failures being reported with an FSError
- deleteIfExists(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- deleteOldLinkedCDCCommitLogSegment(long) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegmentManagerCDC
-
Delete the oldest hard-linked CDC commit log segment to free up space.
- deleteOnExit() - Method in class org.apache.cassandra.io.util.File
-
Try to delete the file on process exit.
- deleteOnExit(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
-
Schedules deletion of the file only on JVM shutdown.
- deleteOrphanedComponents(Descriptor, Set<Component>) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- deleteOrphanedComponents(Descriptor, Set<Component>) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- deleteOrphanedComponents(Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- deleteOrphanedComponents(Descriptor, Set<Component>) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
- deletePartition(UnfilteredRowIterator, long) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Delete all data from all indexes for this partition.
- deletePerSSTableIndexComponents() - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- deletePrevious() - Method in interface org.apache.cassandra.db.rows.Row.SimpleBuilder
-
Deletes the whole row with a timestamp that is just before the new data's timestamp, to make sure no expired data remains on the row.
- deletePrevious() - Method in class org.apache.cassandra.db.SimpleBuilders.RowBuilder
- Deleter(ColumnMetadata) - Constructor for class org.apache.cassandra.cql3.Constants.Deleter
- DeleterByField(ColumnMetadata, FieldIdentifier) - Constructor for class org.apache.cassandra.cql3.UserTypes.DeleterByField
- deleteRecursive() - Method in class org.apache.cassandra.io.util.File
-
Deletes all files and subdirectories under "dir".
- deleteRecursive(RateLimiter) - Method in class org.apache.cassandra.io.util.File
-
Deletes all files and subdirectories under "dir".
- deleteRecursive(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
-
Deletes all files and subdirectories under "path".
- deleteRecursive(Path, RateLimiter) - Static method in class org.apache.cassandra.io.util.PathUtils
-
Deletes all files and subdirectories under "path".
- deleteRecursive(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Deprecated.See CASSANDRA-16926
- deleteRecursiveOnExit() - Method in class org.apache.cassandra.io.util.File
-
This file will be deleted on clean shutdown; if it is a directory, its entire contents at the time of shutdown will be deleted
- deleteRecursiveOnExit(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
-
Schedules deletion of all file and subdirectories under "dir" on JVM shutdown.
- deleteRecursiveOnExit(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Deprecated.See CASSANDRA-16926
- deleteRecursiveWithThrottle(File, RateLimiter) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Deprecated.See CASSANDRA-16926
- deletes(long) - Method in class org.apache.cassandra.db.DeletionTime
- deletes(LivenessInfo) - 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.DeletionTime
- deletes(Cell<?>) - Method in class org.apache.cassandra.db.rows.Row.Deletion
- deleteSession(TimeUUID) - 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) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Deprecated.See CASSANDRA-16926
- deleteWithConfirm(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Deprecated.See CASSANDRA-16926
- deleteWithConfirm(File, Throwable) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Deprecated.See CASSANDRA-16926
- deleteWithConfirm(File, Throwable, RateLimiter) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Deprecated.See CASSANDRA-16926
- 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(long) - Static method in class org.apache.cassandra.tools.SSTableMetadataViewer
- Deletion(DeletionTime, boolean) - Constructor for class org.apache.cassandra.db.rows.Row.Deletion
- 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
- DeletionInfo - Interface in org.apache.cassandra.db
-
A combination of a top-level (partition) tombstone and range tombstones describing the deletions within a partition.
- DeletionPurger - Interface in org.apache.cassandra.db
- deletionTime() - Method in class org.apache.cassandra.cql3.UpdateParameters
- deletionTime() - Method in class org.apache.cassandra.db.RangeTombstone
-
The deletion time for this (range) tombstone.
- deletionTime() - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
-
The deletion time for the range tombstone this is a bound of.
- deletionTime() - Method in class org.apache.cassandra.io.sstable.AbstractRowIndexEntry
- deletionTime() - Method in class org.apache.cassandra.io.sstable.format.big.RowIndexEntry
- DeletionTime - Class in org.apache.cassandra.db
-
Information on deletion of a storage engine object.
- DeletionTime.InvalidDeletionTime - Class in org.apache.cassandra.db
- DeletionTime.LegacySerializer - Class in org.apache.cassandra.db
- DeletionTime.Serializer - Class in org.apache.cassandra.db
- deletionTimeLongToUnsignedInteger(long) - Static method in class org.apache.cassandra.db.rows.Cell
- deletionTimeSerializedSize(DeletionTime) - Method in class org.apache.cassandra.db.SerializationHeader
- deletionTimeUnsignedIntegerToLong(int) - Static method in class org.apache.cassandra.db.rows.Cell
- DELIMITER - Static variable in class org.apache.cassandra.config.Properties
- 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
- deltaBytes - Variable in class org.apache.cassandra.streaming.ProgressInfo
- 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}}
- DENSE - org.apache.cassandra.schema.TableMetadata.Flag
- density(SSTableReader) - Method in interface org.apache.cassandra.db.compaction.ShardManager
-
Return the density of an SSTable, i.e.
- denylist_consistency_level - Variable in class org.apache.cassandra.config.Config
-
Since the denylist in many ways serves to protect the health of the cluster from partitions operators have identified as being in a bad state, we usually want more robustness than just CL.ONE on operations to/from these tables to ensure that these safeguards are in place.
- denylist_initial_load_retry - Variable in class org.apache.cassandra.config.Config
- denylist_max_keys_per_table - Variable in class org.apache.cassandra.config.Config
-
We cap the number of denylisted keys allowed per table to keep things from growing unbounded.
- denylist_max_keys_total - Variable in class org.apache.cassandra.config.Config
-
We cap the total number of denylisted keys allowed in the cluster to keep things from growing unbounded.
- denylist_range_reads_enabled - Variable in class org.apache.cassandra.config.Config
- denylist_reads_enabled - Variable in class org.apache.cassandra.config.Config
- denylist_refresh - Variable in class org.apache.cassandra.config.Config
- denylist_writes_enabled - Variable in class org.apache.cassandra.config.Config
- denylistKey(String, String, String) - Method in class org.apache.cassandra.service.StorageProxy
-
Actively denies read and write access to the provided Partition Key
- denylistKey(String, String, String) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- DenylistMetrics - Class in org.apache.cassandra.metrics
- DenylistMetrics() - Constructor for class org.apache.cassandra.metrics.DenylistMetrics
- deoverlap(List<Range<T>>) - Static method in class org.apache.cassandra.dht.Range
-
Given a list of unwrapped ranges sorted by left position, return an equivalent list of ranges but with no overlapping ranges.
- dependsOn(Function) - Method in class org.apache.cassandra.schema.TableMetadata
- 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.sai.StorageAttachedIndex
- dependsOn(ColumnMetadata) - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
- dependsOn(ColumnMetadata) - Method in class org.apache.cassandra.index.sasi.SASIIndex
- dependsOn(ColumnMetadata) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- deprecated - Variable in class org.apache.cassandra.config.Replacement
- deprecated() - Method in annotation type org.apache.cassandra.config.Replaces
- DEPRECATED_CACHE_NAME - Static variable in interface org.apache.cassandra.auth.jmx.AuthorizationProxy.JmxPermissionsCacheMBean
-
Deprecated.See CASSANDRA-16404
- DEPRECATED_CACHE_NAME - Static variable in interface org.apache.cassandra.auth.NetworkPermissionsCacheMBean
-
Deprecated.See CASSANDRA-16404
- DEPRECATED_MBEAN_NAME - Static variable in class org.apache.cassandra.db.DisallowedDirectories
- depth - Variable in class org.apache.cassandra.utils.MerkleTree.TreeRange
- depth() - Method in interface org.apache.cassandra.db.tries.Trie.Cursor
- depth(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
- deriveIfOpenSslAvailable() - Method in class org.apache.cassandra.security.AbstractSslContextFactory
-
Dervies if
OpenSSL
is available. - deriveSession(StreamMessage) - Method in class org.apache.cassandra.streaming.StreamDeserializingTask
- desc - Variable in class org.apache.cassandra.cache.KeyCacheKey
- 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.state.JobState
- desc - Variable in class org.apache.cassandra.repair.state.SyncState.Id
- desc - Variable in class org.apache.cassandra.repair.state.ValidationState
- 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
- DESC - org.apache.cassandra.cql3.Ordering.Direction
- DESC - org.apache.cassandra.index.sasi.disk.OnDiskIndex.IteratorOrder
- DESC - org.apache.cassandra.schema.ColumnMetadata.ClusteringOrder
- DESC - 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
- DESCRIBE - org.apache.cassandra.audit.AuditLogEntryType
- DESCRIBE - org.apache.cassandra.auth.Permission
- 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.See CASSANDRA-7544
- 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 - Variable in class org.apache.cassandra.metrics.SamplingManager.ResultBuilder
- description() - Method in interface org.apache.cassandra.concurrent.DebuggableTask
- description() - Method in class org.apache.cassandra.concurrent.DebuggableTask.RunningDebuggableTask
- description() - Method in class org.apache.cassandra.concurrent.FutureTask
- description() - Method in class org.apache.cassandra.concurrent.SyncFutureTask
- description() - Method in enum org.apache.cassandra.config.EncryptionOptions.TlsEncryptionPolicy
- description() - Method in class org.apache.cassandra.service.StorageProxy.LocalReadRunnable
- description() - Method in class org.apache.cassandra.streaming.async.NettyStreamingChannel
- description() - Method in interface org.apache.cassandra.streaming.StreamingChannel
- description() - Method in class org.apache.cassandra.transport.Dispatcher.RequestProcessor
- description() - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- descriptor - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegment
- descriptor - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
- descriptor - Variable in class org.apache.cassandra.io.sstable.format.SortedTableWriter.AbstractIndexWriter
- descriptor - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderLoadingBuilder
- descriptor - Variable in class org.apache.cassandra.io.sstable.SSTable.Builder
- descriptor - Variable in class org.apache.cassandra.io.sstable.SSTable
- descriptor() - Method in class org.apache.cassandra.index.sai.SSTableContext
- Descriptor - Class in org.apache.cassandra.index.sasi.disk
-
Object descriptor for SASIIndex files.
- Descriptor - Class in org.apache.cassandra.io.sstable
-
A SSTable is described by the keyspace and column family it contains data for, an id (generation - where higher generations contain more recent data) and an alphabetic version string.
- Descriptor(String) - Constructor for class org.apache.cassandra.index.sasi.disk.Descriptor
- Descriptor(String, File, String, String, SSTableId, SSTableFormat<?, ?>) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
- Descriptor(Version, File, String, String, SSTableId) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
- Descriptor(File, String, String, SSTableId) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
-
A descriptor that assumes CURRENT_VERSION.
- Descriptor(File, String, String, SSTableId, SSTableFormat<?, ?>) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
-
Constructor for sstable writers only.
- Descriptor.Version - Class in org.apache.cassandra.index.sasi.disk
- DeserializationHelper - Class in org.apache.cassandra.db.rows
- DeserializationHelper(TableMetadata, int, DeserializationHelper.Flag) - Constructor for class org.apache.cassandra.db.rows.DeserializationHelper
- DeserializationHelper(TableMetadata, int, DeserializationHelper.Flag, ColumnFilter) - 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(byte) - Static method in enum org.apache.cassandra.tracing.Tracing.TraceType
- deserialize(byte[]) - Static method in class org.apache.cassandra.service.paxos.Ballot
- deserialize(int) - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
- deserialize(int) - Static method in enum org.apache.cassandra.streaming.PreviewKind
- deserialize(int) - Static method in enum org.apache.cassandra.transport.Envelope.Header.Flag
- deserialize(I) - Method in interface org.apache.cassandra.io.IGenericSerializer
- deserialize(ByteBuf, ProtocolVersion) - Static method in class org.apache.cassandra.transport.Event
- deserialize(I, boolean) - Static method in class org.apache.cassandra.utils.obs.OffHeapBitSet
- deserialize(I, ValueAccessor<I>) - Method in class org.apache.cassandra.serializers.MapSerializer
- deserialize(DataInput) - Static method in class org.apache.cassandra.schema.TableId
- deserialize(DataInput) - Static method in class org.apache.cassandra.utils.TimeUUID
- deserialize(DataInput, IPartitioner, int) - Method in class org.apache.cassandra.db.PartitionPosition.RowPositionSerializer
- 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(ByteBuffer) - Method in class org.apache.cassandra.serializers.TypeSerializer
- deserialize(ByteBuffer) - Static method in class org.apache.cassandra.service.paxos.Ballot
- deserialize(ByteBuffer) - Static method in class org.apache.cassandra.utils.TimeUUID
- deserialize(ByteBuffer, int) - Method in class org.apache.cassandra.db.DeletionTime.LegacySerializer
- deserialize(ByteBuffer, int) - Method in class org.apache.cassandra.db.DeletionTime.Serializer
- deserialize(ByteBuffer, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Clustering.Serializer
- 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(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(LZ4SafeDecompressor, DataInputPlus, int) - Method in class org.apache.cassandra.streaming.async.StreamCompressionSerializer
- deserialize(IPartitioner, DataInput) - Static method in class org.apache.cassandra.gms.TokenSerializer
- deserialize(Descriptor, EnumSet<MetadataType>) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
-
Deserialize specified metadata components from given descriptor.
- deserialize(Descriptor, EnumSet<MetadataType>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
- deserialize(Descriptor, MetadataType) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
-
Deserialized only metadata component specified from given descriptor.
- 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.db.SerializationHeader.Serializer
- 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(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) - Method in class org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.cache.SerializingCacheProvider.RowCacheSerializer
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.db.commitlog.CommitLogPosition.CommitLogPositionSerializer
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.db.DeletionTime.LegacySerializer
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.db.DeletionTime.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) - Method in interface org.apache.cassandra.io.ISerializer
-
Deserialize from the specified DataInput instance.
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.io.sstable.IndexInfo.Serializer
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.serializers.AbstractTypeSerializer
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.service.CacheService.CounterCacheSerializer
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.service.CacheService.KeyCacheSerializer
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.service.CacheService.RowCacheSerializer
- deserialize(DataInputPlus) - Static method in class org.apache.cassandra.service.paxos.Ballot
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram.HistogramSerializer
- deserialize(DataInputPlus) - Method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram.LegacyHistogramSerializer
- deserialize(DataInputPlus.DataInputStreamPlus) - Method in class org.apache.cassandra.utils.BloomFilterSerializer
- deserialize(DataInputPlus, boolean, int) - Static method in class org.apache.cassandra.utils.MerkleTree
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.batchlog.Batch.Serializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.db.CounterMutation.CounterMutationSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.db.Mutation.MutationSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.db.ReadCommand.Serializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.CassandraStreamHeaderSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.exceptions.RequestFailureReason.Serializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.gms.GossipShutdown.Serializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.hints.HintMessage.Serializer
- deserialize(DataInputPlus, int) - Method in interface org.apache.cassandra.io.IVersionedAsymmetricSerializer
-
Deserialize into the specified DataInputStream instance.
- 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, int) - Method in class org.apache.cassandra.repair.SyncNodePair.NodePairSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.schema.SchemaMutationsSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.paxos.Ballot.Serializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosStartPrepareCleanup.RequestSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.paxos.Commit.CommitSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.paxos.PaxosCommitAndPrepare.RequestSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.paxos.PaxosPrepare.RequestSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.paxos.PaxosPrepare.ResponseSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.paxos.PaxosPrepareRefresh.RequestSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.paxos.PaxosPrepareRefresh.ResponseSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.paxos.PaxosPropose.RequestSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.paxos.PaxosPropose.ResponseSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.paxos.PaxosRepair.RequestSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.paxos.PaxosRepair.ResponseSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
- 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(DataInputPlus, int) - Method in class org.apache.cassandra.streaming.StreamRequest.StreamRequestSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.streaming.StreamSummary.StreamSummarySerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.BooleanSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.Int32Serializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.Int64Serializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
-
Deserialize an IntervalTree whose keys use the natural ordering.
- deserialize(DataInputPlus, int) - Static method in class org.apache.cassandra.utils.MerkleTree
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.MerkleTrees.MerkleTreesSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.RangesSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.TimeUUID.Serializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
- deserialize(DataInputPlus, int) - Method in class org.apache.cassandra.utils.VoidSerializer
- deserialize(DataInputPlus, int, boolean, int, boolean, TableMetadata, long, ColumnFilter, RowFilter, DataLimits, Index.QueryPlan) - Method in class org.apache.cassandra.db.ReadCommand.SelectionDeserializer
- deserialize(DataInputPlus, int, Comparator<C>) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
- deserialize(DataInputPlus, int, Function<TableId, IPartitioner>) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.CassandraStreamHeaderSerializer
- deserialize(DataInputPlus, 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, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Slice.Serializer
- deserialize(DataInputPlus, int, ClusteringComparator) - Method in class org.apache.cassandra.db.aggregation.GroupingState.Serializer
- deserialize(DataInputPlus, int, DeserializationHelper.Flag) - Method in class org.apache.cassandra.db.Mutation.MutationSerializer
- deserialize(DataInputPlus, int, DeserializationHelper.Flag) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.PartitionUpdateSerializer
- deserialize(DataInputPlus, int, TableMetadata) - Method in class org.apache.cassandra.cql3.selection.Selector.SelectorDeserializer
- deserialize(DataInputPlus, int, TableMetadata) - Method in class org.apache.cassandra.cql3.selection.Selector.Serializer
- deserialize(DataInputPlus, int, TableMetadata) - Method in class org.apache.cassandra.db.aggregation.AggregationSpecification.Serializer
- deserialize(DataInputPlus, int, TableMetadata) - Method in class org.apache.cassandra.db.DataRange.Serializer
- 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, TableMetadata) - Method in class org.apache.cassandra.db.filter.DataLimits.Serializer
- deserialize(DataInputPlus, int, TableMetadata) - Method in class org.apache.cassandra.db.filter.RowFilter.UserExpression.Deserializer
- deserialize(DataInputPlus, int, TableMetadata) - Method in class org.apache.cassandra.db.Slices.Serializer
- deserialize(DataInputPlus, int, TableMetadata) - Method in class org.apache.cassandra.schema.IndexMetadata.Serializer
- deserialize(DataInputPlus, int, TableMetadata, boolean) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter.InternalDeserializer
- deserialize(DataInputPlus, int, TableMetadata, boolean) - Method in class org.apache.cassandra.db.filter.RowFilter.Serializer
- deserialize(DataInputPlus, int, TableMetadata, ColumnFilter, DeserializationHelper.Flag) - Method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators.Serializer
- deserialize(DataInputPlus, int, TableMetadata, ColumnFilter, DeserializationHelper.Flag) - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
- deserialize(DataInputPlus, int, TableMetadata, DeserializationHelper.Flag, UnfilteredRowIteratorSerializer.Header) - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
- deserialize(DataInputPlus, long) - Method in interface org.apache.cassandra.io.sstable.format.big.RowIndexEntry.IndexSerializer
- deserialize(DataInputPlus, long) - Method in class org.apache.cassandra.io.sstable.format.big.RowIndexEntry.Serializer
- deserialize(DataInputPlus, SerializationHeader, DeserializationHelper, Row.Builder) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
-
Deserialize an
Unfiltered
from the provided input. - 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, TableMetadata) - Method in class org.apache.cassandra.db.Columns.Serializer
- deserialize(FileDataInput) - Method in interface org.apache.cassandra.io.sstable.format.big.RowIndexEntry.IndexSerializer
- deserialize(RandomAccessReader) - Method in interface org.apache.cassandra.io.sstable.format.big.RowIndexEntry.IndexSerializer
- deserialize(ProtocolVersion, ByteBuffer) - Method in interface org.apache.cassandra.cql3.functions.ArgumentDeserializer
-
Deserializes the specified function argument.
- deserialize(ProtocolVersion, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType.DefaultArgumentDeserializer
- deserialize(ProtocolVersion, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.NumberType.NumberArgumentDeserializer
- deserialize(R, DataInputPlus) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat.KeyCacheValueSerializer
- deserialize(T, IPartitioner, int, int) - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummary.IndexSummarySerializer
- 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.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.ListSerializer
- deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.LongSerializer
- deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.SetSerializer
- 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(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.UUIDSerializer
- deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.service.paxos.Ballot.Serializer
- deserialize(V, ValueAccessor<V>) - Method in class org.apache.cassandra.utils.TimeUUID.Serializer
- 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)
). - deserializeBloomFilter(SSTableReader) - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- deserializeCollection(IVersionedSerializer<V>, IntFunction<C>, DataInputPlus, int) - Static method in class org.apache.cassandra.utils.CollectionSerializer
- deserializeEvent(ByteBuf, ProtocolVersion) - Static method in class org.apache.cassandra.transport.Event.SchemaChange
- deserializeFirstLastKey(DataInputPlus.DataInputStreamPlus, IPartitioner) - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummary.IndexSummarySerializer
-
Deserializes the first and last key stored in the summary
- deserializeForCache(DataInputPlus) - Method in interface org.apache.cassandra.io.sstable.format.big.RowIndexEntry.IndexSerializer
- deserializeForCache(DataInputPlus) - Method in class org.apache.cassandra.io.sstable.format.big.RowIndexEntry.Serializer
- deserializeForMessaging(DataInputPlus, TableMetadata, ColumnFilter, boolean) - Method in class org.apache.cassandra.db.SerializationHeader.Serializer
- deserializeFromJsonFile(Class<T>, File) - Static method in class org.apache.cassandra.utils.JsonUtils
- deserializeFromJsonFile(File) - Static method in class org.apache.cassandra.service.DataResurrectionCheck.Heartbeat
- deserializeFromJsonFile(File) - Static method in class org.apache.cassandra.service.snapshot.SnapshotManifest
- deserializeHeader(TableMetadata, ColumnFilter, DataInputPlus, int, DeserializationHelper.Flag) - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
- deserializeKeyCacheValue(DataInputPlus) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- deserializeKeyCacheValue(DataInputPlus) - Method in interface org.apache.cassandra.io.sstable.keycache.KeyCacheSupport
- deserializeList(DataInputPlus) - Method in class org.apache.cassandra.serializers.AbstractTypeSerializer
- deserializeMap(IVersionedSerializer<K>, IVersionedSerializer<V>, IntFunction<M>, DataInputPlus, int) - Static method in class org.apache.cassandra.utils.CollectionSerializer
- deserializeMarkerBody(DataInputPlus, SerializationHeader, ClusteringBoundOrBoundary<?>) - Method in class org.apache.cassandra.db.rows.UnfilteredSerializer
- deserializeMetadata(DataInputPlus) - Method in class org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
- deserializeMetadata(DataInputPlus) - Method in class org.apache.cassandra.service.CacheService.KeyCacheSerializer
- 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
- deserializeNullable(IVersionedSerializer<T>, DataInputPlus, int) - Static method in class org.apache.cassandra.utils.NullableSerializer
- deserializePositionAndSkip(DataInputPlus) - Method in interface org.apache.cassandra.io.sstable.format.big.RowIndexEntry.IndexSerializer
- deserializePositionAndSkip(DataInputPlus) - Method in class org.apache.cassandra.io.sstable.format.big.RowIndexEntry.Serializer
- deserializer - Static variable in class org.apache.cassandra.cql3.selection.SimpleSelector
- deserializer - Static variable in class org.apache.cassandra.cql3.selection.TermSelector
- deserializer - Static variable in class org.apache.cassandra.cql3.selection.VectorSelector
- deserializer - Variable in enum org.apache.cassandra.db.filter.ClusteringIndexFilter.Kind
- deserializer - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableIterator.AbstractReader
- Deserializer() - Constructor for class org.apache.cassandra.db.filter.RowFilter.UserExpression.Deserializer
- Deserializer(ClusteringComparator, DataInputPlus, SerializationHeader) - Constructor for class org.apache.cassandra.db.ClusteringPrefix.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
- dest - Variable in class org.apache.cassandra.io.tries.IncrementalTrieWriterBase
- destination - Variable in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- 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
- determanisticId() - Method in class org.apache.cassandra.repair.RepairJobDesc
- DETERMINISM_SSTABLE_COMPRESSION_DEFAULT - org.apache.cassandra.config.CassandraRelevantProperties
-
determinism properties for testing
- DETERMINISM_UNSAFE_UUID_NODE - org.apache.cassandra.config.CassandraRelevantProperties
- dfile - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
- dfile - Variable in class org.apache.cassandra.io.sstable.format.SSTableScanner
- diagnostic_events_enabled - Variable in class org.apache.cassandra.config.Config
- DIAGNOSTIC_SNAPSHOT_INTERVAL_NANOS - org.apache.cassandra.config.CassandraRelevantProperties
- 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
DiagnosticEvent
s. - 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
DiagnosticEvent
s. - 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.
- die - org.apache.cassandra.config.Config.CommitFailurePolicy
- die - org.apache.cassandra.config.Config.DiskFailurePolicy
- die - org.apache.cassandra.config.Config.UserFunctionTimeoutPolicy
- die_immediate - org.apache.cassandra.config.Config.UserFunctionTimeoutPolicy
- diff - Variable in class org.apache.cassandra.schema.SchemaTransformation.SchemaTransformationResult
- 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 multipleinputs
, signals the difference between each input andmerged
todiffListener
. - diff(Keyspaces, Keyspaces) - Static method in class org.apache.cassandra.schema.Keyspaces
- Diff<T extends java.lang.Iterable,S> - Class in org.apache.cassandra.schema
- 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(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.
- Difference - Enum in org.apache.cassandra.schema
- 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
- differences - Variable in class org.apache.cassandra.repair.SyncStat
- 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
- diffPoint(ByteComparable, ByteComparable, ByteComparable.Version) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteComparable
-
Returns the length of the minimum prefix that differentiates the two given byte-comparable representations.
- digest() - Method in class org.apache.cassandra.db.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(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(Digest) - Method in class org.apache.cassandra.db.LivenessInfo
-
Adds this liveness information to the provided digest.
- 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) - 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(Digest) - Method in interface org.apache.cassandra.db.rows.Unfiltered
-
Digest the atom using the provided
Digest
. - digest(Digest, ColumnData) - Static method in class org.apache.cassandra.db.rows.ColumnData
- 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(RowIterator, Digest) - Static method in class org.apache.cassandra.db.rows.RowIterators
- digest(UnfilteredRowIterator, Digest, int) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
-
Digests the partition represented by the provided iterator.
- digest(V, int, int, Digest) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
updates {@param digest} with {@param size} bytes from the contents of {@param value} starting at offset {@param offset}
- digest(V, Digest) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
updates {@param digest} with te contents of {@param value}
- Digest - Class in org.apache.cassandra.db
- DIGEST - Static variable in class org.apache.cassandra.io.sstable.format.SSTableFormat.Components
- DIGEST - Static variable in class org.apache.cassandra.io.sstable.format.SSTableFormat.Components.Types
- 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,P>> - Class in org.apache.cassandra.service.reads
- DigestResolver(ReadCommand, ReplicaPlan.Shared<E, P>, Dispatcher.RequestTime) - 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.
- dimension - Variable in class org.apache.cassandra.db.marshal.TypeParser.Vector
- dimension - Variable in class org.apache.cassandra.db.marshal.VectorType
- dimension() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.CompactionVectorValues
- dimension() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.ConcurrentVectorValues
- direct - org.apache.cassandra.config.Config.DiskAccessMode
-
Direct-I/O is enabled for commitlog disk only.
- DirectBufferRef(T, RefCounted.Tidy) - Constructor for class org.apache.cassandra.utils.concurrent.Ref.DirectBufferRef
- direction - Variable in class org.apache.cassandra.cql3.Ordering
- direction - Variable in class org.apache.cassandra.streaming.ProgressInfo
- direction - Variable in enum org.apache.cassandra.transport.Message.Type
- DirectIOSegment - Class in org.apache.cassandra.db.commitlog
- DirectIOSegment.DirectIOSegmentBuilder - Class in org.apache.cassandra.db.commitlog
- DirectIOSegmentBuilder(AbstractCommitLogSegmentManager) - Constructor for class org.apache.cassandra.db.commitlog.DirectIOSegment.DirectIOSegmentBuilder
- DirectIOSegmentBuilder(AbstractCommitLogSegmentManager, int) - Constructor for class org.apache.cassandra.db.commitlog.DirectIOSegment.DirectIOSegmentBuilder
- directories - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
- directories - Variable in class org.apache.cassandra.db.DiskBoundaries
- 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.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.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() - Constructor for class org.apache.cassandra.utils.DirectorySizeCalculator
- DirectReaders - Class in org.apache.cassandra.index.sai.disk.v1
- DirectReaders() - Constructor for class org.apache.cassandra.index.sai.disk.v1.DirectReaders
- 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() - Method in class org.apache.cassandra.metrics.Sampler
- disable(StartupChecks.StartupCheckType) - Method in class org.apache.cassandra.config.StartupChecksOptions
- DISABLE_AUTH_CACHES_REMOTE_CONFIGURATION - org.apache.cassandra.config.CassandraRelevantProperties
- DISABLE_GOSSIP_ENDPOINT_REMOVAL - org.apache.cassandra.config.CassandraRelevantProperties
-
properties to disable certain behaviours for testing
- DISABLE_PAXOS_AUTO_REPAIRS - org.apache.cassandra.config.CassandraRelevantProperties
- DISABLE_PAXOS_STATE_FLUSH - org.apache.cassandra.config.CassandraRelevantProperties
- DISABLE_SSTABLE_ACTIVITY_TRACKING - org.apache.cassandra.config.CassandraRelevantProperties
- DISABLE_STCS_IN_L0 - org.apache.cassandra.config.CassandraRelevantProperties
- DISABLE_TCACTIVE_OPENSSL - org.apache.cassandra.config.CassandraRelevantProperties
- 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() - Method in class org.apache.cassandra.service.StorageService
- 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 - org.apache.cassandra.config.Config.CorruptedTombstoneStrategy
- disabled() - Static method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
- disabled() - Method in enum org.apache.cassandra.utils.StorageCompatibilityMode
- DISABLED - Static variable in class org.apache.cassandra.config.RetrySpec.MaxAttempt
- DISABLED_ERROR_MESSAGE - Static variable in class org.apache.cassandra.cql3.functions.masking.ColumnMask
- disabledByDefault - Variable in enum org.apache.cassandra.service.StartupChecks.StartupCheckType
- 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
- DisableSslContextFactory - Class in org.apache.cassandra.security
- DisableSslContextFactory() - Constructor for class org.apache.cassandra.security.DisableSslContextFactory
- 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() - Method in class org.apache.cassandra.db.memtable.AbstractAllocatorMemtable
- discard() - Method in class org.apache.cassandra.db.memtable.AbstractMemtableWithCommitlog
- discard() - Method in interface org.apache.cassandra.db.memtable.Memtable
-
This memtable is no longer in use or required for outstanding flushes or operations.
- discard() - Method in class org.apache.cassandra.db.memtable.TrieMemtable
- 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.
- 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 - org.apache.cassandra.concurrent.ExecutorFactory.SimulatorSemantics
- DISCARD_HANDLER_NAME - Static variable in class org.apache.cassandra.net.InternodeConnectionUtils
- discardBuffers() - Method in class org.apache.cassandra.db.tries.InMemoryTrie
- 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.sai.memory.MemtableIndexManager
- 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.
- discoverComponents() - Method in class org.apache.cassandra.io.sstable.Descriptor
- DISJOINT - org.apache.cassandra.db.context.CounterContext.Relationship
- 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
- DISK_USAGE - org.apache.cassandra.gms.ApplicationState
- DISK_USAGE_MONITOR_INTERVAL_MS - org.apache.cassandra.config.CassandraRelevantProperties
-
property for the rate of the scheduled task that monitors disk usage
- DISK_USAGE_NOTIFY_INTERVAL_MS - org.apache.cassandra.config.CassandraRelevantProperties
-
property for the interval on which the repeated client warnings and diagnostic events about disk usage are ignored
- diskAccessMode - Variable in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
-
Flag used to shows user configured Direct-IO status.
- DiskAnn - Class in org.apache.cassandra.index.sai.disk.v1.vector
- DiskAnn(SegmentMetadata.ComponentMetadataMap, PerColumnIndexFiles, IndexWriterConfig) - Constructor for class org.apache.cassandra.index.sai.disk.v1.vector.DiskAnn
- DiskBinarySearch - Class in org.apache.cassandra.index.sai.disk.v1.vector
- DiskBinarySearch() - Constructor for class org.apache.cassandra.index.sai.disk.v1.vector.DiskBinarySearch
- 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
- diskOptimizationEstimatePercentile - Variable in class org.apache.cassandra.io.sstable.IOOptions
- diskOptimizationStrategy - Variable in class org.apache.cassandra.io.sstable.IOOptions
- DiskOptimizationStrategy - Interface in org.apache.cassandra.io.util
- diskUsage() - Method in class org.apache.cassandra.index.sai.SSTableContext
- diskUsage() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- diskUsage() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- diskUsage(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- DiskUsageBroadcaster - Class in org.apache.cassandra.service.disk.usage
-
Starts
DiskUsageMonitor
to monitor local disk usage state and broadcast new state via Gossip. - DiskUsageBroadcaster(DiskUsageMonitor) - Constructor for class org.apache.cassandra.service.disk.usage.DiskUsageBroadcaster
- DiskUsageMonitor - Class in org.apache.cassandra.service.disk.usage
-
Schedule periodic task to monitor local disk usage and notify
DiskUsageBroadcaster
if local state changed. - DiskUsageMonitor() - Constructor for class org.apache.cassandra.service.disk.usage.DiskUsageMonitor
- DiskUsageMonitor(Supplier<Multimap<FileStore, Directories.DataDirectory>>) - Constructor for class org.apache.cassandra.service.disk.usage.DiskUsageMonitor
- DiskUsageState - Enum in org.apache.cassandra.service.disk.usage
- dispatch(Channel, Message.Request, Dispatcher.FlushItemConverter, ClientResourceLimits.Overload) - Method in class org.apache.cassandra.transport.Dispatcher
- dispatcher(boolean) - Method in class org.apache.cassandra.transport.PipelineConfigurator
- Dispatcher - Class in org.apache.cassandra.transport
- Dispatcher(boolean) - Constructor for class org.apache.cassandra.transport.Dispatcher
- Dispatcher.RequestProcessor - Class in org.apache.cassandra.transport
-
It is important to keep this class an instance of
DebuggableTask
, either runnable or callable since this is the only way we can keep it not wrapped into a callable on SEPExecutor submission path. - Dispatcher.RequestTime - Class in org.apache.cassandra.transport
- 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
- distributedKeyspaces() - Method in class org.apache.cassandra.schema.Schema
- DistributedSchema - Class in org.apache.cassandra.schema
-
Immutable snapshot of the current schema along with its version.
- DistributedSchema(Keyspaces, UUID) - Constructor for class org.apache.cassandra.schema.DistributedSchema
- divide(Number, Number) - Method in class org.apache.cassandra.db.marshal.ByteType
- divide(Number, Number) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
- divide(Number, Number) - Method in class org.apache.cassandra.db.marshal.DecimalType
- divide(Number, Number) - Method in class org.apache.cassandra.db.marshal.DoubleType
- divide(Number, Number) - Method in class org.apache.cassandra.db.marshal.FloatType
- divide(Number, Number) - Method in class org.apache.cassandra.db.marshal.Int32Type
- divide(Number, Number) - Method in class org.apache.cassandra.db.marshal.IntegerType
- divide(Number, Number) - Method in class org.apache.cassandra.db.marshal.LongType
- divide(Number, Number) - Method in class org.apache.cassandra.db.marshal.NumberType
-
Divides the left argument by the right one.
- divide(Number, Number) - Method in class org.apache.cassandra.db.marshal.ShortType
- DML - org.apache.cassandra.audit.AuditLogEntryCategory
- 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.format.big.BigTableWriter.IndexWriter
- doAbort(Throwable) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter.IndexWriter
- doAbort(Throwable) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.TransactionalProxy
- 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
- doAuthSetup(boolean) - Method in class org.apache.cassandra.service.StorageService
- DOB_DOUBLING_THRESHOLD_MB - org.apache.cassandra.config.CassandraRelevantProperties
- DOB_MAX_RECYCLE_BYTES - org.apache.cassandra.config.CassandraRelevantProperties
- doClose() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
- doClose() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableScanner
- doClose() - Method in class org.apache.cassandra.io.sstable.format.SSTableScanner
- 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.format.big.BigTableWriter.IndexWriter
- doCommit(Throwable) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter.IndexWriter
- doCommit(Throwable) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.TransactionalProxy
- 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
- doCreateIterator() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
- doCreateIterator() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableScanner
- doCreateIterator() - Method in class org.apache.cassandra.io.sstable.format.SSTableScanner
- doesNotSelect(PrimaryKey) - Method in class org.apache.cassandra.index.sai.plan.QueryController
-
Returns whether this query is not selecting the
PrimaryKey
. - 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
- doGetOrCreateFunction(List<AbstractType<?>>, AbstractType<?>) - Method in class org.apache.cassandra.cql3.functions.FunctionFactory
-
Returns a function compatible with the specified signature.
- 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.AnnRestriction
- 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
- done() - Static method in class org.apache.cassandra.service.reads.thresholds.CoordinatorWarnings
- DONE - org.apache.cassandra.utils.AbstractGuavaIterator.State
-
We have reached the end of the data and are finished.
- DONE - Static variable in class org.apache.cassandra.service.paxos.AbstractPaxosRepair
- doneWithNonLocalSession(TraceState) - Method in class org.apache.cassandra.tracing.Tracing
- doOnChangeNotifications(InetAddressAndPort, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.Gossiper
- 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.format.big.BigTableWriter.IndexWriter
- doPostCleanup(Throwable) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter.IndexWriter
- doPostCleanup(Throwable) - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter.AbstractIndexWriter
- doPostCleanup(Throwable) - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter.TransactionalProxy
- doPostCleanup(Throwable) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.TransactionalProxy
- 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.unified.ShardedCompactionWriter
- 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.format.big.BigTableWriter.IndexWriter
- doPrepare() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter.IndexWriter
- doPrepare() - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter.AbstractIndexWriter
- doPrepare() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.TransactionalProxy
- 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() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
-
Do any preparatory work prior to commit.
- doPrepare(Commit) - Static method in class org.apache.cassandra.service.paxos.v1.PrepareVerbHandler
- doPropose(Commit) - Static method in class org.apache.cassandra.service.paxos.v1.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 - org.apache.cassandra.cql3.CQL3Type.Native
- DOUBLE - org.apache.cassandra.cql3.functions.types.DataType.Name
- DOUBLE - org.apache.cassandra.transport.DataType
- 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
- doValidation(ColumnFamilyStore, Validator) - Static method in class org.apache.cassandra.repair.ValidationManager
-
Performs a readonly "compaction" of all sstables in order to validate complete rows, but without writing the merge result
- doVerb(Message) - Method in class org.apache.cassandra.streaming.ReplicationDoneVerbHandler
- doVerb(Message<Collection<Mutation>>) - Method in class org.apache.cassandra.schema.SchemaPushVerbHandler
- 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<Mutation>) - Method in class org.apache.cassandra.db.ReadRepairVerbHandler
- doVerb(Message<ReadCommand>) - Method in class org.apache.cassandra.db.ReadCommandVerbHandler
- doVerb(Message<SnapshotCommand>) - Method in class org.apache.cassandra.service.SnapshotVerbHandler
- doVerb(Message<TruncateRequest>) - Method in class org.apache.cassandra.db.TruncateVerbHandler
- doVerb(Message<GossipDigestAck>) - Method in class org.apache.cassandra.gms.GossipDigestAckVerbHandler
- doVerb(Message<GossipDigestAck2>) - Method in class org.apache.cassandra.gms.GossipDigestAck2VerbHandler
- doVerb(Message<GossipDigestSyn>) - Method in class org.apache.cassandra.gms.GossipDigestSynVerbHandler
- doVerb(Message<GossipShutdown>) - Method in class org.apache.cassandra.gms.GossipShutdownVerbHandler
- doVerb(Message<HintMessage>) - Method in class org.apache.cassandra.hints.HintVerbHandler
- doVerb(Message<NoPayload>) - Method in class org.apache.cassandra.schema.SchemaPullVerbHandler
- doVerb(Message<NoPayload>) - Method in class org.apache.cassandra.schema.SchemaVersionVerbHandler
- doVerb(Message<NoPayload>) - Method in class org.apache.cassandra.service.EchoVerbHandler
- doVerb(Message<RepairMessage>) - Method in class org.apache.cassandra.repair.RepairMessageVerbHandler
- doVerb(Message<Commit.Agreed>) - Method in class org.apache.cassandra.service.paxos.PaxosCommit.RequestHandler
- doVerb(Message<Commit>) - Method in class org.apache.cassandra.service.paxos.v1.PrepareVerbHandler
- doVerb(Message<Commit>) - Method in class org.apache.cassandra.service.paxos.v1.ProposeVerbHandler
- doVerb(Message<PaxosCommitAndPrepare.Request>) - Method in class org.apache.cassandra.service.paxos.PaxosCommitAndPrepare.RequestHandler
- doVerb(Message<PaxosPrepare.Request>) - Method in class org.apache.cassandra.service.paxos.PaxosPrepare.RequestHandler
- doVerb(Message<PaxosPrepareRefresh.Request>) - Method in class org.apache.cassandra.service.paxos.PaxosPrepareRefresh.RequestHandler
- doVerb(Message<PaxosPropose.Request>) - Method in class org.apache.cassandra.service.paxos.PaxosPropose.RequestHandler
- doVerb(Message<PaxosRepair.Request>) - Method in class org.apache.cassandra.service.paxos.PaxosRepair.RequestHandler
- doVerb(Message<TimeUUID>) - Method in class org.apache.cassandra.batchlog.BatchRemoveVerbHandler
- doVerb(Message<T>) - Method in class org.apache.cassandra.gms.GossipVerbHandler
- 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).
- DOWN - org.apache.cassandra.transport.Event.StatusChange.Status
- downsample(IndexSummary, int, int, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryBuilder
-
Downsamples an existing index summary to a new sampling level.
- Downsampling - Class in org.apache.cassandra.io.sstable
- Downsampling() - Constructor for class org.apache.cassandra.io.sstable.Downsampling
- drain() - Method in class org.apache.cassandra.service.StorageService
-
Shuts node off to writes, empties memtables and the commit log.
- drain() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
makes node unavailable for writes, flushes memtables and replays commitlog.
- drain() - Method in class org.apache.cassandra.tools.NodeProbe
- drain() - Method in interface org.apache.cassandra.utils.concurrent.Semaphore
-
set the number of permits in this semaphore to zero
- drain() - Method in class org.apache.cassandra.utils.concurrent.Semaphore.Standard
- drain(boolean) - Method in class org.apache.cassandra.service.StorageService
- Drain - Class in org.apache.cassandra.tools.nodetool
- Drain() - Constructor for class org.apache.cassandra.tools.nodetool.Drain
- DRAIN - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- DRAIN_EXECUTOR_TIMEOUT_MS - org.apache.cassandra.config.CassandraRelevantProperties
-
When draining, how long to wait for mutating executors to shutdown.
- DRAINED - org.apache.cassandra.service.StorageService.Mode
- DRAINING - org.apache.cassandra.service.StorageService.Mode
- drainTo(Collection<? super T>) - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- 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.BlockingQueues.Sync
- 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.utils.JavaDriverUtils
-
Returns the Java Driver
DataType
for the C* internal type. - driverVersion() - Method in class org.apache.cassandra.transport.ConnectedClient
- drop(Collection<SSTableReader>) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- drop(Collection<SSTableReader>) - Method in class org.apache.cassandra.index.sai.view.IndexViewManager
- drop(RoleResource) - Method in class org.apache.cassandra.auth.AllowAllNetworkAuthorizer
- drop(RoleResource) - Method in class org.apache.cassandra.auth.CassandraNetworkAuthorizer
- drop(RoleResource) - Method in class org.apache.cassandra.auth.CIDRPermissionsManager
-
Drop CIDR permissions of a role, i.e, delete corresponding row from the table
- drop(RoleResource) - Method in interface org.apache.cassandra.auth.INetworkAuthorizer
-
Called when a role is deleted, so any corresponding network permissions data can also be cleaned up
- drop(ColumnIdentifier) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
- DROP - org.apache.cassandra.auth.Permission
- DROP - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- DROP_AGGREGATE - org.apache.cassandra.audit.AuditLogEntryType
- drop_compact_storage_enabled - Variable in class org.apache.cassandra.config.Config
- DROP_FUNCTION - org.apache.cassandra.audit.AuditLogEntryType
- DROP_IDENTITY - org.apache.cassandra.audit.AuditLogEntryType
- DROP_INDEX - org.apache.cassandra.audit.AuditLogEntryType
- DROP_KEYSPACE - org.apache.cassandra.audit.AuditLogEntryType
- drop_keyspace_enabled - Variable in class org.apache.cassandra.config.Config
- DROP_OVERSIZED_READ_REPAIR_MUTATIONS - org.apache.cassandra.config.CassandraRelevantProperties
- DROP_ROLE - org.apache.cassandra.audit.AuditLogEntryType
- DROP_TABLE - org.apache.cassandra.audit.AuditLogEntryType
- DROP_TRIGGER - org.apache.cassandra.audit.AuditLogEntryType
- drop_truncate_table_enabled - Variable in class org.apache.cassandra.config.Config
- DROP_TYPE - org.apache.cassandra.audit.AuditLogEntryType
- DROP_VIEW - org.apache.cassandra.audit.AuditLogEntryType
- 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(boolean) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Remove all indexes
- dropCf(TableId, boolean) - Method in class org.apache.cassandra.db.Keyspace
- dropCidrGroup(String) - Method in class org.apache.cassandra.auth.CIDRGroupsMappingManager
- dropCidrGroup(String) - Method in interface org.apache.cassandra.auth.CIDRGroupsMappingManagerMBean
-
Delete a CIDR group and associated mapping from the table
AuthKeyspace.CIDR_GROUPS
throws exception if input cidr group name doesn't exist in the table before deletion - dropCidrGroup(String) - Method in class org.apache.cassandra.tools.NodeProbe
- DropCIDRGroup - Class in org.apache.cassandra.tools.nodetool
-
Nodetool command to drop a CIDR group and associated mapping from the table
AuthKeyspace.CIDR_GROUPS
- DropCIDRGroup() - Constructor for class org.apache.cassandra.tools.nodetool.DropCIDRGroup
- dropCidrPermissionsForRole(RoleResource) - Method in class org.apache.cassandra.auth.AbstractCIDRAuthorizer
- dropCidrPermissionsForRole(RoleResource) - Method in interface org.apache.cassandra.auth.ICIDRAuthorizer
-
Drop CIDR permissions of a role
- dropCompactStorage() - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
- dropData(long) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
- dropData(long) - Method in class org.apache.cassandra.index.sasi.conf.DataTracker
- dropData(Collection<SSTableReader>) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
- dropData(Collection<SSTableReader>) - 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
- dropIdentity(String) - Method in class org.apache.cassandra.auth.CassandraRoleManager
- dropIdentity(String) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Called on the execution of DROP IDENTITY statement for removing a given identity from the identity_role table.
- DropIdentityStatement - Class in org.apache.cassandra.cql3.statements
-
Cqlsh statement to remove identity from identity_to_roles table.
- DropIdentityStatement(String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.DropIdentityStatement
- 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
- dropKeyspaceEnabled - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail disabling DROP KEYSPACE behavior
- 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
- droppableTombstoneRatio - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- 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 - Variable in class org.apache.cassandra.schema.Diff
- dropped - Variable in class org.apache.cassandra.schema.Keyspaces.KeyspacesDiff
- dropped() - Method in class org.apache.cassandra.net.OutboundConnection
- DROPPED - org.apache.cassandra.index.Index.Status
- DROPPED - org.apache.cassandra.transport.Event.SchemaChange.Change
- DROPPED_COLUMNS - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
- DroppedColumn - Class in org.apache.cassandra.schema
- DroppedColumn(ColumnMetadata, long) - Constructor for class org.apache.cassandra.schema.DroppedColumn
- droppedColumns - Variable in class org.apache.cassandra.schema.TableMetadata
- droppedColumns(Map<ByteBuffer, DroppedColumn>) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- DroppedMessageMetrics - Class in org.apache.cassandra.metrics
-
Metrics for dropped messages by verb.
- DroppedMessageMetrics(Verb) - Constructor for class org.apache.cassandra.metrics.DroppedMessageMetrics
- droppedTime - Variable in class org.apache.cassandra.schema.DroppedColumn
- dropPreparedStatements(boolean) - Method in class org.apache.cassandra.service.StorageService
- 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(Predicate<SSTableReader>, OperationType, Throwable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
removes all sstables that are not busy compacting.
- dropSSTables(Throwable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
- 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
- dropTruncateTableEnabled - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail disabling DROP / TRUNCATE TABLE behavior
- 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
- dst - Variable in class org.apache.cassandra.repair.messages.SyncRequest
- dst - Variable in class org.apache.cassandra.repair.state.SyncState.Id
- DTEST_API_LOG_TOPOLOGY - org.apache.cassandra.config.CassandraRelevantProperties
- DTEST_IS_IN_JVM_DTEST - org.apache.cassandra.config.CassandraRelevantProperties
-
This property indicates if the code is running under the in-jvm dtest framework
- DTEST_JVM_DTESTS_USE_LATEST - org.apache.cassandra.config.CassandraRelevantProperties
-
In_JVM dtest property indicating that the test should use "latest" configuration
- DUMMY - Static variable in class org.apache.cassandra.index.sai.disk.RowMapping
- DUMMY_KEYSPACE_OR_TABLE_NAME - Static variable in class org.apache.cassandra.schema.SchemaConstants
- dump() - Method in class org.apache.cassandra.db.tries.Trie
-
Constuct a textual representation of the trie.
- dump(Function<T, String>) - Method in class org.apache.cassandra.db.tries.InMemoryReadTrie
-
Override of dump to provide more detailed printout that includes the type of each node in the trie.
- dump(Function<T, String>) - Method in class org.apache.cassandra.db.tries.Trie
-
Constuct a textual representation of the trie using the given content-to-string mapper.
- Dump() - Constructor for class org.apache.cassandra.tools.JMXTool.Dump
- dump_heap_on_uncaught_exception - Variable in class org.apache.cassandra.config.Config
- 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
- dumpNode(IncrementalTrieWriterPageAware.Node<VALUE>, long) - Method in class org.apache.cassandra.io.tries.IncrementalTrieWriterPageAware
- dumpTimings(String) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
- dumpTimings(String) - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
- dumpTrie(PrintStream) - Method in class org.apache.cassandra.io.sstable.format.bti.RowIndexReader
- dumpTrie(PrintStream, Walker.PayloadToString, Version) - Method in class org.apache.cassandra.io.tries.Walker
- dumpTrie(String) - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex
-
debug/test code
- duplicate() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
- DUPLICATE - org.apache.cassandra.locator.ReplicaCollection.Builder.Conflict
-
fail on addition of any such conflict where the contents differ (first occurrence and position wins)
- DUPLICATE_ROWS_DETECTED_SNAPSHOT_PREFIX - Static variable in class org.apache.cassandra.utils.DiagnosticSnapshotService
- DUPLICATE_TARGET_COLUMN - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- 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
- DURABLE_WRITES - org.apache.cassandra.schema.KeyspaceParams.Option
- durableWrites - Variable in class org.apache.cassandra.schema.KeyspaceParams
- duration() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
-
Returns the Duration type, introduced in Cassandra 3.10.
- duration() - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
-
Returns the default codec for the
Duration type
. - duration(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
- Duration - Class in org.apache.cassandra.cql3
-
Represents a duration.
- Duration - Class in org.apache.cassandra.cql3.functions.types
-
Represents a duration.
- DURATION - org.apache.cassandra.cql3.Constants.Type
- DURATION - org.apache.cassandra.cql3.CQL3Type.Native
- DURATION - org.apache.cassandra.cql3.functions.types.DataType.Name
- DURATION - org.apache.cassandra.transport.DataType
- durationMillis() - Method in class org.apache.cassandra.streaming.StreamingState
- DURATIONS_NOT_SUPPORTED - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- DurationSerializer - Class in org.apache.cassandra.serializers
- DurationSerializer() - Constructor for class org.apache.cassandra.serializers.DurationSerializer
- DurationSpec - Class in org.apache.cassandra.config
-
Represents a positive time duration.
- DurationSpec.IntMillisecondsBound - Class in org.apache.cassandra.config
-
Represents a duration used for Cassandra configuration.
- DurationSpec.IntMinutesBound - Class in org.apache.cassandra.config
-
Represents a duration used for Cassandra configuration.
- DurationSpec.IntSecondsBound - Class in org.apache.cassandra.config
-
Represents a duration used for Cassandra configuration.
- DurationSpec.LongMicrosecondsBound - Class in org.apache.cassandra.config
-
Represents a duration used for Cassandra configuration.
- DurationSpec.LongMillisecondsBound - Class in org.apache.cassandra.config
-
Represents a duration used for Cassandra configuration.
- DurationSpec.LongNanosecondsBound - Class in org.apache.cassandra.config
-
Represents a duration used for Cassandra configuration.
- DurationSpec.LongSecondsBound - Class in org.apache.cassandra.config
-
Represents a duration used for Cassandra configuration.
- durationString(Long) - Static method in class org.apache.cassandra.tools.SSTableMetadataViewer
- 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_data_masking_enabled - Variable in class org.apache.cassandra.config.Config
- 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 - Variable in class org.apache.cassandra.config.Config
- dynamic_snitch_update_interval - Variable in class org.apache.cassandra.config.Config
- DynamicCompositeType - Class in org.apache.cassandra.db.marshal
- DynamicCompositeType.FixedValueComparator - Class in org.apache.cassandra.db.marshal
- DynamicCompositeType.Serializer - 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(SortedMap<Long, LongSet>) - Constructor for class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
- DynamicTokenTreeBuilder(TokenTreeBuilder) - Constructor for class org.apache.cassandra.index.sasi.disk.DynamicTokenTreeBuilder
E
- EACH_QUORUM - org.apache.cassandra.db.ConsistencyLevel
- eachQuorumForRead(AbstractReplicationStrategy) - Static method in enum org.apache.cassandra.db.ConsistencyLevel
- eachQuorumForWrite(AbstractReplicationStrategy, Endpoints<?>) - Static method in enum org.apache.cassandra.db.ConsistencyLevel
- EARLIEST - Static variable in class org.apache.cassandra.index.sai.disk.format.Version
- EARLY - org.apache.cassandra.io.sstable.format.SSTableReader.OpenReason
-
From
None
- Reader is a compaction replacement that is either incomplete and has been opened to represent its partial result status, or has been finished but the compaction it is a part of has not yet completed fully FromSSTableReader.OpenReason.EARLY
- Same as fromNone
, only it is not the first time it has been - 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
- Ec2MultiRegionSnitch(SnitchProperties) - 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
- ECHO_REQ - org.apache.cassandra.net.Verb
- ECHO_RSP - org.apache.cassandra.net.Verb
- EchoVerbHandler - Class in org.apache.cassandra.service
- EchoVerbHandler() - Constructor for class org.apache.cassandra.service.EchoVerbHandler
- effectiveOwnership(String) - Method in class org.apache.cassandra.service.StorageService
- effectiveOwnership(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-7544
- 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.
- elapsedSinceCreation() - Method in interface org.apache.cassandra.concurrent.DebuggableTask
- 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() - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- element() - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
- element(ColumnMetadata, CellPath) - Static method in class org.apache.cassandra.db.filter.ColumnSubselection
- Element(String, String, BiFunction<KeyspaceMetadata, String, Stream<? extends SchemaElement>>) - Constructor for class org.apache.cassandra.cql3.statements.DescribeStatement.Element
- ELEMENT_SELECTOR - org.apache.cassandra.cql3.selection.Selector.Kind
- 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.cql3.Vectors.Value
- elements - Variable in class org.apache.cassandra.serializers.ListSerializer
- elements - Variable in class org.apache.cassandra.serializers.SetSerializer
- elementType - Variable in class org.apache.cassandra.db.marshal.VectorType
- 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() - 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 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() - 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 method in class org.apache.cassandra.db.ReadExecutionController
- empty() - Static method in class org.apache.cassandra.db.tries.Trie
- empty() - Static method in class org.apache.cassandra.gms.HeartBeatState
- empty() - Static method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator
- empty() - Method in class org.apache.cassandra.schema.KeyspaceMetadata
- empty() - Static method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- empty() - Static method in class org.apache.cassandra.utils.btree.BTree
-
Returns an empty BTree
- empty() - Static method in interface org.apache.cassandra.utils.CloseableIterator
- empty(Comparator<? super V>) - Static method in class org.apache.cassandra.utils.btree.BTreeSet
- empty(StatementType, TableMetadata) - Static method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Creates a new empty
StatementRestrictions
. - empty(Range<Token>) - Static method in class org.apache.cassandra.locator.EndpointsForRange
- empty(Token) - Static method in class org.apache.cassandra.locator.EndpointsForToken
- empty(ChannelProxy) - Static method in class org.apache.cassandra.io.util.MmappedRegions
- empty(InetAddressAndPort) - Static method in class org.apache.cassandra.locator.RangesAtEndpoint
- empty(TableMetadata) - Static method in interface org.apache.cassandra.db.ReadQuery
- empty(Ballot, DecoratedKey, TableMetadata) - Static method in class org.apache.cassandra.service.paxos.Commit.Proposal
- EMPTY - org.apache.cassandra.cql3.CQL3Type.Native
- EMPTY - Static variable in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
- EMPTY - Static variable in interface org.apache.cassandra.db.Clustering
-
Empty clustering for tables having no clustering columns.
- EMPTY - Static variable in class org.apache.cassandra.db.LivenessInfo
- EMPTY - Static variable in class org.apache.cassandra.db.partitions.BTreePartitionData
- EMPTY - Static variable in interface org.apache.cassandra.index.IndexRegistry
-
An empty
IndexRegistry
- EMPTY - Static variable in interface org.apache.cassandra.index.sai.postings.PostingList
- EMPTY - Static variable in interface org.apache.cassandra.io.util.Rebufferer
- EMPTY - Static variable in class org.apache.cassandra.metrics.TableMetrics
- EMPTY - Static variable in class org.apache.cassandra.metrics.TopPartitionTracker.StoredTopPartitions
- EMPTY - Static variable in class org.apache.cassandra.repair.consistent.RepairedState.Stats
- EMPTY - Static variable in class org.apache.cassandra.schema.DistributedSchema
- EMPTY - Static variable in interface org.apache.cassandra.service.pager.QueryPager
- EMPTY - Static variable in class org.apache.cassandra.service.paxos.PaxosRepairHistory
- EMPTY - Static variable in class org.apache.cassandra.streaming.StreamingState
- EMPTY - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteComparable
- EMPTY - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- 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.ArrayClustering
- EMPTY_SIZE - Static variable in class org.apache.cassandra.db.DeletionTime
- EMPTY_SIZE - Static variable in class org.apache.cassandra.db.partitions.AtomicBTreePartition
- EMPTY_SIZE - Static variable in class org.apache.cassandra.io.sstable.IndexInfo
- 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.
- emptyBytesUsed() - Static method in class org.apache.cassandra.index.sai.disk.v1.vector.VectorPostings
- emptyCommit(DecoratedKey, TableMetadata) - Static method in class org.apache.cassandra.service.paxos.Commit
- emptyConfig() - Static method in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- emptyDeletedRow(Clustering<?>, Row.Deletion) - Static method in class org.apache.cassandra.db.rows.BTreeRow
- emptyInstance(ProtocolVersion) - Static method in class org.apache.cassandra.cql3.functions.FunctionArguments
-
Creates an empty
FunctionArguments
. - EmptyIterators - Class in org.apache.cassandra.db
- EmptyIterators() - Constructor for class org.apache.cassandra.db.EmptyIterators
- emptyPartitions - Variable in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- emptyPartitions - Variable in class org.apache.cassandra.io.sstable.IScrubber.ScrubResult
- EmptyPartitionsDiscarder - Class in org.apache.cassandra.db.transform
- EmptyPartitionsDiscarder() - Constructor for class org.apache.cassandra.db.transform.EmptyPartitionsDiscarder
- EmptyPostingList() - Constructor for class org.apache.cassandra.index.sai.postings.PostingList.EmptyPostingList
- EmptyRebufferer - Class in org.apache.cassandra.io.util
- EmptyRebufferer(ChannelProxy) - Constructor for class org.apache.cassandra.io.util.EmptyRebufferer
- 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 - Class in org.apache.cassandra.io.sstable
- EmptySSTableScanner(SSTableReader) - Constructor for class org.apache.cassandra.io.sstable.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() - 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(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(StartupChecks.StartupCheckType) - Method in class org.apache.cassandra.config.StartupChecksOptions
- ENABLE_DC_LOCAL_COMMIT - org.apache.cassandra.config.CassandraRelevantProperties
- ENABLE_NODELOCAL_QUERIES - org.apache.cassandra.config.CassandraRelevantProperties
-
Whether
ConsistencyLevel.NODE_LOCAL
should be allowed. - 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
-
Deprecated.See CASSANDRA-16725
- enableAuditLog(String, String, String, String, String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-16725
- enableAuditLog(String, String, String, String, String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
- enableAuditLog(String, String, String, String, String, String, String, Integer, Boolean, String, Long, Integer, String) - Method in class org.apache.cassandra.service.StorageService
- enableAuditLog(String, String, String, String, String, String, String, Integer, Boolean, String, Long, Integer, 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.service.StorageService
-
Deprecated.See CASSANDRA-16725
- enableAuditLog(String, Map<String, String>, String, String, String, String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-16725
- enableAuditLog(String, Map<String, String>, String, String, String, String, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
- enableAuditLog(String, Map<String, String>, String, String, String, String, String, String, Integer, Boolean, String, Long, Integer, String) - Method in class org.apache.cassandra.service.StorageService
- enableAuditLog(String, Map<String, String>, String, String, String, String, String, String, Integer, Boolean, String, Long, Integer, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- enableAuditLog(String, Map<String, String>, String, String, String, String, String, String, Integer, Boolean, String, Long, Integer, 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 - Variable in class org.apache.cassandra.security.AbstractSslContextFactory
- enabled() - Method in class org.apache.cassandra.db.guardrails.Guardrail
-
Checks whether this guardrail is enabled or not when the check is done for a background opperation that is not associated to a specific
ClientState
, such as compaction or other background processes. - enabled(ClientState) - Method in class org.apache.cassandra.db.guardrails.Guardrail
-
Checks whether this guardrail is enabled or not.
- enabled(ClientState) - Method in class org.apache.cassandra.db.guardrails.Threshold
- ENABLED - org.apache.cassandra.config.EncryptionOptions.ConfigKey
- ENABLED - org.apache.cassandra.schema.CompactionParams.Option
- ENABLED - Static variable in class org.apache.cassandra.audit.AuditLogOptionsCompositeData.AuditLogOption
- ENABLED - Static variable in class org.apache.cassandra.schema.CompressionParams
- ENABLED_PROPERTY - Static variable in class org.apache.cassandra.config.StartupChecksOptions
- 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)
. - EnableFlag - Class in org.apache.cassandra.db.guardrails
-
A guardrail that enables the use of a particular feature.
- EnableFlag(String, String, Predicate<ClientState>, String) - Constructor for class org.apache.cassandra.db.guardrails.EnableFlag
-
Creates a new
EnableFlag
guardrail. - EnableFlag(String, String, Predicate<ClientState>, Predicate<ClientState>, String) - Constructor for class org.apache.cassandra.db.guardrails.EnableFlag
-
Creates a new
EnableFlag
guardrail. - 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
- 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
- enableUserDefinedFunctions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- enableUserDefinedFunctionsThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- enableWithoutClean(Path, String, boolean, int, long, String, int) - Method in class org.apache.cassandra.fql.FullQueryLogger
- encode(boolean, ByteBuffer) - Method in class org.apache.cassandra.net.FrameEncoderLZ4
- 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(ChannelHandlerContext, Message, List<Object>) - Method in class org.apache.cassandra.transport.PreV5Handlers.ProtocolEncoder
- encode(ResultSet, ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.cql3.ResultSet.Codec
- encode(ProtocolVersion) - Method in class org.apache.cassandra.transport.Message
- encode(T, ByteBuf, ProtocolVersion) - Method in interface org.apache.cassandra.transport.CBCodec
- encode(T, ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.transport.messages.UnsupportedMessageCodec
- encodeBigInteger(ByteBuffer) - Static method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Encode a
BigInteger
into a fixed width 20 byte encoded value. - encoded - Variable in class org.apache.cassandra.index.sai.plan.Expression.Value
- ENCODED_CERTIFICATES - org.apache.cassandra.security.PEMBasedSslContextFactory.ConfigKey
- ENCODED_KEY - org.apache.cassandra.security.PEMBasedSslContextFactory.ConfigKey
- encodeDecimal(ByteBuffer) - Static method in class org.apache.cassandra.index.sai.utils.IndexTermType
- 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 - Variable in class org.apache.cassandra.index.sai.utils.PartitionInfo
- encodingStats - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
- encodingStats() - Method in class org.apache.cassandra.db.memtable.AbstractMemtable.AbstractFlushablePartitionSet
- encodingStats() - Method in interface org.apache.cassandra.db.memtable.Memtable.FlushablePartitionSet
-
Statistics required for writing an sstable efficiently
- EncodingStats - Class in org.apache.cassandra.db.rows
-
Stats used for the encoding of the rows and tombstones of a given source.
- EncodingStats(long, long, int) - Constructor for class org.apache.cassandra.db.rows.EncodingStats
- 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 - org.apache.cassandra.config.EncryptionOptions.TlsEncryptionPolicy
- 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(AbstractCommitLogSegmentManager, ThrowingFunction<Path, FileChannel, IOException>) - Constructor for class org.apache.cassandra.db.commitlog.EncryptedSegment
- EncryptedSegment.EncryptedSegmentBuilder - Class in org.apache.cassandra.db.commitlog
- EncryptedSegmentBuilder(AbstractCommitLogSegmentManager) - Constructor for class org.apache.cassandra.db.commitlog.EncryptedSegment.EncryptedSegmentBuilder
- 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
-
This holds various options used for enabling SSL/TLS encryption.
- EncryptionOptions() - Constructor for class org.apache.cassandra.config.EncryptionOptions
- EncryptionOptions(EncryptionOptions) - Constructor for class org.apache.cassandra.config.EncryptionOptions
- EncryptionOptions(ParameterizedClass, String, String, String, String, List<String>, String, List<String>, String, String, boolean, boolean, Boolean, Boolean) - Constructor for class org.apache.cassandra.config.EncryptionOptions
- EncryptionOptions.ConfigKey - Enum in org.apache.cassandra.config
- 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 - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableIterator.ForwardReader
- end - Variable in class org.apache.cassandra.repair.consistent.admin.RepairStats.Section
- end() - Method in class org.apache.cassandra.db.Slice
- end() - Method in class org.apache.cassandra.db.Slices
- end() - Method in class org.apache.cassandra.index.sai.analyzer.AbstractAnalyzer
-
Call when tokenization is finished.
- end() - Method in class org.apache.cassandra.io.util.MmappedRegions.Region
- 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 - org.apache.cassandra.cql3.statements.Bound
- END_OF_STREAM - Static variable in interface org.apache.cassandra.index.sai.postings.PostingList
- END_OF_STREAM - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
Value returned if at the end of the stream.
- END_TOKEN - Static variable in class org.apache.cassandra.index.sai.virtual.SegmentsSystemView
- 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.utils.AbstractGuavaIterator
-
Implementations of
AbstractGuavaIterator.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 - Variable in class org.apache.cassandra.repair.TreeResponse
- endpoint - Variable in class org.apache.cassandra.tools.nodetool.HostStat
- endpoint() - Method in class org.apache.cassandra.locator.RangesAtEndpoint
- endpoint() - Method in class org.apache.cassandra.locator.Replica
- endpoint() - Method in class org.apache.cassandra.net.ResourceLimits.EndpointAndGlobal
- endpoint(int) - Method in class org.apache.cassandra.locator.Endpoints
- endpoint(ResourceLimits.Limit) - Static method in class org.apache.cassandra.net.AbstractMessageHandler.WaitQueue
- 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 - Variable in class org.apache.cassandra.repair.CommonRange
- endpoints - Variable in class org.apache.cassandra.service.TokenRange
- endpoints() - Method in class org.apache.cassandra.locator.Endpoints
- endpoints() - Static method in class org.apache.cassandra.locator.InOurDc
- endpoints() - Method in class org.apache.cassandra.locator.RangesAtEndpoint
- endpoints() - Method in interface org.apache.cassandra.locator.ReplicaCollection
- endpoints() - Method in class org.apache.cassandra.repair.RepairSession
- Endpoints<E extends Endpoints<E>> - Class in org.apache.cassandra.locator
-
A collection of Endpoints for a given ring position.
- 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(EndpointState) - Constructor for class org.apache.cassandra.gms.EndpointState
- EndpointState(HeartBeatState) - Constructor for class org.apache.cassandra.gms.EndpointState
- endpointStateMap - Variable in class org.apache.cassandra.gms.Gossiper
- 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
- ENFORCE - org.apache.cassandra.auth.ICIDRAuthorizer.CIDRAuthorizerMode
- enforce_native_deadline_for_hints - Variable in class org.apache.cassandra.config.Config
- 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
- enqueuedAtNanos() - Method in class org.apache.cassandra.transport.Dispatcher.RequestTime
- ensureAllKeyspacesPermission(Permission) - Method in class org.apache.cassandra.service.ClientState
- ensureAllTablesPermission(String, 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 foroutputLength
. - ensureCapacity(ByteBuffer, int, boolean, BufferType) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Ensure
buf
is large enough foroutputLength
. - ensureEnabled() - Static method in class org.apache.cassandra.cql3.functions.masking.ColumnMask
- ensureEnabled(String, ClientState) - Method in class org.apache.cassandra.db.guardrails.EnableFlag
-
Aborts the operation if this guardrail is not enabled.
- ensureEnabled(ClientState) - Method in class org.apache.cassandra.db.guardrails.EnableFlag
-
Aborts the operation if this guardrail is not enabled.
- 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() - Method in class org.apache.cassandra.utils.memory.HeapPool.Allocator
- 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
- EnsureOnHeap - Class in org.apache.cassandra.utils.memory
- EnsureOnHeap() - Constructor for class org.apache.cassandra.utils.memory.EnsureOnHeap
- ensurePermission(Permission, IResource) - Method in class org.apache.cassandra.service.ClientState
- ensurePermission(Permission, Function) - Method in class org.apache.cassandra.service.ClientState
- ensureReleased() - Method in class org.apache.cassandra.utils.concurrent.Ref
- ensureReleased(Throwable) - 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
- entire_sstable_inter_dc_stream_throughput_outbound - Variable in class org.apache.cassandra.config.Config
- ENTIRE_SSTABLE_INTER_DC_THROTTLE_MEBIBYTES - Static variable in class org.apache.cassandra.tools.LoaderOptions
- entire_sstable_stream_throughput_outbound - Variable in class org.apache.cassandra.config.Config
- ENTIRE_SSTABLE_THROTTLE_MEBIBYTES - Static variable in class org.apache.cassandra.tools.LoaderOptions
- entireSSTableInterDcThrottleMebibytes - Variable in class org.apache.cassandra.tools.LoaderOptions
- entireSSTableThrottleMebibytes - Variable in class org.apache.cassandra.tools.LoaderOptions
- 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.indexsummary.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
- entryIterator() - Method in class org.apache.cassandra.db.tries.Trie
-
Returns the ordered entry set of this trie's content in an iterator.
- entrySet() - Method in class org.apache.cassandra.db.tries.Trie
-
Returns the ordered entry set of this trie's content as an iterable.
- 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.service.FailureRecordingCallback.AsMap
- 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
- EOF - org.apache.cassandra.db.commitlog.CommitLogReadHandler.CommitLogReadErrorReason
- EOF - org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer.TokenType
- ephemeral - Variable in class org.apache.cassandra.service.snapshot.SnapshotManifest
- EQ - org.apache.cassandra.cql3.Operator
- EQ - org.apache.cassandra.index.sai.plan.Expression.IndexOperator
- EQ - org.apache.cassandra.index.sasi.plan.Expression.Op
- 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 - org.apache.cassandra.db.context.CounterContext.Relationship
- 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.DataRateSpec
- equals(Object) - Method in class org.apache.cassandra.config.DataStorageSpec
- equals(Object) - Method in class org.apache.cassandra.config.DurationSpec
- 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.EncryptionOptions.ServerEncryptionOptions
-
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(Object) - Method in class org.apache.cassandra.config.RetrySpec.MaxAttempt
- equals(Object) - Method in class org.apache.cassandra.config.SubnetGroups
- equals(Object) - Method in class org.apache.cassandra.config.TransparentDataEncryptionOptions
- equals(Object) - Method in class org.apache.cassandra.cql3.CIDR
- 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.CQL3Type.Vector
- 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.masking.ColumnMask
- 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.types.VectorType
- equals(Object) - Method in class org.apache.cassandra.cql3.functions.UDAggregate
- equals(Object) - Method in class org.apache.cassandra.cql3.functions.UDFDataType
- equals(Object) - Method in class org.apache.cassandra.cql3.functions.UDFunction
- 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(Object) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
- equals(Object) - Method in class org.apache.cassandra.cql3.selection.TermSelector
- equals(Object) - Method in class org.apache.cassandra.cql3.selection.VectorSelector
- 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(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(Object) - Method in class org.apache.cassandra.db.Columns
- equals(Object) - 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.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(Object) - Method in class org.apache.cassandra.db.LivenessInfo
- equals(Object) - Method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- equals(Object) - Method in class org.apache.cassandra.db.marshal.CollectionType
- equals(Object) - Method in class org.apache.cassandra.db.marshal.CompositeType
- equals(Object) - Method in class org.apache.cassandra.db.marshal.CompositeType.Serializer
- equals(Object) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
- equals(Object) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType.Serializer
- equals(Object) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
- equals(Object) - Method in class org.apache.cassandra.db.marshal.TupleType
- equals(Object) - Method in class org.apache.cassandra.db.marshal.UserType
- equals(Object) - Method in class org.apache.cassandra.db.marshal.VectorType
- equals(Object) - Method in class org.apache.cassandra.db.memtable.ShardBoundaries
- 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.partitions.AbstractBTreePartition
- 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(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.ArtificialBoundMarker
- 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.hints.PendingHintsInfo
- equals(Object) - Method in class org.apache.cassandra.index.Index.Group.Key
- equals(Object) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- equals(Object) - Method in class org.apache.cassandra.index.sai.disk.format.Version
- equals(Object) - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
- equals(Object) - Method in class org.apache.cassandra.index.sai.plan.Expression.Bound
- equals(Object) - Method in class org.apache.cassandra.index.sai.plan.Expression
- equals(Object) - Method in class org.apache.cassandra.index.sai.plan.Expression.Value
- equals(Object) - Method in class org.apache.cassandra.index.sai.SSTableContext
- equals(Object) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- equals(Object) - Method in class org.apache.cassandra.index.sai.utils.IndexIdentifier
- equals(Object) - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
- equals(Object) - Method in class org.apache.cassandra.index.sai.utils.PartitionInfo
- 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.Component.Type
- equals(Object) - Method in class org.apache.cassandra.io.sstable.Descriptor
- equals(Object) - Method in class org.apache.cassandra.io.sstable.format.AbstractSSTableFormat
- 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.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.sstable.SequenceBasedSSTableId
- equals(Object) - Method in class org.apache.cassandra.io.sstable.UUIDBasedSSTableId
- equals(Object) - Method in class org.apache.cassandra.io.util.File
- 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 sensitiveequals
ofList
or the order obliviousequals
ofSet
. - equals(Object) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
- 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.state.Completable.Result
- equals(Object) - Method in class org.apache.cassandra.repair.state.SyncState.Id
- 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.DistributedSchema
- equals(Object) - Method in class org.apache.cassandra.schema.DroppedColumn
- 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.MemtableParams
- 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.UserFunctions
- 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(Object) - Method in class org.apache.cassandra.service.DataResurrectionCheck.Heartbeat
- 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.AbstractPaxosRepair.Failure
- equals(Object) - Method in class org.apache.cassandra.service.paxos.Ballot
- equals(Object) - Method in class org.apache.cassandra.service.paxos.Commit
- equals(Object) - Method in class org.apache.cassandra.service.paxos.PaxosRepairHistory
- equals(Object) - Method in class org.apache.cassandra.service.paxos.PaxosState.Key
- equals(Object) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosKeyState
- 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.service.reads.thresholds.WarningsSnapshot.Counter
- equals(Object) - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- equals(Object) - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Warnings
- equals(Object) - Method in class org.apache.cassandra.service.snapshot.SnapshotManifest
- equals(Object) - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
- 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) - 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.RMIClientSocketFactoryImpl
- equals(Object) - Method in class org.apache.cassandra.utils.RMIServerSocketFactoryImpl
- equals(Object) - Method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram
- equals(Object) - Method in class org.apache.cassandra.utils.TimeUUID
- equals(Object[], Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
- equals(UUID) - Method in class org.apache.cassandra.utils.TimeUUID
- equals(L, ValueAccessor<L>, R, ValueAccessor<R>) - Static method in interface org.apache.cassandra.db.marshal.ValueAccessor
- equals(ParameterizedClass) - Method in class org.apache.cassandra.config.ParameterizedClass
- equals(TransparentDataEncryptionOptions) - Method in class org.apache.cassandra.config.TransparentDataEncryptionOptions
- equals(ClusteringPrefix<?>, Object) - Static method in interface org.apache.cassandra.db.ClusteringPrefix
- equals(ClusteringPrefix<V1>, ClusteringPrefix<V2>) - Static method in interface org.apache.cassandra.db.ClusteringPrefix
- equals(CommitLogDescriptor) - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
- equals(LifecycleTransaction.ReaderState) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState
- 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(SetType<?>, Sets.Value) - Method in class org.apache.cassandra.cql3.Sets.Value
- equals(UserType, UserTypes.Value) - Method in class org.apache.cassandra.cql3.UserTypes.Value
- equals(Cell<V1>, Cell<V2>) - Static method in class org.apache.cassandra.db.rows.AbstractCell
- equals(EncryptionContext) - Method in class org.apache.cassandra.security.EncryptionContext
- equals(PaxosState.Key) - Method in class org.apache.cassandra.service.paxos.PaxosState.Key
- equals(TimeUUID) - Method in class org.apache.cassandra.utils.TimeUUID
- 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
- equalsWithShortLength(DataInput, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Returns true if the buffer at the current position in the input matches given buffer.
- err - Variable in class org.apache.cassandra.tools.Output
- err(Throwable) - Method in class org.apache.cassandra.tools.NodeTool
- 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
- errMsg(boolean, String, long, long) - Method in class org.apache.cassandra.db.guardrails.PercentageThreshold
- errMsg(boolean, String, long, long) - Method in class org.apache.cassandra.db.guardrails.Threshold
- error - Variable in class org.apache.cassandra.metrics.Sampler.Sample
- error - Variable in class org.apache.cassandra.transport.messages.ErrorMessage
- error() - Method in class org.apache.cassandra.utils.MonotonicClock.AbstractEpochSamplingClock.AlmostSameTime
- 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, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
- error(long, String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
- error(Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
- error(String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
- error(RepairJobDesc, PreviewKind, String) - Static method in exception org.apache.cassandra.exceptions.RepairException
- ERROR - org.apache.cassandra.audit.AuditLogEntryCategory
- ERROR - org.apache.cassandra.transport.Message.Type
- ERROR - org.apache.cassandra.utils.NoSpamLogger.Level
- ERROR - org.apache.cassandra.utils.progress.ProgressEventType
-
When observing process completes with error, this is sent once before COMPLETE.
- 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
- ESCAPE - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
Escape value.
- ESCAPED_0_CONT - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- ESCAPED_0_DONE - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- ESTABLISHED - org.apache.cassandra.transport.ConnectionStage
- 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 - 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.db.compaction.writers.CompactionAwareWriter
-
estimated number of keys we should write
- estimatedKeys() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- estimatedKeys() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- estimatedKeys() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Calculates an estimate of the number of keys in the sstable represented by this reader.
- estimatedKeysForRange(Range<Token>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- estimatedKeysForRanges(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- estimatedKeysForRanges(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- estimatedKeysForRanges(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Calculates an estimate of the number of keys for the given ranges in the sstable represented by this reader.
- 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.
- estimatedMemIndexMemoryUsed() - Method in class org.apache.cassandra.index.sai.memory.MemtableIndexManager
- estimatedMemoryUse() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
- estimatedMemoryUsed() - Method in class org.apache.cassandra.index.sai.memory.MemtableIndex
- estimatedPartitionCount - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Approximate number of keys in table.
- estimatedPartitions - Variable in class org.apache.cassandra.repair.state.ValidationState
- 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.SizeTieredCompactionStrategy
- estimatedRemainingTasks - Variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
- estimatedRemainingTasks - Variable in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- estimatedRemainingWriteBytes() - Method in class org.apache.cassandra.db.compaction.ActiveCompactions
-
Get the estimated number of bytes remaining to write per sstable directory
- estimatedRemainingWriteBytes() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
Note that this estimate is based on the amount of data we have left to read - it assumes input size == output size for a compaction, which is not really true, but should most often provide a worst case remaining write size.
- estimatedTombstoneDropTime - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- estimatedTombstoneDropTime - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
- estimatedTotalBytes - Variable in class org.apache.cassandra.repair.state.ValidationState
- 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(FileHandle) - Method in class org.apache.cassandra.io.sstable.format.big.BigSSTableReaderLoadingBuilder
- estimateSize(SSTableWriter.SSTableSizeParameters) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat.SSTableWriterFactory
-
Tries to estimate the size of all the sstable files from the provided parameters.
- 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 - Variable in class org.apache.cassandra.transport.messages.EventMessage
- Event - Class in org.apache.cassandra.transport
- EVENT - org.apache.cassandra.transport.Message.Type
- 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
- EVICTED_FROM_MEMBERSHIP - org.apache.cassandra.gms.GossiperEvent.GossiperEventType
- evictHungRepairs() - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosRepairState
- evictHungRepairs() - Static method in class org.apache.cassandra.service.paxos.Paxos
- evictHungRepairs() - Method in class org.apache.cassandra.service.StorageService
- evictHungRepairs() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- evictPrepared(MD5Digest) - Method in class org.apache.cassandra.cql3.QueryProcessor
- EXACT_MATCH - org.apache.cassandra.cql3.AssignmentTestable.TestResult
- exactCandidate(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex.Reader
-
Finds a candidate for an exact key search.
- exactMatch(ByteComparable) - Method in class org.apache.cassandra.index.sai.disk.v1.trie.TrieTermsDictionaryReader
- exactMatch(ByteComparable, QueryEventListener.TrieIndexEventListener, QueryContext) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.LiteralIndexSegmentTermsReader
- exceedsSegmentLimit(long) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder
- except(String, Object...) - Method in class org.apache.cassandra.schema.TableMetadata
- exception - org.apache.cassandra.config.Config.CorruptedTombstoneStrategy
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.cassandra.net.InboundMessageHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.cassandra.streaming.async.NettyStreamingChannel
- 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.
- EXCL_END_BOUND - org.apache.cassandra.db.ClusteringPrefix.Kind
- EXCL_END_INCL_START_BOUNDARY - org.apache.cassandra.db.ClusteringPrefix.Kind
- EXCL_START_BOUND - org.apache.cassandra.db.ClusteringPrefix.Kind
- 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 - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- excluded_categories - Variable in class org.apache.cassandra.audit.AuditLogOptions
- EXCLUDED_CATEGORIES - Static variable in class org.apache.cassandra.audit.AuditLogOptionsCompositeData.AuditLogOption
- excluded_keyspaces - Variable in class org.apache.cassandra.audit.AuditLogOptions
- EXCLUDED_KEYSPACES - Static variable in class org.apache.cassandra.audit.AuditLogOptionsCompositeData.AuditLogOption
- EXCLUDED_KEYSPACES_CONFIG_PROPERTY - Static variable in class org.apache.cassandra.service.DataResurrectionCheck
- EXCLUDED_TABLES_CONFIG_PROPERTY - Static variable in class org.apache.cassandra.service.DataResurrectionCheck
- excluded_users - Variable in class org.apache.cassandra.audit.AuditLogOptions
- EXCLUDED_USERS - Static variable in class org.apache.cassandra.audit.AuditLogOptionsCompositeData.AuditLogOption
- ExcludeLocalDatacenterFilter(IEndpointSnitch) - Constructor for class org.apache.cassandra.dht.RangeStreamer.ExcludeLocalDatacenterFilter
- 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, ClusteringPrefix<V>, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
- 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
- exclusiveCloseInclusiveOpen(boolean, ClusteringPrefix<V>, DeletionTime, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
- 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
- exclusiveEndOf(ByteBuffer...) - Static method in class org.apache.cassandra.db.BufferClusteringBound
- exclusiveEndOf(ClusteringPrefix<V>) - Static method in interface org.apache.cassandra.db.ClusteringBound
- exclusiveOpen(boolean, ClusteringPrefix<V>, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
- 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
- exclusiveStartOf(ByteBuffer...) - Static method in class org.apache.cassandra.db.BufferClusteringBound
- exclusiveStartOf(ClusteringPrefix<V>) - 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.
- exec(Map<String, String>, Duration, int, int, String...) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Starts and waits for the given
cmd
to finish. - execute() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.LiteralIndexSegmentTermsReader.TermQuery
- execute() - Method in class org.apache.cassandra.streaming.StreamPlan
-
Execute this
StreamPlan
asynchronously. - execute(Runnable) - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
- execute(Runnable) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- execute(Runnable) - Method in class org.apache.cassandra.concurrent.SEPExecutor
- execute(Runnable) - Method in enum org.apache.cassandra.concurrent.Stage
- execute(Runnable) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorPlus
- execute(Runnable) - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- execute(String...) - Method in class org.apache.cassandra.tools.NodeTool
- execute(String, List<ByteBuffer>, ConsistencyLevel) - Method in class org.apache.cassandra.transport.SimpleClient
- execute(String, ConsistencyLevel) - Method in class org.apache.cassandra.transport.SimpleClient
- 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(Throwable) - Method in interface org.apache.cassandra.utils.JVMStabilityInspector.OnKillHook
- 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(Supplier<Future<CoordinatedRepairResult>>) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
-
Runs the asynchronous consistent repair session.
- execute(List<Message.Request>) - Method in class org.apache.cassandra.transport.SimpleClient
- execute(Set<InetAddressAndPort>, Function<InetAddressAndPort, String>) - Method in class org.apache.cassandra.net.StartupClusterConnectivityChecker
- execute(ExecutorLocals, Runnable) - Method in enum org.apache.cassandra.concurrent.Stage
- execute(StartupChecksOptions) - Method in class org.apache.cassandra.service.DataResurrectionCheck
- execute(StartupChecksOptions) - Method in class org.apache.cassandra.service.FileSystemOwnershipCheck
- execute(StartupChecksOptions) - 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(Arguments) - Method in class org.apache.cassandra.cql3.functions.BytesConversionFcts.FromBlobFunction
- execute(Arguments) - Method in class org.apache.cassandra.cql3.functions.BytesConversionFcts.ToBlobFunction
- execute(Arguments) - Method in class org.apache.cassandra.cql3.functions.FromJsonFct
- execute(Arguments) - Method in class org.apache.cassandra.cql3.functions.masking.DefaultMaskingFunction
- execute(Arguments) - Method in class org.apache.cassandra.cql3.functions.masking.HashMaskingFunction
- execute(Arguments) - Method in class org.apache.cassandra.cql3.functions.masking.NullMaskingFunction
- execute(Arguments) - Method in class org.apache.cassandra.cql3.functions.masking.PartialMaskingFunction
- execute(Arguments) - Method in class org.apache.cassandra.cql3.functions.masking.ReplaceMaskingFunction
- execute(Arguments) - Method in interface org.apache.cassandra.cql3.functions.ScalarFunction
-
Applies this function to the specified arguments.
- execute(Arguments) - Method in class org.apache.cassandra.cql3.functions.TimeFcts.TemporalConversionFunction
- execute(Arguments) - Method in class org.apache.cassandra.cql3.functions.ToJsonFct
- execute(Arguments) - Method in class org.apache.cassandra.cql3.functions.TokenFct
- execute(Arguments) - Method in class org.apache.cassandra.cql3.functions.UDFunction
- execute(ActiveCompactionsTracker) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
-
executes the task and unmarks sstables compacting
- execute(ConsistencyLevel, ClientState, Dispatcher.RequestTime) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
- execute(ConsistencyLevel, ClientState, Dispatcher.RequestTime) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand.VirtualTablePartitionRangeReadCommand
- execute(ConsistencyLevel, ClientState, Dispatcher.RequestTime) - Method in interface org.apache.cassandra.db.ReadQuery
-
Executes the query at the provided consistency level.
- execute(ConsistencyLevel, ClientState, Dispatcher.RequestTime) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
- execute(ConsistencyLevel, ClientState, Dispatcher.RequestTime) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand.Group
- execute(ConsistencyLevel, ClientState, Dispatcher.RequestTime) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand.VirtualTableGroup
- execute(ConsistencyLevel, ClientState, Dispatcher.RequestTime) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand.VirtualTableSinglePartitionReadCommand
- 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(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(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(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(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(FilterPipeline, String) - Static method in class org.apache.cassandra.index.sai.analyzer.filter.FilterPipelineExecutor
- execute(FilterPipelineTask<F, T>, T) - Static method in class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineExecutor
- execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.AddIdentityStatement
- execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterRoleStatement
- execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
- execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
- execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.CreateRoleStatement
- execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.DropIdentityStatement
- 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(ClientState) - Method in class org.apache.cassandra.cql3.statements.RevokePermissionsStatement
- execute(ClientState) - Method in class org.apache.cassandra.cql3.statements.RevokeRoleStatement
- execute(Commit.Proposal, InetAddressAndPort) - Static method in class org.apache.cassandra.service.paxos.PaxosPropose.RequestHandler
- execute(PaxosPrepareRefresh.Request, InetAddressAndPort) - Static method in class org.apache.cassandra.service.paxos.PaxosPrepareRefresh.RequestHandler
- execute(QueryState, boolean) - Method in class org.apache.cassandra.cql3.statements.schema.AlterSchemaStatement
- execute(QueryState, BatchQueryOptions, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
- execute(QueryState, QueryOptions, Dispatcher.RequestTime) - Method in interface org.apache.cassandra.cql3.CQLStatement
-
Execute the statement and return the resulting result or null if there is no result.
- execute(QueryState, QueryOptions, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
- execute(QueryState, QueryOptions, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.statements.AuthorizationStatement
- execute(QueryState, QueryOptions, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.statements.BatchStatement
- execute(QueryState, QueryOptions, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.statements.DescribeStatement
- execute(QueryState, QueryOptions, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- execute(QueryState, QueryOptions, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.statements.schema.AlterSchemaStatement
- execute(QueryState, QueryOptions, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
- execute(QueryState, QueryOptions, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.statements.TruncateStatement
- execute(QueryState, QueryOptions, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.statements.UseStatement
- execute(QueryState, Dispatcher.RequestTime) - Method in class org.apache.cassandra.transport.Message.Request
- execute(QueryState, Dispatcher.RequestTime, boolean) - Method in class org.apache.cassandra.transport.Message.Request
- execute(QueryState, Dispatcher.RequestTime, boolean) - Method in class org.apache.cassandra.transport.messages.AuthResponse
- execute(QueryState, Dispatcher.RequestTime, boolean) - Method in class org.apache.cassandra.transport.messages.BatchMessage
- execute(QueryState, Dispatcher.RequestTime, boolean) - Method in class org.apache.cassandra.transport.messages.ExecuteMessage
- execute(QueryState, Dispatcher.RequestTime, boolean) - Method in class org.apache.cassandra.transport.messages.OptionsMessage
- execute(QueryState, Dispatcher.RequestTime, boolean) - Method in class org.apache.cassandra.transport.messages.PrepareMessage
- execute(QueryState, Dispatcher.RequestTime, boolean) - Method in class org.apache.cassandra.transport.messages.QueryMessage
- execute(QueryState, Dispatcher.RequestTime, boolean) - Method in class org.apache.cassandra.transport.messages.RegisterMessage
- execute(QueryState, Dispatcher.RequestTime, boolean) - Method in class org.apache.cassandra.transport.messages.StartupMessage
- execute(StreamPlan) - Method in interface org.apache.cassandra.repair.StreamExecutor
- execute(NodeProbe) - Method in class org.apache.cassandra.tools.ListCIDRGroups
- 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.CIDRFilteringStats
- 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.DataPaths
- 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.DropCIDRGroup
- 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(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.ForceCompact
- 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.GetAuditLog
- execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetAuthCacheConfig
- execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetBatchlogReplayTrottle
- execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetCIDRGroupsOfIP
- execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.GetColumnIndexSize
- 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.GetDefaultKeyspaceRF
- 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.InvalidateCIDRPermissionsCache
- execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.InvalidateCounterCache
- execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.InvalidateCredentialsCache
- execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.InvalidateJmxPermissionsCache
- execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.InvalidateKeyCache
- execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.InvalidateNetworkPermissionsCache
- execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.InvalidatePermissionsCache
- execute(NodeProbe) - Method in class org.apache.cassandra.tools.nodetool.InvalidateRolesCache
- 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.ListPendingHints
- 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.RecompressSSTables
- 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.ReloadCIDRGroupsCache
- 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.SetAuthCacheConfig
- 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.SetColumnIndexSize
- 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.SetDefaultKeyspaceRF
- 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.UpdateCIDRGroup
- 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(Message.Request) - Method in class org.apache.cassandra.transport.SimpleClient
- execute(Message.Request, boolean) - Method in class org.apache.cassandra.transport.SimpleClient
- execute(WithResources, Runnable) - Method in interface org.apache.cassandra.concurrent.ExecutorPlus
-
Invoke
task
. - execute(WithResources, Runnable) - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
- execute(WithResources, Runnable) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- execute(WithResources, Runnable) - Method in class org.apache.cassandra.concurrent.SEPExecutor
- execute(WithResources, Runnable) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorPlus
- execute(WithResources, Runnable) - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- EXECUTE - org.apache.cassandra.auth.Permission
- EXECUTE - org.apache.cassandra.transport.Message.Type
- executeAggregateImpl(Object, Arguments) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
- executeAggregateUserDefined(Object, Arguments) - Method in class org.apache.cassandra.cql3.functions.JavaBasedUDFunction
- executeAggregateUserDefined(Object, Arguments) - 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
- executeAsync(InetAddressAndPort, String, Object...) - Static method in class org.apache.cassandra.cql3.QueryProcessor
- 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(Object, Arguments) - Method in class org.apache.cassandra.cql3.functions.UDFunction
- executeImpl(Arguments) - Method in class org.apache.cassandra.cql3.functions.JavaUDF
- executeInternal(String, Object...) - Static method in class org.apache.cassandra.cql3.QueryProcessor
- 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
- executeInternal(QueryState, QueryOptions, long, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
- executeInternalRawWithNow(long, String, Object...) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
A special version of executeInternal that takes the time used as "now" for the query in argument.
- executeInternalWithCondition(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- executeInternalWithNow(long, Dispatcher.RequestTime, 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.
- executeInternalWithNowInSec(String, long, Object...) - Static method in class org.apache.cassandra.cql3.QueryProcessor
- executeInternalWithoutCondition(QueryState, QueryOptions, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- executeInternalWithPaging(String, int, Object...) - Static method in class org.apache.cassandra.cql3.QueryProcessor
- executeLocally(ReadExecutionController) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand.VirtualTablePartitionRangeReadCommand
- 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.SinglePartitionReadCommand.VirtualTableSinglePartitionReadCommand
- executeLocally(ReadExecutionController) - Method in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
- 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.schema.AlterSchemaStatement
- 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
- 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(long, long, String, Object...) - Static method in class org.apache.cassandra.cql3.QueryProcessor
-
Execute an internal query with the provided
nowInSec
andtimestamp
for theQueryState
. - executeOnSelf() - Method in class org.apache.cassandra.service.paxos.PaxosCommit
-
Execute locally and record response
- executeOnSelf(I, BiFunction<I, InetAddressAndPort, T>) - Method in class org.apache.cassandra.service.paxos.PaxosRequestCallback
- 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
- executeRawInternal(QueryOptions, ClientState, long) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
- 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(Arguments) - Method in class org.apache.cassandra.cql3.functions.JavaBasedUDFunction
- executeUserDefined(Arguments) - Method in class org.apache.cassandra.cql3.functions.UDFunction
- executeWhenFinished(Runnable) - Method in class org.apache.cassandra.service.PendingRangeCalculatorService
- executionController() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand.VirtualTablePartitionRangeReadCommand
- 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.SinglePartitionReadCommand.VirtualTableSinglePartitionReadCommand
- executionController() - Method in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
- 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.
- executionController(boolean) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand.VirtualTablePartitionRangeReadCommand
- executionController(boolean) - Method in class org.apache.cassandra.db.ReadCommand
- executionController(boolean) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand.VirtualTableSinglePartitionReadCommand
- ExecutionFailure - Class in org.apache.cassandra.concurrent
-
Standardised handling of failures during execution - mostly this involves invoking a thread's
Thread.UncaughtExceptionHandler
orJVMStabilityInspector.uncaughtException(Thread, Throwable)
, with special handling forCompactionInterruptedException
. - ExecutionFailure() - Constructor for class org.apache.cassandra.concurrent.ExecutionFailure
- executionQuotaNano - Variable in class org.apache.cassandra.index.sai.QueryContext
- executor - Variable in class org.apache.cassandra.concurrent.SingleThreadExecutorPlus.AtLeastOnce
- executor - Variable in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- executor - Static variable in class org.apache.cassandra.utils.progress.jmx.JMXBroadcastExecutor
- 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
- ExecutorBuilder<E extends java.util.concurrent.ExecutorService> - Interface in org.apache.cassandra.concurrent
-
Configure an executor before creating it.
- ExecutorBuilderFactory<E extends ExecutorPlus,S extends SequentialExecutorPlus> - Interface in org.apache.cassandra.concurrent
-
Entry point for configuring and creating new executors.
- ExecutorBuilderFactory.Jmxable<E extends ExecutorPlus,S extends SequentialExecutorPlus> - Interface in org.apache.cassandra.concurrent
-
Entry point for configuring and creating new executors.
- executorFactory() - Static method in class org.apache.cassandra.concurrent.ExecutorFactory.Global
- executorFactory() - Method in interface org.apache.cassandra.repair.SharedContext
- executorFactory() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- executorFactory() - Method in class org.apache.cassandra.repair.SharedContext.Global
- ExecutorFactory - Interface in org.apache.cassandra.concurrent
-
Entry point for configuring and creating new executors.
- ExecutorFactory.Default - Class in org.apache.cassandra.concurrent
- ExecutorFactory.Global - Class in org.apache.cassandra.concurrent
- ExecutorFactory.LocalAwareSubFactory - Interface in org.apache.cassandra.concurrent
- ExecutorFactory.LocalAwareSubFactoryWithJMX - Interface in org.apache.cassandra.concurrent
- ExecutorFactory.SimulatorSemantics - Enum in org.apache.cassandra.concurrent
- ExecutorLocals - Class in org.apache.cassandra.concurrent
- ExecutorLocals(TraceState, ClientWarn.State) - Constructor for class org.apache.cassandra.concurrent.ExecutorLocals
- ExecutorLocals.Impl - Class in org.apache.cassandra.concurrent
- ExecutorPlus - Interface in org.apache.cassandra.concurrent
-
Cassandra's extension of
ExecutorService
, using our ownFuture
, supportingExecutorPlus.inExecutor()
, and execution with associated resourcesExecutorPlus.execute(WithResources, Runnable)
(which is primarily used for encapsulatingExecutorLocals
without leaking implementing classes). - ExecutorPlus.MaximumPoolSizeListener - Interface 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
- EXHAUSTED - Static variable in class org.apache.cassandra.io.sstable.format.bti.ScrubIterator
- 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
- exists() - Method in class org.apache.cassandra.io.util.File
- exists() - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
- exists(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- EXISTS - org.apache.cassandra.repair.state.ParticipateState.RegisterStatus
- EXIT - org.apache.cassandra.index.sasi.utils.trie.Cursor.Decision
-
Exit the traverse operation
- exp(Number) - Method in class org.apache.cassandra.db.marshal.ByteType
- exp(Number) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
- exp(Number) - Method in class org.apache.cassandra.db.marshal.DecimalType
- exp(Number) - Method in class org.apache.cassandra.db.marshal.DoubleType
- exp(Number) - Method in class org.apache.cassandra.db.marshal.FloatType
- exp(Number) - Method in class org.apache.cassandra.db.marshal.Int32Type
- exp(Number) - Method in class org.apache.cassandra.db.marshal.IntegerType
- exp(Number) - Method in class org.apache.cassandra.db.marshal.LongType
- exp(Number) - Method in class org.apache.cassandra.db.marshal.NumberType
-
Raises e to the power of the argument.
- exp(Number) - Method in class org.apache.cassandra.db.marshal.ShortType
- exp(BigDecimal) - Method in class org.apache.cassandra.db.marshal.DecimalType
- 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
- expected(long, float, int) - Static method in class org.apache.cassandra.index.sai.disk.v1.bitpack.MonotonicBlockPackedReader
- expectedBloomFilterSize - Variable in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- expectedNodesVisited(int, int, int) - Static method in class org.apache.cassandra.index.sai.memory.VectorMemoryIndex
-
All parameters must be greater than zero.
- expFct(NumberType<?>) - Static method in class org.apache.cassandra.cql3.functions.MathFcts
- EXPIRATION_DATE_OVERFLOW_POLICY - org.apache.cassandra.config.CassandraRelevantProperties
- EXPIRATION_OVERFLOW_WARNING_INTERVAL_MINUTES - org.apache.cassandra.config.CassandraRelevantProperties
- 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.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.TimeWindowCompactionStrategyOptions
- expiredSSTableCheckFrequency - Variable in class org.apache.cassandra.db.compaction.unified.Controller
- expiresAfterNanos() - Method in enum org.apache.cassandra.net.Verb
- expiresAt - Variable in class org.apache.cassandra.service.snapshot.SnapshotManifest
- expiresAtNanos - Variable in class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
- expiresAtNanos - Variable in class org.apache.cassandra.net.Message.Header
- expiresAtNanos() - Method in class org.apache.cassandra.net.Message
- expiresAtNanos(long) - Method in enum org.apache.cassandra.net.Verb
- expireUpgradeFromVersion() - Method in class org.apache.cassandra.gms.Gossiper
- expiring(long, int, long) - Static method in class org.apache.cassandra.db.LivenessInfo
- expiring(ColumnMetadata, long, int, long, ByteBuffer) - Static method in class org.apache.cassandra.db.rows.BufferCell
- expiring(ColumnMetadata, long, int, long, 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
- ExpMovingAverage - Class in org.apache.cassandra.utils
-
Sample-based exponential moving average.
- ExponentialBackoff(int, long, long, DoubleSupplier) - Constructor for class org.apache.cassandra.utils.Backoff.ExponentialBackoff
- expression - Variable in class org.apache.cassandra.cql3.Ordering
- Expression - Class in org.apache.cassandra.index.sai.plan
-
An
Expression
is an internal representation of an index query operation. - Expression - Class in org.apache.cassandra.index.sasi.plan
- Expression(String, AbstractType<?>) - Constructor for class org.apache.cassandra.index.sasi.plan.Expression
- 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(ColumnMetadata) - Constructor for class org.apache.cassandra.cql3.Ordering.Expression
- Expression(ColumnMetadata, Operator, ByteBuffer) - Constructor for class org.apache.cassandra.db.filter.RowFilter.Expression
- Expression.Bound - Class in org.apache.cassandra.index.sai.plan
- Expression.Bound - Class in org.apache.cassandra.index.sasi.plan
- Expression.IndexedExpression - Class in org.apache.cassandra.index.sai.plan
- Expression.IndexOperator - Enum in org.apache.cassandra.index.sai.plan
- Expression.Op - Enum in org.apache.cassandra.index.sasi.plan
- Expression.UnindexedExpression - Class in org.apache.cassandra.index.sai.plan
- Expression.Value - Class in org.apache.cassandra.index.sai.plan
-
A representation of a column value in its raw and encoded form.
- 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.sai.plan.FilterTree
- expressions - Variable in class org.apache.cassandra.index.sasi.plan.Operation.Builder
- expressions - Variable in class org.apache.cassandra.index.sasi.plan.Operation
- extend(long) - Method in class org.apache.cassandra.io.util.MmappedRegions
-
Extends this collection of mmapped regions up to the provided total length.
- extend(PartitionIterator, MorePartitions<? super PartitionIterator>) - Static method in interface org.apache.cassandra.db.transform.MorePartitions
- extend(UnfilteredPartitionIterator, MorePartitions<? super UnfilteredPartitionIterator>) - Static method in interface org.apache.cassandra.db.transform.MorePartitions
- extend(RowIterator, MoreRows<? super RowIterator>) - Static method in interface org.apache.cassandra.db.transform.MoreRows
- 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(CompressionMetadata) - Method in class org.apache.cassandra.io.util.MmappedRegions
-
Extends this collection of mmapped regions up to the length of the compressed file described by the provided metadata.
- extend(Replica, Runnable, UnfilteredPartitionIterator, ReadCommand, DataLimits.Counter, Dispatcher.RequestTime, 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 - Variable in class org.apache.cassandra.io.sstable.IVerifier.Options
-
Force extended verification - unless it is enabled, extended verificiation will be done only if there is no digest present.
- extendedVerification(boolean) - Method in class org.apache.cassandra.io.sstable.IVerifier.Options.Builder
- EXTENSION - Static variable in class org.apache.cassandra.io.sstable.Descriptor
- extensions - Variable in class org.apache.cassandra.schema.TableParams
- 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 - org.apache.cassandra.schema.TableParams.Option
- 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
- extract(ByteBuffer, int) - Method in class org.apache.cassandra.locator.InetAddressAndPort.Serializer
-
Extract
InetAddressAndPort
from the providedByteBuffer
without altering its state. - extract(VALUE, int, int) - Method in interface org.apache.cassandra.io.tries.Walker.Extractor
- extractCertificates(String) - Static method in class org.apache.cassandra.security.PEMReader
-
Extracts the certificates/cert-chain from the PEM content.
- 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
- extractPrivateKey(String) - Static method in class org.apache.cassandra.security.PEMReader
-
Extracts private key from the PEM content for the private key, assuming its not PBE.
- extractPrivateKey(String, String) - Static method in class org.apache.cassandra.security.PEMReader
-
Extracts private key from the Password Based Encrypted PEM content for the private key.
F
- FACTORED - org.apache.cassandra.index.sasi.disk.TokenTreeBuilder.EntryType
- factories() - Static method in class org.apache.cassandra.cql3.functions.masking.PartialMaskingFunction
- factory - Static variable in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- 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
- factory() - Static method in class org.apache.cassandra.cql3.functions.masking.DefaultMaskingFunction
- factory() - Static method in class org.apache.cassandra.cql3.functions.masking.HashMaskingFunction
- factory() - Static method in class org.apache.cassandra.cql3.functions.masking.NullMaskingFunction
- factory() - Static method in class org.apache.cassandra.cql3.functions.masking.ReplaceMaskingFunction
- 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 {@param} - factory() - Method in class org.apache.cassandra.schema.MemtableParams
- factory(Map<String, String>) - Static method in class org.apache.cassandra.db.memtable.ShardedSkipListMemtable
- factory(Map<String, String>) - Static method in class org.apache.cassandra.db.memtable.TrieMemtable
- Factory() - Constructor for class org.apache.cassandra.cql3.selection.Selector.Factory
- Factory(String, FunctionParameter...) - Constructor for class org.apache.cassandra.cql3.functions.masking.MaskingFunction.Factory
- Factory(IPartitioner, ClusteringComparator) - Constructor for class org.apache.cassandra.index.sai.utils.PrimaryKey.Factory
- Factory(IndexDescriptor) - Constructor for class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap.Factory
- Factory(IndexDescriptor, SSTableReader) - Constructor for class org.apache.cassandra.index.sai.disk.v1.WidePrimaryKeyMap.Factory
- FACTORY - Static variable in class org.apache.cassandra.db.memtable.SkipListMemtable
- fail - org.apache.cassandra.config.Config.PaxosOnLinearizabilityViolation
- fail() - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
- fail(String) - Method in class org.apache.cassandra.repair.state.AbstractCompletable.BasePhase
- fail(String) - Static method in class org.apache.cassandra.repair.state.Completable.Result
- fail(String, String, ClientState) - Method in class org.apache.cassandra.db.guardrails.Guardrail
- fail(String, ClientState) - Method in class org.apache.cassandra.db.guardrails.Guardrail
- fail(Throwable) - Method in class org.apache.cassandra.repair.state.AbstractCompletable.BasePhase
- fail(Throwable) - Method in class org.apache.cassandra.repair.Validator
-
Called when some error during the validation happened.
- 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 - org.apache.cassandra.index.sai.disk.v1.vector.OnHeapGraph.InvalidVectorBehavior
- FAIL_ON_MISSING_CRYPTO_PROVIDER - org.apache.cassandra.config.CassandraRelevantProperties
- FAIL_ON_MISSING_PROVIDER_KEY - Static variable in class org.apache.cassandra.security.AbstractCryptoProvider
- failed - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStats
- failed() - Method in class org.apache.cassandra.tools.NodeProbe
- failed(UUID, String) - Static method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupResponse
- FAILED - org.apache.cassandra.repair.consistent.ConsistentSession.State
- FAILED - org.apache.cassandra.service.ActiveRepairService.ParentRepairStatus
- FAILED - org.apache.cassandra.streaming.StreamSession.State
- FAILED - org.apache.cassandra.utils.AbstractGuavaIterator.State
-
We've suffered an exception and are kaput.
- FAILED_BOOTSTRAP_TIMEOUT - org.apache.cassandra.config.CassandraRelevantProperties
- FAILED_SESSION_MSG - org.apache.cassandra.net.Verb
- failedRanges - Variable in class org.apache.cassandra.repair.CoordinatedRepairResult
- failedRepairJob(TimeUUID, String, String, Throwable) - Static method in class org.apache.cassandra.schema.SystemDistributedKeyspace
- failIfCanCast(Throwable, Class<T>) - Static method in class org.apache.cassandra.utils.Throwables
- FailingBiConsumer<A,B> - Interface in org.apache.cassandra.utils
- FailingConsumer<T> - Interface in org.apache.cassandra.utils
- failOnMissingProvider - Variable in class org.apache.cassandra.security.AbstractCryptoProvider
- failParentRepair(TimeUUID, Throwable) - Static method in class org.apache.cassandra.schema.SystemDistributedKeyspace
- failRepairs(TimeUUID, String, String[], Throwable) - Static method in class org.apache.cassandra.schema.SystemDistributedKeyspace
- failSession(String, boolean) - Method in class org.apache.cassandra.service.ActiveRepairService
- failSession(String, boolean) - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
- failSession(LocalSession, boolean) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
- failSession(TimeUUID) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
- failSession(TimeUUID, boolean) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
- FailSession - Class in org.apache.cassandra.repair.messages
- FailSession(TimeUUID) - Constructor for class org.apache.cassandra.repair.messages.FailSession
- failsOn(long, ClientState) - Method in class org.apache.cassandra.db.guardrails.Threshold
- failThreshold - Variable in class org.apache.cassandra.db.guardrails.Threshold
- failure - Variable in class org.apache.cassandra.service.paxos.AbstractPaxosRepair.Failure
- failure(Throwable) - Static method in class org.apache.cassandra.utils.concurrent.ImmediateFuture
- FAILURE - org.apache.cassandra.repair.state.Completable.Result.Kind
- FAILURE - org.apache.cassandra.streaming.StreamingState.Status
- failure_detector - Variable in class org.apache.cassandra.config.Config
- FAILURE_INCREMENT - Static variable in class org.apache.cassandra.service.paxos.PaxosPropose
- FAILURE_LOGGING_INTERVAL_SECONDS - org.apache.cassandra.config.CassandraRelevantProperties
- FAILURE_RSP - org.apache.cassandra.net.Verb
- failureCause() - Method in class org.apache.cassandra.streaming.StreamingState
- failureCount() - Method in class org.apache.cassandra.service.FailureRecordingCallback.AsMap
- failureCount(FailureRecordingCallback.FailureResponses) - Static method in class org.apache.cassandra.service.FailureRecordingCallback.FailureResponses
- failureDetector() - Method in interface org.apache.cassandra.repair.SharedContext
- failureDetector() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- failureDetector() - Method in class org.apache.cassandra.repair.SharedContext.Global
- 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
- failureReason - Variable in class org.apache.cassandra.streaming.SessionInfo
- failureReason - Variable in class org.apache.cassandra.streaming.StreamSession
- failureReason() - Method in exception org.apache.cassandra.net.MessagingService.FailureResponseException
- failureReasonByEndpoint - Variable in exception org.apache.cassandra.exceptions.RequestFailureException
- failureReasonsAsMap() - Method in class org.apache.cassandra.service.FailureRecordingCallback
- FailureRecordingCallback<T> - Class in org.apache.cassandra.service
- FailureRecordingCallback() - Constructor for class org.apache.cassandra.service.FailureRecordingCallback
- FailureRecordingCallback.AsMap - Class in org.apache.cassandra.service
- FailureRecordingCallback.FailureResponses - Class in org.apache.cassandra.service
- 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
- FailureResponseException(InetAddressAndPort, RequestFailureReason) - Constructor for exception org.apache.cassandra.net.MessagingService.FailureResponseException
- FailureResponses(InetAddressAndPort, RequestFailureReason) - Constructor for class org.apache.cassandra.service.FailureRecordingCallback.FailureResponses
- failures - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
- failValue(ClientState) - Method in class org.apache.cassandra.db.guardrails.MaxThreshold
- failValue(ClientState) - Method in class org.apache.cassandra.db.guardrails.MinThreshold
- failValue(ClientState) - Method in class org.apache.cassandra.db.guardrails.Threshold
- FakeNode(InetAddressAndPort, Integer, Collection<Token>) - Constructor for class org.apache.cassandra.dht.tokenallocator.OfflineTokenAllocator.FakeNode
- FALSE - Static variable in class org.apache.cassandra.serializers.BooleanSerializer
- familyLowerBound - Variable in class org.apache.cassandra.utils.CassandraVersion
- fanoutFromScalingParameter(int) - Static method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- fast - org.apache.cassandra.config.Config.FlushCompression
- fast(BufferPoolAllocator) - Static method in class org.apache.cassandra.net.FrameDecoderLZ4
- FAST_COMPRESSION - org.apache.cassandra.io.compress.ICompressor.Uses
- FAST_COMPRESSION_LEVEL - Static variable in class org.apache.cassandra.io.compress.ZstdCompressor
- fastBuilder() - Static method in class org.apache.cassandra.utils.btree.BTree
-
Build a tree of unknown size, in order.
- 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
- FD_INITIAL_VALUE_MS - org.apache.cassandra.config.CassandraRelevantProperties
- FD_MAX_INTERVAL_MS - org.apache.cassandra.config.CassandraRelevantProperties
- fdProxy - Variable in class org.apache.cassandra.tools.NodeProbe
- fetch(Object[], int, int) - Method in class org.apache.cassandra.utils.BulkIterator.Adapter
- fetch(Object[], int, int) - Method in interface org.apache.cassandra.utils.BulkIterator
- fetch(Object[], int, int) - Method in class org.apache.cassandra.utils.BulkIterator.FromArray
- fetchAsync() - Method in class org.apache.cassandra.dht.RangeStreamer
- 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
-
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(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(CellPath) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Tester
- 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(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
- fetchNonSystemKeyspaces() - Static method in class org.apache.cassandra.schema.SchemaKeyspace
- fetchPage(int, ConsistencyLevel, ClientState, Dispatcher.RequestTime) - Method in class org.apache.cassandra.service.pager.AggregationQueryPager
- fetchPage(int, ConsistencyLevel, ClientState, Dispatcher.RequestTime) - Method in class org.apache.cassandra.service.pager.MultiPartitionPager
- fetchPage(int, ConsistencyLevel, ClientState, Dispatcher.RequestTime) - 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
- FIELD_SELECTOR - org.apache.cassandra.cql3.selection.Selector.Kind
- 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
- fields_per_udt_fail_threshold - Variable in class org.apache.cassandra.config.Config
- fields_per_udt_warn_threshold - Variable in class org.apache.cassandra.config.Config
- fieldSpecOf(ColumnSpecification, int) - Static method in class org.apache.cassandra.cql3.UserTypes
- fieldsPerUDT - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the number of fields on each UDT.
- 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.io.sstable.AbstractSSTableIterator.AbstractReader
- file - Variable in class org.apache.cassandra.io.util.FileHandle.Builder
- file - Variable in class org.apache.cassandra.io.util.FileInputStreamPlus
- file() - Method in class org.apache.cassandra.io.util.ChannelProxy
- file() - Method in class org.apache.cassandra.io.util.FileHandle
- file(boolean) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
- File - Class in org.apache.cassandra.io.util
-
A thin wrapper around java.nio.file.Path to provide more ergonomic functionality.
- File(File) - Constructor for class org.apache.cassandra.io.util.File
-
Create a File equivalent to the java.io.File provided
- File(File, String) - Constructor for class org.apache.cassandra.io.util.File
-
Construct a File representing the child
child
ofparent
- File(String) - Constructor for class org.apache.cassandra.io.util.File
-
Construct a File representing the provided
path
- File(String, String) - Constructor for class org.apache.cassandra.io.util.File
-
Construct a File representing the child
child
ofparent
- File(URI) - Constructor for class org.apache.cassandra.io.util.File
-
Convenience constructor equivalent to
new File(Paths.get(path))
- File(FileSystem, String, String...) - Constructor for class org.apache.cassandra.io.util.File
-
Unsafe constructor that allows a File to use a differet
FileSystem
thanFile.filesystem
. - File(Path) - Constructor for class org.apache.cassandra.io.util.File
- File(Path, String) - Constructor for class org.apache.cassandra.io.util.File
-
Construct a File representing the child
child
ofparent
- File(File, String) - Constructor for class org.apache.cassandra.io.util.File
-
Construct a File representing the child
child
ofparent
- FILE - org.apache.cassandra.streaming.StreamingChannel.Kind
- file_cache_enabled - Variable in class org.apache.cassandra.config.Config
- FILE_CACHE_ENABLED - org.apache.cassandra.config.CassandraRelevantProperties
- file_cache_round_up - Variable in class org.apache.cassandra.config.Config
-
Because of the current
BufferPool
slab sizes of 64 KiB, we store in the file cache buffers that divide 64 KiB, so we need to round the buffer sizes to powers of two. - file_cache_size - Variable in class org.apache.cassandra.config.Config
- FILE_PROGRESS - org.apache.cassandra.streaming.StreamEvent.Type
- FILE_SYSTEM_CHECK_ENABLE - org.apache.cassandra.config.CassandraRelevantProperties
-
Deprecated.See CASSANDRA-17797
- FILE_SYSTEM_CHECK_OWNERSHIP_FILENAME - org.apache.cassandra.config.CassandraRelevantProperties
-
Deprecated.See CASSANDRA-17797
- FILE_SYSTEM_CHECK_OWNERSHIP_TOKEN - org.apache.cassandra.config.CassandraRelevantProperties
-
Deprecated.See CASSANDRA-17797
- FILE_SYSTEM_CHECK_OWNERSHIP_TOKEN - Static variable in class org.apache.cassandra.service.FileSystemOwnershipCheck
- File.WriteMode - Enum in org.apache.cassandra.io.util
- fileAccessLock - Variable in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- fileAccessLock - Variable in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- 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
- filebasedKeystoreContext - Variable in class org.apache.cassandra.security.PEMBasedSslContextFactory.PEMBasedKeyStoreContext
- FileBasedSslContextFactory - Class in org.apache.cassandra.security
-
Abstract implementation for
ISslContextFactory
using file based, standard keystore format with the ability to hot-reload the files upon file changes (detected by thelast modified timestamp
). - FileBasedSslContextFactory() - Constructor for class org.apache.cassandra.security.FileBasedSslContextFactory
- FileBasedSslContextFactory(Map<String, Object>) - Constructor for class org.apache.cassandra.security.FileBasedSslContextFactory
- FileBasedSslContextFactory.FileBasedStoreContext - Class in org.apache.cassandra.security
- FileBasedSslContextFactory.HotReloadableFile - Class in org.apache.cassandra.security
-
Helper class for hot reloading SSL Contexts
- FileBasedStoreContext(String, String) - Constructor for class org.apache.cassandra.security.FileBasedSslContextFactory.FileBasedStoreContext
- fileBuilder(Component, SSTable) - Static method in class org.apache.cassandra.io.sstable.format.IndexComponent
- fileBuilder(Component, SSTable.Builder<?, ?>) - Static method in class org.apache.cassandra.io.sstable.format.IndexComponent
- fileBuilder(File, IOOptions, ChunkCache) - Static method in class org.apache.cassandra.io.sstable.format.IndexComponent
- FileDataInput - Interface in org.apache.cassandra.io.util
- FileDigestValidator(File, File) - 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.
- fileFor(IndexComponent) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- fileFor(IndexComponent, IndexIdentifier) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- fileFor(Component) - Method in class org.apache.cassandra.io.sstable.Descriptor
- FileHandle - Class in org.apache.cassandra.io.util
-
FileHandle
provides access to a file for reading, including the ones written by variousSequentialWriter
instances, and it is typically used bySSTableReader
. - FileHandle.Builder - Class in org.apache.cassandra.io.util
-
Configures how the file will be read (compressed, mmapped, use cache etc.)
- FileInputStreamPlus - Class in org.apache.cassandra.io.util
- FileInputStreamPlus(String) - Constructor for class org.apache.cassandra.io.util.FileInputStreamPlus
- FileInputStreamPlus(Path) - Constructor for class org.apache.cassandra.io.util.FileInputStreamPlus
- FileInputStreamPlus(File) - Constructor for class org.apache.cassandra.io.util.FileInputStreamPlus
- FileInputStreamPlus(File, int) - Constructor for class org.apache.cassandra.io.util.FileInputStreamPlus
- 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.EmptyRebufferer
- fileLength() - Method in interface org.apache.cassandra.io.util.ReaderFileProxy
- fileLength() - Method in class org.apache.cassandra.io.util.TailOverridingRebufferer
- fileLength() - Method in class org.apache.cassandra.io.util.WrappingRebufferer
- FileMessageHeaderSerializer() - Constructor for class org.apache.cassandra.streaming.messages.StreamMessageHeader.FileMessageHeaderSerializer
- filename(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- fileName - Variable in enum org.apache.cassandra.db.compaction.OperationType
- fileName - Variable in class org.apache.cassandra.streaming.ProgressInfo
- fileName() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
- FILENAME_SEPARATOR - Static variable in class org.apache.cassandra.io.sstable.Descriptor
- fileNameFormatter() - Method in class org.apache.cassandra.index.sai.disk.format.Version
- FileOutputStreamPlus - Class in org.apache.cassandra.io.util
- FileOutputStreamPlus(String) - Constructor for class org.apache.cassandra.io.util.FileOutputStreamPlus
- FileOutputStreamPlus(String, File.WriteMode) - Constructor for class org.apache.cassandra.io.util.FileOutputStreamPlus
- FileOutputStreamPlus(Path) - Constructor for class org.apache.cassandra.io.util.FileOutputStreamPlus
- FileOutputStreamPlus(Path, File.WriteMode) - Constructor for class org.apache.cassandra.io.util.FileOutputStreamPlus
- FileOutputStreamPlus(File) - Constructor for class org.apache.cassandra.io.util.FileOutputStreamPlus
- FileOutputStreamPlus(File, File.WriteMode) - Constructor for class org.apache.cassandra.io.util.FileOutputStreamPlus
- filePath - Variable in exception org.apache.cassandra.io.util.CorruptFileException
- filePath - Variable in class org.apache.cassandra.security.FileBasedSslContextFactory.FileBasedStoreContext
- filePath() - Method in class org.apache.cassandra.io.util.ChannelProxy
- FileReader - Class in org.apache.cassandra.io.util
- FileReader(String) - Constructor for class org.apache.cassandra.io.util.FileReader
- FileReader(File) - Constructor for class org.apache.cassandra.io.util.FileReader
- files - Variable in class org.apache.cassandra.service.snapshot.SnapshotManifest
- 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
- filesReceived - Variable in class org.apache.cassandra.streaming.StreamingState.Sessions
- filesSent - Variable in class org.apache.cassandra.streaming.StreamingState.Sessions
- fileStartPosition - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SyncSegment
-
offset in file where this section begins.
- filesToReceive - Variable in class org.apache.cassandra.streaming.StreamingState.Sessions
- FileStoreUtils - Class in org.apache.cassandra.io.util
- filesToSend - Variable in class org.apache.cassandra.streaming.StreamingState.Sessions
- FileSystemOwnershipCheck - Class in org.apache.cassandra.service
-
Ownership markers on disk are compatible with the java property file format.
- FileUtils - Class in org.apache.cassandra.io.util
- FileWriter - Class in org.apache.cassandra.io.util
- FileWriter(File) - Constructor for class org.apache.cassandra.io.util.FileWriter
- FileWriter(File, File.WriteMode) - Constructor for class org.apache.cassandra.io.util.FileWriter
- fillSslContextParams(Map<String, Object>) - Method in class org.apache.cassandra.config.EncryptionOptions
- fillSslContextParams(Map<String, Object>) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
- filter - Variable in class org.apache.cassandra.db.AbstractReadCommandBuilder
- filter(Predicate<? super Replica>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
- filter(Predicate<? super Replica>) - Method in interface org.apache.cassandra.locator.ReplicaCollection
- filter(Predicate<? super Replica>, int) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
- filter(Predicate<? super Replica>, int) - Method in interface org.apache.cassandra.locator.ReplicaCollection
- filter(Predicate<UserFunction>) - Method in class org.apache.cassandra.schema.UserFunctions
- 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<KeyspaceMetadata>) - Method in class org.apache.cassandra.schema.Keyspaces
- filter(Predicate<TableMetadata>) - Method in class org.apache.cassandra.schema.Tables
- filter(ColumnFilter, DeletionTime, boolean, TableMetadata) - Method in class org.apache.cassandra.db.rows.BTreeRow
- 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(ColumnFilter, DeletionTime, DroppedColumn, LivenessInfo) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
- filter(ColumnFilter, TableMetadata) - Method in class org.apache.cassandra.db.rows.BTreeRow
- 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(PartitionIterator, long, boolean, boolean) - Method in class org.apache.cassandra.db.filter.DataLimits
- filter(PartitionIterator, TableMetadata, long) - 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, long) - 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, long) - Static method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators
- filter(UnfilteredPartitionIterator, long) - 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, long, boolean) - Method in class org.apache.cassandra.db.filter.DataLimits
- filter(UnfilteredPartitionIterator, Filter) - Static method in class org.apache.cassandra.db.transform.FilteredPartitions
- filter(UnfilteredRowIterator, long) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
-
Returns a iterator that only returns rows with only live content.
- filter(UnfilteredRowIterator, long) - Static method in class org.apache.cassandra.db.transform.FilteredRows
-
Filter any RangeTombstoneMarker from the iterator, transforming it into a RowIterator.
- filter(UnfilteredRowIterator, long, boolean) - Method in class org.apache.cassandra.db.filter.DataLimits
- filter(TableMetadata, long) - Method in class org.apache.cassandra.db.filter.RowFilter
-
Note that the application of this transformation does not yet take
RowFilter.isStrict()
into account. - filter(P) - Method in class org.apache.cassandra.index.sai.plan.VectorTopKProcessor
-
Filter given partitions and keep the rows with the highest scores.
- Filter - Class in org.apache.cassandra.db.transform
- Filter(long, boolean) - Constructor for class org.apache.cassandra.db.transform.Filter
- FILTER - Static variable in class org.apache.cassandra.io.sstable.format.SSTableFormat.Components
- FILTER - Static variable in class org.apache.cassandra.io.sstable.format.SSTableFormat.Components.Types
- 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
- filterCommonRanges(String, String[]) - Method in class org.apache.cassandra.repair.RepairCoordinator.NeighborsAndRanges
-
When in the force mode, removes dead nodes from common ranges (not contained within `allNeighbors`), and exludes ranges left without any participants When not in the force mode, no-op.
- FilterComponent - Class in org.apache.cassandra.io.sstable.format
- 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
- filterFirst() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
-
Whether to filter out data before
SSTableReader.first
. - filterForQuery(E, Keyspace, Index.QueryPlan, ConsistencyLevel) - Method in class org.apache.cassandra.index.IndexStatusManager
-
Remove endpoints whose indexes are not queryable for the specified
Index.QueryPlan
. - 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.
- filterHashLowerBits() - Method in interface org.apache.cassandra.utils.IFilter.FilterKey
- FilteringInMemoryKeyRangeIterator - Class in org.apache.cassandra.index.sai.memory
-
An
InMemoryKeyRangeIterator
that filters the returnedPrimaryKey
s based on the provided keyRange - FilteringInMemoryKeyRangeIterator(SortedSet<PrimaryKey>, AbstractBounds<PartitionPosition>) - Constructor for class org.apache.cassandra.index.sai.memory.FilteringInMemoryKeyRangeIterator
- FilteringPostingList - Class in org.apache.cassandra.index.sai.disk.v1.postings
-
A wrapper that iterates over a delegate
PostingList
, filtering out postings at positions that are not present in a provided filter. - FilteringPostingList(FixedBitSet, OrdinalPostingList) - Constructor for class org.apache.cassandra.index.sai.disk.v1.postings.FilteringPostingList
- filterLast() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
-
Whether to filter out data after
SSTableReader.last
. - filterLazily(Predicate<? super Replica>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
- filterLazily(Predicate<? super Replica>) - Method in interface org.apache.cassandra.locator.ReplicaCollection
- filterLazily(Predicate<? super Replica>, int) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
- filterLazily(Predicate<? super 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
- FilterPipeline - Class in org.apache.cassandra.index.sai.analyzer.filter
-
A linked list of
FilterPipeline.Task
objects. - FilterPipeline(FilterPipeline.Task) - Constructor for class org.apache.cassandra.index.sai.analyzer.filter.FilterPipeline
- FilterPipeline.Task - Class in org.apache.cassandra.index.sai.analyzer.filter
- 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.sai.analyzer.filter
-
Executes all linked
FilterPipeline.Task
s serially on the provided input and returns a result - 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.sai.analyzer.filter.FilterPipelineExecutor
- 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
- filterReplicaFilteringProtection(PartitionIterator) - Method in interface org.apache.cassandra.index.Index.Searcher
-
Replica filtering protection may fetch data that doesn't match query conditions.
- filterReplicaFilteringProtection(PartitionIterator) - Method in class org.apache.cassandra.index.sai.plan.StorageAttachedIndexSearcher
- filtersMultipleContains() - Method in interface org.apache.cassandra.index.Index
-
Returns whether this index does any kind of filtering when the query has multiple contains expressions, assuming that each of those expressions are supported as defined by
Index.supportsExpression(ColumnMetadata, Operator)
. - filtersMultipleContains() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- filterSuspectSSTables(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Filters SSTables that are to be excluded from the given collection
- FilterTree - Class in org.apache.cassandra.index.sai.plan
-
Tree-like structure to filter base table data using indexed expressions and non-user-defined filters.
- FINAL - org.apache.cassandra.db.Directories.FileType
-
A permanent sstable file that is safe to use.
- 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.
- FINALIZE_COMMIT_MSG - org.apache.cassandra.net.Verb
- FINALIZE_PROMISE_MSG - org.apache.cassandra.net.Verb
- FINALIZE_PROMISED - org.apache.cassandra.repair.consistent.ConsistentSession.State
- FINALIZE_PROPOSE_MSG - org.apache.cassandra.net.Verb
- finalizeCommit() - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
- FinalizeCommit - Class in org.apache.cassandra.repair.messages
- FinalizeCommit(TimeUUID) - Constructor for class org.apache.cassandra.repair.messages.FinalizeCommit
- finalized - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStats
- FINALIZED - org.apache.cassandra.repair.consistent.ConsistentSession.State
- 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, TimeUUID, boolean, SerializationHeader, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- FinalizePromise - Class in org.apache.cassandra.repair.messages
- FinalizePromise(TimeUUID, 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(TimeUUID) - Constructor for class org.apache.cassandra.repair.messages.FinalizePropose
- finalState - Variable in exception org.apache.cassandra.streaming.StreamException
- find(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
- find(String) - Method in class org.apache.cassandra.db.Directories
- find(FunctionName, List<AbstractType<?>>) - Method in class org.apache.cassandra.schema.UserFunctions
- find(FunctionName, List<AbstractType<?>>, UserFunctions.Filter) - Method in class org.apache.cassandra.schema.UserFunctions
-
Find the function with the specified name
- 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.io.sstable.format.big.IndexState
- findByIndex(Object[], int) - Static method in class org.apache.cassandra.utils.btree.BTree
- findCorrectRange(Token) - Method in class org.apache.cassandra.repair.Validator
- findExistingAncestor(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- 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
- findOldestHintTimestamp(UUID) - Method in class org.apache.cassandra.hints.HintsService
-
Find the oldest hint written for a particular node by looking into descriptors and current open writer, if any.
- 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, TimeUUID, int, boolean) - Method in class org.apache.cassandra.streaming.StreamManager
- findSupportingIndex(IndexRegistry) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
- findSupportingIndex(IndexRegistry) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
Find first supporting index for current restriction
- findSupportingIndex(IndexRegistry) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
- findSupportingIndex(IndexRegistry) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
- findSupportingIndexFromQueryPlan(Index.QueryPlan) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
- findSupportingIndexFromQueryPlan(Index.QueryPlan) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
Find the first supporting index for the current restriction from an
Index.QueryPlan
. - findSupportingIndexFromQueryPlan(Index.QueryPlan) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
- findSupportingIndexFromQueryPlan(Index.QueryPlan) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
- findUserFunction(FunctionName, List<AbstractType<?>>) - Method in class org.apache.cassandra.schema.Schema
-
Find the function with the specified name and arguments.
- 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.sai.disk.v1.bitpack.AbstractBlockPackedWriter
-
Flush all buffered data to disk.
- finish() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
- 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() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormatPartitionWriter
- finish() - Method in class org.apache.cassandra.io.sstable.format.SortedTablePartitionWriter
- 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() - 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.service.paxos.uncommitted.UncommittedTableData.FlushWriter
- 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
- finish(boolean) - Method in class org.apache.cassandra.db.compaction.unified.ShardedMultiWriter
- finish(boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
- finish(boolean) - Method in class org.apache.cassandra.io.sstable.RangeAwareSSTableWriter
- finish(boolean) - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
- finish(boolean) - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
- finish(boolean) - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
- finish(boolean) - Method in class org.apache.cassandra.io.sstable.SSTableZeroCopyWriter
- finish(IndexOutputWriter, List<PackedLongValues>, IndexIdentifier) - Method in class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreePostingsWriter
-
Writes merged posting lists for eligible internal nodes and leaf postings for each leaf in the tree.
- 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(File) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
-
Finishes up index building process by creating/populating index file.
- finish(SharedContext, Collection<InetAddressAndPort>, PaxosCleanupHistory) - Static method in class org.apache.cassandra.service.paxos.cleanup.PaxosFinishPrepareCleanup
- finish(Pair<ByteBuffer, ByteBuffer>, File, TermIterator) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
- FINISH_ON_CLOSE - Static variable in class org.apache.cassandra.io.util.SequentialWriterOption
- 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 - Variable in class org.apache.cassandra.index.sai.disk.v1.bitpack.AbstractBlockPackedWriter
- finished() - Method in class org.apache.cassandra.db.compaction.unified.ShardedMultiWriter
- finished() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReceiver
- 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.RangeAwareSSTableWriter
- 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.io.sstable.SSTableZeroCopyWriter
- 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.
- finisher() - Method in class org.apache.cassandra.utils.concurrent.Threads.StackTraceCombiner
- 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() - Method in class org.apache.cassandra.io.util.SequentialWriterOption
- finishOnClose(boolean) - Method in class org.apache.cassandra.io.util.SequentialWriterOption.Builder
- 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
-
Stop sampling and return the results
- finishSession(InetAddressAndPort, PaxosCleanupResponse) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosRepairState
- 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(String, ProgressEvent) - Method in class org.apache.cassandra.utils.progress.ProgressEventNotifierSupport
- fireProgressEvent(ProgressEvent) - Method in class org.apache.cassandra.repair.RepairCoordinator
- first - Variable in class org.apache.cassandra.io.sstable.format.big.IndexSummaryComponent
- first - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
- first - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
- first - Variable in class org.apache.cassandra.metrics.SamplingManager.ResultBuilder
- first() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
- 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
- firstClustering - Variable in class org.apache.cassandra.io.sstable.format.SortedTablePartitionWriter
- firstIteration - Variable in class org.apache.cassandra.index.sasi.disk.TokenTree.TokenTreeIterator
- firstKey - Variable in class org.apache.cassandra.db.streaming.CassandraStreamHeader
- firstKey - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
- firstKey() - Method in class org.apache.cassandra.index.sasi.utils.trie.PatriciaTrie
- firstKey() - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex
- firstKeyBeyond(PartitionPosition) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
Finds and returns the first key beyond a given token in this SSTable or null if no such key exists.
- firstKeyBeyond(PartitionPosition) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- 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.
- firstKeyComparator - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
- firstKeyOrdering - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
- 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.
- firstPrimaryKeyInRange() - Method in class org.apache.cassandra.index.sai.plan.QueryController
- 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.AbstractForRead
- firstUncontactedCandidate(Predicate<Replica>) - Method in interface org.apache.cassandra.locator.ReplicaPlan.ForRead
- fiveMinuteHitRate - Variable in class org.apache.cassandra.metrics.CacheMetrics
-
5m hit rate
- fixed(CQL3Type...) - Static method in interface org.apache.cassandra.cql3.functions.FunctionParameter
- FIXED - org.apache.cassandra.service.reads.SpeculativeRetryPolicy.Kind
- fixedLength(byte[]) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteComparable
- fixedLength(byte[]) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
A byte source of the given bytes without any encoding.
- fixedLength(byte[], int, int) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteComparable
- fixedLength(byte[], int, int) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- fixedLength(ByteBuffer) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteComparable
- fixedLength(ByteBuffer) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
A byte source of the given bytes without any encoding.
- fixedLength(ValueAccessor<V>, V) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
A byte source of the given bytes without any encoding.
- fixedSizeOf() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Returns the value length for the given
AbstractType
, selecting 16 for types that officially use VARIABLE_LENGTH but are, in fact, of a fixed length. - FixedSpeculativeRetryPolicy - Class in org.apache.cassandra.service.reads
- fixedTimestampMicros() - Method in interface org.apache.cassandra.schema.SchemaTransformation
-
If the transformation should be applied with a certain timestamp, this method should be overriden.
- FixedValueComparator(int) - Constructor for class org.apache.cassandra.db.marshal.DynamicCompositeType.FixedValueComparator
- flag() - Method in class org.apache.cassandra.service.paxos.Ballot
- flags - Variable in class org.apache.cassandra.schema.TableMetadata
- flags - Variable in class org.apache.cassandra.transport.Envelope.Header
- flags(Set<TableMetadata.Flag>) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- flatMap(Function<? super V, ? extends Future<T>>) - Method in interface org.apache.cassandra.utils.concurrent.Future
-
Support
Futures.transformAsync(ListenableFuture, AsyncFunction, Executor)
natively - flatMap(Function<? super V, ? extends Future<T>>, Executor) - Method in class org.apache.cassandra.utils.concurrent.AsyncFuture
-
Support
Futures.transformAsync(ListenableFuture, AsyncFunction, Executor)
natively SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics. - flatMap(Function<? super V, ? extends Future<T>>, Executor) - Method in interface org.apache.cassandra.utils.concurrent.Future
-
Support
Futures.transformAsync(ListenableFuture, AsyncFunction, Executor)
natively - flatMap(Function<? super V, ? extends Future<T>>, Executor) - Method in class org.apache.cassandra.utils.concurrent.SyncFuture
-
Support
Futures.transformAsync(ListenableFuture, AsyncFunction, Executor)
natively SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics. - flatMap(AbstractFuture<T>, Function<? super V, ? extends Future<T>>, Executor) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
-
Support
Futures.transformAsync(ListenableFuture, AsyncFunction, Executor)
natively SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics. - flatten(Class<?>) - Method in interface org.apache.cassandra.config.Loader
- flatten(Class<?>, String) - Method in interface org.apache.cassandra.config.Loader
- flatten(Loader, Map<String, Property>) - Static method in class org.apache.cassandra.config.Properties
-
Given a map of Properties, takes any "nested" property (non primitive, value-type, or collection), and expands them, producing 1 or more Properties.
- flatten(Loader, Map<String, Property>, String) - Static method in class org.apache.cassandra.config.Properties
-
Given a map of Properties, takes any "nested" property (non primitive, value-type, or collection), and expands them, producing 1 or more Properties.
- flattenEntries() - Method in class org.apache.cassandra.locator.ReplicaMultimap
- flattenValues() - Method in class org.apache.cassandra.locator.ReplicaMultimap
- FLOAT - org.apache.cassandra.cql3.Constants.Type
- FLOAT - org.apache.cassandra.cql3.CQL3Type.Native
- FLOAT - org.apache.cassandra.cql3.functions.types.DataType.Name
- FLOAT - org.apache.cassandra.transport.DataType
- FLOAT_SIZE - Static variable in class org.apache.cassandra.db.TypeSizes
- floatBuffer() - Method in class org.apache.cassandra.io.util.MmappedRegions.Region
- floatBuffer() - Method in interface org.apache.cassandra.io.util.Rebufferer.BufferHolder
- 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(PartitionPosition, PartitionIndex.Acceptor<PartitionPosition, ResultType>) - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex.Reader
- floor(Token) - Method in interface org.apache.cassandra.index.sai.disk.PrimaryKeyMap
- floor(Token) - Method in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap
- floor(Token) - Method in class org.apache.cassandra.index.sai.disk.v1.WidePrimaryKeyMap
- 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
- FLOOR - org.apache.cassandra.utils.AsymmetricOrdering.Op
- floorIndex(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTree
- floorTime - Static variable in class org.apache.cassandra.cql3.functions.TimeFcts
-
Function that rounds a time down to the closest multiple of a duration.
- floorTime(long, Duration) - Static method in class org.apache.cassandra.cql3.Duration
-
Rounds a time down to the closest multiple of a duration.
- floorTimestamp(long, Duration, long) - Static method in class org.apache.cassandra.cql3.Duration
-
Rounds a timestamp down to the closest multiple of a duration.
- 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() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosBallotTracker
- flush() - Method in interface org.apache.cassandra.streaming.StreamingDataOutputPlus
- flush(int, int) - Method in class org.apache.cassandra.db.commitlog.DirectIOSegment
- 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(ColumnFamilyStore.FlushReason) - Method in class org.apache.cassandra.db.Keyspace
- flush(IndexDescriptor) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder
- Flush - Class in org.apache.cassandra.tools.nodetool
- Flush() - Constructor for class org.apache.cassandra.tools.nodetool.Flush
- FLUSH - org.apache.cassandra.db.compaction.OperationType
- 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(Memtable) - 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.
- flushBf() - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter.AbstractIndexWriter
- flushBlock() - Method in class org.apache.cassandra.index.sai.disk.v1.bitpack.AbstractBlockPackedWriter
- flushBlock() - Method in class org.apache.cassandra.index.sai.disk.v1.bitpack.BlockPackedWriter
- flushBlock() - Method in class org.apache.cassandra.index.sai.disk.v1.bitpack.MonotonicBlockPackedWriter
- flushBuffer() - Method in class org.apache.cassandra.utils.logging.VirtualTableAppender
-
Flushes all logs which were appended before virtual table was registered.
- flushBuffer(ByteBuffer, DataOutputPlus, boolean) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
- flushCompression - Variable in class org.apache.cassandra.io.sstable.IOOptions
- 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
- Flushing - Class in org.apache.cassandra.db.memtable
- Flushing.FlushRunnable - Class in org.apache.cassandra.db.memtable
- flushingMemtables - Variable in class org.apache.cassandra.db.lifecycle.View
-
contains all memtables that are no longer referenced for writing and are queued for / in the process of being flushed.
- flushInProgress - Static variable in class org.apache.cassandra.cache.AutoSavingCache
-
True if a cache flush is currently executing: only one may execute at a time.
- flushInternal(IndexDescriptor) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder
- flushInternal(IndexDescriptor) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder.TrieSegmentBuilder
- flushInternal(IndexDescriptor) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder.VectorSegmentBuilder
- flushIterator(Memtable) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- flushIterator(Memtable) - Method in interface org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker.UpdateSupplier
- flushLargestMemtable() - Static method in class org.apache.cassandra.db.memtable.AbstractAllocatorMemtable
-
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
- flushPaxosRepairHistory() - Static method in class org.apache.cassandra.db.SystemKeyspace
- FlushRunnable(Memtable.FlushablePartitionSet<?>, SSTableMultiWriter, TableMetrics, boolean) - Constructor for class org.apache.cassandra.db.memtable.Flushing.FlushRunnable
- flushRunnables(ColumnFamilyStore, Memtable, LifecycleTransaction) - Static method in class org.apache.cassandra.db.memtable.Flushing
- flushSizeOnDisk - Variable in class org.apache.cassandra.metrics.TableMetrics
-
The average on-disk flushed size for sstables.
- flushSizeOverride - Variable in class org.apache.cassandra.db.compaction.unified.Controller
- fmix(long) - Static method in class org.apache.cassandra.utils.MurmurHash
- folderSize(File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Get the size of a directory in bytes
- follow(ByteComparable) - Method in class org.apache.cassandra.io.tries.Walker
-
Follows the given key while there are transitions in the trie for it.
- followContentTransition(int) - Method in class org.apache.cassandra.db.tries.InMemoryReadTrie
- follower() - Method in class org.apache.cassandra.streaming.StreamingState
- followWithGreater(ByteComparable) - Method in class org.apache.cassandra.io.tries.Walker
-
Follows the trie for a given key, remembering the closest greater branch.
- followWithLesser(ByteComparable) - Method in class org.apache.cassandra.io.tries.Walker
-
Follows the trie for a given key, remembering the closest lesser branch.
- FOOTER_LENGTH - Static variable in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex
- FOOTER_POINTER - Static variable in class org.apache.cassandra.index.sai.disk.v1.SAICodecUtils
- forAggregate(Event.SchemaChange.Change, UDAggregate) - Static method in class org.apache.cassandra.transport.Event.SchemaChange
- forBatchlogWrite(boolean) - Static method in class org.apache.cassandra.locator.ReplicaPlans
-
Requires that the provided endpoints are alive.
- FORBIDDEN - org.apache.cassandra.db.commitlog.CommitLogSegment.CDCState
- force(FileChannel, boolean) - Static method in class org.apache.cassandra.utils.SyncUtil
- force(MappedByteBuffer) - Static method in class org.apache.cassandra.utils.SyncUtil
- FORCE_DEFAULT_INDEXING_PAGE_SIZE - org.apache.cassandra.config.CassandraRelevantProperties
- FORCE_LOAD_LOCAL_KEYSPACES - org.apache.cassandra.config.CassandraRelevantProperties
-
Used when running in Client mode and the system and schema keyspaces need to be initialized outside of their normal initialization path
- force_new_prepared_statement_behaviour - Variable in class org.apache.cassandra.config.Config
- FORCE_PAXOS_STATE_REBUILD - org.apache.cassandra.config.CassandraRelevantProperties
- 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(String...) - Static method in class org.apache.cassandra.db.SystemKeyspace
- forceBlockingFlush(String, ColumnFamilyStore.FlushReason) - Static method in class org.apache.cassandra.schema.SystemDistributedKeyspace
- forceBlockingFlush(ColumnFamilyStore.FlushReason) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- forceBlockingFlush(ColumnFamilyStore.FlushReason) - Method in class org.apache.cassandra.db.view.TableViews
- forceCheckCertFiles() - Static method in class org.apache.cassandra.security.SSLFactory
-
Forces revalidation and loading of SSL certifcates if valid
- forceCleanup(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- ForceCompact - Class in org.apache.cassandra.tools.nodetool
- ForceCompact() - Constructor for class org.apache.cassandra.tools.nodetool.ForceCompact
- forceCompaction(ColumnFamilyStore, Supplier<Collection<SSTableReader>>, Predicate<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.CompactionManager
- forceCompactionForKey(ColumnFamilyStore, DecoratedKey) - Method in class org.apache.cassandra.db.compaction.CompactionManager
- forceCompactionForKey(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- forceCompactionForKeys(ColumnFamilyStore, Collection<DecoratedKey>) - Method in class org.apache.cassandra.db.compaction.CompactionManager
- forceCompactionForTokenRange(Collection<Range<Token>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- forceCompactionForTokenRange(Collection<Range<Token>>) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.See CASSANDRA-17527
- forceCompactionForTokenRange(ColumnFamilyStore, Collection<Range<Token>>) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Forces a major compaction of specified token ranges of the specified column family.
- forceCompactionForTokenRanges(String...) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- forceCompactionForTokenRanges(String...) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Forces a major compaction of specified token ranges in this column family.
- forceCompactionKeysIgnoringGcGrace(String...) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- forceCompactionKeysIgnoringGcGrace(String, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
Forces compaction for a list of partition keys in a table The method will ignore the gc_grace_seconds for the partitionKeysIgnoreGcGrace during the comapction, in order to purge the tombstones and free up space quicker.
- forceCompactionKeysIgnoringGcGrace(String, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Forces compaction for a list of partition keys on a table.
- forceCompactionKeysIgnoringGcGrace(String, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
- 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(ColumnFamilyStore.FlushReason) - 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).
- forceHighestPossibleVersionUnsafe() - Method in class org.apache.cassandra.gms.HeartBeatState
- forceKeyspaceCleanup(int, String, String...) - Method in class org.apache.cassandra.service.StorageService
- 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
- forceKeyspaceCleanup(String, String...) - Method in class org.apache.cassandra.service.StorageService
- forceKeyspaceCleanup(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-11179
- 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
- forceKeyspaceCompactionForPartitionKey(String, String, String...) - Method in class org.apache.cassandra.service.StorageService
- forceKeyspaceCompactionForPartitionKey(String, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Forces major compactions for the range represented by the partition key
- forceKeyspaceCompactionForPartitionKey(String, 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
-
Forces major compaction of specified token range in a single keyspace.
- 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
- forceKeyspaceFlush(String, ColumnFamilyStore.FlushReason) - Method in class org.apache.cassandra.service.StorageService
-
Flush all memtables for a keyspace and column families.
- 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() - 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(Collection<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
- 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(ByteBuffer, Consumer<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.CollectionType
- forEach(ByteBuffer, Consumer<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.ListType
- forEach(ByteBuffer, Consumer<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.MapType
- forEach(ByteBuffer, Consumer<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.SetType
- forEach(ByteBuffer, Consumer<ByteBuffer>) - Method in class org.apache.cassandra.serializers.CollectionSerializer
- forEach(ByteBuffer, Consumer<ByteBuffer>) - Method in class org.apache.cassandra.serializers.MapSerializer
- forEach(Path, Consumer<Path>) - Static method in class org.apache.cassandra.io.util.PathUtils
- forEach(BiConsumer<Long, InetAddressAndPort>) - Method in class org.apache.cassandra.net.ForwardingInfo
-
Apply the provided consumer to all (host, message_id) pairs.
- forEach(Consumer<? super Replica>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
- forEach(Consumer<? super Replica>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
- forEach(Consumer<? super T>) - Method in class org.apache.cassandra.utils.concurrent.IntrusiveStack
- forEach(Consumer<File>) - Method in class org.apache.cassandra.io.util.File
- forEach(Function<? super Replica, T>, Consumer<? super T>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
- forEach(HistogramDataConsumer<E>) - Method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram
- forEach(T, Consumer<? super T>) - Static method in class org.apache.cassandra.utils.concurrent.IntrusiveStack
- forEachEntry(BiConsumer<ByteComparable, T>) - Method in class org.apache.cassandra.db.tries.Trie
-
Call the given consumer on all (path, content) pairs with non-null content in the trie in order.
- forEachRecursive(Path, Consumer<Path>) - Static method in class org.apache.cassandra.io.util.PathUtils
- forEachRecursive(Consumer<File>) - Method in class org.apache.cassandra.io.util.File
- forEachValue(Trie.ValueConsumer<T>) - Method in class org.apache.cassandra.db.tries.Trie
-
Call the given consumer on all content values in the trie in order.
- forEachWriter(Consumer<SSTableWriter>) - Method in class org.apache.cassandra.io.sstable.SSTableRewriter
- 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)
- forFullRangeRead(Keyspace, ConsistencyLevel, AbstractBounds<PartitionPosition>, Set<InetAddressAndPort>, int) - Static method in class org.apache.cassandra.locator.ReplicaPlans
-
Construct a plan for reading the provided range at the provided consistency level on given endpoints.
- ForFullRangeRead(Keyspace, AbstractReplicationStrategy, ConsistencyLevel, AbstractBounds<PartitionPosition>, EndpointsForRange, EndpointsForRange, int) - Constructor for class org.apache.cassandra.locator.ReplicaPlan.ForFullRangeRead
- 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
- forImmediateExecution() - Static method in class org.apache.cassandra.transport.Dispatcher.RequestTime
- forInternalCalls() - Static method in class org.apache.cassandra.service.ClientState
- forInternalCalls() - Static method in class org.apache.cassandra.service.QueryState
- forInternalCalls(String) - Static method in class org.apache.cassandra.service.ClientState
- forInternalCalls(List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryOptions
- forInternalCalls(ConsistencyLevel, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryOptions
- forInternalCallsWithNowInSec(long, ConsistencyLevel, List<ByteBuffer>) - Static method in class org.apache.cassandra.cql3.QueryOptions
- 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 - Variable in class org.apache.cassandra.config.Config.SSTableConfig
- format - Static variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
- format - Variable in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
- format - Variable in class org.apache.cassandra.io.sstable.format.Version
- format(C) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractCollectionCodec
- format(List<E>) - Method in class org.apache.cassandra.cql3.functions.types.VectorCodec
- format(Map<K, V>) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractMapCodec
- format(IndexComponent, IndexIdentifier) - Method in interface org.apache.cassandra.index.sai.disk.format.Version.FileNameFormatter
- 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.
- formatClass - Variable in class org.apache.cassandra.io.sstable.Component.Type
- 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)
). - formatResult(SamplingManager.ResultBuilder) - Static method in class org.apache.cassandra.metrics.SamplingManager
- formatResults(List<RoleResource>) - Method in class org.apache.cassandra.cql3.statements.ListRolesStatement
- formatResults(List<RoleResource>) - Method in class org.apache.cassandra.cql3.statements.ListUsersStatement
- formatSpecificGauges - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
- formatSpecificGauges - Variable in class org.apache.cassandra.metrics.TableMetrics
- 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(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) - 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(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(AbstractBounds<PartitionPosition>, ClusteringComparator, Clustering<?>, boolean) - Method in class org.apache.cassandra.db.DataRange
-
Returns a new
DataRange
for use when pagingthis
range. - 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(Keyspace, Index.QueryPlan, 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.
- ForRangeRead(Keyspace, AbstractReplicationStrategy, ConsistencyLevel, AbstractBounds<PartitionPosition>, EndpointsForRange, EndpointsForRange, int) - Constructor for class org.apache.cassandra.locator.ReplicaPlan.ForRangeRead
- ForRangeRead(AbstractReplicationStrategy, AbstractBounds<PartitionPosition>, EndpointsForRange) - Constructor for class org.apache.cassandra.locator.ReplicaLayout.ForRangeRead
- forRead(Keyspace, Token, Index.QueryPlan, 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<?, ?>) - 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, 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
- 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
- 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 tothis
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(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.db.view.ViewManager
- 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(Keyspace, AbstractReplicationStrategy, ConsistencyLevel, EndpointsForToken, EndpointsForToken) - Constructor for class org.apache.cassandra.locator.ReplicaPlan.ForTokenRead
- ForTokenRead(AbstractReplicationStrategy, EndpointsForToken) - Constructor for class org.apache.cassandra.locator.ReplicaLayout.ForTokenRead
- forTokenReadLiveSorted(AbstractReplicationStrategy, Token) - Static method in class org.apache.cassandra.locator.ReplicaLayout
- 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
- 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.
- forType(Sampler.SamplerType, String) - Method in class org.apache.cassandra.metrics.SamplingManager.ResultBuilder
- 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
- forVersion(boolean) - Static method in class org.apache.cassandra.utils.BloomFilterSerializer
- FORWARD_TO - org.apache.cassandra.net.ParamType
- 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
- ForwardingProperty - Class in org.apache.cassandra.config
-
This class delegates all calls of
Property
to aForwardingProperty.delegate()
, used for cases where a small number of methods want to be overriden from the delegate. - ForwardingProperty(String, Class<?>, Property) - Constructor for class org.apache.cassandra.config.ForwardingProperty
- ForwardingProperty(String, Property) - Constructor for class org.apache.cassandra.config.ForwardingProperty
- ForwardingSharedContext(SharedContext) - Constructor for class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- forwardMap - Variable in class org.apache.cassandra.utils.BiMultiValMap
- forwardMap - Variable in class org.apache.cassandra.utils.ConcurrentBiMap
- ForwardReader(FileDataInput, boolean) - Constructor for class org.apache.cassandra.io.sstable.AbstractSSTableIterator.ForwardReader
- 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, ReplicaLayout.ForTokenWrite, 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, AbstractReplicationStrategy, ConsistencyLevel, EndpointsForToken, EndpointsForToken, EndpointsForToken, EndpointsForToken) - Constructor for class org.apache.cassandra.locator.ReplicaPlan.ForWrite
- fractionInShard(Range<Token>) - Method in class org.apache.cassandra.db.compaction.ShardManagerDiskAware.BoundaryTrackerDiskAware
-
Returns the fraction of the given token range's coverage that falls within this shard.
- fractionInShard(Range<Token>) - Method in class org.apache.cassandra.db.compaction.ShardManagerNoDisks.BoundaryTracker
- fractionInShard(Range<Token>) - Method in interface org.apache.cassandra.db.compaction.ShardTracker
-
Returns the fraction of the given token range's coverage that falls within this shard.
- frameDecoder(String, BufferPoolAllocator) - Method in class org.apache.cassandra.transport.PipelineConfigurator
- FrameDecoder - Class in org.apache.cassandra.net
-
A Netty inbound handler that decodes incoming frames and passes them forward to
InboundMessageHandler
for processing. - 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(String) - Method in class org.apache.cassandra.transport.PipelineConfigurator
- FrameEncoder - Class in org.apache.cassandra.net
- FrameEncoder() - Constructor for class org.apache.cassandra.net.FrameEncoder
- 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
- freeDiskSpace() - Static method in class org.apache.cassandra.db.commitlog.CommitLog
- 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 - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithSliceSelection
- from - Variable in class org.apache.cassandra.net.Message.Header
- from - Variable 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() - Method in interface org.apache.cassandra.db.memtable.Memtable.FlushablePartitionSet
- from() - Method in class org.apache.cassandra.net.Message
-
Sender of the message.
- from() - Method in exception org.apache.cassandra.net.MessagingService.FailureResponseException
- from() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
- 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(String) - Static method in class org.apache.cassandra.tools.nodetool.stats.CompactionHistoryPrinter
- from(String) - Static method in class org.apache.cassandra.tools.nodetool.stats.DataPathsPrinter
- from(String) - Static method in class org.apache.cassandra.tools.nodetool.stats.TpStatsPrinter
- from(String, boolean) - Static method in class org.apache.cassandra.tools.nodetool.stats.TableStatsPrinter
- from(Collection<ColumnMetadata>) - Static method in class org.apache.cassandra.db.Columns
-
Returns a new
Columns
object holding the same columns than the provided set. - from(Interruptible.SimpleTask) - Static method in interface org.apache.cassandra.concurrent.Interruptible.Task
- from(CQL3Type) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
- from(UntypedResultSet) - Static method in class org.apache.cassandra.db.compaction.CompactionHistoryTabularData
- from(Cell<?>) - Static method in class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable.ColumnValue
-
Returns the column value corresponding to the specified cell.
- from(Row) - Static method in class org.apache.cassandra.db.Columns
-
Returns a new
Columns
object holing the same columns as the provided Row. - from(InetAddressAndPort) - Method in class org.apache.cassandra.net.Message.Builder
- from(TableMetadata, ClusteringPrefix<?>) - Static method in class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable.ColumnValues
-
Returns the set of column values corresponding to the specified clustering prefix.
- from(TableMetadata, DecoratedKey) - Static method in class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable.ColumnValues
-
Returns the set of column values corresponding to the specified partition key.
- from(TableSnapshot, TabularDataSupport) - Static method in class org.apache.cassandra.db.SnapshotDetailsTabularData
- from(BTree.Builder<ColumnMetadata>) - Static method in class org.apache.cassandra.db.Columns
- FROM_REMOTE - org.apache.cassandra.db.rows.DeserializationHelper.Flag
- FromArray() - Constructor for class org.apache.cassandra.utils.BulkIterator.FromArray
- FromBlobFunction(CQL3Type) - Constructor for class org.apache.cassandra.cql3.functions.BytesConversionFcts.FromBlobFunction
- fromBoolean(boolean) - Static method in enum org.apache.cassandra.config.Config.PaxosStatePurging
- 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
- fromByteComparable(ByteComparable, ByteComparable.Version, IPartitioner) - Static method in class org.apache.cassandra.db.BufferDecoratedKey
-
A factory method that translates the given byte-comparable representation to a
BufferDecoratedKey
instance. - fromBytes(long, long) - Static method in class org.apache.cassandra.service.paxos.Ballot
- fromBytes(long, long) - Static method in class org.apache.cassandra.utils.TimeUUID
- fromBytes(ByteBuffer) - Method in class org.apache.cassandra.io.sstable.SequenceBasedSSTableId.Builder
- fromBytes(ByteBuffer) - Method in interface org.apache.cassandra.io.sstable.SSTableId.Builder
-
Creates an identifier instance from its binary representation
- fromBytes(ByteBuffer) - Method in class org.apache.cassandra.io.sstable.SSTableIdFactory
-
Constructs the instance of
SSTableId
from the given bytes. - fromBytes(ByteBuffer) - Method in class org.apache.cassandra.io.sstable.UUIDBasedSSTableId.Builder
- 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
- fromComparableBytes(ValueAccessor<T>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.MapType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Translates the given byte-ordered representation to the common, non-byte-ordered binary representation of a payload for this abstract type (the latter, common binary representation is what we mostly work with in the storage engine internals).
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.BooleanType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.ByteType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.CompositeType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.DecimalType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.DoubleType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.EmptyType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.FloatType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.Int32Type
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.IntegerType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.ListType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.LongType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.ReversedType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.SetType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.ShortType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.SimpleDateType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.TimestampType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.TimeType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.TupleType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.UUIDType
- fromComparableBytes(ValueAccessor<V>, ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.VectorType
- fromComparableBytes(ByteSource) - Method in class org.apache.cassandra.index.sai.utils.PrimaryKey.Factory
-
Create a
PrimaryKey
from aByteSource
. - fromComparableBytes(ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.db.marshal.AbstractType
- fromComparableBytes(ByteSource.Peekable, ByteComparable.Version) - Method in class org.apache.cassandra.dht.Token.TokenFactory
-
Translates the given byte-comparable representation to a token instance.
- 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.audit.AuditLogOptionsCompositeData
- 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
- fromCQLLiteral(String) - Method in interface org.apache.cassandra.cql3.CQL3Type
-
Generates a binary value for the CQL literal of this type
- fromCQLLiteral(String, String) - Method in interface org.apache.cassandra.cql3.CQL3Type
-
Generates a binary value for the CQL literal of this type
- fromDatabaseDescriptor() - Static method in class org.apache.cassandra.io.sstable.IOOptions
- fromDaysSinceEpoch(int) - Static method in class org.apache.cassandra.cql3.functions.types.LocalDate
-
Builds a new instance from a number of days since January 1st, 1970 GMT.
- 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
- fromFile(File) - Static method in class org.apache.cassandra.io.sstable.Descriptor
-
Parse a sstable filename into a Descriptor.
- fromFileName(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
- fromFileName(String) - Static method in enum org.apache.cassandra.db.compaction.OperationType
- fromFileWithComponent(File) - Static method in class org.apache.cassandra.io.sstable.Descriptor
-
Parse a sstable filename, extracting both the
Descriptor
andComponent
part. - fromFileWithComponent(File, boolean) - Static method in class org.apache.cassandra.io.sstable.Descriptor
- fromFileWithComponent(File, String, String) - Static method in class org.apache.cassandra.io.sstable.Descriptor
-
Parse a sstable filename, extracting both the
Descriptor
andComponent
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(RowIterator, ColumnFilter) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
Turns the given iterator into an update.
- fromIterator(UnfilteredRowIterator, 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(byte[]) - Static method in class org.apache.cassandra.utils.JsonUtils
- fromJsonList(String) - Static method in class org.apache.cassandra.utils.JsonUtils
- fromJsonMap(byte[]) - Static method in class org.apache.cassandra.utils.JsonUtils
- fromJsonMap(String) - Static method in class org.apache.cassandra.utils.JsonUtils
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- 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.DynamicCompositeType.FixedValueComparator
- 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.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
- fromJSONObject(Object) - Method in class org.apache.cassandra.db.marshal.VectorType
- fromKeyExcl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder.PartitionRangeBuilder
- fromKeyIncl(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder.PartitionRangeBuilder
- fromLong(long) - Static method in class org.apache.cassandra.utils.CassandraUInt
-
Converts a long to it's unsigned integer representation
- fromLong(long[]) - Static method in class org.apache.cassandra.utils.CassandraUInt
-
The same but works on an array on longs
- fromMap(Map<String, Object>, boolean, Class<T>) - Static method in class org.apache.cassandra.config.YamlConfigurationLoader
- fromMap(Map<String, Object>, Class<T>) - Static method in class org.apache.cassandra.config.YamlConfigurationLoader
- fromMap(Map<String, String>) - Static method in class org.apache.cassandra.index.sai.analyzer.NonTokenizingOptions
- 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) - Static method in class org.apache.cassandra.cql3.functions.types.LocalDate
-
Builds a new instance from a number of milliseconds since January 1st, 1970 GMT.
- fromMillisSinceEpoch(long) - Method in class org.apache.cassandra.utils.MonotonicClock.AbstractEpochSamplingClock.AlmostSameTime
- 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
- fromOptions(String, IndexTermType, Map<String, String>) - Static method in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- fromOptions(ColumnFamilyStore, Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.unified.Controller
- fromOptions(IndexTermType, Map<String, String>) - Static method in class org.apache.cassandra.index.sai.analyzer.AbstractAnalyzer
- fromOrdinal(int) - Static method in enum org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL.Kind
- 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
- fromRepresentation(String, SSTableFormat<?, ?>) - Static method in class org.apache.cassandra.io.sstable.Component.Type
- 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<T>) - Static method in class org.apache.cassandra.cql3.Lists.Value
- fromSerialized(ByteBuffer, ListType<T>) - Static method in class org.apache.cassandra.cql3.Tuples.InValue
- fromSerialized(ByteBuffer, MapType<K, V>) - Static method in class org.apache.cassandra.cql3.Maps.Value
- fromSerialized(ByteBuffer, SetType<T>) - Static method in class org.apache.cassandra.cql3.Sets.Value
- 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.commitlog.CommitLogPosition.CommitLogPositionSerializer
- fromString(String) - Static method in enum org.apache.cassandra.db.ConsistencyLevel
- fromString(String) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
- fromString(String) - Method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- 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.DynamicCompositeType.FixedValueComparator
- 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.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.db.marshal.VectorType
- fromString(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
- fromString(String) - Static method in enum org.apache.cassandra.index.sai.disk.v1.vector.OptimizeFor
- fromString(String) - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
The inverse of the above method.
- fromString(String) - Method in class org.apache.cassandra.io.sstable.SequenceBasedSSTableId.Builder
- fromString(String) - Method in interface org.apache.cassandra.io.sstable.SSTableId.Builder
-
Creates an identifier instance from its string representation
- fromString(String) - Method in class org.apache.cassandra.io.sstable.SSTableIdFactory
-
Constructs the instance of
SSTableId
from the given string representation. - fromString(String) - Method in class org.apache.cassandra.io.sstable.UUIDBasedSSTableId.Builder
- 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 class org.apache.cassandra.service.paxos.Ballot
- 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
- fromString(String) - Static method in class org.apache.cassandra.utils.TimeUUID
- fromStringSet(Set<String>) - Static method in enum org.apache.cassandra.schema.TableMetadata.Flag
- fromSymbol(String) - Static method in enum org.apache.cassandra.config.DataRateSpec.DataRateUnit
- fromSymbol(String) - Static method in enum org.apache.cassandra.config.DataStorageSpec.DataStorageUnit
- fromTimeInMillis(long) - Method in class org.apache.cassandra.cql3.functions.TimeFcts.FloorDateFunction
- fromTimeInMillis(long) - Method in class org.apache.cassandra.cql3.functions.TimeFcts.FloorTimestampFunction
- fromTimeInMillis(long) - Method in class org.apache.cassandra.cql3.functions.TimeFcts.FloorTimeUuidFunction
- 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
- fromTupleBufferList(List<ByteBuffer>) - Static method in class org.apache.cassandra.service.paxos.PaxosRepairHistory
- fromType(AbstractType, ProtocolVersion) - Static method in enum org.apache.cassandra.transport.DataType
- fromUuid(UUID) - Static method in class org.apache.cassandra.service.paxos.Ballot
- fromUuid(UUID) - Static method in class org.apache.cassandra.utils.TimeUUID
- 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
- fsBlockSize - Variable in class org.apache.cassandra.db.commitlog.DirectIOSegment.DirectIOSegmentBuilder
- 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(String, Throwable, Path) - Constructor for error org.apache.cassandra.io.FSError
- FSError(String, Throwable, File) - Constructor for error org.apache.cassandra.io.FSError
- FSError(Throwable, Path) - Constructor for error org.apache.cassandra.io.FSError
- 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(String, Throwable) - Constructor for error org.apache.cassandra.io.FSReadError
- FSReadError(String, Throwable, String) - Constructor for error org.apache.cassandra.io.FSReadError
- FSReadError(String, Throwable, Path) - Constructor for error org.apache.cassandra.io.FSReadError
- FSReadError(String, Throwable, File) - Constructor for error org.apache.cassandra.io.FSReadError
- FSReadError(Throwable, String) - Constructor for error org.apache.cassandra.io.FSReadError
- FSReadError(Throwable, Path) - Constructor for error org.apache.cassandra.io.FSReadError
- FSReadError(Throwable, File) - Constructor for error org.apache.cassandra.io.FSReadError
- FSWriteError - Error in org.apache.cassandra.io
- FSWriteError(String, Throwable) - Constructor for error org.apache.cassandra.io.FSWriteError
- FSWriteError(String, Throwable, String) - Constructor for error org.apache.cassandra.io.FSWriteError
- FSWriteError(String, Throwable, Path) - Constructor for error org.apache.cassandra.io.FSWriteError
- FSWriteError(String, Throwable, File) - Constructor for error org.apache.cassandra.io.FSWriteError
- FSWriteError(Throwable) - Constructor for error org.apache.cassandra.io.FSWriteError
- FSWriteError(Throwable, String) - Constructor for error org.apache.cassandra.io.FSWriteError
- FSWriteError(Throwable, Path) - Constructor for error org.apache.cassandra.io.FSWriteError
- FSWriteError(Throwable, File) - 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 - org.apache.cassandra.cql3.statements.schema.IndexTarget.Type
- FULL - org.apache.cassandra.service.disk.usage.DiskUsageState
-
Disk usage exceeds
GuardrailsConfig.getDataDiskUsagePercentageFailThreshold()
. - FULL_FORM_THRESHOLD - Static variable in class org.apache.cassandra.db.marshal.IntegerType
- FULL_ON_FROZEN_COLLECTIONS - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- full_query_logging_options - Variable in class org.apache.cassandra.config.Config
- FULL_RANGE - Static variable in class org.apache.cassandra.locator.SystemReplicas
- FULL_REBUILD_STARTED - org.apache.cassandra.index.Index.Status
- 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, ByteBuffer, long, long) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
Creates a partition update that entirely deletes a given partition.
- fullPartitionDelete(TableMetadata, DecoratedKey, long, long) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
Creates an immutable partition update that entirely deletes a given partition.
- fullPartitionRead(TableMetadata, long, ByteBuffer) - Static method in class org.apache.cassandra.db.SinglePartitionReadCommand
-
Creates a new read command that queries a single partition in its entirety.
- fullPartitionRead(TableMetadata, long, DecoratedKey) - 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
- fullRange(SSTableReader) - Static method in class org.apache.cassandra.io.sstable.format.SSTableScanner
- 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 - Variable in class org.apache.cassandra.locator.ReplicationFactor
- fullReplicas() - Method in class org.apache.cassandra.locator.Replicas.ReplicaCount
- fullWeightedRange(long, IPartitioner) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
- fullyQualified - Variable in class org.apache.cassandra.cql3.QueryHandler.Prepared
- function - Variable in class org.apache.cassandra.cql3.functions.masking.ColumnMask
-
The CQL function used for masking.
- 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
forDESCRIBE FUNCTION
. - function(String, String, List<AbstractType<?>>) - Static method in class org.apache.cassandra.auth.FunctionResource
-
Creates a FunctionResource representing a specific, keyspace-scoped function.
- function(UserFunction) - Static method in class org.apache.cassandra.auth.FunctionResource
- Function - Interface in org.apache.cassandra.cql3.functions
- FUNCTION - org.apache.cassandra.cql3.SchemaElement.SchemaElementType
- FUNCTION - org.apache.cassandra.transport.Event.SchemaChange.Target
- FUNCTION_FAILURE - org.apache.cassandra.exceptions.ExceptionCode
- FunctionArguments - Class in org.apache.cassandra.cql3.functions
-
Default
Arguments
implementation. - FunctionArguments(ProtocolVersion, ArgumentDeserializer...) - Constructor for class org.apache.cassandra.cql3.functions.FunctionArguments
- 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
- FunctionFactory - Class in org.apache.cassandra.cql3.functions
-
Class for dynamically building different overloads of a CQL
Function
according to specific function calls. - FunctionFactory(String, FunctionParameter...) - Constructor for class org.apache.cassandra.cql3.functions.FunctionFactory
- 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 - Variable in exception org.apache.cassandra.exceptions.FunctionExecutionException
- FunctionName - Class in org.apache.cassandra.cql3.functions
- FunctionName(String, String) - Constructor for class org.apache.cassandra.cql3.functions.FunctionName
- FunctionParameter - Interface in org.apache.cassandra.cql3.functions
-
Generic, loose definition of a function parameter, able to infer the specific data type of the parameter in the function specifically built by a
FunctionFactory
for a particular function call. - FunctionResolver - Class in org.apache.cassandra.cql3.functions
- FunctionResource - Class in org.apache.cassandra.auth
-
IResource implementation representing functions.
- functions - Variable in class org.apache.cassandra.index.internal.CassandraIndex
- functions() - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
-
Creates a
DescribeStatement
forDESCRIBE FUNCTIONS
. - FUNCTIONS - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
- future() - Method in class org.apache.cassandra.streaming.StreamingState
- Future<V> - Interface in org.apache.cassandra.utils.concurrent
-
A Future that integrates several different (but equivalent) APIs used within Cassandra into a single concept, integrating also with our
Awaitable
abstraction, to overall improve coherency and clarity in the codebase. - FutureCombiner<T> - Class in org.apache.cassandra.utils.concurrent
-
Netty's PromiseCombiner is not threadsafe, and we combine futures from multiple event executors.
- FutureDelegate<V> - Class in org.apache.cassandra.net
-
A delegating future, that we can extend to provide subtly modified behaviour.
- FutureResult<V> - Class in org.apache.cassandra.net
-
An abstraction for yielding a result performed by an asynchronous task, for whom we may wish to offer cancellation, but no other access to the underlying task
- FutureResult(Future<V>, Future<?>) - Constructor for class org.apache.cassandra.net.FutureResult
- FutureTask<V> - Class in org.apache.cassandra.concurrent
-
A FutureTask that utilises Cassandra's
AsyncFuture
, making it compatible withExecutorPlus
. - FutureTask(Runnable) - Constructor for class org.apache.cassandra.concurrent.FutureTask
- FutureTask(Callable<? extends V>) - Constructor for class org.apache.cassandra.concurrent.FutureTask
- FutureTaskWithResources<V> - Class in org.apache.cassandra.concurrent
-
A FutureTask that utilises Cassandra's
AsyncFuture
, making it compatible withExecutorPlus
. - FutureTaskWithResources(WithResources, Runnable) - Constructor for class org.apache.cassandra.concurrent.FutureTaskWithResources
- FutureTaskWithResources(WithResources, Callable<V>) - Constructor for class org.apache.cassandra.concurrent.FutureTaskWithResources
- fwdFrmSerializer - Static variable in class org.apache.cassandra.locator.InetAddressAndPort.FwdFrmSerializer
G
- GARBAGE_COLLECT - org.apache.cassandra.db.compaction.OperationType
- garbageCollect(PrintStream, String, int, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
- 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(CompactionParams.TombstoneOption, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- GarbageCollect - Class in org.apache.cassandra.tools.nodetool
- GarbageCollect() - Constructor for class org.apache.cassandra.tools.nodetool.GarbageCollect
- GaugeProvider<T extends java.lang.Number> - Class in org.apache.cassandra.io.sstable
- GaugeProvider(String) - Constructor for class org.apache.cassandra.io.sstable.GaugeProvider
- GC_ALL - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
- gc_grace - org.apache.cassandra.config.Config.PaxosStatePurging
-
Functionally similar to legacy, but the gc_grace expiry is applied at compaction and read time rather than using TTLs, so may be safely enabled at any point.
- GC_GRACE_SECONDS - org.apache.cassandra.schema.TableParams.Option
- gc_log_threshold - Variable in class org.apache.cassandra.config.Config
- gc_warn_threshold - Variable in class org.apache.cassandra.config.Config
- gcBefore - Variable in class org.apache.cassandra.db.AbstractCompactionController
- gcBefore - Variable in class org.apache.cassandra.db.compaction.CompactionTask
- gcBefore(long) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- gcGraceSeconds - Variable in class org.apache.cassandra.schema.TableParams
- gcGraceSeconds(int) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- gcGraceSeconds(int) - Method in class org.apache.cassandra.schema.TableParams.Builder
- 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
- GENERAL - org.apache.cassandra.io.compress.ICompressor.Uses
- 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) - Static method in class org.apache.cassandra.schema.IndexMetadata
- generateDefaultIndexName(String, ColumnIdentifier) - Static method in class org.apache.cassandra.schema.IndexMetadata
- generatedNowInSeconds() - Method in class org.apache.cassandra.service.QueryState
- generatedOnLoadComponents() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- generatedOnLoadComponents() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- generatedOnLoadComponents() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
Returns a set of components that can be automatically generated when loading sstable and thus are not mandatory.
- 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() - 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)
. - generateViewUpdates(Collection<View>, UnfilteredRowIterator, UnfilteredRowIterator, long, 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.
- generation - Variable in class org.apache.cassandra.io.sstable.SequenceBasedSSTableId
- GENERATION - Static variable in class org.apache.cassandra.auth.AuthKeyspace
-
Generation is used as a timestamp for automatic table creation on startup.
- GENERATION - Static variable in class org.apache.cassandra.schema.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.
- generator(Stream<SSTableId>) - Method in class org.apache.cassandra.io.sstable.SequenceBasedSSTableId.Builder
-
Generates a sequential number to represent an sstables identifier.
- generator(Stream<SSTableId>) - Method in interface org.apache.cassandra.io.sstable.SSTableId.Builder
-
Creates a new generator of identifiers.
- generator(Stream<SSTableId>) - Method in class org.apache.cassandra.io.sstable.UUIDBasedSSTableId.Builder
-
Creates a new UUID based identifiers generator.
- Generator() - Constructor for class org.apache.cassandra.utils.TimeUUID.Generator
- generic(String, String) - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
-
Creates a
DescribeStatement
for the genericDESCRIBE ...
. - get() - Method in class org.apache.cassandra.concurrent.ExecutorLocals
-
Overwrite current locals, and return the previous ones
- get() - Method in class org.apache.cassandra.db.memtable.AbstractMemtable.ColumnsCollector
-
Get the current state of the columns set.
- get() - Method in class org.apache.cassandra.db.memtable.AbstractMemtable.StatsCollector
- get() - Method in class org.apache.cassandra.db.Mutation
- get() - Method in class org.apache.cassandra.db.rows.EncodingStats.Collector
- get() - Method in class org.apache.cassandra.index.sai.utils.AtomicRatio
- get() - Method in class org.apache.cassandra.index.sasi.disk.Token
- 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() - 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() - Method in class org.apache.cassandra.net.FutureDelegate
- get() - Method in class org.apache.cassandra.net.ShareableBytes
- get() - Method in class org.apache.cassandra.schema.SchemaUpdateHandlerFactoryProvider
- get() - Method in class org.apache.cassandra.schema.TableMetadataRef
- 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() - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- get() - Method in class org.apache.cassandra.utils.concurrent.NotScheduledFuture
- get() - Method in class org.apache.cassandra.utils.concurrent.Ref.DirectBufferRef
- get() - Method in class org.apache.cassandra.utils.concurrent.Ref
- get() - Method in class org.apache.cassandra.utils.concurrent.Threads.StackTraceCombiner
- get() - Method in class org.apache.cassandra.utils.ExpiringMemoizingSupplier
- get() - Method in class org.apache.cassandra.utils.ExpMovingAverage
- get() - Method in interface org.apache.cassandra.utils.MovingAverage
- get() - Method in interface org.apache.cassandra.utils.WithResources
-
Instantiate any necessary resources
- get() - Method in class org.apache.cassandra.utils.WithResources.None
- get() - Method in class org.apache.cassandra.utils.Wrapped
- get() - Method in class org.apache.cassandra.utils.WrappedBoolean
- get(boolean, boolean) - Static method in enum org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState.Action
- get(int) - Method in interface org.apache.cassandra.cql3.functions.Arguments
-
Returns the specified argument
- get(int) - Method in class org.apache.cassandra.cql3.functions.FunctionArguments
- 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(int) - Method in class org.apache.cassandra.db.NativeClustering
- get(int) - Method in class org.apache.cassandra.db.rows.CellPath
- get(int) - Method in class org.apache.cassandra.db.Slices
-
Returns the ith slice of this
Slices
object. - get(int) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
- get(int) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
- get(int) - Method in interface org.apache.cassandra.locator.ReplicaCollection
- get(int) - Method in interface org.apache.cassandra.streaming.StreamingDataOutputPlus.BufferSupplier
-
Request a buffer with at least the given capacity.
- 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.bytecomparable.ByteSource.AbstractEscaper
- get(int) - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.AccessorEscaper
- get(int) - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.ArrayEscaper
- get(int) - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.BufferEscaper
- get(int) - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.MemoryEscaper
- get(int) - Method in class org.apache.cassandra.utils.concurrent.Accumulator
- get(int) - Method in class org.apache.cassandra.utils.DynamicList
- get(int) - Method in class org.apache.cassandra.utils.LockedDynamicList
- get(int) - Method in class org.apache.cassandra.utils.memory.BufferPool.LocalPool
- get(int, TypeToken<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value converted to the given Java type. - get(int, Class<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value converted to the given Java type. - get(int, TypeCodec<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value converted using the givenTypeCodec
. - get(int, BufferType) - Method in class org.apache.cassandra.utils.memory.BufferPool
- get(long) - Method in class org.apache.cassandra.index.sai.disk.v1.bitpack.AbstractBlockPackedReader
- get(long) - Method in class org.apache.cassandra.index.sai.disk.v1.LongArray.DeferredLongArray
- get(long) - Method in interface org.apache.cassandra.index.sai.disk.v1.LongArray
-
Get value at
idx
. - get(long) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
- 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, Function<Long, DecoratedKey>) - Method in class org.apache.cassandra.index.sasi.disk.TokenTree
- get(long, TimeUnit) - Method in class org.apache.cassandra.net.FutureDelegate
- get(long, TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- get(long, TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.NotScheduledFuture
- get(long, TimeUnit) - Method in class org.apache.cassandra.utils.RecomputingSupplier
- get(Object) - Method in class org.apache.cassandra.config.ForwardingProperty
- get(Object) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaMap
- get(Object) - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
- get(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
- get(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
- get(String) - Method in class org.apache.cassandra.config.TransparentDataEncryptionOptions
- get(String) - Method in class org.apache.cassandra.index.sai.disk.v1.MetadataSource
- 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(String) - Method in class org.apache.cassandra.net.EndpointMessagingVersions
- get(String) - Method in class org.apache.cassandra.schema.Indexes
-
Get the index with the specified name
- get(String) - Method in class org.apache.cassandra.schema.Keyspaces
-
Get the keyspace with the specified name
- get(String) - Static method in class org.apache.cassandra.schema.MemtableParams
- 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(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(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, 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, 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, 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, String) - Method in class org.apache.cassandra.locator.SnitchProperties
-
Get a snitch property value or return defaultValue if not defined.
- get(String, FunctionName, List<? extends AssignmentTestable>, String, String, AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.FunctionResolver
- get(String, FunctionName, List<? extends AssignmentTestable>, String, String, AbstractType<?>, UserFunctions) - Static method in class org.apache.cassandra.cql3.functions.FunctionResolver
- get(String, TypeCodec<T>) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
converted using the givenTypeCodec
. - get(String, TypeCodec<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
-
Returns the value for
name
converted using the givenTypeCodec
. - get(ByteBuffer) - Method in class org.apache.cassandra.schema.Types
-
Get the type with the specified name
- get(ByteBuffer, IPartitioner) - Static method in class org.apache.cassandra.db.PartitionPosition.ForKey
- get(List<? extends Iterator<In>>, Comparator<? super In>, MergeIterator.Reducer<In, Out>) - Static method in class org.apache.cassandra.utils.MergeIterator
- get(UUID) - Method in class org.apache.cassandra.schema.Indexes
-
Get the index with the specified id
- get(CompositeData, String) - Method in class org.apache.cassandra.metrics.SamplingManager.ResultBuilder
- 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(K) - Method in class org.apache.cassandra.locator.ReplicaMultimap.Builder
- get(K) - Method in class org.apache.cassandra.locator.ReplicaMultimap
- get(KeyCacheKey, boolean) - Method in class org.apache.cassandra.io.sstable.keycache.KeyCache
- get(FunctionName) - Method in class org.apache.cassandra.schema.UserFunctions
-
Get all function overloads with the specified name
- get(DecoratedKey, TableMetadata) - Static method in class org.apache.cassandra.service.paxos.PaxosState
- get(Range<Token>) - Method in class org.apache.cassandra.locator.EndpointsByRange
- 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(IndexComponent) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata.ComponentMetadataMap
- get(PrimaryKey) - Method in class org.apache.cassandra.index.sai.disk.RowMapping
-
Returns the SSTable row ID for a
PrimaryKey
- get(File, String...) - Static method in class org.apache.cassandra.db.Directories
- get(InetAddressAndPort) - Method in class org.apache.cassandra.locator.RangesByEndpoint
- get(InetAddressAndPort) - Static method in class org.apache.cassandra.metrics.StreamingMetrics
- 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(InetAddressAndPort) - Method in class org.apache.cassandra.repair.asymmetric.DifferenceHolder
- get(InetAddressAndPort) - Method in class org.apache.cassandra.repair.asymmetric.HostDifferences
- get(Replica) - Method in class org.apache.cassandra.locator.EndpointsByReplica
- get(ConnectionType) - Static method in class org.apache.cassandra.net.PingRequest
- get(ParamType) - Static method in class org.apache.cassandra.db.MessageParams
- get(Commit) - Static method in class org.apache.cassandra.service.paxos.PaxosState
- get(ProtocolVersion) - Method in class org.apache.cassandra.cql3.Constants.Value
- 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(ProtocolVersion) - Method in class org.apache.cassandra.cql3.Vectors.Value
- get(ByteComparable) - Method in class org.apache.cassandra.db.tries.InMemoryReadTrie
-
Get the content mapped by the specified key.
- get(TimeUUID) - Method in class org.apache.cassandra.tracing.Tracing
- get(T) - Method in class org.apache.cassandra.utils.concurrent.Refs
- 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.v1.ProposeCallback
- getAccepted(Row, long, long) - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosRows
- getAcceptedProtocols() - Method in class org.apache.cassandra.config.EncryptionOptions
- getAcceptedProtocols() - Method in class org.apache.cassandra.security.AbstractSslContextFactory
-
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"
- getAcceptedProtocols() - Method in interface org.apache.cassandra.security.ISslContextFactory
-
Returns the prepared list of accepted protocols.
- getAccess() - Method in class org.apache.cassandra.tools.JMXTool.Attribute
- getAcquisitionCallable(ColumnFamilyStore, Set<Range<Token>>, TimeUUID, int, int) - Method in class org.apache.cassandra.db.repair.PendingAntiCompaction
- getAcquisitionCallback(TimeUUID, RangesAtEndpoint) - Method in class org.apache.cassandra.db.repair.PendingAntiCompaction
- getActiveBuilderCount() - Static method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder
- 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.ImmediateExecutor
- getActiveTaskCount() - Method in interface org.apache.cassandra.concurrent.ResizableThreadPool
-
Returns the approximate number of threads that are actively executing tasks.
- getActiveTaskCount() - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- getActiveTaskCount() - Method in class org.apache.cassandra.concurrent.SEPExecutor
- getActiveTaskCount() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBase
- getActiveTaskCount() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorJMXAdapter
- getActiveTaskCount() - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- getActiveUpdate() - Method in class org.apache.cassandra.auth.AuthCache
- getActiveUpdate() - Method in interface org.apache.cassandra.auth.AuthCacheMBean
- getActualTypeArguments() - Method in class org.apache.cassandra.config.ForwardingProperty
- getAddress(ByteBuffer) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
- getAddressReplicas() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
- getAddressReplicas(InetAddressAndPort) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
- getAddressReplicas(TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
- getAddressReplicas(TokenMetadata, 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.
- getAggregationSpec(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
- getAggregator(TableId) - Method in class org.apache.cassandra.streaming.StreamSession
- getAliasParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
- getAll() - Method in class org.apache.cassandra.auth.AuthCache
-
Retrieve all cached entries.
- getAll(String) - Static method in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable
- getAll(String) - Static method in class org.apache.cassandra.db.virtual.LocalRepairTables
- getAll(String) - Static method in class org.apache.cassandra.db.virtual.TableMetricTables
-
Generates all table metric tables in a collection
- getAll(String) - Static method in class org.apache.cassandra.index.sai.virtual.StorageAttachedIndexTables
- getAllByName(String) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
- getAllByNameOverrideDefaults(String, Integer) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
- 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() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
Deprecated.See CASSANDRA-7544
- getAllEndpointStates(boolean) - Method in class org.apache.cassandra.gms.FailureDetector
- getAllEndpointStates(boolean, boolean) - Method in class org.apache.cassandra.gms.FailureDetector
- getAllEndpointStatesWithPort() - Method in class org.apache.cassandra.gms.FailureDetector
- getAllEndpointStatesWithPort() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
- getAllEndpointStatesWithPortAndResolveIp() - Method in class org.apache.cassandra.gms.FailureDetector
- getAllEndpointStatesWithPortAndResolveIp() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
- getAllEndpointStatesWithResolveIp() - Method in class org.apache.cassandra.gms.FailureDetector
- getAllEndpointStatesWithResolveIp() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
-
Deprecated.See CASSANDRA-17934
- 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
- getAllLevelSizeBytes() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
- getAllLevelSizeBytes() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
- getAllLocalAddresses() - Static method in class org.apache.cassandra.utils.TimeUUID.Generator
-
Helper function used exclusively by UUIDGen to create
- getAllMembers() - Method in class org.apache.cassandra.locator.TokenMetadata
- getAllMemtables() - Method in class org.apache.cassandra.db.lifecycle.View
- getAllMemtableSize() - Method in class org.apache.cassandra.service.disk.usage.DiskUsageMonitor
- 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.AbstractAllocatorMemtable
- getAllocator() - Method in class org.apache.cassandra.net.AsyncStreamingInputPlus
- getAllocatorForEndpoint(InetAddress) - Static method in class org.apache.cassandra.transport.ClientResourceLimits
- getAllowFilteringEnabled() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getAllowFilteringEnabled() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getAllowFilteringEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Returns whether ALLOW FILTERING property is allowed.
- getAllowFilteringEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Returns whether ALLOW FILTERING property is allowed.
- 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
-
We hard-code this query to Quorum regardless of the role or auth credentials of the queryer given the nature of this query: we expect to know *all* roles across the entire cluster when we query this, not just local quorum or on a single node.
- getAllRoles() - Method in interface org.apache.cassandra.auth.IRoleManager
-
Called during the execution of an unqualified LIST ROLES query.
- getAllRoles() - Static method in class org.apache.cassandra.auth.Roles
-
Enumerate all the roles in the system, preferably these will be fetched from the cache, which in turn may have been warmed during startup.
- getAllSessionInfo() - Method in class org.apache.cassandra.streaming.StreamCoordinator
- getAllSnapshots() - Method in class org.apache.cassandra.db.Keyspace
- getAllSSTables(SSTableSet) - Method in class org.apache.cassandra.db.Keyspace
- getAllStreamSessions() - Method in class org.apache.cassandra.streaming.StreamCoordinator
- getAlterTableEnabled() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getAlterTableEnabled() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getAlterTableEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Returns whether users are allowed access to the ALTER TABLE statement to mutate columns or not
- getAlterTableEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Gets whether users can use the ALTER TABLE statement to change columns
- getAnalyzer() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
- getAnalyzer(AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.conf.IndexMode
- getAnalyzerOptions(Map<String, String>) - Static method in class org.apache.cassandra.index.sai.analyzer.AbstractAnalyzer
- 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
- getAnnotation(Class<A>) - Method in class org.apache.cassandra.config.ForwardingProperty
- getAnnotations() - Method in class org.apache.cassandra.config.ForwardingProperty
- getAntiCompactionIterator(List<ISSTableScanner>, CompactionController, long, TimeUUID, ActiveCompactionsTracker, BooleanSupplier) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
- getAppender(Class<?>, String) - Method in class org.apache.cassandra.utils.logging.LogbackLoggingSupport
- getAppender(Class<?>, String) - Method in interface org.apache.cassandra.utils.logging.LoggingSupport
- 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.
- getApproximateCommitLogLowerBound() - Method in class org.apache.cassandra.db.memtable.AbstractMemtableWithCommitlog
- getApproximateCommitLogLowerBound() - Method in interface org.apache.cassandra.db.memtable.Memtable
-
Approximate commit log lower bound, <= getCommitLogLowerBound, used as a time stamp for ordering
- 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
- getArgumentDeserializer() - Method in class org.apache.cassandra.cql3.functions.UDFDataType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.AbstractType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.AsciiType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.BooleanType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.BytesType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.ByteType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.DecimalType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.DoubleType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.DurationType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.EmptyType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.FloatType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.FrozenType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.InetAddressType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.Int32Type
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.IntegerType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.LongType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.ReversedType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.ShortType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.TemporalType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.TimeType
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.UTF8Type
- getArgumentDeserializer() - Method in class org.apache.cassandra.db.marshal.UUIDType
- getArray() - Method in interface org.apache.cassandra.index.sasi.analyzer.StandardTokenizerInterface
- 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(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.
- getAsBoolean(int) - Method in interface org.apache.cassandra.cql3.functions.Arguments
-
Returns the specified argument as a
boolean
. - getAsByte(int) - Method in interface org.apache.cassandra.cql3.functions.Arguments
-
Returns the specified argument as a
byte
. - getAsDouble(int) - Method in interface org.apache.cassandra.cql3.functions.Arguments
-
Returns the specified argument as a
double
. - getAsFloat(int) - Method in interface org.apache.cassandra.cql3.functions.Arguments
-
Returns the specified argument as a
float
. - getAsInt(int) - Method in interface org.apache.cassandra.cql3.functions.Arguments
-
Returns the specified argument as a
int
. - getAsLong(int) - Method in interface org.apache.cassandra.cql3.functions.Arguments
-
Returns the specified argument as a
long
. - getAsShort(int) - Method in interface org.apache.cassandra.cql3.functions.Arguments
-
Returns the specified argument as a
short
. - getAtLeast(int) - Method in class org.apache.cassandra.utils.memory.BufferPool.LocalPool
- getAtLeast(int, BufferType) - Method in class org.apache.cassandra.utils.memory.BufferPool
- 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
- GetAuditLog - Class in org.apache.cassandra.tools.nodetool
- GetAuditLog() - Constructor for class org.apache.cassandra.tools.nodetool.GetAuditLog
- 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.AddIdentityStatement
- 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.DropIdentityStatement
- 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
- getAuditLogOptions() - Method in class org.apache.cassandra.audit.AuditLogManager
- getAuditLogOptions() - Method in class org.apache.cassandra.tools.NodeProbe
- getAuditLogOptionsData() - Method in class org.apache.cassandra.audit.AuditLogManager
- getAuditLogOptionsData() - Method in interface org.apache.cassandra.audit.AuditLogManagerMBean
-
Returns the current state of Audit Log framework.
- GetAuthCacheConfig - Class in org.apache.cassandra.tools.nodetool
- GetAuthCacheConfig() - Constructor for class org.apache.cassandra.tools.nodetool.GetAuthCacheConfig
- getAuthCacheMBean(String) - Method in class org.apache.cassandra.tools.NodeProbe
- getAuthCacheWarmingEnabled() - 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
- getAuthFromRoot() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getAuthorizer() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getAuthReadConsistencyLevel() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getAuthWriteConsistencyLevel() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
Deprecated.See CASSANDRA-17195
- 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
- getAutoSnapshotTtl() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getAvailableCidrGroups() - Method in class org.apache.cassandra.auth.CIDRGroupsMappingManager
- getAvailableCidrGroups() - Method in interface org.apache.cassandra.auth.CIDRGroupsMappingManagerMBean
-
Retrieves available CIDR groups in the table
AuthKeyspace.CIDR_GROUPS
- getAvailableProcessors() - 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
- getAvailableSpaceForCompactions(FileStore) - Static method in class org.apache.cassandra.db.Directories
- getAverageIndexInterval() - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryManager
- getAverageIndexInterval() - Method in interface org.apache.cassandra.io.sstable.indexsummary.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(long) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
- getBackgroundTaskSuppliers(long) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
- getBackgroundTaskSuppliers(long) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
- getBackingSSTables() - Method in class org.apache.cassandra.io.sstable.EmptySSTableScanner
- getBackingSSTables() - Method in class org.apache.cassandra.io.sstable.format.SSTableScanner
- 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.sai.StorageAttachedIndex
- getBackingTable() - Method in class org.apache.cassandra.index.sasi.SASIIndex
- getBackingTable() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- getBackPressurePerHost() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Deprecated.See CASSANDRA-7544
- 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
-
Returns directory to write a backup to.
- getBackupsDirectoryIfExists(File) - Static method in class org.apache.cassandra.db.Directories
-
Returns directory to write a backup to.
- getBadnessThreshold() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
- getBadnessThreshold() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
- getBallotForToken(Token) - Method in class org.apache.cassandra.service.paxos.TablePaxosRepairHistory
- getBaseColumn(ColumnMetadata) - Method in class org.apache.cassandra.db.view.View
-
The base column corresponding to the provided view column.
- getBaseSleepTime() - Method in class org.apache.cassandra.config.RetrySpec
- getBaseSstableSize(int) - Method in class org.apache.cassandra.db.compaction.unified.Controller
- getBatch() - Method in class org.apache.cassandra.audit.AuditLogEntry
- getBatchlogReplayThrottle() - Method in class org.apache.cassandra.tools.NodeProbe
- getBatchlogReplayThrottleInKB() - Method in class org.apache.cassandra.service.StorageService
- getBatchlogReplayThrottleInKB() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getBatchlogReplayThrottleInKiB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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
- getBatchSizeFailThresholdInKiB() - 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
-
Deprecated.See CASSANDRA-17668
- getBatchSizeWarnThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.use getBatchSizeWarnThresholdInKiB instead. See CASSANDRA-17668
- getBatchSizeWarnThresholdInKiB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getBatchSizeWarnThresholdInKiB() - Method in class org.apache.cassandra.service.StorageService
- getBatchSizeWarnThresholdInKiB() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the threshold for warning queries due to a large batch size
- getBestIndexFor(RowFilter.Expression) - Method in interface org.apache.cassandra.index.IndexRegistry
- getBestIndexFor(RowFilter.Expression) - Method in class org.apache.cassandra.index.SecondaryIndexManager
- getBestIndexFor(RowFilter.Expression, Class<T>) - Method in class org.apache.cassandra.index.SecondaryIndexManager
- getBestIndexQueryPlanFor(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.
- 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() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.PointerTerm
- getBlock(int) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.Level
- 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 any in-memory index data to persistent storage, independent of any flush of the base table.
- getBlockingFlushTask() - Method in class org.apache.cassandra.index.internal.CassandraIndex
- getBlockingFlushTask() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- getBlockingFlushTask() - Method in class org.apache.cassandra.index.sasi.SASIIndex
- getBlockingFlushTask() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- getBlockingFlushTask(Memtable) - Method in interface org.apache.cassandra.index.Index
-
Return a task which performs a blocking flush of the index's data corresponding to the provided base table's Memtable.
- getBlockingFlushTask(Memtable) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- getBlockSize(File) - Static method in class org.apache.cassandra.io.util.FileUtils
- getBool(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a boolean. - getBool(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
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.CassandraRelevantEnv
-
Gets the value of a system env 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(byte[], int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- getBoolean(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
- getBoolean(String) - Method in class org.apache.cassandra.security.AbstractSslContextFactory
- getBoolean(String, boolean) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
- getBoolean(String, boolean) - Method in class org.apache.cassandra.security.AbstractSslContextFactory
- getBoolean(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
returns a boolean from offset {@param offset}
- getBootstrapState() - Static method in class org.apache.cassandra.db.SystemKeyspace
- getBootstrapState() - Method in class org.apache.cassandra.service.StorageService
- getBootstrapState() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getBootstrapTokens() - Method in class org.apache.cassandra.locator.TokenMetadata
- getBootstrapTokens(TokenMetadata, InetAddressAndPort, long, long) - Static method in class org.apache.cassandra.dht.BootStrapper
-
if initialtoken was specified, use that (split on comma).
- 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.format.SSTableReader
- getBounds() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
- getBounds() - Method in class org.apache.cassandra.io.sstable.SSTable
- getBounds() - Method in class org.apache.cassandra.io.sstable.SSTableZeroCopyWriter
- 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(boolean) - 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
- 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
- getBufferedChecksumIndexInput(IndexInput) - Static method in class org.apache.cassandra.index.sai.disk.io.IndexFileUtils
- getBufferPoolMetric(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
Retrieve buffer pool metrics based on the buffer pool type
- 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.sai.StorageAttachedIndex
- 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
- getByAddress(InetSocketAddress) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
- getByAddressOverrideDefaults(InetAddress, byte[], Integer) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
- getByAddressOverrideDefaults(InetAddress, 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(byte[], int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- getByte(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a byte. - getByte(long) - Method in class org.apache.cassandra.io.util.Memory
- getByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
- getByte(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
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(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 {@param offset}
- getByteArray(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
- 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() - Method in interface org.apache.cassandra.index.sasi.analyzer.StandardTokenizerInterface
- getBytes() - Method in class org.apache.cassandra.index.sasi.sa.IndexedTerm
- getBytes(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a byte array. - 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
- getBytes(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
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
- getBytesPerValue() - Method in class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeReader
- getBytesPerValue() - Method in class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeWriter
- getBytesRead() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
- getBytesRead() - Method in class org.apache.cassandra.db.repair.CassandraValidationIterator
- 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
- getBytesRead() - Method in class org.apache.cassandra.repair.ValidationPartitionIterator
- getBytesScanned() - Method in class org.apache.cassandra.io.sstable.EmptySSTableScanner
- getBytesScanned() - Method in class org.apache.cassandra.io.sstable.format.SSTableScanner
- getBytesScanned() - Method in interface org.apache.cassandra.io.sstable.ISSTableScanner
- getBytesUnsafe(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as aByteBuffer
. - getBytesUnsafe(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
as a ByteBuffer. - getBytesUnsafe(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
-
Returns the value for
name
as a ByteBuffer. - getBytesWritten() - Method in class org.apache.cassandra.db.compaction.unified.ShardedMultiWriter
- getBytesWritten() - Method in class org.apache.cassandra.io.sstable.RangeAwareSSTableWriter
- getBytesWritten() - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
- getBytesWritten() - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
- getBytesWritten() - Method in class org.apache.cassandra.io.sstable.SSTableZeroCopyWriter
- 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(KeyCacheKey, boolean) - Method in interface org.apache.cassandra.io.sstable.keycache.KeyCacheSupport
-
Will return null if key is not found or cache is not available.
- getCachedPosition(DecoratedKey, boolean) - Method in interface org.apache.cassandra.io.sstable.keycache.KeyCacheSupport
-
Will return null if key is not found or cache is not available.
- 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(long, Token) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
- getCacheKey(ByteBuffer) - Method in interface org.apache.cassandra.io.sstable.keycache.KeyCacheSupport
- getCacheKey(DecoratedKey) - Method in interface org.apache.cassandra.io.sstable.keycache.KeyCacheSupport
- getCacheLoadTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getCacheMetadataPath(String) - Method in class org.apache.cassandra.cache.AutoSavingCache
- 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() - 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
- getCasContentionTimeout(TimeUnit) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getCategory() - Method in enum org.apache.cassandra.audit.AuditLogEntryType
- getCDCBlockWrites() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getCDCBlockWrites() - Method in class org.apache.cassandra.db.commitlog.CommitLog
- getCDCBlockWrites() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
- 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
- getCDCState() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
- getCDCTotalSpace() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getCell(CellPath) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
- 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) - Method in interface org.apache.cassandra.db.rows.Row
-
Returns a cell for a simple column.
- getCell(ColumnMetadata, CellPath) - Method in class org.apache.cassandra.db.rows.BTreeRow
- 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.FileInputStreamPlus
- getChannel() - Method in class org.apache.cassandra.io.util.FileOutputStreamPlus
- getChannel() - Method in class org.apache.cassandra.io.util.RandomAccessReader
- getChannel() - Method in class org.apache.cassandra.streaming.StreamSession
- 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
- getChecksum() - Method in class org.apache.cassandra.index.sai.disk.io.IndexOutputWriter
- getChecksum() - Method in class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- getChunkCache() - Method in class org.apache.cassandra.io.sstable.SSTable.Builder
- getChunkLength() - Method in class org.apache.cassandra.security.EncryptionContext
- getChunksForSections(Collection<SSTableReader.PartitionPositionBounds>) - Method in class org.apache.cassandra.io.compress.CompressionMetadata
- getCIDRAuthorizer() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getCidrAuthorizerMetrics() - Method in class org.apache.cassandra.auth.AbstractCIDRAuthorizer
- getCidrAuthorizerMetrics() - Method in interface org.apache.cassandra.auth.ICIDRAuthorizer
- getCidrAuthorizerMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getCidrChecksForSuperusers() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getCidrFilteringMetric(String) - Method in class org.apache.cassandra.tools.NodeProbe
- getCidrGroupsCacheRefreshInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getCidrGroupsMappingManager() - Method in class org.apache.cassandra.auth.AbstractCIDRAuthorizer
- getCidrGroupsMappingManager() - Method in interface org.apache.cassandra.auth.ICIDRAuthorizer
- getCidrGroupsOfIp(String) - Method in class org.apache.cassandra.tools.NodeProbe
- getCidrGroupsOfIP(String) - Method in class org.apache.cassandra.auth.CIDRGroupsMappingManager
- getCidrGroupsOfIP(String) - Method in interface org.apache.cassandra.auth.CIDRGroupsMappingManagerMBean
-
Get CIDR groups of a given IP, when CIDR authorizer is enabled.
- GetCIDRGroupsOfIP - Class in org.apache.cassandra.tools.nodetool
-
Nodetool command to get CIDR groups(s) of given IP
- GetCIDRGroupsOfIP() - Constructor for class org.apache.cassandra.tools.nodetool.GetCIDRGroupsOfIP
- getCidrGroupsTableEntries() - Method in class org.apache.cassandra.auth.CIDRGroupsMappingManager
- getCidrPermissionsForRole(RoleResource) - Method in class org.apache.cassandra.auth.CIDRPermissionsManager
-
Get CIDR permissions of a role
- getCidrsOfCidrGroupAsStrings(String) - Method in class org.apache.cassandra.auth.CIDRGroupsMappingManager
- getCidrsOfCidrGroupAsStrings(String) - Method in interface org.apache.cassandra.auth.CIDRGroupsMappingManagerMBean
-
Retrieves all CIDRs associated with a given CIDR group in the table
AuthKeyspace.CIDR_GROUPS
, including invalid CIDRs (if exists) - getCidrTuplesSetString(List<CIDR>) - Static method in class org.apache.cassandra.auth.CIDRGroupsMappingManager
- getCipherSuites() - Method in class org.apache.cassandra.security.AbstractSslContextFactory
- getCipherSuites() - Method in interface org.apache.cassandra.security.ISslContextFactory
-
Returns the list of cipher suites supported by the implementation.
- getClass(String) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
- getClientAddress() - Method in class org.apache.cassandra.service.QueryState
- getClientErrorReportingExclusions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getClientMetric(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
Retrieve Proxy metrics
- getClientOptions() - Method in class org.apache.cassandra.service.ClientState
- getClientRequestSizeMetricsEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getClientRequestSizeMetricsEnabled() - Method in class org.apache.cassandra.service.StorageProxy
- getClientRequestSizeMetricsEnabled() - Method in interface org.apache.cassandra.service.StorageProxyMBean
- 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
- getClusteringColumns(QueryOptions, ClientState) - 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
- getCollectionSizeFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getCollectionSizeFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getCollectionSizeFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getCollectionSizeFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getCollectionSizeWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getCollectionSizeWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getCollectionSizeWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getCollectionSizeWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getCollectionsParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
- getColumn() - Method in class org.apache.cassandra.cql3.Ordering.Expression
- getColumn() - Method in class org.apache.cassandra.cql3.selection.SimpleSelector.SimpleSelectorFactory
- getColumn(ByteBuffer) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- getColumn(ByteBuffer) - Method in class org.apache.cassandra.schema.TableMetadata
- getColumn(ColumnIdentifier) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- getColumn(ColumnIdentifier) - Method in class org.apache.cassandra.schema.TableMetadata
-
Returns the ColumnMetadata for
name
. - getColumnCount() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
- getColumnData(ColumnMetadata) - Method in class org.apache.cassandra.db.rows.BTreeRow
- getColumnData(ColumnMetadata) - Method in interface org.apache.cassandra.db.rows.Row
-
Returns the
ColumnData
for the specified column. - getColumnDefinitions() - Method in interface org.apache.cassandra.cql3.restrictions.Restrictions
-
This method exists in addition to
Restriction.getColumnDefs()
in case implementations want to provide columns definitions that are not strictly in position order. - 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
- getColumnFamilies() - Method in class org.apache.cassandra.repair.state.CoordinatorState
- 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.See CASSANDRA-9448
- getColumnFamilyName() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.See CASSANDRA-9448
- getColumnFamilyName() - Method in class org.apache.cassandra.io.sstable.SSTable
- getColumnFamilyNames() - Method in class org.apache.cassandra.repair.state.CoordinatorState
- 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
-
Returns
ColumnFamilyStore
by the table identifier. - 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
-
Deprecated.See CASSANDRA-17668
- getColumnIndexCacheSize() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.use getColumnIndexCacheSizeInKiB. See CASSANDRA-17668
- getColumnIndexCacheSizeInKiB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getColumnIndexCacheSizeInKiB() - Method in class org.apache.cassandra.service.StorageService
- getColumnIndexCacheSizeInKiB() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the threshold for skipping the column index when caching partition info
- getColumnIndexCount() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormatPartitionWriter
- getColumnIndexSize(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- GetColumnIndexSize - Class in org.apache.cassandra.tools.nodetool
- GetColumnIndexSize() - Constructor for class org.apache.cassandra.tools.nodetool.GetColumnIndexSize
- getColumnIndexSizeInKB() - Method in class org.apache.cassandra.tools.NodeProbe
- getColumnIndexSizeInKiB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getColumnIndexSizeInKiB() - Method in class org.apache.cassandra.service.StorageService
- getColumnIndexSizeInKiB() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns the granularity of the collation index of rows within a partition.
- 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 separatedString
. - 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
- getColumnsPerTableFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getColumnsPerTableFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getColumnsPerTableFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getColumnsPerTableFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getColumnsPerTableWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getColumnsPerTableWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getColumnsPerTableWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getColumnsPerTableWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getColumnsWithConditions() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- getColumnValueSizeFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getColumnValueSizeFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getColumnValueSizeFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getColumnValueSizeFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getColumnValueSizeWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getColumnValueSizeWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getColumnValueSizeWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getColumnValueSizeWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getCommand() - Static method in class org.apache.cassandra.db.ReadCommand
- 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.AbstractMemtableWithCommitlog
- getCommitLogLowerBound() - Method in interface org.apache.cassandra.db.memtable.Memtable
-
The commit log position at the time that this memtable was created
- 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
- getCommitLogWriteDiskAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
Return commitlog disk access mode.
- getCommitted(TableMetadata, DecoratedKey, Row, long, long) - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosRows
- getCommonRanges() - Method in class org.apache.cassandra.repair.state.CoordinatorState
- 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
- getCompactionAwareWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.unified.UnifiedCompactionTask
- 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.index.sai.StorageAttachedIndexBuilder
- getCompactionInfo() - Method in class org.apache.cassandra.io.sstable.format.SortedTableScrubber.ScrubInfo
- getCompactionInfo() - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier.VerifyInfo
- getCompactionInfo() - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryRedistribution
- 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
- getCompactionsMatching(Iterable<TableMetadata>, Predicate<CompactionInfo>) - Method in class org.apache.cassandra.db.compaction.CompactionManager
- 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, long, long) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
- getCompactionTask(LifecycleTransaction, long, long) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
- getCompactionTask(LifecycleTransaction, long, 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
-
Deprecated.See CASSANDRA-17225
- GetCompactionThroughput - Class in org.apache.cassandra.tools.nodetool
- GetCompactionThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.GetCompactionThroughput
- getCompactionThroughputBytes() - Method in class org.apache.cassandra.tools.NodeProbe
- getCompactionThroughputBytesPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getCompactionThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-17225
- getCompactionThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.Use getCompactionThroughtputMibPerSecAsDouble instead as this one will provide a rounded value. See CASSANDRA-17225
- getCompactionThroughputMebibytesAsDouble() - Method in class org.apache.cassandra.tools.NodeProbe
- getCompactionThroughputMebibytesPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getCompactionThroughputMebibytesPerSecAsInt() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getCompactionThroughtputBytesPerSec() - Method in class org.apache.cassandra.service.StorageService
- getCompactionThroughtputBytesPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getCompactionThroughtputMibPerSecAsDouble() - Method in class org.apache.cassandra.service.StorageService
- getCompactionThroughtputMibPerSecAsDouble() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getCompactionTombstoneWarningThreshold() - Method in class org.apache.cassandra.service.StorageService
- getCompactionTombstoneWarningThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-17194
- getCompactTablesEnabled() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getCompactTablesEnabled() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getCompactTablesEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Returns whether users can create new COMPACT STORAGE tables
- getCompactTablesEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Returns whether users can create new COMPACT STORAGE tables
- getCompactValueColumn(RegularAndStaticColumns) - Static method in class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
- getComparator() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getComparator() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
- 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, VL, ValueAccessor<VL>, VR, ValueAccessor<VR>, int, 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.DynamicCompositeType
- getComparator(int, V, ValueAccessor<V>, int) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
- getComparator(int, V, ValueAccessor<V>, 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
- 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
- getCompatibleTypeIfKnown(String) - Method in interface org.apache.cassandra.cql3.AssignmentTestable
- getCompatibleTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.Constants.Literal
- getCompatibleTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
- getCompatibleTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.Lists.Literal
- getCompatibleTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.Maps.Literal
- getCompatibleTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.BetweenParenthesesOrWithTuple
- getCompatibleTypeIfKnown(String) - Method in interface org.apache.cassandra.cql3.selection.Selectable
- getCompatibleTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithArrayLiteral
- getCompatibleTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithList
- getCompatibleTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithMapOrUdt
- getCompatibleTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithSet
- getCompatibleTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithTerm
- getCompatibleTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithVector
- getCompatibleTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.Sets.Literal
- getCompatibleTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.Term.Raw
- getCompatibleTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.Vectors.Literal
- getCompatibleTypeIfKnown(String) - Method in class org.apache.cassandra.db.marshal.AbstractType
- getCompatibleTypeIfKnown(Collection<AbstractType<?>>) - Static method in interface org.apache.cassandra.cql3.AssignmentTestable
- 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.ResizableThreadPool
-
Returns the approximate total number of tasks that have completed execution.
- getCompletedTaskCount() - Method in class org.apache.cassandra.concurrent.SEPExecutor
- getCompletedTaskCount() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorJMXAdapter
- getCompletedTaskCount() - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- getCompletedTasks() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
- getCompletedTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
- getCompletionStatus() - Method in class org.apache.cassandra.repair.state.AbstractCompletable
- 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() - 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
- getComponents() - Method in interface org.apache.cassandra.index.Index
-
Returns the SSTable-attached
Component
s created by this index. - getComponents() - Method in interface org.apache.cassandra.index.Index.Group
-
Returns the SSTable-attached
Component
s created by this index group. - getComponents() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- getComponents() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- getComponents() - Method in class org.apache.cassandra.index.SingletonIndexGroup
- getComponents() - Method in class org.apache.cassandra.io.sstable.SSTable.Builder
- getComponents() - Method in class org.apache.cassandra.io.sstable.SSTable
- getComponents(Set<Component>, Set<Component>) - Method in class org.apache.cassandra.io.sstable.Descriptor
-
Returns the set of components consisting of the provided mandatory components and those optional components for which the corresponding file exists.
- getComponents(TableMetadata, DecoratedKey) - Static method in class org.apache.cassandra.cql3.statements.SelectStatement
- getCompressedLengthInBytes() - Method in class org.apache.cassandra.io.sstable.EmptySSTableScanner
- getCompressedLengthInBytes() - Method in class org.apache.cassandra.io.sstable.format.SSTableScanner
- 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
- 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
- getCompressorName() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
- 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
- getConcurrentIndexBuilders() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getConcurrentIndexBuilders() - Method in class org.apache.cassandra.service.StorageService
- getConcurrentIndexBuilders() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getConcurrentMerkleTreeRequests() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getConcurrentMerkleTreeRequests() - Method in class org.apache.cassandra.service.ActiveRepairService
- getConcurrentMerkleTreeRequests() - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
- 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
- getConfig(StartupChecks.StartupCheckType) - Method in class org.apache.cassandra.config.StartupChecksOptions
- 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
- getConsistencyLevel() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosKeyState
- getConsistencyLevel() - Method in interface org.apache.cassandra.service.paxos.uncommitted.UncommittedPaxosKey
- getConstructionBeamWidth() - Method in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- getController() - Method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- getCoordinator() - Method in class org.apache.cassandra.streaming.StreamPlan
- getCoordinator() - Method in class org.apache.cassandra.streaming.StreamResultFuture
- getCoordinatorLargeReadAbortThreshold() - Method in class org.apache.cassandra.service.StorageService
- getCoordinatorLargeReadAbortThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getCoordinatorLargeReadWarnThreshold() - Method in class org.apache.cassandra.service.StorageService
- getCoordinatorLargeReadWarnThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getCoordinatorReadSizeAbortThresholdBytes() - Method in class org.apache.cassandra.cql3.QueryOptions
- getCoordinatorReadSizeFailThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getCoordinatorReadSizeWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getCoordinatorReadSizeWarnThresholdBytes() - Method in class org.apache.cassandra.cql3.QueryOptions
- 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 core pool size of thread pool, the minimum number of workers (where that makes sense for a thread pool, SEPExecutor does not have a minimum size).
- getCorePoolSize() - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- getCorePoolSize() - Method in class org.apache.cassandra.concurrent.SEPExecutor
- getCorePoolSize() - Method in class org.apache.cassandra.concurrent.SingleThreadExecutorPlus
- getCorePoolSize() - Method in enum org.apache.cassandra.concurrent.Stage
-
Returns core thread pool size
- getCorePoolSize() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorJMXAdapter
- getCorePoolSize() - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- getCoreSecondaryIndexExecutorThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
- getCoreSecondaryIndexExecutorThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
- getCoreThreads() - Method in interface org.apache.cassandra.concurrent.ResizableThreadPoolMXBean
-
Deprecated.use getCorePoolSize instead. See CASSANDRA-15277
- getCoreThreads() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBase
- getCoreThreads() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorJMXAdapter
- 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.sai.iterators.KeyRangeIterator.Builder
- 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
- 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
- getCounterCacheSizeInMiB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getCounterId() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
- 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
- getCounterWriteRpcTimeout(TimeUnit) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getCountsMetricsFromVtable() - Method in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable
- getCountsMetricsFromVtable() - Method in interface org.apache.cassandra.db.virtual.CIDRFilteringMetricsTableMBean
-
Retreive rows from CIDR filtering counts metrics virtual table
- getCountsMetricsFromVtable() - Method in class org.apache.cassandra.tools.NodeProbe
- getCQLQueryHandler() - Static method in class org.apache.cassandra.service.ClientState
- getCQLStartTime() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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 interface org.apache.cassandra.io.sstable.SSTable.Owner
- 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.EmptyRebufferer
- 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.io.util.WrappingRebufferer
- getCreatedAt() - Method in class org.apache.cassandra.service.snapshot.SnapshotManifest
- getCreatedAt() - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
- getCredentialsCache() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
- getCredentialsCacheActiveUpdate() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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
- getCryptoProvider() - 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() - 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
- getCurrentGenerationNumber(String) - Method in class org.apache.cassandra.gms.Gossiper
- getCurrentGenerationNumber(String) - Method in interface org.apache.cassandra.gms.GossiperMBean
- getCurrentGenerationNumber(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
- getCurrentGlobalUsage() - Static method in class org.apache.cassandra.transport.ClientResourceLimits
- getCurrentIndexInfo() - Method in class org.apache.cassandra.io.sstable.format.bti.RowIndexReader
- getCurrentIndexPos() - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex.Reader
- getCurrentIpUsage() - Static method in class org.apache.cassandra.transport.ClientResourceLimits
- getCurrentMemtable() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getCurrentMemtable() - Method in class org.apache.cassandra.db.lifecycle.View
- getCurrentMemtable() - Method in interface org.apache.cassandra.db.memtable.Memtable.Owner
-
Get the current memtable for this owner.
- 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.EmptySSTableScanner
- getCurrentPosition() - Method in class org.apache.cassandra.io.sstable.format.SSTableScanner
- 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.repair.state.AbstractState
- 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.
- getCustomIndexExpressions() - Method in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
- 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 - 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. - 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() - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
- getDatacenter() - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Datacenter name depending on the respective snitch used for this node
- getDatacenter(String) - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
- getDatacenter(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Datacenter name depending on the respective snitch used, given the hostname/ip
- getDatacenter(InetSocketAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
- 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.DynamicEndpointSnitch
- 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(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(Replica) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
- 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
- getDataCreationTime() - 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
- getDataDiskUsageMaxDiskSize() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getDataDiskUsageMaxDiskSize() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getDataDiskUsageMaxDiskSize() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getDataDiskUsageMaxDiskSize() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getDataDiskUsagePercentageFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getDataDiskUsagePercentageFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getDataDiskUsagePercentageFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getDataDiskUsagePercentageFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getDataDiskUsagePercentageWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getDataDiskUsagePercentageWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getDataDiskUsagePercentageWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getDataDiskUsagePercentageWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getDataFile() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- getDataOffset() - Method in class org.apache.cassandra.index.sasi.Term
- getDataOffsetForChunkOffset(long) - Method in class org.apache.cassandra.io.compress.CompressionMetadata
- getDataPaths() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getDataPaths() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
- getDate(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a date (without time). - getDate(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
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). - getDate(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
- 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.
- getDaysSinceEpoch() - Method in class org.apache.cassandra.cql3.functions.types.LocalDate
-
Returns the number of days since January 1st, 1970 GMT.
- getDC2AllEndpoints(IEndpointSnitch) - Method in class org.apache.cassandra.locator.TokenMetadata
- getDcSuffix() - Method in class org.apache.cassandra.locator.SnitchProperties
- getDecimal(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a variable length decimal. - getDecimal(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
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() - Method in class org.apache.cassandra.security.EncryptionContext
- getDecryptor(String, String, byte[]) - Method in class org.apache.cassandra.security.CipherFactory
- getDefaultCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getDefaultGcBefore(ColumnFamilyStore, long) - Static method in class org.apache.cassandra.db.compaction.CompactionManager
- getDefaultGcBefore(ColumnFamilyStore, long) - Static method in class org.apache.cassandra.db.repair.CassandraValidationIterator
- getDefaultKeyspaceReplicationFactor() - Method in class org.apache.cassandra.service.StorageService
- getDefaultKeyspaceReplicationFactor() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getDefaultKeyspaceReplicationFactor() - Method in class org.apache.cassandra.tools.NodeProbe
- getDefaultKeyspaceRF() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- GetDefaultKeyspaceRF - Class in org.apache.cassandra.tools.nodetool
- GetDefaultKeyspaceRF() - Constructor for class org.apache.cassandra.tools.nodetool.GetDefaultKeyspaceRF
- getDefaultOptions() - Static method in class org.apache.cassandra.index.sai.analyzer.NonTokenizingOptions
- getDefaultOptions() - Static method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
- getDefaultOptions() - Static method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
- getDefaultSecondaryIndex() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getDefaultSecondaryIndexEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getDefaultShardCount() - Static method in class org.apache.cassandra.db.memtable.AbstractShardedMemtable
- getDefaultShardCount() - Method in interface org.apache.cassandra.db.memtable.ShardedMemtableConfigMXBean
-
Returns the shard count for sharded memtables that do not specify it explicitly in the memtable options.
- getDefaultValue() - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
-
Returns default value.
- getDefinition() - Method in class org.apache.cassandra.db.view.View
- getDefinition() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
- getDelay(TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.NotScheduledFuture
- getDelegate() - Method in class org.apache.cassandra.utils.MBeanWrapper.DelegatingMbeanWrapper
- getDeniedKeysInRangeCount(String, String, AbstractBounds<PartitionPosition>) - Method in class org.apache.cassandra.schema.PartitionDenylist
- getDeniedKeysInRangeCount(TableId, AbstractBounds<PartitionPosition>) - Method in class org.apache.cassandra.schema.PartitionDenylist
- getDenylistConsistencyLevel() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getDenylistInitialLoadRetrySeconds() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getDenylistMaxKeysPerTable() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getDenylistMaxKeysTotal() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getDenylistRangeReadsEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getDenylistReadsEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getDenylistRefreshSeconds() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getDenylistWritesEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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
- getDescriptor() - Method in class org.apache.cassandra.io.sstable.SSTable.Builder
- getDigestsByEndpoint() - Method in class org.apache.cassandra.service.reads.DigestResolver
- getDimensions() - Method in class org.apache.cassandra.cql3.functions.types.VectorType
- 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
- getDirectories() - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
- getDirectoriesForFiles(Set<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Grabs the global first/last tokens among sstables and returns the range of data directories that start/end with those tokens.
- getDirectoriesVersion() - Static method in class org.apache.cassandra.db.DisallowedDirectories
- getDirectory() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosBallotTracker
- getDirectory() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker
- 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
- getDisableCoordinatorLocking() - Static method in class org.apache.cassandra.service.paxos.PaxosState
- 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
- getDisksInBounds(DecoratedKey, DecoratedKey) - Method in class org.apache.cassandra.db.DiskBoundaries
- getDiskUsage() - Method in class org.apache.cassandra.service.disk.usage.DiskUsageMonitor
- getDistributedSchemaBlocking() - Method in class org.apache.cassandra.schema.Schema
-
Returns the current keyspaces metadata and version synchronouly.
- getDouble() - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
-
Gets the value of a system property as a double.
- getDouble(byte[], int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- getDouble(byte[], int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- getDouble(double) - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
-
Gets the value of a system property as a double.
- getDouble(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a double. - getDouble(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
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) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
- getDouble(String, double) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
- getDouble(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- getDouble(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- 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
- getDropKeyspaceEnabled() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getDropKeyspaceEnabled() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getDropKeyspaceEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Returns whether DROP on keyspaces is allowed
- getDropKeyspaceEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Returns whether users can DROP a keyspace
- getDroppableTombstoneRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getDroppableTombstoneRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Get the ratio of droppable tombstones to real columns (and non-droppable tombstones)
- getDroppableTombstoneRatio(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
- getDroppableTombstonesBefore(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- getDroppableTombstonesBefore(long) - 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
ofnull
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
- getDropTruncateTableEnabled() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getDropTruncateTableEnabled() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getDropTruncateTableEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Returns whether TRUNCATE or DROP table are allowed
- getDropTruncateTableEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Returns whether users can TRUNCATE or DROP TABLE
- getDumpHeapOnUncaughtException() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getDumpHeapOnUncaughtException() - Method in class org.apache.cassandra.service.StorageProxy
- getDumpHeapOnUncaughtException() - Method in interface org.apache.cassandra.service.StorageProxyMBean
- getDurationMillis() - Method in interface org.apache.cassandra.repair.state.Completable
- getDurationUnit() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
- getDynamicBadnessThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getDynamicDataMaskingEnabled() - 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.indexsummary.IndexSummary
- getEffectiveIndexIntervalAfterIndex(int) - Method in class org.apache.cassandra.io.sstable.indexsummary.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).
- 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.
- getElement(ByteBuffer, int) - Method in class org.apache.cassandra.serializers.ListSerializer
- getElement(V, ValueAccessor<V>, int) - Method in class org.apache.cassandra.serializers.ListSerializer
-
Returns the element at the given index in a list.
- 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
- getElementCount(T) - Method in class org.apache.cassandra.serializers.CollectionSerializer
- 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
- getElements() - Method in class org.apache.cassandra.cql3.Vectors.Value
- getElementsType() - Method in class org.apache.cassandra.db.marshal.ListType
- getElementsType() - Method in class org.apache.cassandra.db.marshal.SetType
- getElementsType() - Method in class org.apache.cassandra.db.marshal.VectorType
- getEnabled() - Method in class org.apache.cassandra.config.EncryptionOptions
-
Indicates if the channel should be encrypted.
- getEnableDcLocalCommit() - Static method in class org.apache.cassandra.service.paxos.PaxosCommit
- 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
- getEncryptionContext() - Method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
- getEncryptor() - Method in class org.apache.cassandra.security.EncryptionContext
- getEncryptor(String, String) - Method in class org.apache.cassandra.security.CipherFactory
- getEndInSummary(int) - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummary
- getEndIpAddress() - Method in class org.apache.cassandra.cql3.CIDR
-
Get ending IP of the CIDR
- getEndpoint() - Method in class org.apache.cassandra.tools.NodeProbe
- getEndpoint(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
- getEndpointCount() - 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
- getEndpointDowntime(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
- 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
- getEndpointStateForEndpoint(InetAddressAndPort) - Method in interface org.apache.cassandra.gms.IGossiper
- 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.See CASSANDRA-7544
- 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
- getEnforceNativeDeadlineForHints() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getEnforceNativeDeadlineForHints() - Method in class org.apache.cassandra.service.StorageService
- getEnforceNativeDeadlineForHints() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getEntireSSTableInterDCRateLimiterRateInBytes() - Static method in class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
- getEntireSSTableInterDCStreamThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
- getEntireSSTableInterDCStreamThroughputMebibytesPerSecAsDouble() - Method in class org.apache.cassandra.service.StorageService
- getEntireSSTableInterDCStreamThroughputMebibytesPerSecAsDouble() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getEntireSSTableInterDCStreamThroughputOutboundBytesPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getEntireSSTableInterDCStreamThroughputOutboundMebibytesPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getEntireSSTableRateLimiter(InetAddressAndPort) - Static method in class org.apache.cassandra.streaming.StreamManager
-
Get streaming rate limiter for entire SSTable operations.
- getEntireSSTableRateLimiterRateInBytes() - Static method in class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
- getEntireSSTableStreamThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
- getEntireSSTableStreamThroughputMebibytesPerSecAsDouble() - Method in class org.apache.cassandra.service.StorageService
- getEntireSSTableStreamThroughputMebibytesPerSecAsDouble() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getEntireSSTableStreamThroughputOutboundBytesPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getEntireSSTableStreamThroughputOutboundMebibytesPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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
- getEnum(boolean, Class<T>) - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
-
Gets the value of a system property as an enum, optionally calling
String.toUpperCase()
first. - getEnum(boolean, T) - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
-
Gets the value of a system property as a enum, optionally calling
String.toUpperCase()
first. - getEnum(T) - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
-
Gets the value of a system property as a enum, calling
String.toUpperCase()
first. - getError() - Method in class org.apache.cassandra.tools.BootstrapMonitor
- 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(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- getEstimatedDroppableTombstoneRatio(long) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
- getEstimatedKeyCount() - Method in class org.apache.cassandra.io.sstable.indexsummary.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.SortedTableWriter
- getEstimatedOnDiskBytesWritten() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
Returns the amount of data already written to disk that may not be accurate (for example, the position after the recently flushed chunk).
- 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.AbstractStrategyHolder
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
- getEstimatedRemainingTasks() - Method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- getEstimatedRemainingTasks(int, long, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
- 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 interface org.apache.cassandra.index.Index.QueryPlan
-
Return an estimate of the number of results this plan is expected to return for any given
ReadCommand
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.sai.plan.StorageAttachedIndexQueryPlan
- getEstimatedResultRows() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- getEstimatedResultRows() - Method in class org.apache.cassandra.index.sasi.SASIIndex
- getEstimatedResultRows() - Method in class org.apache.cassandra.index.SingletonIndexQueryPlan
- getEstimatedResultRows() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- getEstimatedSize() - Method in class org.apache.cassandra.auth.AuthCache
- getEstimatedSize() - Method in interface org.apache.cassandra.auth.AuthCacheMBean
- 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.ArrayLiteral
- 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.WithArrayLiteral
- 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.WithTypeHint
- getExactTypeIfKnown(String) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithVector
- 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.cql3.Vectors.Literal
- getExactTypeIfKnown(String) - Method in class org.apache.cassandra.schema.ColumnMetadata
- getExactVectorTypeIfKnown(List<T>, Function<T, AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.Vectors
-
Returns the exact VectorType from the items if it can be known.
- getExceptionCount() - Method in class org.apache.cassandra.tools.NodeProbe
- getExcludedKeyspaces(Map<String, Object>) - Method in class org.apache.cassandra.service.DataResurrectionCheck
- getExcludedTables(Map<String, Object>) - Method in class org.apache.cassandra.service.DataResurrectionCheck
- 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.
- getExpectedWriteSize() - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
- getExpectedWriteSize() - Method in class org.apache.cassandra.db.compaction.writers.MajorLeveledCompactionWriter
- getExpectedWriteSize() - Method in class org.apache.cassandra.db.compaction.writers.MaxSSTableSizeWriter
- getExpectedWriteSize() - Method in class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
- getExpiredSSTableCheckFrequency() - Method in class org.apache.cassandra.db.compaction.unified.Controller
- getExpiresAt() - Method in class org.apache.cassandra.service.snapshot.SnapshotManifest
- getExpiresAt() - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
- getExpireTimeForEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
- getExpiringSnapshots() - Method in class org.apache.cassandra.service.snapshot.SnapshotManager
- getExpressions() - Method in class org.apache.cassandra.db.filter.RowFilter
- getExpressions() - Method in class org.apache.cassandra.index.sasi.plan.QueryController
- getFactories() - Method in class org.apache.cassandra.cql3.functions.NativeFunctions
- getFactories(FunctionName) - Method in class org.apache.cassandra.cql3.functions.NativeFunctions
-
Returns all the registered functions factories with the specified name.
- getFailedHosts() - Method in class org.apache.cassandra.io.sstable.SSTableLoader
- getFailureCause() - Method in interface org.apache.cassandra.repair.state.Completable
- getFailureDetectorPhilValues(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
- getFailureReason() - Method in class org.apache.cassandra.streaming.SessionInfo
- getFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.filter.BloomFilterTracker
- getFanout(int) - Method in class org.apache.cassandra.db.compaction.unified.Controller
- getfd(FileDescriptor) - Static method in class org.apache.cassandra.utils.NativeLibrary
-
Get system file descriptor from FileDescriptor object.
- getfd(FileChannel) - Static method in class org.apache.cassandra.utils.NativeLibrary
- getField(Class<?>, String) - Static method in class org.apache.cassandra.utils.ReflectionUtils
- getFieldsPerUDTFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getFieldsPerUDTFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getFieldsPerUDTFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getFieldsPerUDTFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getFieldsPerUDTWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getFieldsPerUDTWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getFieldsPerUDTWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getFieldsPerUDTWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getFieldValue(Object, Field) - Static method in class org.apache.cassandra.utils.concurrent.Ref
- getFifteenMinuteRate() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxMeterMBean
- getFifteenMinuteRate() - Method in class org.apache.cassandra.metrics.LatencyMetrics.LatencyMetricsTimer
- getFile() - Method in class org.apache.cassandra.index.sai.disk.io.IndexOutputWriter
- getFile() - Method in class org.apache.cassandra.io.util.SequentialWriter
- getFileCacheEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getFileCacheRoundUp() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getFileCacheSizeInMiB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getFileDataInput(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Create a
FileDataInput
for the data file of the sstable represented by this reader. - 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.db.compaction.unified.ShardedMultiWriter
- getFilename() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- getFilename() - Method in class org.apache.cassandra.io.sstable.RangeAwareSSTableWriter
- 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.index.sai.disk.io.IndexInputReader
- getFilePointer() - Method in class org.apache.cassandra.index.sai.disk.io.IndexOutputWriter
- getFilePointer() - Method in class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- getFilePointer() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.PostingsWriter
- getFilePointer() - Method in class org.apache.cassandra.index.sai.disk.v1.trie.TrieTermsDictionaryWriter
- getFilePointer() - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter
- getFilePointer() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
Returns a position in the uncompressed data - for uncompressed files it is the same as
SSTableWriter.getOnDiskFilePointer()
but for compressed files it returns a position in the data rather than a position in the file on disk. - 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() - Method in class org.apache.cassandra.service.snapshot.SnapshotManifest
- 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(File) - Static method in class org.apache.cassandra.db.Directories
-
Gets the filestore for the actual directory where the sstables are stored.
- getFilter() - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderWithFilter.Builder
- getFilter(long, double) - Static method in class org.apache.cassandra.utils.FilterFactory
- getFilter(long, int) - Static method in class org.apache.cassandra.utils.FilterFactory
- getFilterCopy() - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter.AbstractIndexWriter
- getFilteredCommonRanges() - Method in class org.apache.cassandra.repair.state.CoordinatorState
- getFilteredCurrentToken() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
- getFilterOffHeapSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderWithFilter
- getFilterSerializedSize() - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderWithFilter
- getFilterTracker() - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderWithFilter
- getFinalCommitLogUpperBound() - Method in class org.apache.cassandra.db.memtable.AbstractMemtableWithCommitlog
- getFinalCommitLogUpperBound() - Method in interface org.apache.cassandra.db.memtable.Memtable
-
The commit log position at the time that this memtable was switched out
- getFinalSessionRepairedAt(TimeUUID) - 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
- getFirst() - Method in interface org.apache.cassandra.index.Index.QueryPlan
-
Returns the first index in this plan.
- getFirst() - Method in class org.apache.cassandra.index.SingletonIndexQueryPlan
- getFirst() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- getFirst() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- getFirst() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
- getFirst() - Method in class org.apache.cassandra.io.sstable.SSTable
- getFirst() - Method in class org.apache.cassandra.io.sstable.SSTableZeroCopyWriter
- 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
- getFixedLength(ValueAccessor<V>, ByteSource, int) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
Consume the next length bytes from the source unchanged.
- getFlags() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
- getFloat(byte[], int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- getFloat(byte[], int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- getFloat(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a float. - getFloat(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
as a float. - getFloat(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
-
Returns the value for
name
as a float. - getFloat(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- getFloat(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- getFloat(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- getFlushBeforeTransfer() - Method in class org.apache.cassandra.streaming.StreamPlan
- getFlushCompression() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getFlushObserver(Descriptor, LifecycleNewTracker) - 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, LifecycleNewTracker) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- getFlushObserver(Descriptor, LifecycleNewTracker) - Method in class org.apache.cassandra.index.sasi.SASIIndex
- getFlushObserver(Descriptor, LifecycleNewTracker, TableMetadata) - Method in interface org.apache.cassandra.index.Index.Group
-
Get flush observer to observe partition/cell events generated by flushing SSTable (memtable flush or compaction).
- getFlushObserver(Descriptor, LifecycleNewTracker, TableMetadata) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- getFlushObserver(Descriptor, LifecycleNewTracker, TableMetadata) - Method in class org.apache.cassandra.index.SingletonIndexGroup
- getFlushSet(PartitionPosition, PartitionPosition) - Method in interface org.apache.cassandra.db.memtable.Memtable
-
Get the collection of data between the given partition boundaries in a form suitable for flushing.
- getFlushSet(PartitionPosition, PartitionPosition) - Method in class org.apache.cassandra.db.memtable.ShardedSkipListMemtable
- getFlushSet(PartitionPosition, PartitionPosition) - Method in class org.apache.cassandra.db.memtable.SkipListMemtable
- getFlushSet(PartitionPosition, PartitionPosition) - Method in class org.apache.cassandra.db.memtable.TrieMemtable
- getFlushSizeBytes() - Method in class org.apache.cassandra.db.compaction.unified.Controller
-
Return the flush sstable size in bytes.
- getFlushTransaction() - Method in class org.apache.cassandra.db.memtable.AbstractMemtable
- getFlushTransaction() - Method in interface org.apache.cassandra.db.memtable.Memtable
- 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
- getForceNewPreparedStatementBehaviour() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getForEndpoint(InetAddressAndPort, ApplicationState) - Method in class org.apache.cassandra.gms.Gossiper
- getFormat() - Method in class org.apache.cassandra.io.sstable.Descriptor
- getFormatSpecificMetricsProviders() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- getFormatSpecificMetricsProviders() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- getFormatSpecificMetricsProviders() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
- 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
- getFsOwnershipFilename(Map<String, Object>) - Method in class org.apache.cassandra.service.FileSystemOwnershipCheck
- 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>, long) - Static method in class org.apache.cassandra.db.compaction.CompactionController
- getFullyExpiredSSTables(ColumnFamilyStore, Iterable<SSTableReader>, Iterable<SSTableReader>, long, boolean) - Static method in class org.apache.cassandra.db.compaction.CompactionController
-
Finds expired sstables works something like this; 1.
- getFunction() - Method in interface org.apache.cassandra.cql3.functions.PartialScalarFunction
-
Returns the original function.
- getFunctionName() - Method in class org.apache.cassandra.auth.FunctionResource
- getFunctionName(CQL3Type) - Static method in class org.apache.cassandra.cql3.functions.CastFcts
-
Creates the snake-cased name of the cast function used 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.functions.NativeFunctions
- 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.cql3.functions.NativeFunctions
-
Returns all the registered pre-built functions overloads with the specified name.
- getGaugeProviders() - Method in class org.apache.cassandra.io.sstable.filter.BloomFilterMetrics
- getGaugeProviders() - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryMetrics
- getGaugeProviders() - Method in class org.apache.cassandra.io.sstable.keycache.KeyCacheMetrics
- getGaugeProviders() - Method in interface org.apache.cassandra.io.sstable.MetricsProviders
- 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
- getGeneration() - Method in class org.apache.cassandra.gms.HeartBeatState
- getGitSHA() - Method in class org.apache.cassandra.service.StorageService
- getGitSHA() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch a string representation of the Cassandra git SHA.
- getGitSHA() - Method in class org.apache.cassandra.tools.NodeProbe
- getGitSHA() - Static method in class org.apache.cassandra.utils.FBUtilities
- getGlobalGauge() - Method in class org.apache.cassandra.io.sstable.GaugeProvider
- getGlobalGauge() - Method in class org.apache.cassandra.io.sstable.SimpleGaugeProvider
- getGlobalLimit() - Static method in class org.apache.cassandra.transport.ClientResourceLimits
- getGossipInfo(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
- getGossipInfo(boolean, boolean) - Method in class org.apache.cassandra.tools.NodeProbe
- getGossipMessageCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Deprecated.See CASSANDRA-7544
- 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.See CASSANDRA-7544
- 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.See CASSANDRA-7544
- 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
- getGossipStatus(EndpointState) - Static method in class org.apache.cassandra.gms.Gossiper
- getGossProxy() - Method in class org.apache.cassandra.tools.NodeProbe
- getGroup() - Method in class org.apache.cassandra.db.CassandraWriteContext
- getGroup() - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry.MetricName
-
Returns the group to which the
Metric
belongs. - getGroup(int) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder.GroupedSSTableContainer
- getGroupByEnabled() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getGroupByEnabled() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getGroupByEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Returns whether GROUP BY functionality is allowed
- getGroupByEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Returns whether GROUP BY queries are allowed.
- getGuardrailsConfig() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getHashBuckets(IFilter.FilterKey, int, long) - Method in class org.apache.cassandra.utils.BloomFilter
- getHashedPassword() - Method in class org.apache.cassandra.auth.RoleOptions
-
Return the string value of the hashed password option.
- getHeader(TableMetadata) - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader
- getHeaderLength() - Method in class org.apache.cassandra.io.sstable.format.SortedTablePartitionWriter
- getHeapDumpPath() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
As this is at its heart a debug operation (getting a one-shot heapdump from an uncaught exception), we support both the more evolved cassandra.yaml approach but also the -XX param to override it on a one-off basis so you don't have to change the full config of a node or a cluster in order to get a heap dump from a single node that's misbehaving.
- 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
- getHeartBeatState() - Method in class org.apache.cassandra.gms.EndpointState
- getHeartBeatVersion() - Method in class org.apache.cassandra.gms.HeartBeatState
- getHighBallot(Row, Ballot) - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosRows
- getHighBound() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosBallotTracker
- 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
- getHintedHandoffThrottleInKiB() - 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
- getHistory() - Method in class org.apache.cassandra.service.paxos.TablePaxosRepairHistory
- getHistoryForRanges(Collection<Range<Token>>) - Method in class org.apache.cassandra.service.paxos.TablePaxosRepairHistory
- getHits() - Method in class org.apache.cassandra.io.sstable.keycache.KeyCache
- 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) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Return the unique host ID for an end-point.
- getHostId(InetAddressAndPort, Map<InetAddressAndPort, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
- getHostIdForEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.service.StorageService
- getHostIdMap() - Method in class org.apache.cassandra.service.StorageService
- 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.See CASSANDRA-7544
- getHostIdToEndpointWithPort() - Method in class org.apache.cassandra.service.StorageService
- getHostIdToEndpointWithPort() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getHostIdToEndpointWithPort() - Method in class org.apache.cassandra.tools.NodeProbe
- getHostName(boolean) - Method in class org.apache.cassandra.locator.InetAddressAndPort
- 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() - Method in class org.apache.cassandra.repair.state.AbstractCompletable
- getId() - Method in interface org.apache.cassandra.repair.state.Completable
- getId() - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
-
Unique identifier of a snapshot.
- 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(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.
- 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(TableId) - Method in class org.apache.cassandra.db.Keyspace
- getIfExists(TableMetadata) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
Returns a ColumnFamilyStore by metadata if it exists, null otherwise Differently from others, this method does not throw exception if the table does not exist.
- getIfPresent(K) - Method in class org.apache.cassandra.locator.ReplicaMultimap.Builder
- getIfReady(K) - Method in class org.apache.cassandra.utils.concurrent.LoadingMap
-
Get a value for a given key.
- getIgnoreOverlapsInExpirationCheck() - Method in class org.apache.cassandra.db.compaction.unified.Controller
- getIncoming() - Method in class org.apache.cassandra.repair.asymmetric.IncomingRepairStreamTracker
- getIndex() - Method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy.Level
- getIndex() - Method in class org.apache.cassandra.index.sai.plan.Expression
- getIndex() - Method in class org.apache.cassandra.index.sai.plan.Expression.IndexedExpression
- getIndex() - Method in class org.apache.cassandra.index.sai.plan.Expression.UnindexedExpression
- getIndex() - Method in class org.apache.cassandra.index.sasi.SASIIndex
- getIndex() - Method in class org.apache.cassandra.index.SingletonIndexGroup
- getIndex(RowFilter.Expression) - Method in class org.apache.cassandra.index.sasi.plan.QueryController
- getIndex(ColumnMetadata) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
- getIndex(IndexMetadata) - Method in interface org.apache.cassandra.index.IndexRegistry
- 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>, boolean) - Method in class org.apache.cassandra.index.Index.CollatedViewIndexBuildingSupport
- getIndexBuildTask(ColumnFamilyStore, Set<Index>, Collection<SSTableReader>, boolean) - 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
- getIndexClassName() - Method in class org.apache.cassandra.schema.IndexMetadata
- getIndexComparator() - Method in class org.apache.cassandra.index.internal.CassandraIndex
- getIndexedColumn() - Method in class org.apache.cassandra.index.internal.CassandraIndex
- getIndexedPartitionKeyType(ColumnMetadata) - Method in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
- 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 interface org.apache.cassandra.index.Index.Group
-
Returns the indexes that are members of this group.
- getIndexes() - Method in interface org.apache.cassandra.index.Index.QueryPlan
-
Returns the indexes selected by this query plan, all of them belonging to the same
Index.Group
. - getIndexes() - Method in class org.apache.cassandra.index.sai.plan.StorageAttachedIndexQueryPlan
- getIndexes() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- getIndexes() - Method in class org.apache.cassandra.index.sai.view.View
- getIndexes() - Method in class org.apache.cassandra.index.sasi.conf.view.View
- getIndexes() - Method in class org.apache.cassandra.index.SingletonIndexGroup
- getIndexes() - Method in class org.apache.cassandra.index.SingletonIndexQueryPlan
- 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
- getIndexesRangeFromSerialized(ByteBuffer, ByteBuffer, ByteBuffer, AbstractType<?>) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
Returns the range of indexes corresponding to the specified range of elements in the serialized collection.
- getIndexesRangeFromSerialized(ByteBuffer, ByteBuffer, ByteBuffer, AbstractType<?>) - Method in class org.apache.cassandra.serializers.ListSerializer
- getIndexFile() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader.Builder
- getIndexFile() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- getIndexForSSTable(SSTableReader) - Method in interface org.apache.cassandra.db.compaction.AbstractStrategyHolder.DestinationRouter
- getIndexForSSTableDirectory(Descriptor) - Method in interface org.apache.cassandra.db.compaction.AbstractStrategyHolder.DestinationRouter
- getIndexFromBinarySearchResult(int) - Static method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummary
- getIndexFromSerialized(ByteBuffer, ByteBuffer, AbstractType<?>) - Method in class org.apache.cassandra.serializers.CollectionSerializer
-
Returns the index of an element in a serialized collection.
- getIndexFromSerialized(ByteBuffer, ByteBuffer, AbstractType<?>) - Method in class org.apache.cassandra.serializers.ListSerializer
- getIndexGroup(ColumnFamilyStore) - Static method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- getIndexGroup(Index) - Method in class org.apache.cassandra.index.SecondaryIndexManager
- getIndexGroup(Index.Group.Key) - Method in class org.apache.cassandra.index.SecondaryIndexManager
- getIndexGroup(IndexMetadata) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Returns the
Index.Group
the specified index belongs to, as specified during registering withSecondaryIndexManager.registerIndex(Index, Index.Group.Key, Supplier)
. - getIndexGroups() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- getIndexIdentifier() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
- getIndexIntervals() - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryManager
- getIndexIntervals() - Method in interface org.apache.cassandra.io.sstable.indexsummary.IndexSummaryManagerMBean
-
Returns a map of SSTable filenames to their current effective index interval.
- getIndexMemtables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getIndexMemtables() - Method in interface org.apache.cassandra.db.memtable.Memtable.Owner
-
Collect the index memtables flushed together with this.
- 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.sai.StorageAttachedIndex
- getIndexMetadata() - Method in class org.apache.cassandra.index.sasi.SASIIndex
- getIndexMetadata() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- getIndexName() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
- getIndexName(String) - Static method in class org.apache.cassandra.index.SecondaryIndexManager
-
Returns the index name
- getIndexName(ColumnFamilyStore) - 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.
- getIndexOperator() - Method in class org.apache.cassandra.index.sai.plan.Expression
- getIndexPath() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
- getIndexQueryResults(Collection<Expression>) - Method in class org.apache.cassandra.index.sai.plan.QueryController
-
Build a
KeyRangeIterator.Builder
from the given list ofExpression
s. - getIndexRestrictions() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
- getIndexStatus(InetAddressAndPort, String, String) - Method in class org.apache.cassandra.index.IndexStatusManager
- getIndexSummary() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader.Builder
- getIndexSummary() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- getIndexSummary() - Method in interface org.apache.cassandra.io.sstable.indexsummary.IndexSummarySupport
- getIndexSummaryCapacityInMiB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getIndexSummaryResizeIntervalInMinutes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getIndexTableMetadataRef(String, String) - Method in class org.apache.cassandra.schema.Schema
- getIndexTermType() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
- getIndexTermType() - Method in class org.apache.cassandra.index.sai.plan.Expression
- 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(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as an InetAddress. - getInet(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
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
- 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.sai.StorageAttachedIndex
- getInitializationTask() - Method in class org.apache.cassandra.index.sasi.SASIIndex
- getInitializationTask() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- getInitializedAtMillis() - Method in class org.apache.cassandra.repair.state.AbstractCompletable
- getInitializedAtMillis() - Method in interface org.apache.cassandra.repair.state.Completable
- getInitializedAtNanos() - Method in class org.apache.cassandra.repair.state.AbstractCompletable
- getInitializedAtNanos() - Method in interface org.apache.cassandra.repair.state.Completable
- getInitialPosition() - Method in class org.apache.cassandra.io.sstable.format.SortedTablePartitionWriter
- 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
- getInitiatorStream(TimeUUID) - Method in class org.apache.cassandra.streaming.StreamManager
- getInputStream(File, File) - Method in interface org.apache.cassandra.cache.AutoSavingCache.IStreamFactory
- getInSelectCartesianProductFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getInSelectCartesianProductFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getInSelectCartesianProductFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getInSelectCartesianProductFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getInSelectCartesianProductWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getInSelectCartesianProductWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getInSelectCartesianProductWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getInSelectCartesianProductWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getInstance() - Static method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- getInstance(Iterable<AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.CompositeType
- getInstance(String) - Static method in class org.apache.cassandra.cql3.CIDR
-
Generates a CIDR from given string
- getInstance(String, List<AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.functions.ToJsonFct
- getInstance(List<AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.CompositeType
- getInstance(Map<Byte, AbstractType<?>>) - Static method in class org.apache.cassandra.db.marshal.DynamicCompositeType
- getInstance(Map<String, String>) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat.BigFormatFactory
- getInstance(Map<String, String>) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat.BtiFormatFactory
- getInstance(Map<String, String>) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat.Factory
-
Returns an instance of the sstable format configured with the provided options.
- getInstance(FunctionName, AbstractType<?>) - Static method in class org.apache.cassandra.cql3.functions.FromJsonFct
- getInstance(AbstractType...) - Static method in class org.apache.cassandra.db.marshal.CompositeType
- getInstance(AbstractType<K>, AbstractType<V>, boolean) - Static method in class org.apache.cassandra.db.marshal.MapType
- getInstance(AbstractType<T>) - Static method in class org.apache.cassandra.db.marshal.ReversedType
- getInstance(AbstractType<T>, boolean) - Static method in class org.apache.cassandra.db.marshal.ListType
- getInstance(AbstractType<T>, boolean) - Static method in class org.apache.cassandra.db.marshal.SetType
- getInstance(AbstractType<T>, int) - Static method in class org.apache.cassandra.db.marshal.VectorType
- getInstance(TypeParser) - Static method in class org.apache.cassandra.db.marshal.CompositeType
- getInstance(TypeParser) - 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(TypeParser) - 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(TypeParser) - 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(TypeParser) - Static method in class org.apache.cassandra.db.marshal.VectorType
- getInstance(TypeSerializer<K>, TypeSerializer<V>, ValueComparators) - Static method in class org.apache.cassandra.serializers.MapSerializer
- getInstance(TypeSerializer<T>) - Static method in class org.apache.cassandra.serializers.ListSerializer
- 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() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
- getInt(byte[]) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- getInt(byte[], int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- getInt(byte[], int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- getInt(int) - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
-
Gets the value of a system property as an int.
- getInt(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as an integer. - getInt(long) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
- getInt(long) - Method in class org.apache.cassandra.io.util.Memory
- getInt(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
- getInt(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
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) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
- getInt(String, int) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
- getInt(String, int) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
- 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 {@param offset}
- getIntByByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
- getInterDCRateLimiterRateInBytes() - Static method in class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
- getInterDCStreamThroughput() - Method in class org.apache.cassandra.tools.NodeProbe
-
Deprecated.See CASSANDRA-17225
- GetInterDCStreamThroughput - Class in org.apache.cassandra.tools.nodetool
- GetInterDCStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.GetInterDCStreamThroughput
- getInterDCStreamThroughputAsDouble() - Method in class org.apache.cassandra.tools.NodeProbe
- getInterDCStreamThroughputMbitPerSec() - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-17225
- getInterDCStreamThroughputMbitPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.Use getInterDCStreamThroughputMbitPerSecAsDouble instead as this one will provide a rounded value. See CASSANDRA-17225
- getInterDCStreamThroughputMbitPerSecAsDouble() - Method in class org.apache.cassandra.service.StorageService
- getInterDCStreamThroughputMbitPerSecAsDouble() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getInterDCStreamThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-15234
- getInterDCStreamThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.Use getInterDCStreamThroughputMebibytesPerSecAsDouble instead as this one will provide a rounded value. See CASSANDRA-15234
- getInterDCStreamThroughputMebibytesPerSec() - Method in class org.apache.cassandra.service.StorageService
- getInterDCStreamThroughputMebibytesPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Below method returns Inter_dc_stream_throughput_outbound rounded, for precise number, please, use getInterDCStreamThroughputMebibytesPerSecAsDouble
- getInterDCStreamThroughputMebibytesPerSecAsDouble() - Method in class org.apache.cassandra.service.StorageService
- getInterDCStreamThroughputMebibytesPerSecAsDouble() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getInterDCStreamThroughputMibAsDouble() - Method in class org.apache.cassandra.tools.NodeProbe
- getInterDCStreamThroughputOutboundBytesPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getInterDCStreamThroughputOutboundMebibytesPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getInterDCStreamThroughputOutboundMebibytesPerSecAsInt() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getInterDCStreamThroughputOutboundMegabitsPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getInterDCStreamThroughputOutboundMegabitsPerSecAsDouble() - 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(String, boolean) - Static method in class org.apache.cassandra.cql3.ColumnIdentifier
- getInterned(ByteBuffer, AbstractType<?>) - 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
- getInternodeErrorReportingExclusions() - 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
- getIntersectFilteringQueryEnabled() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getIntersectFilteringQueryEnabled() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getIntersectFilteringQueryEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getIntersectFilteringQueryEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getIntersectFilteringQueryWarned() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getIntersectFilteringQueryWarned() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getIntersectFilteringQueryWarned() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getIntersectFilteringQueryWarned() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getIntervalNanos() - Method in class org.apache.cassandra.utils.concurrent.NonBlockingRateLimiter
- 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.sai.StorageAttachedIndex
- getInvalidateTask() - Method in class org.apache.cassandra.index.sasi.SASIIndex
- getInvalidateTask() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- 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
- getIOOptions() - Method in class org.apache.cassandra.io.sstable.SSTable.Builder
- getIpCacheMaxSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getIPTypeString(boolean) - Method in interface org.apache.cassandra.auth.CIDRGroupsMappingTable
- getIsTransient(Set<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
- getItemsPerCollectionFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getItemsPerCollectionFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getItemsPerCollectionFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getItemsPerCollectionFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getItemsPerCollectionWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getItemsPerCollectionWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getItemsPerCollectionWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getItemsPerCollectionWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- 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.
- getJavaTypeName() - Method in class org.apache.cassandra.cql3.functions.UDFDataType
- getJob(UUID) - Method in class org.apache.cassandra.repair.state.SessionState
- getJobIds() - Method in class org.apache.cassandra.repair.state.SessionState
- getJobs() - Method in class org.apache.cassandra.repair.state.SessionState
- getJobThreads() - Method in class org.apache.cassandra.repair.messages.RepairOption
- getJoiningNodes() - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-7544
- getJoiningNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-7544
- 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 indexbindIndex
. - 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.
- getKernelVersion() - Static method in class org.apache.cassandra.utils.FBUtilities
- 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() - Method in class org.apache.cassandra.service.FailureRecordingCallback.FailureResponses
- getKey() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosKeyState
- getKey() - Method in interface org.apache.cassandra.service.paxos.uncommitted.UncommittedPaxosKey
- getKey() - Method in class org.apache.cassandra.service.reads.AbstractReadExecutor
- getKey(int) - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummary
- getKeyCache() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader.Builder
- getKeyCache() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- getKeyCache() - Method in interface org.apache.cassandra.io.sstable.keycache.KeyCacheSupport
- 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
- 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
- getKeyCacheSizeInMiB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getKeyCacheValueSerializer() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- getKeyCacheValueSerializer() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- getKeyCacheValueSerializer() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
- getKeyCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- getKeyFromPartition(String, String, String) - Method in class org.apache.cassandra.service.StorageService
- getKeyLength() - Method in class org.apache.cassandra.db.BufferDecoratedKey
- getKeyLength() - Method in class org.apache.cassandra.db.DecoratedKey
- getKeyLength() - Method in class org.apache.cassandra.db.NativeDecoratedKey
- getKeySamples(Range<Token>) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- getKeySamples(Range<Token>) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- getKeySamples(Range<Token>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns sample keys for the provided token range.
- getKeySamples(Range<Token>) - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummary
- 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
-
Deprecated.See CASSANDRA-17195
- getKeyspaceCountWarnThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-17195
- getKeyspaceGauge(Keyspace) - Method in class org.apache.cassandra.io.sstable.GaugeProvider
- getKeyspaceGauge(Keyspace) - Method in class org.apache.cassandra.io.sstable.SimpleGaugeProvider
- 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.ColumnFamilyStore
- 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
- getKeyspaceName() - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
- 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.DistributedSchema
- 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
- getKeyspacesFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getKeyspacesFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getKeyspacesFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getKeyspacesFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getKeyspacesWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getKeyspacesWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getKeyspacesWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getKeyspacesWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- 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.See CASSANDRA-7544
- 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.See CASSANDRA-7544
- 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.See CASSANDRA-7544
- 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
- getLast() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- getLast() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- getLast() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
- getLast() - Method in class org.apache.cassandra.io.sstable.SSTable
- getLast() - Method in class org.apache.cassandra.io.sstable.SSTableZeroCopyWriter
- 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
- getLastIndexPosition() - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex.Reader
- getLastReadableBoundary() - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryBuilder
- getLastReturned() - Method in class org.apache.cassandra.db.DataRange.Paging
- getLastTimestampMicros() - Static method in class org.apache.cassandra.service.ClientState
- getLastUpdate() - Method in class org.apache.cassandra.repair.consistent.LocalSession
- getLastUpdatedAtMillis() - Method in class org.apache.cassandra.repair.state.AbstractCompletable
- getLastUpdatedAtMillis() - Method in interface org.apache.cassandra.repair.state.Completable
- getLastUpdatedAtNanos() - Method in class org.apache.cassandra.repair.state.AbstractCompletable
- getLastUpdatedAtNanos() - Method in interface org.apache.cassandra.repair.state.Completable
- getLatenciesMetricsFromVtable() - Method in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable
- getLatenciesMetricsFromVtable() - Method in interface org.apache.cassandra.db.virtual.CIDRFilteringMetricsTableMBean
-
Retreive rows from CIDR filtering latency metrics virtual table
- getLatenciesMetricsFromVtable() - Method in class org.apache.cassandra.tools.NodeProbe
- getLatestVersion() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- getLatestVersion() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- 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.See CASSANDRA-7544
- getLeavingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-7544
- 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.io.util.DataOutputBuffer
- getLengthInBytes() - Method in class org.apache.cassandra.io.sstable.EmptySSTableScanner
- getLengthInBytes() - Method in class org.apache.cassandra.io.sstable.format.SSTableScanner
- 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
- getLevels(Collection<SSTableReader>, Predicate<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
-
Groups the sstables passed in into levels.
- 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(int, TypeToken<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a list. - getList(int, Class<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value 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(String, TypeToken<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
-
Returns the value for
name
as a list. - getList(String, Class<T>) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
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, AbstractType<T>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
- getListenAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getLiveComponents(SSTableReader, Collection<StorageAttachedIndex>) - Static method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- getLiveDataSize() - Method in interface org.apache.cassandra.db.memtable.Memtable
-
Size of the data not accounting for any metadata / mapping overheads
- getLiveDataSize() - Method in class org.apache.cassandra.db.memtable.ShardedSkipListMemtable
-
Technically we should scatter gather on all the core threads because the size in following calls are not using volatile variables, but for metrics purpose this should be good enough.
- getLiveDataSize() - Method in class org.apache.cassandra.db.memtable.SkipListMemtable
- getLiveDataSize() - Method in class org.apache.cassandra.db.memtable.TrieMemtable
-
Technically we should scatter gather on all the core threads because the size in following calls are not using volatile variables, but for metrics purpose this should be good enough.
- getLiveMembers() - Method in class org.apache.cassandra.gms.Gossiper
- getLiveNodes() - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-7544
- getLiveNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-7544
- 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
- getLivePerIndexComponents(IndexTermType, IndexIdentifier) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- getLivePerSSTableComponents() - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- 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
- getLoadAttempts() - Method in class org.apache.cassandra.schema.PartitionDenylist
- 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.See CASSANDRA-7544
- 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
- getLoadSuccesses() - Method in class org.apache.cassandra.schema.PartitionDenylist
- 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
- getLocalAndReplicatedSystemKeyspaceNames() - Static method in class org.apache.cassandra.schema.SchemaConstants
-
Returns the set of local and replicated system keyspace names
- getLocalAndReplicatedSystemTableNames() - Static method in class org.apache.cassandra.schema.SchemaConstants
-
Returns the set of all local and replicated system table names
- 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() - Method in interface org.apache.cassandra.locator.IEndpointSnitch
-
returns a String representing the datacenter current endpoint belongs to
- getLocalDataCenter() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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
- getLocalKeyspaces() - Method in class org.apache.cassandra.schema.Schema
- getLocalPrimaryRange() - Method in class org.apache.cassandra.service.StorageService
- 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
- getLocalRanges(String) - Method in class org.apache.cassandra.service.StorageService
- getLocalReadSizeFailThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getLocalReadSizeWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getLocalReadTooLargeAbortThreshold() - Method in class org.apache.cassandra.service.StorageService
- getLocalReadTooLargeAbortThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getLocalReadTooLargeWarnThreshold() - Method in class org.apache.cassandra.service.StorageService
- getLocalReadTooLargeWarnThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- 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.
- 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() - 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
- GetLoggingLevels - Class in org.apache.cassandra.tools.nodetool
- GetLoggingLevels() - Constructor for class org.apache.cassandra.tools.nodetool.GetLoggingLevels
- 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() - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
-
Gets the value of a system property as a long.
- getLong() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
- getLong(byte[]) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- getLong(byte[], int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- getLong(byte[], int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- getLong(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a long. - getLong(long) - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
-
Gets the value of a system property as a long.
- getLong(long) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
- getLong(long) - Method in class org.apache.cassandra.io.util.Memory
- getLong(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
- getLong(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
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(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 {@param offset}
- getLongByByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
- getLongValue() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
- getLongValue() - Method in class org.apache.cassandra.dht.Token
-
This method exists so that callers can access the primitive
long
value for thisToken
, if one exits. - getLoopbackAddress() - Static method in class org.apache.cassandra.locator.InetAddressAndPort
- getLooseEmptyEnabled() - Method in class org.apache.cassandra.gms.Gossiper
- getLooseEmptyEnabled() - Method in interface org.apache.cassandra.gms.GossiperMBean
- getLowBound() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosBallotTracker
- getLowerBoundPrefixFromCache(DecoratedKey, boolean) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- getLowerBoundPrefixFromCache(DecoratedKey, boolean) - Method in interface org.apache.cassandra.io.sstable.keycache.KeyCacheSupport
-
Should quickly get a lower bound prefix from cache only if everything is already availabe in memory and does not need to be loaded from disk.
- getManagers() - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
- getManifestFile() - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
- getMap(int, TypeToken<K>, TypeToken<V>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a map. - getMap(int, Class<K>, Class<V>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a map. - getMap(String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
- 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(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, Class<K>, Class<V>) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
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, 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
- getMask() - Method in class org.apache.cassandra.schema.ColumnMetadata
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.AbstractType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.AsciiType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.BooleanType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.BytesType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.ByteType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.CounterColumnType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.DateType
-
Deprecated.
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.DecimalType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.DoubleType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.DurationType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.EmptyType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.FloatType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.InetAddressType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.Int32Type
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.IntegerType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.LegacyTimeUUIDType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.ListType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.LongType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.MapType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.ReversedType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.SetType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.ShortType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.SimpleDateType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.TimestampType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.TimeType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.TupleType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.UTF8Type
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.UUIDType
- getMaskedValue() - Method in class org.apache.cassandra.db.marshal.VectorType
- getMaterializedViewsEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getMaterializedViewsPerTableFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getMaterializedViewsPerTableFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getMaterializedViewsPerTableFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getMaterializedViewsPerTableFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getMaterializedViewsPerTableWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getMaterializedViewsPerTableWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getMaterializedViewsPerTableWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getMaterializedViewsPerTableWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getMax() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxHistogramMBean
- getMax() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxTimerMBean
- getMaxAttempts() - Method in class org.apache.cassandra.config.RetrySpec
- 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() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- 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
- getMaxHintsSizePerHost() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getMaxHintsSizePerHostInMiB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getMaxHintsSizePerHostInMiB() - Method in class org.apache.cassandra.service.StorageProxy
- getMaxHintsSizePerHostInMiB() - 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(long, boolean) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
- getMaximalTask(long, boolean) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
- getMaximalTask(long, boolean) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
- getMaximalTask(long, boolean) - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
- getMaximalTask(long, boolean) - Method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- getMaximalTasks(long, boolean) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
- getMaximalTasks(long, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
- getMaximalTasks(long, boolean) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
- getMaximalTasks(long, boolean, OperationType) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
- getMaximum() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator.Builder
- getMaximum() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator
- 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
- getMaximumNodeConnections() - Method in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- 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.ScheduledThreadPoolExecutorPlus
- getMaximumPoolSize() - Method in class org.apache.cassandra.concurrent.SEPExecutor
- getMaximumPoolSize() - Method in class org.apache.cassandra.concurrent.SingleThreadExecutorPlus
- getMaximumPoolSize() - Method in enum org.apache.cassandra.concurrent.Stage
-
Returns maximum pool size of thread pool.
- getMaximumPoolSize() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorJMXAdapter
- getMaximumPoolSize() - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- getMaximumPoolSizes(List<String>) - Method in class org.apache.cassandra.tools.NodeProbe
- getMaximumReplicationFactorFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getMaximumReplicationFactorFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getMaximumReplicationFactorFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getMaximumReplicationFactorFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getMaximumReplicationFactorWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getMaximumReplicationFactorWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getMaximumReplicationFactorWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getMaximumReplicationFactorWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getMaximumSecondaryIndexExecutorThreads() - Method in class org.apache.cassandra.db.compaction.CompactionManager
- getMaximumSecondaryIndexExecutorThreads() - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
- getMaximumThreads() - Method in interface org.apache.cassandra.concurrent.ResizableThreadPoolMXBean
-
Deprecated.use getMaximumThreads instead. See CASSANDRA-15277
- getMaximumThreads() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBase
- getMaximumThreads() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorJMXAdapter
- getMaximumTimestampFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getMaximumTimestampFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getMaximumTimestampFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getMaximumTimestampFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getMaximumTimestampWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getMaximumTimestampWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getMaximumTimestampWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getMaximumTimestampWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- 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
- getMaxKeys() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator
- getMaxLevelDensity(int, double) - Method in class org.apache.cassandra.db.compaction.unified.Controller
- 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.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.
- getMaxPointsInLeafNode() - Method in class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeWriter
- getMaxSizeFile(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getMaxSleepTime() - Method in class org.apache.cassandra.config.RetrySpec
- getMaxSpaceForCompactionsPerDrive() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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.LeveledCompactionStrategy
- getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
- getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
- getMaxSSTableBytes() - Method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- getMaxSSTableDuration() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getMaxSSTableDuration() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Returns the longest duration of an SSTable, in milliseconds, of this table, computed as
maxTimestamp - minTimestamp
. - getMaxSSTableRowId() - Method in class org.apache.cassandra.index.sai.memory.MemtableTermsIterator
- getMaxSSTableSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getMaxSSTableSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Returns the size of the biggest SSTable of this table.
- getMaxTasksQueued() - Method in interface org.apache.cassandra.concurrent.ResizableThreadPool
- getMaxTasksQueued() - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- getMaxTasksQueued() - Method in class org.apache.cassandra.concurrent.SEPExecutor
- getMaxTasksQueued() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorJMXAdapter
- getMaxTasksQueued() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorPlus
- getMaxTasksQueued() - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- getMaxTerm() - Method in class org.apache.cassandra.index.sai.memory.MemoryIndex
- getMaxTerm() - Method in class org.apache.cassandra.index.sai.memory.MemtableIndex
- getMaxTerm() - Method in class org.apache.cassandra.index.sai.memory.MemtableTermsIterator
- getMaxTerm() - Method in class org.apache.cassandra.index.sai.memory.TrieMemoryIndex
- getMaxTerm() - Method in class org.apache.cassandra.index.sai.memory.VectorMemoryIndex
- getMaxTerm() - Method in interface org.apache.cassandra.index.sai.utils.TermsIterator
- getMaxTerm() - Method in class org.apache.cassandra.io.tries.Walker
- 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
- getMaxTopSizePartitionCount() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getMaxTopSizePartitionCount() - Method in class org.apache.cassandra.service.StorageService
- getMaxTopSizePartitionCount() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getMaxTopTombstonePartitionCount() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getMaxTopTombstonePartitionCount() - Method in class org.apache.cassandra.service.StorageService
- getMaxTopTombstonePartitionCount() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- 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. - getMBeanServer() - Method in class org.apache.cassandra.utils.MBeanWrapper.DelegatingMbeanWrapper
- getMBeanServer() - Method in interface org.apache.cassandra.utils.MBeanWrapper
- getMBeanServer() - Method in class org.apache.cassandra.utils.MBeanWrapper.InstanceMBeanWrapper
- getMBeanServer() - Method in class org.apache.cassandra.utils.MBeanWrapper.NoOpMBeanWrapper
- getMBeanServer() - Method in class org.apache.cassandra.utils.MBeanWrapper.PlatformMBeanWrapper
- getMbeanServerConn() - Method in class org.apache.cassandra.tools.NodeProbe
- getMBeanWrapper() - Static method in interface org.apache.cassandra.utils.MBeanWrapper
- 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.indexsummary.IndexSummaryManager
- getMemoryPoolCapacityInMB() - Method in interface org.apache.cassandra.io.sstable.indexsummary.IndexSummaryManagerMBean
- getMemoryPoolSizeInMB() - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryManager
-
Returns the actual space consumed by index summaries for all sstables.
- getMemoryPoolSizeInMB() - Method in interface org.apache.cassandra.io.sstable.indexsummary.IndexSummaryManagerMBean
-
Returns the current actual off-heap memory usage of the index summaries for all non-compacting sstables.
- getMemoryUsage(Memtable) - Static method in interface org.apache.cassandra.db.memtable.Memtable
-
Shorthand for the getting a given table's memory usage.
- getMemtableAllocationType() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getMemtableCleanupThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getMemtableConfigurations() - 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
- getMemtableHeapSpaceInMiB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getMemtableOffheapSpaceInMiB() - 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.
- getMerkleTreeResponseSpec() - Method in class org.apache.cassandra.config.RepairRetrySpec
- 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
- 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.compaction.UnifiedCompactionStrategy
- getMetadata() - Method in class org.apache.cassandra.db.Keyspace
- getMetadataCollector() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- 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.sai.StorageAttachedIndex
- getMetadataReloadTask(IndexMetadata) - Method in class org.apache.cassandra.index.sasi.SASIIndex
- getMetadataReloadTask(IndexMetadata) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- 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.ColumnFamilyStore
- getMetrics() - Method in class org.apache.cassandra.db.compaction.CompactionManager
- getMetrics() - Method in interface org.apache.cassandra.io.sstable.SSTable.Owner
- 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
- getMinFreeSpacePerDriveInMebibytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getMinimum() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator.Builder
- getMinimum() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator
- 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
- getMinimumFlushBytes() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder
- getMinimumReplicationFactorFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getMinimumReplicationFactorFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getMinimumReplicationFactorFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getMinimumReplicationFactorFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getMinimumReplicationFactorWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getMinimumReplicationFactorWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getMinimumReplicationFactorWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getMinimumReplicationFactorWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getMinimumTimestampFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getMinimumTimestampFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getMinimumTimestampFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getMinimumTimestampFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getMinimumTimestampWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getMinimumTimestampWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getMinimumTimestampWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getMinimumTimestampWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- 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.indexsummary.IndexSummary
- getMinLocalDeletionTime() - Method in class org.apache.cassandra.db.memtable.AbstractMemtable
- getMinLocalDeletionTime() - Method in class org.apache.cassandra.db.memtable.ShardedSkipListMemtable
- getMinLocalDeletionTime() - Method in class org.apache.cassandra.db.memtable.TrieMemtable
- getMinLocalDeletionTime() - Method in interface org.apache.cassandra.db.rows.UnfilteredSource
-
Minimum local deletion time in the memtable
- 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
- getMinSSTableRowId() - Method in class org.apache.cassandra.index.sai.memory.MemtableTermsIterator
- getMinTerm() - Method in class org.apache.cassandra.index.sai.memory.MemoryIndex
- getMinTerm() - Method in class org.apache.cassandra.index.sai.memory.MemtableIndex
- getMinTerm() - Method in class org.apache.cassandra.index.sai.memory.MemtableTermsIterator
- getMinTerm() - Method in class org.apache.cassandra.index.sai.memory.TrieMemoryIndex
- getMinTerm() - Method in class org.apache.cassandra.index.sai.memory.VectorMemoryIndex
- getMinTerm() - Method in interface org.apache.cassandra.index.sai.utils.TermsIterator
- getMinTerm() - Method in class org.apache.cassandra.io.tries.Walker
- getMinTimestamp() - Method in class org.apache.cassandra.db.memtable.AbstractMemtable
- getMinTimestamp() - Method in class org.apache.cassandra.db.memtable.ShardedSkipListMemtable
-
Returns the minTS if one available, otherwise NO_MIN_TIMESTAMP.
- getMinTimestamp() - Method in class org.apache.cassandra.db.memtable.TrieMemtable
-
Returns the minTS if one available, otherwise NO_MIN_TIMESTAMP.
- getMinTimestamp() - Method in interface org.apache.cassandra.db.rows.UnfilteredSource
-
Minimum timestamp of all stored data
- getMinTimestamp() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- getMinTokenLength() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
- getMinTrackedPartitionSize() - Method in class org.apache.cassandra.service.StorageService
- getMinTrackedPartitionSize() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getMinTrackedPartitionSizeInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getMinTrackedPartitionTombstoneCount() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getMinTrackedPartitionTombstoneCount() - Method in class org.apache.cassandra.service.StorageService
- getMinTrackedPartitionTombstoneCount() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getMinTTL() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- getMinVersion(long, TimeUnit) - Method in class org.apache.cassandra.gms.Gossiper
- getMmappedRegionsCache() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter.Builder
- getMmappedRegionsCache() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter.Builder
- getMmappedRegionsCache() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- getMode() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
- getMode() - Method in class org.apache.cassandra.index.sasi.sa.SA
- getMode(ColumnMetadata, Map<String, String>) - Static method in class org.apache.cassandra.index.sasi.conf.IndexMode
- getMode(ColumnMetadata, Optional<IndexMetadata>) - Static method in class org.apache.cassandra.index.sasi.conf.IndexMode
- getModifiersField() - Static method in class org.apache.cassandra.utils.ReflectionUtils
- 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.See CASSANDRA-7544
- getMovingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-7544
- 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(ClientState, BatchQueryOptions, boolean, long, long, Dispatcher.RequestTime) - 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() - 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
- getName(int) - Method in class org.apache.cassandra.cql3.functions.types.TupleValue
- getName(int) - Method in class org.apache.cassandra.cql3.functions.types.UDTValue
- getNameAsString() - Method in class org.apache.cassandra.db.marshal.UserType
- getNameReplacements(Class<? extends Object>) - Static method in class org.apache.cassandra.config.Replacements
- 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
- getNativeTransportAllowOlderProtocols() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getNativeTransportMaxAuthThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getNativeTransportMaxBackoffOnQueueOverload(TimeUnit) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getNativeTransportMaxBackoffOnQueueOverloadInMillis() - Method in class org.apache.cassandra.service.StorageService
- getNativeTransportMaxBackoffOnQueueOverloadInMillis() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- 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() - Method in class org.apache.cassandra.service.StorageService
- getNativeTransportMaxConcurrentRequestsInBytes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- 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
- getNativeTransportMaxRequestDataInFlightInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getNativeTransportMaxRequestDataInFlightPerIpInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getNativeTransportMaxRequestsPerSecond() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getNativeTransportMaxRequestsPerSecond() - Method in class org.apache.cassandra.service.StorageService
- getNativeTransportMaxRequestsPerSecond() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getNativeTransportMaxRequestsPerSecond() - Static method in class org.apache.cassandra.transport.ClientResourceLimits
- getNativeTransportMaxThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getNativeTransportMinBackoffOnQueueOverload(TimeUnit) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getNativeTransportMinBackoffOnQueueOverloadInMillis() - Method in class org.apache.cassandra.service.StorageService
- getNativeTransportMinBackoffOnQueueOverloadInMillis() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- 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
- getNativeTransportQueueMaxItemAgeThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
How much time the item is allowed to spend in (currently only Native) queue, compared to
DatabaseDescriptor.nativeTransportIdleTimeout()
, before backpressure starts being applied. - getNativeTransportQueueMaxItemAgeThreshold() - Method in class org.apache.cassandra.service.StorageService
- getNativeTransportQueueMaxItemAgeThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getNativeTransportRateLimitingEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getNativeTransportRateLimitingEnabled() - Method in class org.apache.cassandra.service.StorageService
- getNativeTransportRateLimitingEnabled() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getNativeTransportReceiveQueueCapacityInBytes() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getNativeTransportThrowOnOverload() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getNativeTransportThrowOnOverload() - Method in class org.apache.cassandra.service.StorageService
- getNativeTransportThrowOnOverload() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getNativeTransportTimeout(TimeUnit) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getNativeTransportTimeoutMillis() - Method in class org.apache.cassandra.service.StorageService
- getNativeTransportTimeoutMillis() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getNaturalEndpoints(String, String, String) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-7544
- getNaturalEndpoints(String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-7544
- getNaturalEndpoints(String, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-7544
- getNaturalEndpoints(String, ByteBuffer) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-7544
- getNaturalEndpointsWithPort(String, String, String) - 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 class org.apache.cassandra.service.StorageService
- 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(String, String, String) - Method in class org.apache.cassandra.service.StorageService
- getNaturalReplicasForToken(String, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
- getNaturalReplicasForToken(RingPosition<?>) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
-
get the (possibly cached) endpoints that should store the given Token.
- getNeighbors(String, Iterable<Range<Token>>, Range<Token>, Collection<String>, Collection<String>) - Method in class org.apache.cassandra.service.ActiveRepairService
-
Return all of the neighbors with whom we share the provided range.
- getNeighborsAndRanges() - Method in class org.apache.cassandra.repair.state.CoordinatorState
- getNetMask() - Method in class org.apache.cassandra.cql3.CIDR
-
Get netmask of the CIDR
- getNetworkAuthorizer() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getNetworkingCacheSizeInMiB() - 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
- getNewType() - Method in enum org.apache.cassandra.config.Converters
-
Expected return type from
Converters.convert(Object)
, and input type toConverters.unconvert(Object)
- getNextBackgroundTask(long) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
- getNextBackgroundTask(long) - 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(long) - 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(long) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
- getNextBackgroundTask(long) - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
- getNextBackgroundTask(long) - Method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
-
Returns a compaction task to run next.
- 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.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: [ ] [ ]
- getNonPartitionRestrictedQueryEnabled() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getNonPartitionRestrictedQueryEnabled() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getNonPartitionRestrictedQueryEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Returns whether it is possible to execute a query against secondary indexes without specifying any partition key restrictions.
- getNonPartitionRestrictedQueryEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Returns whether it is possible to execute a query against secondary indexes without specifying any partition key restrictions.
- 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.FutureDelegate
- getNow() - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
-
if isSuccess(), returns the value, otherwise returns null
- getNowInSec(long) - 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.
- getNowInSeconds(QueryState) - Method in class org.apache.cassandra.cql3.BatchQueryOptions
- getNowInSeconds(QueryState) - Method in class org.apache.cassandra.cql3.QueryOptions
- 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(String) - Method in class org.apache.cassandra.schema.Views
-
Get the view with the specified name
- getNullable(ByteBuffer) - Method in class org.apache.cassandra.schema.Types
-
Get the type with the specified name
- getNullable(TableId) - Method in class org.apache.cassandra.schema.Tables
- getNumberOfPausedConnections() - Method in class org.apache.cassandra.metrics.ClientMetrics
- getNumberOfRows() - Method in class org.apache.cassandra.index.sai.disk.v1.bbtree.NumericIndexWriter
- getNumberOfRows() - Method in interface org.apache.cassandra.index.sai.disk.v1.segment.SegmentWriter
-
Returns the number of rows written to the segment
- getNumberOfRows() - Method in class org.apache.cassandra.index.sai.disk.v1.trie.LiteralIndexWriter
- 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
- getNumShards(double) - Method in class org.apache.cassandra.db.compaction.unified.Controller
-
Calculate the number of shards to split the local token space in for the given SSTable density.
- getNumTokens() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getNumTransfers() - Method in class org.apache.cassandra.streaming.StreamSession
- getObject(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as the Java type matching its CQL type. - 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(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.IndexSummary
- getOffsets() - Method in class org.apache.cassandra.index.sasi.disk.Token
- getOffsets() - Method in class org.apache.cassandra.index.sasi.disk.TokenTree.OnDiskToken
- getOldType() - Method in enum org.apache.cassandra.config.Converters
- getOnDiskBytesWritten() - Method in class org.apache.cassandra.db.compaction.unified.ShardedMultiWriter
- getOnDiskBytesWritten() - Method in class org.apache.cassandra.io.sstable.RangeAwareSSTableWriter
- getOnDiskBytesWritten() - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
- getOnDiskBytesWritten() - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
- getOnDiskBytesWritten() - Method in class org.apache.cassandra.io.sstable.SSTableTxnWriter
-
Get the amount of data written to disk.
- getOnDiskBytesWritten() - Method in class org.apache.cassandra.io.sstable.SSTableZeroCopyWriter
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter
- getOnDiskFilePointer() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
Returns a position in the (compressed) data file on disk.
- 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
- getOpenReason() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- 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.tools.JMXTool.Info
- getOperator(FunctionName) - Static method in class org.apache.cassandra.cql3.functions.OperationFcts
-
Returns the operator associated to the specified function.
- getOptimizeFor() - Method in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- getOptional() - Method in class org.apache.cassandra.config.EncryptionOptions
-
Indicates if the channel may be encrypted (but is not required to be).
- getOptionalFixedLength(ValueAccessor<V>, ByteSource, int) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
Consume the next length bytes from the source unchanged, also translating null to an empty buffer.
- getOptionalSignedFixedLength(ValueAccessor<V>, ByteSource, int) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
Produce the bytes for an encoded signed fixed-length number, also translating null to empty buffer.
- getOptionalSignedFixedLengthFloat(ValueAccessor<V>, ByteSource, int) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
Produce the bytes for an encoded signed fixed-length floating-point number, also translating null to an empty buffer.
- 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() - Method in class org.apache.cassandra.cql3.statements.schema.IndexAttributes
- getOptions(RoleResource) - Static method in class org.apache.cassandra.auth.Roles
-
Returns the map of custom options for the named role.
- getOrCreate(int) - Static method in class org.apache.cassandra.io.compress.ZstdCompressor
-
Get a cached instance or return a new one
- getOrCreate(ChannelProxy, long) - Method in class org.apache.cassandra.io.util.MmappedRegionsCache
-
Looks for mmapped regions in cache.
- getOrCreate(ChannelProxy, CompressionMetadata) - Method in class org.apache.cassandra.io.util.MmappedRegionsCache
-
Looks for mmapped regions in cache.
- getOrCreate(ClientState) - Method in class org.apache.cassandra.db.guardrails.GuardrailsConfigProvider.Default
- getOrCreate(ClientState) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfigProvider
-
Returns the
GuardrailsConfig
to be used for the specifiedClientState
. - getOrCreateAndAttachInboundSession(StreamingChannel, int) - Method in class org.apache.cassandra.streaming.messages.IncomingStreamMessage
- getOrCreateAndAttachInboundSession(StreamingChannel, int) - Method in class org.apache.cassandra.streaming.messages.StreamInitMessage
- getOrCreateAndAttachInboundSession(StreamingChannel, int) - 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. - getOrCreateCFSOrdinal(ColumnFamilyStore) - Method in class org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
- getOrCreateFunction(List<? extends AssignmentTestable>, AbstractType<?>, String, String) - Method in class org.apache.cassandra.cql3.functions.FunctionFactory
-
Returns a function with a signature compatible with the specified function call.
- getOrCreateInboundSession(InetAddressAndPort, StreamingChannel, int, int) - Method in class org.apache.cassandra.streaming.StreamCoordinator
- getOrCreateJob(RepairJobDesc) - Method in class org.apache.cassandra.repair.state.ParticipateState
- getOrCreateOutboundSession(InetAddressAndPort) - Method in class org.apache.cassandra.streaming.StreamCoordinator
- getOrCreateSslContext(EncryptionOptions, boolean, ISslContextFactory.SocketType, String) - 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
- getOrdinal() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.PostingsReader
- getOrdinal() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.VectorPostings
- getOrdinal() - Method in class org.apache.cassandra.index.sai.postings.IntArrayPostingList
- getOrdinal() - Method in interface org.apache.cassandra.index.sai.postings.OrdinalPostingList
- getOrdinalForRowId(int) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.OnDiskOrdinalsMap.OrdinalsView
- getOrdinalsView() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.DiskAnn
- getOrdinalsView() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.OnDiskOrdinalsMap
- 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.See CASSANDRA-15066
- getOtcBacklogExpirationInterval() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.See CASSANDRA-15066
- getOtherOptions() - Method in class org.apache.cassandra.schema.CompressionParams
- getOutgoingStreamsForRanges(RangesAtEndpoint, Collection<ColumnFamilyStore>, TimeUUID, 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
- getOutput(ProtocolVersion) - Method in class org.apache.cassandra.cql3.selection.VectorSelector
- 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.schema.DefaultSchemaUpdateHandler
- getOutstandingSchemaVersions() - Method in class org.apache.cassandra.schema.Schema
- getOutstandingSchemaVersions() - Method in class org.apache.cassandra.service.StorageService
- getOutstandingSchemaVersions() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-17668
- 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.See CASSANDRA-7544
- getOwnership() - Method in class org.apache.cassandra.tools.NodeProbe
- getOwnershipByDcWithPort(NodeProbe, boolean, Map<String, String>, Map<String, Float>) - Static method in class org.apache.cassandra.tools.NodeTool
- getOwnershipToken(Map<String, Object>) - Method in class org.apache.cassandra.service.FileSystemOwnershipCheck
- 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.
- getPageSizeFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getPageSizeFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getPageSizeFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getPageSizeFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getPageSizeWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getPageSizeWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getPageSizeWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getPageSizeWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- 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(TimeUUID) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
- getParentRepairSession(TimeUUID) - Method in class org.apache.cassandra.service.ActiveRepairService
-
We assume when calling this method that a parent session for the provided identifier exists, and that session is still in progress.
- 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.
- getPartialArguments() - Method in interface org.apache.cassandra.cql3.functions.PartialScalarFunction
-
Returns the list of input parameters for the function where some parameters can be
Function.UNRESOLVED
. - getParticipants() - Method in class org.apache.cassandra.repair.state.CoordinatorState
- getParticipants() - Method in class org.apache.cassandra.repair.state.JobState
- getParticipants() - Method in class org.apache.cassandra.repair.state.SessionState
- 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
- getPartitionDenylistEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getPartitionDenylistLoadAttempts() - Method in class org.apache.cassandra.service.StorageProxy
- getPartitionDenylistLoadAttempts() - Method in interface org.apache.cassandra.service.StorageProxyMBean
- getPartitionDenylistLoadSuccesses() - Method in class org.apache.cassandra.service.StorageProxy
- getPartitionDenylistLoadSuccesses() - Method in interface org.apache.cassandra.service.StorageProxyMBean
- 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
- getPartitionerDefinedOrder() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
Parse and return the real
PartitionerDefinedOrder
from the string variableTypeParser.str
. - 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
- getPartitionIndex() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader.Builder
- 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, ClientState) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Returns the partition keys for which the data is requested.
- getPartitionKeysInSelectFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getPartitionKeysInSelectFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getPartitionKeysInSelectFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getPartitionKeysInSelectFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getPartitionKeysInSelectWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getPartitionKeysInSelectWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getPartitionKeysInSelectWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getPartitionKeysInSelectWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getPartitionKeyType() - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
- 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(String, 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
- getPartitionSizeFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getPartitionSizeFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getPartitionSizeFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getPartitionSizeFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getPartitionSizeWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getPartitionSizeWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getPartitionSizeWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getPartitionSizeWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getPartitionTombstonesFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getPartitionTombstonesFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getPartitionTombstonesFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getPartitionTombstonesFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getPartitionTombstonesWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getPartitionTombstonesWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getPartitionTombstonesWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getPartitionTombstonesWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- 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
- getPath(String, String...) - Static method in class org.apache.cassandra.io.util.File
- getPaxosAutoRepairsEnabled() - Method in class org.apache.cassandra.service.StorageService
- getPaxosAutoRepairsEnabled() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getPaxosAutoRepairTables() - Method in class org.apache.cassandra.service.StorageService
- getPaxosAutoRepairTables() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getPaxosBallotLowBound(String, String, String) - Method in class org.apache.cassandra.service.StorageService
- getPaxosBallotLowBound(String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getPaxosCacheSizeInMiB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getPaxosContentionMaxWait() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getPaxosContentionMinDelta() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getPaxosContentionMinWait() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getPaxosContentionStrategy() - Method in class org.apache.cassandra.service.StorageProxy
- getPaxosContentionStrategy() - Method in interface org.apache.cassandra.service.StorageProxyMBean
- getPaxosContentionWaitRandomizer() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getPaxosCoordinatorLockingDisabled() - Method in class org.apache.cassandra.service.StorageProxy
- getPaxosCoordinatorLockingDisabled() - Method in interface org.apache.cassandra.service.StorageProxyMBean
- getPaxosDcLocalCommitEnabled() - Method in class org.apache.cassandra.service.StorageService
- getPaxosDcLocalCommitEnabled() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getPaxosOnLinearizabilityViolations() - Method in class org.apache.cassandra.service.StorageService
- getPaxosOnLinearizabilityViolations() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getPaxosPurgeGrace(TimeUnit) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getPaxosPurgeGraceSeconds() - Method in class org.apache.cassandra.service.StorageService
- getPaxosPurgeGraceSeconds() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getPaxosRepairEnabled() - Method in class org.apache.cassandra.service.StorageService
- getPaxosRepairEnabled() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getPaxosRepairHistory() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getPaxosRepairHistoryForRanges(Collection<Range<Token>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getPaxosRepairLowBound(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getPaxosRepairParallelism() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getPaxosRepairParallelism() - Method in class org.apache.cassandra.service.ActiveRepairService
- getPaxosRepairParallelism() - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
- getPaxosStateFlushEnabled() - Method in class org.apache.cassandra.service.StorageService
- getPaxosStateFlushEnabled() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getPaxosStatePurging() - Method in class org.apache.cassandra.service.StorageService
- getPaxosStatePurging() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getPaxosVariant() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getPaxosVariant() - Static method in class org.apache.cassandra.service.paxos.Paxos
- getPaxosVariant() - Method in class org.apache.cassandra.service.StorageProxy
- getPaxosVariant() - Method in interface org.apache.cassandra.service.StorageProxyMBean
- getPeers() - Method in class org.apache.cassandra.streaming.StreamCoordinator
- getPendingAddressRanges(TokenMetadata, Collection<Token>, InetAddressAndPort) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
- getPendingAddressRanges(TokenMetadata, Token, InetAddressAndPort) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
- getPendingHints() - Method in class org.apache.cassandra.hints.HintsService
-
Returns all pending hints that this node has.
- getPendingHints() - Method in interface org.apache.cassandra.hints.HintsServiceMBean
-
Returns all pending hints that this node has.
- getPendingHintsInfo() - Method in class org.apache.cassandra.hints.HintsService
-
Returns all pending hints that this node has.
- getPendingMemtableIndex(LifecycleNewTracker) - Method in class org.apache.cassandra.index.sai.memory.MemtableIndexManager
- 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.See CASSANDRA-7544
- getPendingRangeToEndpointWithPortMap(String) - Method in class org.apache.cassandra.service.StorageService
- getPendingRangeToEndpointWithPortMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getPendingRepair() - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
- getPendingRepair() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- getPendingRepair() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- 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
- getPendingRepair(Set<SSTableReader>) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
- getPendingRepairStats() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getPendingStats(List<String>, String) - Method in class org.apache.cassandra.service.ActiveRepairService
- getPendingStats(List<String>, String) - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
- getPendingStats(TableId, Collection<Range<Token>>) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
- getPendingTaskCount() - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
- getPendingTaskCount() - Method in interface org.apache.cassandra.concurrent.ResizableThreadPool
-
Returns the approximate total of tasks waiting to be executed.
- getPendingTaskCount() - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- getPendingTaskCount() - Method in class org.apache.cassandra.concurrent.SEPExecutor
- getPendingTaskCount() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBase
- getPendingTaskCount() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorJMXAdapter
- getPendingTaskCount() - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- getPendingTasks() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
- getPendingTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
- getPendingTasks() - Method in interface org.apache.cassandra.db.compaction.ICompactionManager
- getPercentileSnapshot() - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
- getPercentileSnapshot() - Method in class org.apache.cassandra.metrics.ScalingReservoir
- getPercentileSnapshot() - Method in interface org.apache.cassandra.metrics.SnapshottingReservoir
- getPercentileSnapshot() - Method in class org.apache.cassandra.metrics.SnapshottingTimer
- getPeriodicCommitLogSyncBlock() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getPerLevelSizeBytes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getPerLevelSizeBytes() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
- getPerLevelSizeBytes() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
- getPermissions - Variable in class org.apache.cassandra.auth.jmx.AuthorizationProxy
- getPermissions(AuthenticatedUser, IResource) - Method in class org.apache.cassandra.auth.PermissionsCache
- getPermissions(IResource) - Method in class org.apache.cassandra.auth.AuthenticatedUser
- getPermissionsCacheActiveUpdate() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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.See CASSANDRA-7544
- 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
- getPointCount() - Method in class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeReader
- getPointer(OnDiskIndex.PointerTerm, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.PointerLevel
- 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() - Method in class org.apache.cassandra.io.sstable.AbstractRowIndexEntry
-
Row position in a data file
- getPosition() - Method in class org.apache.cassandra.io.util.RandomAccessReader
- getPosition(int) - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummary
- 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, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- getPosition(PartitionPosition, SSTableReader.Operator, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- getPosition(PartitionPosition, SSTableReader.Operator, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Retrieve a position in data file according to the provided key and operator.
- getPosition(PartitionPosition, SSTableReader.Operator, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- getPositionInSummary(int) - Method in class org.apache.cassandra.io.sstable.indexsummary.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.sai.StorageAttachedIndex
- getPostIndexQueryFilter(RowFilter) - Method in class org.apache.cassandra.index.sasi.SASIIndex
- getPostIndexQueryFilter(RowFilter) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- getPostingAt(int) - Method in class org.apache.cassandra.index.sai.postings.IntArrayPostingList
- getPostings() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.VectorPostings
- getPostingsReader(long) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.LiteralIndexSegmentTermsReader.TermQuery
- getPostQueryOrdering(Restriction, QueryOptions) - Method in interface org.apache.cassandra.index.Index
-
Return a comparator that reorders query result before sending to client
- getPostQueryOrdering(Restriction, QueryOptions) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- 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
- getPreferredCompatibleType(List<Pair<T, T>>, Function<T, AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.Maps
- getPreferredCompatibleType(List<T>, Function<T, AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.Lists
- getPreferredCompatibleType(List<T>, Function<T, AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.Sets
- getPreferredCompatibleType(List<T>, Function<T, AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.Vectors
- 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.
- getPreJoinTask(boolean) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- 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
- getPreparedStatements() - Method in class org.apache.cassandra.cql3.QueryProcessor
- getPreparedStatements() - Method in class org.apache.cassandra.service.StorageService
- getPreparedStatementsCacheSizeMiB() - 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.repair.Validator
- getPreviewKind() - Method in class org.apache.cassandra.streaming.StreamSession
- getPreviousReleaseVersionString() - Static method in class org.apache.cassandra.utils.FBUtilities
- 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.repair.state.ValidationState
- getProgressCount() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
- getProgressPercentage() - Method in class org.apache.cassandra.utils.progress.ProgressEvent
- getPromise(Row) - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosRows
- getProperties() - Method in class org.apache.cassandra.security.AbstractCryptoProvider
-
Returns unmodifiable properties of this crypto provider
- getProperties(Class<?>) - Method in class org.apache.cassandra.config.DefaultLoader
- getProperties(Class<?>) - Method in interface org.apache.cassandra.config.Loader
- 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
- getProtocol() - Method in class org.apache.cassandra.config.EncryptionOptions
- getProtocolVersion() - Method in interface org.apache.cassandra.cql3.functions.Arguments
-
Returns the protocol version
- getProtocolVersion() - Method in class org.apache.cassandra.cql3.functions.FunctionArguments
- getProtocolVersion() - Method in class org.apache.cassandra.cql3.QueryOptions
-
The protocol version for the query.
- getProtocolVersion() - Method in class org.apache.cassandra.cql3.selection.Selector.InputRow
- getProtocolVersion() - Method in enum org.apache.cassandra.transport.DataType
- getProviderClassAsString() - Method in class org.apache.cassandra.security.AbstractCryptoProvider
-
Returns the name of the class which installs specific provider of name
AbstractCryptoProvider.getProviderName()
. - getProviderClassAsString() - Method in class org.apache.cassandra.security.DefaultCryptoProvider
- getProviderClassAsString() - Method in class org.apache.cassandra.security.JREProvider
- getProviderName() - Method in class org.apache.cassandra.security.AbstractCryptoProvider
-
Returns name of the provider, as returned from
Provider.getName()
- getProviderName() - Method in class org.apache.cassandra.security.DefaultCryptoProvider
- getProviderName() - Method in class org.apache.cassandra.security.JREProvider
- getProxyMetric(String) - Method in class org.apache.cassandra.tools.NodeProbe
-
Retrieve Proxy metrics
- getPurgeEvaluator() - Method in class org.apache.cassandra.db.partitions.PurgeFunction
- 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(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier.VerifyController
- getQuery(QueryOptions, long) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
- getQuery(QueryOptions, ClientState, ColumnFilter, long, int, int, int, AggregationSpecification) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
- getQuery(QueryOptions, ClientState, ColumnFilter, long, DataLimits) - 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() - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
- getRack() - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Rack name depending on the respective snitch used for this node
- getRack() - Method in class org.apache.cassandra.tools.NodeProbe
- getRack(String) - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
- getRack(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
-
Provides the Rack name depending on the respective snitch used, given the host name/ip
- getRack(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.DynamicEndpointSnitch
- 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
- getRandomToken() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
- getRandomToken() - Method in interface org.apache.cassandra.dht.IPartitioner
- getRandomToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
- getRandomToken() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
- getRandomToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
- getRandomToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
- getRandomToken(Random) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
- getRandomToken(Random) - Method in interface org.apache.cassandra.dht.IPartitioner
- getRandomToken(Random) - Method in class org.apache.cassandra.dht.LocalPartitioner
- getRandomToken(Random) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
- getRandomToken(Random) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
- 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
- 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() - 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
- getRangeRpcTimeout(TimeUnit) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getRanges() - Method in class org.apache.cassandra.repair.messages.RepairOption
- getRanges() - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
- getRangeSlice(PartitionRangeReadCommand, ConsistencyLevel, Dispatcher.RequestTime) - 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) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-7544
- getRangeToEndpointMap(String, boolean) - Method in class org.apache.cassandra.service.StorageService
-
for a keyspace, return the ranges and corresponding listen addresses.
- 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.See CASSANDRA-7544
- getRate() - Method in class org.apache.cassandra.utils.concurrent.NonBlockingRateLimiter
- 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.
- getRateLimiterRateInBytes() - Static method in class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
- 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
- getRawSize() - Method in class org.apache.cassandra.db.Directories.DataDirectory
- 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
- getReadAheadKBPath(String) - Static method in class org.apache.cassandra.service.StartupChecks
- getReadBeforeWriteListOperationsEnabled() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getReadBeforeWriteListOperationsEnabled() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getReadBeforeWriteListOperationsEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Returns whether list operations that require read before write are allowed.
- getReadBeforeWriteListOperationsEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Returns whether list operations that require read before write are allowed.
- getReadConsistencyLevel() - Method in class org.apache.cassandra.auth.AuthProperties
- getReadConsistencyLevel() - Method in interface org.apache.cassandra.auth.AuthPropertiesMXBean
- getReadConsistencyLevelsDisallowed() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getReadConsistencyLevelsDisallowed() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getReadConsistencyLevelsDisallowed() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getReadConsistencyLevelsDisallowed() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getReadConsistencyLevelsDisallowedCSV() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getReadConsistencyLevelsDisallowedCSV() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getReadConsistencyLevelsWarned() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getReadConsistencyLevelsWarned() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getReadConsistencyLevelsWarned() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getReadConsistencyLevelsWarned() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getReadConsistencyLevelsWarnedCSV() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getReadConsistencyLevelsWarnedCSV() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getReaderClass() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat.SSTableReaderFactory
- getReaderFactory() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- getReaderFactory() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- getReaderFactory() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
- getReadExecutor(SinglePartitionReadCommand, ConsistencyLevel, Dispatcher.RequestTime) - 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
- getReadRepairRepairTimedOut() - Method in class org.apache.cassandra.service.StorageProxy
- getReadRepairRepairTimedOut() - Method in interface org.apache.cassandra.service.StorageProxyMBean
- 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
- getReadRpcTimeout(TimeUnit) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getReadThresholdsEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getReadThresholdsEnabled() - Method in class org.apache.cassandra.service.StorageService
- getReadThresholdsEnabled() - 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(TimeUUID) - Method in class org.apache.cassandra.streaming.StreamManager
- getRecentFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.filter.BloomFilterTracker
- getRecentTrueNegativeCount() - Method in class org.apache.cassandra.io.sstable.filter.BloomFilterTracker
- getRecentTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.filter.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
- 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
- getReleaseVersion() - Method in class org.apache.cassandra.gms.EndpointState
- 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
- getReleaseVersion(InetAddressAndPort) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Get release version for given endpoint.
- getReleaseVersion(InetAddressAndPort) - Method in interface org.apache.cassandra.gms.IGossiper
- 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.See CASSANDRA-7544
- 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 class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- 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(Collection<Range<Token>>) - Method in class org.apache.cassandra.repair.consistent.RepairedState
- getRepairedStats(TableId, Collection<Range<Token>>) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
- 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
- getRepairRetrySpec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getRepairRpcTimeout() - Method in class org.apache.cassandra.service.StorageService
- getRepairRpcTimeout() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getRepairRpcTimeout(TimeUnit) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getRepairServiceProxy() - Method in class org.apache.cassandra.tools.NodeProbe
- getRepairSessionMaximumTreeDepth() - Method in class org.apache.cassandra.service.StorageService
- getRepairSessionMaximumTreeDepth() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getRepairSessionMaxTreeDepth() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getRepairSessionMaxTreeDepth() - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-17668
- getRepairSessionMaxTreeDepth() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.use getRepairSessionMaximumTreeDepth instead. See CASSANDRA-17668
- getRepairSessionSpaceInMebibytes() - Method in class org.apache.cassandra.service.ActiveRepairService
-
Deprecated.See CASSANDRA-17668
- getRepairSessionSpaceInMebibytes() - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
-
Deprecated.use getRepairSessionSpaceInMiB instead. See CASSANDRA-17668
- getRepairSessionSpaceInMegabytes() - Method in class org.apache.cassandra.service.ActiveRepairService
-
Deprecated.See CASSANDRA-15234
- getRepairSessionSpaceInMegabytes() - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
-
Deprecated.See CASSANDRA-15234
- getRepairSessionSpaceInMiB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getRepairSessionSpaceInMiB() - Method in class org.apache.cassandra.service.ActiveRepairService
- getRepairSessionSpaceInMiB() - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
- getRepairStateExpires() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getRepairStateSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getRepairStats(List<String>, String) - Method in class org.apache.cassandra.service.ActiveRepairService
- getRepairStats(List<String>, String) - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
- getRepairStatus(Integer) - Method in class org.apache.cassandra.service.ActiveRepairService
- 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
- getReplicas(String, InetAddressAndPort) - Method in class org.apache.cassandra.service.StorageService
- 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() - Method in class org.apache.cassandra.locator.SimpleStrategy
- getReplicationFactor(String) - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
- getReplicationStrategy() - Method in class org.apache.cassandra.db.Keyspace
- getReplicationStrategyClass() - Method in class org.apache.cassandra.cql3.statements.schema.KeyspaceAttributes
- getReportingUnconfirmedRepairedDataMismatchesEnabled() - Method in class org.apache.cassandra.service.StorageProxy
- getReportingUnconfirmedRepairedDataMismatchesEnabled() - Method in interface org.apache.cassandra.service.StorageProxyMBean
- getRequests() - Method in class org.apache.cassandra.io.sstable.keycache.KeyCache
- 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.indexsummary.IndexSummaryManager
- getResizeIntervalInMinutes() - Method in interface org.apache.cassandra.io.sstable.indexsummary.IndexSummaryManagerMBean
- getResponseCount() - Method in class org.apache.cassandra.service.paxos.v1.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() - 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
- 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
- getResult() - Method in class org.apache.cassandra.repair.state.AbstractCompletable
- getResult() - Method in interface org.apache.cassandra.repair.state.Completable
- 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) - Static method in class org.apache.cassandra.auth.Roles
-
Identify all roles granted to the supplied Role, including both directly granted and inherited roles.
- 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.
- getRolesCacheActiveUpdate() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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
- getRowCacheSizeInMiB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getRowCount() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
-
Returns the number of indexed rows in the index.
- getRowCount() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder
- getRowCount() - Method in class org.apache.cassandra.index.sai.disk.v1.V1SSTableIndex
- getRowFilter(QueryOptions, ClientState) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
-
May be used by custom QueryHandler implementations
- getRowFilter(IndexRegistry, QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
- getRowIds() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.VectorPostings
- getRowIdsView() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.OnDiskOrdinalsMap
- getRowIndexEntry(PartitionPosition, SSTableReader.Operator) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
Retrieves the position while updating the key cache and the stats.
- getRowIndexEntry(PartitionPosition, SSTableReader.Operator, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- getRowIndexEntry(PartitionPosition, SSTableReader.Operator, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- getRowIndexEntry(PartitionPosition, SSTableReader.Operator, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Retrieve an index entry for the partition found according to the provided key and operator.
- getRowIndexFile() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader.Builder
- getRowIndexReadSizeAbortThreshold() - Method in class org.apache.cassandra.service.StorageService
- getRowIndexReadSizeAbortThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getRowIndexReadSizeFailThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getRowIndexReadSizeWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getRowIndexReadSizeWarnThreshold() - Method in class org.apache.cassandra.service.StorageService
- getRowIndexReadSizeWarnThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getRowIterator(E, DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SSTableScanner.BaseKeyScanningIterator
- getRowIterator(RowIndexEntry, DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.BigScanningIterator
- getRowIterator(TrieIndexEntry, DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableScanner.BtiScanningIterator
- 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() - 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
- getRpcTimeout(TimeUnit) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getSaiFrozenTermSizeFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getSaiFrozenTermSizeFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getSaiFrozenTermSizeFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getSaiFrozenTermSizeFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getSaiFrozenTermSizeWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getSaiFrozenTermSizeWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getSaiFrozenTermSizeWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getSaiFrozenTermSizeWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getSAISegmentWriteBufferSpace() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getSaiSSTableIndexesPerQueryFailThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getSaiSSTableIndexesPerQueryFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getSaiSSTableIndexesPerQueryFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getSaiSSTableIndexesPerQueryFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getSaiSSTableIndexesPerQueryFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getSaiSSTableIndexesPerQueryWarnThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getSaiSSTableIndexesPerQueryWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getSaiSSTableIndexesPerQueryWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getSaiSSTableIndexesPerQueryWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getSaiSSTableIndexesPerQueryWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getSaiStringTermSizeFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getSaiStringTermSizeFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getSaiStringTermSizeFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getSaiStringTermSizeFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getSaiStringTermSizeWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getSaiStringTermSizeWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getSaiStringTermSizeWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getSaiStringTermSizeWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getSaiVectorTermSizeFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getSaiVectorTermSizeFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getSaiVectorTermSizeFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getSaiVectorTermSizeFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getSaiVectorTermSizeWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getSaiVectorTermSizeWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getSaiVectorTermSizeWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getSaiVectorTermSizeWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getSampleIndexesForRanges(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummary
- getSampleTasks() - Method in class org.apache.cassandra.service.StorageService
- getSampleTasks() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getSampleTasks() - Method in class org.apache.cassandra.tools.NodeProbe
- getSamplingLevel() - Method in class org.apache.cassandra.io.sstable.indexsummary.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.
- getSASIIndexesEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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
- getScalingParameter(int) - Method in class org.apache.cassandra.db.compaction.unified.Controller
- getScanner() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
Direct I/O SSTableScanner over the full sstable.
- getScanner() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- 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.big.BigTableReader
-
Direct I/O SSTableScanner over a defined collection of ranges of tokens.
- getScanner(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- 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.big.BigTableReader
-
Direct I/O SSTableScanner over an iterator of bounds.
- getScanner(Iterator<AbstractBounds<PartitionPosition>>) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- getScanner(Iterator<AbstractBounds<PartitionPosition>>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Direct I/O SSTableScanner over an iterator of bounds.
- getScanner(Range<Token>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Direct I/O SSTableScanner over a defined range of tokens.
- getScanner(BigTableReader) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
- getScanner(BigTableReader, Collection<Range<Token>>) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
- getScanner(BigTableReader, Iterator<AbstractBounds<PartitionPosition>>) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
- getScanner(BigTableReader, ColumnFilter, DataRange, SSTableReadsListener) - Static method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
- getScanner(BtiTableReader) - Static method in class org.apache.cassandra.io.sstable.format.bti.BtiTableScanner
- getScanner(BtiTableReader, Collection<Range<Token>>) - Static method in class org.apache.cassandra.io.sstable.format.bti.BtiTableScanner
- getScanner(BtiTableReader, Iterator<AbstractBounds<PartitionPosition>>) - Static method in class org.apache.cassandra.io.sstable.format.bti.BtiTableScanner
- getScanner(BtiTableReader, ColumnFilter, DataRange, SSTableReadsListener) - Static method in class org.apache.cassandra.io.sstable.format.bti.BtiTableScanner
- getScanners(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
- 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.AbstractCompactionStrategy
-
Returns a list of KeyScanners given sstables and a range on which to scan.
- getScanners(Collection<SSTableReader>, Collection<Range<Token>>) - 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(Collection<SSTableReader>, Range<Token>) - 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(AbstractStrategyHolder.GroupedSSTableContainer, Collection<Range<Token>>) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
- getScanPosition(PartitionPosition) - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummary
- getScanPositionFromBinarySearchResult(int) - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummary
- getSchemaFile() - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
- getSchemaUpdateHandler(boolean, BiConsumer<SchemaTransformation.SchemaTransformationResult, Boolean>) - Method in class org.apache.cassandra.schema.DefaultSchemaUpdateHandlerFactory
- getSchemaUpdateHandler(boolean, BiConsumer<SchemaTransformation.SchemaTransformationResult, Boolean>) - Method in interface org.apache.cassandra.schema.SchemaUpdateHandlerFactory
-
A factory which provides the appropriate schema update handler.
- getSchemaVersion() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Gets the schema version or null if missing
- getSchemaVersion() - Method in class org.apache.cassandra.gms.EndpointState
- 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
- getSchemaVersion(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
- getSchemaVersions() - Method in class org.apache.cassandra.service.StorageProxy
- getSchemaVersions() - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.See CASSANDRA-7544
- 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.See CASSANDRA-7544
- getScoresWithPort() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
- getScoresWithPort() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
- getScrubber(ColumnFamilyStore, LifecycleTransaction, OutputHandler, IScrubber.Options) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- getScrubber(ColumnFamilyStore, LifecycleTransaction, OutputHandler, IScrubber.Options) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- getScrubber(ColumnFamilyStore, LifecycleTransaction, OutputHandler, IScrubber.Options) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
Returns a new scrubber for an sstable.
- getScrubInfo() - Method in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- getScrubInfo() - Method in interface org.apache.cassandra.io.sstable.IScrubber
- getSecondaryIndexesEnabled() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getSecondaryIndexesEnabled() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getSecondaryIndexesEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getSecondaryIndexesEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getSecondaryIndexesPerTableFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getSecondaryIndexesPerTableFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getSecondaryIndexesPerTableFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getSecondaryIndexesPerTableFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getSecondaryIndexesPerTableWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getSecondaryIndexesPerTableWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getSecondaryIndexesPerTableWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getSecondaryIndexesPerTableWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- 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
- getSegmentRowIdsMatching(int) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.OnDiskOrdinalsMap.RowIdsView
- getSelectedSSTableFormat() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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.
- getSerializationHeader() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- getSerializationHeader() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- 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.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.CompositeType
- 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.DynamicCompositeType.FixedValueComparator
- getSerializer() - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
- 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.LegacyTimeUUIDType
- 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
- getSerializer() - Method in class org.apache.cassandra.db.marshal.VectorType
- getSerializer(Version) - Static method in class org.apache.cassandra.db.DeletionTime
- getSerializer(Version) - Static method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram
- getSession(InetAddressAndPort, int) - Method in class org.apache.cassandra.streaming.StreamResultFuture
- getSession(TimeUUID) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSessions
- getSession(TimeUUID) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
- getSessionById(InetAddressAndPort, int) - Method in class org.apache.cassandra.streaming.StreamCoordinator
- getSessionId() - Method in class org.apache.cassandra.tracing.Tracing
- getSessionIds() - Method in class org.apache.cassandra.repair.state.CoordinatorState
- getSessionInfo() - Method in class org.apache.cassandra.streaming.StreamSession
- getSessions() - Method in class org.apache.cassandra.repair.state.CoordinatorState
- getSessions(boolean, String) - Method in class org.apache.cassandra.service.ActiveRepairService
- getSessions(boolean, String) - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
- getSet(int, TypeToken<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a set. - getSet(int, Class<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value 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(String, TypeToken<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
-
Returns the value for
name
as a set. - getSet(String, Class<T>) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
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, AbstractType<T>) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
- getSeverity() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
- getSeverity() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
- getSeverity(InetAddressAndPort) - Static method in class org.apache.cassandra.locator.DynamicEndpointSnitch
- getSeverityDuringDecommission() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getShadowedPrimaryKeys() - Method in class org.apache.cassandra.index.sai.VectorQueryContext
- getShardForKey(PartitionPosition) - Method in class org.apache.cassandra.db.memtable.ShardBoundaries
-
Computes the shard to use for the provided key.
- getShardForToken(Token) - Method in class org.apache.cassandra.db.memtable.ShardBoundaries
-
Computes the shard to use for the provided token.
- getShort() - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
- getShort(byte[], int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- getShort(byte[], int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- getShort(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a short. - getShort(long) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
- getShort(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
- getShort(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
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(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 {@param offset}
- getShortByByte(long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
- getShortLength(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- getSignedByte(ByteSource) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
Converts the given
ByteSource
to abyte
. - getSignedFixedLength(ValueAccessor<V>, ByteSource, int) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
Produce the bytes for an encoded signed fixed-length number.
- getSignedFixedLengthFloat(ValueAccessor<V>, ByteSource, int) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
Produce the bytes for an encoded signed fixed-length floating-point number.
- getSignedInt(ByteSource) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
Consume the next
int
from the current position of the givenByteSource
. - getSignedLong(ByteSource) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
Consume the next
long
from the current position of the givenByteSource
. - getSignedShort(ByteSource) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
Converts the given
ByteSource
to ashort
. - getSimilarityFunction() - Method in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- 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.See CASSANDRA-7544
- getSimpleStatesWithPort() - Method in class org.apache.cassandra.gms.FailureDetector
- getSimpleStatesWithPort() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
- getSimpleStatesWithPort() - Method in class org.apache.cassandra.tools.NodeProbe
- getSimpleStrategyEnabled() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getSimpleStrategyEnabled() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getSimpleStrategyEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Returns whether setting SimpleStrategy via keyspace creation or alteration is enabled
- getSimpleStrategyEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Returns whether SimpleStrategy is allowed on keyspace creation or alteration
- getSingleton() - Method in class org.apache.cassandra.io.sstable.Component.Type
- getSingletonsFor(Class<? extends SSTableFormat<?, ?>>) - Static method in class org.apache.cassandra.io.sstable.Component
- getSingletonsFor(SSTableFormat<?, ?>) - Static method in class org.apache.cassandra.io.sstable.Component
- getSize() - Method in class org.apache.cassandra.cql3.selection.ResultSetBuilder
- getSize() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithArrayLiteral
- getSize() - Method in class org.apache.cassandra.db.streaming.CassandraIncomingFile
- getSize() - Method in interface org.apache.cassandra.streaming.IncomingStream
- getSizeInBytes() - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
-
Gets the value of a system property, given as a human-readable size in bytes (e.g.
- getSizeInBytes(long) - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
-
Gets the value of a system property, given as a human-readable size in bytes (e.g.
- 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
- getSkipPaxosRepairCompatibilityCheck() - Static method in class org.apache.cassandra.service.paxos.PaxosRepair
- getSkipPaxosRepairCompatibilityCheck() - Method in class org.apache.cassandra.service.StorageService
- getSkipPaxosRepairCompatibilityCheck() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getSkipPaxosRepairOnTopologyChange() - Method in class org.apache.cassandra.service.StorageService
- getSkipPaxosRepairOnTopologyChange() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getSkipPaxosRepairOnTopologyChangeKeyspaces() - Method in class org.apache.cassandra.service.StorageService
- getSkipPaxosRepairOnTopologyChangeKeyspaces() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getSkipStreamDiskSpaceCheck() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getSkipStreamDiskSpaceCheck() - Method in class org.apache.cassandra.service.StorageService
- getSkipStreamDiskSpaceCheck() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- 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
- 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.See CASSANDRA-7544
- 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.See CASSANDRA-7544
- 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.See CASSANDRA-7544
- 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
- getSnapshot() - Method in class org.apache.cassandra.metrics.ScalingReservoir
- getSnapshotDetails() - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-16789
- getSnapshotDetails() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-16789
- getSnapshotDetails() - Method in class org.apache.cassandra.tools.NodeProbe
-
Deprecated.See CASSANDRA-16789
- getSnapshotDetails(Map<String, String>) - Method in class org.apache.cassandra.service.StorageService
- getSnapshotDetails(Map<String, String>) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Get the details of all the snapshots
- getSnapshotDetails(Map<String, String>) - 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.
- getSnapshotDirectoryIfExists(File, String) - Static method in class org.apache.cassandra.db.Directories
-
Returns directory to write a snapshot to.
- 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
- getSnapshotManifestFile(File) - Static 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
- getSnapshotSchemaFile(File) - Static 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
- getSpecificIndexPos(int, int) - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex.Reader
- 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
- getSslProvider() - Method in class org.apache.cassandra.security.AbstractSslContextFactory
-
Returns
SslProvider
to be used to build Netty's SslContext. - 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.sai.disk.SSTableIndex
- getSSTable() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
- getSstableCompressor() - Method in class org.apache.cassandra.schema.CompressionParams
-
Returns the SSTable compressor.
- getSSTableContext() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
- getSSTableCountByBuckets() - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
- 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
- getSSTableCountPerTWCSBucket() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getSSTableCountPerTWCSBucket() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
- getSSTableCountPerTWCSBucket() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
- getSStableDirectory() - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
- getSSTableFormat() - Method in class org.apache.cassandra.io.sstable.AbstractRowIndexEntry
- getSSTableFormat() - Method in class org.apache.cassandra.io.sstable.format.big.RowIndexEntry
- getSSTableFormats() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getSSTableLevel() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- getSSTableMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- getSSTablePreemptiveOpenIntervalInMB() - Method in class org.apache.cassandra.service.StorageService
-
This method can return negative number for disabled
- getSSTablePreemptiveOpenIntervalInMB() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getSSTablePreemptiveOpenIntervalInMiB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
This method can return negative number for disabled
- getSSTableReadMeter(String, String, SSTableId) - 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.
- getSStableReadRatePersistenceEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getSStableReadRatePersistenceEnabled() - Method in class org.apache.cassandra.service.StorageProxy
- getSStableReadRatePersistenceEnabled() - Method in interface org.apache.cassandra.service.StorageProxyMBean
- 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.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() - Method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- getSSTables() - Method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy.Level
- getSSTables(String, String, String, boolean) - Method in class org.apache.cassandra.tools.NodeProbe
- getSSTables(SSTableSet) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- 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) - 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 class org.apache.cassandra.db.ColumnFamilyStore
- getSSTablesForKey(String, boolean) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Returns a list of filenames that contain the given key on this node
- getSSTablesForKeyWithLevel(String, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getSSTablesForKeyWithLevel(String, boolean) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Returns a list of filenames that contain the given key and which level they belong to.
- getSStablesPerLevelSnapshot() - Method in class org.apache.cassandra.db.compaction.LeveledManifest
- getSSTablesToValidate(ColumnFamilyStore, SharedContext, Collection<Range<Token>>, TimeUUID, boolean) - Static method in class org.apache.cassandra.db.repair.CassandraValidationIterator
- getSSTablesWithLevel(String, String, String, boolean) - Method in class org.apache.cassandra.tools.NodeProbe
- getSSTableTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
- getStartedAt() - Method in class org.apache.cassandra.repair.consistent.LocalSession
- getStartedNanos() - Method in class org.apache.cassandra.utils.concurrent.NonBlockingRateLimiter
- getStartIpAddress() - Method in class org.apache.cassandra.cql3.CIDR
-
Get starting IP of the CIDR
- getStartOffset() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.PostingsWriter
- getStartOffset() - Method in class org.apache.cassandra.index.sai.disk.v1.trie.TrieTermsDictionaryWriter
- getStartPoints(int, int) - Static method in class org.apache.cassandra.io.sstable.Downsampling
- getStartupChecksOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getStartupCheckType() - Method in class org.apache.cassandra.service.DataResurrectionCheck
- getStartupCheckType() - Method in class org.apache.cassandra.service.FileSystemOwnershipCheck
- getStartupCheckType() - Method in interface org.apache.cassandra.service.StartupCheck
- getState() - Method in class org.apache.cassandra.audit.AuditLogEntry
- getState() - Method in class org.apache.cassandra.repair.consistent.ConsistentSession
- getState(long) - Method in class org.apache.cassandra.service.disk.usage.DiskUsageMonitor
- getStatement(String) - Method in class org.apache.cassandra.utils.NoSpamLogger
- getStatement(String, long) - Method in class org.apache.cassandra.utils.NoSpamLogger
- getStatement(String, long, TimeUnit) - Method in class org.apache.cassandra.utils.NoSpamLogger
- getStatement(String, String) - Method in class org.apache.cassandra.utils.NoSpamLogger
- getStatement(String, String, long) - Method in class org.apache.cassandra.utils.NoSpamLogger
- 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
- getStatements() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
- getStateTimesMillis() - Method in class org.apache.cassandra.repair.state.AbstractState
- getStateTimesMillis() - Method in interface org.apache.cassandra.repair.state.State
- getStaticColumns() - Method in class org.apache.cassandra.db.SerializationHeader.Component
- getStaticOperations() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- getStatsMetadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- getStatus() - Method in class org.apache.cassandra.gms.EndpointState
- getStatus() - Method in class org.apache.cassandra.repair.state.AbstractState
- getStatus() - Method in interface org.apache.cassandra.repair.state.State
- 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
- getStorageCompatibilityMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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
- getStoredPreparedStatement(String, String) - Static method in class org.apache.cassandra.cql3.QueryProcessor
- 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
- getStrategySpec() - Static method in class org.apache.cassandra.service.paxos.ContentionStrategy
- getStreamId() - Method in class org.apache.cassandra.transport.Message
- getStreamId() - Method in exception org.apache.cassandra.transport.messages.ErrorMessage.WrappedException
- getStreamingComponents() - Method in class org.apache.cassandra.io.sstable.SSTable
-
Returns all SSTable components that should be streamed.
- getStreamingConnectionsPerHost() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getStreamingKeepAlivePeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getStreamingSlowEventsLogTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getStreamingSlowEventsLogTimeout() - Method in class org.apache.cassandra.streaming.StreamManager
- getStreamingSlowEventsLogTimeout() - Method in interface org.apache.cassandra.streaming.StreamManagerMBean
- getStreamingState(TimeUUID) - Method in class org.apache.cassandra.streaming.StreamManager
- getStreamingStateExpires() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getStreamingStates() - Method in class org.apache.cassandra.streaming.StreamManager
- getStreamingStateSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getStreamingStatsEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getStreamingStatsEnabled() - Method in class org.apache.cassandra.streaming.StreamManager
- getStreamingStatsEnabled() - Method in interface org.apache.cassandra.streaming.StreamManagerMBean
- 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
-
Deprecated.See CASSANDRA-17225
- GetStreamThroughput - Class in org.apache.cassandra.tools.nodetool
- GetStreamThroughput() - Constructor for class org.apache.cassandra.tools.nodetool.GetStreamThroughput
- getStreamThroughputAsDouble() - Method in class org.apache.cassandra.tools.NodeProbe
- getStreamThroughputMbitPerSec() - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-17225
- getStreamThroughputMbitPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.Use getStreamThroughputMbitPerSecAsDouble instead as this one will provide a rounded value. See CASSANDRA-17225
- getStreamThroughputMbitPerSecAsDouble() - Method in class org.apache.cassandra.service.StorageService
- getStreamThroughputMbitPerSecAsDouble() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getStreamThroughputMbPerSec() - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-15234
- getStreamThroughputMbPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.Use getStreamThroughputMebibytesPerSecAsDouble instead as this one will provide a rounded value. See CASSANDRA-15234
- getStreamThroughputMebibytesPerSec() - Method in class org.apache.cassandra.service.StorageService
- getStreamThroughputMebibytesPerSec() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Below method returns stream_throughput_outbound rounded, for precise number, please, use getStreamThroughputMebibytesPerSecAsDouble
- getStreamThroughputMebibytesPerSecAsDouble() - Method in class org.apache.cassandra.service.StorageService
- getStreamThroughputMebibytesPerSecAsDouble() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- getStreamThroughputMibAsDouble() - Method in class org.apache.cassandra.tools.NodeProbe
- getStreamThroughputOutboundBytesPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getStreamThroughputOutboundMebibytesPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getStreamThroughputOutboundMebibytesPerSecAsInt() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getStreamThroughputOutboundMegabitsPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getStreamThroughputOutboundMegabitsPerSecAsDouble() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getStreamTransferTaskTimeout() - 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(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a string. - 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(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
-
Returns the value for
name
as a string. - getString(String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
- getString(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
- getString(String) - Method in class org.apache.cassandra.security.AbstractSslContextFactory
- getString(String, String) - Method in class org.apache.cassandra.security.AbstractSslContextFactory
- getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
- getString(Collection<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.AbstractType
- getString(AbstractType<?>) - Method in class org.apache.cassandra.dht.AbstractBounds
- getString(ByteSource.Peekable) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
Converts the given
ByteSource
to a UTF-8String
. - 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(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.DynamicCompositeType.FixedValueComparator
- 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(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.VectorType
- getStringList(String) - Method in class org.apache.cassandra.security.AbstractSslContextFactory
- 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
- getSubtype() - Method in class org.apache.cassandra.cql3.functions.types.VectorType
- getSuccessMessage() - Method in interface org.apache.cassandra.repair.state.Completable
- 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.
- getSurvivalFactor(int) - Method in class org.apache.cassandra.db.compaction.unified.Controller
- 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 - getSystemKeyspaces() - Static method in class org.apache.cassandra.schema.SchemaConstants
-
Returns the set of all system keyspaces
- 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
-
Deprecated.See CASSANDRA-17195
- getTableCountWarnThreshold() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-17195
- 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.
- getTableGauge(ColumnFamilyStore) - Method in class org.apache.cassandra.io.sstable.GaugeProvider
- getTableGauge(ColumnFamilyStore) - Method in class org.apache.cassandra.io.sstable.SimpleGaugeProvider
- getTableId() - Method in class org.apache.cassandra.db.compaction.unified.ShardedMultiWriter
- 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.RangeAwareSSTableWriter
- getTableId() - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
- getTableId() - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
- getTableId() - Method in class org.apache.cassandra.io.sstable.SSTableZeroCopyWriter
- getTableId() - Method in interface org.apache.cassandra.streaming.IncomingStream
- getTableId() - Method in interface org.apache.cassandra.streaming.OutgoingStream
- getTableId(Row) - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosRows
- 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
- 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 andcfName
one of its existing column family. - getTableMetadata(String) - Method in class org.apache.cassandra.utils.NativeSSTableLoaderClient
- getTableMetadata(String, String) - Method in class org.apache.cassandra.schema.Schema
-
Given a keyspace name and table name, get the table meta data.
- getTableMetadata(String, String) - Method in interface org.apache.cassandra.schema.SchemaProvider
- getTableMetadata(Descriptor) - Method in class org.apache.cassandra.schema.Schema
- getTableMetadata(TableId) - Method in class org.apache.cassandra.schema.Schema
- getTableMetadata(TableId) - Method in interface org.apache.cassandra.schema.SchemaProvider
- getTableMetadataAsCQL(TableMetadata, KeyspaceMetadata) - 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() - Method in class org.apache.cassandra.io.sstable.SSTable.Builder
- 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(String, String) - Method in interface org.apache.cassandra.schema.SchemaProvider
- getTableMetadataRef(Descriptor) - Method in class org.apache.cassandra.schema.Schema
- getTableMetadataRef(Descriptor) - Method in interface org.apache.cassandra.schema.SchemaProvider
- getTableMetadataRef(TableId) - Method in class org.apache.cassandra.schema.Schema
-
Get Table metadata by its identifier
- getTableMetadataRef(TableId) - 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
- getTableName() - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
- getTableNullable(String) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
- 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
- getTablePropertiesDisallowed() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getTablePropertiesDisallowed() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getTablePropertiesDisallowed() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getTablePropertiesDisallowed() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getTablePropertiesDisallowedCSV() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getTablePropertiesDisallowedCSV() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getTablePropertiesIgnored() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getTablePropertiesIgnored() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getTablePropertiesIgnored() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getTablePropertiesIgnored() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getTablePropertiesIgnoredCSV() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getTablePropertiesIgnoredCSV() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getTablePropertiesWarned() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getTablePropertiesWarned() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getTablePropertiesWarned() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getTablePropertiesWarned() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getTablePropertiesWarnedCSV() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getTablePropertiesWarnedCSV() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getTables(String, String) - Static method in class org.apache.cassandra.metrics.SamplingManager
- getTablesAndViews(String) - Method in class org.apache.cassandra.schema.Schema
-
Get metadata about keyspace inner ColumnFamilies
- getTablesFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getTablesFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getTablesFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getTablesFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getTablesWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getTablesWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getTablesWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getTablesWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getTableUuid(Row) - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosRows
- getTag() - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
- getTargetDirectories() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
-
Get the directories this compaction could possibly write to.
- getTargetIndex() - Method in class org.apache.cassandra.db.filter.RowFilter.CustomExpression
- getTask() - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder.TaskSupplier
- 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() - Method in class org.apache.cassandra.index.sasi.sa.ByteTerm
- getTerm() - Method in class org.apache.cassandra.index.sasi.sa.CharTerm
- 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
- getTerm(int) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
- 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
- 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.ArrayLiteral
- 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 class org.apache.cassandra.cql3.Vectors.Literal
- getText() - Method in interface org.apache.cassandra.index.sasi.analyzer.StandardTokenizerInterface
- getThreadFactory() - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- getThreadFactory() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBase
- 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.
- getThreshold(int) - Method in class org.apache.cassandra.db.compaction.unified.Controller
- getTime(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a long in nanoseconds since midnight. - 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(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
-
Returns the value for
name
as a long in nanoseconds since midnight. - getTimeout(String) - Method in class org.apache.cassandra.tools.NodeProbe
- 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 - 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.See CASSANDRA-7544
- 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() - 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.
- getTimestamp(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a date. - getTimestamp(long, QueryOptions) - Method in class org.apache.cassandra.cql3.Attributes
- getTimestamp(long, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- getTimestamp(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
as a date. - getTimestamp(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
-
Returns the value for
name
as a date. - getTimestamp(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
- getTimestamp(QueryState) - Method in class org.apache.cassandra.cql3.BatchQueryOptions
- getTimestamp(QueryState) - Method in class org.apache.cassandra.cql3.QueryOptions
- 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) - Static 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) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- getTimeToLive(QueryOptions, TableMetadata) - Method in class org.apache.cassandra.cql3.Attributes
- getTimeUUID(String) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
- getToken() - Method in class org.apache.cassandra.db.DecoratedKey
- 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() - Method in class org.apache.cassandra.transport.messages.AuthChallenge
- getToken() - Method in class org.apache.cassandra.transport.messages.AuthSuccess
- getToken(String, String, String) - Method in class org.apache.cassandra.service.StorageService
- getToken(String, String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- 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
- 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() - 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() - Method in class org.apache.cassandra.tools.NodeProbe
- getTokens(String) - Method in class org.apache.cassandra.service.StorageService
- getTokens(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Fetch string representations of the tokens for a specified node.
- getTokens(String) - Method in class org.apache.cassandra.tools.NodeProbe
- getTokens(InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
- getTokenToEndpointMap() - Method in class org.apache.cassandra.service.StorageService
- getTokenToEndpointMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-7544
- 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
- getTopKRows(RowFilter.Expression) - Method in class org.apache.cassandra.index.sai.plan.QueryController
- getTopKRows(KeyRangeIterator, RowFilter.Expression) - Method in class org.apache.cassandra.index.sai.plan.QueryController
- getTopology() - Method in class org.apache.cassandra.locator.TokenMetadata
- getTopPartitions(TableMetadata, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
- getTopSizePartitionMap() - Method in class org.apache.cassandra.metrics.TopPartitionTracker
- getTopSizePartitions() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getTopSizePartitions() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
- getTopSizePartitionsLastUpdate() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getTopSizePartitionsLastUpdate() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
- getTopTombstonePartitionMap() - Method in class org.apache.cassandra.metrics.TopPartitionTracker
- getTopTombstonePartitions() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getTopTombstonePartitions() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
- getTopTombstonePartitionsLastUpdate() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- getTopTombstonePartitionsLastUpdate() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
- 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
- getTotalBytes() - Method in class org.apache.cassandra.io.sstable.KeyIterator
- getTotalBytes() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
- getTotalBytes(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
- 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
- getTotalCommitlogSpaceInMiB() - 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
- getTotalHintsSize(UUID) - Method in class org.apache.cassandra.hints.HintsService
-
Get the total size in bytes of all the hints files associating with the host on disk.
- 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
- getTotalPostings() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.PostingsWriter
- getTotalRemainingOngoingBytes() - Method in class org.apache.cassandra.streaming.StreamManager
- 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
- 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
- getTransferHintsOnDecommission() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getTransferHintsOnDecommission() - Method in class org.apache.cassandra.service.StorageService
- getTransferHintsOnDecommission() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- 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
- getTrickleFsyncIntervalInKiB() - 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.filter.BloomFilterTracker
- getTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.filter.BloomFilterTracker
- getTruncatedAt(TableId) - Static method in class org.apache.cassandra.db.SystemKeyspace
- getTruncatedPosition(TableId) - Static method in class org.apache.cassandra.db.SystemKeyspace
- 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
- getTruncateRpcTimeout(TimeUnit) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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.sai.StorageAttachedIndex
- getTruncateTask(long) - Method in class org.apache.cassandra.index.sasi.SASIIndex
- getTruncateTask(long) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- getTTL() - Method in class org.apache.cassandra.tracing.Tracing
- getTTL() - Method in enum org.apache.cassandra.tracing.Tracing.TraceType
- getTTLs(ProtocolVersion) - Method in class org.apache.cassandra.cql3.selection.Selector
- getTTLs(ProtocolVersion) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
- getTupleType(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.Tuples
- getTupleValue(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Return the
i
th value as a tuple value. - getTupleValue(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Return the value for
name
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() - Method in class org.apache.cassandra.cql3.CQL3Type.Vector
- getType() - Method in class org.apache.cassandra.cql3.functions.types.TupleValue
-
The tuple type this is a value of.
- 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.cql3.selection.VectorSelector
- getType() - Method in class org.apache.cassandra.db.marshal.VectorType.VectorSerializer
- getType() - Method in class org.apache.cassandra.db.SerializationHeader.Component
- 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.service.paxos.Ballot.Serializer
- 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
- getType() - Method in class org.apache.cassandra.utils.TimeUUID.Serializer
- getType(int) - Method in class org.apache.cassandra.cql3.functions.types.TupleValue
- getType(int) - Method in class org.apache.cassandra.cql3.functions.types.UDTValue
- getType(ColumnMetadata) - Method in class org.apache.cassandra.db.SerializationHeader
- 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.
- getTypeArguments() - Method in class org.apache.cassandra.cql3.functions.types.VectorType
- 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.UserFunctions
-
Get all UDAs overloads with the specified name
- getUdfs(FunctionName) - Method in class org.apache.cassandra.schema.UserFunctions
-
Get all UDFs overloads with the specified name
- getUDTValue(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Return the
i
th value as a UDT value. - getUDTValue(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Return the value for
name
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.
- getUIDGenerator(SSTableId.Builder<T>) - Method in class org.apache.cassandra.db.Directories
-
Initializes the sstable unique identifier generator using a provided builder for this instance of directories.
- 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
- getUncompressedLoadString() - Method in class org.apache.cassandra.service.StorageService
- getUncompressedLoadString() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Human-readable uncompressed load value
- getUncompressedLoadString() - Method in class org.apache.cassandra.tools.NodeProbe
- getUncompressedTablesEnabled() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getUncompressedTablesEnabled() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getUncompressedTablesEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Returns whether tables can be uncompressed
- getUncompressedTablesEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Returns whether users can disable compression on tables
- getUnescapedBytes(ByteSource.Peekable) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
Reads a single variable-length byte sequence (blob, string, ...) encoded according to the scheme described in ByteComparable.md, decoding it back to its original, unescaped form.
- 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.See CASSANDRA-7544
- getUnreachableNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-7544
- 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
- getUnsignedFixedLengthAsLong(ByteSource, int) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
Consume the given number of bytes and produce a long from them, effectively treating the bytes as a big-endian unsigned encoding of the number.
- getUnsignedShort(byte[], int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- getUnsignedShort(byte[], int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- getUnsignedShort(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- getUnsignedShort(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- getUnsignedShort(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
returns an unsigned short from offset {@param offset}
- getUnsignedVInt(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- getUnsignedVInt(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- getUnsignedVInt(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- getUnsignedVInt(V, ValueAccessor<V>, int) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- getUnsignedVInt(V, ValueAccessor<V>, int, int) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- getUnsignedVInt32(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
-
Read up to a 32-bit integer back, using the unsigned (no zigzag) encoding.
- getUnsignedVInt32(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- getUnsignedVInt32(V, ValueAccessor<V>, 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
- getUpdateCount() - Method in class org.apache.cassandra.index.sai.utils.AtomicRatio
- 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
- 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>, long) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
- getUserDefinedTask(Collection<SSTableReader>, long) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
- getUserDefinedTask(Collection<SSTableReader>, long) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
- getUserDefinedTask(Collection<SSTableReader>, long) - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
- getUserDefinedTask(Collection<SSTableReader>, long) - Method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- getUserDefinedTasks(Collection<SSTableReader>, long) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
Return a list of compaction tasks corresponding to the sstables requested.
- getUserDefinedTasks(AbstractStrategyHolder.GroupedSSTableContainer, long) - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder
- getUserDefinedTasks(AbstractStrategyHolder.GroupedSSTableContainer, long) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
- getUserDefinedTasks(AbstractStrategyHolder.GroupedSSTableContainer, long) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
- getUserFunctions(FunctionName) - Method in class org.apache.cassandra.schema.Schema
-
Get all user-defined function overloads with the specified name.
- getUserFunctionTimeoutPolicy() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getUserKeyspaces() - Method in class org.apache.cassandra.schema.Schema
-
Returns user keyspaces, that is all but
SchemaConstants.LOCAL_SYSTEM_KEYSPACE_NAMES
,SchemaConstants.REPLICATED_SYSTEM_KEYSPACE_NAMES
or virtual keyspaces. - getUserTimestampsEnabled() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getUserTimestampsEnabled() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getUserTimestampsEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Returns whether user-provided timestamps are allowed.
- getUserTimestampsEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Returns whether user-provided timestamps are allowed.
- 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.
- getUseStatementsEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getUseStatementsEnabled() - Method in class org.apache.cassandra.service.StorageProxy
- getUseStatementsEnabled() - Method in interface org.apache.cassandra.service.StorageProxyMBean
- getUUID(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a UUID. - getUUID(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
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(String, UUID) - 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>>, TimeUUID, TimeUUID, boolean, long, TopPartitionTracker.Collector) - Method in class org.apache.cassandra.db.repair.CassandraTableRepairManager
- getValidationIterator(Collection<Range<Token>>, TimeUUID, TimeUUID, boolean, long, TopPartitionTracker.Collector) - 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() - Method in enum org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer.TokenType
- getValue() - Method in interface org.apache.cassandra.metrics.CassandraMetricsRegistry.JmxGaugeMBean
- getValue() - Method in class org.apache.cassandra.service.FailureRecordingCallback.FailureResponses
- getValue(int) - Method in class org.apache.cassandra.cql3.selection.Selector.InputRow
-
Return the value of the column with the specified index.
- getValue(TableMetadata, DecoratedKey, Row) - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
- getValueCount() - Method in class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeWriter
- getValueOf(ColumnMetadata, Row, long) - Static method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
- getValues() - Method in class org.apache.cassandra.cql3.QueryOptions
- getValues() - Method in class org.apache.cassandra.cql3.selection.Selector.InputRow
-
Returns the column values as list.
- 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
- getVariableLengthInteger(ByteSource) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
Decode a variable-length signed integer.
- getVariableLengthUnsignedIntegerXoring(ByteSource, int) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
Decode a variable-length unsigned integer, passing all bytes read through XOR with the given xorWith parameter.
- getVarint(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a variable length integer. - getVarint(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
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. - getVector(int, TypeToken<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a vector, represented as a Java list. - getVector(int, Class<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns the
i
th value as a vector, represented as a Java list. - getVector(String, TypeToken<T>) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
as a vector, represented as a Java list. - getVector(String, TypeToken<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
-
Returns the value for
name
as a vector, represented as a Java list. - getVector(String, Class<T>) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns the value for
name
as a vector, represented as a Java list. - getVector(String, Class<T>) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
-
Returns the value for
name
as a vector, represented as a Java list. - getVector(String, AbstractType<T>, int) - Method in class org.apache.cassandra.cql3.UntypedResultSet.Row
- getVectorDimensionsFailThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getVectorDimensionsFailThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getVectorDimensionsFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getVectorDimensionsFailThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getVectorDimensionsWarnThreshold() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getVectorDimensionsWarnThreshold() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getVectorDimensionsWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getVectorDimensionsWarnThreshold() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getVectorParameters() - Method in class org.apache.cassandra.db.marshal.TypeParser
- getVerifier(ColumnFamilyStore, OutputHandler, boolean, IVerifier.Options) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- getVerifier(ColumnFamilyStore, OutputHandler, boolean, IVerifier.Options) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- getVerifier(ColumnFamilyStore, OutputHandler, boolean, IVerifier.Options) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns a new verifier for this sstable.
- getVerifyInfo() - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- getVerifyInfo() - Method in interface org.apache.cassandra.io.sstable.IVerifier
- getVersion() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
- getVersion() - Method in class org.apache.cassandra.schema.DistributedSchema
- getVersion() - Method in class org.apache.cassandra.schema.Schema
-
Returns the current schema version.
- getVersion() - Method in class org.apache.cassandra.transport.Connection
- getVersion(String) - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- getVersion(String) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- getVersion(String) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
- getVersion(String) - Method in interface org.apache.cassandra.net.MessagingServiceMBean
- getVersion(String) - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
- GetVersion - Class in org.apache.cassandra.tools
- GetVersion() - Constructor for class org.apache.cassandra.tools.GetVersion
- getVersionedLocalRanges(ColumnFamilyStore) - Static method in class org.apache.cassandra.db.DiskBoundaryManager
- getVersionedMaxDeletiontionTime() - Static method in class org.apache.cassandra.db.rows.Cell
- getVersionOrdinal(int) - Static method in class org.apache.cassandra.net.MessagingService
-
This is an optimisation to speed up the translation of the serialization version to the
MessagingService.Version
enum ordinal. - 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) - Method in class org.apache.cassandra.service.StorageService
- getViewBuildStatuses(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-7544
- getViewBuildStatuses(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
- getViewBuildStatuses(String, String, boolean) - Method in class org.apache.cassandra.service.StorageService
- 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.
- getVInt(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- getVInt(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- getVInt(V, ValueAccessor<V>, int) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- getVInt32(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- getVInt32(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- getVInt32(V, ValueAccessor<V>, int) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- getVisitedCount() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.VectorPostingList
- getWaiting() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue
-
Return how many threads are waiting
- getWaiting() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue.Standard
- getWarnings() - Method in class org.apache.cassandra.service.ClientWarn
- getWarnings() - Method in class org.apache.cassandra.transport.Message.Response
- getWhenDone() - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
-
Shared implementation of get() after suitable await(); assumes isDone(), and returns either the success result or throws the suitable exception under failure
- 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
- getWithFallback(String) - Static method in class org.apache.cassandra.schema.MemtableParams
- 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() - Method in class org.apache.cassandra.auth.AuthProperties
- getWriteConsistencyLevel() - Method in interface org.apache.cassandra.auth.AuthPropertiesMXBean
- getWriteConsistencyLevelsDisallowed() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getWriteConsistencyLevelsDisallowed() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getWriteConsistencyLevelsDisallowed() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getWriteConsistencyLevelsDisallowed() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getWriteConsistencyLevelsDisallowedCSV() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getWriteConsistencyLevelsDisallowedCSV() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getWriteConsistencyLevelsWarned() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getWriteConsistencyLevelsWarned() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getWriteConsistencyLevelsWarned() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- getWriteConsistencyLevelsWarned() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- getWriteConsistencyLevelsWarnedCSV() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getWriteConsistencyLevelsWarnedCSV() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- 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
- getWritePromise(Row) - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosRows
- getWriter(int) - Method in class org.apache.cassandra.cache.AutoSavingCache
- getWriteResponseHandler(ReplicaPlan.ForWrite, Runnable, WriteType, Supplier<Mutation>, Dispatcher.RequestTime) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
- getWriteResponseHandler(ReplicaPlan.ForWrite, Runnable, WriteType, Supplier<Mutation>, Dispatcher.RequestTime, ConsistencyLevel) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
- getWriterFactory() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- getWriterFactory() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- getWriterFactory() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
- 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
- getWriteRpcTimeout(TimeUnit) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- getWritetimes(ProtocolVersion) - Method in class org.apache.cassandra.cql3.selection.Selector
- getWritetimes(ProtocolVersion) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
- getYear() - Method in class org.apache.cassandra.cql3.functions.types.LocalDate
-
Returns the year.
- getZeroTTLOnTWCSEnabled() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getZeroTTLOnTWCSEnabled() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getZeroTTLOnTWCSEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Returns whether it is allowed to create or alter table to use 0 default TTL with TimeWindowCompactionStrategy.
- getZeroTTLOnTWCSEnabled() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Returns whether it is allowed to create or alter table to use 0 default TTL with TimeWindowCompactionStrategy.
- getZeroTTLOnTWCSWarned() - Method in class org.apache.cassandra.config.GuardrailsOptions
- getZeroTTLOnTWCSWarned() - Method in class org.apache.cassandra.db.guardrails.Guardrails
- getZeroTTLOnTWCSWarned() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Returns whether warnings will be emitted when usage of 0 default TTL on a table with TimeWindowCompactionStrategy is detected.
- getZeroTTLOnTWCSWarned() - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Returns whether warnings will be emitted when usage of 0 default TTL on a table with TimeWindowCompactionStrategy is detected.
- GIBIBYTES - org.apache.cassandra.config.DataStorageSpec.DataStorageUnit
- GIT_SHA - org.apache.cassandra.config.CassandraRelevantProperties
- 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 - Variable in class org.apache.cassandra.repair.state.ParticipateState
- global() - Static method in interface org.apache.cassandra.dht.IPartitioner
- global() - Method in class org.apache.cassandra.net.ResourceLimits.EndpointAndGlobal
- global(ResourceLimits.Limit) - Static method in class org.apache.cassandra.net.AbstractMessageHandler.WaitQueue
- Global() - Constructor for class org.apache.cassandra.concurrent.ExecutorFactory.Global
- Global() - Constructor for class org.apache.cassandra.repair.SharedContext.Global
- Global() - Constructor for class org.apache.cassandra.service.paxos.BallotGenerator.Global
- Global() - Constructor for class org.apache.cassandra.streaming.StreamingChannel.Factory.Global
- Global() - Constructor for class org.apache.cassandra.utils.Clock.Global
- Global() - Constructor for class org.apache.cassandra.utils.MonotonicClock.Global
- GLOBAL - org.apache.cassandra.service.paxos.Ballot.Flag
- GLOBAL_CLOCK - org.apache.cassandra.utils.Simulate.With
-
Calls to FBUtilities.timestampMicros() will be guaranteed globally monotonically increasing.
- 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_REQUEST_LIMITER - Static variable in class org.apache.cassandra.transport.ClientResourceLimits
- GLOBAL_TABLES_SPEC - org.apache.cassandra.cql3.ResultSet.Flag
- GLOBAL_WRITE_LATENCY - Static variable in class org.apache.cassandra.metrics.TableMetrics
- GlobalBufferPoolAllocator - Class in org.apache.cassandra.net
- 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
- go(long) - Method in class org.apache.cassandra.io.tries.Walker
- goMax(long) - Method in class org.apache.cassandra.io.tries.Walker
- goMin(long) - Method in class org.apache.cassandra.io.tries.Walker
- goodPartitions - Variable in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- goodPartitions - Variable in class org.apache.cassandra.io.sstable.IScrubber.ScrubResult
- goodRows - Variable in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- 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
- GoogleCloudSnitch(AbstractCloudMetadataServiceConnector) - Constructor for class org.apache.cassandra.locator.GoogleCloudSnitch
- GoogleCloudSnitch(SnitchProperties) - Constructor for class org.apache.cassandra.locator.GoogleCloudSnitch
- GOSSIP - org.apache.cassandra.concurrent.Stage
- GOSSIP_DIGEST_ACK - org.apache.cassandra.net.Verb
- GOSSIP_DIGEST_ACK2 - org.apache.cassandra.net.Verb
- GOSSIP_DIGEST_SYN - org.apache.cassandra.net.Verb
- GOSSIP_DISABLE_THREAD_VALIDATION - org.apache.cassandra.config.CassandraRelevantProperties
- GOSSIP_SETTLE_MIN_WAIT_MS - org.apache.cassandra.config.CassandraRelevantProperties
-
Delay before checking if gossip is settled.
- GOSSIP_SETTLE_POLL_INTERVAL_MS - org.apache.cassandra.config.CassandraRelevantProperties
-
Interval delay between checking gossip is settled.
- GOSSIP_SETTLE_POLL_SUCCESSES_REQUIRED - org.apache.cassandra.config.CassandraRelevantProperties
-
Number of polls without gossip state change to consider gossip as settled.
- GOSSIP_SHUTDOWN - org.apache.cassandra.net.Verb
- 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() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- gossiper() - Method in class org.apache.cassandra.repair.SharedContext.Global
- gossiper() - Method in interface org.apache.cassandra.repair.SharedContext
- Gossiper - Class in org.apache.cassandra.gms
-
This module is responsible for Gossiping information for the local endpoint.
- Gossiper(boolean) - Constructor for class org.apache.cassandra.gms.Gossiper
- GOSSIPER_QUARANTINE_DELAY - org.apache.cassandra.config.CassandraRelevantProperties
-
Gossip quarantine delay is used while evaluating membership changes and should only be changed with extreme care.
- GOSSIPER_SKIP_WAITING_TO_SETTLE - org.apache.cassandra.config.CassandraRelevantProperties
- 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
- GossipShutdown - Class in org.apache.cassandra.gms
- GossipShutdown(EndpointState) - Constructor for class org.apache.cassandra.gms.GossipShutdown
- GossipShutdown.Serializer - Class in org.apache.cassandra.gms
- 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.
- GRANT - org.apache.cassandra.audit.AuditLogEntryType
- 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
- GREATER_THAN - org.apache.cassandra.db.context.CounterContext.Relationship
- greaterBranch - Variable in class org.apache.cassandra.io.tries.Walker
- greaterTransition(int, long) - Method in class org.apache.cassandra.io.tries.Walker
- greaterTransition(ByteBuffer, int, long, int, long) - Method in class org.apache.cassandra.io.tries.TrieNode
-
Returns a transition that is higher than the index returned by
search
. - group - org.apache.cassandra.config.Config.CommitLogSync
- Group(List<T>, DataLimits) - Constructor for class org.apache.cassandra.db.SinglePartitionReadQuery.Group
- group_by_enabled - Variable in class org.apache.cassandra.config.Config
- GROUP_COMPLETION_MARKER - org.apache.cassandra.index.sai.disk.format.IndexComponent
-
If present indicates that the per-sstable index build completed successfully
- GROUP_EVERYTHING - Static variable in class org.apache.cassandra.db.aggregation.GroupMaker
-
GroupMaker
that groups all the rows together. - GROUP_KEY - Static variable in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- GROUP_META - org.apache.cassandra.index.sai.disk.format.IndexComponent
-
Metadata for per-SSTable on-disk components.
- GROUP_NAME - Static variable in class org.apache.cassandra.metrics.DefaultNameFactory
- groupByEnabled - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
- groupByLimits(int, int, int, AggregationSpecification) - Static method in class org.apache.cassandra.db.filter.DataLimits
- GroupByPartitionIterator(int, ConsistencyLevel, ClientState, Dispatcher.RequestTime) - Constructor for class org.apache.cassandra.service.pager.AggregationQueryPager.GroupByPartitionIterator
- GroupByPartitionIterator(int, ReadExecutionController, Dispatcher.RequestTime) - Constructor for class org.apache.cassandra.service.pager.AggregationQueryPager.GroupByPartitionIterator
- groupBySize(List<SSTableReader>, int) - Static method in class org.apache.cassandra.index.sai.StorageAttachedIndex
-
Splits SSTables into groups of similar overall size.
- 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.LeveledCompactionStrategy
-
Leveled compaction strategy has guarantees on the data contained within each level so we have to make sure we only create groups of SSTables with members from the same level.
- groupSSTablesForAntiCompaction(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
-
TWCS should not group sstables for anticompaction - this can mix new and old data
- GT - org.apache.cassandra.cql3.Operator
- GT - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader.Operator
- GT_NEXT_COMPONENT - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- GTE - org.apache.cassandra.cql3.Operator
- GTGT_NEXT_COMPONENT - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- guard(long, String, boolean, ClientState) - Method in class org.apache.cassandra.db.guardrails.Threshold
-
Apply the guardrail to the provided value, warning or failing if appropriate.
- guard(Set<T>, Consumer<T>, ClientState) - Method in class org.apache.cassandra.db.guardrails.Values
-
Triggers a warning for each of the provided values that is discouraged by this guardrail.
- guard(Set<T>, ClientState) - Method in class org.apache.cassandra.db.guardrails.Values
-
Triggers a warning for each of the provided values that is discouraged by this guardrail.
- guard(T, ClientState) - Method in class org.apache.cassandra.db.guardrails.Predicates
-
Apply the guardrail to the provided value, triggering a warning or failure if appropriate.
- Guardrail - Class in org.apache.cassandra.db.guardrails
-
General class defining a given guardrail that guards against some particular usage/condition.
- Guardrails - Class in org.apache.cassandra.db.guardrails
-
Entry point for Guardrails, storing the defined guardrails and providing a few global methods over them.
- GuardrailsConfig - Interface in org.apache.cassandra.db.guardrails
-
Configuration settings for guardrails.
- GuardrailsConfigProvider - Interface in org.apache.cassandra.db.guardrails
-
Provider of
GuardrailsConfig
s for aClientState
. - GuardrailsConfigProvider.Default - Class in org.apache.cassandra.db.guardrails
-
Default implementation of
GuardrailsConfigProvider
that always returns theGuardrailsConfig
parsed fromcassandra.yaml
, independently of theClientState
. - GuardrailsMBean - Interface in org.apache.cassandra.db.guardrails
-
JMX entrypoint for updating the default guardrails configuration parsed from
cassandra.yaml
. - GuardrailsOptions - Class in org.apache.cassandra.config
-
Configuration settings for guardrails populated from the Yaml file.
- GuardrailsOptions(Config) - Constructor for class org.apache.cassandra.config.GuardrailsOptions
- GuardrailViolatedException - Exception in org.apache.cassandra.db.guardrails
- guid() - Static method in class org.apache.cassandra.utils.GuidGenerator
- guidAsBytes() - Static method in class org.apache.cassandra.utils.GuidGenerator
- guidAsBytes(Random, String, long) - 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
- HALF_TIME_IN_S - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
- handle(Throwable) - Static method in class org.apache.cassandra.concurrent.ExecutionFailure
-
Invoke the relevant
Thread.UncaughtExceptionHandler
, ignoring (except for logging) anyCompactionInterruptedException
- handleCaseSensitivity(Map<String, Object>) - Static method in class org.apache.cassandra.utils.JsonUtils
-
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.
- handleConstructionFailure(Throwable) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
Constructors of subclasses, if they open any resources, should wrap that in a try-catch block and call this method in the 'catch' section after closing any resources opened in the constructor.
- 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
- handleFailSessionMessage(InetAddressAndPort, FailSession) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
- handleFailSessionMessage(FailSession) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSessions
- handleFinalizeCommitMessage(Message<? extends RepairMessage>) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
-
Finalizes the repair session, completing it as successful.
- handleFinalizePromise(Message<FinalizePromise>) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
- handleFinalizePromiseMessage(Message<? extends RepairMessage>) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSessions
- handleFinalizeProposeMessage(Message<? extends RepairMessage>) - 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(Notification, Object) - Method in class org.apache.cassandra.service.GCInspector
- handleNotification(Notification, Object) - Method in class org.apache.cassandra.utils.progress.jmx.JMXNotificationProgressListener
- handleNotification(INotification, Object) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
- handleNotification(INotification, Object) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- 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(INotification, Object) - Method in class org.apache.cassandra.service.SSTablesGlobalTracker
- 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. - handlePrepareMessage(Message<? extends RepairMessage>) - 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(Message<? extends RepairMessage>) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSessions
- handlePrepareResponse(Message<PrepareConsistentResponse>) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
- handleProgress(ProgressInfo) - Method in class org.apache.cassandra.streaming.StreamResultFuture
- handler - Variable in class org.apache.cassandra.service.reads.AbstractReadExecutor
- handler - Variable in enum org.apache.cassandra.utils.MBeanWrapper.OnException
- handler() - Method in enum org.apache.cassandra.net.Verb
- handlerAdded(ChannelHandlerContext) - Method in class org.apache.cassandra.net.AbstractMessageHandler
- handlerAdded(ChannelHandlerContext) - Method in class org.apache.cassandra.net.FrameDecoder
- handlers - Variable in class org.apache.cassandra.net.InboundConnectionSettings
- handlers() - Method in class org.apache.cassandra.streaming.StreamPlan
- handles(IndexTransaction.Type) - Method in interface org.apache.cassandra.index.Index.Group
- handles(IndexTransaction.Type) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- handles(IndexTransaction.Type) - Method in class org.apache.cassandra.index.SecondaryIndexManager
- handleScheduledSampling(String, String, int, int, int, int, List<String>, boolean) - Method in class org.apache.cassandra.tools.NodeProbe
- handleStartupFSError(Throwable) - Method in interface org.apache.cassandra.io.FSErrorHandler
- handleStartupFSError(Throwable) - Static method in class org.apache.cassandra.io.util.FileUtils
- handleStartupFSError(Throwable) - Method in class org.apache.cassandra.service.DefaultFSErrorHandler
- 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.
- handleStreamEvent(StreamEvent) - Method in class org.apache.cassandra.streaming.StreamingState
- 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.
- HANGUL - org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer.TokenType
- hardlink(Descriptor, Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.SSTable
- 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.
- HAS_MORE_PAGES - org.apache.cassandra.cql3.ResultSet.Flag
- hasAbortedSession() - Method in class org.apache.cassandra.streaming.StreamState
- hasAccessFromIp(InetSocketAddress) - Method in class org.apache.cassandra.auth.AuthenticatedUser
- hasAccessFromIp(RoleResource, InetAddress) - Method in class org.apache.cassandra.auth.AllowAllCIDRAuthorizer
- hasAccessFromIp(RoleResource, InetAddress) - Method in class org.apache.cassandra.auth.CassandraCIDRAuthorizer
- hasAccessFromIp(RoleResource, InetAddress) - Method in interface org.apache.cassandra.auth.ICIDRAuthorizer
-
Determines does the given role has access from CIDR groups associated with given IP
- hasAccurateMinMax() - Method in class org.apache.cassandra.io.sstable.format.Version
-
Deprecated.See CASSANDRA-18134
- 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').
- hasAnalyzer() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- hasAnalyzer(RowFilter.Expression) - Method in class org.apache.cassandra.index.sai.plan.QueryController
- hasAtleast(int, int) - Method in class org.apache.cassandra.locator.Replicas.ReplicaCount
- hasBallot(Ballot) - Method in class org.apache.cassandra.service.paxos.Commit
- hasBallotBeforeOrEqualTo(Row, Ballot) - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosRows
- 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
- hasChildren() - Method in class org.apache.cassandra.io.tries.Walker
- hasClustering - Variable in enum org.apache.cassandra.index.sai.utils.PrimaryKey.Kind
- 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.
- hasClustering() - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- hasClustering() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- 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.
- hasComponent(IndexComponent) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- hasComponent(IndexComponent, IndexIdentifier) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- 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
- hasCrossNodeTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- hasDataForPendingRepair(TimeUUID) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
- hasDataForSession(TimeUUID) - 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(long) - Method in class org.apache.cassandra.db.rows.BTreeRow
- hasDeletion(long) - 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?
- hasDiskSpaceForCompactionsAndStreams(Map<FileStore, Long>) - Static method in class org.apache.cassandra.db.Directories
-
Checks if there is enough space on all file stores to write the given amount of data.
- hasDiskSpaceForCompactionsAndStreams(Map<File, Long>, Map<File, Long>) - Method in class org.apache.cassandra.db.Directories
-
Sums up the space required for ongoing streams + compactions + expected new write size per FileStore and checks if there is enough space available.
- hasDiskSpaceForCompactionsAndStreams(Map<File, Long>, Map<File, Long>, Function<File, FileStore>) - Static method in class org.apache.cassandra.db.Directories
- hasEmptyCompactValue() - Method in class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
- hasEnoughLiveData(CachedPartition, long, boolean, boolean) - Method in class org.apache.cassandra.db.filter.DataLimits
- hasExistingRoles() - Static method in class org.apache.cassandra.auth.CassandraRoleManager
- 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
- hasFactory(FunctionName) - Method in class org.apache.cassandra.cql3.functions.NativeFunctions
-
Returns whether there is a function factory with the specified name.
- hasFailed() - Method in class org.apache.cassandra.repair.CoordinatedRepairResult
- hasFailedSession() - Method in class org.apache.cassandra.streaming.StreamState
- hasFilesToReplay() - Method in class org.apache.cassandra.db.commitlog.CommitLog
- 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
- hash3_x64_128(ByteBuffer, int, int, long, long[]) - Static method in class org.apache.cassandra.utils.MurmurHash
- hash32(ByteBuffer, int, int, int) - Static method in class org.apache.cassandra.utils.MurmurHash
- hashCode - Variable in class org.apache.cassandra.io.sstable.Component
- 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.DataRateSpec
- hashCode() - Method in class org.apache.cassandra.config.DataStorageSpec
- hashCode() - Method in class org.apache.cassandra.config.DurationSpec
- 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.config.EncryptionOptions.ServerEncryptionOptions
-
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.config.ParameterizedClass
- hashCode() - Method in class org.apache.cassandra.config.RetrySpec.MaxAttempt
- hashCode() - Method in class org.apache.cassandra.config.SubnetGroups
- hashCode() - Method in class org.apache.cassandra.cql3.CIDR
- 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.CQL3Type.Vector
- 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.masking.ColumnMask
- 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.types.VectorType
- hashCode() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
- hashCode() - Method in class org.apache.cassandra.cql3.functions.UDFDataType
- 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.selection.SimpleSelector
- hashCode() - Method in class org.apache.cassandra.cql3.selection.TermSelector
- hashCode() - Method in class org.apache.cassandra.cql3.selection.VectorSelector
- 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() - 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.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.CollectionType
- hashCode() - Method in class org.apache.cassandra.db.marshal.CompositeType
- hashCode() - Method in class org.apache.cassandra.db.marshal.CompositeType.Serializer
- hashCode() - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
- hashCode() - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType.Serializer
- hashCode() - Method in class org.apache.cassandra.db.marshal.TupleType
- hashCode() - Method in class org.apache.cassandra.db.marshal.UserType
- hashCode() - Method in class org.apache.cassandra.db.marshal.VectorType
- hashCode() - Method in class org.apache.cassandra.db.memtable.ShardBoundaries
- 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.ArtificialBoundMarker
- 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.hints.PendingHintsInfo
- hashCode() - Method in class org.apache.cassandra.index.Index.Group.Key
- hashCode() - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- hashCode() - Method in class org.apache.cassandra.index.sai.disk.format.Version
- hashCode() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
- hashCode() - Method in class org.apache.cassandra.index.sai.plan.Expression.Bound
- hashCode() - Method in class org.apache.cassandra.index.sai.plan.Expression
- hashCode() - Method in class org.apache.cassandra.index.sai.plan.Expression.Value
- hashCode() - Method in class org.apache.cassandra.index.sai.SSTableContext
- hashCode() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- hashCode() - Method in class org.apache.cassandra.index.sai.utils.IndexIdentifier
- hashCode() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
- hashCode() - Method in class org.apache.cassandra.index.sai.utils.PartitionInfo
- 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() - Method in class org.apache.cassandra.io.sstable.Component
- hashCode() - Method in class org.apache.cassandra.io.sstable.Component.Type
- hashCode() - Method in class org.apache.cassandra.io.sstable.Descriptor
- hashCode() - Method in class org.apache.cassandra.io.sstable.format.AbstractSSTableFormat
- 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.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.io.sstable.SequenceBasedSSTableId
- hashCode() - Method in class org.apache.cassandra.io.sstable.UUIDBasedSSTableId
- hashCode() - Method in class org.apache.cassandra.io.util.File
- hashCode() - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
-
It's not clear whether
AbstractReplicaCollection
should implement the order sensitivehashCode
ofList
or the order obliviousequals
ofSet
. - 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.state.Completable.Result
- hashCode() - Method in class org.apache.cassandra.repair.state.SyncState.Id
- 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.DistributedSchema
- hashCode() - Method in class org.apache.cassandra.schema.DroppedColumn
- 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.MemtableParams
- 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.UserFunctions
- 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.DataResurrectionCheck.Heartbeat
- 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.AbstractPaxosRepair.Failure
- hashCode() - Method in class org.apache.cassandra.service.paxos.Commit
- hashCode() - Method in class org.apache.cassandra.service.paxos.PaxosRepairHistory
- hashCode() - Method in class org.apache.cassandra.service.paxos.PaxosState.Key
- hashCode() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosKeyState
- 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.service.reads.thresholds.WarningsSnapshot.Counter
- hashCode() - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- hashCode() - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Warnings
- hashCode() - Method in class org.apache.cassandra.service.snapshot.SnapshotManifest
- hashCode() - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
- 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() - 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.RMIClientSocketFactoryImpl
- hashCode() - Method in class org.apache.cassandra.utils.RMIServerSocketFactoryImpl
- hashCode() - Method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram
- hashCode() - Method in class org.apache.cassandra.utils.TimeUUID
- hashCode(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
- hashCode(ClusteringPrefix<V>) - Static method in interface org.apache.cassandra.db.ClusteringPrefix
- hashCode(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- hashCount - Variable in class org.apache.cassandra.utils.BloomFilter
- HASHED_PASSWORD - org.apache.cassandra.auth.IRoleManager.Option
- HashMaskingFunction - Class in org.apache.cassandra.cql3.functions.masking
-
A
MaskingFunction
that replaces the specified column value by its hash according to the specified algorithm. - HashPassword - Class in org.apache.cassandra.tools
- HashPassword() - Constructor for class org.apache.cassandra.tools.HashPassword
- hasIfExistCondition() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- hasIfNotExistCondition() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- hasImprovedMinMax() - Method in class org.apache.cassandra.io.sstable.format.Version
- 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
- hasInflightAutoRepairs() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker
- 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
- hasKey() - Method in class org.apache.cassandra.security.PEMBasedSslContextFactory.PEMBasedKeyStoreContext
- hasKeyRange() - Method in class org.apache.cassandra.io.sstable.format.Version
- 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
- hasKeystore() - Method in class org.apache.cassandra.security.DisableSslContextFactory
- hasKeystore() - Method in class org.apache.cassandra.security.FileBasedSslContextFactory.FileBasedStoreContext
- hasKeystore() - Method in class org.apache.cassandra.security.FileBasedSslContextFactory
- hasKeystore() - Method in interface org.apache.cassandra.security.ISslContextFactory
-
Returns if this factory uses private keystore.
- hasKeystore() - Method in class org.apache.cassandra.security.PEMBasedSslContextFactory
-
Decides if this factory has a keystore defined - key material specified in files or inline to the configuration.
- 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
- hasLegacyMinMax() - Method in class org.apache.cassandra.io.sstable.format.Version
-
Deprecated.See CASSANDRA-18134
- hasLegacyShards(Cell<V>) - Static method in class org.apache.cassandra.db.rows.CounterCells
- 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.
- hasListeners() - Method in class org.apache.cassandra.cql3.QueryEvents
- hasLiveData(long, boolean) - Method in class org.apache.cassandra.db.rows.AbstractRow
- hasLiveData(long, 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.
- hasLocalRead() - Method in class org.apache.cassandra.service.reads.AbstractReadExecutor
- hasLower() - Method in class org.apache.cassandra.index.sasi.plan.Expression
- hasLowerBound() - Method in class org.apache.cassandra.db.Slices
-
Whether the slices instance has a lower bound, that is whether it's first slice start is
Slice.BOTTOM
. - hasMajorVersion3OrUnknownNodes() - 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
- hasMaskedColumns() - Method in class org.apache.cassandra.schema.TableMetadata
- 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.io.sstable.AbstractSSTableIterator
-
Checks if there are more slice to process.
- hasMoreSlices() - Method in class org.apache.cassandra.io.sstable.format.big.SSTableIterator
- hasMoreSlices() - Method in class org.apache.cassandra.io.sstable.format.big.SSTableReversedIterator
- hasName() - Method in class org.apache.cassandra.cql3.RoleName
- hasNext() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
- hasNext() - Method in class org.apache.cassandra.db.memtable.ShardedSkipListMemtable.MemtableUnfilteredPartitionIterator
- hasNext() - Method in class org.apache.cassandra.db.partitions.SingletonUnfilteredPartitionIterator
- hasNext() - Method in class org.apache.cassandra.db.repair.CassandraValidationIterator
- hasNext() - Method in interface 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.tries.TrieEntriesIterator
- 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.sai.analyzer.NonTokenizingAnalyzer
- hasNext() - Method in class org.apache.cassandra.index.sai.memory.MemtableTermsIterator
- hasNext() - Method in class org.apache.cassandra.index.sai.utils.InMemoryPartitionIterator
- hasNext() - Method in class org.apache.cassandra.index.sai.utils.InMemoryUnfilteredPartitionIterator
- 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.io.sstable.AbstractSSTableIterator.AbstractReader
- hasNext() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator
- hasNext() - Method in class org.apache.cassandra.io.sstable.EmptySSTableScanner
- hasNext() - Method in class org.apache.cassandra.io.sstable.format.SSTableScanner
- 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.AbstractGuavaIterator
- 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 class org.apache.cassandra.utils.BulkIterator.Adapter
- hasNext() - Method in interface org.apache.cassandra.utils.IndexedSearchIterator
- hasNextInternal() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator.AbstractReader
- hasNextInternal() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator.ForwardReader
- hasNonClusteredOrdering() - Method in class org.apache.cassandra.cql3.Ordering.Ann
- hasNonClusteredOrdering() - Method in class org.apache.cassandra.cql3.Ordering.Expression
- 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).
- hasOngoingOrPendingTasks() - Method in class org.apache.cassandra.db.compaction.CompactionManager
- 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
- hasOutboundKeystore() - Method in class org.apache.cassandra.security.DisableSslContextFactory
- hasOutboundKeystore() - Method in class org.apache.cassandra.security.FileBasedSslContextFactory
- hasOutboundKeystore() - Method in interface org.apache.cassandra.security.ISslContextFactory
-
Returns if this factory uses outbound keystore.
- hasOutboundKeystore() - Method in class org.apache.cassandra.security.PEMBasedSslContextFactory
-
Decides if this factory has an outbound keystore defined - key material specified in files or inline to the configuration.
- 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
- hasPartitionLevelDeletions - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
-
This boolean is used as an approximation of whether a given key can be guaranteed not to have partition deletions in this sstable.
- hasPartitionLevelDeletions(SSTableReader) - Method in class org.apache.cassandra.db.ReadCommand
- hasPartitionLevelDeletionsPresenceMarker() - Method in class org.apache.cassandra.io.sstable.format.Version
-
Records in th stats if the sstable has any partition deletions.
- hasPayload() - Method in class org.apache.cassandra.io.tries.Walker
- hasPending() - Method in class org.apache.cassandra.net.OutboundConnection
- hasPendingRepair() - Method in class org.apache.cassandra.io.sstable.format.Version
- hasPendingRepairSSTable(TimeUUID, SSTableReader) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
- hasPendingRepairSSTable(TimeUUID, SSTableReader) - Method in class org.apache.cassandra.db.compaction.PendingRepairHolder
- 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
, otherwisefalse
. - hasPosition() - Method in class org.apache.cassandra.io.util.SequentialWriter
- hasPrivilege(File, Directories.FileAction) - Static method in enum org.apache.cassandra.db.Directories.FileAction
- hasProcessing() - Method in interface org.apache.cassandra.cql3.selection.Selection.Selectors
-
Checks if this Selectors perform some processing
- hasProperty(String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
- hasQueueCapacity() - Method in class org.apache.cassandra.transport.Dispatcher
-
Checks if the item in the head of the queue has spent more than allowed time in the queue.
- hasRanges() - Method in interface org.apache.cassandra.db.DeletionInfo
- hasRanges() - Method in class org.apache.cassandra.db.MutableDeletionInfo
- hasReachedMinimumFlushSize() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder
- 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
- hasRequiredStatics(SSTableReader) - Method in class org.apache.cassandra.db.ReadCommand
- hasRoom() - Method in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
- hasRows() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
- hasRows() - Method in interface org.apache.cassandra.db.partitions.Partition
-
Whether the partition object has rows.
- hasSameBallot(Commit) - Method in class org.apache.cassandra.service.paxos.Commit
- 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 theMetric
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
- hasSnapshots - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
- 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
- hasStuffedOrFullNode() - Method in class org.apache.cassandra.service.disk.usage.DiskUsageBroadcaster
- 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. - hasSufficientLiveNodesForTopologyChange(Keyspace, Range<Token>, Collection<InetAddressAndPort>) - Static method in class org.apache.cassandra.service.paxos.PaxosRepair
-
checks if we have enough live nodes to perform a paxos repair for topology repair.
- 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
- hasTablePermission(TableMetadata, Permission) - Method in class org.apache.cassandra.service.ClientState
- hasTask() - Method in class org.apache.cassandra.concurrent.DebuggableTask.RunningDebuggableTask
- hasTokenSpaceCoverage() - Method in class org.apache.cassandra.io.sstable.format.Version
-
If the sstable has token space coverage data.
- 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
- hasUIntDeletionTime() - Method in class org.apache.cassandra.io.sstable.format.Version
-
This format raises the legacy int year 2038 limit to 2106 by using an uint instead
- hasUnrepairedMatches - Variable in class org.apache.cassandra.index.sai.QueryContext
-
true
if the local query for this context has matches from Memtable-attached indexes or indexes on unrepaired SSTables, andfalse
otherwise. - 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 instance 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 interface org.apache.cassandra.utils.concurrent.WaitQueue
-
getWaiting() > 0
- hasWaiters() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue.Standard
- haveWork - Variable in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
- head() - Method in class org.apache.cassandra.index.sai.analyzer.filter.FilterPipeline
- 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.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 - org.apache.cassandra.io.sstable.metadata.MetadataType
-
Serialization header
- 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
- HEADER_FOOTER - org.apache.cassandra.index.sai.IndexValidation
-
Basic header/footer validation, but no data validation (fast)
- 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) - Method in class org.apache.cassandra.utils.btree.BTreeSet
- 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
- heap_buffers - org.apache.cassandra.config.Config.MemtableAllocationType
- heap_dump_path - Variable in class org.apache.cassandra.config.Config
- HEAP_SIZE - Static variable in class org.apache.cassandra.db.rows.EncodingStats
- HeapCloner - Class in org.apache.cassandra.utils.memory
-
Cloner class that can be use to clone partition elements on heap.
- HeapPool - Class in org.apache.cassandra.utils.memory
- HeapPool(long, float, MemtableCleaner) - Constructor for class org.apache.cassandra.utils.memory.HeapPool
- HeapPool.Allocator - Class in org.apache.cassandra.utils.memory
- HeapPool.Logged - Class in org.apache.cassandra.utils.memory
- HeapPool.Logged.Listener - Interface in org.apache.cassandra.utils.memory
- HeapUtils - Class in org.apache.cassandra.utils
-
Utility to log heap histogram.
- Heartbeat(Instant) - Constructor for class org.apache.cassandra.service.DataResurrectionCheck.Heartbeat
- HEARTBEAT_FILE_CONFIG_PROPERTY - Static variable in class org.apache.cassandra.service.DataResurrectionCheck
- HeartBeatState - Class in org.apache.cassandra.gms
-
HeartBeat State associated with any given endpoint.
- HeartBeatState(int, int) - Constructor for class org.apache.cassandra.gms.HeartBeatState
- HeartBeatState(HeartBeatState) - Constructor for class org.apache.cassandra.gms.HeartBeatState
- height(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
- HELP_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
- helper - Variable in class org.apache.cassandra.db.UnfilteredDeserializer
- helper - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableIterator
- 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
- HEX - org.apache.cassandra.cql3.Constants.Type
- 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(boolean) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- HIBERNATE - Static variable in class org.apache.cassandra.gms.VersionedValue
- HIGH - org.apache.cassandra.utils.Nemesis.Traffic
- 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
- HIGHER - org.apache.cassandra.utils.AsymmetricOrdering.Op
- 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.
- HINT_REQ - org.apache.cassandra.net.Verb
- HINT_RSP - org.apache.cassandra.net.Verb
- hint_window_persistent_enabled - Variable in class org.apache.cassandra.config.Config
- 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 - 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
- hintOnFailure() - Method in class org.apache.cassandra.db.CounterMutation
- hintOnFailure() - Method in interface org.apache.cassandra.db.IMutation
- hintOnFailure() - Method in class org.apache.cassandra.db.Mutation
- hintOnFailure() - Method in class org.apache.cassandra.db.virtual.VirtualMutation
- hints_compression - Variable in class org.apache.cassandra.config.Config
- hints_directory - Variable in class org.apache.cassandra.config.Config
- hints_flush_period - 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 - an optional scheduled task to clean up the applicable hints files 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
- hintWindowPersistentEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- HIRAGANA - org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer.TokenType
- 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 - Variable in class org.apache.cassandra.db.partitions.ImmutableBTreePartition
- holder() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
- holder() - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
- holder() - Method in class org.apache.cassandra.db.partitions.ImmutableBTreePartition
- holder() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
- Holder() - Constructor for class org.apache.cassandra.db.compaction.CompactionInfo.Holder
- 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
- HOST_ID - org.apache.cassandra.gms.ApplicationState
- HOST_ID - Static variable in class org.apache.cassandra.hints.PendingHintsInfo
- hostAddress(InetSocketAddress, boolean) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
- hostAddressAndPort(InetSocketAddress) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
- 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 - Variable in class org.apache.cassandra.hints.PendingHintsInfo
- hostId(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- hosts - Variable in class org.apache.cassandra.tools.LoaderOptions
- hosts() - Method in class org.apache.cassandra.repair.asymmetric.HostDifferences
- 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
- hotReloadableFiles - Variable in class org.apache.cassandra.security.FileBasedSslContextFactory
-
List of files that trigger hot reloading of SSL certificates
- hsProxy - Variable in class org.apache.cassandra.tools.NodeProbe
- humanReadable - Variable in class org.apache.cassandra.tools.nodetool.stats.TableStatsHolder
- HYBRID - org.apache.cassandra.service.reads.SpeculativeRetryPolicy.Kind
- 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.
- ICIDRAuthorizer - Interface in org.apache.cassandra.auth
-
Backend for CIDR authorization feature
- ICIDRAuthorizer.CIDRAuthorizerMode - Enum in org.apache.cassandra.auth
-
Supported modes by CIDR authorizer
- ICompactionManager - Interface in org.apache.cassandra.db.compaction
- 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 - Variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
- id - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegment
- id - Variable in exception org.apache.cassandra.exceptions.PreparedQueryNotFoundException
- id - Variable in exception org.apache.cassandra.exceptions.UnknownTableException
- id - Variable in class org.apache.cassandra.io.sstable.Component.Type
- id - Variable in class org.apache.cassandra.io.sstable.Descriptor
- id - Variable in enum org.apache.cassandra.net.ConnectionType
- id - Variable in class org.apache.cassandra.net.Message.Header
- id - Variable in enum org.apache.cassandra.net.Verb
- id - Variable in class org.apache.cassandra.repair.state.AbstractCompletable
- id - Variable in class org.apache.cassandra.schema.IndexMetadata
- 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 - Variable in enum org.apache.cassandra.transport.messages.ResultMessage.Kind
- id - Variable in class org.apache.cassandra.utils.MBeanWrapper.InstanceMBeanWrapper
- id() - Method in class org.apache.cassandra.net.AbstractMessageHandler
- id() - Method in class org.apache.cassandra.net.InboundMessageHandler
- id() - Method in class org.apache.cassandra.net.Message
-
id of the request/message.
- id() - Method in class org.apache.cassandra.streaming.async.NettyStreamingChannel
- id() - Method in interface org.apache.cassandra.streaming.StreamingChannel
- id() - Method in class org.apache.cassandra.streaming.StreamingState
- id() - Method in class org.apache.cassandra.transport.CQLMessageHandler
- id(TableId) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- Id(RepairJobDesc, InetAddressAndPort, InetAddressAndPort, InetAddressAndPort) - Constructor for class org.apache.cassandra.repair.state.SyncState.Id
- ID - Static variable in class org.apache.cassandra.cql3.statements.schema.TableAttributes
- ID - Static variable in class org.apache.cassandra.db.compaction.CompactionInfo
- idComparator - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
- 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
- identifier() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- identity(Certificate[]) - Method in interface org.apache.cassandra.auth.MutualTlsCertificateValidator
-
This method should provide logic to extract identity out of a certificate to perform mTLS authentication.
- identity(Certificate[]) - Method in class org.apache.cassandra.auth.SpiffeCertificateValidator
- IDENTITY - org.apache.cassandra.config.Converters
-
This converter is used when we change the name of a cassandra.yaml configuration parameter but we want to be able to still use the old name too.
- IDENTITY_TO_ROLES - Static variable in class org.apache.cassandra.auth.AuthKeyspace
- IdentityCollection(Set<RefCounted.Tidy>) - Constructor for class org.apache.cassandra.utils.concurrent.Ref.IdentityCollection
- IDEOGRAPHIC - org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer.TokenType
- idFromFileName(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
- IDLE - org.apache.cassandra.tracing.TraceState.Status
- idReverseComparator - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
- 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.
- ifColumnExists(boolean) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
- ifColumnNotExists(boolean) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
- ifExists - Variable in class org.apache.cassandra.cql3.statements.schema.AlterTypeStatement
- ifFieldExists(boolean) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTypeStatement.Raw
- ifFieldNotExists(boolean) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTypeStatement.Raw
- ifile - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableIterator
- ifile - Variable in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
- IFilter - Interface in org.apache.cassandra.utils
- IFilter.FilterKey - Interface in org.apache.cassandra.utils
- IGenericSerializer<T,I extends java.io.DataInput,O extends java.io.DataOutput> - Interface in org.apache.cassandra.io
- ignore - org.apache.cassandra.config.Config.CommitFailurePolicy
- ignore - org.apache.cassandra.config.Config.DiskFailurePolicy
- ignore - org.apache.cassandra.config.Config.PaxosOnLinearizabilityViolation
- ignore - org.apache.cassandra.config.Config.UserFunctionTimeoutPolicy
- IGNORE - org.apache.cassandra.db.Directories.OnTxnErr
-
Ignore the problematic parts of the txn log file
- IGNORE - org.apache.cassandra.index.sai.disk.v1.vector.OnHeapGraph.InvalidVectorBehavior
- IGNORE - org.apache.cassandra.utils.MBeanWrapper.OnException
- IGNORE_CORRUPTED_SCHEMA_TABLES - org.apache.cassandra.config.CassandraRelevantProperties
- IGNORE_DC - org.apache.cassandra.config.CassandraRelevantProperties
-
Deprecated.See CASSANDRA-17797
- IGNORE_DYNAMIC_SNITCH_SEVERITY - org.apache.cassandra.config.CassandraRelevantProperties
- IGNORE_KERNEL_BUG_1057843_CHECK - org.apache.cassandra.config.CassandraRelevantProperties
- IGNORE_MISSING_NATIVE_FILE_HINTS - org.apache.cassandra.config.CassandraRelevantProperties
- IGNORE_NODES_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
- IGNORE_RACK - org.apache.cassandra.config.CassandraRelevantProperties
-
Deprecated.See CASSANDRA-17797
- IGNORE_UNREPLICATED_KS - Static variable in class org.apache.cassandra.repair.messages.RepairOption
- IGNORED_SCHEMA_CHECK_ENDPOINTS - org.apache.cassandra.config.CassandraRelevantProperties
- IGNORED_SCHEMA_CHECK_VERSIONS - org.apache.cassandra.config.CassandraRelevantProperties
- ignoreOverlaps - Variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
- 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
- ignoreOverlapsInExpirationCheck - Variable in class org.apache.cassandra.db.compaction.unified.Controller
- 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
- ignoringDeleted(Bits) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.OnDiskOrdinalsMap
- IGossiper - Interface in org.apache.cassandra.gms
- IInternodeAuthenticator - Interface in org.apache.cassandra.auth
- IInternodeAuthenticator.InternodeConnectionDirection - Enum in org.apache.cassandra.auth
-
Enum that represents connection type of internode connection.
- 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
- IMMEDIATE - org.apache.cassandra.concurrent.Stage
- ImmediateExecutor - Class in org.apache.cassandra.concurrent
- ImmediateFuture<V> - Class in org.apache.cassandra.utils.concurrent
- ImmutableBTreePartition - Class in org.apache.cassandra.db.partitions
- ImmutableBTreePartition(TableMetadata, DecoratedKey, BTreePartitionData) - Constructor for class org.apache.cassandra.db.partitions.ImmutableBTreePartition
- ImmutableBTreePartition(TableMetadata, DecoratedKey, RegularAndStaticColumns, Row, Object[], DeletionInfo, EncodingStats) - Constructor for class org.apache.cassandra.db.partitions.ImmutableBTreePartition
- immutableListWithFilteredNulls(T...) - Static method in class org.apache.cassandra.utils.FBUtilities
- Impl() - Constructor for class org.apache.cassandra.concurrent.ExecutorLocals.Impl
- Import - Class in org.apache.cassandra.tools.nodetool
- Import() - Constructor for class org.apache.cassandra.tools.nodetool.Import
- importNewSSTables(String, String, Set<String>, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Method in class org.apache.cassandra.tools.NodeProbe
- 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.See CASSANDRA-16407
- importNewSSTables(Set<String>, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- importNewSSTables(Set<String>, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.See CASSANDRA-18714
- importNewSSTables(Set<String>, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- importNewSSTables(Set<String>, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Load new sstables from the given directory
- 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
- in() - Method in class org.apache.cassandra.streaming.async.NettyStreamingChannel
- in() - Method in interface org.apache.cassandra.streaming.StreamingChannel
- IN - org.apache.cassandra.cql3.Operator
- IN - org.apache.cassandra.index.sasi.plan.Expression.Op
- IN - org.apache.cassandra.streaming.ProgressInfo.Direction
- IN_PROGRESS - org.apache.cassandra.db.monitoring.MonitoringState
- IN_PROGRESS - org.apache.cassandra.db.SystemKeyspace.BootstrapState
- IN_PROGRESS - org.apache.cassandra.service.ActiveRepairService.ParentRepairStatus
- IN_PROGRESS - org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional.State
- in_select_cartesian_product_fail_threshold - Variable in class org.apache.cassandra.config.Config
- in_select_cartesian_product_warn_threshold - Variable in class org.apache.cassandra.config.Config
- INBOUND - org.apache.cassandra.auth.IInternodeAuthenticator.InternodeConnectionDirection
- 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
InboundMessageHandler
s 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 - Variable in class org.apache.cassandra.net.MessagingService
- InboundSink - Class in org.apache.cassandra.net
-
A message sink that all inbound messages go through.
- Incident(LongSupplier, LongSupplier, long, int, int) - Constructor for class org.apache.cassandra.transport.QueueBackpressure.Incident
- INCL_END_BOUND - org.apache.cassandra.db.ClusteringPrefix.Kind
- INCL_END_EXCL_START_BOUNDARY - org.apache.cassandra.db.ClusteringPrefix.Kind
- INCL_START_BOUND - org.apache.cassandra.db.ClusteringPrefix.Kind
- 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_CATEGORIES - Static variable in class org.apache.cassandra.audit.AuditLogOptionsCompositeData.AuditLogOption
- included_keyspaces - Variable in class org.apache.cassandra.audit.AuditLogOptions
- INCLUDED_KEYSPACES - Static variable in class org.apache.cassandra.audit.AuditLogOptionsCompositeData.AuditLogOption
- included_users - Variable in class org.apache.cassandra.audit.AuditLogOptions
- INCLUDED_USERS - Static variable in class org.apache.cassandra.audit.AuditLogOptionsCompositeData.AuditLogOption
- includeRow(Object...) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
- includes(ColumnIdentifier) - Method in class org.apache.cassandra.schema.ViewMetadata
- includes(Clustering<?>) - Method in interface org.apache.cassandra.db.Slices.InOrderTester
- includes(ClusteringComparator, ClusteringPrefix<?>) - Method in class org.apache.cassandra.db.Slice
-
Returns whether a given clustering or bound is included in this slice.
- includes(RegularAndStaticColumns) - Method in class org.apache.cassandra.db.RegularAndStaticColumns
- includes(Cell<?>, LivenessInfo) - Method in class org.apache.cassandra.db.rows.DeserializationHelper
- includes(CellPath) - Method in class org.apache.cassandra.db.rows.DeserializationHelper
- includes(ColumnMetadata) - Method in class org.apache.cassandra.db.rows.DeserializationHelper
- 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.sai.plan.Expression.Bound
- inclusive - Variable in class org.apache.cassandra.index.sasi.plan.Expression.Bound
- inclusiveClose(boolean, ClusteringPrefix<V>, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
- 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
- inclusiveCloseExclusiveOpen(boolean, ClusteringPrefix<V>, DeletionTime, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
- 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
- inclusiveEndOf(ByteBuffer...) - Static method in class org.apache.cassandra.db.BufferClusteringBound
- inclusiveEndOf(ClusteringPrefix<V>) - 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, ClusteringPrefix<V>, DeletionTime) - Static method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
- 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
- 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<V>) - 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
- incomingTransition() - Method in interface org.apache.cassandra.db.tries.Trie.Cursor
- incompatible() - Method in class org.apache.cassandra.net.OutboundConnectionInitiator.Result
- INCOMPATIBLE_SCHEMA - org.apache.cassandra.exceptions.RequestFailureReason
- IncompatibleSchemaException - Exception in org.apache.cassandra.exceptions
- IncompatibleSchemaException(String) - Constructor for exception org.apache.cassandra.exceptions.IncompatibleSchemaException
- incompleteBallot() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosRepair
- inconclusiveDigests - Variable in class org.apache.cassandra.service.reads.repair.RepairedDataTracker
- incrAcceptedAccessCount(Set<String>) - Method in class org.apache.cassandra.metrics.CIDRAuthorizerMetrics
- incrCreatedHints(InetAddressAndPort) - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
- increaseIndent() - Method in class org.apache.cassandra.cql3.CqlBuilder
- increment(long) - Method in class org.apache.cassandra.index.sai.utils.NamedMemoryLimiter
- increment(Replica) - Method in class org.apache.cassandra.locator.Replicas.ReplicaCount
- incrementAborted() - Method in class org.apache.cassandra.db.compaction.CompactionManager
- incremental - Variable in class org.apache.cassandra.repair.state.ParticipateState
- incremental_backups - Variable in class org.apache.cassandra.config.Config
- INCREMENTAL_BACKUPS - org.apache.cassandra.schema.TableParams.Option
- INCREMENTAL_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
- incrementalBackups - Variable in class org.apache.cassandra.schema.TableParams
- incrementalBackups(boolean) - Method in class org.apache.cassandra.schema.TableParams.Builder
- IncrementalDeepTrieWriterPageAware<VALUE> - Class in org.apache.cassandra.io.tries
-
This class is a variant of
IncrementalTrieWriterPageAware
which is able to build even very deep tries. - IncrementalDeepTrieWriterPageAware(TrieSerializer<VALUE, ? super DataOutputPlus>, DataOutputPlus) - Constructor for class org.apache.cassandra.io.tries.IncrementalDeepTrieWriterPageAware
- IncrementalDeepTrieWriterPageAware(TrieSerializer<VALUE, ? super DataOutputPlus>, DataOutputPlus, int) - Constructor for class org.apache.cassandra.io.tries.IncrementalDeepTrieWriterPageAware
- IncrementalRepairTask - Class in org.apache.cassandra.repair
- IncrementalRepairTask(RepairCoordinator, TimeUUID, RepairCoordinator.NeighborsAndRanges, String[]) - Constructor for class org.apache.cassandra.repair.IncrementalRepairTask
- incrementalSessionCompleted(TimeUUID) - Method in class org.apache.cassandra.db.repair.CassandraTableRepairManager
- incrementalSessionCompleted(TimeUUID) - Method in interface org.apache.cassandra.repair.TableRepairManager
-
Called when the given incremental session has completed.
- IncrementalTrieWriter<VALUE> - Interface in org.apache.cassandra.io.tries
-
Common interface for incremental trie writers.
- IncrementalTrieWriter.PartialTail - Interface in org.apache.cassandra.io.tries
- IncrementalTrieWriterBase<VALUE,DEST,NODE extends org.apache.cassandra.io.tries.IncrementalTrieWriterBase.BaseNode<VALUE,NODE>> - Class in org.apache.cassandra.io.tries
-
Helper base class for incremental trie builders.
- IncrementalTrieWriterBase(TrieSerializer<VALUE, ? super DEST>, DEST, NODE) - Constructor for class org.apache.cassandra.io.tries.IncrementalTrieWriterBase
- IncrementalTrieWriterPageAware<VALUE> - Class in org.apache.cassandra.io.tries
-
Incremental builders of on-disk tries which packs trie stages into disk cache pages.
- IncrementalTrieWriterSimple<VALUE> - Class in org.apache.cassandra.io.tries
-
Incremental builder of on-disk tries.
- IncrementalTrieWriterSimple(TrieSerializer<VALUE, ? super DataOutputPlus>, DataOutputPlus) - Constructor for class org.apache.cassandra.io.tries.IncrementalTrieWriterSimple
- incrementAndGetGeneration() - Static method in class org.apache.cassandra.db.SystemKeyspace
- incrementCompactionsReduced() - Method in class org.apache.cassandra.db.compaction.CompactionManager
- incrementRangeReadsRejected() - Method in class org.apache.cassandra.metrics.DenylistMetrics
- incrementReadCount() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Increment the total read count and read rate for this SSTable.
- incrementReadsRejected() - Method in class org.apache.cassandra.metrics.DenylistMetrics
- incrementSstablesDropppedFromCompactions(long) - Method in class org.apache.cassandra.db.compaction.CompactionManager
- incrementToken() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
- incrementWritesRejected() - Method in class org.apache.cassandra.metrics.DenylistMetrics
- incrPastWindow(InetAddressAndPort) - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
- incrRejectedAccessCount(Set<String>) - Method in class org.apache.cassandra.metrics.CIDRAuthorizerMetrics
- INDEFINITE - Static variable in class org.apache.cassandra.service.StorageService
- index - Variable in class org.apache.cassandra.index.internal.CassandraIndexSearcher
- index - Variable in class org.apache.cassandra.index.sai.memory.MemoryIndex
- index - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskBlock.SearchResult
- index - Variable in class org.apache.cassandra.index.sasi.plan.Expression
- index(int) - Method in class org.apache.cassandra.io.sstable.format.big.IndexState
- index(String, String) - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
-
Creates a
DescribeStatement
forDESCRIBE INDEX
. - index(DecoratedKey, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.memory.IndexMemtable
- index(DecoratedKey, Clustering<?>, ByteBuffer) - Method in class org.apache.cassandra.index.sai.memory.MemtableIndex
- index(DecoratedKey, Row) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
- index(DecoratedKey, Row, Memtable) - Method in class org.apache.cassandra.index.sai.memory.MemtableIndexManager
- 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(ColumnIndex) - Constructor for class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
- INDEX - org.apache.cassandra.cql3.SchemaElement.SchemaElementType
- INDEX - org.apache.cassandra.schema.TableMetadata.Kind
- INDEX_ALREADY_EXISTS - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- INDEX_BUILD - org.apache.cassandra.db.compaction.OperationType
- INDEX_BUILD_COMPLETED - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- INDEX_BUILD_STARTED - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- INDEX_BUILDER_SUPPORT - Static variable in interface org.apache.cassandra.index.Index
-
Singleton instance of
CollatedViewIndexBuildingSupport
, which may be used by anyIndex
implementation. - INDEX_DUPLICATE_OF_EXISTING - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- INDEX_ENTRY_FOUND - org.apache.cassandra.io.sstable.SSTableReadsListener.SelectionReason
- INDEX_ENTRY_NOT_FOUND - org.apache.cassandra.io.sstable.SSTableReadsListener.SkippingReason
- INDEX_NAME - Static variable in class org.apache.cassandra.index.sai.virtual.SegmentsSystemView
- INDEX_NOT_AVAILABLE - org.apache.cassandra.exceptions.RequestFailureReason
- INDEX_NOT_FOUND - Static variable in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
- INDEX_OUT_OF_BOUNDS - Static variable in class org.apache.cassandra.index.sai.disk.v1.keystore.KeyLookup
- INDEX_REMOVED - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- INDEX_STATUS - org.apache.cassandra.gms.ApplicationState
- INDEX_SUMMARY - org.apache.cassandra.db.compaction.OperationType
- index_summary_capacity - Variable in class org.apache.cassandra.config.Config
- INDEX_SUMMARY_EXPECTED_KEY_SIZE - org.apache.cassandra.config.CassandraRelevantProperties
- index_summary_resize_interval - Variable in class org.apache.cassandra.config.Config
- INDEX_TABLE_FLUSH - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- Index.CollatedViewIndexBuildingSupport - Class in org.apache.cassandra.index
-
Default implementation of
IndexBuildingSupport
which uses aReducingKeyIterator
to obtain a collated view of the data in the SSTables. - Index.Group - Interface in org.apache.cassandra.index
-
Class providing grouped operations for indexes that communicate with each other.
- Index.Group.Key - Class in org.apache.cassandra.index
-
Group key is used to uniquely identify a
Index.Group
within a table - 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.QueryPlan - Interface in org.apache.cassandra.index
-
Specifies a set of compatible indexes to be used with a query according to its
RowFilter
, ignoring data ranges, limits, etc. - Index.Searcher - Interface in org.apache.cassandra.index
-
Performs the actual index lookup during execution of a ReadCommand.
- Index.Status - Enum in org.apache.cassandra.index
- 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
- IndexComponent - Class in org.apache.cassandra.io.sstable.format
- IndexComponent - Enum in org.apache.cassandra.index.sai.disk.format
-
This is a definitive list of all the on-disk components for all versions
- IndexComponent() - Constructor for class org.apache.cassandra.io.sstable.format.IndexComponent
- indexDescriptor - Variable in class org.apache.cassandra.index.sai.SSTableContext
- IndexDescriptor - Class in org.apache.cassandra.index.sai.disk.format
-
The
IndexDescriptor
is an analog of the SSTableDescriptor
and provides version specific information about the on-disk state of aStorageAttachedIndex
. - indexDiskAccessMode - Variable in class org.apache.cassandra.io.sstable.IOOptions
- indexedColumn - Variable in class org.apache.cassandra.index.internal.CassandraIndex
- indexedEntryClustering - Variable in class org.apache.cassandra.index.internal.IndexEntry
- IndexedExpression(StorageAttachedIndex) - Constructor for class org.apache.cassandra.index.sai.plan.Expression.IndexedExpression
- 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 - Class in org.apache.cassandra.index.sai.utils
- IndexEntry(DecoratedKey, Clustering<?>, long, ByteBuffer, Clustering<?>) - Constructor for class org.apache.cassandra.index.internal.IndexEntry
- indexerFor(Predicate<Index>, DecoratedKey, RegularAndStaticColumns, long, WriteContext, IndexTransaction.Type, Memtable) - Method in interface org.apache.cassandra.index.Index.Group
-
Creates an new
Indexer
object for updates to a given partition. - indexerFor(Predicate<Index>, DecoratedKey, RegularAndStaticColumns, long, WriteContext, IndexTransaction.Type, Memtable) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- indexerFor(Predicate<Index>, DecoratedKey, RegularAndStaticColumns, long, WriteContext, IndexTransaction.Type, Memtable) - Method in class org.apache.cassandra.index.SingletonIndexGroup
- indexerFor(DecoratedKey, RegularAndStaticColumns, long, WriteContext, IndexTransaction.Type, Memtable) - Method in interface org.apache.cassandra.index.Index
-
Creates an new
Indexer
object for updates to a given partition. - indexerFor(DecoratedKey, RegularAndStaticColumns, long, WriteContext, IndexTransaction.Type, Memtable) - Method in class org.apache.cassandra.index.internal.CassandraIndex
- indexerFor(DecoratedKey, RegularAndStaticColumns, long, WriteContext, IndexTransaction.Type, Memtable) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- indexerFor(DecoratedKey, RegularAndStaticColumns, long, WriteContext, IndexTransaction.Type, Memtable) - Method in class org.apache.cassandra.index.sasi.SASIIndex
- indexerFor(DecoratedKey, RegularAndStaticColumns, long, WriteContext, IndexTransaction.Type, Memtable) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- indexes - Variable in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
- indexes - Variable in class org.apache.cassandra.schema.TableMetadata
- indexes() - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- indexes(RegularAndStaticColumns) - Method in class org.apache.cassandra.index.sasi.SASIIndex
- indexes(Indexes) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- 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.SchemaKeyspaceTables
- 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
- indexFileCacheSize() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
-
Returns the amount of memory occupied by the index when it is initially loaded.
- indexFileCacheSize() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.IndexSegmentSearcher
- indexFileCacheSize() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.LiteralIndexSegmentSearcher
- indexFileCacheSize() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.NumericIndexSegmentSearcher
- indexFileCacheSize() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.Segment
- indexFileCacheSize() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.VectorIndexSegmentSearcher
- indexFileCacheSize() - Method in class org.apache.cassandra.index.sai.disk.v1.V1SSTableIndex
- indexFileCacheSize() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- IndexFileUtils - Class in org.apache.cassandra.index.sai.disk.io
- IndexFileUtils(SequentialWriterOption) - Constructor for class org.apache.cassandra.index.sai.disk.io.IndexFileUtils
- indexFilter() - Method in class org.apache.cassandra.index.sai.plan.QueryController
- indexFor(ClusteringPrefix<?>, int) - Method in class org.apache.cassandra.io.sstable.format.big.IndexState
- indexFor(RowFilter.Expression) - Method in class org.apache.cassandra.index.sai.plan.QueryController
- IndexGroupMetrics - Class in org.apache.cassandra.index.sai.metrics
- IndexGroupMetrics(TableMetadata, StorageAttachedIndexGroup) - Constructor for class org.apache.cassandra.index.sai.metrics.IndexGroupMetrics
- indexId - Variable in exception org.apache.cassandra.exceptions.UnknownIndexException
- indexIdentifier - Variable in class org.apache.cassandra.index.sai.disk.SSTableIndex
- IndexIdentifier - Class in org.apache.cassandra.index.sai.utils
-
This is a simple wrapper around the index identity.
- IndexIdentifier(String, String, String) - Constructor for class org.apache.cassandra.index.sai.utils.IndexIdentifier
- IndexInfo - Class in org.apache.cassandra.io.sstable
-
IndexInfo
is embedded in the indexed version ofRowIndexEntry
. - 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.io.sstable.format.big.BigFormatPartitionWriter
- indexInfoSerializer() - Method in interface org.apache.cassandra.io.sstable.format.big.RowIndexEntry.IndexSerializer
- indexInfoSerializer() - Method in class org.apache.cassandra.io.sstable.format.big.RowIndexEntry.Serializer
- IndexInputReader - Class in org.apache.cassandra.index.sai.disk.io
-
This is a wrapper over a Cassandra
RandomAccessReader
that provides anIndexInput
interface for Lucene classes that needIndexInput
. - indexLength - Variable in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryBuilder.ReadableBoundary
- indexLength() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableKeyReader
- 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() - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- 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
- indexMetrics() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- IndexMetrics - Class in org.apache.cassandra.index.sai.metrics
- IndexMetrics(StorageAttachedIndex, MemtableIndexManager) - Constructor for class org.apache.cassandra.index.sai.metrics.IndexMetrics
- IndexMode - Class in org.apache.cassandra.index.sasi.conf
- indexName - Variable in class org.apache.cassandra.cache.CacheKey
- indexName - Variable in class org.apache.cassandra.index.sai.utils.IndexIdentifier
- 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(long) - Method in class org.apache.cassandra.index.sai.disk.v1.bitpack.AbstractBlockPackedReader
- indexOf(long) - Method in class org.apache.cassandra.index.sai.disk.v1.LongArray.DeferredLongArray
- indexOf(long) - Method in interface org.apache.cassandra.index.sai.disk.v1.LongArray
-
Using the given value returns the first index corresponding to the value.
- 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.io.sstable.format.big.RowIndexEntry
- indexOutput - Variable in class org.apache.cassandra.index.sai.disk.v1.bitpack.AbstractBlockPackedWriter
- IndexOutputWriter - Class in org.apache.cassandra.index.sai.disk.io
-
This is a wrapper over a Cassandra
SequentialWriter
that provides a LuceneIndexOutput
interface for the Lucene index writers. - IndexOutputWriter(SequentialWriter) - Constructor for class org.apache.cassandra.index.sai.disk.io.IndexOutputWriter
- indexPartition(DecoratedKey, Set<Index>, int) - Method in class org.apache.cassandra.index.SecondaryIndexManager
- indexPartition(DecoratedKey, Set<Index>, int, RegularAndStaticColumns) - 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
- IndexPosIterator(PartitionIndex) - Constructor for class org.apache.cassandra.io.sstable.format.bti.PartitionIndex.IndexPosIterator
- indexPosition() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableKeyReader
- indexPosition(long) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableKeyReader
- indexQueryPlan() - Method in class org.apache.cassandra.db.ReadCommand
-
Index query plan chosen for this query.
- indexReadController() - Method in class org.apache.cassandra.db.ReadExecutionController
- indexReadSSTablesAbort(WarningsSnapshot.Counter) - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Builder
- indexReadSSTablesCount - Variable in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- indexReadSSTablesWarning(WarningsSnapshot.Counter) - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Builder
- 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.io.sstable.format.big.BigFormatPartitionWriter
- indexSearcher() - Method in class org.apache.cassandra.db.ReadCommand
- IndexSearchResultIterator - Class in org.apache.cassandra.index.sai.disk
- IndexSegmentSearcher - Class in org.apache.cassandra.index.sai.disk.v1.segment
-
Abstract reader for individual segments of an on-disk index.
- IndexSegmentSearcherContext - Class in org.apache.cassandra.index.sai.disk.v1.segment
- IndexSegmentSearcherContext(PrimaryKey, PrimaryKey, long, QueryContext, PeekablePostingList) - Constructor for class org.apache.cassandra.index.sai.disk.v1.segment.IndexSegmentSearcherContext
- indexSize - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
- indexSize() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata.ComponentMetadataMap
- indexSpecOf(ColumnSpecification) - Static method in class org.apache.cassandra.cql3.Lists
- IndexState - Class in org.apache.cassandra.io.sstable.format.big
- IndexState(AbstractSSTableIterator.AbstractReader, ClusteringComparator, RowIndexEntry, boolean, FileHandle) - Constructor for class org.apache.cassandra.io.sstable.format.big.IndexState
- indexStatus(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- IndexStatusManager - Class in org.apache.cassandra.index
-
Handles the status of an index across the ring, updating the status per index and endpoint in a per-endpoint map.
- indexSummary - Variable in class org.apache.cassandra.io.sstable.format.big.IndexSummaryComponent
- IndexSummary - Class in org.apache.cassandra.io.sstable.indexsummary
- IndexSummary(IPartitioner, Memory, int, Memory, long, int, int, int) - Constructor for class org.apache.cassandra.io.sstable.indexsummary.IndexSummary
- IndexSummary.IndexSummarySerializer - Class in org.apache.cassandra.io.sstable.indexsummary
- IndexSummaryBuilder - Class in org.apache.cassandra.io.sstable.indexsummary
- IndexSummaryBuilder(long, int, int) - Constructor for class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryBuilder
-
Build an index summary builder.
- IndexSummaryBuilder.ReadableBoundary - Class in org.apache.cassandra.io.sstable.indexsummary
-
Represents a boundary that is guaranteed fully readable in the summary, index file and data file.
- IndexSummaryComponent - Class in org.apache.cassandra.io.sstable.format.big
- IndexSummaryComponent(IndexSummary, DecoratedKey, DecoratedKey) - Constructor for class org.apache.cassandra.io.sstable.format.big.IndexSummaryComponent
- IndexSummaryManager<T extends SSTableReader & IndexSummarySupport<T>> - Class in org.apache.cassandra.io.sstable.indexsummary
-
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.indexsummary
- IndexSummaryMetrics<R extends SSTableReader & IndexSummarySupport<R>> - Class in org.apache.cassandra.io.sstable.indexsummary
- IndexSummaryMetrics() - Constructor for class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryMetrics
- 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.indexsummary
- IndexSummaryRedistribution(Map<TableId, LifecycleTransaction>, long, long) - Constructor for class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryRedistribution
- indexSummaryRedistributionTime - Variable in class org.apache.cassandra.metrics.CompactionMetrics
-
Time spent redistributing index summaries
- IndexSummarySerializer() - Constructor for class org.apache.cassandra.io.sstable.indexsummary.IndexSummary.IndexSummarySerializer
- IndexSummarySupport<T extends SSTableReader & IndexSummarySupport<T>> - Interface in org.apache.cassandra.io.sstable.indexsummary
- 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
- indexTermType - Variable in class org.apache.cassandra.index.sai.disk.SSTableIndex
- indexTermType - Variable in class org.apache.cassandra.index.sai.view.RangeTermTree
- IndexTermType - Class in org.apache.cassandra.index.sai.utils
-
This class is a representation of an
AbstractType
as an indexable type. - 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.
- indexType() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
- IndexValidation - Enum in org.apache.cassandra.index.sai
- indexValue - Variable in class org.apache.cassandra.index.internal.IndexEntry
- IndexViewManager - Class in org.apache.cassandra.index.sai.view
-
Maintain an atomic view for read requests, so that requests can read all data during concurrent compactions.
- IndexViewManager(StorageAttachedIndex) - Constructor for class org.apache.cassandra.index.sai.view.IndexViewManager
- indexWriter - Variable in class org.apache.cassandra.io.sstable.format.SortedTableWriter
- IndexWriter(BigTableWriter.Builder, SequentialWriter) - Constructor for class org.apache.cassandra.io.sstable.format.big.BigTableWriter.IndexWriter
- indexWriterConfig() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- IndexWriterConfig - Class in org.apache.cassandra.index.sai.disk.v1
-
Per-index config for storage-attached index writers.
- IndexWriterConfig(int, int, VectorSimilarityFunction, OptimizeFor) - Constructor for class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- 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 - org.apache.cassandra.cql3.CQL3Type.Native
- INET - org.apache.cassandra.cql3.functions.types.DataType.Name
- INET - org.apache.cassandra.transport.DataType
- 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
- 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
- inExecutor() - Method in interface org.apache.cassandra.concurrent.ExecutorPlus
- inExecutor() - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
- inExecutor() - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- inExecutor() - Method in class org.apache.cassandra.concurrent.SEPExecutor
- inExecutor() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorPlus
- inExecutor() - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- inferCdcIndexFile(File) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
-
Infer the corresponding cdc index file using its cdc commitlog file
- inferType(String, AssignmentTestable, AbstractType<?>, List<AbstractType<?>>) - Method in interface org.apache.cassandra.cql3.functions.FunctionParameter
-
Tries to infer the data type of the parameter for an argument in a call to the function.
- infiniteLoop(String, Interruptible.SimpleTask, InfiniteLoopExecutor.SimulatorSafe) - Method in interface org.apache.cassandra.concurrent.ExecutorFactory
-
Create and start a new InfiniteLoopExecutor to repeatedly invoke
runnable
. - infiniteLoop(String, Interruptible.Task, InfiniteLoopExecutor.SimulatorSafe, InfiniteLoopExecutor.Daemon, InfiniteLoopExecutor.Interrupts) - Method in class org.apache.cassandra.concurrent.ExecutorFactory.Default
- infiniteLoop(String, Interruptible.Task, InfiniteLoopExecutor.SimulatorSafe, InfiniteLoopExecutor.Daemon, InfiniteLoopExecutor.Interrupts) - Method in interface org.apache.cassandra.concurrent.ExecutorFactory
-
Create and start a new InfiniteLoopExecutor to repeatedly invoke
runnable
. - InfiniteLoopExecutor - Class in org.apache.cassandra.concurrent
- InfiniteLoopExecutor(String, Interruptible.Task, InfiniteLoopExecutor.Daemon) - Constructor for class org.apache.cassandra.concurrent.InfiniteLoopExecutor
- InfiniteLoopExecutor(BiFunction<String, Runnable, Thread>, String, Interruptible.Task, InfiniteLoopExecutor.Interrupts) - Constructor for class org.apache.cassandra.concurrent.InfiniteLoopExecutor
- InfiniteLoopExecutor(ExecutorFactory, String, Interruptible.Task, InfiniteLoopExecutor.Daemon) - Constructor for class org.apache.cassandra.concurrent.InfiniteLoopExecutor
- InfiniteLoopExecutor(ExecutorFactory, String, Interruptible.Task, InfiniteLoopExecutor.Daemon, InfiniteLoopExecutor.Interrupts) - Constructor for class org.apache.cassandra.concurrent.InfiniteLoopExecutor
- InfiniteLoopExecutor.Daemon - Enum in org.apache.cassandra.concurrent
- InfiniteLoopExecutor.InternalState - Enum in org.apache.cassandra.concurrent
- InfiniteLoopExecutor.Interrupts - Enum in org.apache.cassandra.concurrent
- InfiniteLoopExecutor.SimulatorSafe - Enum in org.apache.cassandra.concurrent
- info(long, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
- info(long, String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
- info(Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
- info(String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
- Info - Class in org.apache.cassandra.tools.nodetool
- Info() - Constructor for class org.apache.cassandra.tools.JMXTool.Info
- Info() - Constructor for class org.apache.cassandra.tools.nodetool.Info
- Info(JMXTool.Attribute[], JMXTool.Operation[]) - Constructor for class org.apache.cassandra.tools.JMXTool.Info
- INFO - org.apache.cassandra.utils.NoSpamLogger.Level
- InheritingClass - Class in org.apache.cassandra.config
- InheritingClass() - Constructor for class org.apache.cassandra.config.InheritingClass
- InheritingClass(String, String, Map<String, String>) - Constructor for class org.apache.cassandra.config.InheritingClass
- InheritingClass(Map<String, ?>) - Constructor for class org.apache.cassandra.config.InheritingClass
- inherits - Variable in class org.apache.cassandra.config.InheritingClass
- init() - Method in class org.apache.cassandra.auth.AuthCache
-
Do setup for the cache and MBean.
- init() - Static method in class org.apache.cassandra.auth.AuthenticatedUser
-
Use
AuthCacheService.initializeAndRegisterCaches()
rather than calling this directly - init() - Static method in class org.apache.cassandra.auth.Roles
-
Use
AuthCacheService.initializeAndRegisterCaches()
rather than calling this directly - init() - Static method in class org.apache.cassandra.metrics.ReadRepairMetrics
- init() - Static method in class org.apache.cassandra.metrics.RepairMetrics
- init() - Static method in class org.apache.cassandra.service.reads.thresholds.CoordinatorWarnings
- 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(String) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
-
Initialize the client.
- init(String) - Method in class org.apache.cassandra.utils.NativeSSTableLoaderClient
- init(String[]) - Method in class org.apache.cassandra.service.CassandraDaemon
-
Initialize the Cassandra Daemon based on the given Commons Daemon-specific arguments.
- init(String, String, int, ExecutorPlus.MaximumPoolSizeListener) - Method in interface org.apache.cassandra.concurrent.Stage.ExecutorServiceInitialiser
- init(Collection<Server>) - Method in class org.apache.cassandra.metrics.ClientMetrics
- 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(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(Set<SSTableReader>) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
-
Initialize this column index with specific set of SSTables.
- init(Range<Token>) - Method in class org.apache.cassandra.utils.MerkleTrees
-
Init a selected MerkleTree with an even tree distribution.
- init(NonTokenizingOptions, AbstractType<?>) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingAnalyzer
- 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(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamSession
-
Bind this session to report to specific
StreamResultFuture
and perform pre-streaming initialization. - INIT - org.apache.cassandra.repair.state.AbstractCompletable.Status
- INIT - org.apache.cassandra.streaming.StreamingState.Status
- INIT - Static variable in class org.apache.cassandra.repair.state.AbstractState
- initCache(LoadingCache<K, V>) - Method in class org.apache.cassandra.auth.AuthCache
-
(Re-)initialise the underlying cache.
- initCaches() - Method in class org.apache.cassandra.auth.AllowAllCIDRAuthorizer
- initCaches() - Method in class org.apache.cassandra.auth.CassandraCIDRAuthorizer
- initCaches() - Method in interface org.apache.cassandra.auth.ICIDRAuthorizer
-
Init caches held by CIDR authorizer
- 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() - Method in class org.apache.cassandra.security.DisableSslContextFactory
- initHotReloading() - Method in class org.apache.cassandra.security.FileBasedSslContextFactory
- initHotReloading() - Method in interface org.apache.cassandra.security.ISslContextFactory
-
Initializes hot reloading of the security keys/certs.
- initHotReloading() - Method in class org.apache.cassandra.security.PEMBasedSslContextFactory
-
This enables 'hot' reloading of the key/trust stores based on the last updated timestamps if they are file based.
- 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_TOKEN - org.apache.cassandra.config.CassandraRelevantProperties
- INITIAL_VALUE_NANOS - Static variable in class org.apache.cassandra.gms.FailureDetector
- initialComparator - Variable in class org.apache.cassandra.db.memtable.AbstractAllocatorMemtable
- 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.
- initialFactory - Variable in class org.apache.cassandra.db.memtable.AbstractAllocatorMemtable
- initialize() - Method in class org.apache.cassandra.audit.AuditLogManager
- initialize() - Static method in class org.apache.cassandra.metrics.PaxosMetrics
- initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.apache.cassandra.auth.CassandraLoginModule
-
Initialize this LoginModule.
- initializeAndRegisterCaches() - Static method in class org.apache.cassandra.auth.AuthCacheService
-
NOTE: Can only be called once per instance run.
- initializeChannel(EventLoopGroup, InetSocketAddress, Connection.Factory) - Method in class org.apache.cassandra.transport.PipelineConfigurator
- initializeClientTransports() - Method in class org.apache.cassandra.service.CassandraDaemon
- initializeCommitLogDiskAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- initialized() - Method in class org.apache.cassandra.utils.SigarLibrary
- INITIALIZED - org.apache.cassandra.streaming.StreamSession.State
- 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
- initializeTrackers() - Static method in class org.apache.cassandra.service.paxos.PaxosState
- initializeUnreachableNodeUnsafe(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
-
Creates a new dead
EndpointState
that isempty
. - initialLoad() - Method in class org.apache.cassandra.schema.PartitionDenylist
-
Performs initial load of the partition denylist.
- initialLoadPartitionDenylist() - Method in class org.apache.cassandra.service.StorageProxy
- 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
- initialValue() - Method in class org.apache.cassandra.utils.caching.TinyThreadLocalPool
- initiateMutation(Mutation, long, int, int, CommitLogReplayer) - Method in class org.apache.cassandra.db.commitlog.CommitLogReplayer.MutationInitiator
- initiateStreaming(EventLoop, OutboundConnectionSettings, OutboundConnectionInitiator.SslFallbackConnectionType) - 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.state.ParticipateState
- initiator - Variable in class org.apache.cassandra.repair.state.SyncState.Id
- initiator - Variable in class org.apache.cassandra.repair.state.ValidationState
- initiator - Variable in class org.apache.cassandra.repair.Validator
- initServer() - Method in class org.apache.cassandra.service.StorageService
- initServer(int) - Method in class org.apache.cassandra.service.StorageService
- initServer(int, 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
- InMarker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Tuples.InMarker
- InMemoryKeyRangeIterator - Class in org.apache.cassandra.index.sai.memory
- InMemoryKeyRangeIterator(SortedSet<PrimaryKey>) - Constructor for class org.apache.cassandra.index.sai.memory.InMemoryKeyRangeIterator
-
An in-memory
KeyRangeIterator
that uses aPriorityQueue
built from aSortedSet
which has no duplication as its backing store. - InMemoryKeyRangeIterator(PrimaryKey, PrimaryKey, PriorityQueue<PrimaryKey>) - Constructor for class org.apache.cassandra.index.sai.memory.InMemoryKeyRangeIterator
-
An in-memory
KeyRangeIterator
that uses aPriorityQueue
which may contain duplicated keys as its backing store. - InMemoryPartitionIterator - Class in org.apache.cassandra.index.sai.utils
- InMemoryPartitionIterator(ReadCommand, TreeMap<PartitionInfo, TreeSet<Unfiltered>>) - Constructor for class org.apache.cassandra.index.sai.utils.InMemoryPartitionIterator
- InMemoryReadTrie<T> - Class in org.apache.cassandra.db.tries
-
In-memory trie built for fast modification and reads executing concurrently with writes from a single mutator thread.
- InMemoryTrie<T> - Class in org.apache.cassandra.db.tries
-
In-memory trie built for fast modification and reads executing concurrently with writes from a single mutator thread.
- InMemoryTrie(BufferType) - Constructor for class org.apache.cassandra.db.tries.InMemoryTrie
- InMemoryTrie.SpaceExhaustedException - Exception in org.apache.cassandra.db.tries
-
Because we use buffers and 32-bit pointers, the trie cannot grow over 2GB of size.
- InMemoryTrie.UpsertTransformer<T,U> - Interface in org.apache.cassandra.db.tries
-
Somewhat similar to
Trie.MergeResolver
, this encapsulates logic to be applied whenever new content is being upserted into aInMemoryTrie
. - InMemoryUnfilteredPartitionIterator - Class in org.apache.cassandra.index.sai.utils
- InMemoryUnfilteredPartitionIterator(ReadCommand, TreeMap<PartitionInfo, TreeSet<Unfiltered>>) - Constructor for class org.apache.cassandra.index.sai.utils.InMemoryUnfilteredPartitionIterator
- inner() - Method in annotation type org.apache.cassandra.utils.Shared
- INNER - org.apache.cassandra.cql3.functions.masking.PartialMaskingFunction.Kind
-
Masks everything except the first
begin
and lastend
characters. - 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
- InOurDc - 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
- InputRow(ProtocolVersion, List<ColumnMetadata>, boolean) - Constructor for class org.apache.cassandra.cql3.selection.Selector.InputRow
- InputRow(ProtocolVersion, List<ColumnMetadata>, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.selection.Selector.InputRow
- inputStream(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- 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
- inSecondsString(String) - Static method in class org.apache.cassandra.config.DurationSpec.IntSecondsBound
-
Creates a
DurationSpec.IntSecondsBound
of the specified amount in seconds, expressed either as the number of seconds without unit, or as a regular quantity with unit. - inSelectCartesianProduct - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the number of restrictions created by a cartesian product of a CQL's
IN
query. - inSerializer - Variable in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
- insert(K) - Method in interface org.apache.cassandra.utils.btree.UpdateFunction
-
Computes the value that should be inserted in the BTree.
- insert(ColumnData) - Method in class org.apache.cassandra.db.partitions.BTreePartitionUpdater
- insert(ColumnData) - Method in interface org.apache.cassandra.db.rows.ColumnData.PostReconciliationFunction
- insert(ColumnData) - Method in class org.apache.cassandra.db.rows.ColumnData.Reconciler
- insert(Row) - Method in class org.apache.cassandra.db.partitions.BTreePartitionUpdater
- 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
- insert(V) - Method in class org.apache.cassandra.utils.btree.UpdateFunction.Simple
- INSERT - org.apache.cassandra.cql3.statements.StatementType
- 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() - Method in class org.apache.cassandra.security.AbstractCryptoProvider
-
The default installation runs
AbstractCryptoProvider.installator()
and after thatAbstractCryptoProvider.isHealthyInstallation()
. - install() - Static method in class org.apache.cassandra.security.ThreadAwareSecurityManager
- installator() - Method in class org.apache.cassandra.security.AbstractCryptoProvider
-
Returns a runnable which installs this crypto provider.
- installator() - Method in class org.apache.cassandra.security.DefaultCryptoProvider
- installator() - Method in class org.apache.cassandra.security.JREProvider
- instance - Static variable in class org.apache.cassandra.audit.AuditLogManager
- instance - Static variable in class org.apache.cassandra.auth.AuthCacheService
- instance - Static variable in class org.apache.cassandra.auth.AuthEvents
- instance - Static variable in class org.apache.cassandra.auth.AuthProperties
- 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.cql3.functions.NativeFunctions
- 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 variable in class org.apache.cassandra.db.CounterMutationVerbHandler
- instance - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
- instance - Static variable in interface org.apache.cassandra.db.guardrails.GuardrailsConfigProvider
- 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.LegacyTimeUUIDType
- 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 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.index.IndexStatusManager
- instance - Static variable in class org.apache.cassandra.index.sai.disk.io.IndexFileUtils
- instance - Static variable in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- 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.filter.BloomFilterMetrics
- instance - Static variable in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryManager
- instance - Static variable in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryMetrics
- instance - Static variable in class org.apache.cassandra.io.sstable.keycache.KeyCacheMetrics
- instance - Static variable in class org.apache.cassandra.io.sstable.SequenceBasedSSTableId.Builder
- instance - Static variable in class org.apache.cassandra.io.sstable.SSTableIdFactory
- instance - Static variable in class org.apache.cassandra.io.sstable.UUIDBasedSSTableId.Builder
- 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 variable in class org.apache.cassandra.repair.SharedContext.Global
- instance - Static variable in class org.apache.cassandra.repair.ValidationManager
- instance - Static variable in class org.apache.cassandra.schema.DefaultSchemaUpdateHandlerFactory
- instance - Static variable in class org.apache.cassandra.schema.Schema
- instance - Static variable in class org.apache.cassandra.schema.SchemaMutationsSerializer
- 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.SchemaUpdateHandlerFactoryProvider
- 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.CounterSerializer
- 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.UTF8Serializer
- instance - Static variable in class org.apache.cassandra.serializers.UUIDSerializer
- 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.disk.usage.DiskUsageBroadcaster
- instance - Static variable in class org.apache.cassandra.service.disk.usage.DiskUsageMonitor
- 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.Ballot.Serializer
- instance - Static variable in class org.apache.cassandra.service.paxos.v1.PrepareVerbHandler
- instance - Static variable in class org.apache.cassandra.service.paxos.v1.ProposeVerbHandler
- instance - Static variable in class org.apache.cassandra.service.PendingRangeCalculatorService
- 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.HeapCloner
- instance - Static variable in class org.apache.cassandra.utils.SigarLibrary
- instance - Static variable in class org.apache.cassandra.utils.streamhist.TombstoneHistogram.HistogramSerializer
- instance - Static variable in class org.apache.cassandra.utils.streamhist.TombstoneHistogram.LegacyHistogramSerializer
- instance - Static variable in class org.apache.cassandra.utils.TimeUUID.Serializer
- instance() - Static method in class org.apache.cassandra.db.context.CounterContext
- instance() - Static method in class org.apache.cassandra.diag.DiagnosticEventPersistence
- instance() - Static method in class org.apache.cassandra.diag.DiagnosticEventService
- instance() - Static method in class org.apache.cassandra.net.MessagingService
- instance() - Static method in class org.apache.cassandra.repair.RepairMessageVerbHandler
- instance() - Static method in class org.apache.cassandra.service.ActiveRepairService
- instance() - Static method in class org.apache.cassandra.service.paxos.cleanup.PaxosRepairState
- INSTANCE - org.apache.cassandra.utils.Backoff.None
- INSTANCE - Static variable in class org.apache.cassandra.concurrent.ImmediateExecutor
- INSTANCE - Static variable in class org.apache.cassandra.db.memtable.SkipListMemtableFactory
- INSTANCE - Static variable in exception org.apache.cassandra.repair.SomeRepairFailedException
- INSTANCE - Static variable in class org.apache.cassandra.service.reads.AlwaysSpeculativeRetryPolicy
- INSTANCE - Static variable in class org.apache.cassandra.service.reads.NeverSpeculativeRetryPolicy
- instanceId - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
- InstanceMBeanWrapper(String) - Constructor for class org.apache.cassandra.utils.MBeanWrapper.InstanceMBeanWrapper
- 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.
- instances - Variable in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Counter
- instantiateRebufferer() - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex
- instantiateRebufferer() - Method in class org.apache.cassandra.io.util.CompressedChunkReader
- instantiateRebufferer() - Method in class org.apache.cassandra.io.util.EmptyRebufferer
- instantiateRebufferer() - Method in interface org.apache.cassandra.io.util.RebuffererFactory
- instantiateRebufferer(RateLimiter) - Method in class org.apache.cassandra.io.util.FileHandle
- 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
- INSUFFICIENT_ENDPOINT - org.apache.cassandra.net.ResourceLimits.Outcome
- INSUFFICIENT_GLOBAL - org.apache.cassandra.net.ResourceLimits.Outcome
- INT - org.apache.cassandra.cql3.CQL3Type.Native
- INT - org.apache.cassandra.cql3.functions.types.DataType.Name
- INT - org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.TermSize
- INT - org.apache.cassandra.transport.DataType
- INT_SIZE - Static variable in class org.apache.cassandra.db.TypeSizes
- Int32Serializer - Class in org.apache.cassandra.serializers
- Int32Serializer - Class in org.apache.cassandra.utils
- Int32Serializer() - Constructor for class org.apache.cassandra.serializers.Int32Serializer
- Int32Serializer() - Constructor for class org.apache.cassandra.utils.Int32Serializer
- Int32Type - Class in org.apache.cassandra.db.marshal
- Int64Serializer - Class in org.apache.cassandra.utils
- Int64Serializer() - Constructor for class org.apache.cassandra.utils.Int64Serializer
- IntArrayPostingList - Class in org.apache.cassandra.index.sai.postings
- IntArrayPostingList(int[]) - Constructor for class org.apache.cassandra.index.sai.postings.IntArrayPostingList
- intBuffer() - Method in class org.apache.cassandra.io.util.MmappedRegions.Region
- intBuffer() - Method in interface org.apache.cassandra.io.util.Rebufferer.BufferHolder
- IntBytesBound(long) - Constructor for class org.apache.cassandra.config.DataStorageSpec.IntBytesBound
-
Creates a
DataStorageSpec.IntBytesBound
of the specified amount in bytes. - IntBytesBound(long, DataStorageSpec.DataStorageUnit) - Constructor for class org.apache.cassandra.config.DataStorageSpec.IntBytesBound
-
Creates a
DataStorageSpec.IntBytesBound
of the specified amount in the specified unit. - IntBytesBound(String) - Constructor for class org.apache.cassandra.config.DataStorageSpec.IntBytesBound
-
Creates a
DataStorageSpec.IntBytesBound
of the specified amount. - integer(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
- INTEGER - org.apache.cassandra.cql3.Constants.Type
- INTEGER_PRIMITIVE_LONG - org.apache.cassandra.config.Converters
- 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 - 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
-
Deprecated.Use
inter-dc-throttle-mib
instead. See CASSANDRA-17677 - INTER_DC_THROTTLE_MEBIBYTES - Static variable in class org.apache.cassandra.tools.LoaderOptions
- Intercept - Annotation Type in org.apache.cassandra.utils
- interDcThrottleBytes - Variable in class org.apache.cassandra.tools.LoaderOptions
- INTERFACES - org.apache.cassandra.utils.Shared.Recursive
- InteriorNode() - Constructor for class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
- INTERNAL_ADDRESS_AND_PORT - org.apache.cassandra.gms.ApplicationState
- INTERNAL_IP - org.apache.cassandra.gms.ApplicationState
-
Deprecated.See CASSANDRA-7544
- INTERNAL_RESPONSE - org.apache.cassandra.concurrent.Stage
- INTERNAL_RSP - org.apache.cassandra.net.Verb
-
Deprecated.See CASSANDRA-15066
- 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.DirectIOSegment
- 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
- INTERNALLY_FORCED - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- internalQueryState() - Static method in class org.apache.cassandra.cql3.QueryProcessor
- internalReadForView(DecoratedKey, long) - 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).
- internalRelease() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
- internalRelease() - Method in class org.apache.cassandra.index.sai.disk.v1.V1SSTableIndex
- internalResponse(Verb, T) - Static method in class org.apache.cassandra.net.Message
- internode_application_receive_queue_capacity - Variable in class org.apache.cassandra.config.Config
- internode_application_receive_queue_reserve_endpoint_capacity - Variable in class org.apache.cassandra.config.Config
- internode_application_receive_queue_reserve_global_capacity - Variable in class org.apache.cassandra.config.Config
- internode_application_send_queue_capacity - Variable in class org.apache.cassandra.config.Config
- internode_application_send_queue_reserve_endpoint_capacity - Variable in class org.apache.cassandra.config.Config
- internode_application_send_queue_reserve_global_capacity - 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_error_reporting_exclusions - Variable in class org.apache.cassandra.config.Config
- INTERNODE_EVENT_THREADS - org.apache.cassandra.config.CassandraRelevantProperties
- internode_max_message_size - Variable in class org.apache.cassandra.config.Config
- internode_socket_receive_buffer_size - Variable in class org.apache.cassandra.config.Config
- internode_socket_send_buffer_size - Variable in class org.apache.cassandra.config.Config
- internode_streaming_tcp_user_timeout - Variable in class org.apache.cassandra.config.Config
- internode_tcp_connect_timeout - Variable in class org.apache.cassandra.config.Config
- internode_tcp_user_timeout - Variable in class org.apache.cassandra.config.Config
- internode_timeout - Variable in class org.apache.cassandra.config.Config
- internodeCompression() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- InternodeConnectionUtils - Class in org.apache.cassandra.net
-
Class that contains certificate utility methods.
- InternodeConnectionUtils() - Constructor for class org.apache.cassandra.net.InternodeConnectionUtils
- InternodeConnectionUtils.ByteBufDiscardHandler - Class in org.apache.cassandra.net
-
Discard handler releases the received data silently.
- 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.concurrent.InfiniteLoopExecutor
- interrupt() - Method in interface org.apache.cassandra.concurrent.Interruptible
- 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)
- interrupt() - Method in class org.apache.cassandra.utils.memory.MemtableCleanerThread
- 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
- INTERRUPTED - org.apache.cassandra.concurrent.Interruptible.State
- Interruptible - Interface in org.apache.cassandra.concurrent
- Interruptible.SimpleTask - Interface in org.apache.cassandra.concurrent
-
A Task that only runs on NORMAL states
- Interruptible.State - Enum in org.apache.cassandra.concurrent
- Interruptible.Task - Interface in org.apache.cassandra.concurrent
- Interruptible.TerminateException - Exception in org.apache.cassandra.concurrent
- 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
- intersect(BlockBalancedTreeReader.IntersectVisitor, QueryEventListener.BalancedTreeEventListener, QueryContext) - Method in class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeReader
- intersect_filtering_query_enabled - Variable in class org.apache.cassandra.config.Config
- intersect_filtering_query_warned - Variable in class org.apache.cassandra.config.Config
- intersectFilteringQueryEnabled - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail to warn on or fail filtering queries that contain intersections on mutable columns at consistency levels that require coordinator reconciliation.
- INTERSECTION - org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.IteratorType
- intersectionNonWrapping(Range<T>) - Method in class org.apache.cassandra.dht.Range
-
Returns the intersection of this range with the provided one, assuming neither are wrapping.
- intersectionWith(Range<T>) - Method in class org.apache.cassandra.dht.Range
- intersects(Iterable<Range<Token>>) - Method in class org.apache.cassandra.repair.consistent.ConsistentSession
- intersects(Iterable<Range<Token>>, Iterable<Range<Token>>) - Static method in class org.apache.cassandra.dht.Range
- intersects(Iterable<Range<T>>) - Method in class org.apache.cassandra.dht.AbstractBounds
-
return true if @param range intersects any of the given @param ranges
- intersects(Collection<Range<Token>>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- intersects(ClusteringComparator, Slice) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
-
Whether the data selected by this filter intersects with the provided slice.
- intersects(ClusteringComparator, Slice) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
- intersects(ClusteringComparator, Slice) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
- intersects(ClusteringComparator, Slice) - Method in class org.apache.cassandra.db.Slice
-
Whether this slice and the provided slice intersects.
- intersects(Slice) - Method in class org.apache.cassandra.db.Slices
-
Checks whether any of the slices intersects witht the given one.
- intersects(AbstractBounds<PartitionPosition>) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.Segment
- intersects(AbstractBounds<T>) - Method in class org.apache.cassandra.dht.Range
- intersects(Bounds<T>) - Method in class org.apache.cassandra.dht.Bounds
- intersects(Bounds<T>) - Method in class org.apache.cassandra.dht.Range
- intersects(Range<T>) - Method in class org.apache.cassandra.dht.Range
- intersects(SSTableReader) - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
- intersects(SSTableReader) - Method in class org.apache.cassandra.db.ReadCommand
- intersects(SSTableReader) - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
- 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
- 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
- IntKibibytesBound(long) - Constructor for class org.apache.cassandra.config.DataStorageSpec.IntKibibytesBound
-
Creates a
DataStorageSpec.IntKibibytesBound
of the specified amount in kibibytes. - IntKibibytesBound(long, DataStorageSpec.DataStorageUnit) - Constructor for class org.apache.cassandra.config.DataStorageSpec.IntKibibytesBound
-
Creates a
DataStorageSpec.IntKibibytesBound
of the specified amount in the specified unit. - IntKibibytesBound(String) - Constructor for class org.apache.cassandra.config.DataStorageSpec.IntKibibytesBound
-
Creates a
DataStorageSpec.IntKibibytesBound
of the specified amount. - IntMebibytesBound(long) - Constructor for class org.apache.cassandra.config.DataStorageSpec.IntMebibytesBound
-
Creates a
DataStorageSpec.IntMebibytesBound
of the specified amount in mebibytes. - IntMebibytesBound(long, DataStorageSpec.DataStorageUnit) - Constructor for class org.apache.cassandra.config.DataStorageSpec.IntMebibytesBound
-
Creates a
DataStorageSpec.IntMebibytesBound
of the specified amount in the specified unit. - IntMebibytesBound(String) - Constructor for class org.apache.cassandra.config.DataStorageSpec.IntMebibytesBound
-
Creates a
DataStorageSpec.IntMebibytesBound
of the specified amount. - IntMillisecondsBound(double, TimeUnit) - Constructor for class org.apache.cassandra.config.DurationSpec.IntMillisecondsBound
-
Below constructor is used only for backward compatibility for the old commitlog_sync_group_window_in_ms before 4.1 Creates a
DurationSpec.IntMillisecondsBound
of the specified amount in the specified unit. - IntMillisecondsBound(long) - Constructor for class org.apache.cassandra.config.DurationSpec.IntMillisecondsBound
-
Creates a
DurationSpec.IntMillisecondsBound
of the specified amount in milliseconds. - IntMillisecondsBound(long, TimeUnit) - Constructor for class org.apache.cassandra.config.DurationSpec.IntMillisecondsBound
-
Creates a
DurationSpec.IntMillisecondsBound
of the specified amount in the specified unit. - IntMillisecondsBound(String) - Constructor for class org.apache.cassandra.config.DurationSpec.IntMillisecondsBound
-
Creates a
DurationSpec.IntMillisecondsBound
of the specified amount. - IntMinutesBound(long) - Constructor for class org.apache.cassandra.config.DurationSpec.IntMinutesBound
-
Creates a
DurationSpec.IntMinutesBound
of the specified amount in minutes. - IntMinutesBound(long, TimeUnit) - Constructor for class org.apache.cassandra.config.DurationSpec.IntMinutesBound
-
Creates a
DurationSpec.IntMinutesBound
of the specified amount in the specified unit. - IntMinutesBound(String) - Constructor for class org.apache.cassandra.config.DurationSpec.IntMinutesBound
-
Creates a
DurationSpec.IntMinutesBound
of the specified amount. - IntrusiveStack<T extends IntrusiveStack<T>> - Class in org.apache.cassandra.utils.concurrent
-
An efficient stack/list that is expected to be ordinarily either empty or close to, and for which we need concurrent insertions and do not need to support removal - i.e.
- IntrusiveStack() - Constructor for class org.apache.cassandra.utils.concurrent.IntrusiveStack
- IntrusiveStack.Setter<O,T> - Interface in org.apache.cassandra.utils.concurrent
- IntSecondsBound(long) - Constructor for class org.apache.cassandra.config.DurationSpec.IntSecondsBound
-
Creates a
DurationSpec.IntSecondsBound
of the specified amount in seconds. - IntSecondsBound(long, TimeUnit) - Constructor for class org.apache.cassandra.config.DurationSpec.IntSecondsBound
-
Creates a
DurationSpec.IntSecondsBound
of the specified amount in the specified unit. - IntSecondsBound(String) - Constructor for class org.apache.cassandra.config.DurationSpec.IntSecondsBound
-
Creates a
DurationSpec.IntSecondsBound
of the specified amount. - intSize() - Method in class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- inv_hash3_x64_128(long[]) - Static method in class org.apache.cassandra.utils.MurmurHash
- INVALID - org.apache.cassandra.exceptions.ExceptionCode
- INVALID_BUFFER_SIZE_ERROR - Static variable in class org.apache.cassandra.config.StorageAttachedIndexOptions
- INVALID_CUSTOM_INDEX_TARGET - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- INVALID_DELETION_TIME - Static variable in class org.apache.cassandra.db.rows.Cell
- 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() - 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() - Method in class org.apache.cassandra.db.DiskBoundaries
- invalidate() - Method in class org.apache.cassandra.db.DiskBoundaryManager
- invalidate() - Method in interface org.apache.cassandra.index.Index.Group
-
Called when the table associated with this group has been invalidated or all indexes in the group are removed.
- invalidate() - Method in class org.apache.cassandra.index.sai.memory.MemtableIndexManager
- invalidate() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- invalidate() - Method in class org.apache.cassandra.index.sai.view.IndexViewManager
-
Called when index is dropped.
- invalidate(boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- invalidate(boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- invalidate(K) - Method in class org.apache.cassandra.auth.AuthCache
-
Invalidate a key.
- 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
- invalidateCidrPermissions(String) - Method in class org.apache.cassandra.auth.CIDRPermissionsCache
-
Invalidate a role from CIDR permissions cache
- invalidateCidrPermissionsCache(String) - Method in class org.apache.cassandra.auth.AllowAllCIDRAuthorizer
- invalidateCidrPermissionsCache(String) - Method in class org.apache.cassandra.auth.CassandraCIDRAuthorizer
- invalidateCidrPermissionsCache(String) - Method in class org.apache.cassandra.auth.CIDRPermissionsManager
- invalidateCidrPermissionsCache(String) - Method in interface org.apache.cassandra.auth.CIDRPermissionsManagerMBean
-
Invalidate given role from CIDR permissions cache
- invalidateCidrPermissionsCache(String) - Method in interface org.apache.cassandra.auth.ICIDRAuthorizer
-
Invalidate given role from CIDR permissions cache
- invalidateCidrPermissionsCache(String) - Method in class org.apache.cassandra.tools.NodeProbe
- InvalidateCIDRPermissionsCache - Class in org.apache.cassandra.tools.nodetool
-
Nodetool command to invalidate CIDR permissions cache, for a give role or for all roles in the cache.
- InvalidateCIDRPermissionsCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidateCIDRPermissionsCache
- 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(Collection<Bounds<Token>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- 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 class org.apache.cassandra.auth.PasswordAuthenticator.CredentialsCache
- invalidateCredentials(String) - Method in interface org.apache.cassandra.auth.PasswordAuthenticator.CredentialsCacheMBean
- invalidateCredentialsCache() - Method in class org.apache.cassandra.tools.NodeProbe
- invalidateCredentialsCache(String) - Method in class org.apache.cassandra.tools.NodeProbe
- InvalidateCredentialsCache - Class in org.apache.cassandra.tools.nodetool
- InvalidateCredentialsCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidateCredentialsCache
- invalidateFile(String) - Method in class org.apache.cassandra.cache.ChunkCache
- invalidateJmxPermissionsCache() - Method in class org.apache.cassandra.tools.NodeProbe
- invalidateJmxPermissionsCache(String) - Method in class org.apache.cassandra.tools.NodeProbe
- InvalidateJmxPermissionsCache - Class in org.apache.cassandra.tools.nodetool
- InvalidateJmxPermissionsCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidateJmxPermissionsCache
- 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
- invalidateLocalRanges() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- invalidateNetworkPermissions(String) - Method in class org.apache.cassandra.auth.NetworkPermissionsCache
- invalidateNetworkPermissions(String) - Method in interface org.apache.cassandra.auth.NetworkPermissionsCacheMBean
- invalidateNetworkPermissionsCache() - Method in class org.apache.cassandra.tools.NodeProbe
- invalidateNetworkPermissionsCache(String) - Method in class org.apache.cassandra.tools.NodeProbe
- InvalidateNetworkPermissionsCache - Class in org.apache.cassandra.tools.nodetool
- InvalidateNetworkPermissionsCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidateNetworkPermissionsCache
- invalidatePermissions(String) - Method in class org.apache.cassandra.auth.jmx.AuthorizationProxy.JmxPermissionsCache
- invalidatePermissions(String) - Method in interface org.apache.cassandra.auth.jmx.AuthorizationProxy.JmxPermissionsCacheMBean
- invalidatePermissions(String, String) - Method in class org.apache.cassandra.auth.PermissionsCache
- invalidatePermissions(String, String) - Method in interface org.apache.cassandra.auth.PermissionsCacheMBean
- invalidatePermissionsCache() - Method in class org.apache.cassandra.tools.NodeProbe
- invalidatePermissionsCache(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
- InvalidatePermissionsCache - Class in org.apache.cassandra.tools.nodetool
- InvalidatePermissionsCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidatePermissionsCache
- invalidatePosition(FileHandle, long) - Method in class org.apache.cassandra.cache.ChunkCache
- invalidateRoles(String) - Method in class org.apache.cassandra.auth.RolesCache
- invalidateRoles(String) - Method in interface org.apache.cassandra.auth.RolesCacheMBean
- invalidateRolesCache() - Method in class org.apache.cassandra.tools.NodeProbe
- invalidateRolesCache(String) - Method in class org.apache.cassandra.tools.NodeProbe
- InvalidateRolesCache - Class in org.apache.cassandra.tools.nodetool
- InvalidateRolesCache() - Constructor for class org.apache.cassandra.tools.nodetool.InvalidateRolesCache
- 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(Collection<Bounds<Token>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- 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
- invalidNumberOfArgumentsException() - Method in class org.apache.cassandra.cql3.functions.FunctionFactory
- invalidRequest(String) - Static method in class org.apache.cassandra.cql3.statements.RequestValidations
-
Returns an
InvalidRequestException
with the specified message. - 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
- invFmix(long) - Static method in class org.apache.cassandra.utils.MurmurHash
- invoke() - Method in interface org.apache.cassandra.service.BatchlogResponseHandler.BatchlogCleanupCallback
- invoke(Object, Method, Object[]) - Method in class org.apache.cassandra.auth.jmx.AuthorizationProxy
- invokeAll(Collection<? extends Callable<T>>) - Method in interface org.apache.cassandra.concurrent.ExecutorPlus
- invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in interface org.apache.cassandra.concurrent.ExecutorPlus
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- invokeAny(Collection<? extends Callable<T>>) - Method in interface org.apache.cassandra.concurrent.ExecutorPlus
- invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in interface org.apache.cassandra.concurrent.ExecutorPlus
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- invokeDiskFailurePolicy - Variable in class org.apache.cassandra.io.sstable.IVerifier.Options
- invokeDiskFailurePolicy(boolean) - Method in class org.apache.cassandra.io.sstable.IVerifier.Options.Builder
- invokeOnFailure() - Method in interface org.apache.cassandra.net.RequestCallback
-
Returns true if the callback handles failure reporting - in which case the remove host will be asked to report failures to us in the event of a problem processing the request.
- invokeOnFailure() - Method in interface org.apache.cassandra.net.RequestCallbackWithFailure
- 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.
- IO_NETTY_EVENTLOOP_THREADS - org.apache.cassandra.config.CassandraRelevantProperties
- IO_NETTY_TRANSPORT_ESTIMATE_SIZE_ON_SUBMIT - org.apache.cassandra.config.CassandraRelevantProperties
- IO_NETTY_TRANSPORT_NONATIVE - org.apache.cassandra.config.CassandraRelevantProperties
- ioOptions - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderLoadingBuilder
- ioOptions - Variable in class org.apache.cassandra.io.sstable.SSTable
- IOOptions - Class in org.apache.cassandra.io.sstable
- IOOptions(DiskOptimizationStrategy, Config.DiskAccessMode, Config.DiskAccessMode, double, SequentialWriterOption, Config.FlushCompression) - Constructor for class org.apache.cassandra.io.sstable.IOOptions
- 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
- IPV6_SOCKET_ADDRESS_SIZE - Static variable in class org.apache.cassandra.utils.ObjectSizes
- 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(SSTableFormat<?, ?>) - Static method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- is(SSTableFormat<?, ?>) - Static method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- IS_BOOTSTRAPPING - org.apache.cassandra.exceptions.ExceptionCode
- IS_EMPTY - Static variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
- IS_NOT - org.apache.cassandra.cql3.Operator
- 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
- isAborted() - Method in class org.apache.cassandra.streaming.SessionInfo
- isAbsolute() - Method in class org.apache.cassandra.io.util.File
- isAcceptable(Path) - Method in class org.apache.cassandra.service.snapshot.TableSnapshot.SnapshotTrueSizeCalculator
-
Snapshots are composed of hard-linked sstables.
- isAcceptable(Path) - Method in class org.apache.cassandra.utils.DirectorySizeCalculator
- isAccepted() - Method in class org.apache.cassandra.repair.state.AbstractCompletable
- isAccepted() - Method in class org.apache.cassandra.repair.state.AbstractState
- isAccepted() - Method in class org.apache.cassandra.repair.state.ParticipateState
- 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
- isActive() - Method in class org.apache.cassandra.metrics.Sampler
- isActive() - Method in class org.apache.cassandra.net.FrameDecoder
- isActive() - Method in class org.apache.cassandra.repair.ValidationTask
- isAdministrativelyInactiveState(EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
- isAdministrativelyInactiveState(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
- isAfter(long) - Method in interface org.apache.cassandra.utils.MonotonicClock
- isAfter(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 interface org.apache.cassandra.utils.MonotonicClock
- isAfter(long, long) - Method in class org.apache.cassandra.utils.MonotonicClock.SampledClock
- isAfter(long, long) - Method in class org.apache.cassandra.utils.MonotonicClock.SystemClock
- isAfter(Ballot) - Method in class org.apache.cassandra.service.paxos.Commit
- isAfter(Ballot, Ballot) - Static method in class org.apache.cassandra.service.paxos.Commit
- isAfter(Ballot, Commit) - Static method in class org.apache.cassandra.service.paxos.Commit
- isAfter(Commit) - Method in class org.apache.cassandra.service.paxos.Commit
- isAfter(Commit, Ballot) - Static method in class org.apache.cassandra.service.paxos.Commit
- isAfter(Commit, Commit) - Static method in class org.apache.cassandra.service.paxos.Commit
- isAfter(OpOrder.Group) - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Barrier
- isAggregate() - Method in interface org.apache.cassandra.cql3.functions.Function
-
Checks whether the function is an aggregate function or not.
- isAggregate() - Method in class org.apache.cassandra.cql3.functions.NativeAggregateFunction
- isAggregate() - Method in class org.apache.cassandra.cql3.functions.NativeScalarFunction
- isAggregate() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
- isAggregate() - Method in class org.apache.cassandra.cql3.functions.UDFunction
- isAggregate() - Method in class org.apache.cassandra.cql3.selection.Selection
- isAggregate() - Method in 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(InetAddressAndPort) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
- isAlive(Replica) - Method in class org.apache.cassandra.locator.ReplicaPlan.ForWrite
-
Test liveness, consistent with the upfront analysis done for this operation (i.e.
- isAllTablesLevel() - Method in class org.apache.cassandra.auth.DataResource
- isAnalyzed - Variable in class org.apache.cassandra.index.sasi.conf.IndexMode
- isAncestorOf(File) - Method in class org.apache.cassandra.io.util.File
- isANN() - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.AnnRestriction
- isANN() - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
- isAnonymous() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
If IAuthenticator doesn't require authentication, this method may return true.
- isArtificial() - Method in interface org.apache.cassandra.db.ClusteringBound
- 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
- 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
- isAutoHintsCleanupEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- isAutoRepairsEnabled() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker
- isAutoSnapshot() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- isAutoSnapshotEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- 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 interface org.apache.cassandra.utils.NativeLibraryWrapper
-
Checks if the library has been successfully linked.
- isBackPressureEnabled() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Deprecated.See CASSANDRA-15375
- isBackPressureEnabled() - Method in class org.apache.cassandra.net.MessagingServiceMBeanImpl
- isBefore(int) - Method in enum org.apache.cassandra.utils.StorageCompatibilityMode
- isBefore(Ballot) - Method in class org.apache.cassandra.service.paxos.Commit
- 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
- isBootstrapFailed() - Method in class org.apache.cassandra.service.StorageService
- isBootstrapFailed() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns whether a node has failed to bootstrap.
- 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(Arguments) - 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.FutureDelegate
- isCancellable() - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- isCancelled() - Method in class org.apache.cassandra.net.FutureDelegate
- isCancelled() - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- isCancelled() - Method in class org.apache.cassandra.utils.concurrent.NotScheduledFuture
- 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
- isCDCOnRepairEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- isCDCOnRepairEnabled() - Method in class org.apache.cassandra.db.commitlog.CommitLog
- isCDCOnRepairEnabled() - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Returns true if internodes streaming of CDC data should go through write path
- isClean() - Method in interface org.apache.cassandra.db.memtable.Memtable
-
True if the memtable contains no data
- isClean() - Method in class org.apache.cassandra.db.memtable.ShardedSkipListMemtable
- isClean() - Method in class org.apache.cassandra.db.memtable.SkipListMemtable
- isClean() - Method in class org.apache.cassandra.db.memtable.TrieMemtable
- 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
-
Deprecated.migrate to
DatabaseDescriptor.isClientInitialized()
See CASSANDRA-12550 - 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
- isClosed - Variable in class org.apache.cassandra.io.sstable.format.SSTableScanner
- 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
- isCollection(Property) - Static method in class org.apache.cassandra.config.Properties
- 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.
- isCommutative - Variable in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- 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
- isCompactor(Thread) - Static method 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, andfalse
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. - isComplete() - Method in class org.apache.cassandra.index.sai.disk.RowMapping
- isComplete() - Method in interface org.apache.cassandra.repair.state.Completable
- isComplete() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosRepair
- isComplete() - Method in class org.apache.cassandra.streaming.StreamingState
- 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.ConsistentSession
- isCompleted() - Method in class org.apache.cassandra.streaming.ProgressInfo
- isComplex() - Method in class org.apache.cassandra.schema.ColumnMetadata
- isComposite() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Returns
true
if the index type is a composite type, e.g. - 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(Path, Path) - Static method in class org.apache.cassandra.io.util.PathUtils
-
Return true if file's canonical path is contained in folder's canonical path.
- isContained(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Return true if file is contained in folder
- isContains() - Method in enum org.apache.cassandra.cql3.Operator
-
Checks if this operator is CONTAINS operator.
- 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 aCONTAINS
operator. - isContainsKey() - Method in enum org.apache.cassandra.cql3.Operator
-
Checks if this operator is CONTAINS KEY 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 aCONTAINS_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() - Method in class org.apache.cassandra.schema.TableMetadata
- isCounter(boolean) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- 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.CassandraUInt
- 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.
- IScrubber - Interface in org.apache.cassandra.io.sstable
- IScrubber.Options - Class in org.apache.cassandra.io.sstable
- IScrubber.Options.Builder - Class in org.apache.cassandra.io.sstable
- IScrubber.ScrubResult - Class in org.apache.cassandra.io.sstable
- 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
- isDecommissioned() - Method in class org.apache.cassandra.service.StorageService
- isDecommissionFailed() - Method in class org.apache.cassandra.service.StorageService
- isDecommissionFailed() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns whether a node has failed to decommission.
- isDecommissioning() - Method in class org.apache.cassandra.service.StorageService
- isDecommissioning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Returns whether a node is being decommissioned or not.
- isDefined() - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- 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 - Variable in class org.apache.cassandra.service.reads.DigestResolver.DigestResolverDebugResult
- isDigestResponse() - Method in class org.apache.cassandra.db.ReadResponse
- isDirectBufferPooled() - Method in class org.apache.cassandra.net.BufferPoolAllocator
- isDirectIOEnabled() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
- isDirectory() - Method in class org.apache.cassandra.io.util.File
- isDirectory(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- isDisabled(StartupChecks.StartupCheckType) - Method in class org.apache.cassandra.config.StartupChecksOptions
- isDisjoint() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIntersectionIterator.Builder
- isDisjoint() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
- isDisjoint(KeyRangeIterator, KeyRangeIterator) - Static method in class org.apache.cassandra.index.sai.iterators.KeyRangeIntersectionIterator
- 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.filter.DataLimits.Counter
- isDone() - Method in interface org.apache.cassandra.db.Slices.InOrderTester
- isDone() - Method in class org.apache.cassandra.io.sstable.format.big.IndexState
- isDone() - Method in class org.apache.cassandra.net.FutureDelegate
- isDone() - Method in class org.apache.cassandra.transport.Dispatcher
- isDone() - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- isDone() - Method in class org.apache.cassandra.utils.concurrent.NotScheduledFuture
- 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 - Variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer.Header
- 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.config.SubnetGroups
- 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() - 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() - Method in interface org.apache.cassandra.db.memtable.Memtable.FlushablePartitionSet
- 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() - 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.tries.InMemoryReadTrie
- isEmpty() - Method in class org.apache.cassandra.db.virtual.AbstractVirtualTable.AbstractDataSet
- isEmpty() - Method in interface org.apache.cassandra.db.virtual.AbstractVirtualTable.DataSet
- isEmpty() - Method in class org.apache.cassandra.gms.HeartBeatState
- isEmpty() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder
- isEmpty() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder.TrieSegmentBuilder
- isEmpty() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder.VectorSegmentBuilder
- isEmpty() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.OnHeapGraph
- isEmpty() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.VectorPostings
- isEmpty() - Method in class org.apache.cassandra.index.sai.memory.MemoryIndex
- isEmpty() - Method in class org.apache.cassandra.index.sai.memory.MemtableIndex
- isEmpty() - Method in class org.apache.cassandra.index.sai.memory.TrieMemoryIndex
- isEmpty() - Method in class org.apache.cassandra.index.sai.memory.VectorMemoryIndex
- isEmpty() - Method in class org.apache.cassandra.index.sai.utils.PrimaryKeys
- 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.DistributedSchema
- 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.Types
- isEmpty() - Method in class org.apache.cassandra.schema.UserFunctions
- isEmpty() - Method in class org.apache.cassandra.schema.Views
- isEmpty() - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- isEmpty() - Method in class org.apache.cassandra.streaming.StreamingState.Sessions
- 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() - 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.BlockingQueues.Sync
- 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
- isEmpty(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
- isEmpty(ByteBuffer, DeserializationHelper.Flag, DecoratedKey) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate.PartitionUpdateSerializer
- 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(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(AbstractBounds.Boundary<T>, AbstractBounds.Boundary<T>) - Static method in class org.apache.cassandra.dht.AbstractBounds
- isEmpty(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- isEmptyFromOffset(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- isEmptyIndex(IndexDescriptor, IndexIdentifier) - Static method in class org.apache.cassandra.index.sai.disk.v1.ColumnCompletionMarkerUtil
-
Reads the column index completion marker and returns whether if the index is empty.
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- isEmptyValueMeaningless() - Method in class org.apache.cassandra.db.marshal.AbstractType
- 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.UUIDType
- isEmptyWithoutStatus() - Method in class org.apache.cassandra.gms.EndpointState
- isEnabled - Variable in class org.apache.cassandra.config.EncryptionOptions
- 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() - Method in class org.apache.cassandra.config.RetrySpec
- isEnabled() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
- 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.io.sstable.keycache.KeyCache
- isEnabled() - Method in class org.apache.cassandra.metrics.Sampler
-
A sampler is enabled between {@link this#beginSampling} and {@link this#finishSampling}
- isEnabled() - Method in class org.apache.cassandra.schema.CompactionParams
- isEnabled() - Method in class org.apache.cassandra.schema.CompressionParams
-
Checks if compression is enabled.
- isEnabled() - Method in class org.apache.cassandra.security.EncryptionContext
- isEnabled(Class<E>) - Method in class org.apache.cassandra.diag.DiagnosticEventService
-
Indicates if events are enabled for specified event class based on
DatabaseDescriptor.diagnosticEventsEnabled()
andDiagnosticEventService.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()
andDiagnosticEventService.hasSubscribers(Class, Enum)
. - isEnabled(Map<String, String>) - Static method in class org.apache.cassandra.schema.CompressionParams
-
Returns
true
if the options contains theenabled
option and that its value istrue
, otherwise returnsfalse
. - isEnabled(StartupChecksOptions) - Method in class org.apache.cassandra.service.FileSystemOwnershipCheck
- isEnabled(ClientState) - Method in class org.apache.cassandra.db.guardrails.EnableFlag
-
Returns whether the guarded feature is enabled or not.
- isEnabled(StartupChecks.StartupCheckType) - Method in class org.apache.cassandra.config.StartupChecksOptions
- 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 - Variable in class org.apache.cassandra.db.streaming.CassandraStreamHeader
- isEntireSSTable() - Method in class org.apache.cassandra.db.streaming.CassandraIncomingFile
- isEntireSSTable(boolean) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.Builder
- 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
- isEphemeral() - Method in class org.apache.cassandra.service.snapshot.SnapshotManifest
- isEphemeral() - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
- 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
- isEquality() - Method in enum org.apache.cassandra.index.sai.plan.Expression.IndexOperator
- isEqualityBased() - Method in interface org.apache.cassandra.cql3.restrictions.SingleRestriction
- isEqualityOrRange() - Method in enum org.apache.cassandra.index.sai.plan.Expression.IndexOperator
- isEqualityRestricted(ColumnMetadata) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
This method determines whether a specified column is restricted on equality or something equivalent, like IN.
- isEquivalentTo(DiskBoundaries) - Method in class org.apache.cassandra.db.DiskBoundaries
- ISerializer<T> - Interface in org.apache.cassandra.io
- isEstimationInformative() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
-
Returns whether the number of entries in the IndexSummary > 2.
- isEstimationInformative() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- isEstimationInformative() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns whether methods like
SSTableReader.estimatedKeys()
orSSTableReader.estimatedKeysForRanges(Collection)
can return sensible estimations. - 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
- isExecutable() - Method in class org.apache.cassandra.io.util.File
- isExhausted() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableKeyReader
- isExhausted() - Method in class org.apache.cassandra.io.sstable.format.bti.ScrubIterator
- isExhausted() - Method in interface org.apache.cassandra.io.sstable.format.bti.ScrubPartitionIterator
- isExhausted() - Method in interface org.apache.cassandra.io.sstable.KeyReader
-
Returns true if we reach EOF
- 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.
- isExhausted(DataLimits.Counter) - Method in class org.apache.cassandra.db.filter.DataLimits
- isExistingIdentity(String) - Method in class org.apache.cassandra.auth.CassandraRoleManager
- isExistingIdentity(String) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Returns if an identity exists in the identity_to_role
- 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 - Variable in class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
- isExpired() - Method in class org.apache.cassandra.db.LivenessInfo
- isExpired(Instant) - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
- 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.
- isExpiring() - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
- isExplicitlyOptional() - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
-
EncryptionOptions.isOptional
will be set totrue
implicitly forinternode_encryption
values of "dc" and "all". - isFailed() - Method in class org.apache.cassandra.streaming.SessionInfo
- isFailed() - Method in class org.apache.cassandra.tools.NodeProbe
- isFailedOrAborted() - Method in class org.apache.cassandra.streaming.StreamSession
-
Return if this session was failed or aborted
- isFailureResponse() - Method in class org.apache.cassandra.net.Message
- isFatal() - Method in exception org.apache.cassandra.transport.ProtocolException
- isFile() - Method in class org.apache.cassandra.io.util.File
- isFile(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- isFileSize(String) - Static method in enum org.apache.cassandra.db.compaction.CompactionInfo.Unit
- isFilterFullyCoveredBy(ClusteringIndexFilter, DataLimits, CachedPartition, long, 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() - Method in class org.apache.cassandra.cql3.functions.types.TupleType
- isFrozen() - Method in class org.apache.cassandra.cql3.functions.types.UserType
- isFrozen() - Method in class org.apache.cassandra.cql3.functions.types.VectorType
- isFrozen() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Returns
true
if the index type is frozen, e.g. - isFrozen(String) - Static method in class org.apache.cassandra.cql3.functions.types.DataTypeClassNameParser
- isFrozenCollection() - Method in class org.apache.cassandra.db.marshal.AbstractType
- isFrozenCollection() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Returns
true
if the index type is a frozen collection. - isFull() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
- isFull() - Method in class org.apache.cassandra.locator.Replica
- isFull() - Method in enum org.apache.cassandra.service.disk.usage.DiskUsageState
- isFull(InetAddressAndPort) - Method in class org.apache.cassandra.service.disk.usage.DiskUsageBroadcaster
- 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
- isFullyQualified() - Method in class org.apache.cassandra.cql3.statements.BatchStatement.Parsed
- isFullyQualified() - Method in class org.apache.cassandra.cql3.statements.QualifiedStatement
- isFullyRefused() - Method in class org.apache.cassandra.service.paxos.v1.ProposeCallback
- isGlobal - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
- isGlobal - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
- 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.format.SortedTableScrubber.ScrubInfo
- isGlobal() - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier.VerifyInfo
- isGlobal() - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryRedistribution
- isGlobal() - Method in class org.apache.cassandra.repair.messages.RepairOption
- 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
- isHealthyInstallation() - Method in class org.apache.cassandra.security.AbstractCryptoProvider
-
Returns boolean telling if this provider was installed properly.
- isHealthyInstallation() - Method in class org.apache.cassandra.security.DefaultCryptoProvider
- isHealthyInstallation() - Method in class org.apache.cassandra.security.JREProvider
- 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.
- isImplicitlyFrozen() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
- 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() - Method in interface org.apache.cassandra.db.ClusteringBound
- 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
- isInCorrectLocation - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- isInCorrectLocation(SSTableReader, Directories.DataDirectory) - Method in class org.apache.cassandra.db.DiskBoundaries
- isIncremental - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
- isIncremental - Variable in class org.apache.cassandra.repair.RepairSession
-
Range to repair
- isIncremental - Variable in class org.apache.cassandra.repair.Validator
- isIncremental - Variable in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
- isIncremental() - Method in class org.apache.cassandra.repair.messages.RepairOption
- isIncrementalBackupsEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- isIncrementalBackupsEnabled() - Method in class org.apache.cassandra.schema.TableMetadata
- 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 - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- 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
- 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.index.sasi.conf.ColumnIndex
- isIndexed() - Method in class org.apache.cassandra.index.sasi.plan.Expression
- isIndexed() - Method in class org.apache.cassandra.io.sstable.AbstractRowIndexEntry
- isIndexed() - Method in class org.apache.cassandra.io.sstable.format.big.RowIndexEntry
- isIndexEmpty(IndexTermType, IndexIdentifier) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- isIndexQueryable(Index) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Checks if the specified index is queryable.
- isIndexValid() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- isIndexWritable(Index) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Checks if the specified index is writable.
- isInformative() - Method in class org.apache.cassandra.utils.BloomFilter
- isInformative() - Method in interface org.apache.cassandra.utils.IFilter
- isInitBuildStarted() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- isInitialized() - Static method in class org.apache.cassandra.db.Keyspace
- 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
- isInOurDc(InetAddressAndPort) - Static method in class org.apache.cassandra.locator.InOurDc
- isInOurDc(Replica) - Static method in class org.apache.cassandra.locator.InOurDc
- isInProgress() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
- isInProgress() - Method in class org.apache.cassandra.db.monitoring.MonitorableImpl
- isInRangeAndShouldProcess(InetAddressAndPort, DecoratedKey, TableMetadata, boolean) - Static method in class org.apache.cassandra.service.paxos.Paxos
- 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.See CASSANDRA-12509
- 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
- isIntersectable(PrimaryKey.Kind) - Method in enum org.apache.cassandra.index.sai.utils.PrimaryKey.Kind
- isIPv4() - Method in class org.apache.cassandra.cql3.CIDR
-
Tells is this IPv4 format CIDR
- isIPv6() - Method in class org.apache.cassandra.cql3.CIDR
-
Tells is this IPv6 format CIDR
- 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
- isKeyDenylisted(String, String, String) - Method in class org.apache.cassandra.service.StorageProxy
-
A simple check for operators to determine what the denylisted value for a pk is on a node
- isKeyDenylisted(String, String, String) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- isKeyPermitted(String, String, ByteBuffer) - Method in class org.apache.cassandra.schema.PartitionDenylist
- isKeyPermitted(TableId, ByteBuffer) - Method in class org.apache.cassandra.schema.PartitionDenylist
- 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
-
Checks is the node is a leaf.
- isLeaving(InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
- isLeveledCompaction() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- isLeveledCompaction() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
- isLeveledCompaction() - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
- isLeveledCompaction(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
- 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
- isLimitReached() - Method in class org.apache.cassandra.io.util.TeeDataInputPlus
-
Used to detect if the teeBuffer hit the supplied limit.
- isLinearizable() - Static method in class org.apache.cassandra.service.paxos.Paxos
- isLinux - Static variable in class org.apache.cassandra.utils.FBUtilities
- isLiteral - Variable in class org.apache.cassandra.index.sasi.conf.IndexMode
- isLiteral - Variable in class org.apache.cassandra.index.sasi.plan.Expression
- isLiteral() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Returns
true
if the index type is a literal type and will use a literal index. - isLiteral() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
- 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() - Method in class org.apache.cassandra.db.MutableDeletionInfo
-
Returns whether this DeletionInfo is live, that is deletes no columns.
- 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
- isLive(long) - Method in class org.apache.cassandra.db.LivenessInfo
-
Whether that info is still live.
- isLive(long) - Method in class org.apache.cassandra.db.rows.AbstractCell
- isLive(long) - Method in class org.apache.cassandra.db.rows.Cell
-
Whether the cell is live or not given the current time.
- isLive(Row) - Method in class org.apache.cassandra.db.filter.DataLimits.Counter
- 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
- isLoggingReadRepairs() - Method in class org.apache.cassandra.service.StorageProxy
- isLoggingReadRepairs() - Method in interface org.apache.cassandra.service.StorageProxyMBean
- 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
- isMasked() - Method in class org.apache.cassandra.schema.ColumnMetadata
- isMaxWritetimeSelectorFactory() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
-
Checks if this factory creates
maxwritetime
selector instances. - isMember(InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
- isMemoryLockable() - Method in interface org.apache.cassandra.service.NativeAccessMBean
- isMerkleTreeRetriesEnabled() - Method in class org.apache.cassandra.config.RepairRetrySpec
- 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.CIDRPermissions.Builder
- isModified() - Method in class org.apache.cassandra.auth.DCPermissions.Builder
- isModified() - Method in class org.apache.cassandra.utils.DefaultValue
- isMonitorMode() - Method in class org.apache.cassandra.auth.CassandraCIDRAuthorizer
- isMonotonic() - Method in interface org.apache.cassandra.cql3.functions.ScalarFunction
-
Checks if the function is monotonic.
- isMoving() - Method in class org.apache.cassandra.service.StorageService
- isMoving(InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
- isMultiCell() - Method in class org.apache.cassandra.db.marshal.AbstractType
- isMultiCell() - Method in class org.apache.cassandra.db.marshal.ListType
- isMultiCell() - Method in class org.apache.cassandra.db.marshal.MapType
- isMultiCell() - Method in class org.apache.cassandra.db.marshal.SetType
- 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
- isMultiExpression(RowFilter.Expression) - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Returns
true
if theRowFilter.Expression
passed is backed by a non-frozen collection and theOperator
is one that cannot be merged together. - isMutableIntersection() - Method in class org.apache.cassandra.db.filter.RowFilter
- 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.cql3.functions.FunctionName
-
Validate the function name, e.g.
- 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.UserFunction
- 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.
- isNegative() - Method in class org.apache.cassandra.cql3.Duration
-
Checks if the duration is negative.
- 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
- isNone() - Method in class org.apache.cassandra.service.paxos.Commit.Committed
- isNonFrozenCollection() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Returns
true
if the index type is a non-frozen collection - isNoOp() - Method in interface org.apache.cassandra.utils.WithResources
-
A convenience method to avoid unnecessary work.
- isNoOp() - Method in class org.apache.cassandra.utils.WithResources.None
- isNormal() - Method in class org.apache.cassandra.service.StorageService
- isNormalState() - Method in class org.apache.cassandra.gms.EndpointState
- isNotBuildCompletionMarker(IndexComponent) - Method in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- isNotIndexed() - Method in class org.apache.cassandra.index.sai.plan.Expression.IndexedExpression
- isNotIndexed() - Method in class org.apache.cassandra.index.sai.plan.Expression
- isNotIndexed() - Method in class org.apache.cassandra.index.sai.plan.Expression.UnindexedExpression
- 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(int) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByIndexData
-
Returns whether the
i
th value is NULL. - isNull(String) - Method in class org.apache.cassandra.cql3.functions.types.AbstractGettableData
-
Returns whether the value for
name
is NULL. - isNull(String) - Method in interface org.apache.cassandra.cql3.functions.types.GettableByNameData
-
Returns whether the value for
name
is NULL. - isNull(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
- isNull(ByteBuffer) - Method in class org.apache.cassandra.serializers.TypeSerializer
- isNull(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.AbstractType
- isNull(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
- isNull(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.VectorType.VectorSerializer
- isNull(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
- isNull(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.BytesSerializer
- isNull(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.TypeSerializer
- 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() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
- 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
- isOffline - Variable in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- 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
- Isolated - Annotation Type in org.apache.cassandra.utils
-
Tells jvm-dtest that a class should be isolated and loaded into the instance class loader.
- 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() - Method in class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
- isOpen() - Method in class org.apache.cassandra.io.util.SequentialWriter
- isOpen() - Method in class org.apache.cassandra.security.EncryptionUtils.ChannelProxyReadChannel
- 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
- 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 interface org.apache.cassandra.cql3.functions.FunctionParameter
- isOrdinaryUser() - Method in class org.apache.cassandra.service.ClientState
-
Checks if this user is an ordinary user (not a super or system user).
- 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
- isOutOfDate(long) - Method in interface org.apache.cassandra.db.compaction.ShardManager
- isOutOfDate(long) - Method in class org.apache.cassandra.db.compaction.ShardManagerNoDisks
- isOutOfDate(long) - Method in class org.apache.cassandra.db.compaction.ShardManagerTrivial
- isOverflowed() - Method in class org.apache.cassandra.utils.EstimatedHistogram
- 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.
- isOverlapping(RangeIterator<K, D>, RangeIterator<K, D>) - Static method in class org.apache.cassandra.index.sasi.utils.RangeIterator
- 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
- isPartialApplicationMonotonic(List<ByteBuffer>) - Method in class org.apache.cassandra.cql3.functions.NativeScalarFunction
-
Checks if a partial application of the function is monotonic.
- 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.io.sstable.format.big.IndexState
- isPendingRepair() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- isPerColumnIndexBuildComplete(IndexDescriptor, IndexIdentifier) - Method in interface org.apache.cassandra.index.sai.disk.format.OnDiskFormat
-
Returns true if the per-column index components have been built and are valid.
- isPerColumnIndexBuildComplete(IndexDescriptor, IndexIdentifier) - Method in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- isPerColumnIndexBuildComplete(IndexIdentifier) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- isPerSSTableIndexBuildComplete() - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- isPerSSTableIndexBuildComplete(IndexDescriptor) - Method in interface org.apache.cassandra.index.sai.disk.format.OnDiskFormat
-
Returns true if the per-sstable index components have been built and are valid.
- isPerSSTableIndexBuildComplete(IndexDescriptor) - Method in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- isPrefix(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- 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. - isPresent() - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
- isPresent(IFilter.FilterKey) - Method in class org.apache.cassandra.utils.BloomFilter
- isPresent(IFilter.FilterKey) - Method in interface org.apache.cassandra.utils.IFilter
- isPresentInFilter(IFilter.FilterKey) - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderWithFilter
- 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
- isPrimitive() - Method in class org.apache.cassandra.cql3.functions.UDFDataType
-
Checks if this type is corresponding to a Java primitive type.
- isPrimitive(Property) - Static method in class org.apache.cassandra.config.Properties
- isPullRepair() - Method in class org.apache.cassandra.repair.messages.RepairOption
- isPure() - Method in interface org.apache.cassandra.cql3.functions.Function
-
Checks whether the function is a pure function (as in doesn't depend on, nor produces side effects) or not.
- isPure() - Method in class org.apache.cassandra.cql3.functions.NativeFunction
- isPure() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
- isPure() - Method in class org.apache.cassandra.cql3.functions.UDFunction
- isQueryable(Index.Status) - Method in interface org.apache.cassandra.index.Index
-
Check if current index is queryable based on the index status.
- isQueryable(Index.Status) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- isQuoted(String, char) - Static method in class org.apache.cassandra.cql3.functions.types.ParseUtils
-
Return
true
if the given string is surrounded by the quote character given, andfalse
otherwise. - isRangeCommand() - Method in class org.apache.cassandra.db.ReadExecutionController
- 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
- isRateLimited() - Method in interface org.apache.cassandra.streaming.StreamingDataOutputPlus.RateLimiter
- isRateLimited() - Method in class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
- isReadable() - Method in class org.apache.cassandra.config.ForwardingProperty
- isReadable() - Method in class org.apache.cassandra.io.util.File
- isReadThresholdsEnabled() - Method in class org.apache.cassandra.cql3.QueryOptions
- isRebuildNeeded() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosStateTracker
- isRecoverable() - Method in class org.apache.cassandra.net.FrameDecoder.CorruptFrame
- isRegistered(String) - Method in interface org.apache.cassandra.utils.MBeanWrapper
- isRegistered(String, MBeanWrapper.OnException) - Method in interface org.apache.cassandra.utils.MBeanWrapper
- isRegistered(String, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.NoOpMBeanWrapper
- isRegistered(ObjectName) - Method in interface org.apache.cassandra.utils.MBeanWrapper
- isRegistered(ObjectName, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.DelegatingMbeanWrapper
- isRegistered(ObjectName, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.InstanceMBeanWrapper
- isRegistered(ObjectName, MBeanWrapper.OnException) - Method in interface org.apache.cassandra.utils.MBeanWrapper
- isRegistered(ObjectName, 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
- isRejected() - Method in enum org.apache.cassandra.repair.state.AbstractState.UpdateType
- isReleased() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
- isRemote() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
- isRepaired() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- isRepaired(AbstractCompactionStrategy) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
- 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
- isReplacing() - Method in class org.apache.cassandra.service.StorageService
- 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
- isReproposalOf(Commit) - Method in class org.apache.cassandra.service.paxos.Commit
-
We can witness reproposals of the latest successful commit; we can detect this by comparing the timestamp of the update with our ballot; if it is the same, we are not a reproposal.
- 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 - Variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer.Header
- 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() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
- isReversed() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Returns
true
if the index type is reversed. - isReversed(String) - Static method in class org.apache.cassandra.cql3.functions.types.DataTypeClassNameParser
- isReversed(List<UnfilteredRowIterator>) - Method in class org.apache.cassandra.service.reads.repair.PartitionIteratorMergeListener
- isReversedType() - Method in class org.apache.cassandra.cql3.ColumnSpecification
- 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 interface 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.format.big.SSTableIterator
- isReverseOrder() - Method in class org.apache.cassandra.io.sstable.format.big.SSTableReversedIterator
- 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 interface org.apache.cassandra.transport.Connection.Tracker
- isRunning() - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
- 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.
- isSafeToPerformRead() - Static method in class org.apache.cassandra.service.StorageProxy
- isSafeToPerformRead(List<SinglePartitionReadCommand>) - Static method in class org.apache.cassandra.service.StorageProxy
- isSameOrAfter(Ballot) - Method in class org.apache.cassandra.service.paxos.Commit
- 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(ByteBuffer) - Method in class org.apache.cassandra.index.sai.plan.Expression
-
Used in post-filtering to determine is an indexed value matches the expression
- isSatisfiedBy(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.plan.Expression
- isSatisfiedBy(DecoratedKey, Row, Row) - Method in class org.apache.cassandra.index.sai.plan.FilterTree
- 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) - Method in class org.apache.cassandra.db.filter.RowFilter.SimpleExpression
- isSatisfiedBy(TableMetadata, DecoratedKey, Row, long) - Method in class org.apache.cassandra.db.filter.RowFilter
-
Whether the provided row in the provided partition satisfies this filter.
- isSecondaryIndexFolder(Path) - Static method in class org.apache.cassandra.db.Directories
- 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.
- isSelected() - Static method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- isSelected() - Static method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- 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
- isSerializationCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Similar to
AbstractType.isValueCompatibleWith(AbstractType)
, but takes into accountCell
encoding. - isSerializationCompatibleWith(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.CollectionType
- isSerializedSizeFixed() - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec
-
Checks if all values are of fixed length.
- isSessionFinalized(TimeUUID) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
-
determines if a local session exists, and if it's in the finalized state
- isSessionInProgress(TimeUUID) - 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.concurrent.WrappedExecutorPlus
- isShutdown() - Method in class org.apache.cassandra.service.StorageService
- isShutDown() - Method in class org.apache.cassandra.hints.HintsService
-
Returns true in case service is shut down.
- isSignalled() - Method in class org.apache.cassandra.utils.concurrent.Awaitable.AsyncAwaitable
-
Return true once signalled.
- isSignalled() - Method in class org.apache.cassandra.utils.concurrent.Awaitable.SyncAwaitable
-
Return true once signalled.
- isSignalled() - Method in class org.apache.cassandra.utils.concurrent.Condition.Async
- isSignalled() - Method in interface org.apache.cassandra.utils.concurrent.Condition
-
Returns true once signalled.
- isSignalled() - Method in class org.apache.cassandra.utils.concurrent.Condition.Sync
- isSignalled() - Method in class org.apache.cassandra.utils.concurrent.CountDownLatch.Async
- isSignalled() - Method in class org.apache.cassandra.utils.concurrent.CountDownLatch.Sync
-
not synchronized as only intended for internal usage by externally synchronized methods
- 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
Selector
s 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
Selector
s that simply return the specified column. - isSimpleSelectorFactoryFor(int) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector.SimpleSelectorFactory
- isSingleton() - Method in interface org.apache.cassandra.index.Index.Group
-
Returns whether this group can only ever contain a single index.
- isSingleton() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- ISslContextFactory - Interface in org.apache.cassandra.security
-
The purpose of this interface is to provide pluggable mechanism for creating custom JSSE and Netty SSLContext objects.
- ISslContextFactory.SocketType - Enum in org.apache.cassandra.security
-
Indicates if the process holds the inbound/listening (Server) end of the socket or the outbound side (Client).
- 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
- isSSLError(Throwable) - Static method in class org.apache.cassandra.net.InternodeConnectionUtils
- isSSTableAttached() - Method in interface org.apache.cassandra.index.Index
-
For an index to qualify as SSTable-attached, it must do two things:
- isSSTableAttached() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- 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, long) - 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, long) - Method in class org.apache.cassandra.index.internal.composites.ClusteringColumnIndex
- isStale(Row, ByteBuffer, long) - Method in class org.apache.cassandra.index.internal.composites.CollectionEntryIndex
- isStale(Row, ByteBuffer, long) - Method in class org.apache.cassandra.index.internal.composites.CollectionKeyIndex
- isStale(Row, ByteBuffer, long) - Method in class org.apache.cassandra.index.internal.composites.CollectionValueIndex
- isStale(Row, ByteBuffer, long) - Method in class org.apache.cassandra.index.internal.composites.PartitionKeyIndex
- isStale(Row, ByteBuffer, long) - Method in class org.apache.cassandra.index.internal.composites.RegularColumnIndex
- isStale(Row, ByteBuffer, long) - Method in class org.apache.cassandra.index.internal.keys.KeysIndex
- isStandardModeEnable() - Method in class org.apache.cassandra.db.commitlog.CommitLog.Configuration
- 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.db.commitlog.CommitLog
- isStarted() - Method in class org.apache.cassandra.repair.consistent.LocalSessions
- isStarted() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosRepair
- 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
- isStateEmpty() - Method in class org.apache.cassandra.gms.EndpointState
- isStateFlushEnabled() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker
- 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() - Method in class org.apache.cassandra.schema.ColumnMetadata
- isStatic(int) - Static method in class org.apache.cassandra.db.rows.UnfilteredSerializer
- isStaticCompactTable() - Method in class org.apache.cassandra.schema.TableMetadata.CompactTableMetadata
- isStaticCompactTable() - Method in class org.apache.cassandra.schema.TableMetadata
- isStaticCompactTable(Set<TableMetadata.Flag>) - Static method in enum org.apache.cassandra.schema.TableMetadata.Flag
- 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
- isStrict() - Method in class org.apache.cassandra.db.filter.RowFilter
-
If this filter belongs to a read that requires reconciliation at the coordinator, and it contains an intersection on two or more non-key (and therefore mutable) columns, we cannot strictly apply it to local, unrepaired rows.
- isString() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Returns
true
if the index type is a string type. - isStuffed() - Method in enum org.apache.cassandra.service.disk.usage.DiskUsageState
- isStuffed(InetAddressAndPort) - Method in class org.apache.cassandra.service.disk.usage.DiskUsageBroadcaster
- isStuffedOrFull() - Method in enum org.apache.cassandra.service.disk.usage.DiskUsageState
- isSubDirectory(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Deprecated.See CASSANDRA-16926
- 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.FutureDelegate
- isSuccess() - Method in class org.apache.cassandra.streaming.StreamSession
-
Return if this session completed successfully.
- isSuccess() - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- isSuccessful() - Method in class org.apache.cassandra.service.paxos.v1.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
- isSuitableForCompaction(SSTableReader) - Static method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- isSuper - Variable in class org.apache.cassandra.auth.Role
- isSuper() - Method in class org.apache.cassandra.auth.AuthenticatedUser
-
Checks the user's superuser status.
- isSuper() - Method in class org.apache.cassandra.service.ClientState
-
Checks if this user is a super user.
- isSuper(Set<TableMetadata.Flag>) - Static method in enum org.apache.cassandra.schema.TableMetadata.Flag
- 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.
- isSupersededBy(EndpointState) - Method in class org.apache.cassandra.gms.EndpointState
- isSuperuser - Variable in class org.apache.cassandra.auth.jmx.AuthorizationProxy
- isSupported(Set<ParamType>) - Static method in class org.apache.cassandra.service.reads.thresholds.WarningContext
- isSupportedBy(Index) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.AnnRestriction
- 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
- isSupportedBy(Index, ColumnMetadata) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
- isSupportedBy(Index, ColumnMetadata) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.INRestriction
- isSupportedBy(Index, ColumnMetadata) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
- isSupportedBy(Index, ColumnMetadata) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.NotNullRestriction
- isSupportedBy(Index, ColumnMetadata) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.SliceRestriction
- isSupportedBy(SSTableFormat<?, ?>) - Static method in interface org.apache.cassandra.io.sstable.indexsummary.IndexSummarySupport
- isSupportedBy(SSTableFormat<?, ?>) - Static method in interface org.apache.cassandra.io.sstable.keycache.KeyCacheSupport
- isSurveyMode() - Method in class org.apache.cassandra.service.StorageService
- isSuspect - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
- isSuspected() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- 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()
- isSystem() - Method in class org.apache.cassandra.service.ClientState
-
Checks if the user is the system user.
- isSystemKeyspace(String) - Static method in class org.apache.cassandra.schema.SchemaConstants
-
Checks if the keyspace is a system keyspace (local replicated or virtual).
- isTableIncrementalBackupsEnabled() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- isTableLevel() - Method in class org.apache.cassandra.auth.DataResource
- isTerminal() - Method in class org.apache.cassandra.cql3.selection.Selector
-
A selector is terminal if it doesn't require any input for it's output to be computed, i.e.
- isTerminal() - Method in class org.apache.cassandra.cql3.selection.TermSelector
- isTerminal() - Method in class org.apache.cassandra.cql3.selection.VectorSelector
- 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.auth.AuthCache
- isTerminated() - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
- isTerminated() - Method in class org.apache.cassandra.concurrent.InfiniteLoopExecutor
- isTerminated() - Method in class org.apache.cassandra.concurrent.SEPExecutor
- isTerminated() - Method in interface org.apache.cassandra.concurrent.Shutdownable
- isTerminated() - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- isTerminated() - Method in class org.apache.cassandra.utils.memory.MemtableCleanerThread
- isTestTableStatsHolder() - Method in class org.apache.cassandra.tools.nodetool.stats.TableStatsHolder
- isThrowOnOverload() - Method in class org.apache.cassandra.transport.Connection
- isTimeout(Map<InetAddressAndPort, RequestFailureReason>) - Static method in interface org.apache.cassandra.net.RequestCallback
- 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
- isTopK() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
- isTopK() - Method in class org.apache.cassandra.db.ReadCommand
- isTopK() - Method in interface org.apache.cassandra.db.ReadQuery
-
The query is a top-k query if the query has an
Index.QueryPlan
that supports top-k ordering. - isTopK() - Method in interface org.apache.cassandra.index.Index.QueryPlan
- isTopK() - Method in class org.apache.cassandra.index.sai.plan.StorageAttachedIndexQueryPlan
- isTopK() - Method in class org.apache.cassandra.service.pager.AggregationQueryPager
- isTopK() - Method in class org.apache.cassandra.service.pager.PartitionRangeQueryPager
- isTopK() - Method in interface org.apache.cassandra.service.pager.QueryPager
- 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.
- isTrackable() - Method in class org.apache.cassandra.transport.Message.Request
- isTrackable() - Method in class org.apache.cassandra.transport.messages.BatchMessage
- isTrackable() - Method in class org.apache.cassandra.transport.messages.ExecuteMessage
- isTrackable() - Method in class org.apache.cassandra.transport.messages.QueryMessage
- isTrackingRepairedStatus() - Method in class org.apache.cassandra.db.ReadExecutionController
- isTrackingWarnings() - Method in class org.apache.cassandra.db.ReadCommand
- isTransient - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
- 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.io.sstable.format.SSTableReader
- isTransient() - Method in class org.apache.cassandra.locator.Replica
- isTransientReplicationEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- isTransientSSTable() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- 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.
- isTrulyWrapAround() - Method in class org.apache.cassandra.dht.Range
-
Checks if the range truly wraps around.
- isTrulyWrapAround(T, T) - Static method in class org.apache.cassandra.dht.Range
- 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
- isUncancellable() - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- isUncancellable() - Method in class org.apache.cassandra.utils.concurrent.AsyncPromise
- isUncancellable() - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
- isUniqueIdentifier(String) - Method in class org.apache.cassandra.io.sstable.SequenceBasedSSTableId.Builder
- isUniqueIdentifier(String) - Method in interface org.apache.cassandra.io.sstable.SSTableId.Builder
- isUniqueIdentifier(String) - Method in class org.apache.cassandra.io.sstable.UUIDBasedSSTableId.Builder
- isUniqueIdentifier(ByteBuffer) - Method in class org.apache.cassandra.io.sstable.SequenceBasedSSTableId.Builder
- isUniqueIdentifier(ByteBuffer) - Method in interface org.apache.cassandra.io.sstable.SSTableId.Builder
- isUniqueIdentifier(ByteBuffer) - Method in class org.apache.cassandra.io.sstable.UUIDBasedSSTableId.Builder
- 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(TableMetadata) - 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(TableMetadata) - 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
- isUUIDSSTableIdentifiersEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- isValid() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- isValid(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
- isValid(ByteBuffer) - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Returns
true
if given buffer would pass theAbstractType.validate(ByteBuffer)
check. - 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
- isValidCertificate(Certificate[]) - Method in interface org.apache.cassandra.auth.MutualTlsCertificateValidator
-
Perform any checks that are to be performed on the certificate before making authorization check to grant the access to the client during mTLS connection.
- isValidCertificate(Certificate[]) - Method in class org.apache.cassandra.auth.SpiffeCertificateValidator
- isValidFile(File) - Static method in class org.apache.cassandra.io.sstable.Descriptor
- isValidFor(Descriptor) - Method in class org.apache.cassandra.io.sstable.Component
- 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.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
- isValueFormatReplacement() - Method in class org.apache.cassandra.config.Replacement
- isValueLengthFixed() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
Checks if all values are of fixed length.
- isValueShared() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.CompactionVectorValues
- isValueShared() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.ConcurrentVectorValues
- isVector() - Method in interface org.apache.cassandra.cql3.CQL3Type
- isVector() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
- isVector() - Method in class org.apache.cassandra.cql3.CQL3Type.Vector
- isVector() - Method in class org.apache.cassandra.db.marshal.AbstractType
- isVector() - Method in class org.apache.cassandra.db.marshal.VectorType
- isVector() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Returns
true
if the index type is a vector type. - 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<?>) - 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
- 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() - Method in class org.apache.cassandra.dht.Range
- isWrapAround(T, T) - Static method in class org.apache.cassandra.dht.Range
-
Tells if the given range is a wrap around.
- isWritable() - Method in class org.apache.cassandra.config.ForwardingProperty
- isWritable() - Method in class org.apache.cassandra.io.util.File
- isWritetimeSelectorFactory() - Method in class org.apache.cassandra.cql3.selection.Selector.Factory
-
Checks if this factory creates
writetime
selectors instances. - items_per_collection_fail_threshold - Variable in class org.apache.cassandra.config.Config
- items_per_collection_warn_threshold - Variable in class org.apache.cassandra.config.Config
- itemsPerCollection - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the number of items of a collection.
- iterable(Object[]) - 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
- iterable(Object[], BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
- iterable(AtomicReferenceFieldUpdater<O, T>, O) - Static method in class org.apache.cassandra.utils.concurrent.IntrusiveStack
- iterable(T) - Static method in class org.apache.cassandra.utils.concurrent.IntrusiveStack
- IterationPosition(long, int, int, ValueIterator.IterationPosition) - Constructor for class org.apache.cassandra.io.tries.ValueIterator.IterationPosition
- iterator - Variable in class org.apache.cassandra.io.sstable.format.SSTableScanner
- iterator - Variable in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
- 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() - 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() - 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.sai.disk.v1.segment.SegmentTrieBuffer
- iterator() - Method in class org.apache.cassandra.index.sai.memory.MemoryIndex
-
Iterate all Term->PrimaryKeys mappings in sorted order
- iterator() - Method in class org.apache.cassandra.index.sai.memory.MemtableIndex
- iterator() - Method in class org.apache.cassandra.index.sai.memory.TrieMemoryIndex
-
Returns an
Iterator
over the entire dataset contained in the trie. - iterator() - Method in class org.apache.cassandra.index.sai.memory.VectorMemoryIndex
- iterator() - Method in class org.apache.cassandra.index.sai.utils.PrimaryKeys
- iterator() - Method in class org.apache.cassandra.index.sai.view.View
- 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() - Method in class org.apache.cassandra.index.sasi.disk.TokenTree.OnDiskToken
- 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.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.UserFunctions
- 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() - Method in class org.apache.cassandra.utils.btree.BTreeSet
- iterator() - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- iterator() - Method in class org.apache.cassandra.utils.concurrent.IntrusiveStack
- 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
- iterator(boolean) - Method in class org.apache.cassandra.db.RangeTombstoneList
- iterator(boolean) - Method in class org.apache.cassandra.db.rows.SerializationHelper
- iterator(Function<Long, DecoratedKey>) - Method in class org.apache.cassandra.index.sasi.disk.TokenTree
- iterator(Object[]) - 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(Object[], BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
- iterator(Slice, boolean) - Method in class org.apache.cassandra.db.RangeTombstoneList
- iterator(FailureRecordingCallback.FailureResponses) - Static method in class org.apache.cassandra.service.FailureRecordingCallback.FailureResponses
- iterator(T) - Static method in class org.apache.cassandra.utils.concurrent.IntrusiveStack
- iteratorAt(ByteBuffer, OnDiskIndex.IteratorOrder, boolean) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
- iterators - Variable in class org.apache.cassandra.utils.MergeIterator
- iterators() - Method in interface org.apache.cassandra.utils.IMergeIterator
- 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
- IValidationManager - Interface in org.apache.cassandra.repair
- IVerbHandler<T> - Interface in org.apache.cassandra.net
-
IVerbHandler provides the method that all verb handlers need to implement.
- IVerifier - Interface in org.apache.cassandra.io.sstable
- IVerifier.Options - Class in org.apache.cassandra.io.sstable
- IVerifier.Options.Builder - Class in org.apache.cassandra.io.sstable
- IVersionedAsymmetricSerializer<In,Out> - Interface in org.apache.cassandra.io
- IVersionedSerializer<T> - Interface in org.apache.cassandra.io
J
- JAVA_CLASS_PATH - org.apache.cassandra.config.CassandraRelevantProperties
-
Java class path.
- JAVA_HOME - org.apache.cassandra.config.CassandraRelevantEnv
-
Searching in the JAVA_HOME is safer than searching into System.getProperty("java.home") as the Oracle JVM might use the JRE which do not contains jmap.
- JAVA_HOME - org.apache.cassandra.config.CassandraRelevantProperties
- JAVA_IO_TMPDIR - org.apache.cassandra.config.CassandraRelevantProperties
-
Indicates the temporary directory used by the Java Virtual Machine (JVM) to create and store temporary files.
- JAVA_LIBRARY_PATH - org.apache.cassandra.config.CassandraRelevantProperties
-
Path from which to load native libraries.
- JAVA_RMI_DGC_LEASE_VALUE_IN_JVM_DTEST - org.apache.cassandra.config.CassandraRelevantProperties
-
Controls the distributed garbage collector lease time for JMX objects.
- JAVA_RMI_SERVER_HOSTNAME - org.apache.cassandra.config.CassandraRelevantProperties
-
The value of this property represents the host name string that should be associated with remote stubs for locally created remote objects, in order to allow clients to invoke methods on the remote object.
- JAVA_RMI_SERVER_RANDOM_ID - org.apache.cassandra.config.CassandraRelevantProperties
-
If this value is true, object identifiers for remote objects exported by this VM will be generated by using a cryptographically secure random number generator.
- JAVA_SECURITY_AUTH_LOGIN_CONFIG - org.apache.cassandra.config.CassandraRelevantProperties
- JAVA_SECURITY_EGD - org.apache.cassandra.config.CassandraRelevantProperties
- JAVA_UDF_NAME - Static variable in class org.apache.cassandra.cql3.functions.UDFByteCodeVerifier
- JAVA_VERSION - org.apache.cassandra.config.CassandraRelevantProperties
-
Java Runtime Environment version
- JAVA_VM_NAME - org.apache.cassandra.config.CassandraRelevantProperties
-
Java Virtual Machine implementation name
- JavaBasedUDFunction - Class in org.apache.cassandra.cql3.functions
- JavaDriverUtils - Class in org.apache.cassandra.utils
- JavaUDF - Class in org.apache.cassandra.cql3.functions
-
Base class for all Java UDFs.
- JavaUDF(UDFDataType, 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.
- JAVAX_RMI_SSL_CLIENT_ENABLED_CIPHER_SUITES - org.apache.cassandra.config.CassandraRelevantProperties
- JAVAX_RMI_SSL_CLIENT_ENABLED_PROTOCOLS - org.apache.cassandra.config.CassandraRelevantProperties
- 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
- 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
ProgressListener
s. - JMXNotificationProgressListener() - Constructor for class org.apache.cassandra.utils.progress.jmx.JMXNotificationProgressListener
- jmxPermissionsCache - Static variable in class org.apache.cassandra.auth.jmx.AuthorizationProxy
- JmxPermissionsCache() - Constructor for class org.apache.cassandra.auth.jmx.AuthorizationProxy.JmxPermissionsCache
- 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
- JmxRegistry(int, RMIClientSocketFactory, RMIServerSocketFactory, String) - Constructor for class org.apache.cassandra.utils.JMXServerUtils.JmxRegistry
- JMXResource - Class in org.apache.cassandra.auth
- JMXServerUtils - Class in org.apache.cassandra.utils
- JMXServerUtils() - Constructor for class org.apache.cassandra.utils.JMXServerUtils
- JMXServerUtils.JmxRegistry - Class in org.apache.cassandra.utils
- 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(RepairJobDesc) - Method in class org.apache.cassandra.repair.state.ParticipateState
- Job(Clock, RepairJobDesc) - Constructor for class org.apache.cassandra.repair.state.ParticipateState.Job
- JOB_THREADS_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
- jobs - Variable in class org.apache.cassandra.repair.state.ParticipateState
- JOBS_START - org.apache.cassandra.repair.state.SessionState.State
- jobsSubmitted() - Method in class org.apache.cassandra.repair.state.SessionState.Phase
- JobState - Class in org.apache.cassandra.repair.state
- JobState(Clock, RepairJobDesc, ImmutableSet<InetAddressAndPort>) - Constructor for class org.apache.cassandra.repair.state.JobState
- JobState.Phase - Class in org.apache.cassandra.repair.state
- JobState.State - Enum in org.apache.cassandra.repair.state
- Join - Class in org.apache.cassandra.tools.nodetool
- Join() - Constructor for class org.apache.cassandra.tools.nodetool.Join
- JOIN_RING - org.apache.cassandra.config.CassandraRelevantProperties
- JOINING - org.apache.cassandra.service.StorageService.Mode
- JOINING_FAILED - org.apache.cassandra.service.StorageService.Mode
- 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, long) - Method in class org.apache.cassandra.service.StorageService
- jpcProxy - Variable in class org.apache.cassandra.tools.NodeProbe
- JREProvider - Class in org.apache.cassandra.security
-
Crypto provider which does nothing.
- JREProvider(Map<String, String>) - Constructor for class org.apache.cassandra.security.JREProvider
- json - org.apache.cassandra.tools.JMXTool.Diff.Format
- json - org.apache.cassandra.tools.JMXTool.Dump.Format
- Json - Class in org.apache.cassandra.cql3
-
Term-related classes for INSERT JSON support.
- JSON_COLUMN_ID - Static variable in class org.apache.cassandra.cql3.Json
- JSON_OBJECT_MAPPER - Static variable in class org.apache.cassandra.utils.JsonUtils
- JSON_OBJECT_PRETTY_WRITER - Static variable in class org.apache.cassandra.utils.JsonUtils
- 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
- JsonPrinter() - Constructor for class org.apache.cassandra.tools.nodetool.stats.StatsPrinter.JsonPrinter
- JsonTransformer - Class in org.apache.cassandra.tools
- JsonUtils - Class in org.apache.cassandra.utils
- 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
- KATAKANA - org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer.TokenType
- keep(Set<InetAddressAndPort>) - Method in class org.apache.cassandra.locator.Endpoints
- KEEP_ALIVE - org.apache.cassandra.streaming.messages.StreamMessage.Type
- 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
- keepSSTableLevel() - Method in enum org.apache.cassandra.streaming.StreamOperation
- 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.rows.UnfilteredRowIteratorSerializer.Header
- key - Variable in class org.apache.cassandra.index.sai.utils.PartitionInfo
- key - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableIterator
- key - Variable in class org.apache.cassandra.metrics.TopPartitionTracker.TopPartition
- key - Variable in class org.apache.cassandra.security.PEMBasedSslContextFactory.PEMBasedKeyStoreContext
- 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() - 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.io.sstable.format.big.BigTableKeyReader
- key() - Method in class org.apache.cassandra.io.sstable.format.bti.ScrubIterator
- key() - Method in interface org.apache.cassandra.io.sstable.format.bti.ScrubPartitionIterator
-
Serialized partition key or
null
if the iterator reached the end of the index or if the key may not be fully retrieved from the index file. - key() - Method in interface org.apache.cassandra.io.sstable.KeyReader
-
Current key
- key() - Method in class org.apache.cassandra.service.pager.SinglePartitionPager
- Key(Object) - Constructor for class org.apache.cassandra.index.Index.Group.Key
- Key(DecoratedKey, TableMetadata) - Constructor for class org.apache.cassandra.service.paxos.PaxosState.Key
- key_alias - Variable in class org.apache.cassandra.config.TransparentDataEncryptionOptions
- KEY_CACHE - org.apache.cassandra.service.CacheService.CacheType
- KEY_CACHE_HIT - org.apache.cassandra.io.sstable.SSTableReadsListener.SelectionReason
- 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 - org.apache.cassandra.db.compaction.OperationType
- key_cache_save_period - Variable in class org.apache.cassandra.config.Config
- key_cache_size - Variable in class org.apache.cassandra.config.Config
- KEY_PASSWORD - org.apache.cassandra.security.PEMBasedSslContextFactory.ConfigKey
- 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 thePatriciaTrie
. - keyAtPositionFromSecondaryIndex(long) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- keyAtPositionFromSecondaryIndex(long) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- keyAtPositionFromSecondaryIndex(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Reads the key stored at the position saved in SASI.
- keyBytes - Variable in class org.apache.cassandra.db.tries.TriePathReconstructor
- keyCache - Variable in class org.apache.cassandra.service.CacheService
- KeyCache - Class in org.apache.cassandra.io.sstable.keycache
-
A simple wrapper of possibly global cache with local metrics.
- KeyCache(InstrumentingCache<KeyCacheKey, AbstractRowIndexEntry>) - Constructor for class org.apache.cassandra.io.sstable.keycache.KeyCache
- KeyCacheKey - Class in org.apache.cassandra.cache
- KeyCacheKey(TableMetadata, Descriptor, ByteBuffer) - Constructor for class org.apache.cassandra.cache.KeyCacheKey
- KeyCacheMetrics<R extends SSTableReader & KeyCacheSupport<R>> - Class in org.apache.cassandra.io.sstable.keycache
- KeyCacheMetrics() - Constructor for class org.apache.cassandra.io.sstable.keycache.KeyCacheMetrics
- KeyCacheSerializer() - Constructor for class org.apache.cassandra.service.CacheService.KeyCacheSerializer
- KeyCacheSupport<T extends SSTableReader & KeyCacheSupport<T>> - Interface in org.apache.cassandra.io.sstable.keycache
- keyComparableBytes(ByteComparable.Version) - Method in class org.apache.cassandra.db.DecoratedKey
- keyComparableBytes(ByteComparable.Version) - Method in class org.apache.cassandra.db.NativeDecoratedKey
- keyCount - Variable in class org.apache.cassandra.index.sai.disk.v1.keystore.KeyLookupMeta
- keyCount - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
- keyFactory() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- keyFetcher - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
- keyForToken(long) - Static method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
- 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
- keyFromByteSource(ByteSource.Peekable, ByteComparable.Version, IPartitioner) - Static method in class org.apache.cassandra.db.DecoratedKey
- 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() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns a
KeyIterator
over all keys in the sstable. - KeyIterator - Class in org.apache.cassandra.io.sstable
- KeyIterator(KeyReader, IPartitioner, long, ReadWriteLock) - Constructor for class org.apache.cassandra.io.sstable.KeyIterator
- KeyLookup - Class in org.apache.cassandra.index.sai.disk.v1.keystore
-
Provides read access to an on-disk sequence of partition or clustering keys written by
KeyStoreWriter
. - KeyLookup(FileHandle, FileHandle, KeyLookupMeta, NumericValuesMeta) - Constructor for class org.apache.cassandra.index.sai.disk.v1.keystore.KeyLookup
-
Creates a new reader based on its data components.
- KeyLookup.Cursor - Class in org.apache.cassandra.index.sai.disk.v1.keystore
-
Allows reading the keys from the keys file.
- KeyLookupMeta - Class in org.apache.cassandra.index.sai.disk.v1.keystore
-
Metadata produced by
KeyStoreWriter
, needed byKeyLookup
. - KeyLookupMeta(DataInput) - Constructor for class org.apache.cassandra.index.sai.disk.v1.keystore.KeyLookupMeta
- keyPos - Variable in class org.apache.cassandra.db.tries.TriePathReconstructor
- keyPositionForSecondaryIndex() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableKeyReader
- keyPositionForSecondaryIndex() - Method in interface org.apache.cassandra.io.sstable.KeyReader
-
Position in the component preferred for reading keys.
- 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
. - KeyRangeConcatIterator - Class in org.apache.cassandra.index.sai.iterators
-
KeyRangeConcatIterator
takes a list of sorted range iterators and concatenates them, leaving duplicates in place, to produce a new stably sorted iterator. - KeyRangeConcatIterator(KeyRangeIterator.Builder.Statistics, List<KeyRangeIterator>, Runnable) - Constructor for class org.apache.cassandra.index.sai.iterators.KeyRangeConcatIterator
- KeyRangeConcatIterator.Builder - Class in org.apache.cassandra.index.sai.iterators
- KeyRangeIntersectionIterator - Class in org.apache.cassandra.index.sai.iterators
-
A simple intersection iterator that makes no real attempts at optimising the iteration apart from initially sorting the ranges.
- KeyRangeIntersectionIterator.Builder - Class in org.apache.cassandra.index.sai.iterators
- KeyRangeIterator - Class in org.apache.cassandra.index.sai.iterators
-
An abstract implementation of
AbstractGuavaIterator
that supports the building and management of concatanation, union and intersection iterators. - KeyRangeIterator - Class in org.apache.cassandra.index.sasi.memory
- KeyRangeIterator(ConcurrentSkipListSet<DecoratedKey>, int) - Constructor for class org.apache.cassandra.index.sasi.memory.KeyRangeIterator
- KeyRangeIterator(KeyRangeIterator.Builder.Statistics, Runnable) - Constructor for class org.apache.cassandra.index.sai.iterators.KeyRangeIterator
- KeyRangeIterator(KeyRangeIterator, Runnable) - Constructor for class org.apache.cassandra.index.sai.iterators.KeyRangeIterator
- KeyRangeIterator(PrimaryKey, PrimaryKey, long) - Constructor for class org.apache.cassandra.index.sai.iterators.KeyRangeIterator
- KeyRangeIterator(PrimaryKey, PrimaryKey, long, Runnable) - Constructor for class org.apache.cassandra.index.sai.iterators.KeyRangeIterator
- KeyRangeIterator.Builder - Class in org.apache.cassandra.index.sai.iterators
- KeyRangeIterator.Builder.Statistics - Class in org.apache.cassandra.index.sai.iterators
- KeyRangeListIterator - Class in org.apache.cassandra.index.sai.iterators
-
A
KeyRangeIterator
that iterates over a list ofPrimaryKey
s without modifying the underlying list. - KeyRangeListIterator(PrimaryKey, PrimaryKey, List<PrimaryKey>) - Constructor for class org.apache.cassandra.index.sai.iterators.KeyRangeListIterator
-
Create a new
KeyRangeListIterator
that iterates over the provided list of keys. - KeyRangeOrderingIterator - Class in org.apache.cassandra.index.sai.iterators
-
An iterator that consumes a chunk of
PrimaryKey
s from theKeyRangeIterator
, passes them to theFunction
to filter the chunk ofPrimaryKey
s and then pass the results to next consumer. - KeyRangeOrderingIterator(KeyRangeIterator, int, Function<List<PrimaryKey>, KeyRangeIterator>) - Constructor for class org.apache.cassandra.index.sai.iterators.KeyRangeOrderingIterator
- KeyRangeUnionIterator - Class in org.apache.cassandra.index.sai.iterators
-
Range Union Iterator is used to return sorted stream of elements from multiple RangeIterator instances.
- KeyRangeUnionIterator.Builder - Class in org.apache.cassandra.index.sai.iterators
- keyReader() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- keyReader() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- keyReader() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns a
KeyReader
over all keys in the sstable. - KeyReader - Interface in org.apache.cassandra.io.sstable
-
Reads keys from an SSTable.
- keys - Variable in class org.apache.cassandra.serializers.MapSerializer
- keys() - Method in class org.apache.cassandra.index.sai.utils.PrimaryKeys
- KEYS - org.apache.cassandra.cql3.statements.schema.IndexTarget.Type
- KEYS - org.apache.cassandra.db.compaction.CompactionInfo.Unit
- KEYS - org.apache.cassandra.schema.CachingParams.Option
- KEYS - org.apache.cassandra.schema.IndexMetadata.Kind
- KEYS_AND_VALUES - org.apache.cassandra.cql3.statements.schema.IndexTarget.Type
- 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
- 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
- keysFromOrdinal(int) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.OnHeapGraph
- 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 - Variable in class org.apache.cassandra.cql3.functions.FunctionName
- keyspace - Variable in class org.apache.cassandra.cql3.QueryHandler.Prepared
- keyspace - Variable in class org.apache.cassandra.db.ColumnFamilyStore
- 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 - Variable in class org.apache.cassandra.index.sai.metrics.AbstractMetrics
- keyspace - Variable in class org.apache.cassandra.locator.ReplicaPlan.AbstractReplicaPlan
- keyspace - Variable in class org.apache.cassandra.repair.AbstractRepairTask
- 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.RepairSessionResult
- keyspace - Variable in class org.apache.cassandra.repair.state.CoordinatorState
- keyspace - Variable in class org.apache.cassandra.repair.state.SessionState
- keyspace - Variable in class org.apache.cassandra.schema.TableMetadata
- keyspace - Variable in class org.apache.cassandra.schema.TableMetadataRef
- keyspace - Variable in class org.apache.cassandra.streaming.StreamRequest
- keyspace - Variable in class org.apache.cassandra.transport.Event.SchemaChange
- keyspace - Variable in class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
- keyspace() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
- keyspace() - Method in interface org.apache.cassandra.cql3.CQLStatement.SingleKeyspaceCqlStatement
- keyspace() - Method in class org.apache.cassandra.cql3.statements.BatchStatement.Parsed
- 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.AlterSchemaStatement
- keyspace() - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
- keyspace() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
- keyspace() - Method in class org.apache.cassandra.cql3.statements.UseStatement
- keyspace() - Method in class org.apache.cassandra.locator.ReplicaPlan.AbstractReplicaPlan
- keyspace() - Method in interface org.apache.cassandra.locator.ReplicaPlan
- keyspace() - Method in class org.apache.cassandra.schema.ViewMetadata
- keyspace() - Method in class org.apache.cassandra.service.paxos.uncommitted.UncommittedTableData
- keyspace() - Method in class org.apache.cassandra.transport.ConnectedClient
- 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(String) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
- keyspace(String, boolean) - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
-
Creates a
DescribeStatement
forDESCRIBE KEYSPACE
. - Keyspace - Class in org.apache.cassandra.db
-
It represents a Keyspace.
- KEYSPACE - org.apache.cassandra.cql3.SchemaElement.SchemaElementType
- KEYSPACE - org.apache.cassandra.transport.Event.SchemaChange.Target
- KEYSPACE - Static variable in class org.apache.cassandra.db.compaction.CompactionInfo
- KEYSPACE - Static variable in class org.apache.cassandra.fql.FullQueryLogger
- KEYSPACE - Static variable in class org.apache.cassandra.transport.ConnectedClient
- KEYSPACE_COUNT_THRESHOLD_TO_GUARDRAIL - org.apache.cassandra.config.Converters
- KEYSPACE_DOES_NOT_EXIST - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- KEYSPACE_DOES_NOT_MATCH_INDEX - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- KEYSPACE_DOES_NOT_MATCH_TABLE - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- KEYSPACE_NAME - Static variable in class org.apache.cassandra.index.sai.virtual.SegmentsSystemView
- KeyspaceAttributes - Class in org.apache.cassandra.cql3.statements.schema
- KeyspaceAttributes() - Constructor for class org.apache.cassandra.cql3.statements.schema.KeyspaceAttributes
- 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.AlterSchemaStatement
- keyspaceName - Variable in class org.apache.cassandra.cql3.statements.schema.CreateKeyspaceStatement.Raw
- keyspaceName - Variable in class org.apache.cassandra.index.sai.utils.IndexIdentifier
- 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.db.guardrails.Guardrails
-
Guardrail on the total number of user keyspaces.
- keyspaces - Variable in class org.apache.cassandra.tools.nodetool.stats.TableStatsHolder
- keyspaces() - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
-
Creates a
DescribeStatement
forDESCRIBE KEYSPACES
. - Keyspaces - Class in org.apache.cassandra.schema
- KEYSPACES - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
- keyspaces_fail_threshold - Variable in class org.apache.cassandra.config.Config
- keyspaces_warn_threshold - Variable in class org.apache.cassandra.config.Config
- 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 - org.apache.cassandra.config.EncryptionOptions.ConfigKey
- keystore_password - Variable in class org.apache.cassandra.config.EncryptionOptions
- KEYSTORE_PASSWORD - org.apache.cassandra.config.EncryptionOptions.ConfigKey
- keystoreContext - Variable in class org.apache.cassandra.security.FileBasedSslContextFactory
- KeyStoreWriter - Class in org.apache.cassandra.index.sai.disk.v1.keystore
-
Writes a sequence of partition keys or clustering keys for use with
KeyLookup
. - KeyStoreWriter(String, MetadataWriter, IndexOutput, NumericValuesWriter, int, boolean) - Constructor for class org.apache.cassandra.index.sai.disk.v1.keystore.KeyStoreWriter
-
Creates a new writer.
- keyString(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- keyType() - Method in class org.apache.cassandra.db.SerializationHeader
- keyValidator - Variable in class org.apache.cassandra.index.sasi.memory.MemIndex
- keyValidator() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
- KIBIBYTES - org.apache.cassandra.config.DataStorageSpec.DataStorageUnit
- KIBIBYTES_DATASTORAGE - org.apache.cassandra.config.Converters
- KIBIBYTES_PER_SECOND - org.apache.cassandra.config.DataRateSpec.DataRateUnit
- 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) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
- 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.cql3.selection.Selectable.WritetimeOrTTL
- kind - Variable in class org.apache.cassandra.db.AbstractOnHeapClusteringPrefix
- kind - Variable in class org.apache.cassandra.db.marshal.CollectionType
- kind - Variable in enum org.apache.cassandra.net.Verb
- kind - Variable in class org.apache.cassandra.repair.state.Completable.Result
- 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 - Variable in class org.apache.cassandra.schema.TableMetadata
- kind - Variable in class org.apache.cassandra.transport.messages.ResultMessage
- kind() - Method in class org.apache.cassandra.cql3.selection.Selector
-
Returns the
Selector
kind. - 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() - 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() - Method in class org.apache.cassandra.dht.Token.KeyBound
- kind() - Method in interface org.apache.cassandra.index.sai.utils.PrimaryKey
-
Returns the
PrimaryKey.Kind
of thePrimaryKey
. - 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(int) - Static method in class org.apache.cassandra.db.rows.UnfilteredSerializer
- kind(TableMetadata.Kind) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- klass - Variable in class org.apache.cassandra.schema.ReplicationParams
- klass() - Method in class org.apache.cassandra.schema.CompactionParams
- klass() - Method in class org.apache.cassandra.schema.CompressionParams
- knownDefinitions() - Static method in class org.apache.cassandra.schema.MemtableParams
- knows(InetAddressAndPort) - Method in class org.apache.cassandra.net.EndpointMessagingVersions
- KS_ALTERED - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- KS_ALTERING - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- KS_CREATED - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- KS_CREATING - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- KS_DROPPED - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- KS_DROPPING - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- KS_METADATA_LOADED - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- KS_METADATA_RELOADED - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- KS_METADATA_REMOVED - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- ksname - Variable in class org.apache.cassandra.io.sstable.Descriptor
- ksName - Variable in class org.apache.cassandra.cql3.ColumnSpecification
- ksName - Variable in exception org.apache.cassandra.exceptions.AlreadyExistsException
L
- LANDMARK_RESET_INTERVAL_IN_NS - 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
- LARGE_MESSAGES - org.apache.cassandra.net.ConnectionType
- 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
- LARGER_STATE_SEEN - org.apache.cassandra.repair.state.AbstractState.UpdateType
- largestGcgs() - Method in class org.apache.cassandra.schema.Schema
-
Compute the largest gc grace seconds amongst all the tables
- 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.big.IndexSummaryComponent
- last - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
- last - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
- 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
- LAST_VALID_SEGMENT_ROW_ID - Static variable in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder
- lastClustering - Variable in class org.apache.cassandra.io.sstable.format.SortedTablePartitionWriter
- LastCommitLogPosition(CommitLogPosition) - Constructor for class org.apache.cassandra.db.memtable.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
- lastFlushShardDataSizes - Variable in class org.apache.cassandra.metrics.TrieMemtableMetricsView
- lastHeartbeat - Variable in class org.apache.cassandra.service.DataResurrectionCheck.Heartbeat
- 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 - Variable in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryBuilder.ReadableBoundary
- lastKey - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
- lastKey() - Method in class org.apache.cassandra.index.sasi.utils.trie.PatriciaTrie
- lastKey() - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex
- lastKeyComparator - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
- lastModified() - Method in class org.apache.cassandra.io.util.File
- lastName - Variable in class org.apache.cassandra.io.sstable.IndexInfo
- lastPrimaryKeyInRange() - Method in class org.apache.cassandra.index.sai.plan.QueryController
- 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
- lastTransition() - Method in class org.apache.cassandra.io.tries.Walker
- lastTransition(ByteBuffer, int, long) - Method in class org.apache.cassandra.io.tries.TrieNode
-
Returns the highest transition for this node, or NONE if none exist (PAYLOAD_ONLY nodes).
- lastUpdate - Variable in class org.apache.cassandra.metrics.TopPartitionTracker.TopHolder
- lastUpdated - Variable in class org.apache.cassandra.metrics.TopPartitionTracker.StoredTopPartitions
- lastUpdatedAtMillis() - Method in class org.apache.cassandra.streaming.StreamingState
- lastUpdatedAtNanos() - Method in class org.apache.cassandra.streaming.StreamingState
- lastUpdatedAtNs - Variable in class org.apache.cassandra.repair.state.AbstractCompletable
- lastWriteFuture - Variable in class org.apache.cassandra.transport.SimpleClient
- latch - Variable in class org.apache.cassandra.service.paxos.v1.AbstractPaxosCallback
- latency - Variable in class org.apache.cassandra.metrics.LatencyMetrics
-
Latency
- LATENCY - org.apache.cassandra.index.sai.disk.v1.vector.OptimizeFor
- 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, 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(MetricNameFactory, MetricNameFactory, String) - Constructor for class org.apache.cassandra.metrics.LatencyMetrics
- LatencyMetrics.LatencyMetricsTimer - Class in org.apache.cassandra.metrics
- LatencyMetricsTimer(Reservoir) - Constructor for class org.apache.cassandra.metrics.LatencyMetrics.LatencyMetricsTimer
- latencySubscribers - Variable in class org.apache.cassandra.net.MessagingService
- 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.Subscriber - Interface in org.apache.cassandra.net
- latest(C, C) - Static method in class org.apache.cassandra.service.paxos.Commit
-
the latest of two ballots, or the first ballot if equal timestamps
- latest(Ballot, Ballot) - Static method in class org.apache.cassandra.service.paxos.Commit
-
the latest of two ballots, or the first ballot if equal timestamps
- latest(Commit, Ballot) - Static method in class org.apache.cassandra.service.paxos.Commit
-
the latest of two ballots, or the first ballot if equal timestamps
- LATEST - Static variable in class org.apache.cassandra.index.sai.disk.format.Version
- latestAccepted(Commit.Accepted, Commit.Accepted) - Static method in class org.apache.cassandra.service.paxos.Commit.Accepted
-
Like
Commit.latest(Commit, Commit)
but also takes into account deletion time - latestCommitted(Commit.Committed, Commit.Committed) - Static method in class org.apache.cassandra.service.paxos.Commit.Committed
- latestWitnessedOrLowBound() - Method in class org.apache.cassandra.service.paxos.PaxosState.Snapshot
- latestWitnessedOrLowBound(Ballot) - Method in class org.apache.cassandra.service.paxos.PaxosState.Snapshot
- latestWriteOrLowBound() - Method in class org.apache.cassandra.service.paxos.PaxosState.Snapshot
- LazilyInitializedUnfilteredRowIterator - Class in org.apache.cassandra.db.rows
-
Abstract class to create UnfilteredRowIterator that lazily initializes itself.
- LazilyInitializedUnfilteredRowIterator(DecoratedKey) - Constructor for class org.apache.cassandra.db.rows.LazilyInitializedUnfilteredRowIterator
- lazy(Supplier<String>) - Static method in interface org.apache.cassandra.utils.LazyToString
- LazyToString - Interface in org.apache.cassandra.utils
- 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
- leak() - Method in interface org.apache.cassandra.utils.memory.BufferPool.DebugLeaks
- leaving(Collection<Token>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- LEAVING - org.apache.cassandra.service.StorageService.Mode
- left - Variable in class org.apache.cassandra.dht.AbstractBounds
- 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.dht.Splitter.WeightedRange
- left() - Method in class org.apache.cassandra.utils.Pair
- left(Collection<Token>, long) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- left(Collection<Token>, long, int) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- leftBoundary() - Method in class org.apache.cassandra.dht.AbstractBounds
- leftmostLeaf - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
- legacy - org.apache.cassandra.config.Config.DiskAccessMode
- legacy - org.apache.cassandra.config.Config.PaxosStatePurging
-
system.paxos records are written and garbage collected with TTLs.
- LEGACY - org.apache.cassandra.utils.bytecomparable.ByteComparable.Version
- 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.See CASSANDRA-14404
- LEGACY_MESSAGES - org.apache.cassandra.net.ConnectionType
- LEGACY_PEER_EVENTS - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
Deprecated.See CASSANDRA-7544
- LEGACY_PEERS - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
Deprecated.See CASSANDRA-7544
- LEGACY_SIZE_ESTIMATES - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
Deprecated.See CASSANDRA-15637
- legacy_ssl_storage_port_enabled - Variable in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
- LEGACY_SSTABLE_ACTIVITY - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
Deprecated.See CASSANDRA-17048
- LEGACY_TRANSFERRED_RANGES - Static variable in class org.apache.cassandra.db.SystemKeyspace
-
Deprecated.See CASSANDRA-7544
- 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.MutualTlsAuthenticator
- legacyAuthenticate(Map<String, String>) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
- legacyCas(String, String, DecoratedKey, CASRequest, ConsistencyLevel, ConsistencyLevel, ClientState, long, Dispatcher.RequestTime) - Static method in class org.apache.cassandra.service.StorageProxy
- LegacyHistogramSerializer() - Constructor for class org.apache.cassandra.utils.streamhist.TombstoneHistogram.LegacyHistogramSerializer
- legacyPaxosTtlSec(TableMetadata) - Static method in class org.apache.cassandra.db.SystemKeyspace
- legacyPrepare(Commit) - Static method in class org.apache.cassandra.service.paxos.PaxosState
- legacyPropose(Commit) - Static method in class org.apache.cassandra.service.paxos.PaxosState
- LegacySerializer() - Constructor for class org.apache.cassandra.db.DeletionTime.LegacySerializer
- LegacyTimeUUIDType - Class in org.apache.cassandra.db.marshal
- LegacyTimeUUIDType() - Constructor for class org.apache.cassandra.db.marshal.LegacyTimeUUIDType
- length - Variable in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata.ComponentMetadata
- length - Variable in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
- length() - Method in class org.apache.cassandra.index.sai.disk.io.IndexInputReader
- length() - Method in class org.apache.cassandra.index.sai.disk.v1.bitpack.AbstractBlockPackedReader
- length() - Method in class org.apache.cassandra.index.sai.disk.v1.LongArray.DeferredLongArray
- length() - Method in interface org.apache.cassandra.index.sai.disk.v1.LongArray
-
Get array length.
- 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() - Method in class org.apache.cassandra.io.util.File
- 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(ByteComparable, ByteComparable.Version) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteComparable
-
Return the length of a byte comparable, not including the terminator byte.
- LENGTH - Static variable in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata.ComponentMetadata
- 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.
- LESS_THAN - org.apache.cassandra.db.context.CounterContext.Relationship
- lesserBranch - Variable in class org.apache.cassandra.io.tries.Walker
- lesserTransition(int, long) - Method in class org.apache.cassandra.io.tries.Walker
- lesserTransition(ByteBuffer, int, long, int, long) - Method in class org.apache.cassandra.io.tries.TrieNode
-
Returns a transition that is lower than the index returned by
search
. - level - Variable in class org.apache.cassandra.db.compaction.LeveledManifest.CompactionCandidate
- level - Variable in class org.apache.cassandra.db.virtual.LogMessagesTable.LogMessage
- Level(long, int) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskIndex.Level
- LEVEL_COLUMN_NAME - Static variable in class org.apache.cassandra.db.virtual.LogMessagesTable
- 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, long, 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
- LexicalUUIDType.Serializer - Class in org.apache.cassandra.db.marshal
- LIBJEMALLOC - org.apache.cassandra.config.CassandraRelevantProperties
-
startup checks properties
- lifecycleNewTracker - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
- 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
- LightweightRecycler<T> - Interface in org.apache.cassandra.utils.concurrent
-
A simple thread local object reuse facility with limited capacity and no attempt at rebalancing pooling between threads.
- LIKE - org.apache.cassandra.cql3.Operator
- LIKE_CONTAINS - org.apache.cassandra.cql3.Operator
- LIKE_MATCHES - org.apache.cassandra.cql3.Operator
- LIKE_PREFIX - org.apache.cassandra.cql3.Operator
- LIKE_SUFFIX - org.apache.cassandra.cql3.Operator
- 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 - Variable in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
- limit() - Method in class org.apache.cassandra.index.sai.VectorQueryContext
- limit() - 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() - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.AbstractEscaper
- limit() - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.AccessorEscaper
- limit() - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.ArrayEscaper
- limit() - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.BufferEscaper
- limit() - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.MemoryEscaper
- limit(long) - Method in class org.apache.cassandra.hints.ChecksummedDataInput
- limit(long) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
- limitBytes() - Method in class org.apache.cassandra.index.sai.utils.NamedMemoryLimiter
- 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
- limitToTopKResults(QueryContext, List<PrimaryKey>, Expression) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.Segment
- limitToTopKResults(QueryContext, List<PrimaryKey>, Expression) - Method in interface org.apache.cassandra.index.sai.disk.v1.segment.SegmentOrdering
-
Reorder, limit, and put back into original order the results from a single sstable
- limitToTopKResults(QueryContext, List<PrimaryKey>, Expression) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.VectorIndexSegmentSearcher
- limitToTopKResults(QueryContext, List<PrimaryKey>, Expression) - Method in class org.apache.cassandra.index.sai.disk.v1.V1SSTableIndex
- limitToTopResults(List<PrimaryKey>, Expression, int) - Method in class org.apache.cassandra.index.sai.memory.MemtableIndex
- limitToTopResults(List<PrimaryKey>, Expression, int) - Method in interface org.apache.cassandra.index.sai.memory.MemtableOrdering
-
Filter the given list of
PrimaryKey
results to the top `limit` results corresponding to the given expression, Returns an iterator over the results that is put back in token order. - limitToTopResults(List<PrimaryKey>, Expression, int) - Method in class org.apache.cassandra.index.sai.memory.VectorMemoryIndex
- limitToTopResults(QueryContext, List<PrimaryKey>, Expression) - Method in class org.apache.cassandra.index.sai.memory.MemtableIndexManager
- LINE_SEPARATOR - org.apache.cassandra.config.CassandraRelevantProperties
-
Line separator ("\n" on UNIX).
- linearizabilityViolations - Static variable in class org.apache.cassandra.metrics.PaxosMetrics
- LINUX - org.apache.cassandra.utils.NativeLibrary.OSType
- list - Variable in class org.apache.cassandra.locator.AbstractReplicaCollection
- list() - Method in class org.apache.cassandra.db.Directories.SSTableLister
- list() - Method in class org.apache.cassandra.io.util.File
- list() - Method in class org.apache.cassandra.utils.JMXServerUtils.JmxRegistry
- list(boolean) - Method in class org.apache.cassandra.db.Directories.SSTableLister
-
This method is used upon SSTable importing (nodetool import) as there is no strict requirement to place SSTables in a directory structure where name of a directory equals to table name and parent of such directory equals to keyspace name.
- list(Path, Function<Stream<Path>, Stream<T>>, IntFunction<T[]>) - Static method in class org.apache.cassandra.io.util.PathUtils
- list(BiPredicate<File, String>) - Method in class org.apache.cassandra.io.util.File
- list(Predicate<File>) - Method in class org.apache.cassandra.io.util.File
- 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) - Static method in class org.apache.cassandra.cql3.functions.types.DataType
-
Returns the type of "not frozen" lists of
elementType
elements. - list(DataType, boolean) - Static method in class org.apache.cassandra.cql3.functions.types.DataType
-
Returns the type of 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 - org.apache.cassandra.cql3.functions.types.DataType.Name
- LIST - org.apache.cassandra.db.marshal.CollectionType.Kind
- LIST - org.apache.cassandra.transport.DataType
- LIST_PERMISSIONS - org.apache.cassandra.audit.AuditLogEntryType
- LIST_ROLES - org.apache.cassandra.audit.AuditLogEntryType
- LIST_SELECTOR - org.apache.cassandra.cql3.selection.Selector.Kind
- LIST_USERS - org.apache.cassandra.audit.AuditLogEntryType
- listAvailableCidrGroups() - Method in class org.apache.cassandra.tools.NodeProbe
- ListCIDRGroups - Class in org.apache.cassandra.tools
-
Nodetool command to list available CIDR groups, in the table
AuthKeyspace.CIDR_GROUPS
- ListCIDRGroups() - Constructor for class org.apache.cassandra.tools.ListCIDRGroups
- listCidrsOfCidrGroup(String) - Method in class org.apache.cassandra.tools.NodeProbe
- 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
- listener(FutureCallback<V>) - Static method in interface org.apache.cassandra.utils.concurrent.Promise
- listener(ExecutorService, FutureCallback<V>) - Static method in interface org.apache.cassandra.utils.concurrent.Promise
- 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
- listFiles() - Method in class org.apache.cassandra.db.Directories.SSTableLister
- listFiles(boolean) - 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
- listIndexGroups() - Method in interface org.apache.cassandra.index.IndexRegistry
- listIndexGroups() - 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
- listNames() - Method in class org.apache.cassandra.io.util.File
- listNames(BiPredicate<File, String>) - Method in class org.apache.cassandra.io.util.File
- listNamesUnchecked() - Method in class org.apache.cassandra.io.util.File
- listNamesUnchecked(BiPredicate<File, String>) - Method in class org.apache.cassandra.io.util.File
- listOf(TypeToken<T>) - Static method in class org.apache.cassandra.cql3.functions.types.TypeTokens
-
Create a
TypeToken
that represents aList
whose elements are of the given type. - listOf(Class<T>) - Static method in class org.apache.cassandra.cql3.functions.types.TypeTokens
-
Create a
TypeToken
that represents aList
whose elements are of the given type. - listPendingHints() - Method in class org.apache.cassandra.tools.NodeProbe
- ListPendingHints - Class in org.apache.cassandra.tools.nodetool
- ListPendingHints() - Constructor for class org.apache.cassandra.tools.nodetool.ListPendingHints
- 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
- listSnapshotDirsByTag() - Method in class org.apache.cassandra.db.Directories
- listSnapshots() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- listSnapshots() - Method in class org.apache.cassandra.db.Directories
- ListSnapshots - Class in org.apache.cassandra.tools.nodetool
- ListSnapshots() - Constructor for class org.apache.cassandra.tools.nodetool.ListSnapshots
- 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. - listToString(List<?>) - Static method in class org.apache.cassandra.cql3.Lists
-
Create a
String
representation of the list containing the specified elements. - ListType<T> - Class in org.apache.cassandra.db.marshal
- listUnchecked() - Method in class org.apache.cassandra.io.util.File
- listUnchecked(BiPredicate<File, String>) - Method in class org.apache.cassandra.io.util.File
- listUnchecked(Predicate<File>) - Method in class org.apache.cassandra.io.util.File
- 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<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(List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.Vectors.Literal
- Literal(List<Pair<Term.Raw, Term.Raw>>) - Constructor for class org.apache.cassandra.cql3.Maps.Literal
- Literal(Map<FieldIdentifier, Term.Raw>) - Constructor for class org.apache.cassandra.cql3.UserTypes.Literal
- LITERAL_COMPONENTS - Static variable in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- LiteralIndexSegmentSearcher - Class in org.apache.cassandra.index.sai.disk.v1.segment
-
Executes
Expression
s against the trie-based terms dictionary for an individual index segment. - LiteralIndexSegmentTermsReader - Class in org.apache.cassandra.index.sai.disk.v1.segment
-
Synchronous reader of terms dictionary and postings lists to produce a
PostingList
with matching row ids. - LiteralIndexSegmentTermsReader(IndexIdentifier, FileHandle, FileHandle, long, long) - Constructor for class org.apache.cassandra.index.sai.disk.v1.segment.LiteralIndexSegmentTermsReader
- LiteralIndexSegmentTermsReader.TermQuery - Class in org.apache.cassandra.index.sai.disk.v1.segment
- LiteralIndexWriter - Class in org.apache.cassandra.index.sai.disk.v1.trie
-
Builds an on-disk inverted index structure: terms dictionary and postings lists.
- LiteralIndexWriter(IndexDescriptor, IndexIdentifier) - Constructor for class org.apache.cassandra.index.sai.disk.v1.trie.LiteralIndexWriter
- 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() - Method in class org.apache.cassandra.locator.ReplicaPlan.ForWrite
-
The live replicas present in liveAndDown, usually derived from FailureDetector.isReplicaAlive
- 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 - org.apache.cassandra.db.lifecycle.SSTableSet
- 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 variable in class org.apache.cassandra.db.rows.Row.Deletion
- 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 tables in this keyspace
- 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.
- liveMemtableWriteCount() - Method in class org.apache.cassandra.index.sai.memory.MemtableIndexManager
- 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
andright
, 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 - Static variable in class org.apache.cassandra.metrics.StorageMetrics
- load() - Method in class org.apache.cassandra.diag.store.DiagnosticEventMemoryStore
- load() - Method in interface org.apache.cassandra.diag.store.DiagnosticEventStore
-
Initializes the store.
- load() - Method in class org.apache.cassandra.schema.PartitionDenylist
-
We need to fully rebuild a new cache to accommodate deleting items from the denylist and potentially shrinking the max allowable size in the list.
- load(double) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- load(String, String) - Static method in class org.apache.cassandra.service.paxos.TablePaxosRepairHistory
- load(ChunkCache.Key) - Method in class org.apache.cassandra.cache.ChunkCache
- load(MetadataSource, PrimaryKey.Factory) - Static method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata
- load(Descriptor) - Static method in class org.apache.cassandra.io.sstable.format.CompressionInfoComponent
- load(Descriptor) - Static method in class org.apache.cassandra.io.sstable.format.FilterComponent
-
Load bloom filter from Filter.db file.
- load(Descriptor) - Static method in class org.apache.cassandra.io.sstable.format.StatsComponent
- load(Descriptor, MetadataType...) - Static method in class org.apache.cassandra.io.sstable.format.StatsComponent
- load(File) - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosBallotTracker
- load(File) - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker
- load(FileHandle.Builder, IPartitioner, boolean) - Static method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex
- load(FileHandle, IPartitioner, boolean) - Static method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex
- load(File, TableMetadata) - Static method in class org.apache.cassandra.io.sstable.format.big.IndexSummaryComponent
-
Load index summary, first key and last key from Summary.db file if it exists.
- load(LoaderOptions) - Static method in class org.apache.cassandra.tools.BulkLoader
- LOAD - org.apache.cassandra.gms.ApplicationState
- LOAD_RING_STATE - org.apache.cassandra.config.CassandraRelevantProperties
-
Load persistence ring state.
- LoadBroadcaster - Class in org.apache.cassandra.service
- loadCidrGroupsCache() - Method in class org.apache.cassandra.auth.AllowAllCIDRAuthorizer
- loadCidrGroupsCache() - Method in class org.apache.cassandra.auth.CassandraCIDRAuthorizer
- loadCidrGroupsCache() - Method in class org.apache.cassandra.auth.CIDRGroupsMappingCache
-
Builds CIDR groups cache the first time.
- loadCidrGroupsCache() - Method in class org.apache.cassandra.auth.CIDRGroupsMappingManager
- loadCidrGroupsCache() - Method in interface org.apache.cassandra.auth.CIDRGroupsMappingManagerMBean
-
Trigger reload of CIDR groups cache
- loadCidrGroupsCache() - Method in interface org.apache.cassandra.auth.ICIDRAuthorizer
-
Load CIDR groups mapping cache
- loadClass(String) - Method in class org.apache.cassandra.triggers.CustomClassLoader
- loadClassInternal(String) - Method in class org.apache.cassandra.triggers.CustomClassLoader
- loadColumnMetadata(IndexDescriptor, IndexIdentifier) - Static method in class org.apache.cassandra.index.sai.disk.v1.MetadataSource
- 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 - Interface in org.apache.cassandra.config
- LoaderOptions - Class in org.apache.cassandra.tools
- loadFilter(ValidationMetadata) - Method in class org.apache.cassandra.io.sstable.format.SortedTableReaderLoadingBuilder
- loadFirstAndLastKey(File, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.format.big.IndexSummaryComponent
- loadFromDisk() - Method in class org.apache.cassandra.schema.Schema
-
Load keyspaces definitions from local storage, see
SchemaUpdateHandler.reset(boolean)
. - loadGroupMetadata(IndexDescriptor) - Static method in class org.apache.cassandra.index.sai.disk.v1.MetadataSource
- loadHostIds() - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Return a map of store host_ids to IP addresses
- loadIdentityStatement() - Method in class org.apache.cassandra.auth.CassandraRoleManager
- loadIfExists(Descriptor) - Static method in class org.apache.cassandra.io.sstable.format.CompressionInfoComponent
- loadingBuilder(Descriptor, TableMetadataRef, Set<Component>) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat.SSTableReaderFactory
-
A builder which opens/loads all the required resources upon execution of
SSTableReaderLoadingBuilder.build(SSTable.Owner, boolean, boolean)
and passed them to the created reader instance. - LoadingMap<K,V> - Class in org.apache.cassandra.utils.concurrent
-
An extension of
NonBlockingHashMap
where all values are wrapped byFuture
. - LoadingMap() - Constructor for class org.apache.cassandra.utils.concurrent.LoadingMap
- LoadingMap.UnloadExecutionException - Exception in org.apache.cassandra.utils.concurrent
-
Thrown when unloading a value failed.
- loadNewSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Deprecated.See CASSANDRA-6719
- loadNewSSTables() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
-
Deprecated.See CASSANDRA-6719
- loadNewSSTables(String, String) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
-
See #
StorageService.importNewSSTables
for more info - loadNewSSTables(String, String) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-14417
- loadNewSSTables(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-14417
- loadNewSSTables(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
-
Deprecated.See CASSANDRA-6719
- loadOrCreate(Descriptor) - Static method in class org.apache.cassandra.io.sstable.format.TOCComponent
- loadOrDeleteCorrupted(File, TableMetadata) - Static method in class org.apache.cassandra.io.sstable.format.big.IndexSummaryComponent
- loadPartitionDenylist() - Method in class org.apache.cassandra.service.StorageProxy
- loadPartitionDenylist() - Method in interface org.apache.cassandra.service.StorageProxyMBean
- loadPaxosRepairHistory(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
- loadPaxosState(DecoratedKey, TableMetadata, long) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Load the current paxos state for the table and key NOTE: nowInSec is typically provided as zero, and should not be assumed to be definitive, as the cache may apply different nowInSec filters
- loadPreparedStatement(MD5Digest, SystemKeyspace.TriFunction<MD5Digest, String, String, Boolean>) - Static method in class org.apache.cassandra.db.SystemKeyspace
- loadPreparedStatements(SystemKeyspace.TriFunction<MD5Digest, String, String, Boolean>) - Static method in class org.apache.cassandra.db.SystemKeyspace
- loadRoleStatement() - Method in class org.apache.cassandra.auth.CassandraRoleManager
- loadSaved() - Method in class org.apache.cassandra.cache.AutoSavingCache
- loadSavedAsync() - Method in class org.apache.cassandra.cache.AutoSavingCache
- loadSnapshots() - Method in class org.apache.cassandra.service.snapshot.SnapshotLoader
- loadSnapshots() - Method in class org.apache.cassandra.service.snapshot.SnapshotManager
- loadSnapshots(String) - Method in class org.apache.cassandra.service.snapshot.SnapshotLoader
- loadSnapshots(String) - Method in class org.apache.cassandra.service.snapshot.SnapshotManager
- loadsstables - Variable in class org.apache.cassandra.db.lifecycle.Tracker
- loadTOC(Descriptor) - Static method in class org.apache.cassandra.io.sstable.format.TOCComponent
-
Reads the list of components from the TOC component.
- loadTOC(Descriptor, boolean) - Static method in class org.apache.cassandra.io.sstable.format.TOCComponent
-
Reads the list of components from the TOC component.
- 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 - Variable in class org.apache.cassandra.dht.RangeStreamer.FetchReplica
- local - Variable in class org.apache.cassandra.service.ActiveRepairService.ConsistentSessions
- local() - Static method in class org.apache.cassandra.schema.KeyspaceParams
- LOCAL - org.apache.cassandra.db.rows.DeserializationHelper.Flag
- LOCAL - org.apache.cassandra.service.paxos.Ballot.Flag
- LOCAL - Static variable in class org.apache.cassandra.db.SystemKeyspace
- LOCAL_ONE - org.apache.cassandra.db.ConsistencyLevel
- LOCAL_QUORUM - org.apache.cassandra.db.ConsistencyLevel
- LOCAL_READ_SIZE_FAIL - org.apache.cassandra.net.ParamType
- local_read_size_fail_threshold - Variable in class org.apache.cassandra.config.Config
- LOCAL_READ_SIZE_WARN - org.apache.cassandra.net.ParamType
- local_read_size_warn_threshold - Variable in class org.apache.cassandra.config.Config
- LOCAL_READ_TIME - org.apache.cassandra.metrics.Sampler.SamplerType
- LOCAL_SERIAL - org.apache.cassandra.db.ConsistencyLevel
- 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
- localAware() - Method in class org.apache.cassandra.concurrent.ExecutorFactory.Default
- localAware() - Method in interface org.apache.cassandra.concurrent.ExecutorFactory
- localAware() - Static method in interface org.apache.cassandra.concurrent.TaskFactory
- LocalAware() - Constructor for class org.apache.cassandra.concurrent.TaskFactory.LocalAware
- LocalAwareExecutorPlus - Interface in org.apache.cassandra.concurrent
-
An
ExecutorPlus
that is aware of, and propagates to execution, any ExecutorLocals - LocalAwareSequentialExecutorPlus - Interface in org.apache.cassandra.concurrent
-
A
SequentialExecutorPlus
that is aware of, and propagates to execution, any ExecutorLocals - LocalAwareSingleThreadExecutorPlus - Class in org.apache.cassandra.concurrent
- LocalAwareThreadPoolExecutorPlus - Class in org.apache.cassandra.concurrent
- localDataDiskUsage - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the data disk usage on the local node, used by a periodic task to calculate and propagate that status.
- LocalDate - Class in org.apache.cassandra.cql3.functions.types
-
A date with no time components, no time zone, in the ISO 8601 calendar.
- localDeletionTime - Variable in class org.apache.cassandra.service.paxos.Commit.AcceptedWithTTL
- localDeletionTime - Variable in class org.apache.cassandra.service.paxos.Commit.CommittedWithTTL
- localDeletionTime() - Method in class org.apache.cassandra.db.DeletionTime.InvalidDeletionTime
- 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.Cell
-
The cell local deletion time.
- localDeletionTimeAsUnsignedInt() - Method in class org.apache.cassandra.db.rows.ArrayCell
- localDeletionTimeAsUnsignedInt() - Method in class org.apache.cassandra.db.rows.BufferCell
- localDeletionTimeAsUnsignedInt() - Method in class org.apache.cassandra.db.rows.Cell
- localDeletionTimeAsUnsignedInt() - Method in class org.apache.cassandra.db.rows.NativeCell
- localDeletionTimeSerializedSize(long) - 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
- localRangeSplits(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- localRangeSplits(int) - Method in interface org.apache.cassandra.db.memtable.Memtable.Owner
-
Construct a list of boundaries that split the locally-owned ranges into the given number of shards, splitting the owned space evenly.
- localRangesUpdated() - Method in class org.apache.cassandra.db.memtable.AbstractAllocatorMemtable
- localRangesUpdated() - Method in interface org.apache.cassandra.db.memtable.Memtable
-
Called when the known ranges have been updated and owner.localRangeSplits() may return different values.
- localRangesWeighted() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- 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, Dispatcher.RequestTime) - Constructor for class org.apache.cassandra.service.StorageProxy.LocalReadRunnable
- LocalReadRunnable(ReadCommand, ReadCallback, Dispatcher.RequestTime, boolean) - Constructor for class org.apache.cassandra.service.StorageProxy.LocalReadRunnable
- localReadSize - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
- localReadSize - Variable in class org.apache.cassandra.metrics.TableMetrics
- localReadSize - Variable in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- localReadSizeAbort(ImmutableSet<InetAddressAndPort>, long) - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Builder
- localReadSizeAbort(WarningsSnapshot.Counter) - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Builder
- localReadSizeAbortMessage(int, long, String) - Static method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- localReadSizeAborts - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
- localReadSizeAborts - Variable in class org.apache.cassandra.metrics.TableMetrics
- LocalReadSizeTooLargeException - Exception in org.apache.cassandra.db.filter
- LocalReadSizeTooLargeException(String) - Constructor for exception org.apache.cassandra.db.filter.LocalReadSizeTooLargeException
- localReadSizeWarning(ImmutableSet<InetAddressAndPort>, long) - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Builder
- localReadSizeWarning(WarningsSnapshot.Counter) - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Builder
- localReadSizeWarnings - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
- localReadSizeWarnings - Variable in class org.apache.cassandra.metrics.TableMetrics
- localReadSizeWarnMessage(int, long, String) - Static method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- localReadWriteRatio - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- LocalRepairTables - Class in org.apache.cassandra.db.virtual
- localRequests - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
- 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(SharedContext) - Constructor for class org.apache.cassandra.repair.consistent.LocalSessions
- LocalSessions.Listener - Interface in org.apache.cassandra.repair.consistent
- localSpaceCoverage() - Method in interface org.apache.cassandra.db.compaction.ShardManager
-
The total fraction of the token space covered by the local ranges.
- localSpaceCoverage() - Method in class org.apache.cassandra.db.compaction.ShardManagerNoDisks
- localSpaceCoverage() - Method in class org.apache.cassandra.db.compaction.ShardManagerTrivial
- 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(SharedContext, RepairJobDesc, InetAddressAndPort, InetAddressAndPort, List<Range<Token>>, TimeUUID, 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
- lock(DecoratedKey, TableMetadata, long, ConsistencyLevel, boolean) - Static method in class org.apache.cassandra.service.paxos.PaxosState
- LOCK_SUPPORT - org.apache.cassandra.utils.Simulate.With
-
Usages of LockSupport.
- LockedDynamicList<E> - Class in org.apache.cassandra.utils
- LockedDynamicList(int) - Constructor for class org.apache.cassandra.utils.LockedDynamicList
- LOCKING_OPTION - Static variable in class org.apache.cassandra.db.memtable.ShardedSkipListMemtable
- log - org.apache.cassandra.config.Config.PaxosOnLinearizabilityViolation
- log() - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
- log() - Method in class org.apache.cassandra.metrics.HintedHandoffMetrics
- log() - Static method in class org.apache.cassandra.utils.StatusLogger
- log(Number) - Method in class org.apache.cassandra.db.marshal.ByteType
- log(Number) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
- log(Number) - Method in class org.apache.cassandra.db.marshal.DecimalType
- log(Number) - Method in class org.apache.cassandra.db.marshal.DoubleType
- log(Number) - Method in class org.apache.cassandra.db.marshal.FloatType
- log(Number) - Method in class org.apache.cassandra.db.marshal.Int32Type
- log(Number) - Method in class org.apache.cassandra.db.marshal.IntegerType
- log(Number) - Method in class org.apache.cassandra.db.marshal.LongType
- log(Number) - Method in class org.apache.cassandra.db.marshal.NumberType
-
Takes the natural logrithm of the argument.
- log(Number) - Method in class org.apache.cassandra.db.marshal.ShortType
- log(BigDecimal) - Method in class org.apache.cassandra.db.marshal.DecimalType
- 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(NoSpamLogger.Level, long, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
- log(NoSpamLogger.Level, long, Supplier<Object[]>) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
- log(NoSpamLogger.Level, String, long, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
- 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, long, TimeUnit, String, Supplier<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(Logger, NoSpamLogger.Level, String, long, TimeUnit, long, String, Supplier<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, String, Supplier<Object[]>) - Static method in class org.apache.cassandra.utils.NoSpamLogger
- LOG - org.apache.cassandra.utils.MBeanWrapper.OnException
- LOG_ALL_OPTION - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
- log_dir - Variable in class org.apache.cassandra.fql.FullQueryLoggerOptions
- LOG_DIR - org.apache.cassandra.config.CassandraRelevantProperties
-
Directory where Cassandra puts its logs, defaults to "." which is current directory.
- LOG_DIR_AUDIT - org.apache.cassandra.config.CassandraRelevantProperties
-
Directory where Cassandra persists logs from audit logging.
- log10(Number) - Method in class org.apache.cassandra.db.marshal.ByteType
- log10(Number) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
- log10(Number) - Method in class org.apache.cassandra.db.marshal.DecimalType
- log10(Number) - Method in class org.apache.cassandra.db.marshal.DoubleType
- log10(Number) - Method in class org.apache.cassandra.db.marshal.FloatType
- log10(Number) - Method in class org.apache.cassandra.db.marshal.Int32Type
- log10(Number) - Method in class org.apache.cassandra.db.marshal.IntegerType
- log10(Number) - Method in class org.apache.cassandra.db.marshal.LongType
- log10(Number) - Method in class org.apache.cassandra.db.marshal.NumberType
-
Takes the log base 10 of the arguement.
- log10(Number) - Method in class org.apache.cassandra.db.marshal.ShortType
- log10(BigDecimal) - Method in class org.apache.cassandra.db.marshal.DecimalType
- log10Fct(NumberType<?>) - Static method in class org.apache.cassandra.cql3.functions.MathFcts
- LOG4J_SHUTDOWN_HOOK_ENABLED - org.apache.cassandra.config.CassandraRelevantProperties
- LOG4J2_DISABLE_JMX - org.apache.cassandra.config.CassandraRelevantProperties
- LOG4J2_DISABLE_JMX_LEGACY - org.apache.cassandra.config.CassandraRelevantProperties
- logAll - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
- LOGBACK_CONFIGURATION_FILE - org.apache.cassandra.config.CassandraRelevantProperties
- 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
- logBlockingReadRepairAttemptsForNSeconds(int) - Method in class org.apache.cassandra.service.StorageProxy
- logBlockingReadRepairAttemptsForNSeconds(int) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- logFct(NumberType<?>) - Static method in class org.apache.cassandra.cql3.functions.MathFcts
- loggableTokens() - Method in class org.apache.cassandra.db.PartitionRangeReadCommand
- loggableTokens() - Method in class org.apache.cassandra.db.ReadCommand
-
Return the queried token(s) for logging
- loggableTokens() - Method in class org.apache.cassandra.db.SinglePartitionReadCommand
- Logged(long, float, MemtableCleaner) - Constructor for class org.apache.cassandra.utils.memory.HeapPool.Logged
- LOGGED - org.apache.cassandra.cql3.statements.BatchStatement.Type
- logger - Variable in class org.apache.cassandra.audit.AuditLogOptions
- logger - Static variable in class org.apache.cassandra.audit.FileAuditLogger
- 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.unified.Controller
- logger - Static variable in class org.apache.cassandra.db.compaction.unified.ShardedCompactionWriter
- logger - Static variable in class org.apache.cassandra.db.compaction.unified.ShardedMultiWriter
- 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.guardrails.Guardrail
- 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 - Variable in class org.apache.cassandra.db.virtual.LogMessagesTable.LogMessage
- 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.index.sai.disk.v1.SSTableComponentsWriter
- logger - Static variable in class org.apache.cassandra.index.sai.StorageAttachedIndexBuilder
- logger - Static variable in class org.apache.cassandra.repair.AbstractRepairTask
- logger - Static variable in class org.apache.cassandra.security.AbstractCryptoProvider
- 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.repair.AbstractReadRepair
- 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
- LOGGER - Static variable in class org.apache.cassandra.audit.AuditLogOptionsCompositeData.AuditLogOption
- LOGGER_COLUMN_NAME - Static variable in class org.apache.cassandra.db.virtual.LogMessagesTable
- 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.
- logicalBytesOnDisk() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- 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.
- LOGIN - org.apache.cassandra.auth.IRoleManager.Option
- LOGIN_ERROR - org.apache.cassandra.audit.AuditLogEntryType
- LOGIN_SUCCESS - org.apache.cassandra.audit.AuditLogEntryType
- logInitializationOutcome(Logger) - Static method in class org.apache.cassandra.utils.Clock.Global
- logJmxServiceUrl(InetAddress, int) - Static method in class org.apache.cassandra.utils.JMXServerUtils
- logMessage(String) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- logMessage(String) - Method in class org.apache.cassandra.index.sai.utils.IndexIdentifier
-
A helper method for constructing consistent log messages for specific column indexes.
- LogMessage(long, String, String, String) - Constructor for class org.apache.cassandra.db.virtual.LogMessagesTable.LogMessage
- LogMessage(LoggingEvent) - Constructor for class org.apache.cassandra.db.virtual.LogMessagesTable.LogMessage
- LogMessagesTable - Class in org.apache.cassandra.db.virtual
-
Virtual table for holding Cassandra logs.
- LogMessagesTable.LogMessage - Class in org.apache.cassandra.db.virtual
- 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(TimeUUID) - 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
- logRequestException(Exception, Collection<? extends ReadCommand>) - Static method in class org.apache.cassandra.service.StorageProxy
- 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.
- LOGS_VIRTUAL_TABLE_DEFAULT_ROWS - Static variable in class org.apache.cassandra.db.virtual.LogMessagesTable
- LOGS_VIRTUAL_TABLE_MAX_ROWS - org.apache.cassandra.config.CassandraRelevantProperties
-
Maximum number of rows in system_views.logs table
- LOGS_VIRTUAL_TABLE_MAX_ROWS - Static variable in class org.apache.cassandra.db.virtual.LogMessagesTable
- LOGS_VIRTUAL_TABLE_MIN_ROWS - Static variable in class org.apache.cassandra.db.virtual.LogMessagesTable
- logStackTrace - Variable in exception org.apache.cassandra.exceptions.ConfigurationException
- logSystemInfo(Logger) - Static method in class org.apache.cassandra.service.CassandraDaemon
- LONG - org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.TermSize
- LONG_BYTES_DATASTORAGE_MEBIBYTES_DATASTORAGE - org.apache.cassandra.config.Converters
- LONG_BYTES_DATASTORAGE_MEBIBYTES_INT - org.apache.cassandra.config.Converters
- LONG_SIZE - Static variable in class org.apache.cassandra.db.TypeSizes
- LongAccumulator<T> - Interface in org.apache.cassandra.utils
- LongArray - Interface in org.apache.cassandra.index.sai.disk.v1
-
Abstraction over a long-indexed array of longs.
- LongArray.DeferredLongArray - Class in org.apache.cassandra.index.sai.disk.v1
- LongArray.Factory - Interface in org.apache.cassandra.index.sai.disk.v1
- LongBytesBound(long) - Constructor for class org.apache.cassandra.config.DataStorageSpec.LongBytesBound
-
Creates a
DataStorageSpec.LongBytesBound
of the specified amount in bytes. - LongBytesBound(long, DataStorageSpec.DataStorageUnit) - Constructor for class org.apache.cassandra.config.DataStorageSpec.LongBytesBound
-
Creates a
DataStorageSpec.LongBytesBound
of the specified amount in the specified unit. - LongBytesBound(String) - Constructor for class org.apache.cassandra.config.DataStorageSpec.LongBytesBound
-
Creates a
DataStorageSpec.LongBytesBound
of the specified amount. - LongBytesPerSecondBound(long) - Constructor for class org.apache.cassandra.config.DataRateSpec.LongBytesPerSecondBound
-
Creates a
DataRateSpec.LongBytesPerSecondBound
of the specified amount in bytes per second. - LongBytesPerSecondBound(long, DataRateSpec.DataRateUnit) - Constructor for class org.apache.cassandra.config.DataRateSpec.LongBytesPerSecondBound
-
Creates a
DataRateSpec.LongBytesPerSecondBound
of the specified amount in the specified unit. - LongBytesPerSecondBound(String) - Constructor for class org.apache.cassandra.config.DataRateSpec.LongBytesPerSecondBound
-
Creates a
DataRateSpec.LongBytesPerSecondBound
of the specified amount. - LongMebibytesBound(long) - Constructor for class org.apache.cassandra.config.DataStorageSpec.LongMebibytesBound
-
Creates a
DataStorageSpec.LongMebibytesBound
of the specified amount in mebibytes. - LongMebibytesBound(long, DataStorageSpec.DataStorageUnit) - Constructor for class org.apache.cassandra.config.DataStorageSpec.LongMebibytesBound
-
Creates a
DataStorageSpec.LongMebibytesBound
of the specified amount in the specified unit. - LongMebibytesBound(String) - Constructor for class org.apache.cassandra.config.DataStorageSpec.LongMebibytesBound
-
Creates a
DataStorageSpec.LongMebibytesBound
of the specified amount. - LongMicrosecondsBound(long) - Constructor for class org.apache.cassandra.config.DurationSpec.LongMicrosecondsBound
-
Creates a
DurationSpec.LongMicrosecondsBound
of the specified amount in microseconds. - LongMicrosecondsBound(long, TimeUnit) - Constructor for class org.apache.cassandra.config.DurationSpec.LongMicrosecondsBound
-
Creates a
DurationSpec.LongMicrosecondsBound
of the specified amount in the specified unit. - LongMicrosecondsBound(String) - Constructor for class org.apache.cassandra.config.DurationSpec.LongMicrosecondsBound
-
Creates a
DurationSpec.LongMicrosecondsBound
of the specified amount. - LongMillisecondsBound(long) - Constructor for class org.apache.cassandra.config.DurationSpec.LongMillisecondsBound
-
Creates a
DurationSpec.LongMillisecondsBound
of the specified amount in milliseconds. - LongMillisecondsBound(long, TimeUnit) - Constructor for class org.apache.cassandra.config.DurationSpec.LongMillisecondsBound
-
Creates a
DurationSpec.LongMillisecondsBound
of the specified amount in the specified unit. - LongMillisecondsBound(String) - Constructor for class org.apache.cassandra.config.DurationSpec.LongMillisecondsBound
-
Creates a
DurationSpec.LongMillisecondsBound
of the specified amount. - LongNanosecondsBound(long) - Constructor for class org.apache.cassandra.config.DurationSpec.LongNanosecondsBound
-
Creates a
DurationSpec.LongNanosecondsBound
of the specified amount in nanoseconds. - LongNanosecondsBound(long, TimeUnit) - Constructor for class org.apache.cassandra.config.DurationSpec.LongNanosecondsBound
-
Creates a
DurationSpec.LongNanosecondsBound
of the specified amount in the specified unit. - LongNanosecondsBound(String) - Constructor for class org.apache.cassandra.config.DurationSpec.LongNanosecondsBound
-
Creates a
DurationSpec.LongNanosecondsBound
of the specified amount. - LongSecondsBound(long) - Constructor for class org.apache.cassandra.config.DurationSpec.LongSecondsBound
-
Creates a
DurationSpec.LongSecondsBound
of the specified amount in seconds. - LongSecondsBound(long, TimeUnit) - Constructor for class org.apache.cassandra.config.DurationSpec.LongSecondsBound
-
Creates a
DurationSpec.LongSecondsBound
of the specified amount in the specified unit. - LongSecondsBound(String) - Constructor for class org.apache.cassandra.config.DurationSpec.LongSecondsBound
-
Creates a
DurationSpec.LongSecondsBound
of the specified amount. - 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(String) - Method in class org.apache.cassandra.utils.JMXServerUtils.JmxRegistry
- lookup(InetAddressAndPort) - Method in class org.apache.cassandra.locator.EndpointsForToken
- lookup(InetAddressAndPort) - Method in class org.apache.cassandra.locator.ReplicaPlan.AbstractForRead
- lookup(InetAddressAndPort) - Method in class org.apache.cassandra.locator.ReplicaPlan.ForWrite
- lookup(InetAddressAndPort) - Method in interface org.apache.cassandra.locator.ReplicaPlan
- LOOKUP - org.apache.cassandra.index.sasi.utils.RangeIntersectionIterator.Strategy
- LOOKUP_CIDR_GROUPS_FOR_IP_LATENCY - Static variable in class org.apache.cassandra.metrics.CIDRAuthorizerMetrics
- LOOKUP_CIDR_GROUPS_FOR_IP_LATENCY_NAME - Static variable in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsLatenciesTable
- lookupById(int) - Static method in enum org.apache.cassandra.streaming.messages.StreamMessage.Type
- lookupCidrGroupsCacheForIp(InetAddress) - Method in class org.apache.cassandra.auth.CIDRGroupsMappingLoader
- lookupCidrGroupsForIp(InetAddress) - Method in class org.apache.cassandra.auth.AllowAllCIDRAuthorizer
- lookupCidrGroupsForIp(InetAddress) - Method in class org.apache.cassandra.auth.CassandraCIDRAuthorizer
- lookupCidrGroupsForIp(InetAddress) - Method in class org.apache.cassandra.auth.CIDRGroupsMappingCache
-
Lookup best matching CIDR group for the given IP
- lookupCidrGroupsForIp(InetAddress) - Method in interface org.apache.cassandra.auth.ICIDRAuthorizer
-
Lookup IP in CIDR groups mapping cache
- lookupCidrGroupsForIpLatency - Variable in class org.apache.cassandra.metrics.CIDRAuthorizerMetrics
- lookupLongestMatchForIP(InetAddress) - Method in class org.apache.cassandra.auth.CIDRGroupsMappingIntervalTree
-
Get the longest matching CIDR (i.e, the narrowest match) for given IP
- lookupLongestMatchForIP(InetAddress) - Method in interface org.apache.cassandra.auth.CIDRGroupsMappingTable
-
Finds the longest matching CIDR for the given IP
- lookupPostingsOffset(ByteComparable) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.LiteralIndexSegmentTermsReader.TermQuery
- LOOSE_DEF_OF_EMPTY_ENABLED - org.apache.cassandra.config.CassandraRelevantProperties
-
Loosen the definition of "empty" for gossip state, for use during host replacements if things go awry
- LOW - org.apache.cassandra.utils.Nemesis.Traffic
- LOW_BUCKET_COUNT - Static variable in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
- lower - Variable in class org.apache.cassandra.index.sai.plan.Expression
- lower - Variable in class org.apache.cassandra.index.sasi.plan.Expression
- lower() - Method in class org.apache.cassandra.index.sai.plan.Expression
- lower() - Method in class org.apache.cassandra.utils.IntegerInterval
- 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 - org.apache.cassandra.utils.AsymmetricOrdering.Op
- lowerBound - Variable in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
- lowerBound() - Method in class org.apache.cassandra.db.commitlog.IntervalSet
- lowerBound() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
- 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() - Constructor for class org.apache.cassandra.index.sai.analyzer.filter.BasicFilters.LowerCase
- LowerCase() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.BasicResultFilters.LowerCase
- LowerCase(Locale) - 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
- lowerInclusive - Variable in class org.apache.cassandra.index.sai.plan.Expression
- 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
- lsb() - Method in class org.apache.cassandra.utils.TimeUUID
- LT - org.apache.cassandra.cql3.Operator
- LT_NEXT_COMPONENT - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- LTE - org.apache.cassandra.cql3.Operator
- LTLT_NEXT_COMPONENT - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- 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 - org.apache.cassandra.net.OutboundConnectionSettings.Framing
- 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
- MAC - org.apache.cassandra.utils.NativeLibrary.OSType
- 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.HashPassword
- 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.SSTablePartitions
-
Given arguments specifying a list of SSTables or directories, print information about SSTable partitions.
- 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
- major - Variable in enum org.apache.cassandra.utils.StorageCompatibilityMode
- MAJOR_COMPACTION - org.apache.cassandra.db.compaction.OperationType
- MAJOR_STATE_CHANGE_HANDLED - org.apache.cassandra.gms.GossiperEvent.GossiperEventType
- 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(Object...) - Method in class org.apache.cassandra.db.ClusteringComparator
-
Creates a row clustering based on the clustering values.
- make(ByteBuffer...) - Static method in class org.apache.cassandra.db.BufferClustering
- make(ByteBuffer...) - Static method in interface org.apache.cassandra.db.Clustering
- make(Clustering<?>) - Static method in class org.apache.cassandra.db.Slice
-
Makes a slice covering a single clustering
- make(Clustering<?>, Clustering<?>) - Static method in class org.apache.cassandra.db.Slice
-
Makes a slice covering a range from start to end clusterings, with both start and end included
- make(ClusteringBound<?>, ClusteringBound<?>) - Static method in class org.apache.cassandra.db.Slice
- make(ClusteringBoundOrBoundary<?>, ClusteringBoundOrBoundary<?>) - Static method in class org.apache.cassandra.db.Slice
-
Makes a slice for the given bounds
- make(ClusteringComparator, Object...) - Static method in class org.apache.cassandra.db.Slice
- make(TableMetadata, Collection<SSTableReader>) - Static method in class org.apache.cassandra.db.SerializationHeader
- 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
- makeBounds(SSTableReader, Collection<Range<Token>>) - Static method in class org.apache.cassandra.io.sstable.format.SSTableScanner
- makeBounds(SSTableReader, DataRange) - Static method in class org.apache.cassandra.io.sstable.format.SSTableScanner
- makeBucket(List<Set<E>>, int, int) - Method in interface org.apache.cassandra.utils.Overlaps.BucketMaker
- 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
- makeFullDataRequests(ReplicaCollection<?>) - Method in class org.apache.cassandra.service.reads.AbstractReadExecutor
- makeIndexClustering(ByteBuffer, Clustering<?>) - Method in class org.apache.cassandra.index.internal.CassandraIndexSearcher
- makeIndexNonQueryable() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
-
Removes this index from the
SecondaryIndexManager
's set of queryable indexes. - makeIndexNonQueryable(Index, Index.Status) - Method in class org.apache.cassandra.index.SecondaryIndexManager
- makeIndexQueryable(Index, Index.Status) - Method in class org.apache.cassandra.index.SecondaryIndexManager
- makeInternalOptions(CQLStatement, Object[]) - Static method in class org.apache.cassandra.cql3.QueryProcessor
- makeInternalOptionsWithNowInSec(CQLStatement, long, 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.
- makeMergedPartition(BTreePartitionData, PartitionUpdate) - Method in class org.apache.cassandra.db.partitions.BTreePartitionUpdater
- 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
- makePartialRoot() - Method in interface org.apache.cassandra.io.tries.IncrementalTrieWriter
-
Make a temporary in-memory representation of the unwritten nodes that covers everything added to the trie until this point.
- makePartialRoot() - Method in class org.apache.cassandra.io.tries.IncrementalTrieWriterBase
- makePartialRoot() - Method in class org.apache.cassandra.io.tries.IncrementalTrieWriterPageAware
- makePartialRoot() - Method in class org.apache.cassandra.io.tries.IncrementalTrieWriterSimple
- makePeekable(PostingList) - Static method in class org.apache.cassandra.index.sai.postings.PeekablePostingList
- makePerIndexComponent(IndexComponent, IndexIdentifier) - Method in class org.apache.cassandra.index.sai.disk.format.Version
- makePerSSTableComponent(IndexComponent) - Method in class org.apache.cassandra.index.sai.disk.format.Version
- 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, SSTableReader, DecoratedKey, ClusteringIndexFilter, ColumnFilter, SSTableReadsListener) - Method in interface org.apache.cassandra.db.StorageHook
- makeRowRange(Range<Token>) - Static method in class org.apache.cassandra.dht.Range
- makeRowRange(Token, Token) - Static method in class org.apache.cassandra.dht.Range
-
Compute a range of keys corresponding to a given range of token.
- makeSlices(QueryOptions) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
- makeTransientDataRequests(Iterable<Replica>) - Method in class org.apache.cassandra.service.reads.AbstractReadExecutor
- makeUnflushable() - Method in class org.apache.cassandra.db.memtable.SkipListMemtable
-
For testing only.
- makeUpdates(FilteredPartition, ClientState, Ballot) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
- makeUpdates(FilteredPartition, ClientState, Ballot) - 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 - Variable in class org.apache.cassandra.cql3.Maps.Value
- map(FileChannel.MapMode, long, long) - Method in class org.apache.cassandra.io.util.ChannelProxy
- map(Function<? super V, ? extends T>) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
-
Support
Futures.transformAsync(ListenableFuture, AsyncFunction, Executor)
natively SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics. - map(Function<? super V, ? extends T>) - Method in interface org.apache.cassandra.utils.concurrent.Future
-
Support
Futures.transform(ListenableFuture, com.google.common.base.Function, Executor)
natively - map(Function<? super V, ? extends T>, Executor) - Method in class org.apache.cassandra.utils.concurrent.AsyncFuture
-
Support
Futures.transform(com.google.common.util.concurrent.ListenableFuture<I>, com.google.common.base.Function<? super I, ? extends O>, java.util.concurrent.Executor)
natively SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics. - map(Function<? super V, ? extends T>, Executor) - Method in interface org.apache.cassandra.utils.concurrent.Future
-
Support
Futures.transform(ListenableFuture, com.google.common.base.Function, Executor)
natively - map(Function<? super V, ? extends T>, Executor) - Method in class org.apache.cassandra.utils.concurrent.SyncFuture
-
Support
Futures.transform(com.google.common.util.concurrent.ListenableFuture<I>, com.google.common.base.Function<? super I, ? extends O>, java.util.concurrent.Executor)
natively SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics. - map(CQL3Type.Raw, CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
- map(DataType, DataType) - Static method in class org.apache.cassandra.cql3.functions.types.DataType
-
Returns the type of "not frozen" maps of
keyType
tovalueType
elements. - map(DataType, DataType, boolean) - Static method in class org.apache.cassandra.cql3.functions.types.DataType
-
Returns the type of maps of
keyType
tovalueType
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(SSTableReader) - Method in class org.apache.cassandra.io.sstable.AbstractMetricsProviders
- map(SSTableReader) - Method in class org.apache.cassandra.io.sstable.filter.BloomFilterMetrics
- map(SSTableReader) - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryMetrics
- map(SSTableReader) - Method in class org.apache.cassandra.io.sstable.keycache.KeyCacheMetrics
- map(ChannelProxy, long) - Static method in class org.apache.cassandra.io.util.MmappedRegions
- map(ChannelProxy, CompressionMetadata) - Static method in class org.apache.cassandra.io.util.MmappedRegions
- map(AbstractFuture<T>, Function<? super V, ? extends T>, Executor) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
-
Support
Futures.transform(ListenableFuture, com.google.common.base.Function, Executor)
natively SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics. - MAP - org.apache.cassandra.cql3.functions.types.DataType.Name
- MAP - org.apache.cassandra.db.marshal.CollectionType.Kind
- MAP - org.apache.cassandra.transport.DataType
- MAP_EQUALITY - org.apache.cassandra.db.filter.RowFilter.Expression.Kind
- MAP_SELECTOR - org.apache.cassandra.cql3.selection.Selector.Kind
- mapContent(T, byte[], int) - Method in class org.apache.cassandra.db.tries.TrieEntriesIterator
- mapOf(TypeToken<K>, TypeToken<V>) - Static method in class org.apache.cassandra.cql3.functions.types.TypeTokens
-
Create a
TypeToken
that represents aMap
whose keys and values are of the given key and value types. - mapOf(Class<K>, Class<V>) - Static method in class org.apache.cassandra.cql3.functions.types.TypeTokens
-
Create a
TypeToken
that represents aMap
whose keys and values are of the given key and value types. - MappedBuffer - Class in org.apache.cassandra.index.sasi.utils
- 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
- MappedBuffer(RandomAccessReader) - Constructor for class org.apache.cassandra.index.sasi.utils.MappedBuffer
- 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.IndexWriter
- mark() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter.IndexWriter
- mark() - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter.AbstractIndexWriter
- mark() - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter
- mark() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
- mark() - Method in class org.apache.cassandra.io.util.FileSegmentInputStream
- 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.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() - Method in class org.apache.cassandra.metrics.TableMetrics.TableMeter
- mark() - Method in class org.apache.cassandra.transport.QueueBackpressure.Incident
- mark(int) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
- mark(long) - Method in class org.apache.cassandra.metrics.RestorableMeter
-
Mark the occurrence of a given number of events.
- mark(long) - Method in class org.apache.cassandra.transport.QueueBackpressure.Incident
- markAbort(Throwable) - Method in class org.apache.cassandra.metrics.ClientRequestMetrics
- markAlive() - Method in class org.apache.cassandra.gms.EndpointState
- markAllIndexesRemoved() - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Called when dropping a Table
- markAndGetDelay(TimeUnit) - Method in interface org.apache.cassandra.transport.QueueBackpressure
- markAndThrow(Throwable) - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- markAndThrow(Throwable, boolean) - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- markAsShutdown(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
-
Deprecated.see CASSANDRA-18913
- markAsShutdown(InetAddressAndPort, EndpointState) - 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.indexsummary.IndexSummaryBuilder
- markDead() - Method in class org.apache.cassandra.gms.EndpointState
- markDead(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
- MARKED_ALIVE - org.apache.cassandra.gms.GossiperEvent.GossiperEventType
- MARKED_AS_SHUTDOWN - org.apache.cassandra.gms.GossiperEvent.GossiperEventType
- MARKED_DEAD - org.apache.cassandra.gms.GossiperEvent.GossiperEventType
- 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 - Variable in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithMarker
- marker - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithMarker
- Marker(int) - Constructor for class org.apache.cassandra.cql3.Json.Marker
- Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Constants.Marker
- Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Lists.Marker
- Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Maps.Marker
- Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Sets.Marker
- Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.Tuples.Marker
- Marker(int, ColumnSpecification) - Constructor for class org.apache.cassandra.cql3.UserTypes.Marker
- markExtraOffHeapUsed(long, OpOrder.Group) - Method in class org.apache.cassandra.db.memtable.AbstractAllocatorMemtable
- markExtraOffHeapUsed(long, OpOrder.Group) - Method in interface org.apache.cassandra.db.memtable.Memtable
-
Adjust the used off-heap space by the given size (e.g.
- markExtraOnHeapUsed(long, OpOrder.Group) - Method in class org.apache.cassandra.db.memtable.AbstractAllocatorMemtable
- markExtraOnHeapUsed(long, OpOrder.Group) - Method in interface org.apache.cassandra.db.memtable.Memtable
-
Adjust the used on-heap space by the given size (e.g.
- markFlushing(Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
- markIndexesBuilding(Set<Index>, boolean, boolean) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Marks the specified indexes as (re)building if: 1) There's no in progress rebuild of any of the given indexes.
- markIndexSynced(long) - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryBuilder
- markLocalToBeCleared(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Mark context to delete local references afterward.
- markObsolete() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
- 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.
- markObsolete(Collection<SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- markProtocolException() - Method in class org.apache.cassandra.metrics.ClientMetrics
- markRequestDiscarded() - Method in class org.apache.cassandra.metrics.ClientMetrics
- markRequestDispatched() - 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
- markSuspect() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- markTimedOutBeforeProcessing() - Method in class org.apache.cassandra.metrics.ClientMetrics
- 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
- mask(String, int, int, char) - Method in enum org.apache.cassandra.cql3.functions.masking.PartialMaskingFunction.Kind
- mask(ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.masking.ColumnMask.Masker
- mask(ColumnIdentifier, ColumnMask.Raw) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
- masker(ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.masking.ColumnMask
- MaskingFcts - Class in org.apache.cassandra.cql3.functions.masking
-
A collection of
MaskingFunction
s for dynamic data masking, meant to obscure the real value of a column. - MaskingFcts() - Constructor for class org.apache.cassandra.cql3.functions.masking.MaskingFcts
- MaskingFunction - Class in org.apache.cassandra.cql3.functions.masking
-
A
NativeScalarFunction
that totally or partially replaces the original value of a column value, meant to obscure the real value of the column. - MaskingFunction(FunctionName, AbstractType<?>, AbstractType<?>, AbstractType<?>...) - Constructor for class org.apache.cassandra.cql3.functions.masking.MaskingFunction
- MaskingFunction.Factory - Class in org.apache.cassandra.cql3.functions.masking
- match(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.conf.view.View
- match(Expression) - Method in class org.apache.cassandra.index.sai.view.View
-
Search for a list of
SSTableIndex
es that contain values within the value range requested in theExpression
- match(Expression) - Method in class org.apache.cassandra.index.sasi.conf.view.View
- MATCH - org.apache.cassandra.index.sasi.plan.Expression.Op
- matchesEndpoints(Set<InetAddressAndPort>, Set<InetAddressAndPort>) - Method in class org.apache.cassandra.repair.CommonRange
- matchesViewFilter(DecoratedKey, Row, long) - 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).
- MATERIALIZED_VIEW - org.apache.cassandra.cql3.SchemaElement.SchemaElementType
- materialized_views_enabled - Variable in class org.apache.cassandra.config.Config
- MATERIALIZED_VIEWS_NOT_SUPPORTED - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- materialized_views_per_table_fail_threshold - Variable in class org.apache.cassandra.config.Config
- materialized_views_per_table_warn_threshold - Variable in class org.apache.cassandra.config.Config
- materializedViewsPerTable - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the number of materialized views per table.
- MathFcts - Class in org.apache.cassandra.cql3.functions
- max - Variable in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator.Builder.Statistics
- max - Variable in class org.apache.cassandra.index.sai.view.RangeTermTree
- 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 - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
- max - Variable in class org.apache.cassandra.tools.Util.TermHistogram
- max - Variable in class org.apache.cassandra.utils.Interval
- max() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
- 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() - Method in class org.apache.cassandra.utils.EstimatedHistogram
- max() - Method in class org.apache.cassandra.utils.IntervalTree
- max(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Returns the greater of two
ByteBuffer
values, based on the result ofIndexTermType.compare(ByteBuffer, ByteBuffer)
comparision. - max(T, T) - Static method in class org.apache.cassandra.utils.Comparables
-
Returns the maximum of 2 comparable values.
- max(T, T, Comparator<C>) - Static method in class org.apache.cassandra.utils.Comparables
-
Returns the maximum of 2 values given a comparator of those values.
- MAX - org.apache.cassandra.service.reads.HybridSpeculativeRetryPolicy.Function
- max_archive_retries - Variable in class org.apache.cassandra.utils.binlog.BinLogOptions
-
Limit the number of times to retry a command.
- MAX_ARCHIVE_RETRIES - Static variable in class org.apache.cassandra.audit.AuditLogOptionsCompositeData.AuditLogOption
- MAX_BOUND - org.apache.cassandra.db.PartitionPosition.Kind
- 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_COL - Static variable in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsLatenciesTable
- max_concurrent_automatic_sstable_upgrades - Variable in class org.apache.cassandra.config.Config
- MAX_CONCURRENT_RANGE_REQUESTS - org.apache.cassandra.config.CassandraRelevantProperties
- MAX_CONNECT_ATTEMPTS - Static variable in class org.apache.cassandra.streaming.async.NettyStreamingConnectionFactory
- MAX_DELETION_TIME - Static variable in class org.apache.cassandra.db.rows.Cell
- MAX_DELETION_TIME_2038_LEGACY_CAP - Static variable in class org.apache.cassandra.db.rows.Cell
- MAX_DELETION_TIME_UNSIGNED_INTEGER - Static variable in class org.apache.cassandra.db.rows.Cell
- MAX_FLOAT32_COMPONENT - Static variable in class org.apache.cassandra.index.sai.disk.v1.vector.OnHeapGraph
- MAX_HINT_BUFFERS - org.apache.cassandra.config.CassandraRelevantProperties
- max_hint_window - Variable in class org.apache.cassandra.config.Config
- max_hints_delivery_threads - Variable in class org.apache.cassandra.config.Config
- max_hints_file_size - Variable in class org.apache.cassandra.config.Config
- max_hints_size_per_host - Variable in class org.apache.cassandra.config.Config
- MAX_INDEX_INTERVAL - org.apache.cassandra.schema.TableParams.Option
- MAX_JOB_THREADS - Static variable in class org.apache.cassandra.repair.messages.RepairOption
- MAX_KEYS - Static variable in class org.apache.cassandra.utils.btree.BTree
- MAX_LOCAL_PAUSE_IN_MS - org.apache.cassandra.config.CassandraRelevantProperties
- 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_LOG_SIZE - Static variable in class org.apache.cassandra.audit.AuditLogOptionsCompositeData.AuditLogOption
- max_mutation_size - Variable in class org.apache.cassandra.config.Config
- MAX_MUTATION_SIZE - Static variable in interface org.apache.cassandra.db.IMutation
- MAX_NEXT_COMPONENT - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- 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_OUTSTANDING_VERSION_REQUESTS - Static variable in class org.apache.cassandra.schema.MigrationCoordinator
- MAX_POINTS_IN_LEAF_NODE - Static variable in class org.apache.cassandra.index.sai.disk.v1.bbtree.NumericIndexWriter
- 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_QUEUE_WEIGHT - Static variable in class org.apache.cassandra.audit.AuditLogOptionsCompositeData.AuditLogOption
- MAX_RECURSIVE_KEY_LENGTH - Static variable in class org.apache.cassandra.db.memtable.TrieMemtable
-
If keys is below this length, we will use a recursive procedure for inserting data in the memtable trie.
- 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_SEPARATOR - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- 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_space_usable_for_compactions_in_percentage - Variable in class org.apache.cassandra.config.Config
- MAX_SSTABLE_ROW_ID - Static variable in class org.apache.cassandra.index.sai.virtual.SegmentsSystemView
- MAX_START - Static variable in interface org.apache.cassandra.db.ClusteringBound
-
The biggest start bound, i.e.
- max_streaming_retries - Variable in class org.apache.cassandra.config.Config
-
Deprecated.See CASSANDRA-17378
- MAX_TASKS_QUEUED - Static variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
- MAX_TERM - Static variable in class org.apache.cassandra.index.sai.virtual.SegmentsSystemView
- MAX_TERM_SIZE - Static variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
- MAX_THRESHOLD - org.apache.cassandra.schema.CompactionParams.Option
- MAX_TOP_K - Static variable in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- max_top_size_partition_count - Variable in class org.apache.cassandra.config.Config
- max_top_tombstone_partition_count - Variable in class org.apache.cassandra.config.Config
- 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_LONG - Static variable in class org.apache.cassandra.utils.CassandraUInt
-
Returns the long representation of the maximum value we can hold
- max_value_size - Variable in class org.apache.cassandra.config.Config
-
Max size of values in SSTables, in MebiBytes.
- MAX_VALUE_UINT - Static variable in class org.apache.cassandra.utils.CassandraUInt
-
Returns the UInt representation of the maximum value we can hold
- MAX_WRITE_TIME - org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL.Kind
- maxAge - Variable in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
- maxArchiveRetries(int) - Method in class org.apache.cassandra.utils.binlog.BinLog.Builder
- MaxAttempt(int) - Constructor for class org.apache.cassandra.config.RetrySpec.MaxAttempt
- maxAttempts - Variable in class org.apache.cassandra.config.RetrySpec
-
Represents how many retry attempts are allowed.
- maxAttempts() - Method in class org.apache.cassandra.utils.Backoff.ExponentialBackoff
- maxAttempts() - Method in interface org.apache.cassandra.utils.Backoff
- maxAttempts() - Method in enum org.apache.cassandra.utils.Backoff.None
- maxAtUnixMillis(long) - Static method in class org.apache.cassandra.utils.TimeUUID
-
Returns the biggest possible type 1 UUID having the provided timestamp.
- 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, int, long) - Static method in class org.apache.cassandra.db.compaction.LeveledManifest
- maxBytesForLevel(int, long) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
- maxBytesInPage() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
- maxBytesInPage() - Method in interface org.apache.cassandra.io.util.DataOutputPlus
-
Returns the number of bytes that a page can take at maximum.
- maxBytesInPage() - Method in class org.apache.cassandra.io.util.SequentialWriter
- 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
- maxConcurrentCompactions() - Method in class org.apache.cassandra.db.compaction.unified.Controller
- maxDataAge - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
-
maxDataAge is a timestamp in local server time (e.g.
- maxDataAge - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
- maxDelayNanos() - Method in class org.apache.cassandra.transport.QueueBackpressure.Incident
- maxFunctionForCounter - Static variable in class org.apache.cassandra.cql3.functions.AggregateFcts
-
MAX function for counter column values.
- maximum() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.MergePostingList
- maximum() - Method in class org.apache.cassandra.index.sai.postings.PeekablePostingList
- maximum() - Method in interface org.apache.cassandra.index.sai.postings.PostingList
- MAXIMUM - Static variable in class org.apache.cassandra.dht.Murmur3Partitioner
- MAXIMUM - Static variable in class org.apache.cassandra.dht.RandomPartitioner
- MAXIMUM_CONSTRUCTION_BEAM_WIDTH - Static variable in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- 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_MAXIMUM_NODE_CONNECTIONS - Static variable in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- MAXIMUM_NODE_CONNECTIONS - Static variable in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- maximum_replication_factor_fail_threshold - Variable in class org.apache.cassandra.config.Config
- maximum_replication_factor_warn_threshold - Variable in class org.apache.cassandra.config.Config
- MAXIMUM_SEGMENT_BUFFER_MB - Static variable in class org.apache.cassandra.config.StorageAttachedIndexOptions
- MAXIMUM_SIZE - Static variable in class org.apache.cassandra.locator.InetAddressAndPort.Serializer
- maximum_timestamp_fail_threshold - Variable in class org.apache.cassandra.config.Config
- maximum_timestamp_warn_threshold - Variable in class org.apache.cassandra.config.Config
-
The configuration of timestamp bounds
- MAXIMUM_TOKEN_SIZE - Static variable in class org.apache.cassandra.dht.RandomPartitioner
- maximum_version - Static variable in class org.apache.cassandra.net.MessagingService
- maximumAllowableTimestamp - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
- maximumKey - Variable in class org.apache.cassandra.index.sai.disk.v1.segment.IndexSegmentSearcherContext
- maximumLiveCellsPerSliceLastFiveMinutes - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- maximumPoolSize - Variable in class org.apache.cassandra.service.StorageServiceMBean.StageConcurrency
- maximumReplicationFactor - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the maximum replication factor.
- maximumTombstonesPerSliceLastFiveMinutes - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- maxIndexInterval - Variable in class org.apache.cassandra.schema.TableParams
- maxIndexInterval(int) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- maxIndexInterval(int) - Method in class org.apache.cassandra.schema.TableParams.Builder
- maxKey - Variable in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata
- 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
- maxKeyLength - Variable in class org.apache.cassandra.index.sai.disk.v1.keystore.KeyLookupMeta
- maxLeft(AbstractBounds.Boundary<T>, AbstractBounds.Boundary<T>) - Static method in class org.apache.cassandra.dht.AbstractBounds
- maxLeft(AbstractBounds.Boundary<T>, T, boolean) - 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
- maxLowBound() - Method in class org.apache.cassandra.service.paxos.PaxosRepairHistory
- 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
- maxPositionDelta(long) - Method in interface org.apache.cassandra.io.tries.SerializationNode
-
Returns the furthest distance that needs to be written to store this node, i.e.
- 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
-
Note:
Sampler.samplerExecutor
is single threaded but we still need to synchronize as we have access from both internal and the external JMX context that can cause races. - 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
- maxSleepTime - Variable in class org.apache.cassandra.config.RetrySpec
- maxSSTableBytes - Variable in class org.apache.cassandra.db.compaction.LeveledManifest.CompactionCandidate
- maxSSTableDuration - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Maximum duration of an SSTable for this table, computed as maxTimestamp - minTimestamp
- maxSSTableRowId - Variable in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata
- maxSSTableRowId() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
-
Returns the maximum indexed rowId for the index.
- maxSSTableRowId() - Method in class org.apache.cassandra.index.sai.disk.v1.V1SSTableIndex
- maxSSTableSize - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Maximum size of SSTable of this table - the physical size on disk of all components for such SSTable in bytes
- maxSSTableSize - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- 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
- maxSSTablesToCompact - Variable in class org.apache.cassandra.db.compaction.unified.Controller
- maxSSTablesToCompact() - Method in class org.apache.cassandra.db.compaction.unified.Controller
- 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.sai.disk.v1.segment.SegmentMetadata
- maxTerm - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
- maxTerm() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
-
Returns the maximum term held in the index based on the natural sort order of the index column type comparator.
- maxTerm() - Method in class org.apache.cassandra.index.sai.disk.v1.V1SSTableIndex
- 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
- MaxThreshold - Class in org.apache.cassandra.db.guardrails
-
MaxThreshold
for maximum guardrails, the value is checked to see if it is greater than the warn and fail thresholds. - MaxThreshold(String, String, ToLongFunction<ClientState>, ToLongFunction<ClientState>, Threshold.ErrorMessageProvider) - Constructor for class org.apache.cassandra.db.guardrails.MaxThreshold
-
Creates a new threshold guardrail.
- maxThroughput() - Method in class org.apache.cassandra.db.compaction.unified.Controller
- maxTimestamp - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
- 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
- maxTimestampAscending - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
- maxTimestampDescending - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
- 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
- maxValue - Variable in exception org.apache.cassandra.exceptions.QueryReferencesTooManyIndexesAbortException
- maxValue - Variable in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Counter
- maybeAbort(ReadCommand, ConsistencyLevel, int, int, boolean, Map<InetAddressAndPort, RequestFailureReason>) - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- 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.indexsummary.IndexSummaryBuilder
- maybeAddEntry(DecoratedKey, long, long, long) - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryBuilder
- maybeAddKeyspaceInstance(String, Supplier<Keyspace>) - Method in class org.apache.cassandra.schema.Schema
- maybeAddKeyspaceInstance(String, Supplier<Keyspace>) - Method in interface org.apache.cassandra.schema.SchemaProvider
- 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(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.
- maybeArchive(CommitLogSegment) - Method in class org.apache.cassandra.db.commitlog.CommitLogArchiver
- 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
- maybeCreateHeapDump() - Static method in class org.apache.cassandra.utils.HeapUtils
- maybeExecuteImmediately(Runnable) - Method in interface org.apache.cassandra.concurrent.ExecutorPlus
-
MAY execute
task
immediately, if the calling thread is permitted to do so. - maybeExecuteImmediately(Runnable) - Method in class org.apache.cassandra.concurrent.SEPExecutor
- maybeExecuteImmediately(Runnable) - Method in enum org.apache.cassandra.concurrent.Stage
- maybeExecuteImmediately(Runnable) - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- 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
- maybeFilebasedKey - Variable in class org.apache.cassandra.security.PEMBasedSslContextFactory.PEMBasedKeyStoreContext
- maybeFinishShadowRound(InetAddressAndPort, boolean, Map<InetAddressAndPort, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
- maybeGetChecksumValidator() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- maybeGetDigestValidator() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- 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
- 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.
- maybeLoad(Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.format.CompressionInfoComponent
- maybeLoadBloomFilter(Descriptor, Set<Component>, TableMetadata, ValidationMetadata) - Static method in class org.apache.cassandra.io.sstable.format.FilterComponent
-
Optionally loads a Bloom filter.
- maybeLoadManifest(String, String, String, Set<File>) - Static method in class org.apache.cassandra.db.Directories
- 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
- maybePersistSSTableReadMeter() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- maybeQuote(String) - Static method in class org.apache.cassandra.cql3.ColumnIdentifier
- maybeRebuild() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosStateTracker
- maybeRebuildUncommittedState() - Static method in class org.apache.cassandra.service.paxos.PaxosState
- 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
- 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.
- maybeReloadParamsFromSchema(CompactionParams) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
-
Maybe reload the compaction strategies.
- 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() - 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.
- 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.
- maybeSetRepairing(TimeUUID) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
- maybeSwitchLocation(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
Switches the file location and writer and returns true if the new key should be placed in a different data directory.
- maybeSwitchWriter(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
Switches the writer if necessary, i.e.
- 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
- maybeTryAdditionalReplicas(IMutation, StorageProxy.WritePerformer, String) - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
-
Cheap Quorum backup.
- maybeUpdateState(ParticipateState.Job.State) - Method in class org.apache.cassandra.repair.state.ParticipateState.Job
- maybeUpdateState(T) - Method in class org.apache.cassandra.repair.state.AbstractState
- 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
-
Deprecated.See CASSANDRA-17212
- maybeWarnOnOptions() - Method in class org.apache.cassandra.locator.LocalStrategy
- maybeWarnOnOptions(ClientState) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
- maybeWarnOnOptions(ClientState) - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
- maybeWarnOnOptions(ClientState) - 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
- mayContainAssumingKeyIsInRange(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
The method verifies whether the sstable may contain the provided key.
- mayContainAssumingKeyIsInRange(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderWithFilter
- mayContainDataBefore(CommitLogPosition) - Method in class org.apache.cassandra.db.memtable.AbstractMemtableWithCommitlog
- mayContainDataBefore(CommitLogPosition) - Method in interface org.apache.cassandra.db.memtable.Memtable
-
True if the memtable can contain any data that was written before the given commit log position
- 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() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- mbean() - Method in class org.apache.cassandra.repair.SharedContext.Global
- mbean() - Method in interface org.apache.cassandra.repair.SharedContext
- mbean(String) - Static method in class org.apache.cassandra.auth.JMXResource
- MBEAN_NAME - Static variable in class org.apache.cassandra.audit.AuditLogManager
- MBEAN_NAME - Static variable in class org.apache.cassandra.auth.CIDRGroupsMappingManager
- MBEAN_NAME - Static variable in class org.apache.cassandra.auth.CIDRPermissionsManager
- 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.db.guardrails.Guardrails
- MBEAN_NAME - Static variable in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable
- 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.indexsummary.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_NAME_BASE - Static variable in class org.apache.cassandra.auth.AuthCache
- MBEAN_OBJECT_NAME - Static variable in class org.apache.cassandra.db.compaction.CompactionManager
- MBEAN_REGISTRATION_CLASS - org.apache.cassandra.config.CassandraRelevantProperties
-
what class to use for mbean registeration
- 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.DelegatingMbeanWrapper - Class in org.apache.cassandra.utils
- MBeanWrapper.InstanceMBeanWrapper - Class in org.apache.cassandra.utils
- 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
- measureDeepOmitShared(Object) - Static method in class org.apache.cassandra.utils.ObjectSizes
- MEBIBYTES - org.apache.cassandra.config.DataStorageSpec.DataStorageUnit
- MEBIBYTES_DATA_STORAGE_INT - org.apache.cassandra.config.Converters
- MEBIBYTES_DATA_STORAGE_LONG - org.apache.cassandra.config.Converters
- MEBIBYTES_PER_SECOND - org.apache.cassandra.config.DataRateSpec.DataRateUnit
- MEBIBYTES_PER_SECOND_DATA_RATE - org.apache.cassandra.config.Converters
- MEGABITS_TO_BYTES_PER_SECOND_DATA_RATE - org.apache.cassandra.config.Converters
-
This converter is a custom one to support backward compatibility for stream_throughput_outbound and inter_dc_stream_throughput_outbound which were provided in megabits per second prior CASSANDRA-15234.
- megabitsPerSecondInBytesPerSecond(long) - Static method in class org.apache.cassandra.config.DataRateSpec.LongBytesPerSecondBound
-
Deprecated.See CASSANDRA-17225
- memberOf - Variable in class org.apache.cassandra.auth.Role
- members() - Method in annotation type org.apache.cassandra.utils.Shared
- 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.AbstractAllocatorMemtable
- MemoryIndex - Class in org.apache.cassandra.index.sai.memory
- MemoryIndex(StorageAttachedIndex) - Constructor for class org.apache.cassandra.index.sai.memory.MemoryIndex
- 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
- MemoryMappedSegment.MemoryMappedSegmentBuilder - Class in org.apache.cassandra.db.commitlog
- MemoryMappedSegmentBuilder(AbstractCommitLogSegmentManager) - Constructor for class org.apache.cassandra.db.commitlog.MemoryMappedSegment.MemoryMappedSegmentBuilder
- 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
- memoryUsage() - Method in class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeWalker
- MemoryUsage() - Constructor for class org.apache.cassandra.db.memtable.Memtable.MemoryUsage
- memoryUsageThreshold() - Method in class org.apache.cassandra.utils.memory.BufferPool
- memoryUsed() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentTrieBuffer
- 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 - Variable in class org.apache.cassandra.config.Config
- memtable - Variable in class org.apache.cassandra.notifications.MemtableDiscardedNotification
- memtable - Variable in class org.apache.cassandra.notifications.MemtableSwitchedNotification
- memtable - Variable in class org.apache.cassandra.schema.TableParams
- memtable() - Method in interface org.apache.cassandra.db.memtable.Memtable.FlushablePartitionSet
- 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(MemtableParams) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- memtable(MemtableParams) - Method in class org.apache.cassandra.schema.TableParams.Builder
- Memtable - Interface in org.apache.cassandra.db.memtable
-
Memtable interface.
- MEMTABLE - org.apache.cassandra.db.transform.RTBoundValidator.Stage
- MEMTABLE - org.apache.cassandra.schema.TableParams.Option
- memtable_allocation_type - Variable in class org.apache.cassandra.config.Config
- memtable_cleanup_threshold - Variable in class org.apache.cassandra.config.Config
- MEMTABLE_FLUSH_PERIOD_IN_MS - org.apache.cassandra.schema.TableParams.Option
- memtable_flush_writers - Variable in class org.apache.cassandra.config.Config
- memtable_heap_space - Variable in class org.apache.cassandra.config.Config
- MEMTABLE_LIMIT - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- memtable_offheap_space - Variable in class org.apache.cassandra.config.Config
- MEMTABLE_OVERHEAD_COMPUTE_STEPS - org.apache.cassandra.config.CassandraRelevantProperties
- MEMTABLE_OVERHEAD_SIZE - org.apache.cassandra.config.CassandraRelevantProperties
- MEMTABLE_PERIOD_EXPIRED - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- MEMTABLE_SHARD_COUNT - org.apache.cassandra.config.CassandraRelevantProperties
- MEMTABLE_TRIE_SIZE_LIMIT - org.apache.cassandra.config.CassandraRelevantProperties
- Memtable.Factory - Interface in org.apache.cassandra.db.memtable
-
Factory interface for constructing memtables, and querying write durability features.
- Memtable.FlushablePartitionSet<P extends Partition> - Interface in org.apache.cassandra.db.memtable
-
A collection of partitions for flushing plus some information required for writing an sstable.
- Memtable.LastCommitLogPosition - Class in org.apache.cassandra.db.memtable
-
Special commit log position marker used in the upper bound marker setting process (see
ColumnFamilyStore.setCommitLogUpperBound(java.util.concurrent.atomic.AtomicReference<org.apache.cassandra.db.commitlog.CommitLogPosition>)
andMemtable.accepts(org.apache.cassandra.utils.concurrent.OpOrder.Group, org.apache.cassandra.db.commitlog.CommitLogPosition)
) - Memtable.MemoryUsage - Class in org.apache.cassandra.db.memtable
- Memtable.Owner - Interface in org.apache.cassandra.db.memtable
-
Interface for providing signals back and requesting information from the owner, i.e.
- 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
- 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
- memtableFlushCellsPerSecond - Variable in class org.apache.cassandra.index.sai.metrics.IndexMetrics
- memtableFlushPeriod(int) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- memtableFlushPeriodInMs - Variable in class org.apache.cassandra.schema.TableParams
- memtableFlushPeriodInMs(int) - Method in class org.apache.cassandra.schema.TableParams.Builder
- MemtableIndex - Class in org.apache.cassandra.index.sai.memory
- MemtableIndex(StorageAttachedIndex) - Constructor for class org.apache.cassandra.index.sai.memory.MemtableIndex
- memtableIndexFlushCount - Variable in class org.apache.cassandra.index.sai.metrics.IndexMetrics
- memtableIndexFlushErrors - Variable in class org.apache.cassandra.index.sai.metrics.IndexMetrics
- memtableIndexManager() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- MemtableIndexManager - Class in org.apache.cassandra.index.sai.memory
- MemtableIndexManager(StorageAttachedIndex) - Constructor for class org.apache.cassandra.index.sai.memory.MemtableIndexManager
- memtableIndexWriteLatency - Variable in class org.apache.cassandra.index.sai.metrics.IndexMetrics
- MemtableIndexWriter - Class in org.apache.cassandra.index.sai.disk.v1
-
Column index writer that flushes indexed data directly from the corresponding Memtable index, without buffering index data in memory.
- MemtableIndexWriter(MemtableIndex, IndexDescriptor, IndexTermType, IndexIdentifier, IndexMetrics, RowMapping) - Constructor for class org.apache.cassandra.index.sai.disk.v1.MemtableIndexWriter
- 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.
- MemtableOptions() - Constructor for class org.apache.cassandra.config.Config.MemtableOptions
- MemtableOrdering - Interface in org.apache.cassandra.index.sai.memory
-
Analogue of
SegmentOrdering
, but for memtables. - MemtableParams - Class in org.apache.cassandra.schema
-
Memtable types and options are specified with these parameters.
- 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
- MemtableTermsIterator - Class in org.apache.cassandra.index.sai.memory
-
Iterator over a token range bounded segment of a Memtable index.
- MemtableTermsIterator(ByteBuffer, ByteBuffer, Iterator<Pair<ByteComparable, LongArrayList>>) - Constructor for class org.apache.cassandra.index.sai.memory.MemtableTermsIterator
- MemtableUnfilteredPartitionIterator(TableMetadata, Iterator<AtomicBTreePartition>, ColumnFilter, DataRange) - Constructor for class org.apache.cassandra.db.memtable.ShardedSkipListMemtable.MemtableUnfilteredPartitionIterator
- memtableWritesAreDurable() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- merge() - Method in class org.apache.cassandra.db.rows.RangeTombstoneMarker.Merger
- merge(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Return a context w/ an aggregated count for each counter id.
- merge(Collection<? extends Trie<T>>, Trie.CollectionMergeResolver<T>) - Static method in class org.apache.cassandra.db.tries.Trie
-
Constructs a view of the merge of multiple tries.
- merge(List<? extends UnfilteredPartitionIterator>, UnfilteredPartitionIterators.MergeListener) - Static method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators
- 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<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(List<PostingList>) - Static method in class org.apache.cassandra.index.sai.disk.v1.postings.MergePostingList
- 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(PriorityQueue<PeekablePostingList>) - Static method in class org.apache.cassandra.index.sai.disk.v1.postings.MergePostingList
- merge(PriorityQueue<PeekablePostingList>, Closeable) - Static method in class org.apache.cassandra.index.sai.disk.v1.postings.MergePostingList
- merge(DeletionTime) - Method in class org.apache.cassandra.db.rows.Row.Merger
- merge(BTreeRow, BTreeRow, ColumnData.PostReconciliationFunction) - Static method in class org.apache.cassandra.db.rows.BTreeRow
- merge(Cell<?>, Cell<?>) - Method in class org.apache.cassandra.db.partitions.BTreePartitionUpdater
- merge(Cell<?>, Cell<?>) - Method in interface org.apache.cassandra.db.rows.ColumnData.PostReconciliationFunction
- merge(ColumnData, ColumnData) - Method in class org.apache.cassandra.db.rows.ColumnData.Reconciler
- merge(Row, Row) - Method in class org.apache.cassandra.db.partitions.BTreePartitionUpdater
- merge(Row, Row) - Static method in class org.apache.cassandra.db.rows.Rows
- merge(Row, Row, ColumnData.PostReconciliationFunction) - Static method in class org.apache.cassandra.db.rows.Rows
-
Merges two rows.
- merge(MemtableIndex) - Method in class org.apache.cassandra.index.sai.disk.RowMapping
-
Link the term ->
PrimaryKeys
mappings from a providedMemtableIndex
to thePrimaryKey
-> row ID mappings maintained here inRowMapping.rowMapping
to produce mappings of terms to their postings lists. - 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(TopPartitionTracker.Collector) - Method in class org.apache.cassandra.metrics.TopPartitionTracker
- merge(TopPartitionTracker.TopHolder, Collection<Range<Token>>) - Method in class org.apache.cassandra.metrics.TopPartitionTracker.TopHolder
-
we merge any pre-existing top partitions on to the ones we just collected if they are outside of the range collected.
- merge(PaxosRepairHistory, boolean) - Method in class org.apache.cassandra.service.paxos.TablePaxosRepairHistory
- merge(PaxosRepairHistory, PaxosRepairHistory) - Static method in class org.apache.cassandra.service.paxos.PaxosRepairHistory
- merge(PaxosState.Snapshot, PaxosState.Snapshot) - Static method in class org.apache.cassandra.service.paxos.PaxosState.Snapshot
- merge(WarningsSnapshot.Counter) - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Counter
- merge(WarningsSnapshot.Warnings) - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Warnings
- merge(WarningsSnapshot...) - Static method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- merge(T, T) - Static method in class org.apache.cassandra.utils.Throwables
- merge(V, K) - Method in interface org.apache.cassandra.utils.btree.UpdateFunction
-
Computes the result of merging the existing value with the one from the update.
- merge(V, V) - Method in class org.apache.cassandra.utils.btree.UpdateFunction.Simple
- mergeAndUpdateVersion(SchemaTransformation.SchemaTransformationResult, boolean) - 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)
- MERGED - org.apache.cassandra.db.transform.RTBoundValidator.Stage
- mergedClustering() - Method in class org.apache.cassandra.db.rows.Row.Merger
- mergeDistinct(Collection<? extends Trie<T>>) - Static method in class org.apache.cassandra.db.tries.Trie
-
Constructs a view of the merge of multiple tries, where each source must have distinct keys.
- 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
- mergePartitions(BTreePartitionData, PartitionUpdate) - Method in class org.apache.cassandra.db.partitions.BTreePartitionUpdater
- MergePostingList - Class in org.apache.cassandra.index.sai.disk.v1.postings
-
Merges multiple
PostingList
which individually contain unique items into a single list. - Merger(int, boolean) - Constructor for class org.apache.cassandra.db.rows.Row.Merger
- Merger(int, DeletionTime, boolean) - Constructor for class org.apache.cassandra.db.rows.RangeTombstoneMarker.Merger
- 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
- mergeUncommitted(CloseableIterator<PaxosKeyState>...) - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosKeyState
- mergeWith(Restriction) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
- 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(EncodingStats) - Method in class org.apache.cassandra.db.rows.EncodingStats
-
Merge this stats with another one.
- mergeWith(Trie<T>, Trie.MergeResolver<T>) - Method in class org.apache.cassandra.db.tries.Trie
-
Constructs a view of the merge of this trie with the given one.
- merkle_tree_response - Variable in class org.apache.cassandra.config.RepairRetrySpec
- 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 - Variable in class org.apache.cassandra.db.virtual.LogMessagesTable.LogMessage
- message - Variable in class org.apache.cassandra.repair.state.Completable.Result
- message - Variable in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupResponse
- message(Replica) - Method in class org.apache.cassandra.dht.RangeStreamer.AllowedSourcesFilter
- message(Replica) - Method in class org.apache.cassandra.dht.RangeStreamer.ExcludeLocalDatacenterFilter
- 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
andMessageOut
fused in one class. - Message - Class in org.apache.cassandra.transport
-
A message from the CQL binary protocol.
- Message(String) - Constructor for class org.apache.cassandra.audit.BinAuditLogger.Message
- Message(Message.Type) - Constructor for class org.apache.cassandra.transport.Message
- MESSAGE_COLUMN_NAME - Static variable in class org.apache.cassandra.db.virtual.LogMessagesTable
- 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
- MessageDelivery - Interface in org.apache.cassandra.net
- MessageFlag - Enum in org.apache.cassandra.net
-
Binary message flags to be passed as
flags
field ofMessage
. - messageHandlers - Variable in class org.apache.cassandra.net.MessagingServiceMBeanImpl
- MessageParams - Class in org.apache.cassandra.db
- messageProvider - Variable in class org.apache.cassandra.db.guardrails.Threshold
- messageReceived(StreamMessage) - Method in class org.apache.cassandra.streaming.StreamSession
- messaging() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- messaging() - Method in class org.apache.cassandra.repair.SharedContext.Global
- messaging() - Method in interface org.apache.cassandra.repair.SharedContext
- MESSAGING - org.apache.cassandra.net.ConnectionCategory
- 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.FailureResponseException - Exception in org.apache.cassandra.net
- 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
- MessagingServiceMBeanImpl(boolean, EndpointMessagingVersions, MessagingMetrics) - Constructor for class org.apache.cassandra.net.MessagingServiceMBeanImpl
- messagingVersion - Variable in class org.apache.cassandra.net.OutboundConnectionInitiator.Result.Success
- META - org.apache.cassandra.index.sai.disk.format.IndexComponent
-
Metadata for per-column index components
- 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 - Variable in class org.apache.cassandra.cql3.statements.ModificationStatement
- metadata - Variable in class org.apache.cassandra.cql3.UpdateParameters
- metadata - Variable in class org.apache.cassandra.db.ColumnFamilyStore
- metadata - Variable in class org.apache.cassandra.db.memtable.AbstractMemtable
- metadata - Variable in class org.apache.cassandra.db.partitions.ImmutableBTreePartition
- metadata - Variable in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
- metadata - Variable in class org.apache.cassandra.db.UnfilteredDeserializer
- metadata - Variable in class org.apache.cassandra.db.virtual.AbstractVirtualTable
- metadata - Variable in class org.apache.cassandra.index.internal.CassandraIndex
- metadata - Variable in class org.apache.cassandra.index.sai.disk.v1.segment.Segment
- metadata - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableIterator
- metadata - Variable in class org.apache.cassandra.io.sstable.format.SortedTableWriter.AbstractIndexWriter
- metadata - Variable in class org.apache.cassandra.io.sstable.format.StatsComponent
- metadata - Variable in class org.apache.cassandra.io.sstable.SSTable
- metadata - Variable in class org.apache.cassandra.schema.ViewMetadata
- metadata - Variable in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- metadata - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
Describes the variables to be bound in the prepared statement
- metadata() - Static method in class org.apache.cassandra.auth.AuthKeyspace
- metadata() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- metadata() - Method in class org.apache.cassandra.cql3.UntypedResultSet
- metadata() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- metadata() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
- metadata() - Method in class org.apache.cassandra.db.memtable.AbstractMemtable
- metadata() - Method in interface org.apache.cassandra.db.memtable.Memtable.FlushablePartitionSet
- metadata() - Method in interface org.apache.cassandra.db.memtable.Memtable
-
The table's definition metadata.
- metadata() - Method in class org.apache.cassandra.db.memtable.ShardedSkipListMemtable.MemtableUnfilteredPartitionIterator
- metadata() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
- metadata() - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
- 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() - 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 interface 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() - 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() - Method in class org.apache.cassandra.index.sai.plan.QueryController
- metadata() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- metadata() - Method in class org.apache.cassandra.index.sai.utils.InMemoryUnfilteredPartitionIterator
- metadata() - Method in class org.apache.cassandra.index.sasi.plan.QueryController
- metadata() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator
- metadata() - Method in class org.apache.cassandra.io.sstable.EmptySSTableScanner
- metadata() - Method in class org.apache.cassandra.io.sstable.format.SSTableScanner
- 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.schema.SchemaKeyspace
- metadata() - Static method in class org.apache.cassandra.schema.SystemDistributedKeyspace
- metadata() - Static method in class org.apache.cassandra.tracing.TraceKeyspace
- 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 - 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_CHANGE - org.apache.cassandra.io.sstable.format.SSTableReader.OpenReason
-
From: From
SSTableReader.OpenReason.NORMAL
- Reader has seen low traffic and the amount of memory available for index summaries is constrained, so its index summary has been downsampled FromSSTableReader.OpenReason.METADATA_CHANGE
- Same - METADATA_CHANGED - org.apache.cassandra.cql3.ResultSet.Flag
- 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(Iterable<SSTableReader>, ClusteringComparator) - Constructor for class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- 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.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
- 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
- metadataSource - Variable in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap.Factory
- MetadataSource - Class in org.apache.cassandra.index.sai.disk.v1
- MetadataType - Enum in org.apache.cassandra.io.sstable.metadata
-
Defines Metadata component type.
- metadataUpdated() - Method in class org.apache.cassandra.db.memtable.AbstractAllocatorMemtable
- metadataUpdated() - Method in interface org.apache.cassandra.db.memtable.Memtable
-
Called when the table's metadata is updated.
- MetadataWriter - Class in org.apache.cassandra.index.sai.disk.v1
- MetadataWriter(IndexOutput) - Constructor for class org.apache.cassandra.index.sai.disk.v1.MetadataWriter
- MetadataWriter.Builder - Class in org.apache.cassandra.index.sai.disk.v1
- MetaFactory(ClassLoader, ThreadGroup, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.cassandra.concurrent.NamedThreadFactory.MetaFactory
- 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(Class<?>, String, 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(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.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 - 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.concurrent.ThreadPoolExecutorJMXAdapter
- metrics() - Method in class org.apache.cassandra.utils.memory.BufferPool
- Metrics - Static variable in class org.apache.cassandra.metrics.CassandraMetricsRegistry
- metricsFor(TableId) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
- MetricsProviders - Interface in org.apache.cassandra.io.sstable
- 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.
- 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
- migrate() - Static method in class org.apache.cassandra.db.SystemKeyspaceMigrator41
- 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.
- MIGRATION - org.apache.cassandra.concurrent.Stage
- MIGRATION_DELAY - org.apache.cassandra.config.CassandraRelevantProperties
- MigrationCoordinator - Class in org.apache.cassandra.schema
-
Migration coordinator is responsible for tracking schema versions on various nodes and, if needed, synchronize the schema.
- MILLIS_CUSTOM_DURATION - org.apache.cassandra.config.Converters
-
This converter is used to support backward compatibility for parameters where in the past -1 was used as a value Example: credentials_update_interval_in_ms = -1 and credentials_update_interval = null are equal.
- MILLIS_DURATION_DOUBLE - org.apache.cassandra.config.Converters
- MILLIS_DURATION_INT - org.apache.cassandra.config.Converters
- MILLIS_DURATION_LONG - org.apache.cassandra.config.Converters
- min - Variable in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator.Builder.Statistics
- min - Variable in class org.apache.cassandra.index.sai.view.RangeTermTree
- 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 - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
- min - Variable in class org.apache.cassandra.tools.Util.TermHistogram
- min - Variable in class org.apache.cassandra.utils.Interval
- min() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
- min() - Method in class org.apache.cassandra.io.sstable.format.bti.RowIndexReader
- 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() - Method in class org.apache.cassandra.utils.EstimatedHistogram
- min() - Method in class org.apache.cassandra.utils.IntervalTree
- min(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Returns the smaller of two
ByteBuffer
values, based on the result ofIndexTermType.compare(ByteBuffer, ByteBuffer)
comparision. - min(T, T) - Static method in class org.apache.cassandra.utils.Comparables
-
Returns the minimum of 2 comparable values.
- min(T, T, Comparator<C>) - Static method in class org.apache.cassandra.utils.Comparables
-
Returns the minimum of 2 values given a comparator of those values.
- MIN - org.apache.cassandra.service.reads.HybridSpeculativeRetryPolicy.Function
- MIN_BOUND - org.apache.cassandra.db.PartitionPosition.Kind
- 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_END - Static variable in interface org.apache.cassandra.db.ClusteringBound
-
The smallest end bound, i.e.
- min_free_space_per_drive - Variable in class org.apache.cassandra.config.Config
- MIN_INDEX_INTERVAL - org.apache.cassandra.schema.TableParams.Option
- MIN_KEYS - Static variable in class org.apache.cassandra.utils.btree.BTree
- MIN_MAX_KEYS - org.apache.cassandra.io.sstable.SSTableReadsListener.SkippingReason
- MIN_NEXT_COMPONENT - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- MIN_SEPARATOR - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- MIN_SSTABLE_ROW_ID - Static variable in class org.apache.cassandra.index.sai.virtual.SegmentsSystemView
- MIN_SSTABLE_SIZE_KEY - Static variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
- MIN_TERM - Static variable in class org.apache.cassandra.index.sai.virtual.SegmentsSystemView
- MIN_THRESHOLD - org.apache.cassandra.schema.CompactionParams.Option
- min_tracked_partition_size - Variable in class org.apache.cassandra.config.Config
- min_tracked_partition_tombstone_count - Variable in class org.apache.cassandra.config.Config
- minAtUnixMillis(long) - Static method in class org.apache.cassandra.utils.TimeUUID
-
Returns the smaller possible type 1 UUID having the provided timestamp.
- minClusterVersion - Variable in class org.apache.cassandra.net.EndpointMessagingVersions
- minCompactionThreshold() - Method in class org.apache.cassandra.schema.CompactionParams
- minDelayNanos() - Method in class org.apache.cassandra.transport.QueueBackpressure.Incident
- 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
- minimizeBuffers(ByteBuffer[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- minimum() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.MergePostingList
- minimum() - Method in class org.apache.cassandra.index.sai.postings.PeekablePostingList
- minimum() - Method in interface org.apache.cassandra.index.sai.postings.PostingList
- 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_replication_factor_fail_threshold - Variable in class org.apache.cassandra.config.Config
- minimum_replication_factor_warn_threshold - Variable in class org.apache.cassandra.config.Config
- minimum_timestamp_fail_threshold - Variable in class org.apache.cassandra.config.Config
- minimum_timestamp_warn_threshold - Variable in class org.apache.cassandra.config.Config
- MINIMUM_TOKEN_COVERAGE - Static variable in interface org.apache.cassandra.db.compaction.ShardManager
-
Single-partition, and generally sstables with very few partitions, can cover very small sections of the token space, resulting in very high densities.
- minimum_version - Static variable in class org.apache.cassandra.net.MessagingService
- minimumAllowableTimestamp - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
- minimumKey - Variable in class org.apache.cassandra.index.sai.disk.v1.segment.IndexSegmentSearcherContext
- minimumReplicationFactor - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the minimum replication factor.
- minimumVersion - Variable in enum org.apache.cassandra.transport.Event.Type
- minIndexInterval - Variable in class org.apache.cassandra.schema.TableParams
- minIndexInterval(int) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- minIndexInterval(int) - Method in class org.apache.cassandra.schema.TableParams.Builder
- minKey - Variable in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata
-
Ordered by their token position in current segment
- 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.memtable.AbstractMemtable
- minLocalDeletionTime - Variable in class org.apache.cassandra.db.rows.EncodingStats
- minLocalDeletionTime - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
- MinMaxAvgMetric - Class in org.apache.cassandra.metrics
- MinMaxAvgMetric(MetricNameFactory, String) - Constructor for class org.apache.cassandra.metrics.MinMaxAvgMetric
- 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>, AbstractBounds.Boundary<T>) - Static method in class org.apache.cassandra.dht.AbstractBounds
- minRight(AbstractBounds.Boundary<T>, T, boolean) - Static method in class org.apache.cassandra.dht.AbstractBounds
- minSSTableRowId - Variable in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata
-
Min and max sstable rowId in current segment.
- minSSTableRowId() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
-
Returns the minimum indexed rowId for the index.
- minSSTableRowId() - Method in class org.apache.cassandra.index.sai.disk.v1.V1SSTableIndex
- minSSTableSize - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
- minSSTableSize - Variable in class org.apache.cassandra.db.compaction.unified.Controller
- minSupportedBloomFilterFpChance() - Static method in class org.apache.cassandra.utils.BloomCalculations
-
Retrieves the minimum supported BloomFilterFpChance value
- minTerm - Variable in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata
-
Minimum and maximum indexed column value ordered by its
AbstractType
. - minTerm - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
- minTerm() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
-
Returns the minimum term held in the index based on the natural sort order of the index column type comparator.
- minTerm() - Method in class org.apache.cassandra.index.sai.disk.v1.V1SSTableIndex
- 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
- MinThreshold - Class in org.apache.cassandra.db.guardrails
-
MinThreshold
for minimum guardrails, the value is checked to see if it is lesser than the warn and fail thresholds. - MinThreshold(String, String, ToLongFunction<ClientState>, ToLongFunction<ClientState>, Threshold.ErrorMessageProvider) - Constructor for class org.apache.cassandra.db.guardrails.MinThreshold
-
Creates a new minimum threshold guardrail.
- minTimestamp - Variable in class org.apache.cassandra.db.memtable.AbstractMemtable
- minTimestamp - Variable in class org.apache.cassandra.db.rows.EncodingStats
- minTimestamp - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
- 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
- MINUTES_CUSTOM_DURATION - org.apache.cassandra.config.Converters
-
This converter is used to support backward compatibility for parameters where in the past -1 was used as a value Example: index_summary_resize_interval_in_minutes = -1 and index_summary_resize_interval = null are equal.
- 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
- MISC - org.apache.cassandra.concurrent.Stage
- 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 - org.apache.cassandra.config.Config.DiskAccessMode
- Mmap(ChannelProxy, CompressionMetadata, MmappedRegions, Supplier<Double>) - Constructor for class org.apache.cassandra.io.util.CompressedChunkReader.Mmap
- mmap_index_only - org.apache.cassandra.config.Config.DiskAccessMode
- mmapped(boolean) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
-
Set whether to use mmap for reading
- mmapped(Config.DiskAccessMode) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
- 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
- mmappedRegionsCache - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
- MmappedRegionsCache - Class in org.apache.cassandra.io.util
-
It is a utility class for caching
MmappedRegions
primarily used by aFileHandle.Builder
when a handle to the same file is created multiple times (as when an sstable is opened early). - MmappedRegionsCache() - Constructor for class org.apache.cassandra.io.util.MmappedRegionsCache
- mockKS(KeyspaceMetadata) - Static method in class org.apache.cassandra.db.Keyspace
- mod(Number, Number) - Method in class org.apache.cassandra.db.marshal.ByteType
- mod(Number, Number) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
- mod(Number, Number) - Method in class org.apache.cassandra.db.marshal.DecimalType
- mod(Number, Number) - Method in class org.apache.cassandra.db.marshal.DoubleType
- mod(Number, Number) - Method in class org.apache.cassandra.db.marshal.FloatType
- mod(Number, Number) - Method in class org.apache.cassandra.db.marshal.Int32Type
- mod(Number, Number) - Method in class org.apache.cassandra.db.marshal.IntegerType
- mod(Number, Number) - Method in class org.apache.cassandra.db.marshal.LongType
- mod(Number, Number) - Method in class org.apache.cassandra.db.marshal.NumberType
-
Return the remainder.
- mod(Number, Number) - 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 - Variable in class org.apache.cassandra.index.sasi.sa.SA
- mode() - Method in class org.apache.cassandra.index.sasi.disk.OnDiskIndex
- mode() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
- mode(String) - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.Mode
- 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
- MODIFY - org.apache.cassandra.auth.Permission
- MONITOR - org.apache.cassandra.auth.ICIDRAuthorizer.CIDRAuthorizerMode
- 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
- MONITORING_MAX_OPERATIONS - org.apache.cassandra.config.CassandraRelevantProperties
-
Defines the maximum number of unique timed out queries that will be reported in the logs.
- MONITORING_REPORT_INTERVAL_MS - org.apache.cassandra.config.CassandraRelevantProperties
-
Defines the interval for reporting any operations that have timed out.
- MonitoringState - Enum in org.apache.cassandra.db.monitoring
- MONITORS - org.apache.cassandra.utils.Simulate.With
-
synchronized methods and blocks, and wait/notify.
- MONOTONIC_BLOCK_SIZE - Static variable in class org.apache.cassandra.index.sai.disk.v1.bitpack.NumericValuesWriter
- MonotonicBlockPackedReader - Class in org.apache.cassandra.index.sai.disk.v1.bitpack
-
Provides non-blocking, random access to a stream written with
MonotonicBlockPackedWriter
. - MonotonicBlockPackedReader(FileHandle, NumericValuesMeta) - Constructor for class org.apache.cassandra.index.sai.disk.v1.bitpack.MonotonicBlockPackedReader
- MonotonicBlockPackedWriter - Class in org.apache.cassandra.index.sai.disk.v1.bitpack
-
A writer for large monotonically increasing sequences of positive longs.
- MonotonicBlockPackedWriter(IndexOutput, int) - Constructor for class org.apache.cassandra.index.sai.disk.v1.bitpack.MonotonicBlockPackedWriter
- 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.AbstractEpochSamplingClock.AlmostSameTime - Class in org.apache.cassandra.utils
- MonotonicClock.Global - 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.PrepareResponse
- mostRecentCommit - Variable in class org.apache.cassandra.service.paxos.v1.PrepareCallback
- mostRecentInProgressCommit - Variable in class org.apache.cassandra.service.paxos.v1.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(File) - Method in class org.apache.cassandra.io.util.File
-
Atomically (if supported) rename/move this file to
to
- 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.
- MOVED_NODE - org.apache.cassandra.transport.Event.TopologyChange.Change
- MOVED_START - org.apache.cassandra.io.sstable.format.SSTableReader.OpenReason
-
From
SSTableReader.OpenReason.NORMAL
- Reader is being compacted. - 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
- MOVING - org.apache.cassandra.service.StorageService.Mode
- MovingAverage - Interface in org.apache.cassandra.utils
- msb() - Method in class org.apache.cassandra.utils.TimeUUID
- msbToRawTimestamp(long) - Static method in class org.apache.cassandra.utils.TimeUUID
- msProxy - Variable in class org.apache.cassandra.tools.NodeProbe
- MTLS - org.apache.cassandra.net.OutboundConnectionInitiator.SslFallbackConnectionType
- MulticastQueryEventListeners - Class in org.apache.cassandra.index.sai.metrics
- MulticastQueryEventListeners() - Constructor for class org.apache.cassandra.index.sai.metrics.MulticastQueryEventListeners
- MulticastQueryEventListeners.Multicast2BalancedTreeEventListener - Class in org.apache.cassandra.index.sai.metrics
- MulticastQueryEventListeners.Multicast2BalancedTreePostingListEventListener - Class in org.apache.cassandra.index.sai.metrics
- MulticastQueryEventListeners.Multicast2TrieIndexEventListener - Class in org.apache.cassandra.index.sai.metrics
- MulticastQueryEventListeners.Multicast2TriePostingListEventListener - Class in org.apache.cassandra.index.sai.metrics
- 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() - Constructor for class org.apache.cassandra.cql3.Term.MultiColumnRaw
- MultiColumnRaw(int) - Constructor for class org.apache.cassandra.cql3.AbstractMarker.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(Number, Number) - Method in class org.apache.cassandra.db.marshal.ByteType
- multiply(Number, Number) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
- multiply(Number, Number) - Method in class org.apache.cassandra.db.marshal.DecimalType
- multiply(Number, Number) - Method in class org.apache.cassandra.db.marshal.DoubleType
- multiply(Number, Number) - Method in class org.apache.cassandra.db.marshal.FloatType
- multiply(Number, Number) - Method in class org.apache.cassandra.db.marshal.Int32Type
- multiply(Number, Number) - Method in class org.apache.cassandra.db.marshal.IntegerType
- multiply(Number, Number) - Method in class org.apache.cassandra.db.marshal.LongType
- multiply(Number, Number) - Method in class org.apache.cassandra.db.marshal.NumberType
-
Multiplies the left argument with the right one.
- multiply(Number, Number) - Method in class org.apache.cassandra.db.marshal.ShortType
- MultiSetBucket(UnifiedCompactionStrategy.Level, List<Set<SSTableReader>>) - Constructor for class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy.MultiSetBucket
- 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
- MUST_BE_SORTED_ERROR - Static variable in class org.apache.cassandra.index.sai.iterators.KeyRangeConcatIterator
- MUST_SPECIFY_INDEX_IMPLEMENTATION - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- mutableComponents() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- mutableComponents() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- mutableComponents() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
Returns a set of the components that can be changed after an sstable was written.
- 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, long) - 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(List<? extends IMutation>, ConsistencyLevel, Dispatcher.RequestTime) - Static method in class org.apache.cassandra.service.StorageProxy
-
Use this method to have these Mutations applied across all replicas.
- 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
- mutateAtomically(Collection<Mutation>, ConsistencyLevel, boolean, Dispatcher.RequestTime) - Static method in class org.apache.cassandra.service.StorageProxy
-
See mutate.
- mutateCounter(CounterMutation, String, Dispatcher.RequestTime) - 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(int) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
- 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
- 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, Dispatcher.RequestTime) - Static method in class org.apache.cassandra.service.StorageProxy
-
Use this method to have these Mutations applied across all replicas.
- mutateRepaired(Collection<SSTableReader>, long, TimeUUID, 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, TimeUUID, 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, TimeUUID, boolean) - Method in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
- mutateRepairMetadata(Descriptor, long, TimeUUID, boolean) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataSerializer
-
Mutate the repairedAt time, pendingRepair ID, and transient status.
- mutateRepairMetadata(Descriptor, long, TimeUUID, boolean) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataSerializer
- mutateRepairStatus - Variable in class org.apache.cassandra.io.sstable.IVerifier.Options
- mutateRepairStatus(boolean) - Method in class org.apache.cassandra.io.sstable.IVerifier.Options.Builder
- mutateWithTriggers(List<? extends IMutation>, ConsistencyLevel, boolean, Dispatcher.RequestTime) - Static method in class org.apache.cassandra.service.StorageProxy
- Mutation - Class in org.apache.cassandra.db
- 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(PartitionUpdate) - Constructor for class org.apache.cassandra.db.Mutation
- MUTATION - org.apache.cassandra.concurrent.Stage
- MUTATION_ERROR - org.apache.cassandra.db.commitlog.CommitLogReadHandler.CommitLogReadErrorReason
- MUTATION_REQ - org.apache.cassandra.net.Verb
- MUTATION_RSP - org.apache.cassandra.net.Verb
- 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
- 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
- MutualTlsAuthenticator - Class in org.apache.cassandra.auth
- MutualTlsAuthenticator(Map<String, String>) - Constructor for class org.apache.cassandra.auth.MutualTlsAuthenticator
- MutualTlsCertificateValidator - Interface in org.apache.cassandra.auth
-
Interface for certificate validation and authorization for mTLS authenticators.
- MutualTlsInternodeAuthenticator - Class in org.apache.cassandra.auth
- MutualTlsInternodeAuthenticator(Map<String, String>) - Constructor for class org.apache.cassandra.auth.MutualTlsInternodeAuthenticator
- MutualTlsWithPasswordFallbackAuthenticator - Class in org.apache.cassandra.auth
-
This authenticator can be used in optional mTLS mode, If the client doesn't make an mTLS connection this fallbacks to password authentication.
- MutualTlsWithPasswordFallbackAuthenticator(Map<String, String>) - Constructor for class org.apache.cassandra.auth.MutualTlsWithPasswordFallbackAuthenticator
- MV_ALLOW_FILTERING_NONKEY_COLUMNS_UNSAFE - org.apache.cassandra.config.CassandraRelevantProperties
- MV_ENABLE_COORDINATOR_BATCHLOG - org.apache.cassandra.config.CassandraRelevantProperties
- MX4JADDRESS - org.apache.cassandra.config.CassandraRelevantProperties
-
mx4jaddress
- MX4JPORT - org.apache.cassandra.config.CassandraRelevantProperties
-
mx4jport
- 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 - Variable in class org.apache.cassandra.cql3.functions.FunctionFactory
-
The name of the built functions.
- name - Variable in class org.apache.cassandra.cql3.functions.FunctionName
- name - Variable in class org.apache.cassandra.cql3.functions.masking.ColumnMask.Raw
- name - Variable in class org.apache.cassandra.cql3.functions.types.DataType
- name - Variable in enum org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL.Kind
- name - Variable in class org.apache.cassandra.db.ColumnFamilyStore
- name - Variable in class org.apache.cassandra.db.guardrails.Guardrail
-
A name identifying the guardrail (mainly for shipping with diagnostic events).
- name - Variable in class org.apache.cassandra.db.marshal.UserType
- name - Variable in class org.apache.cassandra.db.view.View
- name - Variable in class org.apache.cassandra.index.sai.analyzer.filter.FilterPipeline.Task
- name - Variable in enum org.apache.cassandra.index.sai.disk.format.IndexComponent
- name - Variable in class org.apache.cassandra.io.sstable.Component
- name - Variable in class org.apache.cassandra.io.sstable.Component.Type
- name - Variable in class org.apache.cassandra.io.sstable.format.AbstractSSTableFormat
- name - Variable in class org.apache.cassandra.io.sstable.GaugeProvider
- 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 - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsKeyspace
- name - Variable in class org.apache.cassandra.transport.Event.SchemaChange
- name - Variable in class org.apache.cassandra.utils.memory.BufferPool
- name() - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
- name() - Method in interface org.apache.cassandra.cql3.functions.Function
- name() - Method in class org.apache.cassandra.cql3.functions.FunctionFactory
- name() - Method in class org.apache.cassandra.cql3.statements.QualifiedStatement
- name() - Method in interface org.apache.cassandra.db.monitoring.Monitorable
- name() - Method in class org.apache.cassandra.db.ReadCommand
- name() - Method in class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable.ColumnValue
-
Returns the column name.
- 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() - Method in class org.apache.cassandra.io.sstable.Component
- name() - Method in class org.apache.cassandra.io.sstable.format.AbstractSSTableFormat
- name() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat.BigFormatFactory
- name() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat.BtiFormatFactory
- name() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat.Factory
-
Returns a name of the format.
- name() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
- name() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.InstanceTidier
- name() - Method in class org.apache.cassandra.io.util.File
- name() - Method in class org.apache.cassandra.io.util.MmappedRegions.Tidier
- name() - Method in class org.apache.cassandra.repair.IncrementalRepairTask
- name() - Method in class org.apache.cassandra.repair.NormalRepairTask
- name() - Method in class org.apache.cassandra.repair.PreviewRepairTask
- name() - Method in interface org.apache.cassandra.repair.RepairTask
- name() - Method in class org.apache.cassandra.schema.ViewMetadata
- name() - Method in interface org.apache.cassandra.utils.concurrent.RefCounted.Tidy
- name(int) - Method in class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable.ColumnValues
-
Returns the name of the specified column
- NAME - Static variable in class org.apache.cassandra.cql3.functions.masking.DefaultMaskingFunction
- NAME - Static variable in class org.apache.cassandra.cql3.functions.masking.HashMaskingFunction
- NAME - Static variable in class org.apache.cassandra.cql3.functions.masking.NullMaskingFunction
- NAME - Static variable in class org.apache.cassandra.cql3.functions.masking.ReplaceMaskingFunction
- NAME - Static variable in class org.apache.cassandra.index.internal.CassandraIndex
- NAME - Static variable in class org.apache.cassandra.index.sai.StorageAttachedIndex
- NAME - Static variable in class org.apache.cassandra.index.sai.virtual.ColumnIndexesSystemView
- NAME - Static variable in class org.apache.cassandra.index.sai.virtual.SegmentsSystemView
- NAME - Static variable in class org.apache.cassandra.io.sstable.format.big.BigFormat
- NAME - Static variable in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- NAME - Static variable in class org.apache.cassandra.schema.SystemDistributedKeyspace
- NAME_COL - Static variable in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsCountsTable
- NAME_COL - Static variable in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsLatenciesTable
- 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
-
The longest permissible KS or CF name.
- NAME_PREFIX - Static variable in class org.apache.cassandra.cql3.functions.masking.MaskingFunction
-
The common prefix for the names of all the native data masking functions.
- 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
- NamedMemoryLimiter - Class in org.apache.cassandra.index.sai.utils
-
A simple, thread-safe memory usage tracker, named to reflect a particular scope.
- NamedMemoryLimiter(long, String) - Constructor for class org.apache.cassandra.index.sai.utils.NamedMemoryLimiter
- 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
- NamedThreadFactory(String, int, ClassLoader, ThreadGroup, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.cassandra.concurrent.NamedThreadFactory
- NamedThreadFactory(String, ClassLoader, ThreadGroup) - Constructor for class org.apache.cassandra.concurrent.NamedThreadFactory
- NamedThreadFactory.MetaFactory - Class in org.apache.cassandra.concurrent
- 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
- NAMES - org.apache.cassandra.db.filter.ClusteringIndexFilter.Kind
- 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
- NANOS_PER_SECOND - Static variable in class org.apache.cassandra.utils.concurrent.NonBlockingRateLimiter
- nanosToMillis(long) - Method in class org.apache.cassandra.repair.state.AbstractCompletable
- nanoTime() - Method in class org.apache.cassandra.utils.Clock.Default
-
System.nanoTime()
- nanoTime() - Static method in class org.apache.cassandra.utils.Clock.Global
-
Semantically equivalent to
System.nanoTime()
- nanoTime() - Method in interface org.apache.cassandra.utils.Clock
-
Semantically equivalent to
System.nanoTime()
- nanoTime() - Method in interface org.apache.cassandra.utils.NoSpamLogger.Clock
- NANOTIMETOMILLIS_TIMESTAMP_UPDATE_INTERVAL - org.apache.cassandra.config.CassandraRelevantProperties
- NATIVE_ADDRESS_AND_PORT - org.apache.cassandra.gms.ApplicationState
- NATIVE_EPOLL_ENABLED - org.apache.cassandra.config.CassandraRelevantProperties
- 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 - Variable in class org.apache.cassandra.config.Config
- native_transport_max_auth_threads - Variable in class org.apache.cassandra.config.Config
-
do bcrypt hashing in a limited pool to prevent cpu load spikes; note: any value < 1 will be set to 1 on init
- native_transport_max_backoff_on_queue_overload - 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_frame_size - Variable in class org.apache.cassandra.config.Config
- native_transport_max_request_data_in_flight - Variable in class org.apache.cassandra.config.Config
- native_transport_max_request_data_in_flight_per_ip - Variable in class org.apache.cassandra.config.Config
- native_transport_max_requests_per_second - Variable in class org.apache.cassandra.config.Config
- native_transport_max_threads - Variable in class org.apache.cassandra.config.Config
- native_transport_min_backoff_on_queue_overload - Variable in class org.apache.cassandra.config.Config
- native_transport_port - Variable in class org.apache.cassandra.config.Config
- NATIVE_TRANSPORT_PORT - org.apache.cassandra.config.CassandraRelevantProperties
-
This is the port used with RPC address for the native protocol to communicate with clients.
- native_transport_port_ssl - Variable in class org.apache.cassandra.config.Config
-
Deprecated.See CASSANDRA-19392
- native_transport_queue_max_item_age_threshold - Variable in class org.apache.cassandra.config.Config
- native_transport_rate_limiting_enabled - Variable in class org.apache.cassandra.config.Config
- native_transport_receive_queue_capacity - Variable in class org.apache.cassandra.config.Config
- native_transport_throw_on_overload - Variable in class org.apache.cassandra.config.Config
- native_transport_timeout - 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 8KiB to 1MiB to serve allocation of up to 128KiB.
- 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
- NativeCell(NativeAllocator, OpOrder.Group, ColumnMetadata, long, int, long, 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, byte[]) - Constructor for class org.apache.cassandra.db.NativeDecoratedKey
- 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
- NativeFunctions - Class in org.apache.cassandra.cql3.functions
-
A container of native functions.
- NativeFunctions() - Constructor for class org.apache.cassandra.cql3.functions.NativeFunctions
- 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
- NativeLibraryWrapper - Interface in org.apache.cassandra.utils
-
An interface to implement for using OS specific native methods.
- 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
- 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, AuthProvider, SSLOptions) - Constructor for class org.apache.cassandra.utils.NativeSSTableLoaderClient
- NativeSSTableLoaderClient(Collection<InetSocketAddress>, int, String, String, SSLOptions) - Constructor for class org.apache.cassandra.utils.NativeSSTableLoaderClient
- nativeTransportIdleTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- nativeTransportService() - Method in class org.apache.cassandra.service.CassandraDaemon
- 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(Keyspace, Token) - Static method in class org.apache.cassandra.locator.EndpointsForToken
- natural(AbstractReplicationStrategy, Token) - Static method in class org.apache.cassandra.locator.EndpointsForToken
- natural(TableMetadata, Token) - Static method in class org.apache.cassandra.locator.EndpointsForToken
- NATURAL_WEIGHER - Static variable in class org.apache.cassandra.utils.concurrent.WeightedQueue
- needFiltering(TableMetadata) - 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
- NEEDS_BOOTSTRAP - org.apache.cassandra.db.SystemKeyspace.BootstrapState
- 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.
- needsFiltering(Index.Group) - Method in class org.apache.cassandra.cql3.restrictions.CustomIndexExpression
-
Returns whether this expression would need filtering if the specified index group were used.
- needsFiltering(Index.Group) - Method in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction
- needsFiltering(Index.Group) - Method in interface org.apache.cassandra.cql3.restrictions.Restriction
-
Returns whether this restriction would need filtering if the specified index group were used.
- needsFiltering(Index.Group) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.ContainsRestriction
- needsFiltering(Index.Group) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
- needsFiltering(Index.Group) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction
- needsFiltering(IndexRegistry) - Method in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
-
Returns whether these restrictions would need filtering if the specified index registry were used.
- needsFullRebuild(String) - Method in class org.apache.cassandra.index.SecondaryIndexManager
- needsReconciliation() - Method in enum org.apache.cassandra.db.ConsistencyLevel
-
With a replication factor greater than one, reads that contact more than one replica will require reconciliation of the individual replica results at the coordinator.
- needsReconciliation() - Method in class org.apache.cassandra.db.filter.RowFilter
- negate(Number) - Method in class org.apache.cassandra.db.marshal.ByteType
- negate(Number) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
- negate(Number) - Method in class org.apache.cassandra.db.marshal.DecimalType
- negate(Number) - Method in class org.apache.cassandra.db.marshal.DoubleType
- negate(Number) - Method in class org.apache.cassandra.db.marshal.FloatType
- negate(Number) - Method in class org.apache.cassandra.db.marshal.Int32Type
- negate(Number) - Method in class org.apache.cassandra.db.marshal.IntegerType
- negate(Number) - Method in class org.apache.cassandra.db.marshal.LongType
- negate(Number) - Method in class org.apache.cassandra.db.marshal.NumberType
-
Negates the argument.
- negate(Number) - 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
- NEGATIVE_MEBIBYTES_DATA_STORAGE_INT - org.apache.cassandra.config.Converters
- NEGATIVE_SECONDS_DURATION - org.apache.cassandra.config.Converters
- negativeLocalDeletionInfoMetrics - Variable in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- NeighborsAndRanges(boolean, Set<InetAddressAndPort>, List<CommonRange>) - Constructor for class org.apache.cassandra.repair.RepairCoordinator.NeighborsAndRanges
- Nemesis - Annotation Type in org.apache.cassandra.utils
-
Annotate fields, particularly important volatile fields, where the system should adversarially schedule thread events around memory accesses (read or write).
- Nemesis.Traffic - Enum in org.apache.cassandra.utils
- NEQ - org.apache.cassandra.cql3.Operator
- NET_VERSION - org.apache.cassandra.gms.ApplicationState
- NetStats - Class in org.apache.cassandra.tools.nodetool
- NetStats() - Constructor for class org.apache.cassandra.tools.nodetool.NetStats
- NettyStreamingChannel - Class in org.apache.cassandra.streaming.async
- NettyStreamingChannel(Channel, StreamingChannel.Kind) - Constructor for class org.apache.cassandra.streaming.async.NettyStreamingChannel
- NettyStreamingConnectionFactory - Class in org.apache.cassandra.streaming.async
- NettyStreamingConnectionFactory() - Constructor for class org.apache.cassandra.streaming.async.NettyStreamingConnectionFactory
- nettySuccessListener(Collection<? extends Future<?>>) - Static method in class org.apache.cassandra.utils.concurrent.FutureCombiner
-
Waits for all of
futures
to complete, only propagating failures on completion - network_authorizer - Variable in class org.apache.cassandra.config.Config
- NETWORK_PERMISSIONS - Static variable in class org.apache.cassandra.auth.AuthKeyspace
- networking_cache_size - Variable in class org.apache.cassandra.config.Config
- networkPermissionsCache - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
- NetworkPermissionsCache - Class in org.apache.cassandra.auth
- NetworkPermissionsCache(INetworkAuthorizer) - Constructor for class org.apache.cassandra.auth.NetworkPermissionsCache
- NetworkPermissionsCacheMBean - Interface in org.apache.cassandra.auth
- NetworkTopologyStrategy - Class in org.apache.cassandra.locator
-
This Replication Strategy takes a property file that gives the intended replication factor in each datacenter.
- NetworkTopologyStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.NetworkTopologyStrategy
- networkVersion() - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- networkVersion(int) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- NEVER - org.apache.cassandra.service.reads.SpeculativeRetryPolicy.Kind
- NEVER_PURGE_TOMBSTONES - org.apache.cassandra.config.CassandraRelevantProperties
- NeverSpeculatingReadExecutor(ColumnFamilyStore, ReadCommand, ReplicaPlan.ForTokenRead, Dispatcher.RequestTime, boolean) - Constructor for class org.apache.cassandra.service.reads.AbstractReadExecutor.NeverSpeculatingReadExecutor
- NeverSpeculativeRetryPolicy - Class in org.apache.cassandra.service.reads
- NEW_NODE - org.apache.cassandra.transport.Event.TopologyChange.Change
- NEW_PREPARED_STATEMENT_BEHAVIOUR_SINCE_40 - Static variable in class org.apache.cassandra.cql3.QueryProcessor
- newAggregate() - Method in class org.apache.cassandra.cql3.functions.AggregateFcts.CountRowsFunction
- 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.MemtablePool.SubPool
- newAllocator(String) - Method in class org.apache.cassandra.utils.memory.HeapPool.Logged
- newAllocator(String) - Method in class org.apache.cassandra.utils.memory.HeapPool
- newAllocator(String) - Method in class org.apache.cassandra.utils.memory.MemtablePool
- newAllocator(String) - Method in class org.apache.cassandra.utils.memory.NativePool
- newAllocator(String) - Method in class org.apache.cassandra.utils.memory.SlabPool
- newArgTupleValue(int) - Method in interface org.apache.cassandra.cql3.functions.UDFContext
-
Creates a new
TupleValue
instance for an argument. - newArgTupleValue(int) - Method in class org.apache.cassandra.cql3.functions.UDFContextImpl
- newArgTupleValue(String) - 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
- newArgUDTValue(int) - Method in interface org.apache.cassandra.cql3.functions.UDFContext
-
Creates a new
UDTValue
instance for an argument. - newArgUDTValue(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(String) - Method in class org.apache.cassandra.cql3.functions.UDFContextImpl
- newArguments(ProtocolVersion) - Method in interface org.apache.cassandra.cql3.functions.Function
-
Creates some new input arguments for this function.
- newArguments(ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.masking.DefaultMaskingFunction
- newArguments(ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.masking.HashMaskingFunction
- newArguments(ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.masking.NullMaskingFunction
- newArguments(ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.masking.PartialMaskingFunction
- newArguments(ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.masking.ReplaceMaskingFunction
- newArguments(ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.NativeFunction
- newArguments(ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.ToJsonFct
- newArguments(ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.TokenFct
- newArguments(ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.UDAggregate
- newArguments(ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.UDFunction
- 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
- newBallot(Ballot, ConsistencyLevel) - Static method in class org.apache.cassandra.service.paxos.Paxos
- newBarrier() - Method in class org.apache.cassandra.utils.concurrent.OpOrder
-
Creates a new barrier.
- newBlockingQueue() - Static method in class org.apache.cassandra.utils.concurrent.BlockingQueues
- newBlockingQueue(int) - Static method in class org.apache.cassandra.utils.concurrent.BlockingQueues
- newBuilder() - Static method in class org.apache.cassandra.cql3.conditions.ColumnConditions
-
Creates a new
Builder
forColumnConditions
. - 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(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(K) - Method in class org.apache.cassandra.locator.ReplicaMultimap.Builder
- newBuilder(Range<Token>) - Method in class org.apache.cassandra.locator.EndpointsByRange.Builder
- newBuilder(InetAddressAndPort) - Method in class org.apache.cassandra.locator.RangesByEndpoint.Builder
- newBuilder(Replica) - Method in class org.apache.cassandra.locator.EndpointsByReplica.Builder
- newCast(Term.Raw, CQL3Type) - Static method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
- 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. - newCIDRAuthorizer(ParameterizedClass) - Static method in interface org.apache.cassandra.auth.ICIDRAuthorizer
- newCleanupTransaction(DecoratedKey, RegularAndStaticColumns, long) - 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, long) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Transaction for use when merging rows during compaction
- newConditionAsConsumer() - Static method in interface org.apache.cassandra.utils.concurrent.ConditionAsConsumer
- 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
- newCountDownLatch(int) - Static method in interface org.apache.cassandra.utils.concurrent.CountDownLatch
-
Factory method used to capture and redirect instantiations for simulation
- newCounter(long, 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
- newCryptoProvider(String, Map<String, String>) - Static method in class org.apache.cassandra.utils.FBUtilities
- 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
- newDummyTracker() - Static method in class org.apache.cassandra.db.lifecycle.Tracker
- 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
- NEWEST_TIMESTAMP - Static variable in class org.apache.cassandra.hints.PendingHintsInfo
- newestTimestamp - Variable in class org.apache.cassandra.hints.PendingHintsInfo
- newExecutor(int, String, String) - Method in class org.apache.cassandra.concurrent.SharedExecutorPool
- newExecutor(int, ExecutorPlus.MaximumPoolSizeListener, String, String) - Method in class org.apache.cassandra.concurrent.SharedExecutorPool
- newFactory(String, Term, AbstractType<?>) - Static method in class org.apache.cassandra.cql3.selection.TermSelector
- newFactory(AbstractType<?>, SelectorFactories) - Static method in class org.apache.cassandra.cql3.selection.VectorSelector
- newFactory(ColumnMetadata, int, boolean) - Static method in class org.apache.cassandra.cql3.selection.SimpleSelector
- newFailureDetector() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- newFairSemaphore(int) - Static method in interface org.apache.cassandra.utils.concurrent.Semaphore
-
Factory method used to capture and redirect instantiations for simulation Construct a fair Semaphore initially holding the specified number of permits
- newFormatInstance - Static variable in class org.apache.cassandra.utils.BloomFilterSerializer
- newGaugeProvider(String, Function<Iterable<R>, T>) - Method in class org.apache.cassandra.io.sstable.AbstractMetricsProviders
- newGaugeProvider(String, T, Function<R, T>, BiFunction<T, T, T>) - Method in class org.apache.cassandra.io.sstable.AbstractMetricsProviders
- 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. - newHashMap() - Static method in class org.apache.cassandra.utils.CollectionSerializer
- newHashSet() - Static method in class org.apache.cassandra.utils.CollectionSerializer
- 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
- newInputStream() - Method in class org.apache.cassandra.io.util.File
- 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() - Static method in class org.apache.cassandra.cql3.functions.TimeFcts.FloorDateFunction
- newInstance() - Static method in class org.apache.cassandra.cql3.functions.TimeFcts.FloorTimestampFunction
- newInstance() - Static method in class org.apache.cassandra.cql3.functions.TimeFcts.FloorTimeUuidFunction
- 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() - Method in enum org.apache.cassandra.utils.ChecksumType
- 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(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(ParameterizedClass, List<String>) - Static method in class org.apache.cassandra.config.ParameterizedClass
- 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(QueryOptions) - Method in interface org.apache.cassandra.db.aggregation.AggregationSpecification.Factory
-
Creates a new
AggregationSpecification
instance after having binded the parameters. - 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. - newInstanceForNativeFunction(ProtocolVersion, List<AbstractType<?>>) - Static method in class org.apache.cassandra.cql3.functions.FunctionArguments
-
Creates a new
FunctionArguments
for a native function. - newInstanceForUdf(ProtocolVersion, List<UDFDataType>) - Static method in class org.apache.cassandra.cql3.functions.FunctionArguments
-
Creates a new
FunctionArguments
for the specified types. - newInstanceWithStartTimeArgument() - Static method in class org.apache.cassandra.cql3.functions.TimeFcts.FloorDateFunction
- newInstanceWithStartTimeArgument() - Static method in class org.apache.cassandra.cql3.functions.TimeFcts.FloorTimestampFunction
- newInstanceWithStartTimeArgument() - Static method in class org.apache.cassandra.cql3.functions.TimeFcts.FloorTimeUuidFunction
- 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
- 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
- newMapping() - Static method in class org.apache.cassandra.cql3.selection.SelectionColumnMapping
- newMemoryUsage() - Static method in interface org.apache.cassandra.db.memtable.Memtable
-
Creates a holder for memory usage collection.
- newMessageDigest(String) - Static method in class org.apache.cassandra.utils.FBUtilities
- newName - Variable in class org.apache.cassandra.config.Replacement
-
New name used for the configuration parameter
- newNegation(Selectable.Raw) - Static method in class org.apache.cassandra.cql3.selection.Selectable.WithFunction.Raw
- newNegation(Term.Raw) - Static method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
- newNetworkAuthorizer(String) - Static method in class org.apache.cassandra.utils.FBUtilities
- newNode(InetAddressAndPort) - Static method in class org.apache.cassandra.transport.Event.TopologyChange
- newNoopInstance(ProtocolVersion, int) - Static method in class org.apache.cassandra.cql3.functions.FunctionArguments
-
Creates a new
FunctionArguments
that does not deserialize the arguments. - newOffsets(int, boolean) - Static method in class org.apache.cassandra.utils.EstimatedHistogram
- newOneTimeCondition() - Static method in interface org.apache.cassandra.utils.concurrent.Condition
-
Factory method used to capture and redirect instantiations for simulation
- newOperation(char, Selectable.Raw, Selectable.Raw) - Static method in class org.apache.cassandra.cql3.selection.Selectable.WithFunction.Raw
- newOperation(char, Term.Raw, Term.Raw) - Static method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
- newOutputStream(File.WriteMode) - Method in class org.apache.cassandra.io.util.File
- newPartition() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader.StreamDeserializer
- newPartitioner(String) - Static method in class org.apache.cassandra.utils.FBUtilities
- newPartitioner(Descriptor) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Create a new instance of a partitioner defined in an SSTable Descriptor
- newPerColumnIndexWriter(StorageAttachedIndex, LifecycleNewTracker, RowMapping) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- newPerColumnIndexWriter(StorageAttachedIndex, IndexDescriptor, LifecycleNewTracker, RowMapping) - Method in interface org.apache.cassandra.index.sai.disk.format.OnDiskFormat
-
Create a new
PerColumnIndexWriter
to write the per-column on-disk components of an index. - newPerColumnIndexWriter(StorageAttachedIndex, IndexDescriptor, LifecycleNewTracker, RowMapping) - Method in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- newPerSSTableIndexWriter() - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- newPerSSTableIndexWriter(IndexDescriptor) - Method in interface org.apache.cassandra.index.sai.disk.format.OnDiskFormat
-
Create a new
PerSSTableIndexWriter
to write the per-SSTable on-disk components of an index. - newPerSSTableIndexWriter(IndexDescriptor) - Method in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- newPerSSTablePrimaryKeyMap() - Method in interface org.apache.cassandra.index.sai.disk.PrimaryKeyMap.Factory
-
Creates a new
PrimaryKeyMap
instance - newPerSSTablePrimaryKeyMap() - Method in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap.Factory
- newPerSSTablePrimaryKeyMap() - Method in class org.apache.cassandra.index.sai.disk.v1.WidePrimaryKeyMap.Factory
- newPkPrefixGroupMaker(ClusteringComparator, int) - Static method in class org.apache.cassandra.db.aggregation.GroupMaker
- newPkPrefixGroupMaker(ClusteringComparator, int, GroupingState) - Static method in class org.apache.cassandra.db.aggregation.GroupMaker
- newPrepare(DecoratedKey, TableMetadata, Ballot) - Static method in class org.apache.cassandra.service.paxos.Commit
- newPrimaryKeyMapFactory(IndexDescriptor, SSTableReader) - Method in interface org.apache.cassandra.index.sai.disk.format.OnDiskFormat
-
Returns a
PrimaryKeyMap.Factory
for the SSTable - newPrimaryKeyMapFactory(IndexDescriptor, SSTableReader) - Method in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- newPrimaryKeyMapFactory(SSTableReader) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- newProposal(Ballot, PartitionUpdate) - Static method in class org.apache.cassandra.service.paxos.Commit
-
Deprecated.See CASSANDRA-17164
- newReadChannel() - Method in class org.apache.cassandra.io.util.File
- newReadChannel(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- newReadOrderingBarrier() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- newReadOrderingBarrier() - Method in interface org.apache.cassandra.io.sstable.SSTable.Owner
- newReadWriteChannel() - Method in class org.apache.cassandra.io.util.File
- newReadWriteChannel(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- newRestrictions(ClientState, TableMetadata, VariableSpecifications, Operations, WhereClause, Conditions, List<Ordering>) - 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(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
. - newRow(Clustering<V>) - Method in class org.apache.cassandra.cql3.UpdateParameters
- newRow(ProtocolVersion, DecoratedKey, Clustering<?>, List<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.ResultSetBuilder
-
Notifies this
Builder
that a new row is being processed. - 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) - Method in class org.apache.cassandra.auth.MutualTlsAuthenticator
- newSaslNegotiator(InetAddress) - Method in class org.apache.cassandra.auth.PasswordAuthenticator
- newSaslNegotiator(InetAddress, Certificate[]) - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Provide a SASL handler to perform authentication for an single connection.
- newSaslNegotiator(InetAddress, Certificate[]) - Method in class org.apache.cassandra.auth.MutualTlsAuthenticator
- newSaslNegotiator(InetAddress, Certificate[]) - Method in class org.apache.cassandra.auth.MutualTlsWithPasswordFallbackAuthenticator
- 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.WithArrayLiteral
- 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.WithTypeHint
- newSelectorFactory(TableMetadata, AbstractType<?>, List<ColumnMetadata>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithVector
- 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
- newSelectorGroupMaker(ClusteringComparator, int, Selector, List<ColumnMetadata>) - Static method in class org.apache.cassandra.db.aggregation.GroupMaker
- newSelectorGroupMaker(ClusteringComparator, int, Selector, List<ColumnMetadata>, GroupingState) - Static method in class org.apache.cassandra.db.aggregation.GroupMaker
- newSelectors(QueryOptions) - Method in class org.apache.cassandra.cql3.selection.Selection
- newSemaphore(int) - Static method in interface org.apache.cassandra.utils.concurrent.Semaphore
-
Factory method used to capture and redirect instantiations for simulation Construct an unfair Semaphore initially holding the specified number of permits
- newSession(Map<String, ByteBuffer>) - Method in class org.apache.cassandra.tracing.Tracing
- newSession(Tracing.TraceType) - Method in class org.apache.cassandra.tracing.Tracing
- newSession(TimeUUID, Map<String, ByteBuffer>) - Method in class org.apache.cassandra.tracing.Tracing
- newSession(TimeUUID, 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 currentMillis 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
- newSslContextFactory(String, Map<String, Object>) - Static method in class org.apache.cassandra.utils.FBUtilities
- newSslHandler(Channel, SslContext, InetSocketAddress) - Static method in class org.apache.cassandra.net.SocketFactory
-
Creates a new
SslHandler
from provided SslContext. - newSSTableDescriptor(File) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- newSSTableDescriptor(File, SSTableFormat<?, ?>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- newSSTableDescriptor(File, Version) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- newSSTableIndex(SSTableContext, StorageAttachedIndex) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- newSSTableIndex(SSTableContext, StorageAttachedIndex) - Method in interface org.apache.cassandra.index.sai.disk.format.OnDiskFormat
-
Create a new
SSTableIndex
for an on-disk index. - newSSTableIndex(SSTableContext, StorageAttachedIndex) - Method in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- newSSTableIndex(StorageAttachedIndex) - Method in class org.apache.cassandra.index.sai.SSTableContext
-
Returns a new
SSTableIndex
for a per-column index - newTask(Runnable) - Method in class org.apache.cassandra.concurrent.TaskFactory.Standard
- newTask(Callable<T>) - Method in class org.apache.cassandra.concurrent.TaskFactory.Standard
- newTask(WithResources, Runnable) - Method in class org.apache.cassandra.concurrent.TaskFactory.Standard
- newTask(WithResources, Callable<T>) - Method in class org.apache.cassandra.concurrent.TaskFactory.Standard
- newTaskFor(Runnable, T) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- newTaskFor(Runnable, T) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorPlus
- newTaskFor(Callable<T>) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- newTaskFor(Callable<T>) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorPlus
- newTester(ColumnMetadata) - Method in class org.apache.cassandra.db.filter.ColumnFilter
-
Creates a new
Tester
to efficiently test the inclusion of cells of complex columncolumn
. - 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
- newThread(ThreadGroup, Runnable, String) - Method in class org.apache.cassandra.concurrent.NamedThreadFactory
- newThreadGroup(String) - Method in class org.apache.cassandra.concurrent.ExecutorFactory.Default
- newThreadGroup(String) - Method in interface org.apache.cassandra.concurrent.ExecutorFactory
-
Create a new thread group for use with builders - this thread group will be situated within this factory's parent thread group, and may be supplied to multiple executor builders.
- newTraceState(InetAddressAndPort, TimeUUID, Tracing.TraceType) - Method in class org.apache.cassandra.tracing.Tracing
- newTraversalState() - Method in class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeWalker
- 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, long, Memtable) - 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() - Method in class org.apache.cassandra.cql3.functions.types.UserType
-
Returns a new empty value for this user type definition.
- 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.
- newWaitQueue() - Static method in interface org.apache.cassandra.utils.concurrent.WaitQueue
-
Factory method used to capture and redirect instantiations for simulation
- newWriteAppendChannel(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- newWriteChannel(File.WriteMode) - Method in class org.apache.cassandra.io.util.File
- newWriteOverwriteChannel(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- newWriter(AbstractType<?>, Descriptor, Map<ColumnMetadata, ColumnIndex>, OperationType) - Static method in class org.apache.cassandra.index.sasi.SASIIndex
- newWriter(File.WriteMode) - Method in class org.apache.cassandra.io.util.File
- newWriterBuilder(Descriptor) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
It is up to the caller to set the following fields: -
SSTableWriter.Builder.setKeyCount(long)
, -SSTableWriter.Builder.setSerializationHeader(SerializationHeader)
and, -SSTableWriter.Builder.setMetadataCollector(MetadataCollector)
- next - Variable in class org.apache.cassandra.index.sai.analyzer.AbstractAnalyzer
- next - Variable in class org.apache.cassandra.index.sai.analyzer.filter.FilterPipeline.Task
- next - Variable in class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
- 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.io.sstable.AbstractSSTableIterator.ForwardReader
- next - Variable in class org.apache.cassandra.utils.AbstractGuavaIterator
- next() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
- next() - Method in class org.apache.cassandra.db.memtable.ShardedSkipListMemtable.MemtableUnfilteredPartitionIterator
- next() - Method in class org.apache.cassandra.db.partitions.SingletonUnfilteredPartitionIterator
- next() - Method in class org.apache.cassandra.db.repair.CassandraValidationIterator
- next() - Method in interface org.apache.cassandra.db.rows.WrappingUnfilteredRowIterator
- next() - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader.StreamDeserializer
- next() - Method in class org.apache.cassandra.db.tries.TrieEntriesIterator
- next() - Method in class org.apache.cassandra.index.sai.analyzer.AbstractAnalyzer
-
Note: This method does not advance, as we rely on
Iterator.hasNext()
to buffer the next value. - next() - Method in class org.apache.cassandra.index.sai.memory.MemtableTermsIterator
- next() - Method in class org.apache.cassandra.index.sai.utils.InMemoryPartitionIterator
- next() - Method in class org.apache.cassandra.index.sai.utils.InMemoryUnfilteredPartitionIterator
- next() - Method in class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
- next() - Method in class org.apache.cassandra.index.sasi.analyzer.DelimiterAnalyzer
- next() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator.AbstractReader
- next() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator
- next() - Method in class org.apache.cassandra.io.sstable.EmptySSTableScanner
- next() - Method in class org.apache.cassandra.io.sstable.format.SSTableScanner
- 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.AbstractGuavaIterator
- next() - Method in class org.apache.cassandra.utils.AbstractIterator
- next() - Method in class org.apache.cassandra.utils.btree.FullBTreeSearchIterator
- next() - Method in class org.apache.cassandra.utils.btree.LeafBTreeSearchIterator
- next() - Method in class org.apache.cassandra.utils.BulkIterator.Adapter
- next() - Method in class org.apache.cassandra.utils.BulkIterator.FromArray
- next() - Method in interface org.apache.cassandra.utils.BulkIterator
- next() - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.AbstractEscaper
- next() - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.Multi
- next() - Method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
Consume the next byte, unsigned.
- next() - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.Number
- next() - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.Peekable
- next() - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.Separator
- next() - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.SignedFixedLengthFloat
- next() - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.SignedFixedLengthNumber
- next() - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.VariableLengthInteger
- next() - Method in class org.apache.cassandra.utils.bytecomparable.ByteSource.VariableLengthUnsignedInteger
- next(long) - Method in class org.apache.cassandra.service.paxos.BallotGenerator.Default
- next(long, Ballot.Flag) - Method in class org.apache.cassandra.service.paxos.BallotGenerator.Default
- next(long, Ballot.Flag) - Method in interface org.apache.cassandra.service.paxos.BallotGenerator
- next(K) - Method in class org.apache.cassandra.utils.btree.FullBTreeSearchIterator
- 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.
- NEXT_COMPONENT - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- NEXT_COMPONENT_EMPTY - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- NEXT_COMPONENT_EMPTY_REVERSED - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- NEXT_COMPONENT_NULL - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- nextBallot(long, Ballot.Flag) - Static method in class org.apache.cassandra.service.paxos.BallotGenerator.Global
- nextBallot(Ballot.Flag) - Static method in class org.apache.cassandra.service.paxos.BallotGenerator.Global
- nextChunk() - Method in interface org.apache.cassandra.db.commitlog.EncryptedFileSegmentInputStream.ChunkProvider
-
Get the next chunk from the backing provider, if any chunks remain.
- nextCollectedValue() - Method in class org.apache.cassandra.io.tries.ValueIterator
- nextComponentNull(int) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
- nextComponentSource(ByteSource.Peekable) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
A utility for consuming components from a peekable multi-component sequence.
- nextComponentSource(ByteSource.Peekable, int) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
A utility for consuming components from a peekable multi-component sequence, very similar to
ByteSourceInverse.nextComponentSource(ByteSource.Peekable)
- the difference being that here the separator can be passed in case it had to be consumed beforehand. - nextIndexPos() - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex.IndexPosIterator
-
Returns the position in the row index or data file.
- nextInternal() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator.AbstractReader
- nextInternal() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator.ForwardReader
- nextIsRow() - Method in class org.apache.cassandra.db.UnfilteredDeserializer
-
Returns whether the next atom is a row or not.
- nextLiteral - Variable in class org.apache.cassandra.index.sai.analyzer.AbstractAnalyzer
- nextPageReadQuery(int) - Method in class org.apache.cassandra.service.pager.PartitionRangeQueryPager
- nextPageReadQuery(int) - Method in class org.apache.cassandra.service.pager.SinglePartitionPager
- nextPayloadedNode() - Method in class org.apache.cassandra.io.tries.ReverseValueIterator
-
Returns the position of the next node with payload contained in the iterated span.
- nextPayloadedNode() - Method in class org.apache.cassandra.io.tries.ValueIterator
-
Returns the position of the next node with payload contained in the iterated span.
- nextPosting() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.FilteringPostingList
- nextPosting() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.MergePostingList
- nextPosting() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.PackedLongsPostingList
- nextPosting() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.PostingsReader
- nextPosting() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.VectorPostingList
- nextPosting() - Method in class org.apache.cassandra.index.sai.postings.IntArrayPostingList
- nextPosting() - Method in class org.apache.cassandra.index.sai.postings.PeekablePostingList
- nextPosting() - Method in class org.apache.cassandra.index.sai.postings.PostingList.EmptyPostingList
- nextPosting() - Method in interface org.apache.cassandra.index.sai.postings.PostingList
-
Retrieves the next segment row ID, not including row IDs that have been returned by
PostingList.advance(long)
. - nextRow(PrimaryKey) - Method in interface org.apache.cassandra.index.sai.disk.PerSSTableIndexWriter
- nextRow(PrimaryKey) - Method in class org.apache.cassandra.index.sai.disk.v1.SSTableComponentsWriter
- nextSliceIndex() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator
-
Returns the index of the next slice to process.
- nextSliceIndex() - Method in class org.apache.cassandra.io.sstable.format.big.SSTableIterator
- nextSliceIndex() - Method in class org.apache.cassandra.io.sstable.format.big.SSTableReversedIterator
- nextTimeAsUUID() - Static method in class org.apache.cassandra.utils.TimeUUID.Generator
- nextTimeUUID() - Static method in class org.apache.cassandra.utils.TimeUUID.Generator
- nextTimeUUIDAsBytes() - Method in class org.apache.cassandra.cql3.UpdateParameters
- nextTimeUUIDAsBytes() - Static method in class org.apache.cassandra.utils.TimeUUID.Generator
- nextUnfilteredCluster(Unfiltered) - Method in class org.apache.cassandra.index.sai.disk.StorageAttachedIndexWriter
- nextUnfilteredCluster(Unfiltered) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
- nextUnfilteredCluster(Unfiltered) - Method in interface org.apache.cassandra.io.sstable.SSTableFlushObserver
-
Called after an unfiltered is written to the sstable.
- nextValidToken() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner.BytesToken
- nextValidToken() - Method in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
- nextValidToken() - Method in class org.apache.cassandra.dht.RandomPartitioner.BigIntegerToken
- nextValidToken() - Method in class org.apache.cassandra.dht.Token
-
Returns the next possible token in the token space, one that compares greater than this and such that there is no other token that sits between this token and it in the token order.
- NINETY_NINE_P - Static variable in class org.apache.cassandra.service.reads.PercentileSpeculativeRetryPolicy
- NIO_DATA_OUTPUT_STREAM_PLUS_BUFFER_SIZE - org.apache.cassandra.config.CassandraRelevantProperties
- 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_CACHE - Static variable in class org.apache.cassandra.io.sstable.keycache.KeyCache
- NO_CHANGE - org.apache.cassandra.repair.state.AbstractState.UpdateType
- 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_DELETION_TIME_UNSIGNED_INTEGER - 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_LENGTH_OVERRIDE - Static variable in class org.apache.cassandra.io.util.FileHandle.Builder
- NO_LIMIT - Static variable in class org.apache.cassandra.db.filter.DataLimits
- NO_METADATA - org.apache.cassandra.cql3.ResultSet.Flag
- NO_MIN_TIMESTAMP - Static variable in interface org.apache.cassandra.db.memtable.Memtable
- NO_OP - Static variable in interface org.apache.cassandra.index.sai.metrics.QueryEventListener.PostingListEventListener
- 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_OP - Static variable in interface org.apache.cassandra.transport.QueueBackpressure
- NO_OP - Static variable in interface org.apache.cassandra.utils.memory.BufferPool.DebugLeaks
- NO_OP_LIMITER - Static variable in class org.apache.cassandra.utils.concurrent.NonBlockingRateLimiter
- NO_PENDING_REPAIR - Static variable in class org.apache.cassandra.service.ActiveRepairService
- NO_POSITION - Static variable in class org.apache.cassandra.schema.ColumnMetadata
- NO_SSL - org.apache.cassandra.net.OutboundConnectionInitiator.SslFallbackConnectionType
- 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
- noBackpressure(LongSupplier, LongSupplier) - Static method in interface org.apache.cassandra.transport.QueueBackpressure
- noCellLiveRow(Clustering<?>, LivenessInfo) - Static method in class org.apache.cassandra.db.rows.BTreeRow
- noCompression() - Static method in class org.apache.cassandra.schema.CompressionParams
- node - Variable in class org.apache.cassandra.transport.Event.NodeEvent
- Node(Long, Long) - Constructor for class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
- NODE_DOWN - org.apache.cassandra.exceptions.RequestFailureReason
- NODE_LOCAL - org.apache.cassandra.db.ConsistencyLevel
- 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() - Constructor for class org.apache.cassandra.tools.NodeProbe
- NodeProbe(String) - Constructor for class org.apache.cassandra.tools.NodeProbe
-
Creates a NodeProbe using the specified JMX host and default port.
- NodeProbe(String, int) - Constructor for class org.apache.cassandra.tools.NodeProbe
-
Creates a NodeProbe using the specified JMX host and port.
- 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.
- nodes - Variable in exception org.apache.cassandra.exceptions.QueryReferencesTooManyIndexesAbortException
- nodes - Variable in exception org.apache.cassandra.exceptions.TombstoneAbortException
- 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
- nodeSize() - Method in class org.apache.cassandra.io.tries.Walker
-
To be used only in analysis.
- NodeTool - Class in org.apache.cassandra.tools
- NodeTool(INodeProbeFactory, Output) - Constructor for class org.apache.cassandra.tools.NodeTool
- NODETOOL_JMX_NOTIFICATION_POLL_INTERVAL_SECONDS - org.apache.cassandra.config.CassandraRelevantProperties
- 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
- nodeType - Variable in class org.apache.cassandra.io.tries.Walker
- nodeTypeOrdinal() - Method in class org.apache.cassandra.io.tries.Walker
-
To be used only in analysis.
- nodeUp(InetAddressAndPort) - Static method in class org.apache.cassandra.transport.Event.StatusChange
- NON_COLLECTION_SIMPLE_INDEX - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- non_configurable_check - org.apache.cassandra.service.StartupChecks.StartupCheckType
- NON_CUSTOM_INDEX_IN_EXPRESSION - Static variable in class org.apache.cassandra.cql3.restrictions.IndexRestrictions
- NON_DAEMON - org.apache.cassandra.concurrent.InfiniteLoopExecutor.Daemon
- 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. - NON_GRACEFUL_SHUTDOWN - org.apache.cassandra.config.CassandraRelevantProperties
-
If set,
MessagingService
is shutdown abrtuptly without waiting for anything. - NON_LOCAL_STRATEGY - org.apache.cassandra.tools.NodeTool.NodeToolCmd.KeyspaceSet
- non_partition_restricted_index_query_enabled - Variable in class org.apache.cassandra.config.Config
- NON_SYSTEM - org.apache.cassandra.tools.NodeTool.NodeToolCmd.KeyspaceSet
- NonBlockingRateLimiter - Class in org.apache.cassandra.utils.concurrent
-
A rate limiter implementation that allows callers to reserve permits that may only be available in the future, delegating to them decisions about how to schedule/delay work and whether or not to block execution to do so.
- NonBlockingRateLimiter(int) - Constructor for class org.apache.cassandra.utils.concurrent.NonBlockingRateLimiter
- NonBlockingRateLimiter(int, long, Ticker) - Constructor for class org.apache.cassandra.utils.concurrent.NonBlockingRateLimiter
- NONCOMPACTING - org.apache.cassandra.db.lifecycle.SSTableSet
- none - org.apache.cassandra.config.Config.FlushCompression
- none - org.apache.cassandra.config.Config.InternodeCompression
- none - org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions.InternodeEncryption
- none - Static variable in interface org.apache.cassandra.db.compaction.CompactionLogger.Strategy
- none() - Static method in class org.apache.cassandra.auth.CIDRPermissions
-
Generates CIDR permissions object which doesn't allow from any CIDR group
- none() - Static method in class org.apache.cassandra.auth.DCPermissions
- none() - Static method in class org.apache.cassandra.cql3.Attributes
- none() - Static method in class org.apache.cassandra.db.filter.RowFilter
- 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.UserFunctions
- none() - Static method in class org.apache.cassandra.schema.Views
- none() - Static method in class org.apache.cassandra.service.paxos.Ballot
- none() - Static method in interface org.apache.cassandra.utils.WithResources
- none(DecoratedKey, TableMetadata) - Static method in class org.apache.cassandra.service.paxos.Commit.Accepted
- none(DecoratedKey, TableMetadata) - Static method in class org.apache.cassandra.service.paxos.Commit.Committed
- NONE - org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState.Action
- NONE - org.apache.cassandra.index.sai.IndexValidation
-
No validation to be performed
- NONE - org.apache.cassandra.locator.ReplicaCollection.Builder.Conflict
-
fail on addition of any such conflict
- NONE - org.apache.cassandra.schema.ColumnMetadata.ClusteringOrder
- NONE - org.apache.cassandra.schema.CompactionParams.TombstoneOption
- NONE - org.apache.cassandra.service.paxos.Ballot.Flag
- NONE - org.apache.cassandra.service.reads.repair.ReadRepairStrategy
- NONE - org.apache.cassandra.streaming.PreviewKind
- NONE - org.apache.cassandra.tracing.Tracing.TraceType
- NONE - org.apache.cassandra.transport.ClientResourceLimits.Overload
- NONE - org.apache.cassandra.utils.Overlaps.InclusionMethod
- NONE - org.apache.cassandra.utils.Shared.Recursive
- NONE - org.apache.cassandra.utils.StorageCompatibilityMode
-
Don't try to be compatible with older versions.
- NONE - Static variable in enum org.apache.cassandra.auth.Permission
- 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 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.memtable.ShardBoundaries
- 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 variable in interface org.apache.cassandra.index.sai.disk.PerSSTableIndexWriter
- NONE - Static variable in class org.apache.cassandra.io.tries.TrieNode
-
Value used to indicate a branch (e.g.
- NONE - Static variable in class org.apache.cassandra.io.tries.Walker
-
Value used to indicate a branch (e.g.
- NONE - Static variable in class org.apache.cassandra.schema.Keyspaces.KeyspacesDiff
- NONE - Static variable in interface org.apache.cassandra.streaming.StreamSession.MessageStateSink
- NONE_AVAILABLE - org.apache.cassandra.concurrent.SEPExecutor.TakeTaskPermitResult
- 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
- nonPartitionRestrictedIndexQueryEnabled - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
- 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.
- nonPeriodicTasks() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- nonPeriodicTasks() - Method in class org.apache.cassandra.repair.SharedContext.Global
- nonPeriodicTasks() - Method in interface org.apache.cassandra.repair.SharedContext
- nonPKRestrictedColumns(boolean) - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
Returns the non-PK column that are restricted.
- NonTerminal() - Constructor for class org.apache.cassandra.cql3.Term.NonTerminal
- NonTokenizingAnalyzer - Class in org.apache.cassandra.index.sai.analyzer
-
Analyzer that does *not* tokenize the input.
- 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.sai.analyzer
- NonTokenizingOptions - Class in org.apache.cassandra.index.sasi.analyzer
- NonTokenizingOptions() - Constructor for class org.apache.cassandra.index.sai.analyzer.NonTokenizingOptions
- NonTokenizingOptions() - Constructor for class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
- NonTokenizingOptions.OptionsBuilder - Class in org.apache.cassandra.index.sai.analyzer
- NonTokenizingOptions.OptionsBuilder - Class in org.apache.cassandra.index.sasi.analyzer
- nonZeroSize(long) - Static method in class org.apache.cassandra.io.util.SizedInts
-
Returns the number of bytes we need to store the given position.
- noop() - Static method in class org.apache.cassandra.schema.CompressionParams
- noOp - Static variable in class org.apache.cassandra.db.rows.ColumnData
- noOp - Static variable in interface org.apache.cassandra.utils.btree.UpdateFunction
- noOp() - Static method in interface org.apache.cassandra.service.paxos.PaxosOperationLock
- noOp() - Static method in interface org.apache.cassandra.utils.btree.UpdateFunction
- NOOP - org.apache.cassandra.index.Index.LoadType
- 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 variable in class org.apache.cassandra.utils.memory.EnsureOnHeap
- NOOP_CALLBACK - Static variable in class org.apache.cassandra.repair.messages.RepairMessage
- NOOP_DESERIALIZER - Static variable in interface org.apache.cassandra.cql3.functions.ArgumentDeserializer
-
An
ArgumentDeserializer
that do not deserialize data. - NOOP_LISTENER - Static variable in interface org.apache.cassandra.io.sstable.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.sai.analyzer.filter.BasicFilters.NoOperation
- 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,P>> - Class in org.apache.cassandra.service.reads.repair
-
Bypasses the read repair path for short read protection and testing
- NoopScheduler() - Constructor for class org.apache.cassandra.repair.Scheduler.NoopScheduler
- noPayload - Static variable in class org.apache.cassandra.net.NoPayload
- NoPayload - Class in org.apache.cassandra.net
-
Empty message payload - primarily used for responses.
- 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 - org.apache.cassandra.concurrent.ExecutorFactory.SimulatorSemantics
- NORMAL - org.apache.cassandra.concurrent.Interruptible.State
- NORMAL - org.apache.cassandra.io.sstable.format.SSTableReader.OpenReason
-
From
None
- Reader has been read from disk, either at startup or from a flushed memtable FromSSTableReader.OpenReason.EARLY
- Reader is the final result of a compaction FromSSTableReader.OpenReason.MOVED_START
- Reader WAS being compacted, but this failed and it has been restored to {code NORMAL}status - NORMAL - org.apache.cassandra.net.Verb.Kind
- NORMAL - org.apache.cassandra.service.StorageService.Mode
- 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(String) - Static method in class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
- normalize(Collection<Range<T>>) - Static method in class org.apache.cassandra.dht.Range
- Normalize() - Constructor for class org.apache.cassandra.index.sai.analyzer.filter.BasicFilters.Normalize
- NORMALIZE - Static variable in class org.apache.cassandra.index.sai.analyzer.NonTokenizingOptions
- 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
- NormalRepairTask - Class in org.apache.cassandra.repair
- NormalRepairTask(RepairCoordinator, TimeUUID, List<CommonRange>, String[]) - Constructor for class org.apache.cassandra.repair.NormalRepairTask
- 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.Clock - Interface in org.apache.cassandra.utils
- 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
- NoSuchRepairSessionException - Exception in org.apache.cassandra.repair
- NoSuchRepairSessionException(TimeUUID) - Constructor for exception org.apache.cassandra.repair.NoSuchRepairSessionException
- NOT_ASSIGNABLE - org.apache.cassandra.cql3.AssignmentTestable.TestResult
- NOT_AVAILABLE - org.apache.cassandra.service.disk.usage.DiskUsageState
-
Either disk usage guardrail is not enabled or gossip state is not ready.
- NOT_COMPARABLE - org.apache.cassandra.db.marshal.AbstractType.ComparisonType
-
This type should never be compared
- NOT_EQ - org.apache.cassandra.index.sasi.plan.Expression.Op
- NOT_FOUND - Static variable in class org.apache.cassandra.index.sai.disk.v1.trie.TrieTermsDictionaryReader
- NOT_FOUND - Static variable in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex
- NOT_INDEXED - Static variable in class org.apache.cassandra.index.sasi.conf.IndexMode
- NOT_READY - org.apache.cassandra.utils.AbstractGuavaIterator.State
-
We haven't yet computed or have already returned the element.
- notDone(Future<?>) - Static method in class org.apache.cassandra.repair.messages.RepairMessage
- notification(String) - Method in class org.apache.cassandra.repair.RepairCoordinator
- notification(String) - Method in interface org.apache.cassandra.repair.RepairNotifier
- NOTIFICATION - org.apache.cassandra.utils.progress.ProgressEventType
-
Used when sending message without progress.
- 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.RepairCoordinator
- notifyError(Throwable) - Method in interface org.apache.cassandra.repair.RepairNotifier
- 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
- notifyExecutor() - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- notifyExecutor() - Method in class org.apache.cassandra.utils.concurrent.AsyncPromise.WithExecutor
- notifyExecutor() - Method in interface org.apache.cassandra.utils.concurrent.Future
- notifyExecutor() - Method in class org.apache.cassandra.utils.concurrent.SyncPromise.WithExecutor
- notifyFailureDetector(Map<InetAddressAndPort, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
- notifyFailureDetector(Map<InetAddressAndPort, EndpointState>) - Method in interface org.apache.cassandra.gms.IGossiper
- notifyIfBlocking(WaitQueue.Signal) - Method in class org.apache.cassandra.utils.concurrent.OpOrder.Group
- notifyKeyspaceAltered(KeyspaceMetadata.KeyspaceDiff, boolean) - Method in class org.apache.cassandra.schema.SchemaChangeNotifier
- notifyKeyspaceCreated(KeyspaceMetadata) - Method in class org.apache.cassandra.schema.SchemaChangeNotifier
- notifyKeyspaceDropped(KeyspaceMetadata, boolean) - Method in class org.apache.cassandra.schema.SchemaChangeNotifier
- notifyObservers(Consumer<SSTableFlushObserver>) - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter
- notifyPreChanges(SchemaTransformation.SchemaTransformationResult) - Method in class org.apache.cassandra.schema.SchemaChangeNotifier
- 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
- notifyProgress(String) - Method in class org.apache.cassandra.repair.RepairCoordinator
- notifyProgress(String) - Method in interface org.apache.cassandra.repair.RepairNotifier
- 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
- notifySelected(SSTableReadsListener.SelectionReason, SSTableReadsListener, SSTableReader.Operator, boolean, AbstractRowIndexEntry) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
A method to be called by
SSTableReader.getPosition(PartitionPosition, Operator, boolean, SSTableReadsListener)
andSSTableReader.getRowIndexEntry(PartitionPosition, Operator, boolean, SSTableReadsListener)
methods when a searched key is found. - notifySelected(SSTableReadsListener.SelectionReason, SSTableReadsListener, SSTableReader.Operator, boolean, AbstractRowIndexEntry) - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderWithFilter
- notifySkipped(SSTableReadsListener.SkippingReason, SSTableReadsListener, SSTableReader.Operator, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
A method to be called by
SSTableReader.getPosition(PartitionPosition, Operator, boolean, SSTableReadsListener)
andSSTableReader.getRowIndexEntry(PartitionPosition, Operator, boolean, SSTableReadsListener)
methods when a searched key is not found. - notifySkipped(SSTableReadsListener.SkippingReason, SSTableReadsListener, SSTableReader.Operator, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderWithFilter
- 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
- NotScheduledFuture<T> - Class in org.apache.cassandra.utils.concurrent
- NotScheduledFuture() - Constructor for class org.apache.cassandra.utils.concurrent.NotScheduledFuture
- now() - Method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- 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() - Static method in class org.apache.cassandra.utils.FBUtilities
- 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 - Variable in class org.apache.cassandra.repair.messages.ValidationRequest
- nowInSec - Variable in class org.apache.cassandra.repair.Validator
- 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(long) - 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.
- nowInSeconds - Variable in class org.apache.cassandra.db.AbstractReadCommandBuilder
- nowInSeconds() - Method in interface org.apache.cassandra.utils.Clock
- nowInSeconds() - Static method in class org.apache.cassandra.utils.FBUtilities
- npcProxy - Variable in class org.apache.cassandra.tools.NodeProbe
- 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.utils.CassandraVersion
-
Used to indicate that no previous version information was found.
- nullableSerializer - Static variable in class org.apache.cassandra.gms.EndpointState
- NullableSerializer - Class in org.apache.cassandra.utils
- NullableSerializer() - Constructor for class org.apache.cassandra.utils.NullableSerializer
- NullMaskingFunction - Class in org.apache.cassandra.cql3.functions.masking
-
A
MaskingFunction
that always returns anull
column. - 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.
- nullSafeMax(PrimaryKey, PrimaryKey) - Static method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator
- nullSafeMin(PrimaryKey, PrimaryKey) - Static method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator
- NUM - org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer.TokenType
- num_tokens - Variable in class org.apache.cassandra.config.Config
- Number(long, int) - Constructor for class org.apache.cassandra.utils.bytecomparable.ByteSource.Number
- NumberArgumentDeserializer(M) - Constructor for class org.apache.cassandra.db.marshal.NumberType.NumberArgumentDeserializer
- 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
- NumberType.NumberArgumentDeserializer<M extends org.apache.commons.lang3.mutable.Mutable<java.lang.Number>> - Class in org.apache.cassandra.db.marshal
-
Base class for numeric type
ArgumentDeserializer
. - numBlocks - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
- numBlocks(long, int) - Static method in class org.apache.cassandra.index.sai.disk.v1.SAICodecUtils
- numColumns() - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- NUMERIC_COMPONENTS - Static variable in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- NumericIndexSegmentSearcher - Class in org.apache.cassandra.index.sai.disk.v1.segment
-
Executes
Expression
s against the balanced tree for an individual index segment. - NumericIndexWriter - Class in org.apache.cassandra.index.sai.disk.v1.bbtree
-
Specialized writer for values, that builds them into a
BlockBalancedTreeWriter
with auxiliary posting lists on eligible tree levels. - NumericIndexWriter(IndexDescriptor, IndexIdentifier, int) - Constructor for class org.apache.cassandra.index.sai.disk.v1.bbtree.NumericIndexWriter
- NumericIndexWriter(IndexDescriptor, IndexIdentifier, int, int) - Constructor for class org.apache.cassandra.index.sai.disk.v1.bbtree.NumericIndexWriter
- numericSetOrList() - Static method in interface org.apache.cassandra.cql3.functions.FunctionParameter
- NumericValuesMeta - Class in org.apache.cassandra.index.sai.disk.v1.bitpack
- NumericValuesMeta(DataInput) - Constructor for class org.apache.cassandra.index.sai.disk.v1.bitpack.NumericValuesMeta
- NumericValuesWriter - Class in org.apache.cassandra.index.sai.disk.v1.bitpack
- NumericValuesWriter(IndexDescriptor, IndexComponent, MetadataWriter, boolean) - Constructor for class org.apache.cassandra.index.sai.disk.v1.bitpack.NumericValuesWriter
- NumericValuesWriter(IndexDescriptor, IndexComponent, MetadataWriter, boolean, int) - Constructor for class org.apache.cassandra.index.sai.disk.v1.bitpack.NumericValuesWriter
- numGroups() - Method in class org.apache.cassandra.db.compaction.AbstractStrategyHolder.GroupedSSTableContainer
- numPages(int) - Static method in class org.apache.cassandra.io.util.PageAware
-
Calculate the number of pages that fit in the given size, rounded up to a page if the size is not an exact multiple.
- numPendingTasks - Variable in class org.apache.cassandra.utils.memory.MemtablePool
- numPendingTasks() - Method in class org.apache.cassandra.utils.memory.MemtableCleanerThread
-
Return the number of pending tasks
- numRows - Variable in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata
-
number of indexed rows (aka.
- numRows() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentTrieBuffer
- numSSTables - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStat.Builder
- numSSTables - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStat
O
- obfuscate(String) - Static method in class org.apache.cassandra.cql3.PasswordObfuscator
-
Obfuscates everything after the first appearance password token
- obfuscate(String, RoleOptions) - Static method in class org.apache.cassandra.cql3.PasswordObfuscator
-
Obfuscates the password in a query
- obfuscatePassword(String) - Method in class org.apache.cassandra.cql3.statements.AlterRoleStatement
- obfuscatePassword(String) - Method in class org.apache.cassandra.cql3.statements.AuthenticationStatement
- obfuscatePassword(String) - Method in class org.apache.cassandra.cql3.statements.CreateRoleStatement
- 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
- OBSOLETED - org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState.Action
- 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(byte[], int, int) - Method in enum org.apache.cassandra.utils.ChecksumType
- of(byte[], ByteComparable.Version) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
Encodes a byte array as a byte-comparable source that has 0s escaped and finishes in an escape.
- 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(int) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteComparable
- of(int) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- of(long) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteComparable
- of(long) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- of(Iterable<IndexMetadata>) - Static method in class org.apache.cassandra.schema.Indexes
- of(Iterable<TableMetadata>) - Static method in class org.apache.cassandra.schema.Tables
- of(Iterable<TriggerMetadata>) - Static method in class org.apache.cassandra.schema.Triggers
- of(Object[]) - Static method in interface org.apache.cassandra.utils.BulkIterator
- of(Object[], int) - Static method in interface org.apache.cassandra.utils.BulkIterator
- of(String) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteComparable
- of(String, ByteComparable.Version) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- of(ByteBuffer) - Method in enum org.apache.cassandra.utils.ChecksumType
- of(ByteBuffer, ByteComparable.Version) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
Encodes a byte buffer as a byte-comparable source that has 0s escaped and finishes in an escape.
- of(Collection<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(Iterator<V>) - Static method in interface org.apache.cassandra.utils.BulkIterator
- of(List<Term>) - Static method in interface org.apache.cassandra.cql3.Terms
-
Creates a
Terms
containing a set ofTerm
. - of(VectorType, TypeCodec<E>) - Static method in class org.apache.cassandra.cql3.functions.types.VectorCodec
- of(Term) - Static method in interface org.apache.cassandra.cql3.Terms
-
Creates a
Terms
containing a singleTerm
. - of(UserType...) - Static method in class org.apache.cassandra.schema.Types
- of(ValueAccessor<V>, V, ByteComparable.Version) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
Encodes byte-accessible data as a byte-comparable source that has 0s escaped and finishes in an escaped state.
- 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(QueryContext, QueryEventListener.BalancedTreeEventListener) - Static method in class org.apache.cassandra.index.sai.metrics.MulticastQueryEventListeners
- of(QueryContext, QueryEventListener.TrieIndexEventListener) - Static method in class org.apache.cassandra.index.sai.metrics.MulticastQueryEventListeners
- of(Replica) - Static method in class org.apache.cassandra.locator.EndpointsForRange
- of(Replica) - Static method in class org.apache.cassandra.locator.RangesAtEndpoint
- of(Replica...) - Static method in class org.apache.cassandra.locator.EndpointsForRange
- of(Replica...) - Static method in class org.apache.cassandra.locator.RangesAtEndpoint
- 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(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(TriggerMetadata...) - Static method in class org.apache.cassandra.schema.Triggers
- of(Ballot, PartitionUpdate) - Static method in class org.apache.cassandra.service.paxos.Commit.Proposal
- 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(V) - Static method in class org.apache.cassandra.utils.btree.BTreeSet
- OFF_HEAP - org.apache.cassandra.io.compress.BufferType
- 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.BlockingQueues.Sync
- offer(T) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
- offer(T, long, TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- offer(T, long, TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
- offer(V) - Method in class org.apache.cassandra.utils.caching.TinyThreadLocalPool
- offer(V) - Method in class org.apache.cassandra.utils.caching.TinyThreadLocalPool.TinyPool
- offHeap - Variable in class org.apache.cassandra.utils.memory.MemtablePool
- offHeap() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
- offheap_buffers - org.apache.cassandra.config.Config.MemtableAllocationType
- offheap_objects - org.apache.cassandra.config.Config.MemtableAllocationType
- 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.db.rows.NativeCell
- 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.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) - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
construct an empty Transaction with no existing readers
- 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, SSTableReader) - Static method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
-
construct a Transaction for use in an offline operation
- OfflineSchemaUpdateHandler - Class in org.apache.cassandra.schema
-
Update handler which works only in memory.
- OfflineSchemaUpdateHandler(BiConsumer<SchemaTransformation.SchemaTransformationResult, Boolean>) - Constructor for class org.apache.cassandra.schema.OfflineSchemaUpdateHandler
- 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.index.sai.disk.v1.segment.SegmentMetadata.ComponentMetadata
- offset - Variable in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
- offset - Variable in class org.apache.cassandra.io.sstable.format.bti.RowIndexReader.IndexInfo
- offset - Variable in class org.apache.cassandra.io.sstable.IndexInfo
- offset - Variable in class org.apache.cassandra.io.util.BufferManagingRebufferer
- offset - Variable in class org.apache.cassandra.io.util.MmappedRegions.Region
- offset - Variable in class org.apache.cassandra.io.util.WrappingRebufferer
- offset() - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
- 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.
- offset() - Method in class org.apache.cassandra.io.util.WrappingRebufferer
- OFFSET - Static variable in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata.ComponentMetadata
- OFFSET_NOT_FOUND - Static variable in interface org.apache.cassandra.index.sai.postings.PostingList
- 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.io.sstable.format.big.BigFormatPartitionWriter
- ofListMarker(Lists.Marker, AbstractType<?>) - Static method in interface org.apache.cassandra.cql3.Terms
-
Creates a
Terms
for the specified list marker. - ofMemory(long, int, ByteComparable.Version) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
Encodes a memory range as a byte-comparable source that has 0s escaped and finishes in an escape.
- 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
- OLDEST_TASK_QUEUE_TIME - Static variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
- OLDEST_TIMESTAMP - Static variable in class org.apache.cassandra.hints.PendingHintsInfo
- oldestTaskQueueTime - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
-
For how long the oldest task in the queue was queued
- oldestTaskQueueTime() - Method in interface org.apache.cassandra.concurrent.ResizableThreadPool
- oldestTaskQueueTime() - Method in class org.apache.cassandra.concurrent.SEPExecutor
- oldestTimestamp - Variable in class org.apache.cassandra.hints.PendingHintsInfo
- oldFormatInstance - Static variable in class org.apache.cassandra.utils.BloomFilterSerializer
- oldMetadata - Variable in class org.apache.cassandra.notifications.SSTableMetadataChanged
- oldName - Variable in class org.apache.cassandra.config.Replacement
-
Old name of the configuration parameter
- oldName() - Method in annotation type org.apache.cassandra.config.Replaces
- oldSSTableCount - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- oldType - Variable in class org.apache.cassandra.config.Replacement
-
Old type of the configuration parameter
- oldVersionSSTableCount - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Number of SSTables with old version on disk for this CF
- ON_HEAP - org.apache.cassandra.io.compress.BufferType
- onAdvance() - Method in class org.apache.cassandra.index.sai.metrics.MulticastQueryEventListeners.Multicast2BalancedTreePostingListEventListener
- onAdvance() - Method in class org.apache.cassandra.index.sai.metrics.MulticastQueryEventListeners.Multicast2TriePostingListEventListener
- onAdvance() - Method in interface org.apache.cassandra.index.sai.metrics.QueryEventListener.PostingListEventListener
-
When an individual posting lists is advanced.
- 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.schema.DefaultSchemaUpdateHandler
- onAlive(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.ActiveRepairService
- onAlive(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.disk.usage.DiskUsageBroadcaster
- onAlive(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupSession
- onAlive(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.StorageService
- onAllocatedOnHeap(long) - Method in class org.apache.cassandra.db.partitions.BTreePartitionUpdater
- onAllocatedOnHeap(long) - Method in interface org.apache.cassandra.db.rows.ColumnData.PostReconciliationFunction
- onAllocatedOnHeap(long) - Method in class org.apache.cassandra.db.rows.ColumnData.Reconciler
- onAllocatedOnHeap(long) - Method in interface org.apache.cassandra.utils.btree.UpdateFunction
- onAllocatedOnHeap(long) - Method in class org.apache.cassandra.utils.btree.UpdateFunction.Simple
- onAlterAggregate(UDAggregate, UDAggregate) - Method in interface org.apache.cassandra.schema.SchemaChangeListener
- onAlterAggregate(UDAggregate, UDAggregate) - Method in class org.apache.cassandra.transport.Server.EventNotifier
- onAlterFunction(UDFunction, UDFunction) - Method in interface org.apache.cassandra.schema.SchemaChangeListener
- onAlterFunction(UDFunction, UDFunction) - Method in class org.apache.cassandra.transport.Server.EventNotifier
- onAlterKeyspace(KeyspaceMetadata, KeyspaceMetadata) - Method in interface org.apache.cassandra.schema.SchemaChangeListener
- onAlterKeyspace(KeyspaceMetadata, KeyspaceMetadata) - Method in class org.apache.cassandra.transport.Server.EventNotifier
- onAlterTable(TableMetadata, TableMetadata, boolean) - Method in interface org.apache.cassandra.schema.SchemaChangeListener
- onAlterTable(TableMetadata, TableMetadata, boolean) - Method in class org.apache.cassandra.transport.Server.EventNotifier
- onAlterType(UserType, UserType) - Method in interface org.apache.cassandra.schema.SchemaChangeListener
- onAlterType(UserType, UserType) - Method in class org.apache.cassandra.transport.Server.EventNotifier
- onAlterView(ViewMetadata, ViewMetadata, boolean) - Method in interface 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.schema.DefaultSchemaUpdateHandler
- onChange(InetAddressAndPort, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.ActiveRepairService
- onChange(InetAddressAndPort, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.disk.usage.DiskUsageBroadcaster
- onChange(InetAddressAndPort, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.LoadBroadcaster
- onChange(InetAddressAndPort, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupSession
- onChange(InetAddressAndPort, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.StorageService
- onClose - Variable in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator.Builder
- 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(Runnable) - Method in class org.apache.cassandra.streaming.async.NettyStreamingChannel
- onClose(Runnable) - Method in interface org.apache.cassandra.streaming.StreamingChannel
- 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
- onComplete() - Method in class org.apache.cassandra.repair.state.AbstractCompletable
- onComplete() - Method in class org.apache.cassandra.repair.state.AbstractState
- onComplete(AbstractPaxosRepair, AbstractPaxosRepair.Result) - Method in interface org.apache.cassandra.service.paxos.AbstractPaxosRepair.Listener
- onComplete(AbstractPaxosRepair, AbstractPaxosRepair.Result) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosTableRepairs
- 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(UDAggregate) - Method in interface org.apache.cassandra.schema.SchemaChangeListener
- onCreateAggregate(UDAggregate) - Method in class org.apache.cassandra.transport.Server.EventNotifier
- onCreateFunction(UDFunction) - Method in interface org.apache.cassandra.schema.SchemaChangeListener
- onCreateFunction(UDFunction) - Method in class org.apache.cassandra.transport.Server.EventNotifier
- onCreateKeyspace(KeyspaceMetadata) - Method in interface org.apache.cassandra.schema.SchemaChangeListener
- onCreateKeyspace(KeyspaceMetadata) - Method in class org.apache.cassandra.transport.Server.EventNotifier
- onCreateTable(TableMetadata) - Method in interface org.apache.cassandra.schema.SchemaChangeListener
- onCreateTable(TableMetadata) - Method in class org.apache.cassandra.transport.Server.EventNotifier
- onCreateType(UserType) - Method in interface org.apache.cassandra.schema.SchemaChangeListener
- onCreateType(UserType) - Method in class org.apache.cassandra.transport.Server.EventNotifier
- onCreateView(ViewMetadata) - Method in interface 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.schema.DefaultSchemaUpdateHandler
- onDead(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.ActiveRepairService
- onDead(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.disk.usage.DiskUsageBroadcaster
- onDead(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupSession
- onDead(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.StorageService
- 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
- onDiskFormat() - Method in class org.apache.cassandra.index.sai.disk.format.Version
- OnDiskFormat - Interface in org.apache.cassandra.index.sai.disk.format
-
An interface to the on-disk format of an index.
- 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 - Variable in class org.apache.cassandra.io.util.FileHandle
- onDiskLength() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
The length in bytes of the on disk size for this SSTable.
- OnDiskOrdinalsMap - Class in org.apache.cassandra.index.sai.disk.v1.vector
- OnDiskOrdinalsMap(FileHandle, long, long) - Constructor for class org.apache.cassandra.index.sai.disk.v1.vector.OnDiskOrdinalsMap
- OnDiskOrdinalsMap.OrdinalsView - Class in org.apache.cassandra.index.sai.disk.v1.vector
- OnDiskOrdinalsMap.RowIdsView - Class in org.apache.cassandra.index.sai.disk.v1.vector
- 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.DirectIOSegment
- 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(UDAggregate) - Method in class org.apache.cassandra.auth.AuthSchemaChangeListener
- onDropAggregate(UDAggregate) - Method in interface org.apache.cassandra.schema.SchemaChangeListener
- onDropAggregate(UDAggregate) - Method in class org.apache.cassandra.transport.Server.EventNotifier
- onDropFunction(UDFunction) - Method in class org.apache.cassandra.auth.AuthSchemaChangeListener
- onDropFunction(UDFunction) - Method in interface org.apache.cassandra.schema.SchemaChangeListener
- onDropFunction(UDFunction) - Method in class org.apache.cassandra.transport.Server.EventNotifier
- onDropKeyspace(KeyspaceMetadata, boolean) - Method in class org.apache.cassandra.auth.AuthSchemaChangeListener
- onDropKeyspace(KeyspaceMetadata, boolean) - Method in interface org.apache.cassandra.schema.SchemaChangeListener
- onDropKeyspace(KeyspaceMetadata, boolean) - Method in class org.apache.cassandra.transport.Server.EventNotifier
- onDropTable(TableMetadata, boolean) - Method in class org.apache.cassandra.auth.AuthSchemaChangeListener
- onDropTable(TableMetadata, boolean) - Method in class org.apache.cassandra.db.SizeEstimatesRecorder
- onDropTable(TableMetadata, boolean) - Method in interface org.apache.cassandra.schema.SchemaChangeListener
- onDropTable(TableMetadata, boolean) - Method in class org.apache.cassandra.transport.Server.EventNotifier
- onDropType(UserType) - Method in interface org.apache.cassandra.schema.SchemaChangeListener
- onDropType(UserType) - Method in class org.apache.cassandra.transport.Server.EventNotifier
- onDropView(ViewMetadata, boolean) - Method in interface 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 - org.apache.cassandra.db.ConsistencyLevel
- ONE_GIB - Static variable in class org.apache.cassandra.io.util.FileUtils
- ONE_KIB - Static variable in class org.apache.cassandra.io.util.FileUtils
- ONE_MIB - Static variable in class org.apache.cassandra.io.util.FileUtils
- ONE_TIB - Static variable in class org.apache.cassandra.io.util.FileUtils
- oneByte(int) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- 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 asStreamSession.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(Exception) - Method in interface org.apache.cassandra.repair.messages.RepairMessage.RepairFailureCallback
- onFailure(Throwable) - Method in class org.apache.cassandra.dht.StreamStateStore
- onFailure(Throwable) - Method in class org.apache.cassandra.io.sstable.SSTableLoader
- 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(Throwable) - Method in class org.apache.cassandra.streaming.management.StreamEventJMXNotifier
- onFailure(Throwable) - Method in class org.apache.cassandra.streaming.StreamingState
- 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(InetAddressAndPort, RequestFailureReason) - Method in interface org.apache.cassandra.net.RequestCallbackWithFailure
-
Called when there is an exception on the remote node or timeout happens
- 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.FailureRecordingCallback
- onFailure(InetAddressAndPort, RequestFailureReason) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupComplete
- onFailure(InetAddressAndPort, RequestFailureReason) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupSession
- onFailure(InetAddressAndPort, RequestFailureReason) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosFinishPrepareCleanup
- onFailure(InetAddressAndPort, RequestFailureReason) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosStartPrepareCleanup
- onFailure(InetAddressAndPort, RequestFailureReason) - Method in class org.apache.cassandra.service.paxos.PaxosCommit
-
Record a failure or timeout, and maybe submit a hint to
from
- onFailure(InetAddressAndPort, RequestFailureReason) - Method in class org.apache.cassandra.service.paxos.PaxosPrepare
- onFailure(InetAddressAndPort, RequestFailureReason) - Method in class org.apache.cassandra.service.paxos.PaxosPrepareRefresh
- onFailure(InetAddressAndPort, RequestFailureReason) - Method in class org.apache.cassandra.service.paxos.PaxosPropose
- onFailure(InetAddressAndPort, RequestFailureReason) - Method in class org.apache.cassandra.service.reads.ReadCallback
- onFailure(InetAddressAndPort, RequestFailureReason) - Method in class org.apache.cassandra.service.TruncateResponseHandler
- onFailureWithMutex(InetAddressAndPort, RequestFailureReason) - Method in class org.apache.cassandra.service.FailureRecordingCallback
- onHeap - Variable in class org.apache.cassandra.utils.memory.MemtablePool
- onHeap() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator
- OnHeapGraph<T> - Class in org.apache.cassandra.index.sai.disk.v1.vector
- OnHeapGraph(AbstractType<?>, IndexWriterConfig) - Constructor for class org.apache.cassandra.index.sai.disk.v1.vector.OnHeapGraph
- OnHeapGraph(AbstractType<?>, IndexWriterConfig, boolean) - Constructor for class org.apache.cassandra.index.sai.disk.v1.vector.OnHeapGraph
- OnHeapGraph.InvalidVectorBehavior - Enum in org.apache.cassandra.index.sai.disk.v1.vector
- 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
- onInserted(Row) - Method in interface org.apache.cassandra.index.transactions.UpdateTransaction
- onIntersectionComplete(long, TimeUnit) - Method in class org.apache.cassandra.index.sai.metrics.ColumnQueryMetrics.BalancedTreeIndexMetrics
- onIntersectionComplete(long, TimeUnit) - Method in class org.apache.cassandra.index.sai.metrics.MulticastQueryEventListeners.Multicast2BalancedTreeEventListener
- onIntersectionComplete(long, TimeUnit) - Method in interface org.apache.cassandra.index.sai.metrics.QueryEventListener.BalancedTreeEventListener
-
Per-segment balanced tree index intersection time in given units.
- onIntersectionEarlyExit() - Method in class org.apache.cassandra.index.sai.metrics.ColumnQueryMetrics.BalancedTreeIndexMetrics
- onIntersectionEarlyExit() - Method in class org.apache.cassandra.index.sai.metrics.MulticastQueryEventListeners.Multicast2BalancedTreeEventListener
- onIntersectionEarlyExit() - Method in interface org.apache.cassandra.index.sai.metrics.QueryEventListener.BalancedTreeEventListener
-
When an intersection exits early due to the query shape being completely outside the min/max range.
- 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.schema.DefaultSchemaUpdateHandler
- onJoin(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.ActiveRepairService
- onJoin(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.disk.usage.DiskUsageBroadcaster
- onJoin(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.LoadBroadcaster
- onJoin(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupSession
- onJoin(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.StorageService
- 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.
- onLeaf(int, long, IntArrayList) - Method in class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreePostingsWriter
-
Called when a leaf node is hit as we traverse the packed index.
- onLeak(Object) - Method in interface org.apache.cassandra.utils.concurrent.Ref.OnLeak
- 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_PARTITION_KEY - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- 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
- onOrAfter(Version) - Method in class org.apache.cassandra.index.sai.disk.format.Version
- 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
- onPartitionClose() - Method in class org.apache.cassandra.metrics.TopPartitionTracker.TombstoneCounter
- onPartitionDeletion(DeletionTime) - Method in interface org.apache.cassandra.index.transactions.CleanupTransaction
- onPartitionDeletion(DeletionTime) - Method in interface org.apache.cassandra.index.transactions.UpdateTransaction
- onPaxosRepairComplete(Collection<Range<Token>>, Ballot) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- onPreAlterTable(TableMetadata, TableMetadata) - Method in interface org.apache.cassandra.schema.SchemaChangeListener
- onPreAlterView(ViewMetadata, ViewMetadata) - Method in interface org.apache.cassandra.schema.SchemaChangeListener
- 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
- onRangeTombstoneMarker(RangeTombstoneMarker) - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter
- onRefreshFailure(InetAddressAndPort, RequestFailureReason) - Method in class org.apache.cassandra.service.paxos.PaxosPrepare
- onRefreshSuccess(Ballot, InetAddressAndPort) - Method in class org.apache.cassandra.service.paxos.PaxosPrepare
- onRegister(StreamResultFuture) - Method in interface org.apache.cassandra.streaming.StreamManager.StreamListener
- 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.schema.DefaultSchemaUpdateHandler
- onRemove(InetAddressAndPort) - Method in class org.apache.cassandra.service.ActiveRepairService
- onRemove(InetAddressAndPort) - Method in class org.apache.cassandra.service.disk.usage.DiskUsageBroadcaster
- onRemove(InetAddressAndPort) - Method in class org.apache.cassandra.service.LoadBroadcaster
- onRemove(InetAddressAndPort) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupSession
- onRemove(InetAddressAndPort) - Method in class org.apache.cassandra.service.StorageService
- onResponse(Message<Boolean>) - Method in class org.apache.cassandra.service.paxos.v1.ProposeCallback
- onResponse(Message<Object>) - Method in class org.apache.cassandra.service.reads.repair.BlockingPartitionRepair
- onResponse(Message<Void>) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupComplete
- onResponse(Message<Void>) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupSession
- onResponse(Message<Void>) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosFinishPrepareCleanup
- onResponse(Message<ReadResponse>) - Method in class org.apache.cassandra.service.reads.ReadCallback
- onResponse(Message<TruncateResponse>) - Method in class org.apache.cassandra.service.TruncateResponseHandler
- onResponse(Message<NoPayload>) - Method in class org.apache.cassandra.service.paxos.PaxosCommit
-
Record a success response
- onResponse(Message<PaxosCleanupHistory>) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosStartPrepareCleanup
- onResponse(Message<PaxosPrepareRefresh.Response>) - Method in class org.apache.cassandra.service.paxos.PaxosPrepareRefresh
- onResponse(Message<PrepareResponse>) - Method in class org.apache.cassandra.service.paxos.v1.PrepareCallback
- 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<T>) - Method in class org.apache.cassandra.service.paxos.PaxosRequestCallback
- onResponse(Message<T>) - Method in class org.apache.cassandra.service.WriteResponseHandler
- onResponse(NoPayload, InetAddressAndPort) - Method in class org.apache.cassandra.service.paxos.PaxosCommit
- onResponse(PaxosPrepare.Response, InetAddressAndPort) - Method in class org.apache.cassandra.service.paxos.PaxosPrepare
- onResponse(PaxosPropose.Response, InetAddressAndPort) - Method in class org.apache.cassandra.service.paxos.PaxosPropose
- onResponse(T, InetAddressAndPort) - Method in class org.apache.cassandra.service.paxos.PaxosRequestCallback
- 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.schema.DefaultSchemaUpdateHandler
- onRestart(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.ActiveRepairService
- onRestart(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.disk.usage.DiskUsageBroadcaster
- onRestart(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupSession
- onRestart(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.service.StorageService
- onRow(Row) - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter
- 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.SSTableReadsListener
-
Handles notification that the specified SSTable is being scanned during a partition range query.
- onSegmentHit() - Method in class org.apache.cassandra.index.sai.metrics.ColumnQueryMetrics.BalancedTreeIndexMetrics
- onSegmentHit() - Method in class org.apache.cassandra.index.sai.metrics.ColumnQueryMetrics.TrieIndexMetrics
- onSegmentHit() - Method in class org.apache.cassandra.index.sai.metrics.MulticastQueryEventListeners.Multicast2BalancedTreeEventListener
- onSegmentHit() - Method in class org.apache.cassandra.index.sai.metrics.MulticastQueryEventListeners.Multicast2TrieIndexEventListener
- onSegmentHit() - Method in interface org.apache.cassandra.index.sai.metrics.QueryEventListener.BalancedTreeEventListener
-
When query potentially matches value range within a segment, and we need to do a traversal.
- onSegmentHit() - Method in interface org.apache.cassandra.index.sai.metrics.QueryEventListener.TrieIndexEventListener
-
When query potentially matches value range within a segment, and we need to do a traversal.
- onSessionStateUpdate(CoordinatorSession) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSessions
- onShutdown() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBase
- 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.
- onShutdown(Runnable) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBase
- onSSTableChanged(Collection<SSTableReader>, Collection<SSTableContext>, IndexValidation) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- onSSTableSelected(SSTableReader, SSTableReadsListener.SelectionReason) - Method in interface org.apache.cassandra.io.sstable.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.SSTableReadsListener
-
Handles notification that the specified SSTable has been skipped during a single partition query.
- onStartPartition(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
- onStartPartition(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter
- 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.
- onStaticRow(Row) - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter
- 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
- onSuccess(StreamState) - Method in class org.apache.cassandra.streaming.StreamingState
- 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
- onTraversalComplete(long, TimeUnit) - Method in class org.apache.cassandra.index.sai.metrics.ColumnQueryMetrics.TrieIndexMetrics
- onTraversalComplete(long, TimeUnit) - Method in class org.apache.cassandra.index.sai.metrics.MulticastQueryEventListeners.Multicast2TrieIndexEventListener
- onTraversalComplete(long, TimeUnit) - Method in interface org.apache.cassandra.index.sai.metrics.QueryEventListener.TrieIndexEventListener
-
Per-segment trie index traversal time in given units.
- 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
- onUpdate(Row) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosBallotTracker
- onUpdated(Row, Row) - Method in interface org.apache.cassandra.index.transactions.UpdateTransaction
- onUpdateMaximumPoolSize(int) - Method in interface org.apache.cassandra.concurrent.ExecutorPlus.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() - Method in class org.apache.cassandra.index.sai.disk.v1.bitpack.BlockPackedReader
- open() - Method in class org.apache.cassandra.index.sai.disk.v1.bitpack.MonotonicBlockPackedReader
- open() - Method in interface org.apache.cassandra.index.sai.disk.v1.LongArray.Factory
- open(boolean) - Method in class org.apache.cassandra.db.Slice
- open(long) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
- open(long, long) - Method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
- open(String) - Static method in class org.apache.cassandra.db.Keyspace
- open(String, SchemaProvider, boolean) - Static method in class org.apache.cassandra.db.Keyspace
- open(PrimaryKeyMap.Factory, PerColumnIndexFiles, SegmentMetadata, StorageAttachedIndex) - Static method in class org.apache.cassandra.index.sai.disk.v1.segment.IndexSegmentSearcher
- open(SSTable.Owner, Descriptor) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
- open(SSTable.Owner, Descriptor, Set<Component>, TableMetadataRef) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
- open(SSTable.Owner, Descriptor, Set<Component>, TableMetadataRef, boolean, boolean) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Open an SSTable for reading
- open(SSTable.Owner, Descriptor, TableMetadataRef) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
- open(TrieSerializer<VALUE, ? super DataOutputPlus>, DataOutputPlus) - Static method in interface org.apache.cassandra.io.tries.IncrementalTrieWriter
-
Construct a suitable trie writer.
- open(File) - Static method in class org.apache.cassandra.hints.ChecksummedDataInput
- 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.
- open(File, long, boolean) - Static method in class org.apache.cassandra.io.compress.CompressionMetadata
- open(File, File) - Static method in class org.apache.cassandra.io.util.ChecksummedRandomAccessReader
- open(CompressionParams, File) - Static method in class org.apache.cassandra.io.compress.CompressionMetadata.Writer
- openAll(SSTable.Owner, Set<Map.Entry<Descriptor, Set<Component>>>, TableMetadataRef) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
- openAndGetStore(TableMetadata) - Static method in class org.apache.cassandra.db.Keyspace
- openAndGetStore(TableMetadataRef) - Static method in class org.apache.cassandra.db.Keyspace
- openAndGetStoreIfExists(TableMetadata) - Static method in class org.apache.cassandra.db.Keyspace
- openBlockingInput(File) - Method in class org.apache.cassandra.index.sai.disk.io.IndexFileUtils
- 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
- openComponents(B, SSTable.Owner, boolean, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderLoadingBuilder
- openComponents(BigTableReader.Builder, SSTable.Owner, boolean, boolean) - Method in class org.apache.cassandra.io.sstable.format.big.BigSSTableReaderLoadingBuilder
- openComponents(BtiTableReader.Builder, SSTable.Owner, boolean, boolean) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReaderLoadingBuilder
- openCursor() - Method in class org.apache.cassandra.index.sai.disk.v1.keystore.KeyLookup
-
Opens a cursor over the keys stored in the keys file.
- openDataFile(long, StatsMetadata) - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter
- openDataReader() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- openDataReader(RateLimiter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- openDataWriter() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter.Builder
- openDataWriter() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter.Builder
- openDataWriter() - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter.Builder
- openDeletion - Variable in class org.apache.cassandra.io.sstable.format.bti.RowIndexReader.IndexInfo
- 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(Consumer<SSTableReader>) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
- openEarly(Consumer<SSTableReader>) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter
- openEarly(Consumer<SSTableReader>) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
Open the resultant SSTableReader before it has been fully written.
- openFilesPerColumnIndex() - Method in interface org.apache.cassandra.index.sai.disk.format.OnDiskFormat
-
Return the number of open per-column index files that can be open during a query.
- openFilesPerColumnIndex() - Method in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- openFilesPerSSTable() - Method in class org.apache.cassandra.index.sai.SSTableContext
- openFilesPerSSTableIndex(boolean) - Method in interface org.apache.cassandra.index.sai.disk.format.OnDiskFormat
-
Return the number of open per-SSTable files that can be open during a query.
- openFilesPerSSTableIndex(boolean) - Method in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- openFinal(SSTableReader.OpenReason) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
- openFinal(SSTableReader.OpenReason) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter
- openFinal(SSTableReader.OpenReason) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
- openFinalEarly() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter
- openFinalEarly() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter
- 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(SSTable.Owner, 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).
- openIndexFiles() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
-
open index files by checking number of
SSTableContext
andSSTableIndex
, so transient open files during validation and files that are still open for in-flight requests will not be tracked. - openIndexReader() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- openIndexWriter(SequentialWriter) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter.Builder
- openIndexWriter(SequentialWriter) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter.Builder
- openIndexWriter(SequentialWriter) - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter.Builder
- openInput(FileHandle) - Method in class org.apache.cassandra.index.sai.disk.io.IndexFileUtils
- 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.io.sstable.AbstractSSTableIterator.AbstractReader
- openMarker - Variable in class org.apache.cassandra.io.sstable.format.SortedTablePartitionWriter
- openNoValidation(Descriptor, Set<Component>, ColumnFamilyStore) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
- openNoValidation(SSTable.Owner, Descriptor, TableMetadataRef) - Static method in class org.apache.cassandra.io.sstable.format.SSTableReader
- openOutput(File) - Method in class org.apache.cassandra.index.sai.disk.io.IndexFileUtils
- openOutput(File, boolean) - Method in class org.apache.cassandra.index.sai.disk.io.IndexFileUtils
- openPartitionWriter(SequentialWriter, I) - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter.Builder
- openPartitionWriter(SequentialWriter, BigTableWriter.IndexWriter) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter.Builder
- openPartitionWriter(SequentialWriter, BtiTableWriter.IndexWriter) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter.Builder
- openPerColumnIndexFiles() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- openPerIndexInput(IndexComponent, IndexIdentifier) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- openPerIndexOutput(IndexComponent, IndexIdentifier) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- openPerIndexOutput(IndexComponent, IndexIdentifier, boolean) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- openPerSSTableInput(IndexComponent) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- openPerSSTableOutput(IndexComponent) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- openPerSSTableOutput(IndexComponent, boolean) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- openReader() - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex
- openReason - Variable in class org.apache.cassandra.io.sstable.format.SSTableReader
- openSslIsAvailable - Variable in class org.apache.cassandra.security.AbstractSslContextFactory
- openSslIsAvailable() - Static method in class org.apache.cassandra.security.SSLFactory
- openWithIndex(FileHandle) - Method in class org.apache.cassandra.io.sstable.format.big.RowIndexEntry
- openWithoutSSTables(String) - Static method in class org.apache.cassandra.db.Keyspace
- operation - Variable in class org.apache.cassandra.index.sasi.plan.Expression
- operation() - Method in class org.apache.cassandra.streaming.StreamingState
- Operation - Class in org.apache.cassandra.cql3
-
An UPDATE or DELETE operation.
- Operation - Class in org.apache.cassandra.index.sai.plan
- Operation - Class in org.apache.cassandra.index.sasi.plan
- Operation() - Constructor for class org.apache.cassandra.index.sai.plan.Operation
- 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(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Operation
- Operation.Addition - Class in org.apache.cassandra.cql3
- Operation.BooleanOperator - Enum in org.apache.cassandra.index.sai.plan
- 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.memtable.AbstractMemtable
- operationCount() - Method in interface org.apache.cassandra.db.memtable.Memtable
-
Number of "operations" (in the sense defined in
PartitionUpdate.operationCount()
) the memtable has executed. - operationCount() - Method in class org.apache.cassandra.db.memtable.ShardedSkipListMemtable
- operationCount() - Method in class org.apache.cassandra.db.memtable.TrieMemtable
- 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(char, List<String>, 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
Operation
s. - 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 - Variable in class org.apache.cassandra.db.filter.RowFilter.Expression
- operator - Variable in class org.apache.cassandra.index.sai.plan.Expression
- operator() - Method in class org.apache.cassandra.cql3.Relation
- operator() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
- Operator - Enum in org.apache.cassandra.cql3
- 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 - Variable in class org.apache.cassandra.repair.RepairSession
- optimiseStreams() - Method in class org.apache.cassandra.repair.messages.RepairOption
- OPTIMIZE_FOR - Static variable in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- OptimizeFor - Enum in org.apache.cassandra.index.sai.disk.v1.vector
-
Allows the vector index searches to be optimised for latency or recall.
- option(String, String, OpenType<?>, Function<AuditLogOptions, Object>, BiConsumer<AuditLogOptions, Object>) - Static method in class org.apache.cassandra.audit.AuditLogOptionsCompositeData.AuditLogOption
- optional - Variable in class org.apache.cassandra.config.EncryptionOptions
- optional - Variable in class org.apache.cassandra.security.AbstractSslContextFactory
- optional(FunctionParameter) - Static method in interface org.apache.cassandra.cql3.functions.FunctionParameter
- OPTIONAL - org.apache.cassandra.config.EncryptionOptions.ConfigKey
- OPTIONAL - org.apache.cassandra.config.EncryptionOptions.TlsEncryptionPolicy
- optionalFixedLength(ValueAccessor<V>, V) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- optionalSignedFixedLengthFloat(ValueAccessor<V>, V) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
Produce a source for a signed fixed-length floating-point number, also translating empty to null.
- optionalSignedFixedLengthNumber(ValueAccessor<V>, V) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
Produce a source for a signed fixed-length number, also translating empty to null.
- 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.
- optionalTasks() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- optionalTasks() - Method in class org.apache.cassandra.repair.SharedContext.Global
- optionalTasks() - Method in interface org.apache.cassandra.repair.SharedContext
- 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 - Variable in class org.apache.cassandra.io.sstable.format.AbstractSSTableFormat
- options - Variable in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- options - Variable in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- options - Variable in class org.apache.cassandra.repair.AbstractRepairTask
- options - Variable in class org.apache.cassandra.repair.state.CoordinatorState
- 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
- options() - Method in interface org.apache.cassandra.db.compaction.CompactionLogger.Strategy
- options() - Static method in class org.apache.cassandra.db.SSTableImporter.Options
- options() - Static method in interface org.apache.cassandra.io.sstable.IScrubber
- options() - Static method in interface org.apache.cassandra.io.sstable.IVerifier
- options() - Method in class org.apache.cassandra.schema.CompactionParams
-
All strategy options - excluding 'class'.
- 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(Set<String>, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.db.SSTableImporter.Options
- OPTIONS - org.apache.cassandra.auth.IRoleManager.Option
- OPTIONS - org.apache.cassandra.transport.Message.Type
- 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
- OR - org.apache.cassandra.index.sai.plan.Operation.BooleanOperator
- OR - org.apache.cassandra.index.sasi.plan.Operation.OperationType
- order(ByteOrder) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
- order(ByteOrder) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
- ORDER_IN_MILLISECOND_COLUMN_NAME - Static variable in class org.apache.cassandra.db.virtual.LogMessagesTable
- OrderedRangeContainmentChecker(Collection<Range<Token>>) - Constructor for class org.apache.cassandra.dht.Range.OrderedRangeContainmentChecker
- Ordering - Class in org.apache.cassandra.cql3
-
A single element of an ORDER BY clause.
- Ordering(Ordering.Expression, Ordering.Direction) - Constructor for class org.apache.cassandra.cql3.Ordering
- Ordering.Ann - Class in org.apache.cassandra.cql3
-
An expression used in Approximate Nearest Neighbor ordering.
- Ordering.Direction - Enum in org.apache.cassandra.cql3
- Ordering.Expression - Class in org.apache.cassandra.cql3
- Ordering.Raw - Class in org.apache.cassandra.cql3
-
Represents ANTLR's abstract syntax tree of a single element in the
ORDER BY
clause. - Ordering.Raw.Ann - Class in org.apache.cassandra.cql3
- Ordering.Raw.Expression - Interface in org.apache.cassandra.cql3
- Ordering.Raw.SingleColumn - Class in org.apache.cassandra.cql3
- Ordering.SingleColumn - Class in org.apache.cassandra.cql3
-
Represents a single column in
ORDER BY column
- 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
- OrdinalPostingList - Interface in org.apache.cassandra.index.sai.postings
- OrdinalsView() - Constructor for class org.apache.cassandra.index.sai.disk.v1.vector.OnDiskOrdinalsMap.OrdinalsView
- orFail(FailingBiConsumer<A, B>) - Static method in interface org.apache.cassandra.utils.FailingBiConsumer
- orFail(FailingConsumer<T>) - Static method in interface org.apache.cassandra.utils.FailingConsumer
- ORG_APACHE_CASSANDRA_DISABLE_MBEAN_REGISTRATION - org.apache.cassandra.config.CassandraRelevantProperties
-
This property indicates whether disable_mbean_registration is true
- 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.masking - package org.apache.cassandra.cql3.functions.masking
- 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.commitlog - package org.apache.cassandra.db.commitlog
- org.apache.cassandra.db.compaction - package org.apache.cassandra.db.compaction
- org.apache.cassandra.db.compaction.unified - package org.apache.cassandra.db.compaction.unified
- 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.guardrails - package org.apache.cassandra.db.guardrails
- 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.memtable - package org.apache.cassandra.db.memtable
- 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.tries - package org.apache.cassandra.db.tries
- 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.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.sai - package org.apache.cassandra.index.sai
- org.apache.cassandra.index.sai.analyzer - package org.apache.cassandra.index.sai.analyzer
- org.apache.cassandra.index.sai.analyzer.filter - package org.apache.cassandra.index.sai.analyzer.filter
- org.apache.cassandra.index.sai.disk - package org.apache.cassandra.index.sai.disk
- org.apache.cassandra.index.sai.disk.format - package org.apache.cassandra.index.sai.disk.format
- org.apache.cassandra.index.sai.disk.io - package org.apache.cassandra.index.sai.disk.io
- org.apache.cassandra.index.sai.disk.v1 - package org.apache.cassandra.index.sai.disk.v1
- org.apache.cassandra.index.sai.disk.v1.bbtree - package org.apache.cassandra.index.sai.disk.v1.bbtree
- org.apache.cassandra.index.sai.disk.v1.bitpack - package org.apache.cassandra.index.sai.disk.v1.bitpack
- org.apache.cassandra.index.sai.disk.v1.keystore - package org.apache.cassandra.index.sai.disk.v1.keystore
- org.apache.cassandra.index.sai.disk.v1.postings - package org.apache.cassandra.index.sai.disk.v1.postings
- org.apache.cassandra.index.sai.disk.v1.segment - package org.apache.cassandra.index.sai.disk.v1.segment
- org.apache.cassandra.index.sai.disk.v1.trie - package org.apache.cassandra.index.sai.disk.v1.trie
- org.apache.cassandra.index.sai.disk.v1.vector - package org.apache.cassandra.index.sai.disk.v1.vector
- org.apache.cassandra.index.sai.iterators - package org.apache.cassandra.index.sai.iterators
- org.apache.cassandra.index.sai.memory - package org.apache.cassandra.index.sai.memory
- org.apache.cassandra.index.sai.metrics - package org.apache.cassandra.index.sai.metrics
- org.apache.cassandra.index.sai.plan - package org.apache.cassandra.index.sai.plan
- org.apache.cassandra.index.sai.postings - package org.apache.cassandra.index.sai.postings
- org.apache.cassandra.index.sai.utils - package org.apache.cassandra.index.sai.utils
- org.apache.cassandra.index.sai.view - package org.apache.cassandra.index.sai.view
- org.apache.cassandra.index.sai.virtual - package org.apache.cassandra.index.sai.virtual
- 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.filter - package org.apache.cassandra.io.sstable.filter
- 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.format.bti - package org.apache.cassandra.io.sstable.format.bti
- org.apache.cassandra.io.sstable.indexsummary - package org.apache.cassandra.io.sstable.indexsummary
- org.apache.cassandra.io.sstable.keycache - package org.apache.cassandra.io.sstable.keycache
- org.apache.cassandra.io.sstable.metadata - package org.apache.cassandra.io.sstable.metadata
- org.apache.cassandra.io.tries - package org.apache.cassandra.io.tries
- 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.repair.state - package org.apache.cassandra.repair.state
- 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.disk.usage - package org.apache.cassandra.service.disk.usage
- 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.paxos.cleanup - package org.apache.cassandra.service.paxos.cleanup
- org.apache.cassandra.service.paxos.uncommitted - package org.apache.cassandra.service.paxos.uncommitted
- org.apache.cassandra.service.paxos.v1 - package org.apache.cassandra.service.paxos.v1
- 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.service.reads.thresholds - package org.apache.cassandra.service.reads.thresholds
- org.apache.cassandra.service.snapshot - package org.apache.cassandra.service.snapshot
- 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.bytecomparable - package org.apache.cassandra.utils.bytecomparable
- org.apache.cassandra.utils.caching - package org.apache.cassandra.utils.caching
- 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
- OS_ARCH - org.apache.cassandra.config.CassandraRelevantProperties
-
Operating system architecture.
- OS_NAME - org.apache.cassandra.config.CassandraRelevantProperties
-
Operating system name.
- OSS50 - org.apache.cassandra.utils.bytecomparable.ByteComparable.Version
- osType - Static variable in class org.apache.cassandra.utils.NativeLibrary
- otc_backlog_expiration_interval_ms - Variable in class org.apache.cassandra.config.Config
-
Deprecated.
- otc_backlog_expiration_interval_ms_default - Static variable in class org.apache.cassandra.config.Config
-
Deprecated.
- otc_coalescing_enough_coalesced_messages - Variable in class org.apache.cassandra.config.Config
-
Deprecated.
- otc_coalescing_strategy - Variable in class org.apache.cassandra.config.Config
-
Deprecated.
- otc_coalescing_window_us - Variable in class org.apache.cassandra.config.Config
-
Deprecated.
- otc_coalescing_window_us_default - Static variable in class org.apache.cassandra.config.Config
-
Deprecated.
- OTC_INTRADC_TCP_NODELAY - org.apache.cassandra.config.CassandraRelevantProperties
-
Enabled/disable TCP_NODELAY for intradc connections.
- OTCP_LARGE_MESSAGE_THRESHOLD - org.apache.cassandra.config.CassandraRelevantProperties
- OTHER - org.apache.cassandra.audit.AuditLogEntryCategory
- OTHER - org.apache.cassandra.streaming.StreamOperation
- OTHER - org.apache.cassandra.utils.NativeLibrary.OSType
- out - Variable in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
- out - Variable in class org.apache.cassandra.tools.AbstractJmxClient
- out - Variable in class org.apache.cassandra.tools.Output
- 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 - org.apache.cassandra.streaming.ProgressInfo.Direction
- 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. - OUTBOUND - org.apache.cassandra.auth.IInternodeAuthenticator.InternodeConnectionDirection
- OUTBOUND_ENCODED_KEY - org.apache.cassandra.security.PEMBasedSslContextFactory.ConfigKey
- OUTBOUND_ENCODED_KEY_PASSWORD - org.apache.cassandra.security.PEMBasedSslContextFactory.ConfigKey
- outbound_keystore - Variable in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
- OUTBOUND_KEYSTORE - org.apache.cassandra.config.EncryptionOptions.ConfigKey
- outbound_keystore_password - Variable in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
- OUTBOUND_KEYSTORE_PASSWORD - org.apache.cassandra.config.EncryptionOptions.ConfigKey
- OUTBOUND_PRECONNECT - org.apache.cassandra.auth.IInternodeAuthenticator.InternodeConnectionDirection
- 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
- OutboundConnectionInitiator.SslFallbackConnectionType - Enum 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
- outboundKeystoreContext - Variable in class org.apache.cassandra.security.FileBasedSslContextFactory
- 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
- outcome() - Method in class org.apache.cassandra.service.paxos.PaxosState.MaybePromise
- OUTER - org.apache.cassandra.cql3.functions.masking.PartialMaskingFunction.Kind
-
Masks only the first
begin
and lastend
characters. - 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
- outOfOrder - Variable in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- output - Variable in class org.apache.cassandra.tools.NodeProbe
- output - Variable in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
- output() - Method in class org.apache.cassandra.tools.NodeProbe
- 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(String, Object...) - Method in interface org.apache.cassandra.utils.OutputHandler
- Output - Class in org.apache.cassandra.tools
- Output(PrintStream, PrintStream) - Constructor for class org.apache.cassandra.tools.Output
- outputFile - Variable in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
- outputHandler - Variable in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- outputHandler - Variable in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- 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
- 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
- outWithFlags(Verb, T, Dispatcher.RequestTime, List<MessageFlag>) - Static method in class org.apache.cassandra.net.Message
- OVERFLOW - org.apache.cassandra.index.sasi.disk.TokenTreeBuilder.EntryType
- 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.
- overlapInclusionMethod - Variable in class org.apache.cassandra.db.compaction.unified.Controller
- overlapInclusionMethod() - Method in class org.apache.cassandra.db.compaction.unified.Controller
-
Return the overlap inclusion method to use when combining overlap sections into a bucket.
- 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
- overlaps(CIDR, CIDR) - Static method in class org.apache.cassandra.cql3.CIDR
- Overlaps - Class in org.apache.cassandra.utils
- Overlaps() - Constructor for class org.apache.cassandra.utils.Overlaps
- Overlaps.BucketMaker<E,B> - Interface in org.apache.cassandra.utils
- Overlaps.InclusionMethod - Enum in org.apache.cassandra.utils
- OVERLOADED - org.apache.cassandra.exceptions.ExceptionCode
- 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
- OVERRIDE_DECOMMISSION - org.apache.cassandra.config.CassandraRelevantProperties
- overrideLocalParams(CompactionParams) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
- 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
- OVERWRITE - org.apache.cassandra.io.util.File.WriteMode
- OWNED_RANGES_CHANGE - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- owner - Variable in class org.apache.cassandra.db.memtable.AbstractAllocatorMemtable
- owner() - Method in class org.apache.cassandra.io.sstable.SSTable
- ownershipRatio() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator.SubAllocator
- ownershipRatioOffHeap - Variable in class org.apache.cassandra.db.memtable.Memtable.MemoryUsage
-
Off-heap memory as ratio to permitted memtable space
- ownershipRatioOnHeap - Variable in class org.apache.cassandra.db.memtable.Memtable.MemoryUsage
-
On-heap memory as ratio to permitted memtable space
- owns - Variable in class org.apache.cassandra.tools.nodetool.HostStat
- owns() - Method in class org.apache.cassandra.utils.memory.MemtableAllocator.SubAllocator
- ownsOffHeap - Variable in class org.apache.cassandra.db.memtable.Memtable.MemoryUsage
-
Off-heap memory used in bytes
- ownsOnHeap - Variable in class org.apache.cassandra.db.memtable.Memtable.MemoryUsage
-
On-heap memory used in bytes
P
- P0 - org.apache.cassandra.db.compaction.OperationType
-
Each modification here should be also applied to
Stop.compactionType
- P0 - org.apache.cassandra.net.Verb.Priority
- P1 - org.apache.cassandra.net.Verb.Priority
- P2 - org.apache.cassandra.net.Verb.Priority
- P3 - org.apache.cassandra.net.Verb.Priority
- P4 - org.apache.cassandra.net.Verb.Priority
- P50_COL - Static variable in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsLatenciesTable
- P95_COL - Static variable in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsLatenciesTable
- P99_COL - Static variable in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsLatenciesTable
- P999_COL - Static variable in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsLatenciesTable
- pack(ByteBuffer[], int, ProtocolVersion) - Static method in class org.apache.cassandra.cql3.functions.types.CodecUtils
-
Utility method that "packs" together a list of
ByteBuffer
s containing serialized collection elements. - pack(Collection<ByteBuffer>, int) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
- pack(Collection<V>, ValueAccessor<V>, int) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
- PACKED - org.apache.cassandra.index.sasi.disk.TokenTreeBuilder.EntryType
- PackedLongsPostingList - Class in org.apache.cassandra.index.sai.disk.v1.postings
-
Adapter class for
PackedLongValues
to expose it asPostingList
. - PackedLongsPostingList(PackedLongValues) - Constructor for class org.apache.cassandra.index.sai.disk.v1.postings.PackedLongsPostingList
- pad(DataOutputPlus) - Static method in class org.apache.cassandra.io.util.PageAware
-
Pad the given output stream with zeroes until the next page boundary.
- padded(long) - Static method in class org.apache.cassandra.io.util.PageAware
-
Calculate the earliest page boundary for the given position.
- paddedPosition() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
- paddedPosition() - Method in interface org.apache.cassandra.io.util.DataOutputPlus
-
Returns the next padded position.
- paddedPosition() - Method in class org.apache.cassandra.io.util.SequentialWriter
- padToPageBoundary() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
- padToPageBoundary() - Method in interface org.apache.cassandra.io.util.DataOutputPlus
-
Pad this with zeroes until the next page boundary.
- padToPageBoundary() - Method in class org.apache.cassandra.io.util.SequentialWriter
- PAGE_SIZE - Static variable in class org.apache.cassandra.io.util.PageAware
- page_size_fail_threshold - Variable in class org.apache.cassandra.config.Config
- PAGE_SIZE_SHIFT - Static variable in class org.apache.cassandra.io.util.PageAware
- page_size_warn_threshold - Variable in class org.apache.cassandra.config.Config
- PageAware - Class in org.apache.cassandra.io.util
- PageAware() - Constructor for class org.apache.cassandra.io.util.PageAware
- pageLimit(long) - Static method in class org.apache.cassandra.io.util.PageAware
-
Calculate the end of the page identified by the given position.
- pageNum(long) - Static method in class org.apache.cassandra.io.util.PageAware
-
Given a position relative to the start of a number of pages, determine the exact page number this position falls into.
- pageSize - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the number of elements returned within page.
- pageSize() - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
- pageStart(long) - Static method in class org.apache.cassandra.io.util.PageAware
-
Calculate the start of the page that contains the given position.
- 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
- PARALLEL - org.apache.cassandra.repair.RepairParallelism
-
All nodes at the same time
- 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) - 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 - Variable in class org.apache.cassandra.config.ParameterizedClass
- parameters - Variable in class org.apache.cassandra.cql3.functions.FunctionFactory
-
The accepted parameters.
- parameters - Variable in class org.apache.cassandra.cql3.statements.SelectStatement
- parameters - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
- parameters - Variable in class org.apache.cassandra.io.compress.CompressionMetadata
- parameters - Variable in class org.apache.cassandra.security.AbstractSslContextFactory
- parameters() - Method in class org.apache.cassandra.db.streaming.CompressionInfo
-
Returns the compression parameters.
- Parameters(List<Ordering.Raw>, List<Selectable.Raw>, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.statements.SelectStatement.Parameters
- PARAMETERS - Static variable in class org.apache.cassandra.config.ParameterizedClass
- parameterTypes() - Method in class org.apache.cassandra.tools.JMXTool.Operation
- params - Variable in class org.apache.cassandra.schema.KeyspaceMetadata
- params - Variable in class org.apache.cassandra.schema.TableMetadata
- params() - Method in class org.apache.cassandra.net.Message.Header
- params(TableParams) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- 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.config.Replacement
-
Currently we use Config class
- parent - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
- parent() - Method in class org.apache.cassandra.io.util.File
- PARENT_REPAIR_HISTORY - Static variable in class org.apache.cassandra.schema.SystemDistributedKeyspace
- PARENT_REPAIR_STATUS_CACHE_SIZE - org.apache.cassandra.config.CassandraRelevantProperties
- PARENT_REPAIR_STATUS_EXPIRY_SECONDS - org.apache.cassandra.config.CassandraRelevantProperties
- parentPath() - Method in class org.apache.cassandra.io.util.File
- 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.state.SessionState
- parentRepairSession() - Method in class org.apache.cassandra.repair.messages.CleanupMessage
- parentRepairSession() - Method in class org.apache.cassandra.repair.messages.FailSession
- parentRepairSession() - Method in class org.apache.cassandra.repair.messages.FinalizeCommit
- parentRepairSession() - Method in class org.apache.cassandra.repair.messages.FinalizePromise
- parentRepairSession() - Method in class org.apache.cassandra.repair.messages.FinalizePropose
- parentRepairSession() - Method in class org.apache.cassandra.repair.messages.PrepareConsistentRequest
- parentRepairSession() - Method in class org.apache.cassandra.repair.messages.PrepareConsistentResponse
- parentRepairSession() - Method in class org.apache.cassandra.repair.messages.PrepareMessage
- parentRepairSession() - Method in class org.apache.cassandra.repair.messages.RepairMessage
- ParentRepairSession(InetAddressAndPort, List<ColumnFamilyStore>, Collection<Range<Token>>, boolean, long, boolean, PreviewKind) - Constructor for class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
- parentRepairSessionCount() - Method in class org.apache.cassandra.service.ActiveRepairService
- 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 theActiveRepairService
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() - Method in class org.apache.cassandra.db.marshal.TypeParser
-
Parse an AbstractType from current position of this parser.
- parse(CharSequence) - Static method in class org.apache.cassandra.db.marshal.TypeParser
- 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) - Method in class org.apache.cassandra.cql3.functions.types.VectorCodec
- 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(String) - Static method in class org.apache.cassandra.index.sai.disk.format.Version
- parse(String...) - Static method in class org.apache.cassandra.repair.consistent.admin.SchemaArgsParser
- parse(String, String) - Static method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement
- parse(String, String, Types) - Static method in class org.apache.cassandra.schema.CQLTypeParser
- parse(String, SSTableFormat<?, ?>) - Static method in class org.apache.cassandra.io.sstable.Component
-
Parse the component part of a sstable filename into a
Component
object. - parse(String, QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
- 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(List<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(CqlParser) - Method in interface org.apache.cassandra.cql3.CQLFragmentParser.CQLParserFunction
- parse(TableMetadata, String) - Static method in class org.apache.cassandra.index.TargetParser
- parse(TableMetadata, IndexMetadata) - Static method in class org.apache.cassandra.index.TargetParser
- parseAndPrepare(String, ClientState, boolean) - Static method in class org.apache.cassandra.cql3.QueryProcessor
- 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. - parseBoolean(String, String) - Static method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
- 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(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
- Parsed(BatchStatement.Type, Attributes.Raw, List<ModificationStatement.Parsed>) - Constructor for class org.apache.cassandra.cql3.statements.BatchStatement.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
- parseDouble(String, String) - Static method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
- 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
- parseHumanReadable(String, String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Parse a human-readable value printed using one of the methods above.
- parseHumanReadableBytes(String) - Static method in class org.apache.cassandra.utils.FBUtilities
- parseInt(String, String) - Static method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
- parseLong(String, int, int) - Static method in class org.apache.cassandra.utils.Hex
- 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
- parseOptionMap(Supplier<String>, List<String>) - Static method in class org.apache.cassandra.tools.nodetool.Repair
- parsePartitionKeys(List<String>) - Method in class org.apache.cassandra.tools.NodeTool.NodeToolCmd
- parsePercent(String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Parse a double where both a direct value and a percentage are accepted.
- parseRanges(String, IPartitioner) - Static method in class org.apache.cassandra.repair.messages.RepairOption
- parseScalingParameter(String) - Static method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- parseScalingParameters(String) - Static method in class org.apache.cassandra.db.compaction.unified.Controller
- parseStatement(String) - 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, ClientState) - 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).
- Partial() - Constructor for class org.apache.cassandra.config.RetrySpec.Partial
- partialApplication(ProtocolVersion, List<ByteBuffer>) - Method in interface org.apache.cassandra.cql3.functions.ScalarFunction
-
Does a partial application of the function.
- partialArgumentTypes() - Method in class org.apache.cassandra.cql3.functions.masking.ColumnMask
- partialArgumentValues - Variable in class org.apache.cassandra.cql3.functions.masking.ColumnMask
-
The values of the arguments of the partially applied masking function.
- partialArgumentValues() - Method in class org.apache.cassandra.cql3.functions.masking.ColumnMask
- 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
- PartialMaskingFunction - Class in org.apache.cassandra.cql3.functions.masking
-
A
MaskingFunction
applied to aStringType
value that, depending onPartialMaskingFunction.Kind
: Replaces each character between the supplied positions by the supplied padding character. - PartialMaskingFunction.Kind - Enum in org.apache.cassandra.cql3.functions.masking
- PartialScalarFunction - Interface in org.apache.cassandra.cql3.functions
-
A partial application of a function.
- 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 - Variable in class org.apache.cassandra.repair.messages.PrepareConsistentRequest
- participants - Variable in class org.apache.cassandra.repair.RepairCoordinator.NeighborsAndRanges
- PARTICIPANTS - Static variable in class org.apache.cassandra.repair.consistent.LocalSessionInfo
- PARTICIPANTS_WP - Static variable in class org.apache.cassandra.repair.consistent.LocalSessionInfo
- participate(TimeUUID) - Method in class org.apache.cassandra.service.ActiveRepairService
- participates() - Method in class org.apache.cassandra.service.ActiveRepairService
- ParticipateState - Class in org.apache.cassandra.repair.state
- ParticipateState(Clock, InetAddressAndPort, PrepareMessage) - Constructor for class org.apache.cassandra.repair.state.ParticipateState
- ParticipateState.Job - Class in org.apache.cassandra.repair.state
- ParticipateState.Job.State - Enum in org.apache.cassandra.repair.state
- ParticipateState.Phase - Class in org.apache.cassandra.repair.state
- ParticipateState.RegisterStatus - Enum in org.apache.cassandra.repair.state
- 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_denylist_enabled - Variable in class org.apache.cassandra.config.Config
-
This feature allows denying access to operations on certain key partitions, intended for use by operators to provide another tool to manage cluster health vs application access.
- PARTITION_DENYLIST_TABLE - Static variable in class org.apache.cassandra.schema.SystemDistributedKeyspace
- PARTITION_INDEX - Static variable in class org.apache.cassandra.io.sstable.format.bti.BtiFormat.Components
- PARTITION_INDEX - Static variable in class org.apache.cassandra.io.sstable.format.bti.BtiFormat.Components.Types
- PARTITION_INDEX_LOOKUP - org.apache.cassandra.io.sstable.SSTableReadsListener.SkippingReason
- PARTITION_KEY - org.apache.cassandra.schema.ColumnMetadata.Kind
- PARTITION_KEY_BLOCK_OFFSETS - org.apache.cassandra.index.sai.disk.format.IndexComponent
-
Encoded sequence of offsets to partition key blocks
- PARTITION_KEY_BLOCKS - org.apache.cassandra.index.sai.disk.format.IndexComponent
-
Prefix-compressed blocks of partition keys used for rowId to partition key lookups
- PARTITION_KEY_INDEX_FUNCTIONS - Static variable in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
- partition_keys_in_select_fail_threshold - Variable in class org.apache.cassandra.config.Config
- partition_keys_in_select_warn_threshold - Variable in class org.apache.cassandra.config.Config
- PARTITION_MESSAGE_LIMIT - Static variable in exception org.apache.cassandra.db.MutationExceededMaxSizeException
- PARTITION_RANGE - org.apache.cassandra.db.ReadCommand.Kind
- partition_size_fail_threshold - Variable in class org.apache.cassandra.config.Config
- partition_size_warn_threshold - Variable in class org.apache.cassandra.config.Config
- PARTITION_TO_SIZE - org.apache.cassandra.index.sai.disk.format.IndexComponent
-
An on-disk block packed index mapping partitionIds to the number of rows for the partition.
- partition_tombstones_fail_threshold - Variable in class org.apache.cassandra.config.Config
- partition_tombstones_warn_threshold - Variable in class org.apache.cassandra.config.Config
- partitionCount() - Method in interface org.apache.cassandra.db.memtable.Memtable
-
Number of partitions stored in the memtable
- partitionCount() - Method in class org.apache.cassandra.db.memtable.ShardedSkipListMemtable
- partitionCount() - Method in class org.apache.cassandra.db.memtable.SkipListMemtable
- partitionCount() - Method in class org.apache.cassandra.db.memtable.TrieMemtable
- partitionCount() - Method in interface org.apache.cassandra.io.sstable.format.SSTableWriter.SSTableSizeParameters
- 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
- partitionDeletion - Variable in class org.apache.cassandra.index.sai.utils.PartitionInfo
- PartitionDenylist - Class in org.apache.cassandra.schema
-
PartitionDenylist uses the system_distributed.partition_denylist table to maintain a list of denylisted partition keys for each keyspace/table.
- PartitionDenylist() - Constructor for class org.apache.cassandra.schema.PartitionDenylist
- PartitionDenylistTable - Static variable in class org.apache.cassandra.schema.SystemDistributedKeyspace
- 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 - 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.
- partitioner(IPartitioner) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- PARTITIONER - org.apache.cassandra.config.CassandraRelevantProperties
- 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
- PartitionerDefinedOrder(IPartitioner, AbstractType<?>) - Constructor for class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
- PartitionIndex - Class in org.apache.cassandra.io.sstable.format.bti
-
This class holds the partition index as an on-disk trie mapping unique prefixes of decorated keys to: data file position if the partition is small enough to not need an index row index file position if the partition has a row index plus the last 8 bits of the key's filter hash which is used to filter out mismatched keys without reading the key To avoid having to create an object to carry the result, the two are distinguished by sign.
- PartitionIndex(FileHandle, long, long, DecoratedKey, DecoratedKey) - Constructor for class org.apache.cassandra.io.sstable.format.bti.PartitionIndex
- PartitionIndex.Acceptor<ArgType,ResultType> - Interface in org.apache.cassandra.io.sstable.format.bti
- PartitionIndex.IndexPosIterator - Class in org.apache.cassandra.io.sstable.format.bti
-
Iterator of index positions covered between two keys.
- PartitionIndex.Reader - Class in org.apache.cassandra.io.sstable.format.bti
-
Provides methods to read the partition index trie.
- PartitionInfo - Class in org.apache.cassandra.index.sai.utils
- PartitionInfo(DecoratedKey, Row) - Constructor for class org.apache.cassandra.index.sai.utils.PartitionInfo
- PartitionInfo(DecoratedKey, Row, DeletionTime, EncodingStats) - Constructor for class org.apache.cassandra.index.sai.utils.PartitionInfo
- partitionIterator(ColumnFilter, DataRange, SSTableReadsListener) - Method in class org.apache.cassandra.db.memtable.ShardedSkipListMemtable
- partitionIterator(ColumnFilter, DataRange, SSTableReadsListener) - Method in class org.apache.cassandra.db.memtable.SkipListMemtable
- partitionIterator(ColumnFilter, DataRange, SSTableReadsListener) - Method in class org.apache.cassandra.db.memtable.TrieMemtable
- partitionIterator(ColumnFilter, DataRange, SSTableReadsListener) - Method in interface org.apache.cassandra.db.rows.UnfilteredSource
-
Returns a partition iterator for the given data range.
- partitionIterator(ColumnFilter, DataRange, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- partitionIterator(ColumnFilter, DataRange, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- 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 - Variable in class org.apache.cassandra.db.partitions.AbstractBTreePartition
- partitionKey - Variable in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
- partitionKey - Variable in class org.apache.cassandra.db.SinglePartitionReadCommand
- partitionKey - Variable in class org.apache.cassandra.service.pager.PagingState
- 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.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() - 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 interface 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 interface org.apache.cassandra.index.sai.utils.PrimaryKey
-
Returns the
DecoratedKey
representing the partition key of thePrimaryKey
. - partitionKey() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator
- partitionKey() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
- partitionKey() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosRepair
- partitionKeyAsClusteringComparator() - Method in class org.apache.cassandra.schema.TableMetadata
- partitionKeyAsCQLLiteral(ByteBuffer) - Method in class org.apache.cassandra.schema.TableMetadata
-
Returns a string representation of a partition in a CQL-friendly format.
- partitionKeyColumn(String, String, String, AbstractType<?>, int) - Static method in class org.apache.cassandra.schema.ColumnMetadata
- partitionKeyColumn(TableMetadata, ByteBuffer, 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
- partitionKeyCursor - Variable in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap
- partitionKeyFromComparableBytes(ByteSource) - Method in class org.apache.cassandra.index.sai.utils.PrimaryKey.Factory
-
Create a
DecoratedKey
from aByteSource
. - 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
- partitionKeyReader - Variable in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap.Factory
- 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.
- partitionKeysInSelect - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the number of partition keys in the IN clause.
- partitionKeysSize() - Method in interface org.apache.cassandra.io.sstable.format.SSTableWriter.SSTableSizeParameters
- partitionKeyType - Variable in class org.apache.cassandra.schema.TableMetadata
- partitionLevelDeletion - Variable in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
- partitionLevelDeletion - Variable in class org.apache.cassandra.io.sstable.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() - 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 interface 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.AbstractSSTableIterator
- partitionLevelDeletion() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
- partitionOrdering - Static variable in class org.apache.cassandra.dht.Murmur3Partitioner
- partitionOrdering - Static variable in class org.apache.cassandra.dht.RandomPartitioner
- partitionOrdering() - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
- partitionOrdering() - Method in interface org.apache.cassandra.dht.IPartitioner
-
Deprecated.See CASSANDRA-17698
- partitionOrdering() - Method in class org.apache.cassandra.dht.LocalPartitioner
- partitionOrdering() - Method in class org.apache.cassandra.dht.Murmur3Partitioner
- partitionOrdering() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
- partitionOrdering() - Method in class org.apache.cassandra.dht.RandomPartitioner
- partitionOrdering(AbstractType<?>) - Method in interface org.apache.cassandra.dht.IPartitioner
-
Abstract type that orders the same way as DecoratedKeys provided by this partitioner.
- partitionOrdering(AbstractType<?>) - Method in class org.apache.cassandra.dht.Murmur3Partitioner
- partitionOrdering(AbstractType<?>) - 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.
- PartitionRangeReadCommand.VirtualTablePartitionRangeReadCommand - Class in org.apache.cassandra.db
- 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, Dispatcher.RequestTime) - 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
- partitionSize - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the size of a partition.
- 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
- partitionsProcessed - Variable in class org.apache.cassandra.repair.state.ValidationState
- partitionsRead - Variable in class org.apache.cassandra.index.sai.QueryContext
- 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
- partitionTombstones - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the number of rows of a partition.
- 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
- partitionWriter - Variable in class org.apache.cassandra.io.sstable.format.SortedTableWriter
- 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.security.FileBasedSslContextFactory.FileBasedStoreContext
- password - Variable in class org.apache.cassandra.security.PEMBasedSslContextFactory.PEMBasedKeyStoreContext
- password - Variable in class org.apache.cassandra.tools.AbstractJmxClient
- PASSWORD - org.apache.cassandra.auth.IRoleManager.Option
- PASSWORD_KEY - Static variable in class org.apache.cassandra.auth.PasswordAuthenticator
- PASSWORD_TOKEN - Static variable in class org.apache.cassandra.cql3.PasswordObfuscator
- 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.CredentialsCache - Class in org.apache.cassandra.auth
- PasswordAuthenticator.CredentialsCacheMBean - Interface in org.apache.cassandra.auth
- passwordMatchesIfPresent(String) - Method in class org.apache.cassandra.security.FileBasedSslContextFactory.FileBasedStoreContext
- 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 - 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.metrics.ThreadPoolMetrics
- path - Variable in class org.apache.cassandra.utils.binlog.BinLog
- 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() - Method in class org.apache.cassandra.io.util.File
- path() - Method in class org.apache.cassandra.io.util.FileHandle
- path(Path) - Method in class org.apache.cassandra.utils.binlog.BinLog.Builder
- pathSeparator() - Static method in class org.apache.cassandra.io.util.File
- pathsHash - Variable in class org.apache.cassandra.tools.nodetool.stats.DataPathsHolder
- PathUtils - Class in org.apache.cassandra.io.util
-
Vernacular: tryX means return false or 0L on any failure; XIfNotY means propagate any exceptions besides those caused by Y This class tries to apply uniform IOException handling, and does not propagate IOException except for NoSuchFileException.
- PathUtils.IOConsumer - Interface in org.apache.cassandra.io.util
- PathUtils.IOToLongFunction<V> - Interface in org.apache.cassandra.io.util
- 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 - Class in org.apache.cassandra.service.paxos
-
This class serves as an entry-point to Cassandra's implementation of Paxos Consensus.
- Paxos() - Constructor for class org.apache.cassandra.service.paxos.Paxos
- PAXOS - Static variable in class org.apache.cassandra.db.SystemKeyspace
- paxos_cache_size - Variable in class org.apache.cassandra.config.Config
- PAXOS_CLEANUP_SESSION_TIMEOUT_SECONDS - org.apache.cassandra.config.CassandraRelevantProperties
- PAXOS_COMMIT_REQ - org.apache.cassandra.net.Verb
- PAXOS_COMMIT_RSP - org.apache.cassandra.net.Verb
- paxos_contention_max_wait - Variable in class org.apache.cassandra.config.Config
- paxos_contention_min_delta - Variable in class org.apache.cassandra.config.Config
- paxos_contention_min_wait - Variable in class org.apache.cassandra.config.Config
- paxos_contention_wait_randomizer - Variable in class org.apache.cassandra.config.Config
- PAXOS_DISABLE_COORDINATOR_LOCKING - org.apache.cassandra.config.CassandraRelevantProperties
- PAXOS_LOG_TTL_LINEARIZABILITY_VIOLATIONS - org.apache.cassandra.config.CassandraRelevantProperties
- PAXOS_MODERN_RELEASE - org.apache.cassandra.config.CassandraRelevantProperties
- paxos_on_linearizability_violations - Variable in class org.apache.cassandra.config.Config
- PAXOS_ONLY_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
- PAXOS_PREPARE_REQ - org.apache.cassandra.net.Verb
- PAXOS_PREPARE_RSP - org.apache.cassandra.net.Verb
- PAXOS_PROPOSE_REQ - org.apache.cassandra.net.Verb
- PAXOS_PROPOSE_RSP - org.apache.cassandra.net.Verb
- paxos_purge_grace_period - Variable in class org.apache.cassandra.config.Config
-
A safety margin when purging paxos state information that has been safely replicated to a quorum.
- PAXOS_REPAIR - org.apache.cassandra.concurrent.Stage
- PAXOS_REPAIR_ALLOW_MULTIPLE_PENDING_UNSAFE - org.apache.cassandra.config.CassandraRelevantProperties
- paxos_repair_enabled - Variable in class org.apache.cassandra.config.Config
-
Enable/disable paxos repair.
- PAXOS_REPAIR_HISTORY - Static variable in class org.apache.cassandra.db.SystemKeyspace
- PAXOS_REPAIR_ON_TOPOLOGY_CHANGE_RETRIES - org.apache.cassandra.config.CassandraRelevantProperties
- PAXOS_REPAIR_ON_TOPOLOGY_CHANGE_RETRY_DELAY_SECONDS - org.apache.cassandra.config.CassandraRelevantProperties
- paxos_repair_parallelism - Variable in class org.apache.cassandra.config.Config
-
The number of keys we may simultaneously attempt to finish incomplete paxos operations for.
- PAXOS_REPAIR_RETRY_TIMEOUT_IN_MS - org.apache.cassandra.config.CassandraRelevantProperties
- PAXOS_REPAIR_STATE - Static variable in class org.apache.cassandra.db.SystemKeyspace
- paxos_state_purging - Variable in class org.apache.cassandra.config.Config
-
See
Config.PaxosStatePurging
default is legacy. - paxos_topology_repair_no_dc_checks - Variable in class org.apache.cassandra.config.Config
-
If true, paxos topology change repair only requires a global quorum of live nodes.
- paxos_topology_repair_strict_each_quorum - Variable in class org.apache.cassandra.config.Config
-
If true, a quorum will be required for the global and local quorum checks.
- PAXOS_USE_SELF_EXECUTION - org.apache.cassandra.config.CassandraRelevantProperties
- paxos_variant - Variable in class org.apache.cassandra.config.Config
-
See
Config.PaxosVariant
. - Paxos.Async<Result> - Interface in org.apache.cassandra.service.paxos
- PAXOS2_CLEANUP_COMPLETE_REQ - org.apache.cassandra.net.Verb
- PAXOS2_CLEANUP_COMPLETE_RSP - org.apache.cassandra.net.Verb
- PAXOS2_CLEANUP_FINISH_PREPARE_REQ - org.apache.cassandra.net.Verb
- PAXOS2_CLEANUP_FINISH_PREPARE_RSP - org.apache.cassandra.net.Verb
- PAXOS2_CLEANUP_REQ - org.apache.cassandra.net.Verb
- PAXOS2_CLEANUP_RSP - org.apache.cassandra.net.Verb
- PAXOS2_CLEANUP_RSP2 - org.apache.cassandra.net.Verb
- PAXOS2_CLEANUP_START_PREPARE_REQ - org.apache.cassandra.net.Verb
- PAXOS2_CLEANUP_START_PREPARE_RSP - org.apache.cassandra.net.Verb
- PAXOS2_COMMIT_AND_PREPARE_REQ - org.apache.cassandra.net.Verb
- PAXOS2_COMMIT_AND_PREPARE_RSP - org.apache.cassandra.net.Verb
- PAXOS2_COMMIT_REMOTE_REQ - org.apache.cassandra.net.Verb
- PAXOS2_COMMIT_REMOTE_RSP - org.apache.cassandra.net.Verb
- PAXOS2_PREPARE_REFRESH_REQ - org.apache.cassandra.net.Verb
- PAXOS2_PREPARE_REFRESH_RSP - org.apache.cassandra.net.Verb
- PAXOS2_PREPARE_REQ - org.apache.cassandra.net.Verb
- PAXOS2_PREPARE_RSP - org.apache.cassandra.net.Verb
- PAXOS2_PROPOSE_REQ - org.apache.cassandra.net.Verb
- PAXOS2_PROPOSE_RSP - org.apache.cassandra.net.Verb
- PAXOS2_REPAIR_REQ - org.apache.cassandra.net.Verb
- PAXOS2_REPAIR_RSP - org.apache.cassandra.net.Verb
- PaxosBallotTracker - Class in org.apache.cassandra.service.paxos.uncommitted
-
Tracks the highest paxos ballot we've seen, and the lowest ballot we can accept.
- PaxosCleanup - Class in org.apache.cassandra.service.paxos.cleanup
- PaxosCleanup(SharedContext, Collection<InetAddressAndPort>, TableMetadata, Collection<Range<Token>>, boolean, Executor) - Constructor for class org.apache.cassandra.service.paxos.cleanup.PaxosCleanup
- PaxosCleanupComplete - Class in org.apache.cassandra.service.paxos.cleanup
- PaxosCleanupComplete.Request - Class in org.apache.cassandra.service.paxos.cleanup
- PaxosCleanupHistory - Class in org.apache.cassandra.service.paxos.cleanup
- PaxosCleanupHistory(TableId, Ballot, PaxosRepairHistory) - Constructor for class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupHistory
- PaxosCleanupLocalCoordinator - Class in org.apache.cassandra.service.paxos.cleanup
- PaxosCleanupRequest - Class in org.apache.cassandra.service.paxos.cleanup
- PaxosCleanupRequest(UUID, TableId, Collection<Range<Token>>) - Constructor for class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupRequest
- PaxosCleanupResponse - Class in org.apache.cassandra.service.paxos.cleanup
- PaxosCleanupResponse(UUID, boolean, String) - Constructor for class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupResponse
- PaxosCleanupSession - Class in org.apache.cassandra.service.paxos.cleanup
- PaxosCommit<OnDone extends java.util.function.Consumer<? super org.apache.cassandra.service.paxos.PaxosCommit.Status>> - Class in org.apache.cassandra.service.paxos
- PaxosCommit(Commit.Agreed, boolean, ConsistencyLevel, ConsistencyLevel, Paxos.Participants, OnDone) - Constructor for class org.apache.cassandra.service.paxos.PaxosCommit
- PaxosCommit.RequestHandler - Class in org.apache.cassandra.service.paxos
- PaxosCommitAndPrepare - Class in org.apache.cassandra.service.paxos
- PaxosCommitAndPrepare() - Constructor for class org.apache.cassandra.service.paxos.PaxosCommitAndPrepare
- PaxosCommitAndPrepare.RequestHandler - Class in org.apache.cassandra.service.paxos
- PaxosCommitAndPrepare.RequestSerializer - Class in org.apache.cassandra.service.paxos
- PaxosFinishPrepareCleanup - Class in org.apache.cassandra.service.paxos.cleanup
- PaxosKeyState - Class in org.apache.cassandra.service.paxos.uncommitted
- PaxosKeyState(TableId, DecoratedKey, Ballot, boolean) - Constructor for class org.apache.cassandra.service.paxos.uncommitted.PaxosKeyState
- PaxosMetrics - Class in org.apache.cassandra.metrics
- PaxosMetrics() - Constructor for class org.apache.cassandra.metrics.PaxosMetrics
- paxosOnLinearizabilityViolations() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- paxosOnly - Variable in class org.apache.cassandra.repair.RepairSession
- paxosOnly() - Method in class org.apache.cassandra.repair.messages.RepairOption
- PaxosOperationLock - Interface in org.apache.cassandra.service.paxos
- PaxosPrepare - Class in org.apache.cassandra.service.paxos
-
Perform one paxos "prepare" attempt, with various optimisations.
- PaxosPrepare.RequestHandler - Class in org.apache.cassandra.service.paxos
- PaxosPrepare.RequestSerializer - Class in org.apache.cassandra.service.paxos
- PaxosPrepare.ResponseSerializer - Class in org.apache.cassandra.service.paxos
- PaxosPrepareRefresh - Class in org.apache.cassandra.service.paxos
-
Nodes that have promised in response to our prepare, may be missing the latestCommit, meaning we cannot be sure the prior round has been committed to the necessary quorum of participants, so that it will be visible to future quorums.
- PaxosPrepareRefresh(Ballot, Paxos.Participants, Commit.Committed, PaxosPrepareRefresh.Callbacks) - Constructor for class org.apache.cassandra.service.paxos.PaxosPrepareRefresh
- PaxosPrepareRefresh.RequestHandler - Class in org.apache.cassandra.service.paxos
- PaxosPrepareRefresh.RequestSerializer - Class in org.apache.cassandra.service.paxos
- PaxosPrepareRefresh.ResponseSerializer - Class in org.apache.cassandra.service.paxos
- PaxosPropose<OnDone extends java.util.function.Consumer<? super org.apache.cassandra.service.paxos.PaxosPropose.Status>> - Class in org.apache.cassandra.service.paxos
-
In waitForNoSideEffect mode, we will not return failure to the caller until we have received a complete set of refusal responses, or at least one accept, indicating (respectively) that we have had no side effect, or that we cannot know if we our proposal produced a side effect.
- PaxosPropose.RequestHandler - Class in org.apache.cassandra.service.paxos
-
The proposal request handler, i.e.
- PaxosPropose.RequestSerializer - Class in org.apache.cassandra.service.paxos
- PaxosPropose.ResponseSerializer - Class in org.apache.cassandra.service.paxos
- PaxosRepair - Class in org.apache.cassandra.service.paxos
-
Facility to finish any in-progress paxos transaction, and ensure that a quorum of nodes agree on the most recent operation.
- PaxosRepair.RequestHandler - Class in org.apache.cassandra.service.paxos
-
The proposal request handler, i.e.
- PaxosRepair.RequestSerializer - Class in org.apache.cassandra.service.paxos
- PaxosRepair.ResponseSerializer - Class in org.apache.cassandra.service.paxos
- paxosRepairEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- PaxosRepairHistory - Class in org.apache.cassandra.service.paxos
- PaxosRepairHistory.Searcher - Class in org.apache.cassandra.service.paxos
- paxosRepairState() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- paxosRepairState() - Method in class org.apache.cassandra.repair.SharedContext.Global
- paxosRepairState() - Method in interface org.apache.cassandra.repair.SharedContext
- PaxosRepairState - Class in org.apache.cassandra.service.paxos.cleanup
-
Tracks the state of paxos repair cleanup work
- PaxosRepairState(SharedContext) - Constructor for class org.apache.cassandra.service.paxos.cleanup.PaxosRepairState
- PaxosRequestCallback<T> - Class in org.apache.cassandra.service.paxos
- PaxosRequestCallback() - Constructor for class org.apache.cassandra.service.paxos.PaxosRequestCallback
- PaxosRows - Class in org.apache.cassandra.service.paxos.uncommitted
- PaxosStartPrepareCleanup - Class in org.apache.cassandra.service.paxos.cleanup
-
Determines the highest ballot we should attempt to repair
- PaxosStartPrepareCleanup.Request - Class in org.apache.cassandra.service.paxos.cleanup
- PaxosStartPrepareCleanup.RequestSerializer - Class in org.apache.cassandra.service.paxos.cleanup
- PaxosState - Class in org.apache.cassandra.service.paxos
-
We save to memory the result of each operation before persisting to disk, however each operation that performs the update does not return a result to the coordinator until the result is fully persisted.
- PaxosState.Key - Class in org.apache.cassandra.service.paxos
- PaxosState.MaybePromise - Class in org.apache.cassandra.service.paxos
- PaxosState.MaybePromise.Outcome - Enum in org.apache.cassandra.service.paxos
- PaxosState.Snapshot - Class in org.apache.cassandra.service.paxos
- PaxosState.UnsafeSnapshot - Class in org.apache.cassandra.service.paxos
- paxosStatePurging() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- PaxosStateTracker - Class in org.apache.cassandra.service.paxos.uncommitted
-
Tracks uncommitted and ballot high/low bounds
- PaxosStateTracker(PaxosUncommittedTracker, PaxosBallotTracker, boolean) - Constructor for class org.apache.cassandra.service.paxos.uncommitted.PaxosStateTracker
- PaxosTableRepairs - Class in org.apache.cassandra.service.paxos.cleanup
-
Coordinates repairs on a given key to prevent multiple repairs being scheduled for a single key
- PaxosTableRepairs() - Constructor for class org.apache.cassandra.service.paxos.cleanup.PaxosTableRepairs
- PaxosUncommittedIndex - Class in org.apache.cassandra.service.paxos.uncommitted
-
A 2i implementation made specifically for system.paxos that listens for changes to paxos state by interpreting mutations against system.paxos and updates the uncommitted tracker accordingly.
- PaxosUncommittedIndex(ColumnFamilyStore, IndexMetadata) - Constructor for class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- PaxosUncommittedTracker - Class in org.apache.cassandra.service.paxos.uncommitted
-
Tracks uncommitted paxos operations to enable operation completion as part of repair by returning an iterator of partition keys with uncommitted paxos operations (and their consistency levels) for a given table and token range(s) There are 2 parts to the uncommitted states it tracks: operations flushed to disk, and updates still in memory.
- PaxosUncommittedTracker(File) - Constructor for class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker
- PaxosUncommittedTracker(File, ImmutableMap<TableId, UncommittedTableData>) - Constructor for class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker
- PaxosUncommittedTracker.UpdateSupplier - Interface in org.apache.cassandra.service.paxos.uncommitted
- paxoTopologyRepairNoDcChecks() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- paxoTopologyRepairStrictEachQuorum() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- payload - Variable in class org.apache.cassandra.net.Message
- payload() - Method in interface org.apache.cassandra.io.tries.SerializationNode
-
The payload of the node if the node has any associated, otherwise null.
- payloadAsString(ByteBuffer, int, int, Version) - Method in interface org.apache.cassandra.io.tries.Walker.PayloadToString
- payloadFlags() - Method in class org.apache.cassandra.io.tries.Walker
- payloadFlags(ByteBuffer, int) - Method in class org.apache.cassandra.io.tries.TrieNode
-
Returns the 4 payload flag bits.
- payloadPosition() - Method in class org.apache.cassandra.io.tries.Walker
- payloadPosition(ByteBuffer, int) - Method in class org.apache.cassandra.io.tries.TrieNode
-
Return the position just after the node, where the payload is usually stored.
- payloadSize() - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex.Reader
-
To be used only in analysis.
- pcProxy - Variable in class org.apache.cassandra.tools.NodeProbe
- peek() - Method in class org.apache.cassandra.index.sai.postings.PeekablePostingList
- peek() - Method in class org.apache.cassandra.utils.AbstractGuavaIterator
-
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.bytecomparable.ByteSource.Peekable
- peek() - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- peek() - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
- peekable(ByteSource) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- Peekable(ByteSource) - Constructor for class org.apache.cassandra.utils.bytecomparable.ByteSource.Peekable
- PeekablePostingList - Class in org.apache.cassandra.index.sai.postings
-
A peekable wrapper around a
PostingList
that allows the next value to be looked at without advancing the state of thePostingList
- peekNode() - Method in class org.apache.cassandra.io.tries.ValueIterator
-
Returns the payload node position without advancing.
- 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() - Method in class org.apache.cassandra.streaming.async.NettyStreamingChannel
- peer() - Method in class org.apache.cassandra.streaming.async.StreamingMultiplexedChannel
- peer() - Method in interface org.apache.cassandra.streaming.StreamingChannel
- PEER_EVENTS_V2 - Static variable in class org.apache.cassandra.db.SystemKeyspace
- peerIndexStatus - Variable in class org.apache.cassandra.index.IndexStatusManager
-
A map of per-endpoint index statuses: the key of inner map is the identifier "keyspace.index"
- peers() - Method in class org.apache.cassandra.streaming.StreamingState
- PEERS_V2 - Static variable in class org.apache.cassandra.db.SystemKeyspace
- PEMBasedKeyStoreContext(String, String, boolean, FileBasedSslContextFactory.FileBasedStoreContext) - Constructor for class org.apache.cassandra.security.PEMBasedSslContextFactory.PEMBasedKeyStoreContext
- PEMBasedSslContextFactory - Class in org.apache.cassandra.security
-
SslContextFactory for the PEM standard encoded PKCS#8 private keys and X509 certificates/public-keys.
- PEMBasedSslContextFactory() - Constructor for class org.apache.cassandra.security.PEMBasedSslContextFactory
- PEMBasedSslContextFactory(Map<String, Object>) - Constructor for class org.apache.cassandra.security.PEMBasedSslContextFactory
- PEMBasedSslContextFactory.ConfigKey - Enum in org.apache.cassandra.security
- PEMBasedSslContextFactory.PEMBasedKeyStoreContext - Class in org.apache.cassandra.security
- PEMReader - Class in org.apache.cassandra.security
-
This is a helper class to read private keys and X509 certifificates encoded based on PEM (RFC 1421) format.
- PEMReader() - Constructor for class org.apache.cassandra.security.PEMReader
- pending - Variable in class org.apache.cassandra.db.commitlog.AbstractCommitLogService
- pending - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStats
- 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(String, Token) - Static method in class org.apache.cassandra.locator.EndpointsForToken
- pending(AbstractCompactionStrategy, int) - Method in class org.apache.cassandra.db.compaction.CompactionLogger
- pending(Keyspace, Token) - Static method in class org.apache.cassandra.locator.EndpointsForToken
- pending(TableMetadata, Token) - Static method in class org.apache.cassandra.locator.EndpointsForToken
- PENDING_RANGE_CALCULATION_COMPLETED - org.apache.cassandra.locator.TokenMetadataEvent.TokenMetadataEventType
- PENDING_RANGE_CALCULATION_STARTED - org.apache.cassandra.locator.TokenMetadataEvent.TokenMetadataEventType
- 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(TimeUUID, 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
- 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
- PendingHintsInfo - Class in org.apache.cassandra.hints
- PendingHintsInfo(UUID, int, long, long) - Constructor for class org.apache.cassandra.hints.PendingHintsInfo
- pendingRangeCalculator() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- pendingRangeCalculator() - Method in class org.apache.cassandra.repair.SharedContext.Global
- pendingRangeCalculator() - Method in interface org.apache.cassandra.repair.SharedContext
- 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<TimeUUID>) - 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
- PercentageThreshold - Class in org.apache.cassandra.db.guardrails
-
A
Threshold
guardrail whose values represent a percentage - PercentageThreshold(String, String, ToLongFunction<ClientState>, ToLongFunction<ClientState>, Threshold.ErrorMessageProvider) - Constructor for class org.apache.cassandra.db.guardrails.PercentageThreshold
-
Creates a new threshold guardrail.
- percentile(double) - Method in class org.apache.cassandra.utils.EstimatedHistogram
- PERCENTILE - org.apache.cassandra.service.reads.SpeculativeRetryPolicy.Kind
- 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
- perColumnIndexComponents(IndexTermType) - Method in interface org.apache.cassandra.index.sai.disk.format.OnDiskFormat
-
Returns the set of
IndexComponent
for the per-column part of an index. - perColumnIndexComponents(IndexTermType) - Method in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- PerColumnIndexFiles - Class in org.apache.cassandra.index.sai.disk.v1
-
Maintains a mapping of
IndexComponent
s to associatedFileHandle
s for read operations on the components. - PerColumnIndexFiles(IndexDescriptor, IndexTermType, IndexIdentifier) - Constructor for class org.apache.cassandra.index.sai.disk.v1.PerColumnIndexFiles
- PerColumnIndexWriter - Interface in org.apache.cassandra.index.sai.disk
-
Creates the on-disk components for a given column index.
- perFileStore(Map<File, Long>, Function<File, FileStore>) - Static method in class org.apache.cassandra.db.Directories
- perform() - Method in interface org.apache.cassandra.utils.Throwables.DiscreteAction
- perform(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
- perform(Throwable, String, Throwables.FileOpType, Throwables.DiscreteAction<? extends IOException>...) - 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(Throwable, Stream<? extends Throwables.DiscreteAction<?>>) - Static method in class org.apache.cassandra.utils.Throwables
- perform(Throwable, Throwables.DiscreteAction<?>...) - 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(ExecutorPlus, Scheduler) - Method in interface org.apache.cassandra.repair.RepairTask
- perform(File, Throwables.FileOpType, Throwables.DiscreteAction<? extends IOException>...) - Static method in class org.apache.cassandra.utils.Throwables
- perform(Throwables.DiscreteAction<? extends E>...) - Static method in class org.apache.cassandra.utils.Throwables
- performAnticompaction(ColumnFamilyStore, RangesAtEndpoint, Refs<SSTableReader>, LifecycleTransaction, TimeUUID, 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, IScrubber.Options, 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(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
- performSkipTo(PrimaryKey) - Method in class org.apache.cassandra.index.sai.disk.IndexSearchResultIterator
- performSkipTo(PrimaryKey) - Method in class org.apache.cassandra.index.sai.disk.v1.postings.PostingListRangeIterator
- performSkipTo(PrimaryKey) - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeConcatIterator
- performSkipTo(PrimaryKey) - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIntersectionIterator
- performSkipTo(PrimaryKey) - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator
-
Skip to nextKey.
- performSkipTo(PrimaryKey) - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeListIterator
- performSkipTo(PrimaryKey) - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeOrderingIterator
- performSkipTo(PrimaryKey) - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeUnionIterator
- performSkipTo(PrimaryKey) - Method in class org.apache.cassandra.index.sai.memory.InMemoryKeyRangeIterator
- performSkipTo(OnDiskIndex.DataTerm) - Method in class org.apache.cassandra.index.sasi.utils.OnDiskIndexIterator
- performSnapshot(String) - Method in class org.apache.cassandra.db.memtable.AbstractAllocatorMemtable
- performSnapshot(String) - Method in interface org.apache.cassandra.db.memtable.Memtable
-
If the memtable needs to do some special action for snapshots (e.g.
- performSSTableRewrite(ColumnFamilyStore, boolean, long, boolean, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
- performSSTableRewrite(ColumnFamilyStore, Predicate<SSTableReader>, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Perform SSTable rewrite
- performUnsafe(ExecutorPlus, Scheduler) - Method in class org.apache.cassandra.repair.IncrementalRepairTask
- performUnsafe(ExecutorPlus, Scheduler) - Method in class org.apache.cassandra.repair.NormalRepairTask
- performUnsafe(ExecutorPlus, Scheduler) - Method in class org.apache.cassandra.repair.PreviewRepairTask
- performUnsafe(ExecutorPlus, Scheduler) - Method in interface org.apache.cassandra.repair.RepairTask
- performVerify(ColumnFamilyStore, IVerifier.Options) - Method in class org.apache.cassandra.db.compaction.CompactionManager
- performWrite(IMutation, ConsistencyLevel, String, StorageProxy.WritePerformer, Runnable, WriteType, Dispatcher.RequestTime) - Static method in class org.apache.cassandra.service.StorageProxy
-
Perform the write of a mutation given a WritePerformer.
- periodic - org.apache.cassandra.config.Config.CommitLogSync
- periodic_commitlog_sync_lag_block - Variable in class org.apache.cassandra.config.Config
- permissible - Variable in exception org.apache.cassandra.db.commitlog.CommitLogReadHandler.CommitLogReadException
- permission - Variable in class org.apache.cassandra.auth.PermissionDetails
- Permission - Enum in org.apache.cassandra.auth
-
An enum encapsulating the set of possible permissions that an authenticated user can have on a resource.
- 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_active_update - Variable in class org.apache.cassandra.config.Config
- permissions_cache_max_entries - Variable in class org.apache.cassandra.config.Config
- permissions_update_interval - Variable in class org.apache.cassandra.config.Config
- permissions_validity - Variable in class org.apache.cassandra.config.Config
- permissionsCache - Static variable in class org.apache.cassandra.auth.AuthenticatedUser
- PermissionsCache - Class in org.apache.cassandra.auth
- PermissionsCache(IAuthorizer) - Constructor for class org.apache.cassandra.auth.PermissionsCache
- PermissionsCacheMBean - Interface in org.apache.cassandra.auth
- PermissionsManagementStatement - Class in org.apache.cassandra.cql3.statements
- PermissionsManagementStatement(Set<Permission>, IResource, RoleName) - Constructor for class org.apache.cassandra.cql3.statements.PermissionsManagementStatement
- PERMIT_READ - org.apache.cassandra.service.paxos.PaxosState.MaybePromise.Outcome
- permits() - Method in interface org.apache.cassandra.utils.concurrent.Semaphore
- permits() - Method in class org.apache.cassandra.utils.concurrent.Semaphore.Standard
-
Number of permits that are available to be acquired.
- PERMITTED - org.apache.cassandra.db.commitlog.CommitLogSegment.CDCState
- perPartitionCount() - Method in class org.apache.cassandra.db.filter.DataLimits
- perPartitionLimit - Variable in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
- PerQueryMetrics(TableMetadata) - Constructor for class org.apache.cassandra.index.sai.metrics.TableQueryMetrics.PerQueryMetrics
- 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
- persistLocalMetadata(Supplier<UUID>) - Static method in class org.apache.cassandra.db.SystemKeyspace
- persistSSTableReadMeter(String, String, SSTableId, RestorableMeter) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Writes the current read rates for a given SSTable to system.sstable_activity
- perSSTableIndexComponents(boolean) - Method in interface org.apache.cassandra.index.sai.disk.format.OnDiskFormat
-
Returns the set of
IndexComponent
for the per-SSTable part of an index. - perSSTableIndexComponents(boolean) - Method in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- PerSSTableIndexWriter - Class in org.apache.cassandra.index.sasi.disk
- PerSSTableIndexWriter - Interface in org.apache.cassandra.index.sai.disk
-
Writes all SSTable-attached index files.
- 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
- phase - Variable in class org.apache.cassandra.repair.state.CoordinatorState
- phase - Variable in class org.apache.cassandra.repair.state.JobState
- phase - Variable in class org.apache.cassandra.repair.state.ParticipateState
- phase - Variable in class org.apache.cassandra.repair.state.SessionState
- phase - Variable in class org.apache.cassandra.repair.state.SyncState
- phase - Variable in class org.apache.cassandra.repair.state.ValidationState
- phase - Variable in class org.apache.cassandra.streaming.StreamingState
- Phase() - Constructor for class org.apache.cassandra.repair.state.CoordinatorState.Phase
- Phase() - Constructor for class org.apache.cassandra.repair.state.JobState.Phase
- Phase() - Constructor for class org.apache.cassandra.repair.state.ParticipateState.Phase
- Phase() - Constructor for class org.apache.cassandra.repair.state.SessionState.Phase
- Phase() - Constructor for class org.apache.cassandra.repair.state.SyncState.Phase
- Phase() - Constructor for class org.apache.cassandra.repair.state.ValidationState.Phase
- Phase() - Constructor for class org.apache.cassandra.streaming.StreamingState.Phase
- phi_convict_threshold - Variable in class org.apache.cassandra.config.Config
- PING_REQ - org.apache.cassandra.net.Verb
- PING_RSP - org.apache.cassandra.net.Verb
- 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
- PipelineConfigurator(boolean, boolean, EncryptionOptions.TlsEncryptionPolicy, Dispatcher) - 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 - Variable in class org.apache.cassandra.streaming.StreamState
- planId() - Method in class org.apache.cassandra.streaming.StreamPlan
- planId() - Method in class org.apache.cassandra.streaming.StreamSession
- planning() - Method in class org.apache.cassandra.repair.state.SyncState.Phase
- PLANNING - org.apache.cassandra.repair.state.SyncState.State
- PlatformMBeanWrapper() - Constructor for class org.apache.cassandra.utils.MBeanWrapper.PlatformMBeanWrapper
- POINTER - org.apache.cassandra.index.sasi.disk.OnDiskBlock.BlockType
- 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.caching.TinyThreadLocalPool
- poll() - Method in class org.apache.cassandra.utils.caching.TinyThreadLocalPool.TinyPool
- poll() - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- poll() - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
- poll(long, TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- 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
- pooled(String, int) - Method in interface org.apache.cassandra.concurrent.ExecutorBuilderFactory
-
Return a default configuration of pooled executor
- poolName - Variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
- pop() - Method in class org.apache.cassandra.io.tries.Walker.TransitionBytesCollector
- populateSegmentView(SimpleDataSet) - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
-
Populates a virtual table using the index metadata owned by the index
- populateSegmentView(SimpleDataSet) - Method in class org.apache.cassandra.index.sai.disk.v1.V1SSTableIndex
- populateTokenMetadata() - Method in class org.apache.cassandra.service.StorageService
- port - Variable in class org.apache.cassandra.tools.AbstractJmxClient
- port - Variable in class org.apache.cassandra.transport.SimpleClient
- pos - Variable in class org.apache.cassandra.io.tries.Walker.TransitionBytesCollector
- position - Variable in class org.apache.cassandra.db.commitlog.CommitLogPosition
- position - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
- position - Variable in class org.apache.cassandra.index.sasi.sa.Term
- position - Variable in class org.apache.cassandra.io.sstable.AbstractRowIndexEntry
- position - Variable in class org.apache.cassandra.io.tries.Walker
- position() - 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
- position(long) - Method in class org.apache.cassandra.db.streaming.CompressedInputStream
-
Invoked when crossing into the next
SSTableReader.PartitionPositionBounds
section inCassandraCompressedStreamReader.read(DataInputPlus)
. - position(long) - Method in class org.apache.cassandra.index.sasi.utils.MappedBuffer
- 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
- postAction(StartupChecksOptions) - Method in class org.apache.cassandra.service.DataResurrectionCheck
- postAction(StartupChecksOptions) - Method in interface org.apache.cassandra.service.StartupCheck
-
Post-hook after all startup checks succeeded.
- postFilteringReadLatency - Variable in class org.apache.cassandra.index.sai.metrics.TableQueryMetrics
- postIndexQueryFilter() - Method in interface org.apache.cassandra.index.Index.QueryPlan
-
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. - postIndexQueryFilter() - Method in class org.apache.cassandra.index.sai.plan.StorageAttachedIndexQueryPlan
- postIndexQueryFilter() - Method in class org.apache.cassandra.index.SingletonIndexQueryPlan
- POSTING_LISTS - org.apache.cassandra.index.sai.disk.format.IndexComponent
-
Stores postings written by
PostingsWriter
- postingDecoded(long) - Method in class org.apache.cassandra.index.sai.metrics.MulticastQueryEventListeners.Multicast2BalancedTreePostingListEventListener
- postingDecoded(long) - Method in class org.apache.cassandra.index.sai.metrics.MulticastQueryEventListeners.Multicast2TriePostingListEventListener
- postingDecoded(long) - Method in interface org.apache.cassandra.index.sai.metrics.QueryEventListener.PostingListEventListener
-
When a posting is successfully read from disk and decoded.
- postingList - Variable in class org.apache.cassandra.index.sai.disk.v1.segment.IndexSegmentSearcherContext
- postingList - Variable in class org.apache.cassandra.index.sai.utils.IndexEntry
- PostingList - Interface in org.apache.cassandra.index.sai.postings
-
Interface for advancing on and consuming a posting list.
- PostingList.EmptyPostingList - Class in org.apache.cassandra.index.sai.postings
- postingListEventListener() - Method in class org.apache.cassandra.index.sai.metrics.ColumnQueryMetrics.BalancedTreeIndexMetrics
- postingListEventListener() - Method in class org.apache.cassandra.index.sai.metrics.ColumnQueryMetrics.TrieIndexMetrics
- postingListEventListener() - Method in class org.apache.cassandra.index.sai.metrics.MulticastQueryEventListeners.Multicast2BalancedTreeEventListener
- postingListEventListener() - Method in class org.apache.cassandra.index.sai.metrics.MulticastQueryEventListeners.Multicast2TrieIndexEventListener
- postingListEventListener() - Method in interface org.apache.cassandra.index.sai.metrics.QueryEventListener.BalancedTreeEventListener
-
Returns events listener for balanced tree postings.
- postingListEventListener() - Method in interface org.apache.cassandra.index.sai.metrics.QueryEventListener.TrieIndexEventListener
-
Returns events listener for trie postings.
- PostingListRangeIterator - Class in org.apache.cassandra.index.sai.disk.v1.postings
-
A key iterator based on a
PostingList
derived from a single index segment. - PostingListRangeIterator(IndexIdentifier, PrimaryKeyMap, IndexSegmentSearcherContext) - Constructor for class org.apache.cassandra.index.sai.disk.v1.postings.PostingListRangeIterator
-
Create a direct PostingListRangeIterator where the underlying PostingList is materialised immediately so the posting list size can be used.
- postingLists() - Method in class org.apache.cassandra.index.sai.disk.v1.PerColumnIndexFiles
- postingListsHit(int) - Method in class org.apache.cassandra.index.sai.metrics.ColumnQueryMetrics.BalancedTreeIndexMetrics
- postingListsHit(int) - Method in class org.apache.cassandra.index.sai.metrics.MulticastQueryEventListeners.Multicast2BalancedTreeEventListener
- postingListsHit(int) - Method in interface org.apache.cassandra.index.sai.metrics.QueryEventListener.BalancedTreeEventListener
-
How many balanced tree posting list were matched during the intersection.
- PostingsReader - Class in org.apache.cassandra.index.sai.disk.v1.postings
-
Reads, decompresses and decodes postings lists written by
PostingsWriter
. - PostingsReader(IndexInput, long, QueryEventListener.PostingListEventListener) - Constructor for class org.apache.cassandra.index.sai.disk.v1.postings.PostingsReader
- PostingsReader(IndexInput, PostingsReader.BlocksSummary, QueryEventListener.PostingListEventListener) - Constructor for class org.apache.cassandra.index.sai.disk.v1.postings.PostingsReader
- PostingsReader.BlocksSummary - Class in org.apache.cassandra.index.sai.disk.v1.postings
- PostingsWriter - Class in org.apache.cassandra.index.sai.disk.v1.postings
-
Encodes, compresses and writes postings lists to disk.
- PostingsWriter(IndexDescriptor, IndexIdentifier) - Constructor for class org.apache.cassandra.index.sai.disk.v1.postings.PostingsWriter
- PostingsWriter(IndexOutputWriter) - Constructor for class org.apache.cassandra.index.sai.disk.v1.postings.PostingsWriter
- postProcessor(ReadCommand) - Method in interface org.apache.cassandra.index.Index.QueryPlan
-
Return a function which performs post processing on the results of a partition range read command.
- postProcessor(ReadCommand) - Method in class org.apache.cassandra.index.sai.plan.StorageAttachedIndexQueryPlan
-
Called on coordinator after merging replica responses before returning to client
- 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
- preciseTime - Static variable in class org.apache.cassandra.utils.MonotonicClock.Global
-
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
- Predicates<T> - Class in org.apache.cassandra.db.guardrails
-
A guardrail based on two predicates.
- Predicates.MessageProvider<T> - Interface in org.apache.cassandra.db.guardrails
-
A function used to build the warning or error message of a triggered
Predicates
guardrail. - 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
- prefix(ByteComparable, Walker.Extractor<RESULT, CONCRETE>) - Method in class org.apache.cassandra.io.tries.Walker
-
Takes a prefix of the given key.
- PREFIX - org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.Mode
- PREFIX - org.apache.cassandra.index.sasi.plan.Expression.Op
- prefixAndNeighbours(ByteComparable, Walker.Extractor<RESULT, CONCRETE>) - Method in class org.apache.cassandra.io.tries.Walker
-
Follows the trie for a given key, taking a prefix (in the sense above) and searching for neighboring values.
- 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
- preloadPreparedStatements() - Method in class org.apache.cassandra.cql3.QueryProcessor
- prepare() - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
- prepare(int, int) - Method in class org.apache.cassandra.db.ClusteringPrefix.Deserializer
- prepare(String) - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
- prepare(String) - Method in class org.apache.cassandra.transport.SimpleClient
- prepare(String[], PrintStream, PrintStream) - Method in class org.apache.cassandra.tools.nodetool.Sjk.Wrapper
- prepare(String, String) - Method in class org.apache.cassandra.cql3.Attributes.Raw
- prepare(String, String, ColumnIdentifier, AbstractType<?>) - Method in class org.apache.cassandra.cql3.functions.masking.ColumnMask.Raw
- prepare(String, List<? extends ColumnSpecification>) - Method in class org.apache.cassandra.cql3.Term.MultiColumnRaw
- prepare(String, List<? extends ColumnSpecification>) - Method in class org.apache.cassandra.cql3.Tuples.INRaw
- 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.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, ColumnSpecification) - Method in class org.apache.cassandra.cql3.ArrayLiteral
- prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Constants.Literal
- prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.functions.FunctionCall.Raw
- prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Lists.Literal
- prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Maps.Literal
- prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Sets.Literal
- 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, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Tuples.Literal
- prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.TypeCast
- prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.UserTypes.Literal
- prepare(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Vectors.Literal
- prepare(String, ColumnMetadata, TableMetadata) - Method in class org.apache.cassandra.cql3.conditions.ColumnCondition.Raw
- 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(String, ColumnMetadata, TableMetadata) - Method in interface org.apache.cassandra.cql3.Operation.RawDeletion
-
This method validates the operation (i.e.
- prepare(String, Types) - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
- prepare(String, ClientState) - Method in class org.apache.cassandra.cql3.QueryProcessor
-
This method got slightly out of hand, but this is with best intentions: to allow users to be upgraded from any prior version, and help implementers avoid previous mistakes by clearly separating fully qualified and non-fully qualified statement behaviour.
- prepare(String, ClientState, Map<String, ByteBuffer>) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
- prepare(String, ClientState, Map<String, ByteBuffer>) - Method in interface org.apache.cassandra.cql3.QueryHandler
- prepare(String, ClientState, Map<String, ByteBuffer>) - Method in class org.apache.cassandra.cql3.QueryProcessor
- prepare(Collection<StreamRequest>, Collection<StreamSummary>) - Method in class org.apache.cassandra.streaming.StreamSession
-
Prepare this session for sending/receiving files.
- prepare(List<ColumnSpecification>) - Method in class org.apache.cassandra.cql3.QueryOptions
- prepare(ColumnFamilyStore, MerkleTrees, TopPartitionTracker.Collector) - Method in class org.apache.cassandra.repair.Validator
- prepare(SharedContext, TableId, Collection<InetAddressAndPort>, EndpointState, Collection<Range<Token>>) - Static method in class org.apache.cassandra.service.paxos.cleanup.PaxosStartPrepareCleanup
-
We run paxos repair as part of topology changes, so we include the local endpoint state in the paxos repair prepare message to prevent racing with gossip dissemination and guarantee that every repair participant is aware of the pending ring change during repair.
- 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.WithArrayLiteral.Raw
- 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.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(TableMetadata) - Method in class org.apache.cassandra.cql3.statements.schema.IndexTarget.Raw
- prepare(TableMetadata, ColumnMetadata, boolean) - Method in class org.apache.cassandra.cql3.Operation.Addition
- prepare(TableMetadata, ColumnMetadata, boolean) - Method in class org.apache.cassandra.cql3.Operation.Prepend
- prepare(TableMetadata, ColumnMetadata, boolean) - Method in interface org.apache.cassandra.cql3.Operation.RawUpdate
-
This method validates the operation (i.e.
- prepare(TableMetadata, ColumnMetadata, boolean) - Method in class org.apache.cassandra.cql3.Operation.SetElement
- prepare(TableMetadata, ColumnMetadata, boolean) - Method in class org.apache.cassandra.cql3.Operation.SetField
- prepare(TableMetadata, ColumnMetadata, boolean) - Method in class org.apache.cassandra.cql3.Operation.SetValue
- prepare(TableMetadata, ColumnMetadata, boolean) - Method in class org.apache.cassandra.cql3.Operation.Substraction
- prepare(ClientState) - Method in class org.apache.cassandra.cql3.CQLStatement.Raw
- 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(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(ClientState) - 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(ClientState, boolean) - Method in class org.apache.cassandra.cql3.statements.SelectStatement.RawStatement
- prepare(ClientState, VariableSpecifications) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
- PREPARE - org.apache.cassandra.audit.AuditLogEntryCategory
- PREPARE - org.apache.cassandra.transport.Message.Type
- PREPARE_ACK - org.apache.cassandra.streaming.messages.StreamMessage.Type
- PREPARE_COMPLETE - org.apache.cassandra.repair.state.CoordinatorState.State
- PREPARE_CONSISTENT_REQ - org.apache.cassandra.net.Verb
- PREPARE_CONSISTENT_RSP - org.apache.cassandra.net.Verb
- PREPARE_MSG - org.apache.cassandra.net.Verb
- PREPARE_START - org.apache.cassandra.repair.state.CoordinatorState.State
- PREPARE_STATEMENT - org.apache.cassandra.audit.AuditLogEntryType
- PREPARE_SYN - org.apache.cassandra.streaming.messages.StreamMessage.Type
- PREPARE_SYNACK - org.apache.cassandra.streaming.messages.StreamMessage.Type
- 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.v1
- PrepareCallback(DecoratedKey, TableMetadata, int, ConsistencyLevel, Dispatcher.RequestTime) - Constructor for class org.apache.cassandra.service.paxos.v1.PrepareCallback
- prepareComplete() - Method in class org.apache.cassandra.repair.state.CoordinatorState.Phase
- PrepareConsistentRequest - Class in org.apache.cassandra.repair.messages
- PrepareConsistentRequest(TimeUUID, InetAddressAndPort, Set<InetAddressAndPort>) - Constructor for class org.apache.cassandra.repair.messages.PrepareConsistentRequest
- PrepareConsistentResponse - Class in org.apache.cassandra.repair.messages
- PrepareConsistentResponse(TimeUUID, InetAddressAndPort, boolean) - Constructor for class org.apache.cassandra.repair.messages.PrepareConsistentResponse
- Prepared() - Constructor for class org.apache.cassandra.cql3.Json.Prepared
- Prepared(CQLStatement, String, boolean, 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 - org.apache.cassandra.repair.consistent.ConsistentSession.State
- PREPARED - org.apache.cassandra.transport.messages.ResultMessage.Kind
- PREPARED_STATEMENTS - Static variable in class org.apache.cassandra.db.SystemKeyspace
- prepared_statements_cache_size - Variable in class org.apache.cassandra.config.Config
-
Size of the CQL prepared statements cache in MiB.
- prepareDirection - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionPreparedEvent
- 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 - Variable in class org.apache.cassandra.metrics.CQLMetrics
- preparedStatementsCount() - Static method in class org.apache.cassandra.cql3.QueryProcessor
- 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, long) - Method in class org.apache.cassandra.service.StorageService
- prepareForRepair(TimeUUID, 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(TimeUUID, Collection<ColumnFamilyStore>, RangesAtEndpoint, ExecutorService, BooleanSupplier) - Method in class org.apache.cassandra.db.repair.CassandraKeyspaceRepairManager
- prepareIncrementalRepair(TimeUUID, 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) - Static method in class org.apache.cassandra.cql3.QueryProcessor
- prepareInternal(String, Types) - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
- prepareInternal(ClientState, TableMetadata, VariableSpecifications, Conditions, Attributes) - Method in class org.apache.cassandra.cql3.statements.DeleteStatement.Parsed
- prepareInternal(ClientState, TableMetadata, VariableSpecifications, Conditions, Attributes) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement.Parsed
- prepareInternal(ClientState, TableMetadata, VariableSpecifications, Conditions, Attributes) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement.ParsedInsert
- prepareInternal(ClientState, TableMetadata, VariableSpecifications, Conditions, Attributes) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement.ParsedInsertJson
- prepareInternal(ClientState, TableMetadata, VariableSpecifications, Conditions, Attributes) - Method in class org.apache.cassandra.cql3.statements.UpdateStatement.ParsedUpdate
- PrepareMessage - Class in org.apache.cassandra.repair.messages
- PrepareMessage - Class in org.apache.cassandra.transport.messages
- PrepareMessage(String, String) - Constructor for class org.apache.cassandra.transport.messages.PrepareMessage
- PrepareMessage(TimeUUID, List<TableId>, Collection<Range<Token>>, boolean, long, boolean, PreviewKind) - Constructor for class org.apache.cassandra.repair.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.
- prepareOptions(Map<String, String>, Map<String, String>) - Static method in class org.apache.cassandra.locator.SimpleStrategy
- 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
- prepareSerializedBuffer(Mutation, int) - Method in class org.apache.cassandra.db.Mutation.MutationSerializer
-
Called early during request processing to prevent that
Mutation.MutationSerializer.serialization(Mutation, int)
is called concurrently. - prepareStart() - Method in class org.apache.cassandra.repair.state.CoordinatorState.Phase
- 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.compaction.unified.ShardedMultiWriter
- prepareToCommit() - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
- prepareToCommit() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
- prepareToCommit() - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryBuilder
- prepareToCommit() - Method in class org.apache.cassandra.io.sstable.RangeAwareSSTableWriter
- prepareToCommit() - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
- prepareToCommit() - Method in class org.apache.cassandra.io.sstable.SSTableZeroCopyWriter
- 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
- prepareToIterateRow() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner.BigScanningIterator
- prepareToIterateRow() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableScanner.BtiScanningIterator
- prepareToIterateRow() - Method in class org.apache.cassandra.io.sstable.format.SSTableScanner.BaseKeyScanningIterator
- prepareUnbootstrapStreaming() - Method in class org.apache.cassandra.service.StorageService
- prepareValue(TableMetadata, AbstractType<?>, VariableSpecifications) - Method in class org.apache.cassandra.cql3.restrictions.CustomIndexExpression
- PrepareVerbHandler - Class in org.apache.cassandra.service.paxos.v1
- PrepareVerbHandler() - Constructor for class org.apache.cassandra.service.paxos.v1.PrepareVerbHandler
- PREPARING - org.apache.cassandra.repair.consistent.ConsistentSession.State
- PREPARING - org.apache.cassandra.streaming.StreamSession.State
- 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
- PRESERVE_SIZE - org.apache.cassandra.db.rows.DeserializationHelper.Flag
- preserveOrder() - Method in interface org.apache.cassandra.db.partitions.UnfilteredPartitionIterators.MergeListener
-
Returns true if the merger needs to preserve the position of sources within the merge when passing data to the listener.
- 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
- prettyPrint(StackTraceElement[], boolean, String) - Static method in class org.apache.cassandra.utils.concurrent.Threads
- prettyPrint(StackTraceElement[], boolean, String, String, String) - Static method in class org.apache.cassandra.utils.concurrent.Threads
- prettyPrint(Stream<StackTraceElement>, boolean, String, String, String) - Static method in class org.apache.cassandra.utils.concurrent.Threads
- prettyPrintBinary(double, String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Convert the given value to a human-readable string using binary (i.e.
- prettyPrintDecimal(double, String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Convert the given value to a human-readable string using decimal (i.e.
- prettyPrintMemory(long) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Convert the given size in bytes to a human-readable value using binary (i.e.
- prettyPrintMemory(long, String) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Convert the given size in bytes to a human-readable value using binary (i.e.
- prettyPrintMemoryPerSecond(long) - Static method in class org.apache.cassandra.utils.FBUtilities
- prettyPrintMemoryPerSecond(long, long) - Static method in class org.apache.cassandra.utils.FBUtilities
- prettyPrintStackTrace(Thread, boolean, String) - Static method in class org.apache.cassandra.utils.concurrent.Threads
- prettyPrintStackTrace(Thread, boolean, String, String, String) - Static method in class org.apache.cassandra.utils.concurrent.Threads
- prev - Variable in class org.apache.cassandra.io.tries.IncrementalTrieWriterBase
- 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 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.state.ParticipateState
- 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
- PreviewRepairTask - Class in org.apache.cassandra.repair
- PreviewRepairTask(RepairCoordinator, TimeUUID, List<CommonRange>, String[]) - Constructor for class org.apache.cassandra.repair.PreviewRepairTask
- prevUnixMicros() - Method in class org.apache.cassandra.service.paxos.BallotGenerator.Default
- prevUnixMicros() - Static method in class org.apache.cassandra.service.paxos.BallotGenerator.Global
- prevUnixMicros() - Method in interface org.apache.cassandra.service.paxos.BallotGenerator
- PRIMARY_INDEX - Static variable in class org.apache.cassandra.io.sstable.format.big.BigFormat.Components
- PRIMARY_INDEX - Static variable in class org.apache.cassandra.io.sstable.format.big.BigFormat.Components.Types
- PRIMARY_KEY_IN_COMPACT_STORAGE - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- PRIMARY_RANGE_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
- primaryComponents() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- primaryComponents() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- primaryComponents() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
- PrimaryKey - Interface in org.apache.cassandra.index.sai.utils
-
Representation of the primary key for a row consisting of the
DecoratedKey
andClustering
associated with aRow
. - PrimaryKey.Factory - Class in org.apache.cassandra.index.sai.utils
- PrimaryKey.Kind - Enum in org.apache.cassandra.index.sai.utils
-
See the javadoc for
PrimaryKey.kind()
for how this enum is used. - primaryKeyAsCQLLiteral(ByteBuffer, Clustering<?>) - Method in class org.apache.cassandra.schema.TableMetadata
-
Returns a string representation of a primary key in a CQL-friendly format.
- primaryKeyColumns() - Method in class org.apache.cassandra.schema.TableMetadata
- primaryKeyFactory - Variable in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- primaryKeyFactory - Variable in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap.Factory
- primaryKeyFactory - Variable in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap
- primaryKeyFactory() - Method in class org.apache.cassandra.index.sai.plan.QueryController
- primaryKeyFromRowId(long) - Method in interface org.apache.cassandra.index.sai.disk.PrimaryKeyMap
-
Returns a
PrimaryKey
for a row ID - primaryKeyFromRowId(long) - Method in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap
- primaryKeyFromRowId(long) - Method in class org.apache.cassandra.index.sai.disk.v1.WidePrimaryKeyMap
- 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.
- PrimaryKeyMap - Interface in org.apache.cassandra.index.sai.disk
-
A bidirectional map of
PrimaryKey
to row ID. - PrimaryKeyMap.Factory - Interface in org.apache.cassandra.index.sai.disk
-
A factory for creating
PrimaryKeyMap
instances. - primaryKeyMapFactory - Variable in class org.apache.cassandra.index.sai.SSTableContext
- PrimaryKeys - Class in org.apache.cassandra.index.sai.utils
-
A sorted set of
PrimaryKey
s. - PrimaryKeys() - Constructor for class org.apache.cassandra.index.sai.utils.PrimaryKeys
- print(PrintStream) - Method in class org.apache.cassandra.metrics.SamplingManager.ResultBuilder
- print(CompactionHistoryHolder, PrintStream) - Method in class org.apache.cassandra.tools.nodetool.stats.CompactionHistoryPrinter.DefaultPrinter
- print(DataPathsHolder, PrintStream) - Method in class org.apache.cassandra.tools.nodetool.stats.DataPathsPrinter.DefaultPrinter
- print(TpStatsHolder, PrintStream) - Method in class org.apache.cassandra.tools.nodetool.stats.TpStatsPrinter.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_HEAP_HISTOGRAM_ON_OUT_OF_MEMORY_ERROR - org.apache.cassandra.config.CassandraRelevantProperties
- 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
- printScalingParameter(int) - Static method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- printScalingParameters(int[]) - Static method in class org.apache.cassandra.db.compaction.unified.Controller
- printSendingSummaries(PrintStream, SessionInfo, boolean) - Method in class org.apache.cassandra.tools.nodetool.NetStats
- printSet(PrintStream, String, Set<String>) - Method in class org.apache.cassandra.tools.NodeProbe
- 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.HashPassword
- printUsage(Options) - Static method in class org.apache.cassandra.tools.LoaderOptions
- priority - Variable in enum org.apache.cassandra.db.compaction.OperationType
- 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(F) - Method in class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineTask
- process(Object) - Method in class org.apache.cassandra.index.sasi.analyzer.filter.BasicResultFilters.NoOperation
- process(String) - Method in class org.apache.cassandra.index.sai.analyzer.filter.BasicFilters.Ascii
- process(String) - Method in class org.apache.cassandra.index.sai.analyzer.filter.BasicFilters.LowerCase
- process(String) - Method in class org.apache.cassandra.index.sai.analyzer.filter.BasicFilters.NoOperation
- process(String) - Method in class org.apache.cassandra.index.sai.analyzer.filter.BasicFilters.Normalize
- process(String) - Method in class org.apache.cassandra.index.sai.analyzer.filter.FilterPipeline.Task
- process(String) - Method in class org.apache.cassandra.index.sasi.analyzer.filter.BasicResultFilters.LowerCase
- process(String) - Method in class org.apache.cassandra.index.sasi.analyzer.filter.BasicResultFilters.UpperCase
- 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(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(String, ConsistencyLevel, QueryState, Dispatcher.RequestTime) - Static method in class org.apache.cassandra.cql3.QueryProcessor
- process(CQLStatement, QueryState, QueryOptions, Map<String, ByteBuffer>, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
- process(CQLStatement, QueryState, QueryOptions, Map<String, ByteBuffer>, Dispatcher.RequestTime) - Method in interface org.apache.cassandra.cql3.QueryHandler
- process(CQLStatement, QueryState, QueryOptions, Map<String, ByteBuffer>, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.QueryProcessor
- process(CQLStatement, QueryState, QueryOptions, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.QueryProcessor
- process(PartitionIterator, long, boolean, ClientState) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
- process(Trie.Walker<T, R>) - Method in class org.apache.cassandra.db.tries.Trie
-
Process the trie using the given Walker.
- 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>, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
- processBatch(BatchStatement, QueryState, BatchQueryOptions, Map<String, ByteBuffer>, Dispatcher.RequestTime) - Method in interface org.apache.cassandra.cql3.QueryHandler
- processBatch(BatchStatement, QueryState, BatchQueryOptions, Map<String, ByteBuffer>, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.QueryProcessor
- processBatch(BatchStatement, QueryState, BatchQueryOptions, Dispatcher.RequestTime) - 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
- PROCESSED - org.apache.cassandra.db.transform.RTBoundValidator.Stage
- 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
-
Checks limits on bytes in flight and the request rate limiter (if enabled), then takes one of three actions: 1.) If no limits are breached, process the request.
- processPartition(RowIterator, QueryOptions, ResultSetBuilder, long) - Method in class org.apache.cassandra.cql3.statements.SelectStatement
- processPrepared(CQLStatement, QueryState, QueryOptions, Map<String, ByteBuffer>, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.CustomPayloadMirroringQueryHandler
- processPrepared(CQLStatement, QueryState, QueryOptions, Map<String, ByteBuffer>, Dispatcher.RequestTime) - Method in interface org.apache.cassandra.cql3.QueryHandler
- processPrepared(CQLStatement, QueryState, QueryOptions, Map<String, ByteBuffer>, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.QueryProcessor
- processPrepared(CQLStatement, QueryState, QueryOptions, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.QueryProcessor
- processRequest(Envelope) - Method in class org.apache.cassandra.transport.CQLMessageHandler
- processRequest(Envelope, ClientResourceLimits.Overload) - Method in class org.apache.cassandra.transport.CQLMessageHandler
- processStatement(CQLStatement, QueryState, QueryOptions, Dispatcher.RequestTime) - Method in class org.apache.cassandra.cql3.QueryProcessor
- processSubsequentFrameOfLargeMessage(FrameDecoder.Frame) - Method in class org.apache.cassandra.net.AbstractMessageHandler
- processUpToOneMessage(ResourceLimits.Limit, ResourceLimits.Limit) - 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.streaming.StreamEvent.ProgressEvent
- progress() - Method in class org.apache.cassandra.streaming.StreamingState
- progress() - Method in class org.apache.cassandra.streaming.StreamingState.Sessions
- progress(double, int, boolean) - Static method in class org.apache.cassandra.tools.Util
- progress(String, ProgressInfo.Direction, long, long, long) - Method in class org.apache.cassandra.streaming.StreamSession
- progress(String, ProgressEvent) - Method in class org.apache.cassandra.tools.BootstrapMonitor
- progress(String, ProgressEvent) - Method in class org.apache.cassandra.tools.RepairRunner
- progress(String, ProgressEvent) - Method in class org.apache.cassandra.utils.progress.jmx.JMXProgressSupport
- progress(String, ProgressEvent) - Method in interface org.apache.cassandra.utils.progress.ProgressListener
-
Called when some progress is made by progress publisher.
- PROGRESS - org.apache.cassandra.utils.progress.ProgressEventType
-
Fire when progress happens.
- 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
- ProgressEvent(TimeUUID, ProgressInfo) - Constructor for class org.apache.cassandra.streaming.StreamEvent.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, 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
- progressPercentage() - Method in class org.apache.cassandra.streaming.ProgressInfo
- Promise<V> - Interface in org.apache.cassandra.utils.concurrent
-
A Promise that integrates
Promise
with ourFuture
API to improve clarity and coherence in the codebase. - PROMISE - org.apache.cassandra.service.paxos.PaxosState.MaybePromise.Outcome
- promised - Variable in class org.apache.cassandra.repair.messages.FinalizePromise
- promised - Variable in class org.apache.cassandra.service.paxos.PaxosState.Snapshot
- promised - Variable in class org.apache.cassandra.service.paxos.PrepareResponse
- promised - Variable in class org.apache.cassandra.service.paxos.v1.PrepareCallback
- promisedWrite - Variable in class org.apache.cassandra.service.paxos.PaxosState.Snapshot
- promiseIfNewer(Ballot, boolean) - Method in class org.apache.cassandra.service.paxos.PaxosState
-
Record the requested ballot as promised if it is newer than our current promise; otherwise do nothing.
- propagate() - Static method in class org.apache.cassandra.concurrent.ExecutorLocals
-
The
ExecutorLocals.current()
Locals, if any; otherwiseWithResources.none()
. - propagate(E, Path, boolean) - Static method in class org.apache.cassandra.io.util.PathUtils
-
propagate an IOException either as itself or an FSWriteError or FSReadError
- propagateLocalIndexStatus(String, String, Index.Status) - Method in class org.apache.cassandra.index.IndexStatusManager
-
Propagate a new index status to the ring.
- propagateUnchecked(IOException, Path, boolean) - Static method in class org.apache.cassandra.io.util.PathUtils
-
propagate an IOException as an FSWriteError, FSReadError or UncheckedIOException
- propagateUnchecked(String, IOException, Path, boolean) - Static method in class org.apache.cassandra.io.util.PathUtils
-
propagate an IOException as an FSWriteError, FSReadError or UncheckedIOException
- propagateUncheckedOrNoSuchFileException(IOException, Path, boolean) - Static method in class org.apache.cassandra.io.util.PathUtils
-
propagate an IOException as an FSWriteError, FSReadError or UncheckedIOException - except for NoSuchFileException
- properties - Variable in class org.apache.cassandra.cql3.statements.PropertyDefinitions
- Properties - Class in org.apache.cassandra.config
-
Utility class for working with
Property
types. - 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
- Proposal(Ballot, PartitionUpdate) - Constructor for class org.apache.cassandra.service.paxos.Commit.Proposal
- ProposeCallback - Class in org.apache.cassandra.service.paxos.v1
-
ProposeCallback has two modes of operation, controlled by the failFast parameter.
- ProposeCallback(int, int, boolean, ConsistencyLevel, Dispatcher.RequestTime) - Constructor for class org.apache.cassandra.service.paxos.v1.ProposeCallback
- ProposeVerbHandler - Class in org.apache.cassandra.service.paxos.v1
- ProposeVerbHandler() - Constructor for class org.apache.cassandra.service.paxos.v1.ProposeVerbHandler
- protectedResources() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
- protectedResources() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
- protectedResources() - Method in class org.apache.cassandra.auth.CassandraAuthorizer
- protectedResources() - Method in class org.apache.cassandra.auth.CassandraRoleManager
- protectedResources() - Method in interface org.apache.cassandra.auth.IAuthenticator
-
Set of resources that should be made inaccessible to users and only accessible internally.
- protectedResources() - Method in interface org.apache.cassandra.auth.IAuthorizer
-
Set of resources that should be made inaccessible to users and only accessible internally.
- protectedResources() - Method in interface org.apache.cassandra.auth.IRoleManager
-
Set of resources that should be made inaccessible to users and only accessible internally.
- protectedResources() - Method in class org.apache.cassandra.auth.MutualTlsAuthenticator
- protectedResources() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
- protocol - Variable in class org.apache.cassandra.config.EncryptionOptions
- protocol - Variable in class org.apache.cassandra.security.AbstractSslContextFactory
- PROTOCOL - org.apache.cassandra.config.EncryptionOptions.ConfigKey
- PROTOCOL - Static variable in class org.apache.cassandra.transport.ConnectedClient
- PROTOCOL_ERROR - org.apache.cassandra.exceptions.ExceptionCode
- 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(ProtocolVersion) - Method in class org.apache.cassandra.transport.SimpleClient.Builder
- ProtocolVersion - Enum in org.apache.cassandra.transport
-
The native (CQL binary) protocol version.
- ProtocolVersionTracker - Class in org.apache.cassandra.transport
-
This class tracks the last 100 connections per protocol version
- PROVIDE_OVERLAPPING_TOMBSTONES - org.apache.cassandra.schema.CompactionParams.Option
- ProxyHistograms - Class in org.apache.cassandra.tools.nodetool
- ProxyHistograms() - Constructor for class org.apache.cassandra.tools.nodetool.ProxyHistograms
- 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
- pullLast(List<T>, int) - Static method in class org.apache.cassandra.utils.Overlaps
-
Pull the last elements from the given list, up to the given limit.
- pullLastWithOverlapLimit(List<T>, List<Set<T>>, int) - Static method in class org.apache.cassandra.utils.Overlaps
-
Select up to `limit` sstables from each overlapping set (more than `limit` in total) by taking the last entries from `allObjectsSorted`.
- pullRepair - Variable in class org.apache.cassandra.repair.RepairSession
- PureJavaOperations() - Constructor for class org.apache.cassandra.utils.FastByteOperations.PureJavaOperations
- purge(DeletionPurger, long) - Method in class org.apache.cassandra.db.rows.AbstractCell
- purge(DeletionPurger, long) - Method in class org.apache.cassandra.db.rows.Cell
- purge(DeletionPurger, long) - Method in class org.apache.cassandra.db.rows.ColumnData
- purge(DeletionPurger, long) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
- purge(DeletionPurger, long, boolean) - Method in class org.apache.cassandra.db.rows.BTreeRow
- purge(DeletionPurger, long, 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
- PURGED - org.apache.cassandra.db.transform.RTBoundValidator.Stage
- purgeDataOlderThan(long) - Method in class org.apache.cassandra.db.rows.AbstractCell
- purgeDataOlderThan(long) - Method in class org.apache.cassandra.db.rows.Cell
- purgeDataOlderThan(long) - Method in class org.apache.cassandra.db.rows.ColumnData
- purgeDataOlderThan(long) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
- purgeDataOlderThan(long, boolean) - Method in class org.apache.cassandra.db.rows.BTreeRow
- purgeDataOlderThan(long, boolean) - Method in interface org.apache.cassandra.db.rows.Row
- PurgeFunction - Class in org.apache.cassandra.db.partitions
- PurgeFunction(long, long, long, boolean, boolean) - Constructor for class org.apache.cassandra.db.partitions.PurgeFunction
- push(AtomicReferenceFieldUpdater<? super O, T>, O, T) - Static method in class org.apache.cassandra.utils.concurrent.IntrusiveStack
- push(AtomicReferenceFieldUpdater<O, FailureRecordingCallback.FailureResponses>, O, InetAddressAndPort, RequestFailureReason) - Static method in class org.apache.cassandra.service.FailureRecordingCallback.FailureResponses
- push(AtomicReferenceFieldUpdater<O, T>, O, T, BiFunction<T, T, T>) - Static method in class org.apache.cassandra.utils.concurrent.IntrusiveStack
- push(Function<O, T>, IntrusiveStack.Setter<O, T>, O, T) - Static method in class org.apache.cassandra.utils.concurrent.IntrusiveStack
- push(Function<O, T>, IntrusiveStack.Setter<O, T>, O, T, BiFunction<T, T, T>) - Static method in class org.apache.cassandra.utils.concurrent.IntrusiveStack
- pushExclusive(AtomicReferenceFieldUpdater<O, FailureRecordingCallback.FailureResponses>, O, InetAddressAndPort, RequestFailureReason) - Static method in class org.apache.cassandra.service.FailureRecordingCallback.FailureResponses
- pushExclusive(AtomicReferenceFieldUpdater<O, T>, O, T) - Static method in class org.apache.cassandra.utils.concurrent.IntrusiveStack
- pushExclusive(AtomicReferenceFieldUpdater<O, T>, O, T, BiFunction<T, T, T>) - Static method in class org.apache.cassandra.utils.concurrent.IntrusiveStack
- pushExclusive(FailureRecordingCallback.FailureResponses, InetAddressAndPort, RequestFailureReason) - Static method in class org.apache.cassandra.service.FailureRecordingCallback.FailureResponses
- pushExclusive(T, T) - Static method in class org.apache.cassandra.utils.concurrent.IntrusiveStack
- pushViewReplicaUpdates(PartitionUpdate, boolean, AtomicLong) - Method in class org.apache.cassandra.db.view.TableViews
-
Calculates and pushes updates to the views replicas.
- put(long, Memory, long, long) - Method in class org.apache.cassandra.io.util.Memory
- put(Iterable<ViewMetadata>) - Method in class org.apache.cassandra.schema.Views.Builder
- put(ByteBuffer) - Method in class org.apache.cassandra.utils.memory.BufferPool.LocalPool
- put(ByteBuffer) - Method in class org.apache.cassandra.utils.memory.BufferPool
- put(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- put(K, Replica) - Method in class org.apache.cassandra.locator.ReplicaMultimap.Builder
- 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(K, V) - Method in class org.apache.cassandra.utils.BiMultiValMap
- put(K, V) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
- put(KeyCacheKey, AbstractRowIndexEntry) - Method in class org.apache.cassandra.io.sstable.keycache.KeyCache
- put(PartitionUpdate, UpdateTransaction, OpOrder.Group) - Method in interface org.apache.cassandra.db.memtable.Memtable
-
Put new data in the memtable.
- put(PartitionUpdate, UpdateTransaction, OpOrder.Group) - Method in class org.apache.cassandra.db.memtable.ShardedSkipListMemtable
-
Should only be called by ColumnFamilyStore.apply via Keyspace.apply, which supplies the appropriate OpOrdering.
- put(PartitionUpdate, UpdateTransaction, OpOrder.Group) - Method in class org.apache.cassandra.db.memtable.SkipListMemtable
-
Should only be called by ColumnFamilyStore.apply via Keyspace.apply, which supplies the appropriate OpOrdering.
- put(PartitionUpdate, UpdateTransaction, OpOrder.Group) - Method in class org.apache.cassandra.db.memtable.TrieMemtable
-
Should only be called by ColumnFamilyStore.apply via Keyspace.apply, which supplies the appropriate OpOrdering.
- put(Range<Token>, T) - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
- put(IndexComponent, long, long, long) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata.ComponentMetadataMap
- put(IndexComponent, long, long, long, Map<String, String>) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata.ComponentMetadataMap
- put(ViewMetadata) - Method in class org.apache.cassandra.schema.Views.Builder
- put(BinLog.ReleaseableWriteMarshallable) - Method in class org.apache.cassandra.utils.binlog.BinLog
-
Put a record into the log.
- put(T) - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- put(T) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
- 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
- putAll(Map<? extends Range<Token>, ? extends T>) - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
- 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
- putBoolean(byte[], int, boolean) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- putByte(byte[], int, byte) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- putByte(ByteBuffer, int, byte) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- putByte(V, int, byte) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
writes the byte value {@param value} to {@param dst} at offset {@param offset}
- putBytes(V, int, byte[]) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- putBytes(V, int, byte[], int, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- 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) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- putFloat(byte[], int, float) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- putFloat(ByteBuffer, int, float) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- putFloat(V, int, float) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
writes the float value {@param value} to {@param dst} at offset {@param offset}
- putFollowerStream(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamManager
- putIfAbsent(String, String) - Method in class org.apache.cassandra.locator.SnitchProperties
-
Returns this instance of snitch properties if key is present otherwise create new instance of properties and put key with a give value into it
- 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
- 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
- putInitiatorStream(StreamResultFuture) - Method in class org.apache.cassandra.streaming.StreamManager
- putInt(byte[], int, int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- putInt(byte[], int, int) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- 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 {@param value} to {@param dst} at offset {@param offset}
- 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(byte[], int, long) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- 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 {@param value} to {@param dst} at offset {@param offset}
- putLongByByte(long, long) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
- putRecursive(ByteComparable, R, InMemoryTrie.UpsertTransformer<T, R>) - Method in class org.apache.cassandra.db.tries.InMemoryTrie
-
Map-like put method, using a fast recursive implementation through the key bytes.
- putShort(byte[], int, short) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- putShort(byte[], int, short) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- 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 {@param value} to {@param dst} at offset {@param offset}
- putSingleton(ByteComparable, R, InMemoryTrie.UpsertTransformer<T, ? super R>) - Method in class org.apache.cassandra.db.tries.InMemoryTrie
-
Map-like put method, using the apply machinery above which cannot run into stack overflow.
- putSingleton(ByteComparable, R, InMemoryTrie.UpsertTransformer<T, ? super R>, boolean) - Method in class org.apache.cassandra.db.tries.InMemoryTrie
-
A version of putSingleton which uses recursive put if the last argument is true.
- putSslContextFactoryParameter(Map<String, Object>, EncryptionOptions.ConfigKey, Object) - Static method in class org.apache.cassandra.config.EncryptionOptions
- putStreamingState(StreamingState) - Method in class org.apache.cassandra.streaming.StreamManager
- Putter(ColumnMetadata, Term) - Constructor for class org.apache.cassandra.cql3.Maps.Putter
- putUnsignedVInt(V, int, long) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- putUnsignedVInt32(V, int, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- putUnusedPortion(ByteBuffer) - Method in class org.apache.cassandra.utils.memory.BufferPool.LocalPool
- putUnusedPortion(ByteBuffer) - Method in class org.apache.cassandra.utils.memory.BufferPool
- putVInt(V, int, long) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- putVInt32(V, int, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
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.)
- quantity() - Method in class org.apache.cassandra.config.DataStorageSpec
- quantity() - Method in class org.apache.cassandra.config.DurationSpec
- QUARANTINE_DELAY - Static variable in class org.apache.cassandra.gms.Gossiper
- QUARANTINED_ENDPOINT - org.apache.cassandra.gms.GossiperEvent.GossiperEventType
- 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 - Variable in class org.apache.cassandra.transport.messages.QueryMessage
- Query(String, QueryOptions, QueryState, long) - Constructor for class org.apache.cassandra.fql.FullQueryLogger.Query
- QUERY - org.apache.cassandra.audit.AuditLogEntryCategory
- QUERY - org.apache.cassandra.tracing.Tracing.TraceType
- QUERY - org.apache.cassandra.transport.Message.Type
- QUERY - Static variable in class org.apache.cassandra.fql.FullQueryLogger
- QUERY_OPTIONS - Static variable in class org.apache.cassandra.fql.FullQueryLogger
- QUERY_START_TIME - Static variable in class org.apache.cassandra.fql.FullQueryLogger
- QueryCancelledException - Exception in org.apache.cassandra.exceptions
- QueryCancelledException(ReadCommand) - Constructor for exception org.apache.cassandra.exceptions.QueryCancelledException
- QueryContext - Class in org.apache.cassandra.index.sai
-
Tracks state relevant to the execution of a single query, including metrics and timeout monitoring.
- QueryContext(ReadCommand, long) - Constructor for class org.apache.cassandra.index.sai.QueryContext
- QueryController - Class in org.apache.cassandra.index.sai.plan
- QueryController - Class in org.apache.cassandra.index.sasi.plan
- QueryController(ColumnFamilyStore, PartitionRangeReadCommand, long) - Constructor for class org.apache.cassandra.index.sasi.plan.QueryController
- QueryController(ColumnFamilyStore, ReadCommand, RowFilter, QueryContext) - Constructor for class org.apache.cassandra.index.sai.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
- QueryEventListener - Interface in org.apache.cassandra.index.sai.metrics
-
Listener that gets notified during storage-attached index query execution.
- QueryEventListener.BalancedTreeEventListener - Interface in org.apache.cassandra.index.sai.metrics
-
Collector for balanced tree file related metrics.
- QueryEventListener.PostingListEventListener - Interface in org.apache.cassandra.index.sai.metrics
-
Collector for posting file related metrics.
- QueryEventListener.TrieIndexEventListener - Interface in org.apache.cassandra.index.sai.metrics
- 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
- queryNames(ObjectName, QueryExp) - Method in class org.apache.cassandra.utils.MBeanWrapper.DelegatingMbeanWrapper
- queryNames(ObjectName, QueryExp) - Method in class org.apache.cassandra.utils.MBeanWrapper.InstanceMBeanWrapper
- queryNames(ObjectName, QueryExp) - Method in class org.apache.cassandra.utils.MBeanWrapper.NoOpMBeanWrapper
- queryNames(ObjectName, QueryExp) - Method in class org.apache.cassandra.utils.MBeanWrapper.PlatformMBeanWrapper
- queryNames(ObjectName, QueryExp) - Method in interface org.apache.cassandra.utils.MBeanWrapper
- 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.
- queryPlanFor(RowFilter) - Method in interface org.apache.cassandra.index.Index.Group
-
Returns a new
Index.QueryPlan
for the specifiedRowFilter
, ornull
if none of the indexes in this group supports the expression in the row filter. - queryPlanFor(RowFilter) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- queryPlanFor(RowFilter) - Method in class org.apache.cassandra.index.sasi.SASIIndexGroup
- queryPlanFor(RowFilter) - Method in class org.apache.cassandra.index.SingletonIndexGroup
- QueryProcessor - Class in org.apache.cassandra.cql3
- QueryReferencesTooManyIndexesAbortException - Exception in org.apache.cassandra.exceptions
- QueryReferencesTooManyIndexesAbortException(String, int, long, boolean, ConsistencyLevel, int, int, Map<InetAddressAndPort, RequestFailureReason>) - Constructor for exception org.apache.cassandra.exceptions.QueryReferencesTooManyIndexesAbortException
- QueryReferencingTooManyIndexesException - Exception in org.apache.cassandra.index.sai.plan
- QueryReferencingTooManyIndexesException(String) - Constructor for exception org.apache.cassandra.index.sai.plan.QueryReferencingTooManyIndexesException
- 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, long) - 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
- queryStorage(PrimaryKey, ReadExecutionController) - Method in class org.apache.cassandra.index.sai.plan.QueryController
- 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
- queryTimedOut - Variable in class org.apache.cassandra.index.sai.QueryContext
- QueryView(Collection<Pair<Expression, Collection<SSTableIndex>>>, Set<SSTableIndex>) - Constructor for class org.apache.cassandra.index.sai.plan.QueryViewBuilder.QueryView
- QueryViewBuilder - Class in org.apache.cassandra.index.sai.plan
-
Build a query specific view of the on-disk indexes for a query.
- QueryViewBuilder.QueryView - Class in org.apache.cassandra.index.sai.plan
- queue - org.apache.cassandra.config.Config.RepairCommandPoolFullStrategy
- queue - Variable in class org.apache.cassandra.transport.SimpleClient.SimpleEventHandler
- QUEUE - org.apache.cassandra.config.Config.CQLStartTime
- QUEUE_TIME - org.apache.cassandra.transport.ClientResourceLimits.Overload
- QueueBackpressure - Interface in org.apache.cassandra.transport
-
Native Queue Backpressure mechanism.
- QueueBackpressure.Incident - Class in org.apache.cassandra.transport
- queueCapacity - Variable in class org.apache.cassandra.net.AbstractMessageHandler
- queueTime(long, TimeUnit) - Method in class org.apache.cassandra.metrics.ClientMetrics
- quick - Variable in class org.apache.cassandra.io.sstable.IVerifier.Options
-
Quick check which does not include sstable data verification.
- quick(boolean) - Method in class org.apache.cassandra.io.sstable.IVerifier.Options.Builder
- QUIET_FILTER - Static variable in class org.apache.cassandra.security.SSLFactory.LoggingCipherSuiteFilter
- QUORUM - org.apache.cassandra.db.ConsistencyLevel
- 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.utils.JsonUtils
-
Quotes string contents using standard JSON quoting.
R
- R - org.apache.cassandra.db.Directories.FileAction
- rack - org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions.InternodeEncryption
- rack - Variable in class org.apache.cassandra.service.TokenRange.EndpointDetails
- rack(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- RACK - org.apache.cassandra.gms.ApplicationState
- 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
- RamAwareVectorValues - Interface in org.apache.cassandra.index.sai.disk.v1.vector
- ramBytesUsed() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.DiskAnn
- ramBytesUsed() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.VectorPostings
- RamEstimation - Class in org.apache.cassandra.index.sai.disk.v1.vector
- RamEstimation() - Constructor for class org.apache.cassandra.index.sai.disk.v1.vector.RamEstimation
- random() - Method in class org.apache.cassandra.db.compaction.unified.Controller
-
Random number generator to be used for the selection of tasks.
- random() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- random() - Method in class org.apache.cassandra.repair.SharedContext.Global
- random() - Method in interface org.apache.cassandra.repair.SharedContext
- RandomAccessReader - Class in org.apache.cassandra.io.util
- RandomAccessReader(Rebufferer) - Constructor for class org.apache.cassandra.io.util.RandomAccessReader
-
Only created through Builder
- RandomAccessReaderAdapter - Class in org.apache.cassandra.index.sai.disk.v1.vector
- 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 - Variable in class org.apache.cassandra.index.sasi.plan.Operation
- range - Variable in class org.apache.cassandra.repair.consistent.RepairedState.Section
- range - Variable in class org.apache.cassandra.service.TokenRange
- range() - Method in class org.apache.cassandra.dht.Splitter.WeightedRange
- 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<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 - org.apache.cassandra.index.sai.plan.Expression.IndexOperator
- RANGE - org.apache.cassandra.index.sasi.plan.Expression.Op
- RANGE_REQ - org.apache.cassandra.net.Verb
- range_request_timeout - Variable in class org.apache.cassandra.config.Config
- RANGE_RSP - org.apache.cassandra.net.Verb
- range_tombstone_list_growth_factor - Variable in class org.apache.cassandra.config.Config
-
The growth factor to enlarge a RangeTombstoneList.
- RANGE_TOMBSTONE_MARKER - org.apache.cassandra.db.rows.Unfiltered.Kind
- Range.OrderedRangeContainmentChecker - Class in org.apache.cassandra.dht
-
Helper class to check if a token is contained within a given collection of ranges
- RangeAwareSSTableWriter - Class in org.apache.cassandra.io.sstable
- RangeAwareSSTableWriter(ColumnFamilyStore, long, long, TimeUUID, boolean, SSTableFormat<?, ?>, int, long, LifecycleNewTracker, SerializationHeader) - Constructor for class org.apache.cassandra.io.sstable.RangeAwareSSTableWriter
- RangeCommandIterator - Class in org.apache.cassandra.service.reads.range
- 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.sai.iterators.KeyRangeConcatIterator.Builder
- rangeCount() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIntersectionIterator.Builder
- rangeCount() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator.Builder
- rangeCount() - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeUnionIterator.Builder
- 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 - Variable in class org.apache.cassandra.io.sstable.format.SSTableScanner
- rangeIterator() - Method in class org.apache.cassandra.utils.MerkleTrees
-
Get an iterator for all the iterator generated by the MerkleTrees.
- rangeIterator(boolean) - Method in interface org.apache.cassandra.db.DeletionInfo
- rangeIterator(boolean) - Method in class org.apache.cassandra.db.MutableDeletionInfo
- rangeIterator(Slice, boolean) - Method in interface org.apache.cassandra.db.DeletionInfo
- 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(K, K, long) - Constructor for class org.apache.cassandra.index.sasi.utils.RangeIterator
- 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.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
- rangeIterators - Variable in class org.apache.cassandra.index.sai.iterators.KeyRangeIntersectionIterator.Builder
- rangeIterators - Variable in class org.apache.cassandra.index.sai.iterators.KeyRangeUnionIterator.Builder
- 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
- rangeMetrics - Static variable in class org.apache.cassandra.service.reads.range.RangeCommandIterator
- RangeOwnHelper(List<Range<Token>>) - Constructor for class org.apache.cassandra.io.sstable.format.SortedTableVerifier.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 - 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 - Variable in class org.apache.cassandra.repair.RepairSessionResult
- ranges - Variable in class org.apache.cassandra.repair.state.ParticipateState
- ranges - Variable in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupRequest
- ranges() - Method in class org.apache.cassandra.locator.RangesAtEndpoint
- ranges() - Method in class org.apache.cassandra.repair.RepairSession
- ranges() - Method in class org.apache.cassandra.utils.MerkleTrees
-
Get the ranges that these merkle trees covers.
- RANGES - org.apache.cassandra.db.compaction.CompactionInfo.Unit
- 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
- rangeSpanned(PartitionPosition, PartitionPosition) - Method in interface org.apache.cassandra.db.compaction.ShardManager
- rangeSpanned(PartitionPosition, PartitionPosition) - Method in class org.apache.cassandra.db.compaction.ShardManagerDiskAware.BoundaryTrackerDiskAware
- rangeSpanned(PartitionPosition, PartitionPosition) - Method in class org.apache.cassandra.db.compaction.ShardManagerNoDisks.BoundaryTracker
- rangeSpanned(PartitionPosition, PartitionPosition) - Method in interface org.apache.cassandra.db.compaction.ShardTracker
- rangeSpanned(Range<Token>) - Method in interface org.apache.cassandra.db.compaction.ShardManager
-
The token range fraction spanned by the given range, adjusted for the local range ownership.
- rangeSpanned(Range<Token>) - Method in class org.apache.cassandra.db.compaction.ShardManagerNoDisks
- rangeSpanned(Range<Token>) - Method in class org.apache.cassandra.db.compaction.ShardManagerTrivial
- rangeSpanned(SSTableReader) - Method in interface org.apache.cassandra.db.compaction.ShardManager
-
Return the token space share that the given SSTable spans, excluding any non-locally owned space.
- rangeSpanned(SSTableReader) - Method in class org.apache.cassandra.db.compaction.ShardManagerTrivial
- RangesSerializer - Class in org.apache.cassandra.utils
- RangesSerializer() - Constructor for class org.apache.cassandra.utils.RangesSerializer
- 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.ExcludeLocalDatacenterFilter - Class in org.apache.cassandra.dht
-
Source filter which excludes nodes from local DC.
- 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.sai.view
- 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.sai.view
-
This is required since IntervalTree doesn't support custom Comparator implementations and relied on items to be comparable which "raw" terms are not.
- 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.
- rangeToBytes(Range<Token>) - Static method in class org.apache.cassandra.db.SystemKeyspace
- rangeTombstone(RangeTombstone) - Method in interface org.apache.cassandra.index.Index.Indexer
-
Notification of a RangeTombstone.
- 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
- 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
- RangeUtil - Class in org.apache.cassandra.index.sai.utils
- RangeUtil() - Constructor for class org.apache.cassandra.index.sai.utils.RangeUtil
- RATE_LIMITER_DELAY_UNIT - Static variable in class org.apache.cassandra.transport.CQLMessageHandler
- raw - Variable in class org.apache.cassandra.index.sai.plan.Expression.Value
- Raw() - Constructor for class org.apache.cassandra.cql3.Attributes.Raw
- Raw() - Constructor for class org.apache.cassandra.cql3.CQLStatement.Raw
- Raw() - Constructor for class org.apache.cassandra.cql3.Term.Raw
- Raw(boolean) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Raw
- Raw(int) - Constructor for class org.apache.cassandra.cql3.AbstractMarker.Raw
- Raw(int) - Constructor for class org.apache.cassandra.cql3.Tuples.Raw
- Raw(String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropKeyspaceStatement.Raw
- Raw(String, KeyspaceAttributes, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.AlterKeyspaceStatement.Raw
- Raw(String, KeyspaceAttributes, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateKeyspaceStatement.Raw
- Raw(List<Selectable.Raw>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.BetweenParenthesesOrWithTuple.Raw
- Raw(List<Selectable.Raw>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithArrayLiteral.Raw
- Raw(List<Selectable.Raw>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithSet.Raw
- Raw(List<Pair<Selectable.Raw, Selectable.Raw>>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithMapOrUdt.Raw
- Raw(CQL3Type.Raw, Selectable.Raw) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithTypeHint.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(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(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<Selectable.Raw>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithFunction.Raw
- Raw(FunctionName, List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.functions.FunctionCall.Raw
- Raw(FunctionName, List<Term.Raw>) - Constructor for class org.apache.cassandra.cql3.functions.masking.ColumnMask.Raw
- Raw(Ordering.Raw.Expression, Ordering.Direction) - Constructor for class org.apache.cassandra.cql3.Ordering.Raw
- Raw(QualifiedName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
- Raw(QualifiedName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
- Raw(QualifiedName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropIndexStatement.Raw
- Raw(QualifiedName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropTableStatement.Raw
- Raw(QualifiedName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropViewStatement.Raw
- Raw(QualifiedName, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropTriggerStatement.Raw
- Raw(QualifiedName, String, String, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateTriggerStatement.Raw
- Raw(QualifiedName, QualifiedName, List<RawSelector>, WhereClause, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateViewStatement.Raw
- Raw(QualifiedName, QualifiedName, List<IndexTarget.Raw>, IndexAttributes, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement.Raw
- Raw(QualifiedName, TableAttributes, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.AlterViewStatement.Raw
- Raw(Selectable.RawIdentifier, Selectable.Raw, Selectable.WritetimeOrTTL.Kind) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL.Raw
- Raw(Selectable.Raw, CQL3Type) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithCast.Raw
- Raw(Selectable.Raw, FieldIdentifier) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithFieldSelection.Raw
- Raw(Selectable.Raw, Term.Raw) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithElementSelection.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(UTName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.AlterTypeStatement.Raw
- Raw(UTName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.CreateTypeStatement.Raw
- Raw(UTName, boolean) - Constructor for class org.apache.cassandra.cql3.statements.schema.DropTypeStatement.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
- rawPartialArguments - Variable in class org.apache.cassandra.cql3.functions.masking.ColumnMask.Raw
- 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
- rawTimestampToMsb(long) - Static method in class org.apache.cassandra.utils.TimeUUID
- rawTimestampToUnixMicros(long) - Static method in class org.apache.cassandra.utils.TimeUUID
- rcProxy - Variable in class org.apache.cassandra.tools.NodeProbe
- reachedAllocatedSizeThreshold() - Method in class org.apache.cassandra.db.tries.InMemoryTrie
-
Returns true if the allocation threshold has been reached.
- reactivate() - Method in class org.apache.cassandra.net.FrameDecoder
-
For use by InboundMessageHandler (or other upstream handlers) that want to resume receiving frames after previously indicating that processing should be paused.
- read - Variable in exception org.apache.cassandra.net.Message.InvalidLegacyProtocolMagic
- read() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
- read() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
- read() - Method in class org.apache.cassandra.io.util.TrackedInputStream
- read(byte[]) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
- read(byte[]) - Method in class org.apache.cassandra.io.util.TrackedInputStream
- read(byte[], int, int) - Method in class org.apache.cassandra.hints.ChecksummedDataInput
- 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(byte[], int, int) - Method in class org.apache.cassandra.io.util.TrackedInputStream
- read(int[], int, int) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.RandomAccessReaderAdapter
-
Read ints into an int[], starting at the current position.
- read(DataInput, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- read(ByteBuffer) - Method in class org.apache.cassandra.security.EncryptionUtils.ChannelProxyReadChannel
- read(ByteBuffer, int, int) - Static method in class org.apache.cassandra.io.util.SizedInts
- read(ByteBuffer, long) - Method in class org.apache.cassandra.io.util.ChannelProxy
- read(ValueAccessor<V>, DataInputPlus, int) - Method in class org.apache.cassandra.db.marshal.AbstractType
- read(SinglePartitionReadCommand.Group, ConsistencyLevel, long) - Static method in class org.apache.cassandra.service.paxos.Paxos
- read(SinglePartitionReadCommand.Group, ConsistencyLevel, Dispatcher.RequestTime) - Static method in class org.apache.cassandra.service.paxos.Paxos
- read(SinglePartitionReadCommand.Group, ConsistencyLevel, Dispatcher.RequestTime) - 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) - Method in class org.apache.cassandra.db.streaming.CassandraCompressedStreamReader
- read(DataInputPlus) - Method in class org.apache.cassandra.db.streaming.CassandraEntireSSTableStreamReader
- read(DataInputPlus) - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader
- read(DataInputPlus) - Method in interface org.apache.cassandra.db.streaming.IStreamReader
- 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 {@param length} bytes from {@param in}
- read(DataInputPlus, int) - Method in class org.apache.cassandra.db.streaming.CassandraIncomingFile
- read(DataInputPlus, int) - Method in interface org.apache.cassandra.streaming.IncomingStream
-
Read in the stream data.
- read(TableMetadata, DataInputPlus) - Static method in class org.apache.cassandra.cache.CounterCacheKey
- READ - org.apache.cassandra.concurrent.Stage
- READ - org.apache.cassandra.index.Index.LoadType
- READ - org.apache.cassandra.service.paxos.ContentionStrategy.Type
- READ - org.apache.cassandra.utils.Throwables.FileOpType
- read_before_write_list_operations_enabled - Variable in class org.apache.cassandra.config.Config
- read_consistency_levels_disallowed - Variable in class org.apache.cassandra.config.Config
- read_consistency_levels_warned - Variable in class org.apache.cassandra.config.Config
- READ_FAILURE - org.apache.cassandra.exceptions.ExceptionCode
- READ_REPAIR - org.apache.cassandra.schema.TableParams.Option
- READ_REPAIR_REQ - org.apache.cassandra.net.Verb
- READ_REPAIR_RSP - org.apache.cassandra.net.Verb
- READ_REQ - org.apache.cassandra.net.Verb
- read_request_timeout - Variable in class org.apache.cassandra.config.Config
- READ_ROW_COUNT - org.apache.cassandra.metrics.Sampler.SamplerType
- READ_RSP - org.apache.cassandra.net.Verb
- READ_SIZE - org.apache.cassandra.exceptions.RequestFailureReason
- READ_SSTABLE_COUNT - org.apache.cassandra.metrics.Sampler.SamplerType
- read_thresholds_enabled - Variable in class org.apache.cassandra.config.Config
- READ_TIMEOUT - org.apache.cassandra.exceptions.ExceptionCode
- READ_TOMBSTONE_COUNT - org.apache.cassandra.metrics.Sampler.SamplerType
- READ_TOO_MANY_INDEXES - org.apache.cassandra.exceptions.RequestFailureReason
- READ_TOO_MANY_TOMBSTONES - org.apache.cassandra.exceptions.RequestFailureReason
- ReadableBoundary(DecoratedKey, long, long, int, long) - Constructor for class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryBuilder.ReadableBoundary
- ReadableMemory - Interface in org.apache.cassandra.io.util
- ReadAbortException - Exception in org.apache.cassandra.exceptions
-
Special Read Failure which is caused by user query; implies a user request is not allowed and not that Cassandra had an issue.
- ReadAbortException(String, ConsistencyLevel, int, int, boolean, Map<InetAddressAndPort, RequestFailureReason>) - Constructor for exception org.apache.cassandra.exceptions.ReadAbortException
- 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
- readBeforeWriteListOperationsEnabled - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail disabling operations on lists that require read before write.
- readBoolean() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
- readBoolean() - Method in class org.apache.cassandra.io.util.TeeDataInputPlus
- readBoolean() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
- readBoundValue(ByteBuf, ProtocolVersion) - Static method in class org.apache.cassandra.transport.CBUtil
- 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
- readBuffer(DataInputPlus) - 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.AbstractType
- readBuffer(DataInputPlus, int) - Method in class org.apache.cassandra.db.marshal.EmptyType
- readByte() - Method in class org.apache.cassandra.index.sai.disk.io.IndexInputReader
- readByte() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
- readByte() - Method in class org.apache.cassandra.io.util.TeeDataInputPlus
- readByte() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
- readByte(long) - Method in class org.apache.cassandra.index.sai.disk.io.SeekingRandomAccessInput
- readBytes(byte[], int, int) - Method in class org.apache.cassandra.index.sai.disk.io.IndexInputReader
- 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.cql3.functions.types.CodecUtils
-
Read
length
bytes frombb
into a new ByteBuffer. - readBytes(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- readBytes(ByteSource) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
Reads the bytes of the given source into a byte array.
- readBytes(ByteSource, int) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
Reads the bytes of the given source into a byte array.
- 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,P>> - Class in org.apache.cassandra.service.reads
- ReadCallback(ResponseResolver<E, P>, ReadCommand, ReplicaPlan.Shared<E, P>, Dispatcher.RequestTime) - Constructor for class org.apache.cassandra.service.reads.ReadCallback
- readCandidates() - Method in class org.apache.cassandra.locator.ReplicaPlan.AbstractForRead
- readCandidates() - Method in interface org.apache.cassandra.locator.ReplicaPlan.ForRead
- readCFS(DataInputPlus) - Method in class org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
- readChar() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
- readChar() - Method in class org.apache.cassandra.io.util.TeeDataInputPlus
- 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(V, ValueAccessor<V>) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
- readCommand(long) - Method in class org.apache.cassandra.cql3.statements.CQL3CasRequest
- readCommand(long) - Method in interface org.apache.cassandra.service.CASRequest
-
The command to use to fetch the value to compare for the CAS.
- 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, long, ColumnFilter, RowFilter, DataLimits, Index.QueryPlan, boolean) - Constructor for class org.apache.cassandra.db.ReadCommand
- 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, int, boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLogReader
-
Reads passed in file fully, up to mutationLimit count
- 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, 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
- readConsistencyLevels - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on read consistency levels.
- 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.TeeDataInputPlus
- 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.io.sstable.AbstractSSTableIterator
- Reader(PartitionIndex) - Constructor for class org.apache.cassandra.io.sstable.format.bti.PartitionIndex.Reader
- 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(String, ConsistencyLevel, int, int, boolean, Map<InetAddressAndPort, RequestFailureReason>) - Constructor for exception org.apache.cassandra.exceptions.ReadFailureException
- ReadFailureException(ConsistencyLevel, int, int, boolean, Map<InetAddressAndPort, RequestFailureReason>) - Constructor for exception org.apache.cassandra.exceptions.ReadFailureException
- readFirstAndLastKey(File, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex
- readFloat() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
- readFloat() - Method in class org.apache.cassandra.io.util.TeeDataInputPlus
- 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[]) - Method in class org.apache.cassandra.io.util.TeeDataInputPlus
- readFully(byte[]) - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.RebufferingInputStream
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.TeeDataInputPlus
- readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
- readFully(float[]) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.RandomAccessReaderAdapter
- readFully(ByteBuffer) - Method in class org.apache.cassandra.io.util.RebufferingInputStream
-
Equivalent to
RebufferingInputStream.read(byte[], int, int)
, where offset isdst.position()
and length isdst.remaining()
- readFully(FileChannel, ByteBuffer, long) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- 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.TeeDataInputPlus
- readInt() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
- readInt(long) - Method in class org.apache.cassandra.index.sai.disk.io.SeekingRandomAccessInput
- 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
- readKeyRange(Descriptor, IPartitioner) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat.SSTableReaderFactory
-
Retrieves a key range for the given sstable at the lowest cost - that is, without opening all sstables files if possible.
- 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.TeeDataInputPlus
- 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.TeeDataInputPlus
- readLong() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
- readLong(long) - Method in class org.apache.cassandra.index.sai.disk.io.SeekingRandomAccessInput
- readLongString(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
- readMetrics - Static variable in class org.apache.cassandra.metrics.ClientRequestsMetricsHolder
- readMetricsForLevel(ConsistencyLevel) - Static method in class org.apache.cassandra.metrics.ClientRequestsMetricsHolder
- readMetricsMap - Static variable in class org.apache.cassandra.metrics.ClientRequestsMetricsHolder
- 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
- readNonNullValue(V, ValueAccessor<V>, int) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
- readOne(SinglePartitionReadCommand, ConsistencyLevel, Dispatcher.RequestTime) - Static method in class org.apache.cassandra.service.StorageProxy
- ReadOnlyReadRepair<E extends Endpoints<E>,P extends ReplicaPlan.ForRead<E,P>> - 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
- readPartitionKey(long) - Method in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap
- readPayload(int, int) - Method in class org.apache.cassandra.io.sstable.format.bti.RowIndexReader
- readPosition(DataInputPlus) - Static method in class org.apache.cassandra.io.sstable.format.big.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.
- readQuorum() - Method in class org.apache.cassandra.locator.ReplicaPlan.AbstractForRead
- readQuorum() - Method in class org.apache.cassandra.locator.ReplicaPlan.ForFullRangeRead
- readQuorum() - Method in interface org.apache.cassandra.locator.ReplicaPlan.ForRead
- readRawBytes(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
- readRepair - Variable in class org.apache.cassandra.schema.TableParams
- readRepair - Variable in class org.apache.cassandra.service.reads.AbstractReadExecutor
- readRepair(ReadRepairStrategy) - Method in class org.apache.cassandra.schema.TableParams.Builder
- ReadRepair<E extends Endpoints<E>,P extends ReplicaPlan.ForRead<E,P>> - 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
- READS - org.apache.cassandra.metrics.Sampler.SamplerType
- READS_THRESHOLDS_COORDINATOR_DEFENSIVE_CHECKS_ENABLED - org.apache.cassandra.config.CassandraRelevantProperties
- readShort() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
- readShort() - Method in class org.apache.cassandra.io.util.TeeDataInputPlus
- readShort() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
- readShort(long) - Method in class org.apache.cassandra.index.sai.disk.io.SeekingRandomAccessInput
- readShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- readShortLength(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- ReadSizeAbortException - Exception in org.apache.cassandra.exceptions
- ReadSizeAbortException(String, ConsistencyLevel, int, int, boolean, Map<InetAddressAndPort, RequestFailureReason>) - Constructor for exception org.apache.cassandra.exceptions.ReadSizeAbortException
- readSizeAborts - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
- readSSTableActivity(String, String, SSTableId) - Static method in class org.apache.cassandra.db.SystemKeyspace
- 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
- readTimeUUID(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
- readTTL(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
- readType(KeyspaceMetadata, DataInputPlus) - Method in class org.apache.cassandra.cql3.selection.Selector.SelectorDeserializer
- readType(TableMetadata, DataInputPlus) - Method in class org.apache.cassandra.cql3.selection.Selector.SelectorDeserializer
- readUnsigned(ByteBuffer, int, int) - Static method in class org.apache.cassandra.io.util.SizedInts
- readUnsignedByte() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
- readUnsignedByte() - Method in class org.apache.cassandra.io.util.TeeDataInputPlus
- 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.TeeDataInputPlus
- 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() - Method in class org.apache.cassandra.io.util.TeeDataInputPlus
- readUnsignedVInt(DataInput) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- readUnsignedVInt32() - Method in interface org.apache.cassandra.io.util.DataInputPlus
-
Read up to a 32-bit integer back.
- readUnsignedVInt32() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
- readUnsignedVInt32(DataInput) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
-
Read up to a 32-bit integer.
- readUTF() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
- readUTF() - Method in class org.apache.cassandra.io.util.TeeDataInputPlus
- readUTF() - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
- readUUID(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
- readValue(ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
- readValue(ByteBuf, ProtocolVersion) - Method in enum org.apache.cassandra.transport.DataType
- 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) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
- 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
-
Read a 64-bit integer back.
- readVInt() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
- readVInt() - Method in class org.apache.cassandra.io.util.TeeDataInputPlus
- readVInt(DataInput) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- readVInt32() - Method in interface org.apache.cassandra.io.util.DataInputPlus
-
Read up to a 32-bit integer back.
- readVInt32() - Method in class org.apache.cassandra.io.util.RebufferingInputStream
- readVInt32(DataInput) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
-
Read up to a signed 32-bit integer back.
- readVLong(DataInput) - Static method in class org.apache.cassandra.index.sai.disk.v1.SAICodecUtils
-
Same as DataInput.readVLong but supports negative values
- 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.ByteArrayUtil
- readWithVIntLength(DataInputPlus) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- READY - org.apache.cassandra.transport.ConnectionStage
- READY - org.apache.cassandra.transport.Message.Type
- READY - org.apache.cassandra.utils.AbstractGuavaIterator.State
-
We have computed the next element and haven't returned it yet.
- READY_TO_COMMIT - org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional.State
- 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
- REAL_MARKED_ALIVE - org.apache.cassandra.gms.GossiperEvent.GossiperEventType
- realAppend(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
- realAppend(UnfilteredRowIterator) - Method in class org.apache.cassandra.db.compaction.writers.MajorLeveledCompactionWriter
- realMarkAlive(InetAddressAndPort, EndpointState) - Method in class org.apache.cassandra.gms.Gossiper
- reason - Variable in exception org.apache.cassandra.db.commitlog.CommitLogReadHandler.CommitLogReadException
- reason - Variable in class org.apache.cassandra.db.guardrails.Guardrail
-
An optional description of the reason for guarding the operation.
- rebase(DecayingEstimatedHistogramReservoir.EstimatedHistogramReservoirSnapshot) - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
-
Replaces current internal values with the given one from a Snapshot.
- rebind(String, Remote) - Method in class org.apache.cassandra.utils.JMXServerUtils.JmxRegistry
- rebuffer(long) - Method in class org.apache.cassandra.io.util.BufferManagingRebufferer
- rebuffer(long) - Method in class org.apache.cassandra.io.util.EmptyRebufferer
- rebuffer(long) - Method in class org.apache.cassandra.io.util.LimitingRebufferer
- 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(long) - Method in class org.apache.cassandra.io.util.TailOverridingRebufferer
- rebuffer(long) - Method in class org.apache.cassandra.io.util.WrappingRebufferer
- 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() - Method in class org.apache.cassandra.io.util.DataInputBuffer
- reBuffer() - Method in class org.apache.cassandra.io.util.FileInputStreamPlus
- 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() - 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) - 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 class org.apache.cassandra.service.StorageService
- 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, boolean) - Method in class org.apache.cassandra.service.StorageService
- rebuild(String, String, String, String, boolean) - 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, boolean) - Method in class org.apache.cassandra.tools.NodeProbe
- rebuild(Iterator<PaxosKeyState>) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker
- Rebuild - Class in org.apache.cassandra.tools.nodetool
- Rebuild() - Constructor for class org.apache.cassandra.tools.nodetool.Rebuild
- REBUILD - org.apache.cassandra.streaming.StreamOperation
- 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
- recalcTotalSize(IncrementalTrieWriterPageAware.Node<VALUE>, long) - Method in class org.apache.cassandra.io.tries.IncrementalDeepTrieWriterPageAware
- recalcTotalSize(IncrementalTrieWriterPageAware.Node<VALUE>, long) - Method in class org.apache.cassandra.io.tries.IncrementalTrieWriterPageAware
- RECALL - org.apache.cassandra.index.sai.disk.v1.vector.OptimizeFor
- receive(IncomingStreamMessage) - Method in class org.apache.cassandra.streaming.StreamSession
-
Call back after receiving a stream.
- 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(TableId, int) - Method in class org.apache.cassandra.streaming.StreamSession
- received(IncomingStream) - Method in class org.apache.cassandra.db.streaming.CassandraStreamReceiver
- 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 - org.apache.cassandra.streaming.messages.StreamMessage.Type
- 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
- receivedEntireSSTable - Variable in class org.apache.cassandra.db.streaming.CassandraStreamReceiver
- ReceivedMessage - Class in org.apache.cassandra.streaming.messages
- ReceivedMessage(TableId, int) - Constructor for class org.apache.cassandra.streaming.messages.ReceivedMessage
- receivePeerIndexStatus(InetAddressAndPort, VersionedValue) - Method in class org.apache.cassandra.index.IndexStatusManager
-
Recieve a new index status map from a peer.
- 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
- RECENT - Static variable in class org.apache.cassandra.service.paxos.PaxosState
- recentBloomFilterFalsePositives - Variable in class org.apache.cassandra.io.sstable.filter.BloomFilterMetrics
-
Number of false positives in bloom filter from last read
- recentBloomFilterFalseRatio - Variable in class org.apache.cassandra.io.sstable.filter.BloomFilterMetrics
-
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
- recompressSSTables(PrintStream, String, int, String...) - Method in class org.apache.cassandra.tools.NodeProbe
- recompressSSTables(String, int, String...) - Method in class org.apache.cassandra.service.StorageService
- recompressSSTables(String, int, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- recompressSSTables(String, int, String...) - Method in class org.apache.cassandra.tools.NodeProbe
- RecompressSSTables - Class in org.apache.cassandra.tools.nodetool
- RecompressSSTables() - Constructor for class org.apache.cassandra.tools.nodetool.RecompressSSTables
- recompute() - Method in class org.apache.cassandra.utils.RecomputingSupplier
- recomputeNext() - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator
- RecomputingSupplier<T> - Class in org.apache.cassandra.utils
-
Supplier that caches the last computed value until it is reset, forcing every caller of
RecomputingSupplier.get(long, TimeUnit)
to wait until this value is computed if it was not computed yet. - RecomputingSupplier(Supplier<T>, ExecutorService) - Constructor for class org.apache.cassandra.utils.RecomputingSupplier
- reconcile(Cell<?>, Cell<?>) - Static method in class org.apache.cassandra.db.rows.Cells
-
Reconciles/merge two cells.
- reconciler(ColumnData.PostReconciliationFunction, DeletionTime) - Static method in class org.apache.cassandra.db.rows.ColumnData
-
Construct an UpdateFunction for reconciling normal ColumnData (i.e.
- Reconciler() - Constructor for class org.apache.cassandra.db.rows.ColumnData.Reconciler
- 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
- record(QueryContext) - Method in class org.apache.cassandra.index.sai.metrics.TableQueryMetrics.PerQueryMetrics
- record(QueryContext) - Method in class org.apache.cassandra.index.sai.metrics.TableQueryMetrics
- 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(int, RemovalCause) - 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
- recordReadRegularAbort(ConsistencyLevel, Throwable) - Static method in class org.apache.cassandra.service.StorageProxy
- recordReadResponseMetrics(ResultMessage.Rows, StatementRestrictions, Selection) - Static method in class org.apache.cassandra.metrics.ClientRequestSizeMetrics
- recordRepairStatus(int, ActiveRepairService.ParentRepairStatus, List<String>) - Method in class org.apache.cassandra.service.ActiveRepairService
- recordRowAndColumnCountMetrics(Collection<? extends IMutation>) - Static method in class org.apache.cassandra.metrics.ClientRequestSizeMetrics
- recordRowAndColumnCountMetrics(PartitionUpdate) - Static method in class org.apache.cassandra.metrics.ClientRequestSizeMetrics
- recordSelfDroppedMessage(Verb) - Method in class org.apache.cassandra.metrics.MessagingMetrics
- recordSelfDroppedMessage(Verb, long, TimeUnit) - Method in class org.apache.cassandra.metrics.MessagingMetrics
- recordShadowedPrimaryKey(PrimaryKey) - Method in class org.apache.cassandra.index.sai.VectorQueryContext
- 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.
- RECOVERABLE_DESCRIPTOR_ERROR - org.apache.cassandra.db.commitlog.CommitLogReadHandler.CommitLogReadErrorReason
- 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.
- recreateCidrGroupsMapping(Map<String, List<String>>) - Method in class org.apache.cassandra.auth.CIDRGroupsMappingManager
- recreateCidrGroupsMapping(Map<String, List<String>>) - Method in interface org.apache.cassandra.auth.CIDRGroupsMappingManagerMBean
-
Update
AuthKeyspace.CIDR_GROUPS
table with completly new mappings. - reCreateStatementsForSchemaCql(TableMetadata, KeyspaceMetadata) - 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
- REDACTED - Static variable in class org.apache.cassandra.db.guardrails.Guardrail
- redistributeSummaries() - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryManager
- redistributeSummaries() - Method in interface org.apache.cassandra.io.sstable.indexsummary.IndexSummaryManagerMBean
- redistributeSummaries() - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryRedistribution
- redistributeSummaries(IndexSummaryRedistribution) - Static method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryManager
-
Attempts to fairly distribute a fixed pool of memory for index summaries across a set of SSTables based on their recent read rates.
- reduce(int, In) - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
-
combine this object with the previous ones.
- 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
- 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
- reduceScopeForLimitedSpace(Set<SSTableReader>, long) - Method in class org.apache.cassandra.db.compaction.LeveledCompactionTask
- 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() - Method in class org.apache.cassandra.utils.concurrent.Ref.DirectBufferRef
- ref() - Method in class org.apache.cassandra.utils.concurrent.Ref
- ref() - Method in interface org.apache.cassandra.utils.concurrent.RefCounted
- ref(Iterable<? extends T>) - Static method in class org.apache.cassandra.utils.concurrent.Refs
- 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.DirectBufferRef<T extends sun.nio.ch.DirectBuffer> - Class in org.apache.cassandra.utils.concurrent
-
A version of
Ref
for objects that implementDirectBuffer
. - Ref.IdentityCollection - Class in org.apache.cassandra.utils.concurrent
- Ref.OnLeak - Interface 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.sai.disk.SSTableIndex
- reference() - Method in class org.apache.cassandra.index.sasi.SSTableIndex
- referencedIndexes - Variable in class org.apache.cassandra.index.sai.plan.QueryViewBuilder.QueryView
- 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(ByteBuffer) - Method in class org.apache.cassandra.schema.ViewMetadata
- 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.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(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
- referencingUserType(ByteBuffer) - Method in class org.apache.cassandra.schema.Tables
- referencingUserType(ByteBuffer) - Method in class org.apache.cassandra.schema.Types
- referencingUserType(ByteBuffer) - Method in class org.apache.cassandra.schema.UserFunctions
- ReflectionUtils - Class in org.apache.cassandra.utils
- Refresh - Class in org.apache.cassandra.tools.nodetool
- Refresh() - Constructor for class org.apache.cassandra.tools.nodetool.Refresh
- 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
- REFUSAL_INCREMENT - Static variable in class org.apache.cassandra.service.paxos.PaxosPropose
- 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() - Method in class org.apache.cassandra.metrics.ThreadPoolMetrics
- register() - Static method in class org.apache.cassandra.service.GCInspector
- register() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue
-
The calling thread MUST be the thread that uses the signal
- register() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue.Standard
-
The calling thread MUST be the thread that uses the signal
- register(Class<? extends RowFilter.UserExpression>, RowFilter.UserExpression.Deserializer) - Static method in class org.apache.cassandra.db.filter.RowFilter.UserExpression
- register(Iterable<? extends TypeCodec<?>>) - Method in class org.apache.cassandra.cql3.functions.types.CodecRegistry
-
Register the given codecs with this registry.
- register(String, String, int, int, int, int, List<String>) - Method in class org.apache.cassandra.metrics.SamplingManager
-
Register the samplers for the keyspace and table.
- register(String, ThreadPoolExecutorBase) - Static method in class org.apache.cassandra.concurrent.ThreadPoolExecutorJMXAdapter
- register(Consumer<Message<Collection<Mutation>>>) - Method in class org.apache.cassandra.schema.SchemaPushVerbHandler
- register(Consumer<Message<NoPayload>>) - Method in class org.apache.cassandra.schema.SchemaPullVerbHandler
- register(AuthCache<?, ?>) - Method in class org.apache.cassandra.auth.AuthCacheService
- 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(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(IEndpointStateChangeSubscriber) - Method in interface org.apache.cassandra.gms.IGossiper
- 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.sai.StorageAttachedIndex
- register(IndexRegistry) - Method in class org.apache.cassandra.index.sasi.SASIIndex
- register(IndexRegistry) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- register(CassandraMetricsRegistry.MetricName, CassandraMetricsRegistry.MetricName, T) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
- register(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(INotificationConsumer) - Method in class org.apache.cassandra.service.SSTablesGlobalTracker
-
Register a new subscriber to this tracker.
- register(CoordinatorState) - Method in class org.apache.cassandra.service.ActiveRepairService
- register(JobState) - Method in class org.apache.cassandra.repair.state.SessionState
- register(ParticipateState) - Method in class org.apache.cassandra.service.ActiveRepairService
- register(SessionState) - Method in class org.apache.cassandra.repair.state.CoordinatorState
- register(SyncState) - Method in class org.apache.cassandra.repair.state.ParticipateState.Job
- register(SyncState) - Method in class org.apache.cassandra.repair.state.ParticipateState
- register(ValidationState) - Method in class org.apache.cassandra.repair.state.ParticipateState.Job
- register(ValidationState) - Method in class org.apache.cassandra.repair.state.ParticipateState
- register(IEndpointLifecycleSubscriber) - Method in class org.apache.cassandra.service.StorageService
- register(Event.Type, Channel) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
- register(V, Consumer<V>) - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue
-
The calling thread MUST be the thread that uses the signal.
- register(V, Consumer<V>) - Method in class org.apache.cassandra.utils.concurrent.WaitQueue.Standard
-
The calling thread MUST be the thread that uses the signal.
- REGISTER - org.apache.cassandra.transport.Message.Type
- registerComponents(Collection<Component>, Tracker) - Method in class org.apache.cassandra.io.sstable.SSTable
-
Registers new custom components into sstable and update size tracking
- 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, Index.Group.Key, Supplier<Index.Group>) - Method in interface org.apache.cassandra.index.IndexRegistry
- registerIndex(Index, Index.Group.Key, Supplier<Index.Group>) - 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
- registerListener(SchemaChangeListener) - Method in class org.apache.cassandra.schema.SchemaChangeNotifier
- registerMBean() - Method in class org.apache.cassandra.hints.HintsService
- registerMBean(Metric, ObjectName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
- registerMBean(Object, String) - Method in interface org.apache.cassandra.utils.MBeanWrapper
- registerMBean(Object, String, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.NoOpMBeanWrapper
- registerMBean(Object, String, MBeanWrapper.OnException) - Method in interface org.apache.cassandra.utils.MBeanWrapper
- registerMBean(Object, ObjectName) - Method in interface org.apache.cassandra.utils.MBeanWrapper
- registerMBean(Object, ObjectName, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.DelegatingMbeanWrapper
- registerMBean(Object, ObjectName, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.InstanceMBeanWrapper
- registerMBean(Object, ObjectName, 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
- 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(TimeUUID, InetAddressAndPort, List<ColumnFamilyStore>, Collection<Range<Token>>, boolean, long, boolean, PreviewKind) - Method in class org.apache.cassandra.service.ActiveRepairService
- registerSession(TimeUUID, Set<InetAddressAndPort>, boolean) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSessions
- registerTimer(String) - Method in class org.apache.cassandra.metrics.ClientMetrics
- regular(DeletionTime) - Static method in class org.apache.cassandra.db.rows.Row.Deletion
- REGULAR - org.apache.cassandra.schema.ColumnMetadata.Kind
- REGULAR - org.apache.cassandra.schema.KeyspaceMetadata.Kind
- REGULAR - org.apache.cassandra.schema.TableMetadata.Kind
- REGULAR_COLUMN_INDEX_FUNCTIONS - Static variable in interface org.apache.cassandra.index.internal.CassandraIndexFunctions
- regularAndStaticColumns - Variable in class org.apache.cassandra.schema.TableMetadata
- regularAndStaticColumns() - Method in class org.apache.cassandra.schema.TableMetadata
- 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.Builder - Class in org.apache.cassandra.db
- regularColumn(String, String, String, AbstractType<?>) - Static method in class org.apache.cassandra.schema.ColumnMetadata
- regularColumn(TableMetadata, ByteBuffer, 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
- reinsertOverflowedTTLRows - Variable in class org.apache.cassandra.io.sstable.IScrubber.Options
- reinsertOverflowedTTLRows() - Method in class org.apache.cassandra.io.sstable.IScrubber.Options.Builder
- reinsertOverflowedTTLRows(boolean) - Method in class org.apache.cassandra.io.sstable.IScrubber.Options.Builder
- reject - org.apache.cassandra.config.Config.RepairCommandPoolFullStrategy
- REJECT - org.apache.cassandra.db.ExpirationDateOverflowHandling.ExpirationDateOverflowPolicy
- REJECT - org.apache.cassandra.service.paxos.PaxosState.MaybePromise.Outcome
- reject_repair_compaction_threshold - Variable in class org.apache.cassandra.config.Config
- rejectedCidrAccessCount - Variable in class org.apache.cassandra.metrics.CIDRAuthorizerMetrics
- rejectedExecutionHandler - Static variable in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- RejectException - Exception in org.apache.cassandra.db
-
Represents a request to reject the current operation
- RejectException(String) - Constructor for exception org.apache.cassandra.db.RejectException
- RejectException(String, Throwable) - Constructor for exception org.apache.cassandra.db.RejectException
- RejectException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.cassandra.db.RejectException
- RejectException(Throwable) - Constructor for exception org.apache.cassandra.db.RejectException
- 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.sai.disk.SSTableIndex
- release() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder
-
This method does three things:
- release() - Method in class org.apache.cassandra.index.sai.metrics.AbstractMetrics
- release() - Method in class org.apache.cassandra.index.sai.metrics.TableQueryMetrics
- 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.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.io.util.WrappingRebufferer
- 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.ClientRangeRequestMetrics
- 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 class org.apache.cassandra.metrics.MinMaxAvgMetric
- 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.TrieMemtableMetricsView
- release() - Method in class org.apache.cassandra.metrics.ViewWriteMetrics
- release() - Method in class org.apache.cassandra.net.FrameEncoder.Payload
- 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.DirectBufferRef
- 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() - 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.
- release(int) - Method in interface org.apache.cassandra.utils.concurrent.Semaphore
-
Increase the number of available permits and signal any waiters that may be served by the release
- 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(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(Collection<SSTableReader>) - Method in class org.apache.cassandra.index.sai.SSTableContextManager
- 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(T) - Method in class org.apache.cassandra.utils.concurrent.Refs
- RELEASE_VERSION - org.apache.cassandra.config.CassandraRelevantProperties
- RELEASE_VERSION - org.apache.cassandra.gms.ApplicationState
- 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
- releaseInMemoryComponents() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- releaseInMemoryComponents() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- releaseInMemoryComponents() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
This method is expected to close the components which occupy memory but are not needed when we just want to stream the components (for example, when SSTable is opened with SSTableLoader).
- releaseLocal() - Method in class org.apache.cassandra.utils.memory.BufferPool
-
Forces to recycle free local chunks back to the global pool.
- 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.
- releaseQuietly() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
- releaseReference() - Method in class org.apache.cassandra.tracing.TraceState
- releaseRepairData(Collection<TimeUUID>) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyManager
- releaseRepairData(Collection<TimeUUID>, 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
- releaseSpace(long) - Method in class org.apache.cassandra.net.AsyncChannelOutputPlus
-
Update our flushed count, and signal any waiters.
- 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() - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Drops and adds new indexes associated with the underlying CF
- reload(boolean) - Method in class org.apache.cassandra.db.view.ViewManager
- reloadCidrGroupsCache() - Method in class org.apache.cassandra.tools.NodeProbe
- ReloadCIDRGroupsCache - Class in org.apache.cassandra.tools.nodetool
-
Nodetool command to reload CIDR groups cache
- ReloadCIDRGroupsCache() - Constructor for class org.apache.cassandra.tools.nodetool.ReloadCIDRGroupsCache
- 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
- RELOCATE - org.apache.cassandra.db.compaction.OperationType
- relocateSSTables(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- relocateSSTables(int, String, String...) - Method in class org.apache.cassandra.service.StorageService
- 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(String, String...) - Method in class org.apache.cassandra.service.StorageService
- relocateSSTables(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-11179
- relocateSSTables(ColumnFamilyStore, int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
- RelocateSSTables - Class in org.apache.cassandra.tools.nodetool
- RelocateSSTables() - Constructor for class org.apache.cassandra.tools.nodetool.RelocateSSTables
- RELOCATION - org.apache.cassandra.streaming.StreamOperation
- remaining - Variable in class org.apache.cassandra.service.pager.PagingState
- 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(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- remainingCapacity() - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- 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
- remoteRequests - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
- remoteResponse(InetAddressAndPort, Verb, T) - Static method in class org.apache.cassandra.net.Message
-
Used by the
MultiRangeReadCommand
to split multi-range responses from a replica into single-range responses. - REMOVAL_COORDINATOR - org.apache.cassandra.gms.ApplicationState
- REMOVAL_COORDINATOR - Static variable in class org.apache.cassandra.gms.VersionedValue
- removalCoordinator(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- remove() - Method in class org.apache.cassandra.db.compaction.CompactionIterator
- remove() - Method in class org.apache.cassandra.db.partitions.AbstractUnfilteredPartitionIterator
- remove() - Method in class org.apache.cassandra.db.partitions.SingletonUnfilteredPartitionIterator
- remove() - Method in class org.apache.cassandra.index.sai.analyzer.AbstractAnalyzer
- remove() - Method in class org.apache.cassandra.index.sasi.analyzer.AbstractAnalyzer
- remove() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator
- remove() - Method in class org.apache.cassandra.io.sstable.format.SSTableScanner
- remove() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
- remove() - Method in class org.apache.cassandra.utils.AbstractGuavaIterator
- remove() - Method in class org.apache.cassandra.utils.AbstractIterator
- remove() - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- remove() - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
- remove(int) - Method in class org.apache.cassandra.utils.btree.BTreeSet
- remove(long, InetAddressAndPort) - Method in class org.apache.cassandra.net.RequestCallbacks
-
Remove and return the
RequestCallbacks.CallbackInfo
associated with given id and peer, if known. - remove(Object) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaMap
- remove(Object) - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
- remove(Object) - Method in class org.apache.cassandra.utils.BiMultiValMap
- remove(Object) - Method in class org.apache.cassandra.utils.btree.BTreeSet
- remove(Object) - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- remove(Object) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
- remove(Object) - Method in class org.apache.cassandra.utils.ConcurrentBiMap
- remove(Object[], Comparator<? super V>, V) - Static method in class org.apache.cassandra.utils.btree.BTreeRemoval
-
Remove |elem| from |btree|.
- remove(String) - Method in class org.apache.cassandra.config.TransparentDataEncryptionOptions
- remove(String) - Method in class org.apache.cassandra.schema.Views.Builder
- remove(ByteBuffer, T) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.OnHeapGraph
- remove(BiPredicate<Message<?>, InetAddressAndPort>) - Method in class org.apache.cassandra.net.OutboundSink
- remove(Predicate<Message<?>>) - Method in class org.apache.cassandra.net.InboundSink
- 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(SSTableReader) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
- 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(CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
- remove(CassandraMetricsRegistry.MetricName, CassandraMetricsRegistry.MetricName...) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
- remove(ParamType) - Static method in class org.apache.cassandra.db.MessageParams
- remove(DynamicList.Node<E>) - Method in class org.apache.cassandra.utils.DynamicList
- remove(DynamicList.Node<E>) - Method in class org.apache.cassandra.utils.LockedDynamicList
- remove(TimeUUID) - Static method in class org.apache.cassandra.batchlog.BatchlogManager
- remove(T) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.VectorPostings
- REMOVE - org.apache.cassandra.index.sasi.utils.trie.Cursor.Decision
-
Remove the previously returned element from the
Trie
and continue - REMOVE_AND_EXIT - org.apache.cassandra.index.sasi.utils.trie.Cursor.Decision
-
Remove the previously returned element from the
Trie
and exit from the traverse operation - removeAll(Collection<?>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
- removeAll(Collection<?>) - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- removeAll(Collection<?>) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
- 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_ENDPOINT - org.apache.cassandra.gms.GossiperEvent.GossiperEventType
- REMOVED_NODE - org.apache.cassandra.transport.Event.TopologyChange.Change
- REMOVED_TOKEN - Static variable in class org.apache.cassandra.gms.VersionedValue
- removeDenylistKey(String, String, String) - Method in class org.apache.cassandra.service.StorageProxy
-
Attempts to remove the provided pk from the ks + table deny list
- removeDenylistKey(String, String, String) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- 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(InetSocketAddress) - 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
- removeIndex(Index) - Method in interface org.apache.cassandra.index.Index.Group
-
Removes the specified
Index
from the members of this group. - removeIndex(Index) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- removeIntersecting(Range<Token>) - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
- removeKeyFromDenylist(String, String, ByteBuffer) - Method in class org.apache.cassandra.schema.PartitionDenylist
-
We expect the caller to confirm that we are working with a valid keyspace and table.
- 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.FutureDelegate
- removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in class org.apache.cassandra.utils.concurrent.AsyncPromise
- removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface org.apache.cassandra.utils.concurrent.Future
- removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in interface org.apache.cassandra.utils.concurrent.Promise
- removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
- removeListener(StreamManager.StreamListener) - Method in class org.apache.cassandra.streaming.StreamManager
- 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.FutureDelegate
- removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class org.apache.cassandra.utils.concurrent.AsyncPromise
- removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface org.apache.cassandra.utils.concurrent.Future
- removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in interface org.apache.cassandra.utils.concurrent.Promise
- removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
- 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.service.StorageService
- removeNotificationListener(NotificationListener) - Method in class org.apache.cassandra.streaming.StreamManager
- removeNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class org.apache.cassandra.service.StorageService
- removeNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class org.apache.cassandra.streaming.StreamManager
- removeParentRepairSession(TimeUUID) - Method in class org.apache.cassandra.service.ActiveRepairService
-
called when the repair session is done - either failed or anticompaction has completed
- 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.RepairCoordinator
- 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
- removeProperty(String) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
- 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.
- removeSession(PaxosCleanupSession) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosRepairState
- 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)
- removeSnapshotDirectory(RateLimiter, File) - Static method in class org.apache.cassandra.db.Directories
- 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.LeveledCompactionStrategy
- removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
- removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
- removeSSTable(SSTableReader) - Method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- 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(String, Property) - Static method in class org.apache.cassandra.config.Properties
- rename(Path, Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- 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.SSTable
- 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
-
Deprecated.See CASSANDRA-16926
- renameWithConfirm(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Deprecated.See CASSANDRA-16926
- renameWithOutConfirm(String, String) - Static method in class org.apache.cassandra.io.util.FileUtils
-
Deprecated.See CASSANDRA-16926
- renewed - Variable in class org.apache.cassandra.notifications.MemtableRenewedNotification
- renewMemtable(Memtable) - Method in class org.apache.cassandra.index.sai.memory.MemtableIndexManager
- reorderBackTimestampBytes(long) - Static method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- reorderTimestampBytes(long) - Static method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- repair - Variable in class org.apache.cassandra.config.Config
- repair() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- repair() - Method in class org.apache.cassandra.repair.SharedContext.Global
- repair() - Method in interface org.apache.cassandra.repair.SharedContext
- repair(String, Map<String, String>, List<ProgressListener>) - Method in class org.apache.cassandra.service.StorageService
- repair(String, RepairOption, 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 - org.apache.cassandra.service.paxos.ContentionStrategy.Type
- REPAIR - org.apache.cassandra.streaming.StreamOperation
- REPAIR - org.apache.cassandra.tracing.Tracing.TraceType
- REPAIR_CLEANUP_INTERVAL_SECONDS - org.apache.cassandra.config.CassandraRelevantProperties
- 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_COMPLETE - org.apache.cassandra.repair.state.CoordinatorState.State
- REPAIR_DELETE_TIMEOUT_SECONDS - org.apache.cassandra.config.CassandraRelevantProperties
- REPAIR_FAIL_TIMEOUT_SECONDS - org.apache.cassandra.config.CassandraRelevantProperties
- REPAIR_HISTORY - Static variable in class org.apache.cassandra.schema.SystemDistributedKeyspace
- REPAIR_MUTATION_REPAIR_ROWS_PER_BATCH - org.apache.cassandra.config.CassandraRelevantProperties
- REPAIR_PAXOS_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
- repair_request_timeout - Variable in class org.apache.cassandra.config.Config
- REPAIR_RSP - org.apache.cassandra.net.Verb
- repair_session_max_tree_depth - Variable in class org.apache.cassandra.config.Config
-
Deprecated.See
- repair_session_space - Variable in class org.apache.cassandra.config.Config
- REPAIR_START - org.apache.cassandra.repair.state.CoordinatorState.State
- repair_state_expires - Variable in class org.apache.cassandra.config.Config
- repair_state_size - Variable in class org.apache.cassandra.config.Config
- REPAIR_STATUS_CHECK_TIMEOUT_SECONDS - org.apache.cassandra.config.CassandraRelevantProperties
- 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(PrintStream, String, Map<String, String>) - Method in class org.apache.cassandra.tools.NodeProbe
- 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.
- repairCommandExecutor() - Static method in class org.apache.cassandra.service.ActiveRepairService
- RepairCommandExecutorHandle() - Constructor for class org.apache.cassandra.service.ActiveRepairService.RepairCommandExecutorHandle
- repairCompleted() - Method in class org.apache.cassandra.repair.state.CoordinatorState.Phase
- RepairConfig - Class in org.apache.cassandra.config
- RepairConfig() - Constructor for class org.apache.cassandra.config.RepairConfig
- RepairCoordinator - Class in org.apache.cassandra.repair
- RepairCoordinator(StorageService, int, RepairOption, String) - Constructor for class org.apache.cassandra.repair.RepairCoordinator
- RepairCoordinator.NeighborsAndRanges - Class in org.apache.cassandra.repair
- repaired - org.apache.cassandra.config.Config.PaxosStatePurging
-
Clears system.paxos records only once they are known to be persisted to a quorum of replica's base tables through the use of paxos repair.
- REPAIRED - org.apache.cassandra.streaming.PreviewKind
- 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.repair.messages.PrepareMessage
- repairedAt - Variable in class org.apache.cassandra.repair.state.ParticipateState
- 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.See CASSANDRA-13910
- 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
- repairedDataMismatch(TableMetadata, Iterable<InetAddressAndPort>, List<Range<Token>>) - 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
- repairExceptions - Static variable in class org.apache.cassandra.metrics.StorageMetrics
- REPAIRING - org.apache.cassandra.repair.consistent.ConsistentSession.State
- repairIterator(TableId, Collection<Range<Token>>) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- repairIterator(TableId, Collection<Range<Token>>) - Method in interface org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker.UpdateSupplier
- 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(TimeUUID, TimeUUID, String, String, Collection<Range<Token>>) - Constructor for class org.apache.cassandra.repair.RepairJobDesc
- repairJobResults - Variable in class org.apache.cassandra.repair.RepairSessionResult
- repairManager(ColumnFamilyStore) - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- repairManager(ColumnFamilyStore) - Method in class org.apache.cassandra.repair.SharedContext.Global
- repairManager(ColumnFamilyStore) - Method in interface org.apache.cassandra.repair.SharedContext
- 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
- RepairMessage.RepairFailureCallback - Interface in org.apache.cassandra.repair.messages
- RepairMessageVerbHandler - Class in org.apache.cassandra.repair
-
Handles all repair related message.
- RepairMessageVerbHandler(SharedContext) - Constructor for class org.apache.cassandra.repair.RepairMessageVerbHandler
- RepairMetrics - Class in org.apache.cassandra.metrics
- RepairMetrics() - Constructor for class org.apache.cassandra.metrics.RepairMetrics
- RepairNotifier - Interface in org.apache.cassandra.repair
- 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, 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.ForWrite) - Method in class org.apache.cassandra.service.reads.repair.BlockingReadRepair
- repairPartition(DecoratedKey, Map<Replica, Mutation>, ReplicaPlan.ForWrite) - Method in class org.apache.cassandra.service.reads.repair.NoopReadRepair
- repairPartition(DecoratedKey, Map<Replica, Mutation>, ReplicaPlan.ForWrite) - Method in class org.apache.cassandra.service.reads.repair.ReadOnlyReadRepair
- repairPartition(DecoratedKey, Map<Replica, Mutation>, ReplicaPlan.ForWrite) - Method in interface org.apache.cassandra.service.reads.repair.ReadRepair
-
Repairs a partition _after_ receiving data responses.
- repairPaxos - Variable in class org.apache.cassandra.repair.RepairSession
- repairPaxos() - Method in class org.apache.cassandra.repair.messages.RepairOption
- repairPaxosForTopologyChange(String, Collection<Range<Token>>, String) - Method in class org.apache.cassandra.service.ActiveRepairService
- 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
- RepairRetrySpec - Class in org.apache.cassandra.config
- RepairRetrySpec() - Constructor for class org.apache.cassandra.config.RepairRetrySpec
- RepairRunner - Class in org.apache.cassandra.tools
- RepairRunner(PrintStream, StorageServiceMBean, String, Map<String, String>) - Constructor for class org.apache.cassandra.tools.RepairRunner
- repairs - Variable in class org.apache.cassandra.service.reads.repair.BlockingReadRepair
- REPAIRS - Static variable in class org.apache.cassandra.db.SystemKeyspace
- 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(SharedContext, Scheduler, TimeUUID, CommonRange, String, RepairParallelism, boolean, boolean, PreviewKind, boolean, boolean, 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(TimeUUID, 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
- repairSubmitted() - Method in class org.apache.cassandra.repair.state.CoordinatorState.Phase
- 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
- RepairTask - Interface in org.apache.cassandra.repair
- repairTime - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
total time spent as a repair coordinator
- replace(Collection<SSTableReader>, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.compaction.LeveledManifest
- 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(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
- REPLACE_ADDRESS - org.apache.cassandra.config.CassandraRelevantProperties
- REPLACE_ADDRESS_FIRST_BOOT - org.apache.cassandra.config.CassandraRelevantProperties
- REPLACE_NODE - org.apache.cassandra.config.CassandraRelevantProperties
- REPLACE_TOKEN - org.apache.cassandra.config.CassandraRelevantProperties
- REPLACED_ENDPOINT - org.apache.cassandra.gms.GossiperEvent.GossiperEventType
- 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
- ReplaceMaskingFunction - Class in org.apache.cassandra.cql3.functions.masking
-
A
MaskingFunction
that replaces the specified column value by a certain replacement value. - Replacement - Class in org.apache.cassandra.config
-
Holder for replacements to support backward compatibility between old and new names and types of configuration parameters (CASSANDRA-15234)
- Replacement(Class<?>, String, Class<?>, String, Converters, boolean) - Constructor for class org.apache.cassandra.config.Replacement
- REPLACEMENT_ALLOW_EMPTY - org.apache.cassandra.config.CassandraRelevantProperties
-
When doing a host replacement its possible that the gossip state is "empty" meaning that the endpoint is known but the current state isn't known.
- REPLACEMENT_QUARANTINE - org.apache.cassandra.gms.GossiperEvent.GossiperEventType
- replacementQuarantine(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
-
Quarantine endpoint specifically for replacement purposes.
- Replacements - Class in org.apache.cassandra.config
- Replaces - Annotation Type in org.apache.cassandra.config
-
Repeatable annotation for providing old name, converter from old to new type and whether the config parameters we annotate are deprecated and we need to warn the users.
- ReplacesList - Annotation Type in org.apache.cassandra.config
-
Concatenating annotation type for the repeatable annotation
Replaces
- 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(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.AbstractStrategyHolder
- replaceSSTables(AbstractStrategyHolder.GroupedSSTableContainer, AbstractStrategyHolder.GroupedSSTableContainer) - Method in class org.apache.cassandra.db.compaction.CompactionStrategyHolder
- 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
- replicaDiskUsage - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the data disk usage on replicas, used at write time to verify the status of the involved replicas.
- 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 - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
- replicaPlan - Variable 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.ReadCallback
- replicaPlan() - Method in class org.apache.cassandra.service.reads.repair.AbstractReadRepair
- replicaPlan() - Method in class org.apache.cassandra.service.reads.ResponseResolver
- ReplicaPlan<E extends Endpoints<E>,P extends ReplicaPlan<E,P>> - Interface in org.apache.cassandra.locator
- ReplicaPlan.AbstractForRead<E extends Endpoints<E>,P extends ReplicaPlan.ForRead<E,P>> - Class in org.apache.cassandra.locator
- ReplicaPlan.AbstractReplicaPlan<E extends Endpoints<E>,P extends ReplicaPlan<E,P>> - Class in org.apache.cassandra.locator
- ReplicaPlan.ForFullRangeRead - Class in org.apache.cassandra.locator
- ReplicaPlan.ForPaxosWrite - Class in org.apache.cassandra.locator
- ReplicaPlan.ForRangeRead - Class in org.apache.cassandra.locator
- ReplicaPlan.ForRead<E extends Endpoints<E>,P extends ReplicaPlan.ForRead<E,P>> - Interface in org.apache.cassandra.locator
- ReplicaPlan.ForTokenRead - Class in org.apache.cassandra.locator
- ReplicaPlan.ForWrite - Class in org.apache.cassandra.locator
- ReplicaPlan.Shared<E extends Endpoints<E>,P extends ReplicaPlan<E,P>> - 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.InOurDc
- 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() - Method in class org.apache.cassandra.service.paxos.v1.PrepareCallback
- REPLICATED_SYSTEM_KEYSPACE_NAMES - Static variable in class org.apache.cassandra.schema.SchemaConstants
- replication - Variable in class org.apache.cassandra.schema.KeyspaceParams
- REPLICATION - org.apache.cassandra.schema.KeyspaceParams.Option
- REPLICATION_DONE_REQ - org.apache.cassandra.net.Verb
- REPLICATION_DONE_RSP - org.apache.cassandra.net.Verb
- REPLICATION_FACTOR - Static variable in class org.apache.cassandra.locator.NetworkTopologyStrategy
- REPLICATION_FACTOR - Static variable in class org.apache.cassandra.locator.SimpleStrategy
- 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 - Variable in class org.apache.cassandra.locator.ReplicaPlan.AbstractReplicaPlan
- replicationStrategy() - Method in class org.apache.cassandra.locator.ReplicaLayout
- replicationStrategy() - Method in class org.apache.cassandra.locator.ReplicaPlan.AbstractReplicaPlan
- replicationStrategy() - Method in interface 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
- reportAllocatedMemory() - Method in class org.apache.cassandra.db.partitions.BTreePartitionUpdater
- reportCompactionTable(List<Map<String, String>>, long, boolean, boolean, PrintStream, TableBuilder) - Static method in class org.apache.cassandra.tools.nodetool.CompactionStats
- reportCompactionTable(List<Map<String, String>>, long, boolean, PrintStream, TableBuilder) - Static method in class org.apache.cassandra.tools.nodetool.CompactionStats
- 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
- repr - Variable in class org.apache.cassandra.io.sstable.Component.Type
- Request(TableId, EndpointState, Collection<Range<Token>>) - Constructor for class org.apache.cassandra.service.paxos.cleanup.PaxosStartPrepareCleanup.Request
- Request(Message.Type) - Constructor for class org.apache.cassandra.transport.Message.Request
- REQUEST - org.apache.cassandra.config.Config.CQLStartTime
- REQUEST - org.apache.cassandra.transport.Message.Direction
- REQUEST_FAILURE - org.apache.cassandra.audit.AuditLogEntryType
- REQUEST_RESPONSE - org.apache.cassandra.concurrent.Stage
- REQUEST_RSP - org.apache.cassandra.net.Verb
-
Deprecated.See CASSANDRA-15066
- request_timeout - 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 toRequestCallback.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.
- RequestCallbacks.CallbackInfo - Class in org.apache.cassandra.net
- RequestCallbackWithFailure<T> - Interface in org.apache.cassandra.net
- 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 - Variable in class org.apache.cassandra.db.PartitionRangeReadCommand
- 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, String, ConsistencyLevel, int, int, Map<InetAddressAndPort, RequestFailureReason>) - Constructor for exception org.apache.cassandra.exceptions.RequestFailureException
- 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
- requestHandler - Static variable in class org.apache.cassandra.service.paxos.PaxosCommit
- requestHandler - Static variable in class org.apache.cassandra.service.paxos.PaxosCommitAndPrepare
- requestHandler - Static variable in class org.apache.cassandra.service.paxos.PaxosPrepare
- requestHandler - Static variable in class org.apache.cassandra.service.paxos.PaxosPrepareRefresh
- requestHandler - Static variable in class org.apache.cassandra.service.paxos.PaxosPropose
- requestHandler - Static variable in class org.apache.cassandra.service.paxos.PaxosRepair
- RequestHandler() - Constructor for class org.apache.cassandra.service.paxos.PaxosCommit.RequestHandler
- RequestHandler() - Constructor for class org.apache.cassandra.service.paxos.PaxosCommitAndPrepare.RequestHandler
- RequestHandler() - Constructor for class org.apache.cassandra.service.paxos.PaxosPrepare.RequestHandler
- RequestHandler() - Constructor for class org.apache.cassandra.service.paxos.PaxosPrepareRefresh.RequestHandler
- RequestHandler() - Constructor for class org.apache.cassandra.service.paxos.PaxosPropose.RequestHandler
- RequestHandler() - Constructor for class org.apache.cassandra.service.paxos.PaxosRepair.RequestHandler
- 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.
- RequestProcessor(Channel, Message.Request, Dispatcher.FlushItemConverter, ClientResourceLimits.Overload) - Constructor for class org.apache.cassandra.transport.Dispatcher.RequestProcessor
- 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
andranges
from specific node. - requestRanges(InetAddressAndPort, String, RangesAtEndpoint, RangesAtEndpoint, String...) - Method in class org.apache.cassandra.streaming.StreamPlan
-
Request data in
columnFamilies
underkeyspace
andranges
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 - Variable in class org.apache.cassandra.transport.ServerConnection
- REQUESTS - org.apache.cassandra.transport.ClientResourceLimits.Overload
- REQUESTS - Static variable in class org.apache.cassandra.transport.ConnectedClient
- requestSerializer - Static variable in class org.apache.cassandra.service.paxos.PaxosCommitAndPrepare
- requestSerializer - Static variable in class org.apache.cassandra.service.paxos.PaxosPrepare
- requestSerializer - Static variable in class org.apache.cassandra.service.paxos.PaxosPrepareRefresh
- requestSerializer - Static variable in class org.apache.cassandra.service.paxos.PaxosPropose
- requestSerializer - Static variable in class org.apache.cassandra.service.paxos.PaxosRepair
- RequestSerializer() - Constructor for class org.apache.cassandra.service.paxos.cleanup.PaxosStartPrepareCleanup.RequestSerializer
- RequestSerializer() - Constructor for class org.apache.cassandra.service.paxos.PaxosCommitAndPrepare.RequestSerializer
- RequestSerializer() - Constructor for class org.apache.cassandra.service.paxos.PaxosPrepare.RequestSerializer
- RequestSerializer() - Constructor for class org.apache.cassandra.service.paxos.PaxosPrepareRefresh.RequestSerializer
- RequestSerializer() - Constructor for class org.apache.cassandra.service.paxos.PaxosPropose.RequestSerializer
- RequestSerializer() - Constructor for class org.apache.cassandra.service.paxos.PaxosRepair.RequestSerializer
- requestTime - Variable in class org.apache.cassandra.service.reads.AbstractReadExecutor
- requestTime - Variable in class org.apache.cassandra.service.reads.repair.AbstractReadRepair
- requestTime - Variable in class org.apache.cassandra.service.reads.ResponseResolver
- RequestTime(long) - Constructor for class org.apache.cassandra.transport.Dispatcher.RequestTime
- RequestTime(long, long) - Constructor for class org.apache.cassandra.transport.Dispatcher.RequestTime
- 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_client_auth - Variable in class org.apache.cassandra.security.AbstractSslContextFactory
- REQUIRE_CLIENT_AUTH - org.apache.cassandra.config.EncryptionOptions.ConfigKey
- require_endpoint_verification - Variable in class org.apache.cassandra.config.EncryptionOptions
- require_endpoint_verification - Variable in class org.apache.cassandra.security.AbstractSslContextFactory
- REQUIRE_ENDPOINT_VERIFICATION - org.apache.cassandra.config.EncryptionOptions.ConfigKey
- 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.MutualTlsAuthenticator
- requireAuthentication() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
- requireAuthorization() - Method in class org.apache.cassandra.auth.AbstractCIDRAuthorizer
- requireAuthorization() - Method in class org.apache.cassandra.auth.AllowAllAuthorizer
- requireAuthorization() - Method in class org.apache.cassandra.auth.AllowAllCIDRAuthorizer
- 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.ICIDRAuthorizer
- 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
- requiresAllowFilteringIfNotSpecified() - Method in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
- requiresRead() - Method in class org.apache.cassandra.cql3.Constants.Adder
- 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
- reserveAndGetDelay(TimeUnit) - Method in class org.apache.cassandra.utils.concurrent.NonBlockingRateLimiter
-
Reserves a single permit slot on the timeline which may not yet be available.
- RESERVED_POOL_SPACE_IN_MiB - 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 enum org.apache.cassandra.config.CassandraRelevantProperties
-
Sets the property to its default value if a default value was specified.
- 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.cql3.selection.VectorSelector
- reset() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
- reset() - Static method in class org.apache.cassandra.db.MessageParams
- reset() - Method in class org.apache.cassandra.db.rows.BTreeRow.Builder
- reset() - Method in class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- reset() - Method in class org.apache.cassandra.index.sai.disk.v1.keystore.KeyLookup.Cursor
- reset() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
-
Simulate the index going through a restart of node
- reset() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormatPartitionWriter
- reset() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableKeyReader
- reset() - Method in class org.apache.cassandra.io.sstable.format.SortedTablePartitionWriter
- reset() - Method in interface org.apache.cassandra.io.sstable.KeyReader
-
Resets the iterator to the initial position
- reset() - Method in interface org.apache.cassandra.io.tries.IncrementalTrieWriter
- reset() - Method in class org.apache.cassandra.io.tries.IncrementalTrieWriterPageAware
- reset() - Method in class org.apache.cassandra.io.tries.IncrementalTrieWriterSimple
- reset() - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
- reset() - Method in class org.apache.cassandra.io.util.RandomAccessReader
- reset() - Method in class org.apache.cassandra.metrics.CacheMetrics
- reset() - Method in class org.apache.cassandra.metrics.MinMaxAvgMetric
- reset() - Static method in class org.apache.cassandra.service.reads.thresholds.CoordinatorWarnings
- reset() - Method in class org.apache.cassandra.utils.DefaultValue
- reset() - Static method in class org.apache.cassandra.utils.FBUtilities
- reset(boolean) - Method in class org.apache.cassandra.cql3.selection.Selector.InputRow
-
Reset the row internal state.
- reset(boolean) - Method in class org.apache.cassandra.schema.DefaultSchemaUpdateHandler
- reset(boolean) - Method in class org.apache.cassandra.schema.OfflineSchemaUpdateHandler
- reset(boolean) - Method in interface org.apache.cassandra.schema.SchemaUpdateHandler
-
Resets the schema either by reloading data from the local storage or from the other nodes.
- reset(long) - Method in interface org.apache.cassandra.io.util.BytesReadTracker
-
reset counter to @param count
- 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(InputStream) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer
- 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.sai.analyzer.AbstractAnalyzer
- 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(NODE) - Method in class org.apache.cassandra.io.tries.IncrementalTrieWriterBase
- reset(Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
(Re)initializes the tracker, purging all references.
- reset(DataPosition) - Method in class org.apache.cassandra.io.util.FileSegmentInputStream
- reset(DataPosition) - Method in class org.apache.cassandra.io.util.RandomAccessReader
- reset(DataPosition) - Method in interface org.apache.cassandra.io.util.RewindableDataInput
- reset(InetAddressAndPort) - Method in class org.apache.cassandra.net.EndpointMessagingVersions
- RESET_BOOTSTRAP_PROGRESS - org.apache.cassandra.config.CassandraRelevantProperties
-
Whether we reset any found data from previously run bootstraps.
- resetAndConsumeDroppedErrors(Consumer<String>) - Method in class org.apache.cassandra.metrics.MessagingMetrics
- resetAndTruncate() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableWriter.IndexWriter
- resetAndTruncate() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableWriter.IndexWriter
- resetAndTruncate() - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter.AbstractIndexWriter
- resetAndTruncate() - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter
- resetAndTruncate() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
Reset the data file to the marked position (see
SSTableWriter.mark()
) and truncate the rest of the file. - 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(DataPosition) - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
- 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
- resetAvailableStreamedRanges() - Static method in class org.apache.cassandra.db.SystemKeyspace
- resetAvailableStreamedRangesForKeyspace(String) - 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
- 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
- resetInternal(ByteBuffer) - Method in class org.apache.cassandra.index.sai.analyzer.AbstractAnalyzer
- resetInternal(ByteBuffer) - Method in class org.apache.cassandra.index.sai.analyzer.NonTokenizingAnalyzer
- resetLastTimestamp(long) - Static method in class org.apache.cassandra.service.ClientState
- resetLimit() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
- resetLocalSchema() - Method in class org.apache.cassandra.schema.Schema
-
Clear all locally stored schema information and fetch schema from another node.
- 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
- resetPathLength(int) - Method in interface org.apache.cassandra.db.tries.Trie.ResettingTransitionsReceiver
-
Delete all bytes beyond the given length.
- resetPathLength(int) - Method in interface org.apache.cassandra.db.tries.Trie.ValueConsumer
- resetPathLength(int) - Method in class org.apache.cassandra.db.tries.TriePathReconstructor
- resetPreparedStatements() - Static method in class org.apache.cassandra.db.SystemKeyspace
- resetSize() - Method in class org.apache.cassandra.utils.DirectorySizeCalculator
-
Reset the size to 0 in case that the size calculator is used multiple times
- resetSSTableFormats(Iterable<SSTableFormat.Factory>, Config.SSTableConfig) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- ResettableByteBuffersIndexOutput - Class in org.apache.cassandra.index.sai.disk
-
A wrapper around
ByteBuffersIndexOutput
that adds several methods that interact with the underlying delegate. - ResettableByteBuffersIndexOutput(int, String) - Constructor for class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- ResettableByteBuffersIndexOutput(String) - Constructor for class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- 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
- ResizableThreadPoolMXBean - Interface in org.apache.cassandra.concurrent
- resolve() - Method in class org.apache.cassandra.service.reads.DataResolver
- resolve(Object[], int, int) - Method in interface org.apache.cassandra.utils.btree.BTree.Builder.Resolver
- resolve(Runnable) - Method in class org.apache.cassandra.service.reads.DataResolver
- resolve(Collection<T>) - Method in interface org.apache.cassandra.db.tries.Trie.CollectionMergeResolver
- resolve(Map<String, ParameterizedClass>) - Method in class org.apache.cassandra.config.InheritingClass
- resolve(BTree.Builder.Resolver) - Method in class org.apache.cassandra.utils.btree.BTree.Builder
- resolve(T, T) - Method in interface org.apache.cassandra.db.tries.Trie.CollectionMergeResolver
- resolve(T, T) - Method in interface org.apache.cassandra.db.tries.Trie.MergeResolver
- resolve(V, V) - Method in interface org.apache.cassandra.utils.btree.BTree.Builder.QuickResolver
- RESOLVE_MULTIPLE_IP_ADDRESSES_PER_DNS_RECORD_KEY - Static variable in class org.apache.cassandra.locator.SimpleSeedProvider
- 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
- respond(V, Message<?>) - Method in interface org.apache.cassandra.net.MessageDelivery
- respond(V, Message<?>) - Method in class org.apache.cassandra.net.MessagingService
-
Send a message to a given endpoint.
- RESPOND_TO - org.apache.cassandra.net.ParamType
- respondTo() - Method in class org.apache.cassandra.net.Message
-
The originator of the request - used when forwarding and will differ from
Message.from()
- respondWithFailure(RequestFailureReason, Message<?>) - Method in interface org.apache.cassandra.net.MessageDelivery
- response(ReadResponse) - Method in class org.apache.cassandra.service.reads.ReadCallback
- Response(Message.Type) - Constructor for class org.apache.cassandra.transport.Message.Response
- RESPONSE - org.apache.cassandra.transport.Message.Direction
- responseHandler - Variable in class org.apache.cassandra.transport.SimpleClient
- ResponseResolver<E extends Endpoints<E>,P extends ReplicaPlan.ForRead<E,P>> - Class in org.apache.cassandra.service.reads
- ResponseResolver(ReadCommand, Supplier<? extends P>, Dispatcher.RequestTime) - 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
- responseSerializer - Static variable in class org.apache.cassandra.service.paxos.PaxosPrepare
- responseSerializer - Static variable in class org.apache.cassandra.service.paxos.PaxosPrepareRefresh
- responseSerializer - Static variable in class org.apache.cassandra.service.paxos.PaxosPropose
- responseSerializer - Static variable in class org.apache.cassandra.service.paxos.PaxosRepair
- ResponseSerializer() - Constructor for class org.apache.cassandra.service.paxos.PaxosPrepare.ResponseSerializer
- ResponseSerializer() - Constructor for class org.apache.cassandra.service.paxos.PaxosPrepareRefresh.ResponseSerializer
- ResponseSerializer() - Constructor for class org.apache.cassandra.service.paxos.PaxosPropose.ResponseSerializer
- ResponseSerializer() - Constructor for class org.apache.cassandra.service.paxos.PaxosRepair.ResponseSerializer
- responsesMatch() - Method in class org.apache.cassandra.service.reads.DigestResolver
- responseVerb - Variable in enum org.apache.cassandra.net.Verb
- 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
- restart(AbstractPaxosRepair.State) - Method in class org.apache.cassandra.service.paxos.AbstractPaxosRepair
- restart(AbstractPaxosRepair.State, long) - Method in class org.apache.cassandra.service.paxos.AbstractPaxosRepair
- restart(AbstractPaxosRepair.State, long) - Method in class org.apache.cassandra.service.paxos.PaxosRepair
- 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.
- RESTORE_REPLICA_COUNT - org.apache.cassandra.streaming.StreamOperation
- 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.CIDRPermissions
-
Determines whether this permissions object restricts access from some CIDR groups or allows access from any CIDR group
- 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)
- restrictsNonStaticRow() - Method in class org.apache.cassandra.index.sai.plan.FilterTree
- 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
- Result(AbstractPaxosRepair.Result.Outcome) - Constructor for class org.apache.cassandra.service.paxos.AbstractPaxosRepair.Result
- RESULT - org.apache.cassandra.transport.Message.Type
- ResultBuilder(AtomicBoolean, Map<String, List<CompositeData>>, List<String>) - Constructor for class org.apache.cassandra.metrics.SamplingManager.ResultBuilder
- resultify(String, PartitionIterator) - Static method in class org.apache.cassandra.cql3.QueryProcessor
- resultify(String, RowIterator) - Static method in class org.apache.cassandra.cql3.QueryProcessor
- ResultMessage - Class in org.apache.cassandra.transport.messages
- ResultMessage(ResultMessage.Kind) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage
- ResultMessage.Kind - Enum in org.apache.cassandra.transport.messages
- ResultMessage.Prepared - Class in org.apache.cassandra.transport.messages
- ResultMessage.Rows - Class in org.apache.cassandra.transport.messages
- ResultMessage.SchemaChange - Class in org.apache.cassandra.transport.messages
- ResultMessage.SetKeyspace - Class in org.apache.cassandra.transport.messages
- ResultMessage.Void - Class in org.apache.cassandra.transport.messages
- resultMetadata - Variable in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
-
Describes the results of executing this prepared statement
- 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(MD5Digest, List<ColumnSpecification>) - Constructor for class org.apache.cassandra.cql3.ResultSet.ResultMetadata
- 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
- results - Variable in class org.apache.cassandra.metrics.SamplingManager.ResultBuilder
- results - Variable in class org.apache.cassandra.repair.CoordinatedRepairResult
- 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, boolean) - Constructor for class org.apache.cassandra.cql3.selection.ResultSetBuilder
- ResultSetBuilder(ResultSet.ResultMetadata, Selection.Selectors, boolean, GroupMaker) - Constructor for class org.apache.cassandra.cql3.selection.ResultSetBuilder
- resultType - Variable in class org.apache.cassandra.cql3.functions.UDFunction
- 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
- retain(ColumnData) - Method in class org.apache.cassandra.db.rows.ColumnData.Reconciler
-
Checks if the specified value should be deleted or not.
- retainable() - Method in class org.apache.cassandra.db.AbstractArrayClusteringPrefix
- retainable() - Method in class org.apache.cassandra.db.AbstractBufferClusteringPrefix
- retainable() - Method in interface org.apache.cassandra.db.ClusteringPrefix
-
Return the key in a form that can be retained for longer-term use.
- retainable() - Method in class org.apache.cassandra.db.DecoratedKey
-
If this key occupies only part of a larger buffer, allocate a new buffer that is only as large as necessary.
- retainable() - Method in class org.apache.cassandra.db.NativeClustering
- retainAll(Collection<?>) - Method in class org.apache.cassandra.utils.btree.BTreeSet
- retainAll(Collection<?>) - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- retainAll(Collection<?>) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
- rethrowIfFailed() - Method in interface org.apache.cassandra.utils.concurrent.Future
- retries - Variable in class org.apache.cassandra.config.RepairConfig
- retries - Static variable in class org.apache.cassandra.metrics.RepairMetrics
- retriesByVerb - Static variable in class org.apache.cassandra.metrics.RepairMetrics
- retrieveCidrsFromRow(UntypedResultSet.Row) - Method in class org.apache.cassandra.auth.CIDRGroupsMappingManager
- retrieveTemporaryBuffer(int) - Static method in class org.apache.cassandra.io.util.DataOutputStreamPlus
- retry() - Method in class org.apache.cassandra.net.OutboundConnectionInitiator.Result
- retry(Verb, int) - Static method in class org.apache.cassandra.metrics.RepairMetrics
- retryFailure - Static variable in class org.apache.cassandra.metrics.RepairMetrics
- retryFailure(Verb) - Static method in class org.apache.cassandra.metrics.RepairMetrics
- retryFailureByVerb - Static variable in class org.apache.cassandra.metrics.RepairMetrics
- RetrySpec - Class in org.apache.cassandra.config
- RetrySpec() - Constructor for class org.apache.cassandra.config.RetrySpec
- RetrySpec(RetrySpec.MaxAttempt, DurationSpec.LongMillisecondsBound, DurationSpec.LongMillisecondsBound) - Constructor for class org.apache.cassandra.config.RetrySpec
- RetrySpec.MaxAttempt - Class in org.apache.cassandra.config
- RetrySpec.Partial - Class in org.apache.cassandra.config
- retryTimeout - Static variable in class org.apache.cassandra.metrics.RepairMetrics
- retryTimeout(Verb) - Static method in class org.apache.cassandra.metrics.RepairMetrics
- retryTimeoutByVerb - Static variable in class org.apache.cassandra.metrics.RepairMetrics
- 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
- RETURNED_WORK_PERMIT - org.apache.cassandra.concurrent.SEPExecutor.TakeTaskPermitResult
- 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 - Variable in enum org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL.Kind
- 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() - Method in interface org.apache.cassandra.utils.concurrent.LightweightRecycler
- reuse(Comparator<? super V>) - Method in class org.apache.cassandra.utils.btree.BTree.Builder
- reuseOrAllocate(Supplier<T>) - Method in interface org.apache.cassandra.utils.concurrent.LightweightRecycler
- 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
- reverse() - Method in class org.apache.cassandra.utils.concurrent.IntrusiveStack
- reverse(T) - Static method in class org.apache.cassandra.utils.concurrent.IntrusiveStack
- reverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
- reversed - Variable in class org.apache.cassandra.db.AbstractReadCommandBuilder
- reversed - Variable in class org.apache.cassandra.db.filter.AbstractClusteringIndexFilter
- reversed() - Method in class org.apache.cassandra.db.ClusteringComparator
- 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.
- reverseInSitu(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
- 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
- ReverseValueIterator<Concrete extends ReverseValueIterator<Concrete>> - Class in org.apache.cassandra.io.tries
-
Thread-unsafe reverse value iterator for on-disk tries.
- ReverseValueIterator(Rebufferer, long) - Constructor for class org.apache.cassandra.io.tries.ReverseValueIterator
- ReverseValueIterator(Rebufferer, long, ByteComparable, ByteComparable, boolean) - Constructor for class org.apache.cassandra.io.tries.ReverseValueIterator
-
Constrained iterator.
- 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.
- REVOKE - org.apache.cassandra.audit.AuditLogEntryType
- 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
- 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
- rewriteSSTables(String, boolean, long, boolean, int, String...) - Method in class org.apache.cassandra.service.StorageService
- rewriteTOC(Descriptor, Collection<Component>) - Static method in class org.apache.cassandra.io.sstable.format.TOCComponent
-
Rewrite TOC components by deleting existing TOC file and append new components
- 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 - 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.dht.Splitter.WeightedRange
- 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 - org.apache.cassandra.config.CassandraRelevantProperties
- RING_DELAY_MILLIS - Static variable in class org.apache.cassandra.service.StorageService
- RING_VERSION_IRRELEVANT - Static variable in class org.apache.cassandra.db.ColumnFamilyStore
-
Special values used when the local ranges are not changed with ring changes (e.g.
- 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.
- ringVersion - Variable in class org.apache.cassandra.db.ColumnFamilyStore.VersionedLocalRanges
- ringVersion - Variable in class org.apache.cassandra.db.memtable.ShardBoundaries
- RMIClientSocketFactoryImpl - Class in org.apache.cassandra.utils
-
This class is used to override the local address the JMX client calculates when trying to connect, which can otherwise be influenced by the system property "java.rmi.server.hostname" in strange and unpredictable ways.
- RMIClientSocketFactoryImpl(InetAddress) - Constructor for class org.apache.cassandra.utils.RMIClientSocketFactoryImpl
- RMIServerSocketFactoryImpl - Class in org.apache.cassandra.utils
- RMIServerSocketFactoryImpl(InetAddress) - Constructor for class org.apache.cassandra.utils.RMIServerSocketFactoryImpl
- role - Variable in class org.apache.cassandra.cql3.statements.RoleManagementStatement
- role(String) - Static method in class org.apache.cassandra.auth.RoleResource
-
Creates a RoleResource representing an individual Role.
- 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_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
- roleForIdentity(String) - Method in class org.apache.cassandra.auth.CassandraRoleManager
- roleForIdentity(String) - Method in interface org.apache.cassandra.auth.IRoleManager
-
Each valid identity is associated with a role in the identity_to_role table, this method returns role of a given identity
- 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 - Class in org.apache.cassandra.auth
- Roles() - Constructor for class org.apache.cassandra.auth.Roles
- ROLES - Static variable in class org.apache.cassandra.auth.AuthKeyspace
- roles_cache_active_update - Variable in class org.apache.cassandra.config.Config
- roles_cache_max_entries - Variable in class org.apache.cassandra.config.Config
- roles_update_interval - Variable in class org.apache.cassandra.config.Config
- roles_validity - 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
- RolesCacheMBean - Interface in org.apache.cassandra.auth
- roll_cycle - Variable in class org.apache.cassandra.utils.binlog.BinLogOptions
-
How often to roll BinLog segments so they can potentially be reclaimed.
- ROLL_CYCLE - Static variable in class org.apache.cassandra.audit.AuditLogOptionsCompositeData.AuditLogOption
- rollCycle(String) - Method in class org.apache.cassandra.utils.binlog.BinLog.Builder
- root - Variable in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata.ComponentMetadata
- root - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
- root - Variable in class org.apache.cassandra.io.tries.Walker
- 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 method in class org.apache.cassandra.auth.RoleResource
- root() - Method in interface org.apache.cassandra.io.tries.IncrementalTrieWriter.PartialTail
-
Position of the root of the partial representation.
- ROOT - Static variable in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata.ComponentMetadata
- rotl64(long, int) - Static method in class org.apache.cassandra.utils.MurmurHash
- round(Number) - Method in class org.apache.cassandra.db.marshal.ByteType
- round(Number) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
- round(Number) - Method in class org.apache.cassandra.db.marshal.DecimalType
- round(Number) - Method in class org.apache.cassandra.db.marshal.DoubleType
- round(Number) - Method in class org.apache.cassandra.db.marshal.FloatType
- round(Number) - Method in class org.apache.cassandra.db.marshal.Int32Type
- round(Number) - Method in class org.apache.cassandra.db.marshal.IntegerType
- round(Number) - Method in class org.apache.cassandra.db.marshal.LongType
- round(Number) - Method in class org.apache.cassandra.db.marshal.NumberType
-
Rounds the argument to the nearest whole number.
- round(Number) - Method in class org.apache.cassandra.db.marshal.ShortType
- 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
. - roundFct(NumberType<?>) - Static method in class org.apache.cassandra.cql3.functions.MathFcts
- 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 betweenDiskOptimizationStrategy.MIN_BUFFER_SIZE
andDiskOptimizationStrategy.MAX_BUFFER_SIZE
. - roundTrips - Variable in class org.apache.cassandra.metrics.ClientRangeRequestMetrics
-
Metric for tracking the number of round trips made for a range request.
- 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(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(Object...) - Method in class org.apache.cassandra.db.SimpleBuilders.PartitionUpdateBuilder
- row(Object...) - Method in class org.apache.cassandra.db.virtual.SimpleDataSet
- row(TableMetadata, DecoratedKey, boolean) - Static method in class org.apache.cassandra.db.EmptyIterators
- Row - Interface in org.apache.cassandra.db.rows
-
Storage engine representation of a row.
- Row(List<ColumnSpecification>, List<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.UntypedResultSet.Row
- Row(Map<String, ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.UntypedResultSet.Row
- ROW - org.apache.cassandra.db.rows.Unfiltered.Kind
- ROW - org.apache.cassandra.schema.CompactionParams.TombstoneOption
- ROW_CACHE - org.apache.cassandra.service.CacheService.CacheType
- 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 - org.apache.cassandra.db.compaction.OperationType
- row_cache_save_period - Variable in class org.apache.cassandra.config.Config
- row_cache_size - Variable in class org.apache.cassandra.config.Config
- ROW_INDEX - Static variable in class org.apache.cassandra.io.sstable.format.bti.BtiFormat.Components
- ROW_INDEX - Static variable in class org.apache.cassandra.io.sstable.format.bti.BtiFormat.Components.Types
- ROW_INDEX_READ_SIZE_FAIL - org.apache.cassandra.net.ParamType
- row_index_read_size_fail_threshold - Variable in class org.apache.cassandra.config.Config
- ROW_INDEX_READ_SIZE_WARN - org.apache.cassandra.net.ParamType
- row_index_read_size_warn_threshold - Variable in class org.apache.cassandra.config.Config
- ROW_KEY - org.apache.cassandra.db.PartitionPosition.Kind
- ROW_OVERHEAD_HEAP_SIZE - Static variable in class org.apache.cassandra.db.memtable.SkipListMemtable
- ROW_TO_PARTITION - org.apache.cassandra.index.sai.disk.format.IndexComponent
-
An on-disk block packed index mapping rowIds to partitionIds.
- ROW_TO_TOKEN - org.apache.cassandra.index.sai.disk.format.IndexComponent
-
An on-disk block packed index mapping rowIds to token values.
- 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.
- 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(OpOrder.Group) - Method in class org.apache.cassandra.utils.memory.NativeAllocator
- RowBuilder(TableMetadata, Object...) - Constructor for class org.apache.cassandra.db.SimpleBuilders.RowBuilder
- 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(TableId, String, ByteBuffer) - Constructor for class org.apache.cassandra.cache.RowCacheKey
- RowCacheKey(TableMetadata, DecoratedKey) - 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() - Method in interface org.apache.cassandra.db.ReadQuery
-
Filters/Resrictions on CQL rows.
- rowFilter() - Method in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
- RowFilter - Class in org.apache.cassandra.db.filter
-
A filter on which rows a given query should include or exclude.
- RowFilter(List<RowFilter.Expression>, boolean) - Constructor for class org.apache.cassandra.db.filter.RowFilter
- 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
- rowIdFromPrimaryKey(PrimaryKey) - Method in interface org.apache.cassandra.index.sai.disk.PrimaryKeyMap
-
Returns a row ID for a
PrimaryKey
- rowIdFromPrimaryKey(PrimaryKey) - Method in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap
- rowIdFromPrimaryKey(PrimaryKey) - Method in class org.apache.cassandra.index.sai.disk.v1.WidePrimaryKeyMap
- rowIdOffset - Variable in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata
-
Used to retrieve sstableRowId which equals to offset plus segmentRowId.
- RowIdsView() - Constructor for class org.apache.cassandra.index.sai.disk.v1.vector.OnDiskOrdinalsMap.RowIdsView
- rowIdToPartitionIdArray - Variable in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap
- rowIdToTokenArray - Variable in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap
- RowIndexEntry - Class in org.apache.cassandra.io.sstable.format.big
-
Binary format of
RowIndexEntry
is defined as follows:(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) int/Uint DeletionTime.localDeletionTime (uint if version >= "oa" (5.0)) (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.io.sstable.format.big.RowIndexEntry
- RowIndexEntry.IndexInfoRetriever - Interface in org.apache.cassandra.io.sstable.format.big
-
Base class to access
IndexInfo
objects. - RowIndexEntry.IndexSerializer - Interface in org.apache.cassandra.io.sstable.format.big
- RowIndexEntry.RowIndexEntryReadSizeTooLargeException - Exception in org.apache.cassandra.io.sstable.format.big
- RowIndexEntry.Serializer - Class in org.apache.cassandra.io.sstable.format.big
- RowIndexEntryReadSizeTooLargeException(String) - Constructor for exception org.apache.cassandra.io.sstable.format.big.RowIndexEntry.RowIndexEntryReadSizeTooLargeException
- RowIndexReader - Class in org.apache.cassandra.io.sstable.format.bti
-
Reader class for row index files created by
RowIndexWriter
. - RowIndexReader(FileHandle, long, Version) - Constructor for class org.apache.cassandra.io.sstable.format.bti.RowIndexReader
- RowIndexReader(FileHandle, TrieIndexEntry, Version) - Constructor for class org.apache.cassandra.io.sstable.format.bti.RowIndexReader
- RowIndexReader.IndexInfo - Class in org.apache.cassandra.io.sstable.format.bti
- rowIndexReadSize - Variable in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- rowIndexReadSizeAbortMessage(int, long, String) - Static method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- rowIndexSize - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
- rowIndexSize - Variable in class org.apache.cassandra.metrics.TableMetrics
- rowIndexSizeAbort(WarningsSnapshot.Counter) - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Builder
- rowIndexSizeAborts - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
- rowIndexSizeAborts - Variable in class org.apache.cassandra.metrics.TableMetrics
- rowIndexSizeWarning(WarningsSnapshot.Counter) - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Builder
- rowIndexSizeWarnings - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
- rowIndexSizeWarnings - Variable in class org.apache.cassandra.metrics.TableMetrics
- rowIndexSizeWarnMessage(int, long, String) - Static method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- rowIterator() - Method in class org.apache.cassandra.db.partitions.FilteredPartition
- rowIterator(DecoratedKey) - Method in class org.apache.cassandra.db.memtable.ShardedSkipListMemtable
- rowIterator(DecoratedKey) - Method in class org.apache.cassandra.db.memtable.SkipListMemtable
- rowIterator(DecoratedKey) - Method in class org.apache.cassandra.db.memtable.TrieMemtable
- rowIterator(DecoratedKey) - Method in interface org.apache.cassandra.db.rows.UnfilteredSource
- rowIterator(DecoratedKey, Slices, ColumnFilter, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.db.memtable.ShardedSkipListMemtable
- rowIterator(DecoratedKey, Slices, ColumnFilter, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.db.memtable.SkipListMemtable
- rowIterator(DecoratedKey, Slices, ColumnFilter, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.db.memtable.TrieMemtable
- rowIterator(DecoratedKey, Slices, ColumnFilter, boolean, SSTableReadsListener) - Method in interface org.apache.cassandra.db.rows.UnfilteredSource
-
Returns a row iterator for the given partition, applying the specified row and column filters.
- rowIterator(DecoratedKey, Slices, ColumnFilter, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- rowIterator(DecoratedKey, Slices, ColumnFilter, boolean, SSTableReadsListener) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- rowIterator(FileDataInput, DecoratedKey, RowIndexEntry, Slices, ColumnFilter, boolean) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- rowIterator(FileDataInput, DecoratedKey, TrieIndexEntry, Slices, ColumnFilter, boolean) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- 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<E, ?>) - 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.
- RowMapping - Class in org.apache.cassandra.index.sai.disk
-
In memory representation of
PrimaryKey
to row ID mappings which only containsRow
regardless of whether it's live or deleted. - rowMark - Variable in class org.apache.cassandra.service.pager.PagingState
- rowPositionSerializer - Static variable in class org.apache.cassandra.dht.AbstractBounds
- RowPositionSerializer() - Constructor for class org.apache.cassandra.db.PartitionPosition.RowPositionSerializer
- 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
- ROWS - org.apache.cassandra.transport.messages.ResultMessage.Kind
- ROWS_PER_PARTITION - org.apache.cassandra.schema.CachingParams.Option
- 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.
- rowsFiltered - Variable in class org.apache.cassandra.index.sai.QueryContext
- 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.
- rowToPartitionReaderFactory - Variable in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap.Factory
- rowToTokenReaderFactory - Variable in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap.Factory
- rpc_address - Variable in class org.apache.cassandra.config.Config
- RPC_ADDRESS - org.apache.cassandra.gms.ApplicationState
-
Deprecated.See CASSANDRA-7544
- rpc_interface - Variable in class org.apache.cassandra.config.Config
- rpc_interface_prefer_ipv6 - Variable in class org.apache.cassandra.config.Config
- rpc_keepalive - Variable in class org.apache.cassandra.config.Config
- RPC_READY - org.apache.cassandra.gms.ApplicationState
- 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 - Variable in class org.apache.cassandra.concurrent.SingleThreadExecutorPlus.AtLeastOnce
- run() - Method in class org.apache.cassandra.auth.CacheRefresher
- run() - Method in class org.apache.cassandra.concurrent.FutureTask
- run() - Method in interface org.apache.cassandra.concurrent.Interruptible.SimpleTask
- run() - Method in class org.apache.cassandra.concurrent.SingleThreadExecutorPlus.AtLeastOnce
- run() - Method in class org.apache.cassandra.concurrent.SyncFutureTask
- run() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorJMXAdapter
- 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.repair.RepairCoordinator
- run() - Method in class org.apache.cassandra.repair.RepairJob
-
Runs repair job.
- run() - Method in class org.apache.cassandra.repair.Scheduler.Task
- run() - Method in class org.apache.cassandra.repair.SnapshotTask
- run() - Method in class org.apache.cassandra.repair.StreamingRepairTask
- run() - Method in class org.apache.cassandra.repair.SyncTask
-
Compares trees, and triggers repairs for any ranges that mismatch.
- run() - Method in class org.apache.cassandra.repair.ValidationTask
-
Send ValidationRequest to replica
- run() - Method in class org.apache.cassandra.repair.Validator
-
Called after the validation lifecycle to respond with the now valid tree.
- run() - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanup
- run() - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupComplete
- run() - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupSession
- run() - Method in class org.apache.cassandra.streaming.StreamDeserializingTask
- 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.transport.Dispatcher.RequestProcessor
- run() - Method in class org.apache.cassandra.utils.binlog.BinLog
- run() - Method in class org.apache.cassandra.utils.ResourceWatcher.WatchedResource
- run() - Method in class org.apache.cassandra.utils.WrappedRunnable
- run(Interruptible.State) - Method in interface org.apache.cassandra.concurrent.Interruptible.Task
- 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
- runAfter(Runnable) - Method in interface org.apache.cassandra.concurrent.SequentialExecutorPlus.AtLeastOnceTrigger
-
Run the provided task after all queued and executing jobs have completed
- runAfter(Runnable) - Method in class org.apache.cassandra.concurrent.SingleThreadExecutorPlus.AtLeastOnce
- runAsActiveCompaction(CompactionInfo.Holder, ThrowingSupplier<T, E>) - 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
- RunnableFuture<V> - Interface in org.apache.cassandra.utils.concurrent
- RunningDebuggableTask(String, DebuggableTask) - Constructor for class org.apache.cassandra.concurrent.DebuggableTask.RunningDebuggableTask
- runningTasks() - Method in class org.apache.cassandra.concurrent.SharedExecutorPool
- 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
-
The runnable passed to this method must not be an anonymous or non-static inner class.
- runOnCommit(Runnable) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
- runOnExitThreadsAndClear() - Static method in class org.apache.cassandra.io.util.PathUtils
- runPostFlush - Variable in class org.apache.cassandra.io.util.SequentialWriter
- runRepair(TimeUUID, boolean, ExecutorPlus, Scheduler, List<CommonRange>, String...) - Method in class org.apache.cassandra.repair.AbstractRepairTask
- runStartupChecks() - Method in class org.apache.cassandra.service.CassandraDaemon
- runtimeProxy - Variable in class org.apache.cassandra.tools.NodeProbe
- runWithCompactionsDisabled(Callable<V>, Predicate<SSTableReader>, OperationType, boolean, boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Runs callable with compactions paused and compactions including sstables matching sstablePredicate stopped
- runWithCompactionsDisabled(Callable<V>, OperationType, boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- runWithLock(CheckedFunction<Descriptor, R, E>) - 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
- RW - org.apache.cassandra.db.Directories.FileAction
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
- SAFE - org.apache.cassandra.concurrent.InfiniteLoopExecutor.SimulatorSafe
- 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
- SAI_DESCRIPTOR - Static variable in class org.apache.cassandra.index.sai.disk.format.Version
- sai_frozen_term_size_fail_threshold - Variable in class org.apache.cassandra.config.Config
- sai_frozen_term_size_warn_threshold - Variable in class org.apache.cassandra.config.Config
- SAI_INTERSECTION_CLAUSE_LIMIT - org.apache.cassandra.config.CassandraRelevantProperties
-
Controls the maximum number of index query intersections that will take part in a query
- SAI_LATEST_VERSION - org.apache.cassandra.config.CassandraRelevantProperties
-
Latest version to be used for SAI index writing
- SAI_MINIMUM_POSTINGS_LEAVES - org.apache.cassandra.config.CassandraRelevantProperties
-
Minimum number of reachable leaves for a given node to be eligible for an auxiliary posting list
- sai_options - Variable in class org.apache.cassandra.config.Config
- SAI_POSTINGS_SKIP - org.apache.cassandra.config.CassandraRelevantProperties
-
Skip, or the sampling interval, for selecting a balanced tree level that is eligible for an auxiliary posting list.
- SAI_SEPARATOR - Static variable in class org.apache.cassandra.index.sai.disk.format.Version
- SAI_SORTED_TERMS_CLUSTERING_BLOCK_SHIFT - org.apache.cassandra.config.CassandraRelevantProperties
-
Used to determine the block size and block mask for the clustering sorted terms.
- SAI_SORTED_TERMS_PARTITION_BLOCK_SHIFT - org.apache.cassandra.config.CassandraRelevantProperties
-
Used to determine the block size and block mask for the partition sorted terms.
- sai_sstable_indexes_per_query_fail_threshold - Variable in class org.apache.cassandra.config.Config
- sai_sstable_indexes_per_query_warn_threshold - Variable in class org.apache.cassandra.config.Config
- sai_string_term_size_fail_threshold - Variable in class org.apache.cassandra.config.Config
- sai_string_term_size_warn_threshold - Variable in class org.apache.cassandra.config.Config
- SAI_TEST_BALANCED_TREE_DEBUG_ENABLED - org.apache.cassandra.config.CassandraRelevantProperties
- SAI_TEST_DISABLE_TIMEOUT - org.apache.cassandra.config.CassandraRelevantProperties
- SAI_VECTOR_ALLOW_CUSTOM_PARAMETERS - org.apache.cassandra.config.CassandraRelevantProperties
-
Whether to allow the user to specify custom options to the hnsw index
- SAI_VECTOR_SEARCH_MAX_TOP_K - org.apache.cassandra.config.CassandraRelevantProperties
-
Controls the maximum top-k limit for vector search
- SAI_VECTOR_SEARCH_ORDER_CHUNK_SIZE - org.apache.cassandra.config.CassandraRelevantProperties
-
Controls the maximum number of PrimaryKeys that will be read into memory at one time when ordering/limiting the results of an ANN query constrained by non-ANN predicates.
- sai_vector_term_size_fail_threshold - Variable in class org.apache.cassandra.config.Config
- sai_vector_term_size_warn_threshold - Variable in class org.apache.cassandra.config.Config
- SAICodecUtils - Class in org.apache.cassandra.index.sai.disk.v1
- SAICodecUtils() - Constructor for class org.apache.cassandra.index.sai.disk.v1.SAICodecUtils
- saiFrozenTermSize - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the size of a frozen term written to SAI index.
- saiSSTableIndexesPerQuery - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
- saiStringTermSize - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the size of a string term written to SAI index.
- saiVectorTermSize - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the size of a vector term written to SAI index.
- sameAs(int, boolean, FunctionParameter) - Static method in interface org.apache.cassandra.cql3.functions.FunctionParameter
- 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
- samplePartitions(String, int, int, int, List<String>) - Method in class org.apache.cassandra.service.StorageService
- samplePartitions(String, 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
- sampleReadLatencyMicros - Variable in class org.apache.cassandra.db.ColumnFamilyStore
- samplers - Variable in class org.apache.cassandra.metrics.TableMetrics
- SamplingManager - Class in org.apache.cassandra.metrics
- SamplingManager() - Constructor for class org.apache.cassandra.metrics.SamplingManager
- SamplingManager.ResultBuilder - Class in org.apache.cassandra.metrics
- SASI_INDEX_DISABLED - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- sasi_indexes_enabled - Variable in class org.apache.cassandra.config.Config
- SASIIndex - Class in org.apache.cassandra.index.sasi
- SASIIndex(ColumnFamilyStore, IndexMetadata) - Constructor for class org.apache.cassandra.index.sasi.SASIIndex
- SASIIndexGroup - Class in org.apache.cassandra.index.sasi
- SASIIndexGroup(SASIIndex) - Constructor for class org.apache.cassandra.index.sasi.SASIIndexGroup
- SASIIndexQueryPlan - Class in org.apache.cassandra.index.sasi.plan
- SASIIndexSearcher - Class in org.apache.cassandra.index.sasi.plan
- SASIIndexSearcher(ColumnFamilyStore, ReadCommand, long) - Constructor for class org.apache.cassandra.index.sasi.plan.SASIIndexSearcher
- 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
- saturatingCastToLong(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 long with maximum value of
Cell.MAX_DELETION_TIME
to avoid representing values that aren't a tombstone - save() - Method in class org.apache.cassandra.metrics.TopPartitionTracker
- save(Descriptor) - Method in class org.apache.cassandra.io.sstable.format.StatsComponent
- save(File, boolean) - Method in class org.apache.cassandra.io.sstable.format.big.IndexSummaryComponent
-
Save index summary to Summary.db file.
- save(IFilter, Descriptor, boolean) - Static method in class org.apache.cassandra.io.sstable.format.FilterComponent
- 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
- savePaxosProposal(Commit) - Static method in class org.apache.cassandra.db.SystemKeyspace
- savePaxosReadPromise(DecoratedKey, TableMetadata, Ballot) - Static method in class org.apache.cassandra.db.SystemKeyspace
- savePaxosRepairHistory(String, String, PaxosRepairHistory, boolean) - Static method in class org.apache.cassandra.db.SystemKeyspace
- savePaxosWritePromise(DecoratedKey, TableMetadata, Ballot) - Static method in class org.apache.cassandra.db.SystemKeyspace
- saveTask - Variable in class org.apache.cassandra.cache.AutoSavingCache
- saveTopPartitions(TableMetadata, String, Collection<TopPartitionTracker.TopPartition>, long) - Static method in class org.apache.cassandra.db.SystemKeyspace
- saveTruncationRecord(ColumnFamilyStore, long, CommitLogPosition) - Static method in class org.apache.cassandra.db.SystemKeyspace
- sawCDCMutation - Variable in class org.apache.cassandra.db.commitlog.CommitLogReplayer
- SCALAR_FUNCTION_SELECTOR - org.apache.cassandra.cql3.selection.Selector.Kind
- ScalarFunction - Interface in org.apache.cassandra.cql3.functions
-
Determines a single output value based on any number of input values.
- ScalingReservoir - Class in org.apache.cassandra.metrics
-
A reservoir that scales the values before updating.
- ScalingReservoir(SnapshottingReservoir, ScalingReservoir.ScaleFunction) - Constructor for class org.apache.cassandra.metrics.ScalingReservoir
- ScalingReservoir.ScaleFunction - Interface in org.apache.cassandra.metrics
-
Scale the 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.
- ScanAllRangesCommandIterator - Class in org.apache.cassandra.service.reads.range
-
A custom
RangeCommandIterator
that queries all replicas required by consistency level at once with data range specify inPartitionRangeReadCommand
. - 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
- schedule(Runnable, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- schedule(Callable<V>, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- schedule(Supplier<Future<T>>, Executor) - Method in interface org.apache.cassandra.repair.Scheduler
- schedule(Scheduler.Task<T>, Executor) - Method in class org.apache.cassandra.repair.Scheduler.LimitedConcurrentScheduler
- schedule(Scheduler.Task<T>, Executor) - Method in class org.apache.cassandra.repair.Scheduler.NoopScheduler
- schedule(Scheduler.Task<T>, Executor) - Method in interface org.apache.cassandra.repair.Scheduler
- scheduleAt(Runnable, long) - Method in interface org.apache.cassandra.concurrent.ScheduledExecutorPlus
-
Schedule a timeout action.
- scheduleAt(Runnable, long) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- scheduled(boolean, String) - Method in interface org.apache.cassandra.concurrent.ExecutorFactory
- scheduled(boolean, String, int) - Method in interface org.apache.cassandra.concurrent.ExecutorFactory
- scheduled(boolean, String, int, ExecutorFactory.SimulatorSemantics) - Method in class org.apache.cassandra.concurrent.ExecutorFactory.Default
- scheduled(boolean, String, int, ExecutorFactory.SimulatorSemantics) - Method in interface org.apache.cassandra.concurrent.ExecutorFactory
- scheduled(String) - Method in interface org.apache.cassandra.concurrent.ExecutorFactory
- scheduled(String, ExecutorFactory.SimulatorSemantics) - Method in interface org.apache.cassandra.concurrent.ExecutorFactory
- scheduledBytes() - Method in class org.apache.cassandra.net.InboundMessageHandlers
- scheduledCount() - Method in class org.apache.cassandra.net.InboundMessageHandlers
- ScheduledExecutorPlus - Interface in org.apache.cassandra.concurrent
- 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.
- scheduledTasks() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- scheduledTasks() - Method in class org.apache.cassandra.repair.SharedContext.Global
- scheduledTasks() - Method in interface org.apache.cassandra.repair.SharedContext
- ScheduledThreadPoolExecutorPlus - Class in org.apache.cassandra.concurrent
-
Like ExecutorPlus, ScheduledThreadPoolExecutorPlus always logs exceptions from the tasks it is given, even if Future.get is never called elsewhere.
- scheduleLogging() - Method in class org.apache.cassandra.metrics.MessagingMetrics
- Scheduler - Interface in org.apache.cassandra.repair
-
Task scheduler that limits the number of concurrent tasks across multiple executors.
- Scheduler.LimitedConcurrentScheduler - Class in org.apache.cassandra.repair
- Scheduler.NoopScheduler - Class in org.apache.cassandra.repair
- Scheduler.Task<T> - Class in org.apache.cassandra.repair
- scheduleSaving(int, int) - Method in class org.apache.cassandra.cache.AutoSavingCache
- scheduleSegmentFlush(boolean) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
- scheduleSelfRecurring(Runnable, long, TimeUnit) - Method in interface org.apache.cassandra.concurrent.ScheduledExecutorPlus
-
Schedule an action that is recurring but self-administered.
- scheduleSelfRecurring(Runnable, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- 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.
- scheduleTimeoutAt(Runnable, long) - Method in interface org.apache.cassandra.concurrent.ScheduledExecutorPlus
-
Schedule a timeout action.
- scheduleTimeoutAt(Runnable, long) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- scheduleTimeoutWithDelay(Runnable, long, TimeUnit) - Method in interface org.apache.cassandra.concurrent.ScheduledExecutorPlus
-
Schedule a timeout action.
- scheduleTimeoutWithDelay(Runnable, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- schema(boolean) - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
-
Creates a
DescribeStatement
forDESCRIBE [FULL] SCHEMA
. - schema(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- Schema - Class in org.apache.cassandra.schema
-
Manages shared schema, keyspace instances and table metadata refs.
- Schema(boolean, Keyspaces, SchemaUpdateHandler) - Constructor for class org.apache.cassandra.schema.Schema
- SCHEMA - org.apache.cassandra.gms.ApplicationState
- SCHEMA_CHANGE - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- SCHEMA_CHANGE - org.apache.cassandra.transport.Event.Type
- SCHEMA_CHANGE - org.apache.cassandra.transport.messages.ResultMessage.Kind
- SCHEMA_DELAY_MILLIS - Static variable in class org.apache.cassandra.service.StorageService
- SCHEMA_KEYSPACE_NAME - Static variable in class org.apache.cassandra.schema.SchemaConstants
- SCHEMA_PULL_INTERVAL_MS - org.apache.cassandra.config.CassandraRelevantProperties
- SCHEMA_PULL_REQ - org.apache.cassandra.net.Verb
- SCHEMA_PULL_RSP - org.apache.cassandra.net.Verb
- SCHEMA_PUSH_REQ - org.apache.cassandra.net.Verb
- SCHEMA_PUSH_RSP - org.apache.cassandra.net.Verb
- SCHEMA_UPDATE_HANDLER_FACTORY_CLASS - org.apache.cassandra.config.CassandraRelevantProperties
- SCHEMA_VERSION_REQ - org.apache.cassandra.net.Verb
- SCHEMA_VERSION_RSP - org.apache.cassandra.net.Verb
- SchemaArgsParser - Class in org.apache.cassandra.repair.consistent.admin
- SchemaChange(Event.SchemaChange) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SchemaChange
- SchemaChange(Event.SchemaChange.Change, 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, Event.SchemaChange.Target, String, String, List<String>) - Constructor for class org.apache.cassandra.transport.Event.SchemaChange
- SchemaChangeListener - Interface in org.apache.cassandra.schema
- SchemaChangeNotifier - Class in org.apache.cassandra.schema
-
Registers schema change listeners and sends the notifications.
- SchemaChangeNotifier() - Constructor for class org.apache.cassandra.schema.SchemaChangeNotifier
- SchemaConstants - Class in org.apache.cassandra.schema
-
When adding new String keyspace names here, double check if it needs to be added to PartitionDenylist.canDenylistKeyspace
- 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.
- SchemaKeyspaceTables - Class in org.apache.cassandra.schema
- SchemaKeyspaceTables() - Constructor for class org.apache.cassandra.schema.SchemaKeyspaceTables
- SchemaMutationsSerializer - Class in org.apache.cassandra.schema
- SchemaMutationsSerializer() - Constructor for class org.apache.cassandra.schema.SchemaMutationsSerializer
- 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
- SCHEMATA_CLEARED - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- SCHEMATA_LOADED - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- SCHEMATA_LOADING - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- SchemaTransformation - Interface in org.apache.cassandra.schema
- SchemaTransformation.SchemaTransformationResult - Class in org.apache.cassandra.schema
-
The result of applying (on this node) a given schema transformation.
- SchemaTransformationResult(DistributedSchema, DistributedSchema, Keyspaces.KeyspacesDiff) - Constructor for class org.apache.cassandra.schema.SchemaTransformation.SchemaTransformationResult
- SchemaTransformations - Class in org.apache.cassandra.schema
-
Factory and utility methods to create simple schema transformation.
- SchemaTransformations() - Constructor for class org.apache.cassandra.schema.SchemaTransformations
- SchemaUpdateHandler - Interface in org.apache.cassandra.schema
-
Schema update handler is responsible for maintaining the shared schema and synchronizing it with other nodes in the cluster, which means pushing and pulling changes, as well as tracking the current version in the cluster.
- SchemaUpdateHandlerFactory - Interface in org.apache.cassandra.schema
- SchemaUpdateHandlerFactoryProvider - Class in org.apache.cassandra.schema
-
Provides the instance of SchemaUpdateHandler factory pointed by
CassandraRelevantProperties.SCHEMA_UPDATE_HANDLER_FACTORY_CLASS
system property. - SchemaUpdateHandlerFactoryProvider() - Constructor for class org.apache.cassandra.schema.SchemaUpdateHandlerFactoryProvider
- schemaVersionToString(UUID) - Static method in class org.apache.cassandra.schema.DistributedSchema
-
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
- scope() - Method in annotation type org.apache.cassandra.utils.Shared
- scratchBuffer - Static variable in class org.apache.cassandra.io.util.DataOutputBuffer
-
Scratch buffers used mostly for serializing in memory.
- scripted_user_defined_functions_enabled - Variable in class org.apache.cassandra.config.Config
-
Deprecated.See CASSANDRA-18252
- scrub() - Method in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- scrub() - Method in interface org.apache.cassandra.io.sstable.IScrubber
- scrub(boolean, boolean, boolean, boolean, int, String, String...) - Method in class org.apache.cassandra.service.StorageService
- 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(boolean, boolean, boolean, int, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-14092
- scrub(boolean, boolean, boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-11179
- scrub(boolean, boolean, IScrubber.Options, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- scrub(boolean, IScrubber.Options, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- scrub(boolean, IScrubber.Options, int, String, String...) - Method in class org.apache.cassandra.service.StorageService
- 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
- SCRUB - org.apache.cassandra.db.compaction.OperationType
- scrubDataDirectories() - Method in class org.apache.cassandra.service.CassandraDaemon
- 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.
- scrubInfo - Variable in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- ScrubInfo(RandomAccessReader, SSTableReader, Lock) - Constructor for class org.apache.cassandra.io.sstable.format.SortedTableScrubber.ScrubInfo
- scrubInternal(SSTableRewriter) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScrubber
- scrubInternal(SSTableRewriter) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableScrubber
- scrubInternal(SSTableRewriter) - Method in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- ScrubIterator - Class in org.apache.cassandra.io.sstable.format.bti
- ScrubPartitionIterator - Interface in org.apache.cassandra.io.sstable.format.bti
-
Iterator over the partitions of an sstable used for scrubbing.
- scrubPartitionsIterator() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- ScrubResult(int, int, int) - Constructor for class org.apache.cassandra.io.sstable.IScrubber.ScrubResult
- scrubWithResult() - Method in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- scrubWithResult() - Method in interface org.apache.cassandra.io.sstable.IScrubber
- search(float[], int, int, Bits) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.DiskAnn
- search(float[], int, Bits) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.OnHeapGraph
- search(int) - Method in class org.apache.cassandra.io.tries.Walker
- search(C) - Method in class org.apache.cassandra.utils.IntervalTree
- search(ByteBuffer, int, int) - Method in class org.apache.cassandra.io.tries.TrieNode
-
Returns search index for the given byte in the node.
- search(Clustering<?>) - Method in class org.apache.cassandra.db.RangeTombstoneList
- search(AbstractType<?>, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.OnDiskBlock
- search(ReadExecutionController) - Method in interface org.apache.cassandra.index.Index.Searcher
- search(ReadExecutionController) - Method in class org.apache.cassandra.index.internal.CassandraIndexSearcher
- search(ReadExecutionController) - Method in class org.apache.cassandra.index.sai.plan.StorageAttachedIndexSearcher
- search(ReadExecutionController) - Method in class org.apache.cassandra.index.sasi.plan.SASIIndexSearcher
- search(Expression) - Method in class org.apache.cassandra.index.sai.view.RangeTermTree
- search(Expression, AbstractBounds<PartitionPosition>, QueryContext) - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
-
Perform a search on the index for a single expression and keyRange.
- search(Expression, AbstractBounds<PartitionPosition>, QueryContext) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.IndexSegmentSearcher
-
Search on-disk index synchronously.
- search(Expression, AbstractBounds<PartitionPosition>, QueryContext) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.LiteralIndexSegmentSearcher
- search(Expression, AbstractBounds<PartitionPosition>, QueryContext) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.NumericIndexSegmentSearcher
- search(Expression, AbstractBounds<PartitionPosition>, QueryContext) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.Segment
-
Search on-disk index synchronously
- search(Expression, AbstractBounds<PartitionPosition>, QueryContext) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.VectorIndexSegmentSearcher
- search(Expression, AbstractBounds<PartitionPosition>, QueryContext) - Method in class org.apache.cassandra.index.sai.disk.v1.V1SSTableIndex
- search(QueryContext, Expression, AbstractBounds<PartitionPosition>) - Method in class org.apache.cassandra.index.sai.memory.MemoryIndex
- search(QueryContext, Expression, AbstractBounds<PartitionPosition>) - Method in class org.apache.cassandra.index.sai.memory.MemtableIndex
- search(QueryContext, Expression, AbstractBounds<PartitionPosition>) - Method in class org.apache.cassandra.index.sai.memory.TrieMemoryIndex
-
Search for an expression in the in-memory index within the
AbstractBounds
defined by keyRange. - search(QueryContext, Expression, AbstractBounds<PartitionPosition>) - Method in class org.apache.cassandra.index.sai.memory.VectorMemoryIndex
- 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(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) - Method in class org.apache.cassandra.index.sasi.memory.TrieMemIndex
- search(Expression) - Method in class org.apache.cassandra.index.sasi.SSTableIndex
- 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(Interval<C, D>) - Method in class org.apache.cassandra.utils.IntervalTree
- SEARCH_CONCURRENCY_FACTOR - org.apache.cassandra.config.CassandraRelevantProperties
- 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 ifname
is not covered by any tombstone. - searcher() - Method in class org.apache.cassandra.service.paxos.PaxosRepairHistory
- Searcher() - Constructor for class org.apache.cassandra.service.paxos.PaxosRepairHistory.Searcher
- searcherFor(ReadCommand) - Method in interface org.apache.cassandra.index.Index.QueryPlan
-
Factory method for query time search helper.
- 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.sai.plan.StorageAttachedIndexQueryPlan
- searcherFor(ReadCommand) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- searcherFor(ReadCommand) - Method in class org.apache.cassandra.index.sasi.SASIIndex
- searcherFor(ReadCommand) - Method in class org.apache.cassandra.index.SingletonIndexQueryPlan
- searcherFor(ReadCommand) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- searchInt(long, long, int, Function<Long, Integer>) - Static method in class org.apache.cassandra.index.sai.disk.v1.vector.DiskBinarySearch
-
Search for the target int between positions low and high, using the provided function to retrieve the int value at the given ordinal.
- searchIterator() - Method in class org.apache.cassandra.db.rows.BTreeRow
- searchIterator() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
- 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
- searchMemtableIndexes(QueryContext, Expression, AbstractBounds<PartitionPosition>) - Method in class org.apache.cassandra.index.sai.memory.MemtableIndexManager
- SearchResult(T, int, int) - Constructor for class org.apache.cassandra.index.sasi.disk.OnDiskBlock.SearchResult
- SECONDARY_INDEX - Static variable in class org.apache.cassandra.io.sstable.format.SSTableFormat.Components.Types
- SECONDARY_INDEX_NAME_SEPARATOR - Static variable in class org.apache.cassandra.db.Directories
- secondary_indexes_enabled - Variable in class org.apache.cassandra.config.Config
- secondary_indexes_per_table_fail_threshold - Variable in class org.apache.cassandra.config.Config
- secondary_indexes_per_table_warn_threshold - Variable in class org.apache.cassandra.config.Config
- 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
- secondaryIndexesPerTable - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
- 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
- SECONDS_CUSTOM_DURATION - org.apache.cassandra.config.Converters
-
This converter is used to support backward compatibility for Duration parameters where we added the opportunity for the users to add a unit in the parameters' values but we didn't change the names.
- SECONDS_DURATION - org.apache.cassandra.config.Converters
- 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_COUNT_WARN_THRESHOLD - org.apache.cassandra.config.CassandraRelevantProperties
-
The maximum number of seeds returned by a seed provider before emmitting a warning.
- seed_provider - Variable in class org.apache.cassandra.config.Config
- SeedProvider - Interface in org.apache.cassandra.locator
- SEEDS_KEY - Static variable in class org.apache.cassandra.locator.SimpleSeedProvider
- seek(long) - Method in class org.apache.cassandra.db.commitlog.EncryptedFileSegmentInputStream
- seek(long) - Method in class org.apache.cassandra.index.sai.disk.io.IndexInputReader
- 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
- 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
- SeekingRandomAccessInput - Class in org.apache.cassandra.index.sai.disk.io
-
IndexInput
adapter that exposes it as aRandomAccessInput
. - SeekingRandomAccessInput(IndexInput) - Constructor for class org.apache.cassandra.index.sai.disk.io.SeekingRandomAccessInput
- seekToPointId(long) - Method in class org.apache.cassandra.index.sai.disk.v1.keystore.KeyLookup.Cursor
-
Positions the cursor on the target point id and reads the key at the target to the current key buffer.
- seekToPosition(long) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator.AbstractReader
-
Seek to the given position in the file.
- seekToPosition(long) - Method in interface org.apache.cassandra.io.sstable.AbstractSSTableIterator.Reader
- seenAnySeed() - Method in class org.apache.cassandra.gms.Gossiper
- Segment - Class in org.apache.cassandra.index.sai.disk.v1.segment
-
Each segment represents an on-disk index structure (balanced tree/terms/postings) flushed by memory limit or token boundaries.
- Segment(Token, Token) - Constructor for class org.apache.cassandra.index.sai.disk.v1.segment.Segment
- Segment(StorageAttachedIndex, SSTableContext, PerColumnIndexFiles, SegmentMetadata) - Constructor for class org.apache.cassandra.index.sai.disk.v1.segment.Segment
- SEGMENT_BUILD_MEMORY_LIMIT - Static variable in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
-
Global limit on heap consumed by all index segment building that occurs outside the context of Memtable flush.
- SEGMENT_BUILD_MEMORY_LIMITER - Static variable in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- SEGMENT_ROW_ID_OFFSET - Static variable in class org.apache.cassandra.index.sai.virtual.SegmentsSystemView
- segment_write_buffer_size - Variable in class org.apache.cassandra.config.StorageAttachedIndexOptions
- SegmentBuilder - Class in org.apache.cassandra.index.sai.disk.v1.segment
-
Creates an on-heap index data structure to be flushed to an SSTable index.
- SegmentBuilder.TrieSegmentBuilder - Class in org.apache.cassandra.index.sai.disk.v1.segment
- SegmentBuilder.VectorSegmentBuilder - Class in org.apache.cassandra.index.sai.disk.v1.segment
- segmentFlushErrors - Variable in class org.apache.cassandra.index.sai.metrics.IndexMetrics
- 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
- segmentManager - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegment.Builder
- SegmentMetadata - Class in org.apache.cassandra.index.sai.disk.v1.segment
-
Multiple
SegmentMetadata
are stored inIndexComponent.META
file, each corresponds to an on-disk index segment. - SegmentMetadata(long, long, long, long, PrimaryKey, PrimaryKey, ByteBuffer, ByteBuffer, SegmentMetadata.ComponentMetadataMap) - Constructor for class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata
- SegmentMetadata.ComponentMetadata - Class in org.apache.cassandra.index.sai.disk.v1.segment
- SegmentMetadata.ComponentMetadataMap - Class in org.apache.cassandra.index.sai.disk.v1.segment
- SegmentOrdering - Interface in org.apache.cassandra.index.sai.disk.v1.segment
-
A
SegmentOrdering
orders and limits a list ofPrimaryKey
s. - SegmentReadException(String, boolean) - Constructor for exception org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SegmentReadException
- segmentRowIdOffset - Variable in class org.apache.cassandra.index.sai.disk.v1.segment.IndexSegmentSearcherContext
- segments - Variable in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter.Index
- segmentsHit - Variable in class org.apache.cassandra.index.sai.QueryContext
- segmentsPerCompaction - Variable in class org.apache.cassandra.index.sai.metrics.IndexMetrics
- SegmentsSystemView - Class in org.apache.cassandra.index.sai.virtual
-
A
VirtualTable
providing a system view of SSTable index segment metadata. - SegmentsSystemView(String) - Constructor for class org.apache.cassandra.index.sai.virtual.SegmentsSystemView
- segmentTrieBuffer - Variable in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder.TrieSegmentBuilder
- SegmentTrieBuffer - Class in org.apache.cassandra.index.sai.disk.v1.segment
-
On-heap buffer for values that provides a sorted view of itself as an
Iterator
. - SegmentTrieBuffer() - Constructor for class org.apache.cassandra.index.sai.disk.v1.segment.SegmentTrieBuffer
- SegmentWriter - Interface in org.apache.cassandra.index.sai.disk.v1.segment
- select(Function<View, Iterable<SSTableReader>>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- select(Iterable<InetAddressAndPort>, boolean) - Method in class org.apache.cassandra.locator.Endpoints
- select(Map.Entry<? extends K, ? extends V>) - Method in interface org.apache.cassandra.index.sasi.utils.trie.Cursor
-
Called for each
Map.Entry
in theTrie
. - 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(ConsistencyLevel, L, L) - Method in interface org.apache.cassandra.locator.ReplicaPlans.Selector
-
Select the
Endpoints
from {@param liveAndDown} and {@param live} to contact according to the consistency level. - select(DataRange, ColumnFilter) - Method in class org.apache.cassandra.db.virtual.AbstractVirtualTable
- select(DataRange, ColumnFilter) - Method in interface org.apache.cassandra.db.virtual.VirtualTable
-
Selects the rows from a range of partitions.
- select(DecoratedKey, ClusteringIndexFilter, 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(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(ColumnMetadata, CellPath) - Method in class org.apache.cassandra.db.filter.ColumnFilter.Builder
- SELECT - org.apache.cassandra.audit.AuditLogEntryType
- SELECT - org.apache.cassandra.auth.Permission
- SELECT - org.apache.cassandra.cql3.statements.StatementType
- SELECT_MASKED - org.apache.cassandra.auth.Permission
- selectable - Variable in class org.apache.cassandra.cql3.selection.RawSelector
- selectable - Variable in class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL
- Selectable - Interface in org.apache.cassandra.cql3.selection
- Selectable.BetweenParenthesesOrWithTuple - Class in org.apache.cassandra.cql3.selection
-
Selectable
forSelectable
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.WithArrayLiteral - Class in org.apache.cassandra.cql3.selection
-
Selectable
for literal Lists. - Selectable.WithArrayLiteral.Raw - Class in org.apache.cassandra.cql3.selection
- 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.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.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.WithVector - Class in org.apache.cassandra.cql3.selection
- Selectable.WritetimeOrTTL - Class in org.apache.cassandra.cql3.selection
- Selectable.WritetimeOrTTL.Kind - Enum in org.apache.cassandra.cql3.selection
- Selectable.WritetimeOrTTL.Raw - Class in org.apache.cassandra.cql3.selection
- selectables - Variable in class org.apache.cassandra.cql3.selection.Selectable.WithArrayLiteral
-
The list elements
- 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(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithArrayLiteral
- 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.WithTypeHint
- selectColumns(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WithVector
- selectColumns(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL
- selectColumns(Predicate<ColumnMetadata>) - Method in class org.apache.cassandra.schema.ColumnMetadata
- 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.
- 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
- selected_format - Variable in class org.apache.cassandra.config.Config.SSTableConfig
- selectFunction(SSTableSet) - Static method in class org.apache.cassandra.db.lifecycle.View
- 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 - 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.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 - Static variable in class org.apache.cassandra.db.SinglePartitionReadCommand
- SelectionDeserializer() - Constructor for class org.apache.cassandra.db.ReadCommand.SelectionDeserializer
- 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(Selector.Kind) - Constructor for class org.apache.cassandra.cql3.selection.Selector
- Selector.Factory - Class in org.apache.cassandra.cql3.selection
-
A factory for
Selector
instances. - Selector.InputRow - Class in org.apache.cassandra.cql3.selection
-
A row of data that need to be processed by a
Selector
- Selector.Kind - Enum in org.apache.cassandra.cql3.selection
-
The
Selector
kinds. - Selector.SelectorDeserializer - Class in org.apache.cassandra.cql3.selection
- Selector.Serializer - Class in org.apache.cassandra.cql3.selection
- 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
- SelectorDeserializer() - Constructor for class org.apache.cassandra.cql3.selection.Selector.SelectorDeserializer
- 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
- 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.Factory, SelectStatement.ColumnComparator<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
- Semaphore - Interface in org.apache.cassandra.utils.concurrent
- Semaphore.Standard - Class in org.apache.cassandra.utils.concurrent
- send(IntFunction<StreamingDataOutputPlus>) - Method in interface org.apache.cassandra.streaming.StreamingChannel.Send
- send(Message<REQ>, InetAddressAndPort) - Method in interface org.apache.cassandra.net.MessageDelivery
- 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(StreamingChannel.Send) - Method in class org.apache.cassandra.streaming.async.NettyStreamingChannel
- send(StreamingChannel.Send) - Method in interface org.apache.cassandra.streaming.StreamingChannel
- send(Event) - Method in class org.apache.cassandra.transport.Server.ConnectionTracker
- SEND - org.apache.cassandra.streaming.StreamSession.PrepareDirection
- SEND_GOSSIP_DIGEST_SYN - org.apache.cassandra.gms.GossiperEvent.GossiperEventType
- sendAck(SharedContext, Message<? extends RepairMessage>) - Static method in class org.apache.cassandra.repair.messages.RepairMessage
- sendByFollower - Variable in class org.apache.cassandra.streaming.messages.StreamMessageHeader
- sendControlMessage(StreamMessage) - Method in class org.apache.cassandra.streaming.async.StreamingMultiplexedChannel
- sender - Variable in class org.apache.cassandra.streaming.messages.StreamMessageHeader
- sendFailureResponse(SharedContext, Message<?>) - Static method in class org.apache.cassandra.repair.messages.RepairMessage
- SENDING_TREES - org.apache.cassandra.repair.state.ValidationState.State
- 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
- sendingTrees() - Method in class org.apache.cassandra.repair.state.ValidationState.Phase
- sendInitialRepairs() - Method in class org.apache.cassandra.service.reads.repair.BlockingPartitionRepair
- sendMessage(InetAddressAndPort, Message<? extends RepairMessage>) - Method in class org.apache.cassandra.repair.consistent.LocalSessions
- sendMessage(StreamingChannel, StreamMessage) - Method in class org.apache.cassandra.streaming.async.StreamingMultiplexedChannel
- sendMessageWithFailureCB(SharedContext, Supplier<Boolean>, RepairMessage, Verb, InetAddressAndPort, RepairMessage.RepairFailureCallback) - Static method in class org.apache.cassandra.repair.messages.RepairMessage
- sendMessageWithRetries(SharedContext, Supplier<Boolean>, RepairMessage, Verb, InetAddressAndPort) - Static method in class org.apache.cassandra.repair.messages.RepairMessage
- sendMessageWithRetries(SharedContext, Supplier<Boolean>, RepairMessage, Verb, InetAddressAndPort, RequestCallback<T>) - Static method in class org.apache.cassandra.repair.messages.RepairMessage
- sendMessageWithRetries(SharedContext, RepairMessage, Verb, InetAddressAndPort) - Static method in class org.apache.cassandra.repair.messages.RepairMessage
- sendMessageWithRetries(SharedContext, RepairMessage, Verb, InetAddressAndPort, RequestCallback<T>) - Static method in class org.apache.cassandra.repair.messages.RepairMessage
- sendNextRequests() - Method in class org.apache.cassandra.service.reads.range.ScanAllRangesCommandIterator
- 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.ForWrite, AbstractWriteResponseHandler<IMutation>, String, Stage, Dispatcher.RequestTime) - 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<REQ>, InetAddressAndPort, RequestCallback<RSP>) - Method in interface org.apache.cassandra.net.MessageDelivery
- sendWithCallback(Message<REQ>, InetAddressAndPort, RequestCallback<RSP>, ConnectionType) - Method in interface org.apache.cassandra.net.MessageDelivery
- 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
- sendWithResult(Message<REQ>, InetAddressAndPort) - Method in interface org.apache.cassandra.net.MessageDelivery
- sendWithResult(Message<REQ>, InetAddressAndPort) - Method in class org.apache.cassandra.net.MessagingService
- sendWriteWithCallback(Message, Replica, AbstractWriteResponseHandler<?>) - 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
- separatorFloor(ByteComparable) - Method in class org.apache.cassandra.io.sstable.format.bti.RowIndexReader
-
Computes the floor for a given key.
- separatorGt(ByteComparable, ByteComparable) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteComparable
-
Returns a separator for two byte comparable, i.e.
- separatorGt(ByteSource, ByteSource) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
Returns a separator for two byte sources, i.e.
- separatorPrefix(ByteComparable, ByteComparable) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteComparable
-
Returns a separator for two byte sources, i.e.
- separatorPrefix(ByteSource, ByteSource) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
Returns a separator for two byte sources, i.e.
- SEPExecutor - Class in org.apache.cassandra.concurrent
- SEPExecutor.TakeTaskPermitResult - Enum in org.apache.cassandra.concurrent
- SEPExecutorMBean - Interface in org.apache.cassandra.concurrent
- SequenceBasedSSTableId - Class in org.apache.cassandra.io.sstable
-
Generation identifier based on sequence of integers.
- SequenceBasedSSTableId(int) - Constructor for class org.apache.cassandra.io.sstable.SequenceBasedSSTableId
- SequenceBasedSSTableId.Builder - Class in org.apache.cassandra.io.sstable
- 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
- sequential(String) - Method in interface org.apache.cassandra.concurrent.ExecutorBuilderFactory
-
Return a default configuration of sequential executor
- SEQUENTIAL - org.apache.cassandra.repair.RepairParallelism
-
One node at a time
- SequentialExecutorPlus - Interface in org.apache.cassandra.concurrent
-
An
ExecutorPlus
that guarantees the order of execution matches the order of task submission, and provides a simple mechanism for the recurring pattern of ensuring a job is executed at least once after some point in time (i.e. - SequentialExecutorPlus.AtLeastOnceTrigger - Interface in org.apache.cassandra.concurrent
- 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
- SERIAL - org.apache.cassandra.db.ConsistencyLevel
- SerializableHintMessage - Interface in org.apache.cassandra.hints
- SERIALIZATION_EMPTY_TYPE_NONEMPTY_BEHAVIOR - org.apache.cassandra.config.CassandraRelevantProperties
- SerializationException(ColumnMetadata, Throwable) - Constructor for exception org.apache.cassandra.db.virtual.SimpleDataSet.SerializationException
- serializationHeader - Variable in class org.apache.cassandra.db.streaming.CassandraStreamHeader
- serializationHeader() - Method in class org.apache.cassandra.io.sstable.format.StatsComponent
- serializationHeader(TableMetadata) - Method in class org.apache.cassandra.io.sstable.format.StatsComponent
- SerializationHeader - Class in org.apache.cassandra.db
- SerializationHeader(boolean, TableMetadata, RegularAndStaticColumns, EncodingStats) - Constructor for class org.apache.cassandra.db.SerializationHeader
- 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
- SerializationNode<VALUE> - Interface in org.apache.cassandra.io.tries
-
An abstraction of a node given to the trie serializer to write.
- serialize(long, ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
- 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(C, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractCollectionCodec
- serialize(In, DataOutputPlus, int) - Method in interface org.apache.cassandra.io.IVersionedAsymmetricSerializer
-
Serialize the specified type into the specified DataOutputStream instance.
- serialize(ByteBuf, ProtocolVersion) - Method in class org.apache.cassandra.transport.Event
- serialize(DataOutput) - Method in class org.apache.cassandra.schema.TableId
- serialize(DataOutput) - Method in class org.apache.cassandra.utils.TimeUUID
- serialize(Boolean) - Method in class org.apache.cassandra.serializers.BooleanSerializer
- serialize(Boolean, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.BooleanSerializer
- serialize(Boolean, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveBooleanCodec
- serialize(Byte) - Method in class org.apache.cassandra.serializers.ByteSerializer
- serialize(Byte, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveByteCodec
- serialize(Double) - Method in class org.apache.cassandra.serializers.DoubleSerializer
- serialize(Double, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveDoubleCodec
- serialize(Float) - Method in class org.apache.cassandra.serializers.FloatSerializer
- serialize(Float, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveFloatCodec
- serialize(Integer) - Method in class org.apache.cassandra.serializers.Int32Serializer
- serialize(Integer) - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
- serialize(Integer, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.Int32Serializer
- serialize(Integer, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveIntCodec
- serialize(Long) - Method in class org.apache.cassandra.serializers.LongSerializer
- serialize(Long) - Method in class org.apache.cassandra.serializers.TimeSerializer
- serialize(Long, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.Int64Serializer
- serialize(Long, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveLongCodec
- serialize(Object, DataOutputPlus, int) - Method in class org.apache.cassandra.gms.GossipShutdown.Serializer
- serialize(Short) - Method in class org.apache.cassandra.serializers.ShortSerializer
- serialize(Short, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.PrimitiveShortCodec
- serialize(String) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
- serialize(Void) - Method in class org.apache.cassandra.serializers.EmptySerializer
- serialize(Void, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.VoidSerializer
- serialize(BigDecimal) - Method in class org.apache.cassandra.serializers.DecimalSerializer
- serialize(BigInteger) - Method in class org.apache.cassandra.serializers.IntegerSerializer
- serialize(InetAddress) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
- serialize(InetSocketAddress, DataOutputPlus, int) - Method in class org.apache.cassandra.locator.InetAddressAndPort.Serializer
- serialize(ByteBuffer) - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf.LeafEntry
- serialize(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
- serialize(Collection<Mutation>, DataOutputPlus, int) - Method in class org.apache.cassandra.schema.SchemaMutationsSerializer
- serialize(Collection<Range<Token>>, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.RangesSerializer
- serialize(Date) - Method in class org.apache.cassandra.serializers.TimestampSerializer
- serialize(EnumSet<ResultSet.Flag>) - Static method in enum org.apache.cassandra.cql3.ResultSet.Flag
- serialize(EnumSet<Envelope.Header.Flag>) - Static method in enum org.apache.cassandra.transport.Envelope.Header.Flag
- serialize(Map<K, V>, ProtocolVersion) - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec.AbstractMapCodec
- 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(UUID) - Method in class org.apache.cassandra.serializers.UUIDSerializer
- serialize(UUID, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
- serialize(K, DataOutputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
- serialize(LZ4Compressor, ByteBuffer, int) - Static method in class org.apache.cassandra.streaming.async.StreamCompressionSerializer
- serialize(Batch, DataOutputPlus, int) - Method in class org.apache.cassandra.batchlog.Batch.Serializer
- serialize(CounterCacheKey, DataOutputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.service.CacheService.CounterCacheSerializer
- serialize(IRowCacheEntry, DataOutputPlus) - Method in class org.apache.cassandra.cache.SerializingCacheProvider.RowCacheSerializer
- 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(Duration) - Method in class org.apache.cassandra.serializers.DurationSerializer
- serialize(Selector, DataOutputPlus, int) - Method in class org.apache.cassandra.cql3.selection.Selector.Serializer
- 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<?>, int, List<AbstractType<?>>) - Method in class org.apache.cassandra.db.Clustering.Serializer
- serialize(Clustering<?>, DataOutputPlus, 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.LegacySerializer
- 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(AbstractType<?>, DataOutputPlus) - Method in class org.apache.cassandra.serializers.AbstractTypeSerializer
- 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(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(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(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(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(IPartitioner, Collection<Token>, DataOutput) - Static method in class org.apache.cassandra.gms.TokenSerializer
- serialize(Token, ByteBuffer) - Method in class org.apache.cassandra.dht.Token.TokenFactory
- serialize(Token, DataOutputPlus) - 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(SerializableHintMessage, DataOutputPlus, int) - Method in class org.apache.cassandra.hints.HintMessage.Serializer
- serialize(RowIndexEntry, DataOutputPlus, ByteBuffer) - Method in interface org.apache.cassandra.io.sstable.format.big.RowIndexEntry.IndexSerializer
- serialize(RowIndexEntry, DataOutputPlus, ByteBuffer) - Method in class org.apache.cassandra.io.sstable.format.big.RowIndexEntry.Serializer
- serialize(Version, SerializationHeader.Component, DataOutputPlus) - Method in class org.apache.cassandra.db.SerializationHeader.Serializer
- serialize(Version, CompactionMetadata, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
- 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(Version, T, DataOutputPlus) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataComponentSerializer
-
Serialize metadata component to given output.
- 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.IndexSummary.IndexSummarySerializer
- serialize(DataOutputPlus) - Method in interface org.apache.cassandra.utils.obs.IBitSet
- serialize(DataOutputPlus) - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
- serialize(DataOutputPlus, int) - Method in class org.apache.cassandra.cql3.selection.Selector
- serialize(DataOutputPlus, int) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
- serialize(DataOutputPlus, int) - Method in class org.apache.cassandra.cql3.selection.TermSelector
- serialize(DataOutputPlus, int) - Method in class org.apache.cassandra.cql3.selection.VectorSelector
- serialize(DataOutputPlus, int) - Method in class org.apache.cassandra.db.filter.RowFilter.UserExpression
- serialize(DataOutputPlus, int) - Method in class org.apache.cassandra.utils.MerkleTree
- serialize(DataOutputPlus, ByteBuffer) - Method in class org.apache.cassandra.io.sstable.format.big.RowIndexEntry
- serialize(DataOutputPlus, SerializationNode<?>, int, long) - Method in class org.apache.cassandra.io.tries.TrieNode
-
Serializes the node.
- serialize(DataOutputStreamPlus, boolean) - Method in class org.apache.cassandra.utils.BloomFilter
- serialize(DataOutputStreamPlus, boolean) - Method in interface org.apache.cassandra.utils.IFilter
- 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(Ballot, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.Ballot.Serializer
- serialize(PaxosStartPrepareCleanup.Request, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosStartPrepareCleanup.RequestSerializer
- serialize(PaxosCommitAndPrepare.Request, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.PaxosCommitAndPrepare.RequestSerializer
- serialize(PaxosPrepare.Response, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.PaxosPrepare.ResponseSerializer
- serialize(PaxosPrepareRefresh.Request, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.PaxosPrepareRefresh.RequestSerializer
- serialize(PaxosPrepareRefresh.Response, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.PaxosPrepareRefresh.ResponseSerializer
- serialize(PaxosPropose.Request, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.PaxosPropose.RequestSerializer
- serialize(PaxosPropose.Response, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.PaxosPropose.ResponseSerializer
- serialize(PaxosRepair.Request, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.PaxosRepair.RequestSerializer
- serialize(PaxosRepair.Response, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.PaxosRepair.ResponseSerializer
- serialize(PrepareResponse, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
- serialize(StreamMessageHeader, DataOutputPlus, int) - Method in class org.apache.cassandra.streaming.messages.StreamMessageHeader.FileMessageHeaderSerializer
- serialize(StreamMessage, StreamingDataOutputPlus, int, StreamSession) - Static method in class org.apache.cassandra.streaming.messages.StreamMessage
- serialize(StreamingDataOutputPlus, int, StreamSession) - Method in class org.apache.cassandra.streaming.messages.OutgoingStreamMessage
- 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(ProtocolVersion) - Method in class org.apache.cassandra.service.pager.PagingState
- serialize(BloomFilter, DataOutputStreamPlus) - Method in class org.apache.cassandra.utils.BloomFilterSerializer
- serialize(EstimatedHistogram, DataOutputPlus) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
- serialize(IntervalTree<C, D, I>, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
- serialize(MerkleTrees, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.MerkleTrees.MerkleTreesSerializer
- serialize(TombstoneHistogram, DataOutputPlus) - Method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram.HistogramSerializer
- serialize(TombstoneHistogram, DataOutputPlus) - Method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram.LegacyHistogramSerializer
- serialize(TimeUUID, DataOutputPlus, int) - Method in class org.apache.cassandra.utils.TimeUUID.Serializer
- serialize(T) - Method in class org.apache.cassandra.serializers.CollectionSerializer
- serialize(T) - Method in class org.apache.cassandra.serializers.TypeSerializer
- serialize(T) - Method in class org.apache.cassandra.utils.TimeUUID.AbstractSerializer
- serialize(T, O) - Method in interface org.apache.cassandra.io.IGenericSerializer
- serialize(T, IVersionedSerializer<T>, int) - Static method in class org.apache.cassandra.utils.FBUtilities
- serialize(T, DataOutputPlus) - Method in interface org.apache.cassandra.io.ISerializer
-
Serialize the specified type into the specified DataOutput instance.
- serialize(T, DataOutputPlus) - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat.KeyCacheValueSerializer
- serialize(T, DataOutputPlus, int) - Method in interface org.apache.cassandra.dht.IPartitionerDependentSerializer
-
Serialize the specified type into the specified DataOutputStream instance.
- serialize(T, DataOutputPlus, int) - Method in class org.apache.cassandra.service.paxos.Commit.CommitSerializer
- 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(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(V, StreamingDataOutputPlus, int, StreamSession) - Method in interface org.apache.cassandra.streaming.messages.StreamMessage.Serializer
- serializeAsPartitionKey() - Method in interface org.apache.cassandra.db.ClusteringPrefix
- serializeCollection(IVersionedSerializer<V>, Collection<V>, DataOutputPlus, int) - Static method in class org.apache.cassandra.utils.CollectionSerializer
- 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
- serializedListSize(List<AbstractType<?>>) - Method in class org.apache.cassandra.serializers.AbstractTypeSerializer
- serializedPositionDelta(int, long) - Method in interface org.apache.cassandra.io.tries.SerializationNode
-
Returns the distance between this node's position and the child at index i.
- serializedSize() - Method in class org.apache.cassandra.cql3.functions.types.TypeCodec
- serializedSize() - Method in enum org.apache.cassandra.cql3.Operator
- serializedSize() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
- serializedSize() - Method in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
- serializedSize() - Method in class org.apache.cassandra.schema.TableId
- serializedSize() - Method in interface org.apache.cassandra.utils.obs.IBitSet
- serializedSize() - Method in class org.apache.cassandra.utils.obs.OffHeapBitSet
- serializedSize(boolean) - Method in class org.apache.cassandra.utils.BloomFilter
- serializedSize(boolean) - Method in interface org.apache.cassandra.utils.IFilter
- serializedSize(int) - Method in class org.apache.cassandra.cql3.selection.Selector
- serializedSize(int) - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
- serializedSize(int) - Method in class org.apache.cassandra.cql3.selection.TermSelector
- serializedSize(int) - Method in class org.apache.cassandra.cql3.selection.VectorSelector
- serializedSize(int) - Method in class org.apache.cassandra.db.CounterMutation
- serializedSize(int) - Method in class org.apache.cassandra.db.filter.RowFilter.UserExpression
- serializedSize(int) - Method in class org.apache.cassandra.db.Mutation
- serializedSize(int) - Method in class org.apache.cassandra.net.Message
-
Serialized size of the entire message, for the provided messaging version.
- serializedSize(int) - Method in class org.apache.cassandra.utils.MerkleTree
- serializedSize(In, int) - Method in interface org.apache.cassandra.io.IVersionedAsymmetricSerializer
-
Calculate serialized size of object without actually serializing.
- serializedSize(Boolean, int) - Method in class org.apache.cassandra.utils.BooleanSerializer
- serializedSize(Integer, int) - Method in class org.apache.cassandra.utils.Int32Serializer
- serializedSize(Long, int) - Method in class org.apache.cassandra.utils.Int64Serializer
- serializedSize(Object, int) - Method in class org.apache.cassandra.gms.GossipShutdown.Serializer
- serializedSize(Void, int) - Method in class org.apache.cassandra.utils.VoidSerializer
- serializedSize(InetSocketAddress, int) - Method in class org.apache.cassandra.locator.InetAddressAndPort.Serializer
- serializedSize(Collection<Mutation>, int) - Method in class org.apache.cassandra.schema.SchemaMutationsSerializer
- serializedSize(Collection<Range<Token>>, int) - Method in class org.apache.cassandra.utils.RangesSerializer
- serializedSize(UUID, int) - Method in class org.apache.cassandra.utils.UUIDSerializer
- serializedSize(Batch, int) - Method in class org.apache.cassandra.batchlog.Batch.Serializer
- serializedSize(IRowCacheEntry) - Method in class org.apache.cassandra.cache.SerializingCacheProvider.RowCacheSerializer
- serializedSize(Selector, int) - Method in class org.apache.cassandra.cql3.selection.Selector.Serializer
- 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(DataRange, int, TableMetadata) - Method in class org.apache.cassandra.db.DataRange.Serializer
- serializedSize(DeletionTime) - Method in class org.apache.cassandra.db.DeletionTime.LegacySerializer
- 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(AbstractType<?>) - Method in class org.apache.cassandra.serializers.AbstractTypeSerializer
- serializedSize(Mutation, int) - Method in class org.apache.cassandra.db.Mutation.MutationSerializer
- 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(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(UnfilteredRowIterator, ColumnFilter, int, int) - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer
- 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(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(Version, SerializationHeader.Component) - Method in class org.apache.cassandra.db.SerializationHeader.Serializer
- serializedSize(Version, CompactionMetadata) - Method in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata.CompactionMetadataSerializer
- 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(Version, T) - Method in interface org.apache.cassandra.io.sstable.metadata.IMetadataComponentSerializer
-
Calculate and return serialized size.
- serializedSize(IndexInfo) - Method in class org.apache.cassandra.io.sstable.IndexInfo.Serializer
- 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(SyncNodePair, int) - Method in class org.apache.cassandra.repair.SyncNodePair.NodePairSerializer
- serializedSize(IndexMetadata, int) - Method in class org.apache.cassandra.schema.IndexMetadata.Serializer
- serializedSize(Ballot, int) - Method in class org.apache.cassandra.service.paxos.Ballot.Serializer
- serializedSize(PaxosStartPrepareCleanup.Request, int) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosStartPrepareCleanup.RequestSerializer
- serializedSize(PaxosCommitAndPrepare.Request, int) - Method in class org.apache.cassandra.service.paxos.PaxosCommitAndPrepare.RequestSerializer
- serializedSize(PaxosPrepare.Response, int) - Method in class org.apache.cassandra.service.paxos.PaxosPrepare.ResponseSerializer
- serializedSize(PaxosPrepareRefresh.Request, int) - Method in class org.apache.cassandra.service.paxos.PaxosPrepareRefresh.RequestSerializer
- serializedSize(PaxosPrepareRefresh.Response, int) - Method in class org.apache.cassandra.service.paxos.PaxosPrepareRefresh.ResponseSerializer
- serializedSize(PaxosPropose.Request, int) - Method in class org.apache.cassandra.service.paxos.PaxosPropose.RequestSerializer
- serializedSize(PaxosPropose.Response, int) - Method in class org.apache.cassandra.service.paxos.PaxosPropose.ResponseSerializer
- serializedSize(PaxosRepair.Request, int) - Method in class org.apache.cassandra.service.paxos.PaxosRepair.RequestSerializer
- serializedSize(PaxosRepair.Response, int) - Method in class org.apache.cassandra.service.paxos.PaxosRepair.ResponseSerializer
- serializedSize(PrepareResponse, int) - Method in class org.apache.cassandra.service.paxos.PrepareResponse.PrepareResponseSerializer
- serializedSize(StreamMessageHeader, int) - Method in class org.apache.cassandra.streaming.messages.StreamMessageHeader.FileMessageHeaderSerializer
- serializedSize(StreamMessage, int) - Static method in class org.apache.cassandra.streaming.messages.StreamMessage
- 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.service.pager.PagingState
- serializedSize(ProtocolVersion) - Method in class org.apache.cassandra.transport.Event
- serializedSize(BloomFilter) - Method in class org.apache.cassandra.utils.BloomFilterSerializer
-
Calculates a serialized size of the given Bloom Filter
- serializedSize(EstimatedHistogram) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
- serializedSize(IntervalTree<C, D, I>, int) - Method in class org.apache.cassandra.utils.IntervalTree.Serializer
- serializedSize(MerkleTrees, int) - Method in class org.apache.cassandra.utils.MerkleTrees.MerkleTreesSerializer
- serializedSize(TombstoneHistogram) - Method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram.HistogramSerializer
- serializedSize(TombstoneHistogram) - Method in class org.apache.cassandra.utils.streamhist.TombstoneHistogram.LegacyHistogramSerializer
- serializedSize(TimeUUID, int) - Method in class org.apache.cassandra.utils.TimeUUID.Serializer
- serializedSize(T) - Method in interface org.apache.cassandra.io.IGenericSerializer
- serializedSize(T) - Method in interface org.apache.cassandra.io.ISerializer
- serializedSize(T, int) - Method in interface org.apache.cassandra.dht.IPartitionerDependentSerializer
-
Calculate serialized size of object without actually serializing.
- serializedSize(T, int) - Method in class org.apache.cassandra.service.paxos.Commit.CommitSerializer
- serializedSize(V, int) - Method in interface org.apache.cassandra.streaming.messages.StreamMessage.Serializer
- serializedSizeCollection(IVersionedSerializer<V>, Collection<V>, int) - Static method in class org.apache.cassandra.utils.CollectionSerializer
- 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
- serializedSizeList(IVersionedSerializer<V>, L, int) - Static method in class org.apache.cassandra.utils.CollectionSerializer
- serializedSizeMap(IVersionedSerializer<K>, IVersionedSerializer<V>, Map<K, V>, int) - Static method in class org.apache.cassandra.utils.CollectionSerializer
- serializedSizeNullable(IVersionedSerializer<T>, T, int) - Static method in class org.apache.cassandra.utils.NullableSerializer
- serializedSizeWithLength(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- serializedSizeWithShortLength(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- serializedSizeWithVIntLength(byte[]) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- 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, DataOutputPlus) - Method in interface org.apache.cassandra.io.sstable.format.big.RowIndexEntry.IndexSerializer
- serializeForCache(RowIndexEntry, DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.format.big.RowIndexEntry.Serializer
- serializeForCache(DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.AbstractRowIndexEntry
-
Serialize this entry for key cache
- serializeForCache(DataOutputPlus) - Method in class org.apache.cassandra.io.sstable.format.big.RowIndexEntry
- serializeForMessaging(SerializationHeader, ColumnFilter, DataOutputPlus, boolean) - Method in class org.apache.cassandra.db.SerializationHeader.Serializer
- serializeForNativeProtocol(Iterator<Cell<?>>) - 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
- serializeList(List<AbstractType<?>>, DataOutputPlus) - Method in class org.apache.cassandra.serializers.AbstractTypeSerializer
- serializeList(IVersionedSerializer<V>, L, DataOutputPlus, int) - Static method in class org.apache.cassandra.utils.CollectionSerializer
- serializeMap(IVersionedSerializer<K>, IVersionedSerializer<V>, Map<K, V>, DataOutputPlus, int) - Static method in class org.apache.cassandra.utils.CollectionSerializer
- serializeMetadata(DataOutputPlus) - Method in class org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
- serializeMetadata(DataOutputPlus) - Method in class org.apache.cassandra.service.CacheService.KeyCacheSerializer
- 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
- serializeNullable(IVersionedSerializer<T>, T, DataOutputPlus, int) - Static method in class org.apache.cassandra.utils.NullableSerializer
- 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 - Static variable in class org.apache.cassandra.cql3.selection.Selector
-
The
Selector
serializer. - serializer - Static variable in class org.apache.cassandra.db.aggregation.AggregationSpecification
- serializer - Static variable in class org.apache.cassandra.db.aggregation.GroupingState
- serializer - Static variable in interface org.apache.cassandra.db.Clustering
- serializer - Static variable in interface org.apache.cassandra.db.ClusteringBoundOrBoundary
- serializer - Static variable in interface org.apache.cassandra.db.ClusteringPrefix
- serializer - Static variable in class org.apache.cassandra.db.Columns
- serializer - Static variable in class org.apache.cassandra.db.commitlog.CommitLogPosition
- serializer - Static variable in class org.apache.cassandra.db.CounterMutation
- serializer - Static variable in class org.apache.cassandra.db.DataRange
- serializer - Static variable in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
- serializer - Static variable in class org.apache.cassandra.db.filter.ColumnFilter
- serializer - Static variable in class org.apache.cassandra.db.filter.ColumnSubselection
- serializer - Static variable in class org.apache.cassandra.db.filter.DataLimits
- serializer - Static variable in class org.apache.cassandra.db.filter.RowFilter
- 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 - Static variable in class org.apache.cassandra.db.ReadCommand
- serializer - Static variable in class org.apache.cassandra.db.ReadResponse
- serializer - Static variable in class org.apache.cassandra.db.rows.Cell
- serializer - Static variable in class org.apache.cassandra.db.rows.EncodingStats
- 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 - Static variable in class org.apache.cassandra.db.Slice
- serializer - Static variable in class org.apache.cassandra.db.Slices
- 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.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.GossipShutdown
- 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 - Static variable in class org.apache.cassandra.io.compress.CompressionMetadata.Chunk
- serializer - Static variable in class org.apache.cassandra.io.sstable.indexsummary.IndexSummary
- serializer - Static variable in class org.apache.cassandra.io.sstable.metadata.CompactionMetadata
- serializer - Variable in enum org.apache.cassandra.io.sstable.metadata.MetadataType
- serializer - Static variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
- serializer - Static variable in class org.apache.cassandra.io.sstable.metadata.ValidationMetadata
- serializer - Variable in class org.apache.cassandra.io.tries.IncrementalTrieWriterBase
- serializer - Static variable in class org.apache.cassandra.net.Message
- serializer - Static variable in class org.apache.cassandra.net.NoPayload
- 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 - Static variable in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupComplete
- serializer - Static variable in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupHistory
- serializer - Static variable in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupRequest
- serializer - Static variable in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupResponse
- serializer - Static variable in class org.apache.cassandra.service.paxos.cleanup.PaxosStartPrepareCleanup
- serializer - Static variable in class org.apache.cassandra.service.paxos.Commit.Accepted
- serializer - Static variable in class org.apache.cassandra.service.paxos.Commit.Agreed
- serializer - Static variable in class org.apache.cassandra.service.paxos.Commit.Committed
- serializer - Static variable in class org.apache.cassandra.service.paxos.Commit.Proposal
- serializer - Static variable in class org.apache.cassandra.service.paxos.Commit
- serializer - Static variable in class org.apache.cassandra.service.paxos.PaxosRepairHistory
- 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 - Static variable in class org.apache.cassandra.utils.Int32Serializer
- serializer - Static variable in class org.apache.cassandra.utils.Int64Serializer
- serializer - Static variable in class org.apache.cassandra.utils.MerkleTrees
- serializer - Static variable in class org.apache.cassandra.utils.RangesSerializer
- serializer - Static variable in class org.apache.cassandra.utils.UUIDSerializer
- serializer - Static variable in class org.apache.cassandra.utils.VoidSerializer
- serializer() - Method in enum org.apache.cassandra.net.Verb
- serializer(ISerializer<C>, ISerializer<D>, Constructor<I>) - Static method in class org.apache.cassandra.utils.IntervalTree
- serializer(ISerializer<T>) - Static method in class org.apache.cassandra.db.commitlog.IntervalSet
- serializer(Version, SerializationHeader) - Static method in class org.apache.cassandra.io.sstable.IndexInfo
- Serializer() - Constructor for class org.apache.cassandra.batchlog.Batch.Serializer
- Serializer() - Constructor for class org.apache.cassandra.cql3.selection.Selector.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.aggregation.AggregationSpecification.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.aggregation.GroupingState.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.Clustering.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.ClusteringBoundOrBoundary.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.ClusteringPrefix.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.Columns.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.DataRange.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.DeletionTime.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.filter.ColumnFilter.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.filter.ColumnSubselection.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.filter.DataLimits.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.filter.RowFilter.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.marshal.LexicalUUIDType.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.ReadCommand.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.rows.EncodingStats.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.SerializationHeader.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.Slice.Serializer
- Serializer() - Constructor for class org.apache.cassandra.db.Slices.Serializer
- Serializer() - Constructor for class org.apache.cassandra.gms.GossipShutdown.Serializer
- Serializer() - Constructor for class org.apache.cassandra.hints.HintMessage.Serializer
- Serializer() - Constructor for class org.apache.cassandra.schema.IndexMetadata.Serializer
- Serializer() - Constructor for class org.apache.cassandra.service.paxos.Ballot.Serializer
- Serializer() - Constructor for class org.apache.cassandra.utils.TimeUUID.Serializer
- Serializer(List<AbstractType<?>>) - Constructor for class org.apache.cassandra.db.marshal.CompositeType.Serializer
- Serializer(Map<Byte, AbstractType<?>>) - Constructor for class org.apache.cassandra.db.marshal.DynamicCompositeType.Serializer
- Serializer(Version, List<AbstractType<?>>) - Constructor for class org.apache.cassandra.io.sstable.IndexInfo.Serializer
- Serializer(Version, SerializationHeader, TableMetrics) - Constructor for class org.apache.cassandra.io.sstable.format.big.RowIndexEntry.Serializer
- Serializer(SchemaProvider) - Constructor for class org.apache.cassandra.db.ReadCommand.Serializer
- serializeRaw(List<V>, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.VectorType.VectorSerializer
- serializerForIntraNode() - Static method in class org.apache.cassandra.db.partitions.UnfilteredPartitionIterators
- serializers - Static variable in class org.apache.cassandra.db.streaming.ComponentManifest
- 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.
- serializeToJsonFile(Object, File) - Static method in class org.apache.cassandra.utils.JsonUtils
- serializeToJsonFile(File) - Method in class org.apache.cassandra.service.DataResurrectionCheck.Heartbeat
- serializeToJsonFile(File) - Method in class org.apache.cassandra.service.snapshot.SnapshotManifest
- 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
- serializeValues(T) - Method in class org.apache.cassandra.serializers.CollectionSerializer
- 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
- serialVersionUID - Static variable in class org.apache.cassandra.service.paxos.Ballot
- serialVersionUID - Static variable in class org.apache.cassandra.utils.TimeUUID
- Server - Class in org.apache.cassandra.transport
- SERVER - org.apache.cassandra.security.ISslContextFactory.SocketType
- SERVER_CONFIG - org.apache.cassandra.net.OutboundConnectionInitiator.SslFallbackConnectionType
- server_encryption_options - Variable in class org.apache.cassandra.config.Config
- SERVER_ERROR - org.apache.cassandra.exceptions.ExceptionCode
- Server.Builder - Class in org.apache.cassandra.transport
- Server.ConnectionTracker - Class in org.apache.cassandra.transport
- Server.EventNotifier - Class in org.apache.cassandra.transport
- 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(EncryptionOptions.ServerEncryptionOptions) - Constructor for class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
- ServerEncryptionOptions(ParameterizedClass, String, String, 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
- ServerError - Exception in org.apache.cassandra.transport
-
Exceptions thrown when a client didn't respect the protocol.
- ServerError(String) - Constructor for exception org.apache.cassandra.transport.ServerError
- ServerError(Throwable) - Constructor for exception org.apache.cassandra.transport.ServerError
- session - Variable in class org.apache.cassandra.db.streaming.CassandraStreamReader
- session - Variable in class org.apache.cassandra.db.streaming.CassandraStreamWriter
- session - Variable in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupRequest
- session - Variable in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupResponse
- session - Variable in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupSession
- session - Variable in class org.apache.cassandra.streaming.StreamDeserializingTask
- 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() - Method in class org.apache.cassandra.db.streaming.CassandraIncomingFile
- session() - Method in interface org.apache.cassandra.streaming.IncomingStream
- SESSION_FAILED - org.apache.cassandra.streaming.messages.StreamMessage.Type
- 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
- sessionCount() - Method in class org.apache.cassandra.service.ActiveRepairService
- sessionExists(TimeUUID) - 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.RepairJobDesc
-
RepairSession id
- sessionId - Variable in class org.apache.cassandra.repair.RepairSessionResult
- sessionId - Variable in class org.apache.cassandra.tracing.TraceState
- 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
- 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(InetSocketAddress, int, InetSocketAddress, Collection<StreamSummary>, Collection<StreamSummary>, StreamSession.State, String) - Constructor for class org.apache.cassandra.streaming.SessionInfo
- SessionInfo(SessionInfo) - 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(TimeUUID, SessionInfo, StreamSession.PrepareDirection) - 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 - Variable in class org.apache.cassandra.tracing.Tracing
- sessions() - Method in class org.apache.cassandra.streaming.StreamingState
- sessions() - Method in class org.apache.cassandra.streaming.StreamState
- Sessions() - Constructor for class org.apache.cassandra.streaming.StreamingState.Sessions
- SESSIONS - Static variable in class org.apache.cassandra.tracing.TraceKeyspace
- SessionState - Class in org.apache.cassandra.repair.state
- SessionState(Clock, TimeUUID, String, String[], CommonRange) - Constructor for class org.apache.cassandra.repair.state.SessionState
- SessionState.Phase - Class in org.apache.cassandra.repair.state
- SessionState.State - Enum in org.apache.cassandra.repair.state
- SessionSummary - Class in org.apache.cassandra.streaming
- SessionSummary(InetSocketAddress, InetSocketAddress, Collection<StreamSummary>, Collection<StreamSummary>) - Constructor for class org.apache.cassandra.streaming.SessionSummary
- sessionTimeout() - Method in class org.apache.cassandra.streaming.StreamSession
-
Call back on receiving
StreamMessage.Type.SESSION_FAILED
message. - set(boolean) - Method in class org.apache.cassandra.utils.WrappedBoolean
- set(int, ByteBuffer) - Method in interface org.apache.cassandra.cql3.functions.Arguments
-
Sets the specified value to the arguments
- set(int, ByteBuffer) - Method in class org.apache.cassandra.cql3.functions.FunctionArguments
- set(int, V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
- set(int, V, TypeToken<V>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th value to the provided value of the provided Java type. - set(int, V, Class<V>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th value to the provided value of the provided Java class. - set(int, V, TypeCodec<V>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th value to the provided value, converted using the givenTypeCodec
. - 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(Object, Object) - Method in class org.apache.cassandra.config.ForwardingProperty
- 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, 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, 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 givenTypeCodec
. - set(CQL3Type.Raw) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
- set(DataType) - Static method in class org.apache.cassandra.cql3.functions.types.DataType
-
Returns the type of "not frozen" sets of
elementType
elements. - set(DataType, boolean) - Static method in class org.apache.cassandra.cql3.functions.types.DataType
-
Returns the type of sets of
elementType
elements. - 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(AbstractPaxosRepair.Result) - Method in class org.apache.cassandra.service.paxos.AbstractPaxosRepair
- set(StartupChecks.StartupCheckType, String, Object) - Method in class org.apache.cassandra.config.StartupChecksOptions
- set(TraceState) - Method in class org.apache.cassandra.tracing.Tracing
- set(TraceState, ClientWarn.State) - Static method in class org.apache.cassandra.concurrent.ExecutorLocals.Impl
- set(T) - Method in class org.apache.cassandra.utils.DefaultValue
- set(T) - Method in class org.apache.cassandra.utils.Wrapped
- Set() - Constructor for class org.apache.cassandra.utils.IntegerInterval.Set
- SET - org.apache.cassandra.cql3.functions.types.DataType.Name
- SET - org.apache.cassandra.db.marshal.CollectionType.Kind
- SET - org.apache.cassandra.transport.DataType
- SET_KEYSPACE - org.apache.cassandra.transport.messages.ResultMessage.Kind
- SET_SELECTOR - org.apache.cassandra.cql3.selection.Selector.Kind
- SET_SEP_THREAD_NAME - org.apache.cassandra.config.CassandraRelevantProperties
- setAcceptedProtocols(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
- setActiveUpdate(boolean) - Method in class org.apache.cassandra.auth.AuthCache
- setActiveUpdate(boolean) - Method in interface org.apache.cassandra.auth.AuthCacheMBean
- setAllowFilteringEnabled(boolean) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setAllowFilteringEnabled(boolean) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setAllowFilteringEnabled(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Sets whether ALLOW FILTERING is allowed.
- setAllowSkipSyncMarkerCrc(boolean) - Static method in class org.apache.cassandra.db.commitlog.CommitLogSegmentReader
- setAllTermsToLowerCase(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
- setAllTermsToUpperCase(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
- setAlterTableEnabled(boolean) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setAlterTableEnabled(boolean) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setAlterTableEnabled(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Sets whether users can use the ALTER TABLE statement to change columns
- 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
- SetAuthCacheConfig - Class in org.apache.cassandra.tools.nodetool
- SetAuthCacheConfig() - Constructor for class org.apache.cassandra.tools.nodetool.SetAuthCacheConfig
- setAuthenticator(IAuthenticator) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setAuthFromRoot(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setAuthorizer(IAuthorizer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setAuthReadConsistencyLevel(ConsistencyLevel) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setAuthWriteConsistencyLevel(ConsistencyLevel) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setAutoHintsCleanupEnabled(boolean) - 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
- setAutoRepairsEnabled(boolean) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker
- setAutoSnapshot(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setAutoSnapshotTtl(DurationSpec.IntSecondsBound) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setAvailableProcessors(int) - Static method in class org.apache.cassandra.utils.FBUtilities
- setBackPressureEnabled(boolean) - Method in interface org.apache.cassandra.net.MessagingServiceMBean
-
Deprecated.See CASSANDRA-15375
- 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) - Method in class org.apache.cassandra.service.StorageService
- setBatchlogReplayThrottleInKB(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setBatchlogReplayThrottleInKiB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setBatchSizeFailThresholdInKiB(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
-
Deprecated.See CASSANDRA-17668
- setBatchSizeWarnThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.use setBatchSizeWarnThresholdInKiB instead as it will not throw non-standard exceptions. See CASSANDRA-17668
- setBatchSizeWarnThresholdInKiB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setBatchSizeWarnThresholdInKiB(int) - Method in class org.apache.cassandra.service.StorageService
- setBatchSizeWarnThresholdInKiB(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Sets the threshold for warning queries due to a large batch size
- 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
i
th 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
- setBuffer(ByteBuffer) - Method in class org.apache.cassandra.io.util.DataOutputBuffer
- setByte(int, byte) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Set the
i
th value 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
- 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. - 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(byte[], int, long, long) - 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
i
th value to the provided byte buffer. - setBytes(long, byte[], int, int) - Method in class org.apache.cassandra.io.util.Memory
-
Transfers count bytes from buffer to Memory
- 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(long, ByteBuffer) - Method in class org.apache.cassandra.io.util.Memory
- setBytes(long, ByteBuffer) - Static method in class org.apache.cassandra.utils.memory.MemoryUtil
- 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. - setBytesUnsafe(int, ByteBuffer) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th 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
- setCacheLoadTimeout(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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.StorageService
- setCasContentionTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setCasContentionTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
- setCasContentionTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setCaseSensitive(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.NonTokenizingOptions
- setCaseSensitive(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
- setCDCBlockWrites(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setCDCBlockWrites(boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLog
- setCDCBlockWrites(boolean) - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
- setCDCEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setCDCOnRepairEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setCDCOnRepairEnabled(boolean) - Method in class org.apache.cassandra.db.commitlog.CommitLog
- setCDCOnRepairEnabled(boolean) - Method in interface org.apache.cassandra.db.commitlog.CommitLogMBean
-
Set whether enable write path for CDC data during internodes streaming, e.g.
- setCDCState(CommitLogSegment.CDCState) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
-
Change the current cdcState on this CommitLogSegment.
- setCDCTotalSpaceInMiB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setCheckForDuplicateRowsDuringCompaction(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setCheckForDuplicateRowsDuringReads(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setChunkCache(ChunkCache) - Method in class org.apache.cassandra.io.sstable.SSTable.Builder
- setCIDRAuthorizer(ICIDRAuthorizer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setCidrGroupsForRole(RoleResource, CIDRPermissions) - Method in class org.apache.cassandra.auth.AbstractCIDRAuthorizer
- setCidrGroupsForRole(RoleResource, CIDRPermissions) - Method in class org.apache.cassandra.auth.CIDRPermissionsManager
-
Set CIDR permissions for a given role
- setCidrGroupsForRole(RoleResource, CIDRPermissions) - Method in interface org.apache.cassandra.auth.ICIDRAuthorizer
-
Set CIDR permissions for a given role
- setClientMode(boolean) - Static method in class org.apache.cassandra.config.Config
-
Deprecated.migrate to
DatabaseDescriptor.clientInitialization(boolean)
See CASSANDRA-12550 - setClientOptions(Map<String, String>) - Method in class org.apache.cassandra.service.ClientState
- setClientRequestSizeMetricsEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setClientRequestSizeMetricsEnabled(boolean) - Method in class org.apache.cassandra.service.StorageProxy
- setClientRequestSizeMetricsEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setClosed() - Method in class org.apache.cassandra.streaming.async.StreamingMultiplexedChannel
-
For testing purposes only.
- setCollectionSizeThreshold(String, String) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setCollectionSizeThreshold(String, String) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setCollectionSizeThreshold(DataStorageSpec.LongBytesBound, DataStorageSpec.LongBytesBound) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setColumnIndexCacheSize(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setColumnIndexCacheSize(int) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-17668
- setColumnIndexCacheSize(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.use setColumnIndexCacheSizeInKiB instead as it will not throw non-standard exceptions. See CASSANDRA-17668
- setColumnIndexCacheSizeInKiB(int) - Method in class org.apache.cassandra.service.StorageService
- setColumnIndexCacheSizeInKiB(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Sets the threshold for skipping the column index when caching partition info
- setColumnIndexSize(int) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-17668
- setColumnIndexSize(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.use setColumnIndexSizeInKiB instead as it will not throw non-standard exceptions. See CASSANDRA-17668
- setColumnIndexSize(int) - Method in class org.apache.cassandra.tools.NodeProbe
- SetColumnIndexSize - Class in org.apache.cassandra.tools.nodetool
- SetColumnIndexSize() - Constructor for class org.apache.cassandra.tools.nodetool.SetColumnIndexSize
- setColumnIndexSizeInKiB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setColumnIndexSizeInKiB(int) - Method in class org.apache.cassandra.service.StorageService
- setColumnIndexSizeInKiB(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Sets the granularity of the collation index of rows within a partition.
- setColumnsPerTableThreshold(int, int) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setColumnsPerTableThreshold(int, int) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setColumnsPerTableThreshold(int, int) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setColumnValueSizeThreshold(String, String) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setColumnValueSizeThreshold(String, String) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setColumnValueSizeThreshold(DataStorageSpec.LongBytesBound, DataStorageSpec.LongBytesBound) - Method in class org.apache.cassandra.config.GuardrailsOptions
- 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
-
Update commitlog_segment_size in the tests.
- setCommitLogSync(Config.CommitLogSync) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setCommitLogSyncGroupWindow(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setCommitLogSyncPeriod(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setCommitLogWriteDiskAccessMode(Config.DiskAccessMode) - 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
- setCompactionThroughputBytesPerSec(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
- setCompactionThroughputMebibytesPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setCompactionTombstoneWarningThreshold(int) - Method in class org.apache.cassandra.service.StorageService
- setCompactionTombstoneWarningThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-17194
- setCompactionType(OperationType) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionTask
- setCompactStorage() - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
- setCompactTablesEnabled(boolean) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setCompactTablesEnabled(boolean) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setCompactTablesEnabled(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Sets whether users can create new COMPACT STORAGE tables
- setComplexDeletionTime(ColumnMetadata) - Method in class org.apache.cassandra.cql3.UpdateParameters
- setComplexDeletionTimeForOverwrite(ColumnMetadata) - Method in class org.apache.cassandra.cql3.UpdateParameters
- setComponents(Collection<Component>) - Method in class org.apache.cassandra.io.sstable.SSTable.Builder
- 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
- setConcurrentIndexBuilders(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setConcurrentIndexBuilders(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
- setConcurrentIndexBuilders(int) - Method in class org.apache.cassandra.service.StorageService
- setConcurrentIndexBuilders(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setConcurrentMerkleTreeRequests(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setConcurrentMerkleTreeRequests(int) - Method in class org.apache.cassandra.service.ActiveRepairService
- setConcurrentMerkleTreeRequests(int) - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
- setConcurrentReaders(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setConcurrentValidations() - Method in class org.apache.cassandra.db.compaction.CompactionManager
- setConcurrentValidations(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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
- setConfig(Config) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setConnectionFactory(StreamingChannel.Factory) - Method in class org.apache.cassandra.streaming.StreamCoordinator
- setConsecutiveMessageErrorsThreshold(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setCoordinatorLargeReadAbortThreshold(String) - Method in class org.apache.cassandra.service.StorageService
- setCoordinatorLargeReadAbortThreshold(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setCoordinatorLargeReadWarnThreshold(String) - Method in class org.apache.cassandra.service.StorageService
- setCoordinatorLargeReadWarnThreshold(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setCoordinatorReadSizeFailThreshold(DataStorageSpec.LongBytesBound) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setCoordinatorReadSizeWarnThreshold(DataStorageSpec.LongBytesBound) - 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 minimum size of the thread pool.
- setCorePoolSize(int) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- setCorePoolSize(int) - Method in class org.apache.cassandra.concurrent.SEPExecutor
- setCorePoolSize(int) - Method in class org.apache.cassandra.concurrent.SingleThreadExecutorPlus
- setCorePoolSize(int) - Method in enum org.apache.cassandra.concurrent.Stage
-
Allows user to resize core thread pool size
- setCorePoolSize(int) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorJMXAdapter
- setCorePoolSize(int) - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- setCoreSecondaryIndexExecutorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
- setCoreSecondaryIndexExecutorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
- setCoreThreads(int) - Method in interface org.apache.cassandra.concurrent.ResizableThreadPoolMXBean
-
Deprecated.use setCorePoolSize instead. See CASSANDRA-15277
- setCoreThreads(int) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBase
- setCoreThreads(int) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorJMXAdapter
- 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(String) - Method in class org.apache.cassandra.service.StorageService
- setCorruptedTombstoneStrategy(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setCorruptedTombstoneStrategy(Config.CorruptedTombstoneStrategy) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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.StorageService
- setCounterWriteRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setCounterWriteRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
- setCounterWriteRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setCQLStartTime(Config.CQLStartTime) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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.
- setCredentialsCacheActiveUpdate(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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
- setCryptoProvider(AbstractCryptoProvider) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setCustomPayload(Map<String, ByteBuffer>) - Method in class org.apache.cassandra.transport.Message
- setDataDiskUsageMaxDiskSize(String) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setDataDiskUsageMaxDiskSize(String) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setDataDiskUsageMaxDiskSize(DataStorageSpec.LongBytesBound) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setDataDiskUsagePercentageThreshold(int, int) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setDataDiskUsagePercentageThreshold(int, int) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setDataDiskUsagePercentageThreshold(int, int) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setDataFile(FileHandle) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- setDate(int, LocalDate) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Set the
i
th 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
i
th 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. - setDefaultFailureDetector() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setDefaultKeyspaceReplicationFactor(int) - Method in class org.apache.cassandra.service.StorageService
- setDefaultKeyspaceReplicationFactor(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setDefaultKeyspaceReplicationFactor(int) - Method in class org.apache.cassandra.tools.NodeProbe
- setDefaultKeyspaceRF(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- SetDefaultKeyspaceRF - Class in org.apache.cassandra.tools.nodetool
- SetDefaultKeyspaceRF() - Constructor for class org.apache.cassandra.tools.nodetool.SetDefaultKeyspaceRF
- setDefaultSecondaryIndex(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setDefaultSecondaryIndexEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setDefaultShardCount(String) - Method in interface org.apache.cassandra.db.memtable.ShardedMemtableConfigMXBean
-
Adjust the shard count for sharded memtables that do not specify it explicitly in the memtable options.
- setDelegate(MBeanWrapper) - Method in class org.apache.cassandra.utils.MBeanWrapper.DelegatingMbeanWrapper
- setDeletionListener(Consumer<Path>) - Static method in class org.apache.cassandra.io.util.PathUtils
- setDenylistConsistencyLevel(ConsistencyLevel) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setDenylistInitialLoadRetrySeconds(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setDenylistMaxKeysPerTable(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setDenylistMaxKeysPerTable(int) - Method in class org.apache.cassandra.service.StorageProxy
- setDenylistMaxKeysPerTable(int) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setDenylistMaxKeysTotal(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setDenylistMaxKeysTotal(int) - Method in class org.apache.cassandra.service.StorageProxy
- setDenylistMaxKeysTotal(int) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setDenylistRangeReadsEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setDenylistReadsEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setDenylistRefreshSeconds(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setDenylistWritesEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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
- setDisableCoordinatorLocking(boolean) - Static method in class org.apache.cassandra.service.paxos.PaxosState
- 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() - 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
i
th 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
- setDropKeyspaceEnabled(boolean) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setDropKeyspaceEnabled(boolean) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setDropKeyspaceEnabled(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Sets whether users can DROP a keyspace
- setDropTruncateTableEnabled(boolean) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setDropTruncateTableEnabled(boolean) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setDropTruncateTableEnabled(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Sets whether users can TRUNCATE or DROP TABLE
- setDumpHeapOnUncaughtException(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setDumpHeapOnUncaughtException(boolean) - Method in class org.apache.cassandra.service.StorageProxy
- setDumpHeapOnUncaughtException(boolean) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setDynamicBadnessThreshold(double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setDynamicDataMaskingEnabled(boolean) - 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.RetrySpec
- setEnabled(Boolean) - Method in class org.apache.cassandra.config.EncryptionOptions
-
Sets if encryption should be enabled for this channel.
- setEnableDcLocalCommit(boolean) - Static method in class org.apache.cassandra.service.paxos.PaxosCommit
- setEnableDenylistRangeReads(boolean) - Method in class org.apache.cassandra.service.StorageProxy
- setEnableDenylistRangeReads(boolean) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setEnableDenylistReads(boolean) - Method in class org.apache.cassandra.service.StorageProxy
- setEnableDenylistReads(boolean) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setEnableDenylistWrites(boolean) - Method in class org.apache.cassandra.service.StorageProxy
- setEnableDenylistWrites(boolean) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setEnableDropCompactStorage(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setEnablePartitionDenylist(boolean) - Method in class org.apache.cassandra.service.StorageProxy
- setEnablePartitionDenylist(boolean) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- 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
- setEnforceNativeDeadlineForHints(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setEnforceNativeDeadlineForHints(boolean) - Method in class org.apache.cassandra.service.StorageService
- setEnforceNativeDeadlineForHints(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setEntireSSTableInterDCStreamThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
- setEntireSSTableInterDCStreamThroughputMebibytesPerSec(int) - Method in class org.apache.cassandra.service.StorageService
- setEntireSSTableInterDCStreamThroughputMebibytesPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setEntireSSTableInterDCStreamThroughputOutboundMebibytesPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setEntireSSTableStreamThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
- setEntireSSTableStreamThroughputMebibytesPerSec(int) - Method in class org.apache.cassandra.service.StorageService
- setEntireSSTableStreamThroughputMebibytesPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setEntireSSTableStreamThroughputOutboundMebibytesPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setEnum(Enum<?>) - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
-
Sets the value into system properties.
- 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.utils.concurrent.AsyncPromise
-
Complete the promise abnormally if not already complete
- setFailure(Throwable) - Method in interface org.apache.cassandra.utils.concurrent.Promise
-
Complete the promise abnormally if not already complete
- setFailure(Throwable) - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
-
Complete the promise abnormally if not already complete
- SetField(FieldIdentifier, Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.SetField
- setFieldsPerUDTThreshold(int, int) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setFieldsPerUDTThreshold(int, int) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setFieldsPerUDTThreshold(int, int) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setFileCacheEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setFilter(IFilter) - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderWithFilter.Builder
- setFirst(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- setFloat(int, float) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th 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
- setFlushTransaction(LifecycleTransaction) - Method in class org.apache.cassandra.db.memtable.AbstractMemtable
- setFlushTransaction(LifecycleTransaction) - Method in interface org.apache.cassandra.db.memtable.Memtable
- setForceNewPreparedStatementBehaviour(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setForSlice(Slice) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator.AbstractReader
- setForSlice(Slice) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator.ForwardReader
- setForSlice(Slice) - Method in interface org.apache.cassandra.io.sstable.AbstractSSTableIterator.Reader
- setFSErrorHandler(FSErrorHandler) - Static method in class org.apache.cassandra.io.util.FileUtils
- setFullQueryLogOptions(FullQueryLoggerOptions) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setGCLogThreshold(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setGcLogThresholdInMs(long) - Method in class org.apache.cassandra.service.GCInspector
- setGcLogThresholdInMs(long) - Method in interface org.apache.cassandra.service.GCInspectorMXBean
- setGCWarnThreshold(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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
- setGroupByEnabled(boolean) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setGroupByEnabled(boolean) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setGroupByEnabled(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Sets whether GROUP BY queries are allowed.
- setHasMorePages(PagingState) - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
- setHasSnapshots() - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
- 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) - Method in class org.apache.cassandra.service.StorageService
- setHintedHandoffThrottleInKB(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Sets the hinted handoff throttle in KiB 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
- setHintedHandoffThrottleInKiB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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(String) - Method in class org.apache.cassandra.service.StorageProxy
- setIdealConsistencyLevel(String) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setIdealConsistencyLevel(ConsistencyLevel) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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
- setIndexFile(FileHandle) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader.Builder
- setIndexRemoved(String, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
- setIndexSummary(IndexSummary) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader.Builder
- setIndexSummaryResizeIntervalInMinutes(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setInet(int, InetAddress) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th 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
- setInSelectCartesianProductThreshold(int, int) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setInSelectCartesianProductThreshold(int, int) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setInSelectCartesianProductThreshold(int, int) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- 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
i
th value 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
- 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. - 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
- setInterDCStreamThroughputMbitPerSec(int) - Method in class org.apache.cassandra.service.StorageService
- setInterDCStreamThroughputMbitPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setInterDCStreamThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-15234
- setInterDCStreamThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-15234
- setInterDCStreamThroughputMebibytesPerSec(int) - Method in class org.apache.cassandra.service.StorageService
- setInterDCStreamThroughputMebibytesPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setInterDCStreamThroughputMiB(int) - Method in class org.apache.cassandra.tools.NodeProbe
- setInterDCStreamThroughputOutboundBytesPerSec(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setInterDCStreamThroughputOutboundMebibytesPerSecAsInt(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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
- setIntersectFilteringQueryEnabled(boolean) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setIntersectFilteringQueryEnabled(boolean) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setIntersectFilteringQueryEnabled(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- setIntersectFilteringQueryEnabled(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setIntersectFilteringQueryWarned(boolean) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setIntersectFilteringQueryWarned(boolean) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setIntersectFilteringQueryWarned(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
- setIntersectFilteringQueryWarned(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setIOOptions(IOOptions) - Method in class org.apache.cassandra.io.sstable.SSTable.Builder
- setIsShutdownUnsafeForTests(boolean) - Method in class org.apache.cassandra.service.StorageService
-
for in-jvm dtest use - forces isShutdown to be set to whatever passed in.
- setItemsPerCollectionThreshold(int, int) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setItemsPerCollectionThreshold(int, int) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setItemsPerCollectionThreshold(int, int) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setKernelVersionSupplier(Supplier<Semver>) - Static method in class org.apache.cassandra.utils.FBUtilities
- setKeyCache(KeyCache) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader.Builder
- 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
- setKeyCount(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- setKeyspace(String) - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
- 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, boolean) - Method in class org.apache.cassandra.cql3.QualifiedName
-
Sets the keyspace.
- setKeyspace(CQLStatement) - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
- setKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.BatchStatement.Parsed
- setKeyspace(ClientState) - Method in class org.apache.cassandra.cql3.statements.QualifiedStatement
- setKeyspace(QueryState, CQLStatement) - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
- SetKeyspace(String) - Constructor for class org.apache.cassandra.transport.messages.ResultMessage.SetKeyspace
- setKeyspaceCountWarnThreshold(int) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-17195
- setKeyspaceCountWarnThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-17195
- setKeyspacesThreshold(int, int) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setKeyspacesThreshold(int, int) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setKeyspacesThreshold(int, int) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setLast(String, FilterPipelineTask<K, V>) - Method in class org.apache.cassandra.index.sasi.analyzer.filter.FilterPipelineTask
- setLast(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- 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 acquired, subsequent calls toResourceLimits.Limit.allocate(long)
orResourceLimits.Limit.tryAllocate(long)
will succeed. - setLimitBytes(long) - Method in class org.apache.cassandra.index.sai.utils.NamedMemoryLimiter
- setList(int, List<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th value to the provided list. - setList(int, List<E>, TypeToken<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th value to the provided list, which elements are of the provided Java type. - setList(int, List<E>, Class<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th value to the provided list, which elements are of the provided Java class. - 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>, 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. - 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. - setListenAddress(InetAddress) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setListener(HeapPool.Logged.Listener) - Static method in class org.apache.cassandra.utils.memory.HeapPool.Logged
- setListenOnBroadcastAddress(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setLocalDataCenter(String) - 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
- setLocalReadSizeFailThreshold(DataStorageSpec.LongBytesBound) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setLocalReadSizeWarnThreshold(DataStorageSpec.LongBytesBound) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setLocalReadTooLargeAbortThreshold(String) - Method in class org.apache.cassandra.service.StorageService
- setLocalReadTooLargeAbortThreshold(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setLocalReadTooLargeWarnThreshold(String) - Method in class org.apache.cassandra.service.StorageService
- setLocalReadTooLargeWarnThreshold(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- 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(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
- SetLoggingLevel - Class in org.apache.cassandra.tools.nodetool
- SetLoggingLevel() - Constructor for class org.apache.cassandra.tools.nodetool.SetLoggingLevel
- setLong(int, long) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th value to the provided long. - setLong(long) - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
-
Sets the value into system properties.
- 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
- 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. - setLooseEmptyEnabled(boolean) - Method in class org.apache.cassandra.gms.Gossiper
- setLooseEmptyEnabled(boolean) - Method in interface org.apache.cassandra.gms.GossiperMBean
- 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
i
th value to the provided map. - setMap(int, Map<K, V>, TypeToken<K>, TypeToken<V>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th value to the provided map, which keys and values are of the provided Java types. - setMap(int, Map<K, V>, Class<K>, Class<V>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th value to the provided map, which keys and values are of the provided Java classes. - 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>, 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. - 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. - setMaterializedViewsEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setMaterializedViewsPerTableThreshold(int, int) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setMaterializedViewsPerTableThreshold(int, int) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setMaterializedViewsPerTableThreshold(int, int) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- 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.SSTableReader.Builder
- 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
- setMaxHintsSizePerHostInMiB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setMaxHintsSizePerHostInMiB(int) - Method in class org.apache.cassandra.service.StorageProxy
- setMaxHintsSizePerHostInMiB(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 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.ScheduledThreadPoolExecutorPlus
- setMaximumPoolSize(int) - Method in class org.apache.cassandra.concurrent.SEPExecutor
- setMaximumPoolSize(int) - Method in class org.apache.cassandra.concurrent.SingleThreadExecutorPlus
- setMaximumPoolSize(int) - Method in enum org.apache.cassandra.concurrent.Stage
-
Allows user to resize maximum size of the thread pool.
- setMaximumPoolSize(int) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorJMXAdapter
- setMaximumPoolSize(int) - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- setMaximumReplicationFactorThreshold(int, int) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setMaximumReplicationFactorThreshold(int, int) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setMaximumReplicationFactorThreshold(int, int) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setMaximumSecondaryIndexExecutorThreads(int) - Method in class org.apache.cassandra.db.compaction.CompactionManager
- setMaximumSecondaryIndexExecutorThreads(int) - Method in interface org.apache.cassandra.db.compaction.CompactionManagerMBean
- setMaximumThreads(int) - Method in interface org.apache.cassandra.concurrent.ResizableThreadPoolMXBean
-
Deprecated.use setMaximumThreads instead. See CASSANDRA-15277
- setMaximumThreads(int) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBase
- setMaximumThreads(int) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorJMXAdapter
- setMaximumTimestampThreshold(String, String) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setMaximumTimestampThreshold(String, String) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Sets the warning upper bound for user supplied timestamps.
- setMaximumTimestampThreshold(DurationSpec.LongMicrosecondsBound, DurationSpec.LongMicrosecondsBound) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setMaximumTimestampThreshold(DurationSpec.LongMicrosecondsBound, DurationSpec.LongMicrosecondsBound) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Sets the warning upper bound for user supplied timestamps
- 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.
- setMaxSpaceForCompactionsPerDrive(double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setMaxTokenLength(int) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
- setMaxTopSizePartitionCount(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setMaxTopSizePartitionCount(int) - Method in class org.apache.cassandra.service.StorageService
- setMaxTopSizePartitionCount(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setMaxTopTombstonePartitionCount(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setMaxTopTombstonePartitionCount(int) - Method in class org.apache.cassandra.service.StorageService
- setMaxTopTombstonePartitionCount(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- 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.indexsummary.IndexSummaryManager
- setMemoryPoolCapacityInMB(long) - Method in interface org.apache.cassandra.io.sstable.indexsummary.IndexSummaryManagerMBean
- setMetadata(KeyspaceMetadata) - Method in class org.apache.cassandra.db.Keyspace
- setMetadataChanged() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
- setMetadataCollector(MetadataCollector) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- 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
- setMinFreeSpacePerDriveInMebibytes(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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
- setMinimumReplicationFactorThreshold(int, int) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setMinimumReplicationFactorThreshold(int, int) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setMinimumReplicationFactorThreshold(int, int) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setMinimumTimestampThreshold(String, String) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setMinimumTimestampThreshold(String, String) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Sets the warning lower bound for user supplied timestamps.
- setMinimumTimestampThreshold(DurationSpec.LongMicrosecondsBound, DurationSpec.LongMicrosecondsBound) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setMinimumTimestampThreshold(DurationSpec.LongMicrosecondsBound, DurationSpec.LongMicrosecondsBound) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Sets the warning lower bound for user supplied timestamps
- setMinTokenLength(int) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
- setMinTrackedPartitionSize(String) - Method in class org.apache.cassandra.service.StorageService
- setMinTrackedPartitionSize(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setMinTrackedPartitionSizeInBytes(DataStorageSpec.LongBytesBound) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setMinTrackedPartitionTombstoneCount(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setMinTrackedPartitionTombstoneCount(long) - Method in class org.apache.cassandra.service.StorageService
- setMinTrackedPartitionTombstoneCount(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- 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
- setMutableValue(M, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.NumberType.NumberArgumentDeserializer
-
Sets the value of the mutable.
- 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
- setName(String, boolean) - Method in class org.apache.cassandra.cql3.QualifiedName
- setName(String, boolean) - Method in class org.apache.cassandra.cql3.RoleName
- setNativeTransportAllowOlderProtocols(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setNativeTransportBackoffOnQueueOverload(long, long, TimeUnit) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setNativeTransportBackoffOnQueueOverloadInMillis(long, long) - Method in class org.apache.cassandra.service.StorageService
- setNativeTransportBackoffOnQueueOverloadInMillis(long, long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setNativeTransportConcurrentRequestDataInFlightInBytes(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setNativeTransportIdleTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setNativeTransportMaxAuthThreads(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
If this value is set to <= 0 it will move auth requests to the standard request pool regardless of the current size of the
Dispatcher.authExecutor
's active size. - 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) - Method in class org.apache.cassandra.service.StorageService
- setNativeTransportMaxConcurrentRequestsInBytes(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setNativeTransportMaxConcurrentRequestsInBytesPerIp(long) - Method in class org.apache.cassandra.service.StorageService
- setNativeTransportMaxConcurrentRequestsInBytesPerIp(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setNativeTransportMaxFrameSize(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setNativeTransportMaxQueueItemAgeThreshold(double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setNativeTransportMaxRequestDataInFlightPerIpInBytes(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setNativeTransportMaxRequestsPerSecond(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setNativeTransportMaxRequestsPerSecond(int) - Method in class org.apache.cassandra.service.StorageService
- setNativeTransportMaxRequestsPerSecond(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setNativeTransportMaxRequestsPerSecond(int) - Static method in class org.apache.cassandra.transport.ClientResourceLimits
- 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
- setNativeTransportQueueMaxItemAgeThreshold(double) - Method in class org.apache.cassandra.service.StorageService
- setNativeTransportQueueMaxItemAgeThreshold(double) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setNativeTransportRateLimitingEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setNativeTransportRateLimitingEnabled(boolean) - Method in class org.apache.cassandra.service.StorageService
- setNativeTransportRateLimitingEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setNativeTransportReceiveQueueCapacityInBytes(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setNativeTransportThrowOnOverload(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setNativeTransportThrowOnOverload(boolean) - Method in class org.apache.cassandra.service.StorageService
- setNativeTransportThrowOnOverload(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setNativeTransportTimeout(long, TimeUnit) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setNativeTransportTimeoutMillis(long) - Method in class org.apache.cassandra.service.StorageService
- setNativeTransportTimeoutMillis(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- 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
- setNonPartitionRestrictedQueryEnabled(boolean) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setNonPartitionRestrictedQueryEnabled(boolean) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setNonPartitionRestrictedQueryEnabled(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Sets whether it is possible to execute a query against indexes (secondary or SAI) without specifying any partition key restrictions.
- setNonPartitionRestrictedQueryEnabled(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Sets whether it is possible to execute a query against indexes (secondary or SAI) without specifying any partition key restrictions.
- setNormalModeUnsafe() - Method in class org.apache.cassandra.service.StorageService
-
Only used in jvm dtest when not using GOSSIP.
- setOf(TypeToken<T>) - Static method in class org.apache.cassandra.cql3.functions.types.TypeTokens
-
Create a
TypeToken
that represents aSet
whose elements are of the given type. - setOf(Class<T>) - Static method in class org.apache.cassandra.cql3.functions.types.TypeTokens
-
Create a
TypeToken
that represents aSet
whose elements are of the given type. - setOnClose(Runnable) - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator
- setOnLeak(Ref.OnLeak) - Static method in class org.apache.cassandra.utils.concurrent.Ref
- setOnLinearizabilityViolation(Runnable) - Static method in class org.apache.cassandra.service.paxos.PaxosPrepare
- setOp(Expression.Op) - Method in class org.apache.cassandra.index.sasi.plan.Expression
- setOpenReason(SSTableReader.OpenReason) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- setOpenResult(boolean) - Method in class org.apache.cassandra.db.compaction.unified.ShardedMultiWriter
- setOpenResult(boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
- setOpenResult(boolean) - Method in class org.apache.cassandra.io.sstable.RangeAwareSSTableWriter
- setOpenResult(boolean) - Method in class org.apache.cassandra.io.sstable.SimpleSSTableMultiWriter
- setOpenResult(boolean) - Method in interface org.apache.cassandra.io.sstable.SSTableMultiWriter
- setOpenResult(boolean) - Method in class org.apache.cassandra.io.sstable.SSTableZeroCopyWriter
- 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
- setOrList() - Static method in interface org.apache.cassandra.cql3.functions.FunctionParameter
- setOrListToJsonString(ByteBuffer, AbstractType<?>, ProtocolVersion) - Static method in class org.apache.cassandra.db.marshal.CollectionType
- setOtcBacklogExpirationInterval(int) - Method in class org.apache.cassandra.service.StorageProxy
-
Deprecated.See CASSANDRA-15066
- setOtcBacklogExpirationInterval(int) - Method in interface org.apache.cassandra.service.StorageProxyMBean
-
Deprecated.See CASSANDRA-15066
- setOutput(PrintStream) - Method in class org.apache.cassandra.tools.AbstractJmxClient
- setOutput(Output) - Method in class org.apache.cassandra.tools.NodeProbe
- setOverrideLoadConfig(Supplier<Config>) - Static method in class org.apache.cassandra.config.Config
- setPageSizeThreshold(int, int) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setPageSizeThreshold(int, int) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setPageSizeThreshold(int, int) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- 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
- setPartitionDenylistEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setPartitionerUnsafe(IPartitioner) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setPartitionerUnsafe(IPartitioner) - Method in class org.apache.cassandra.service.StorageService
- setPartitionIndex(PartitionIndex) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader.Builder
- 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
- setPartitionKeysInSelectThreshold(int, int) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setPartitionKeysInSelectThreshold(int, int) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setPartitionKeysInSelectThreshold(int, int) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setPartitionSizeThreshold(String, String) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setPartitionSizeThreshold(String, String) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setPartitionSizeThreshold(DataStorageSpec.LongBytesBound, DataStorageSpec.LongBytesBound) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setPartitionTombstonesThreshold(long, long) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setPartitionTombstonesThreshold(long, long) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setPartitionTombstonesThreshold(long, long) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setPaxosAutoRepairsEnabled(boolean) - Method in class org.apache.cassandra.service.StorageService
- setPaxosAutoRepairsEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setPaxosContentionMaxWait(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setPaxosContentionMinDelta(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setPaxosContentionMinWait(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setPaxosContentionStrategy(String) - Method in class org.apache.cassandra.service.StorageProxy
- setPaxosContentionStrategy(String) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setPaxosContentionWaitRandomizer(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setPaxosCoordinatorLockingDisabled(boolean) - Method in class org.apache.cassandra.service.StorageProxy
- setPaxosCoordinatorLockingDisabled(boolean) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setPaxosDcLocalCommitEnabled(boolean) - Method in class org.apache.cassandra.service.StorageService
- setPaxosDcLocalCommitEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setPaxosOnLinearizabilityViolations(String) - Method in class org.apache.cassandra.service.StorageService
- setPaxosOnLinearizabilityViolations(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setPaxosOnLinearizabilityViolations(Config.PaxosOnLinearizabilityViolation) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setPaxosPurgeGrace(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setPaxosPurgeGraceSeconds(long) - Method in class org.apache.cassandra.service.StorageService
- setPaxosPurgeGraceSeconds(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setPaxosRepairEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setPaxosRepairEnabled(boolean) - Method in class org.apache.cassandra.service.StorageService
- setPaxosRepairEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setPaxosRepairParallelism(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setPaxosRepairParallelism(int) - Method in class org.apache.cassandra.service.ActiveRepairService
- setPaxosRepairParallelism(int) - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
- setPaxosStateFlushEnabled(boolean) - Method in class org.apache.cassandra.service.StorageService
- setPaxosStateFlushEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setPaxosStatePurging(String) - Method in class org.apache.cassandra.service.StorageService
- setPaxosStatePurging(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setPaxosStatePurging(Config.PaxosStatePurging) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setPaxosVariant(String) - Method in class org.apache.cassandra.service.StorageProxy
- setPaxosVariant(String) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setPaxosVariant(Config.PaxosVariant) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setPaxosVariant(Config.PaxosVariant) - Static method in class org.apache.cassandra.service.paxos.Paxos
- setPendingRepair(TimeUUID) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- setPermissionsCacheActiveUpdate(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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(LongConsumer) - 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
- setRangeRpcTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setRangeRpcTimeout(long) - Method in class org.apache.cassandra.service.StorageService
- setRangeRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setRangeRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
- setRangeRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- 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(double) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Deprecated.Use setRateInBytes instead See CASSANDRA-17225
- setRate(int) - Method in class org.apache.cassandra.batchlog.BatchlogManager
-
Sets the rate for the current rate limiter.
- setRate(int) - Method in class org.apache.cassandra.utils.concurrent.NonBlockingRateLimiter
- setRate(int, Ticker) - Method in class org.apache.cassandra.utils.concurrent.NonBlockingRateLimiter
- setRateInBytes(double) - Method in class org.apache.cassandra.db.compaction.CompactionManager
-
Sets the rate for the rate limiter.
- setReadBeforeWriteListOperationsEnabled(boolean) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setReadBeforeWriteListOperationsEnabled(boolean) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setReadBeforeWriteListOperationsEnabled(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Sets whether list operations that require read before write are allowed.
- setReadConsistencyLevel(ConsistencyLevel) - Method in class org.apache.cassandra.auth.AuthProperties
- setReadConsistencyLevel(ConsistencyLevel) - Method in interface org.apache.cassandra.auth.AuthPropertiesMXBean
- setReadConsistencyLevelsDisallowed(Set<String>) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setReadConsistencyLevelsDisallowed(Set<String>) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setReadConsistencyLevelsDisallowed(Set<ConsistencyLevel>) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setReadConsistencyLevelsDisallowedCSV(String) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setReadConsistencyLevelsDisallowedCSV(String) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setReadConsistencyLevelsWarned(Set<String>) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setReadConsistencyLevelsWarned(Set<String>) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setReadConsistencyLevelsWarned(Set<ConsistencyLevel>) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setReadConsistencyLevelsWarnedCSV(String) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setReadConsistencyLevelsWarnedCSV(String) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setReadRpcTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setReadRpcTimeout(long) - Method in class org.apache.cassandra.service.StorageService
- setReadRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setReadRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
- setReadRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setReadThresholdsEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setReadThresholdsEnabled(boolean) - Method in class org.apache.cassandra.service.StorageService
- setReadThresholdsEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setRecycleWhenFreeForCurrentThread(boolean) - Method in class org.apache.cassandra.utils.memory.BufferPool
- setRemoteServerStub(Remote) - Method in class org.apache.cassandra.utils.JMXServerUtils.JmxRegistry
- setRepairedAt(long) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
- setRepairedAt(long) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- 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
- setRepairRpcTimeout(Long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setRepairRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageService
- setRepairRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setRepairSessionMaximumTreeDepth(int) - Method in class org.apache.cassandra.service.StorageService
- setRepairSessionMaximumTreeDepth(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setRepairSessionMaxTreeDepth(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setRepairSessionMaxTreeDepth(int) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-17668
- setRepairSessionMaxTreeDepth(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.use setRepairSessionMaximumTreeDepth instead as it will not throw non-standard exceptions. See CASSANDRA-17668
- setRepairSessionSpaceInMebibytes(int) - Method in class org.apache.cassandra.service.ActiveRepairService
-
Deprecated.See CASSANDRA-17668
- setRepairSessionSpaceInMebibytes(int) - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
-
Deprecated.use setRepairSessionSpaceInMiB instead as it will not throw non-standard exceptions. See CASSANDRA-17668
- setRepairSessionSpaceInMegabytes(int) - Method in class org.apache.cassandra.service.ActiveRepairService
-
Deprecated.See CASSANDRA-15234
- setRepairSessionSpaceInMegabytes(int) - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
-
Deprecated.See CASSANDRA-15234
- setRepairSessionSpaceInMiB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setRepairSessionSpaceInMiB(int) - Method in class org.apache.cassandra.service.ActiveRepairService
- setRepairSessionSpaceInMiB(int) - Method in interface org.apache.cassandra.service.ActiveRepairServiceMBean
- setRepairStateExpires(DurationSpec.LongNanosecondsBound) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setRepairStateSize(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setReplaced() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- setResizeIntervalInMinutes(int) - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryManager
- setResizeIntervalInMinutes(int) - Method in interface org.apache.cassandra.io.sstable.indexsummary.IndexSummaryManagerMBean
-
Set resizeIntervalInMinutes = -1 for disabled; This is the equivalent of index_summary_resize_interval being set to null in cassandra.yaml
- 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
- setRolesCacheActiveUpdate(boolean) - 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
- setRowCacheSizeInMiB(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setRowIndexFile(FileHandle) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader.Builder
- setRowIndexReadSizeAbortThreshold(String) - Method in class org.apache.cassandra.service.StorageService
- setRowIndexReadSizeAbortThreshold(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setRowIndexReadSizeFailThreshold(DataStorageSpec.LongBytesBound) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setRowIndexReadSizeWarnThreshold(String) - Method in class org.apache.cassandra.service.StorageService
- setRowIndexReadSizeWarnThreshold(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setRowIndexReadSizeWarnThreshold(DataStorageSpec.LongBytesBound) - 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.StorageService
- setRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
- setRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- Sets - Class in org.apache.cassandra.cql3
-
Static helper methods and classes for sets.
- Sets.Adder - Class in org.apache.cassandra.cql3
- Sets.DelayedValue - Class in org.apache.cassandra.cql3
- Sets.Discarder - Class in org.apache.cassandra.cql3
- Sets.ElementDiscarder - Class in org.apache.cassandra.cql3
- Sets.Literal - Class in org.apache.cassandra.cql3
- Sets.Marker - Class in org.apache.cassandra.cql3
- Sets.Setter - Class in org.apache.cassandra.cql3
- Sets.Value - Class in org.apache.cassandra.cql3
- setSaiFrozenTermSizeThreshold(String, String) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setSaiFrozenTermSizeThreshold(String, String) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setSaiFrozenTermSizeThreshold(DataStorageSpec.LongBytesBound, DataStorageSpec.LongBytesBound) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setSaiFrozenTermSizeThreshold(DataStorageSpec.LongBytesBound, DataStorageSpec.LongBytesBound) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Sets warning and failure thresholds for the size of frozen terms written to an SAI index
- setSaiSSTableIndexesPerQueryThreshold(int, int) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setSaiSSTableIndexesPerQueryThreshold(int, int) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setSaiSSTableIndexesPerQueryThreshold(int, int) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Sets warning and failure thresholds for the number of SAI SSTable indexes searched by a query
- setSaiSSTableIndexesPerQueryThreshold(int, int) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Sets warning and failure thresholds for the number of SAI SSTable indexes searched by a query
- setSaiStringTermSizeThreshold(String, String) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setSaiStringTermSizeThreshold(String, String) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setSaiStringTermSizeThreshold(DataStorageSpec.LongBytesBound, DataStorageSpec.LongBytesBound) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setSaiStringTermSizeThreshold(DataStorageSpec.LongBytesBound, DataStorageSpec.LongBytesBound) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Sets warning and failure thresholds for the size of string terms written to an SAI index
- setSaiVectorTermSizeThreshold(String, String) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setSaiVectorTermSizeThreshold(String, String) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setSaiVectorTermSizeThreshold(DataStorageSpec.LongBytesBound, DataStorageSpec.LongBytesBound) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setSaiVectorTermSizeThreshold(DataStorageSpec.LongBytesBound, DataStorageSpec.LongBytesBound) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Sets warning and failure thresholds for the size of vector terms written to an SAI index
- setSASIIndexesEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setScope(CQLStatement) - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
- setSecondaryIndexesEnabled(boolean) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setSecondaryIndexesEnabled(boolean) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setSecondaryIndexesEnabled(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Enables or disables the ability to create secondary indexes
- setSecondaryIndexesPerTableThreshold(int, int) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setSecondaryIndexesPerTableThreshold(int, int) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setSecondaryIndexesPerTableThreshold(int, int) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setSecondaryIndexGroups(Collection<Index.Group>) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- setSeedProvider(SeedProvider) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setSelectedSSTableFormat(SSTableFormat<?, ?>) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setSerializationHeader(SerializationHeader) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- setSerializationHeader(SerializationHeader) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- SetSerializer<T> - Class in org.apache.cassandra.serializers
- SetSerializer(TypeSerializer<T>, ValueComparators) - Constructor for class org.apache.cassandra.serializers.SetSerializer
- setSession(PaxosCleanupSession) - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosRepairState
- setSet(int, Set<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th value to the provided set. - setSet(int, Set<E>, TypeToken<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th value to the provided set, which elements are of the provided Java type. - setSet(int, Set<E>, Class<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th value to the provided set, which elements are of the provided Java class. - 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>, 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. - 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. - 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
i
th value 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
- 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. - setShouldListenOnBroadcastAddress(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setSimpleStrategyEnabled(boolean) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setSimpleStrategyEnabled(boolean) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setSimpleStrategyEnabled(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Sets whether SimpleStrategy is allowed on keyspace creation or alteration
- setSkipMetadata() - Method in class org.apache.cassandra.cql3.ResultSet.ResultMetadata
- setSkipPaxosRepairCompatibilityCheck(boolean) - Static method in class org.apache.cassandra.service.paxos.PaxosRepair
- setSkipPaxosRepairCompatibilityCheck(boolean) - Method in class org.apache.cassandra.service.StorageService
- setSkipPaxosRepairCompatibilityCheck(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setSkipPaxosRepairOnTopologyChange(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setSkipPaxosRepairOnTopologyChange(boolean) - Method in class org.apache.cassandra.service.StorageService
- setSkipPaxosRepairOnTopologyChange(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setSkipPaxosRepairOnTopologyChangeKeyspaces(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setSkipPaxosRepairOnTopologyChangeKeyspaces(String) - Method in class org.apache.cassandra.service.StorageService
- setSkipPaxosRepairOnTopologyChangeKeyspaces(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setSkipStreamDiskSpaceCheck(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setSkipStreamDiskSpaceCheck(boolean) - Method in class org.apache.cassandra.service.StorageService
- setSkipStreamDiskSpaceCheck(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- 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) - Method in class org.apache.cassandra.service.StorageService
-
Negative number for disabled
- setSSTablePreemptiveOpenIntervalInMB(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setSSTablePreemptiveOpenIntervalInMiB(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
Negative number for disabled
- setSStableReadRatePersistenceEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setSStableReadRatePersistenceEnabled(boolean) - Method in class org.apache.cassandra.service.StorageProxy
- setSStableReadRatePersistenceEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setState(ConsistentSession.State) - Method in class org.apache.cassandra.repair.consistent.ConsistentSession
- setState(ConsistentSession.State) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession
- setStateFlushEnabled(boolean) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker
- setStatsMetadata(StatsMetadata) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- setStemTerms(boolean) - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
- setStrategy(String) - Static method in class org.apache.cassandra.service.paxos.ContentionStrategy
- 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
- setStreamEntireSSTables(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setStreamFactory(AutoSavingCache.IStreamFactory) - Static method in class org.apache.cassandra.cache.AutoSavingCache
- setStreamId(int) - Method in class org.apache.cassandra.transport.Message
- setStreamingSlowEventsLogTimeout(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setStreamingSlowEventsLogTimeout(String) - Method in class org.apache.cassandra.streaming.StreamManager
- setStreamingSlowEventsLogTimeout(String) - Method in interface org.apache.cassandra.streaming.StreamManagerMBean
-
Sets the timeout for the streaming slow events log
- setStreamingStateExpires(DurationSpec.LongNanosecondsBound) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setStreamingStateSize(DataStorageSpec.LongBytesBound) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setStreamingStatsEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setStreamingStatsEnabled(boolean) - Method in class org.apache.cassandra.streaming.StreamManager
- setStreamingStatsEnabled(boolean) - Method in interface org.apache.cassandra.streaming.StreamManagerMBean
-
enable/disable collection of streaming stats while streaming is running.
- 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
- setStreamThroughputMbitPerSec(int) - Method in class org.apache.cassandra.service.StorageService
- setStreamThroughputMbitPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setStreamThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-15234
- setStreamThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-15234
- setStreamThroughputMebibytesPerSec(int) - Method in class org.apache.cassandra.service.StorageService
- setStreamThroughputMebibytesPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setStreamThroughputMiB(int) - Method in class org.apache.cassandra.tools.NodeProbe
- setStreamThroughputOutboundBytesPerSec(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setStreamThroughputOutboundMebibytesPerSecAsInt(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setStreamThroughputOutboundMegabitsPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setString(int, String) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th value to the provided string. - setString(String) - Method in enum org.apache.cassandra.config.CassandraRelevantProperties
-
Sets the value into system properties.
- 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.utils.concurrent.AsyncPromise
-
Complete the promise successfully if not already complete
- setSuccess(V) - Method in interface org.apache.cassandra.utils.concurrent.Promise
-
Complete the promise successfully if not already complete
- setSuccess(V) - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
-
Complete the promise successfully if not already complete
- setSuspected(boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.Builder
- 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) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-17195
- setTableCountWarnThreshold(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-17195
- 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.
- setTableMetadata(TableMetadataRef) - Method in class org.apache.cassandra.io.sstable.SSTableLoader.Client
- setTableMetadata(TableMetadataRef) - Method in class org.apache.cassandra.utils.NativeSSTableLoaderClient
- setTableMetadataRef(TableMetadataRef) - Method in class org.apache.cassandra.io.sstable.SSTable.Builder
- setTablePropertiesDisallowed(String...) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setTablePropertiesDisallowed(Set<String>) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setTablePropertiesDisallowed(Set<String>) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setTablePropertiesDisallowed(Set<String>) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setTablePropertiesDisallowedCSV(String) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setTablePropertiesDisallowedCSV(String) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setTablePropertiesIgnored(String...) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setTablePropertiesIgnored(Set<String>) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setTablePropertiesIgnored(Set<String>) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setTablePropertiesIgnored(Set<String>) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setTablePropertiesIgnoredCSV(String) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setTablePropertiesIgnoredCSV(String) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setTablePropertiesWarned(String...) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setTablePropertiesWarned(Set<String>) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setTablePropertiesWarned(Set<String>) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setTablePropertiesWarned(Set<String>) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setTablePropertiesWarnedCSV(String) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setTablePropertiesWarnedCSV(String) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setTablesThreshold(int, int) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setTablesThreshold(int, int) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setTablesThreshold(int, int) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setTargetDirectory(String) - Method in class org.apache.cassandra.db.compaction.CompactionIterator
- 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
- 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
i
th 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(int, Date) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Set the
i
th value to the provided date. - setTimestamp(long) - Method in class org.apache.cassandra.audit.AuditLogEntry.Builder
- 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.io.sstable.format.big.IndexState
- setTokens(Collection<Token>) - Method in class org.apache.cassandra.service.StorageService
-
This method updates the local token on disk
- setTokenSpaceCoverage(double) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
- 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
i
th value tonull
. - setToNull(String) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByNameData
-
Sets the value for (all occurrences of) variable
name
tonull
. - 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. - setToString(List<?>) - Static method in class org.apache.cassandra.cql3.Sets
-
Create a
String
representation of the set containing the specified 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
- setTransferHintsOnDecommission(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setTransferHintsOnDecommission(boolean) - Method in class org.apache.cassandra.service.StorageService
- setTransferHintsOnDecommission(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setTransientReplicationEnabledUnsafe(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setTransientSSTable(boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter.Builder
- setTruncateRpcTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setTruncateRpcTimeout(long) - Method in class org.apache.cassandra.service.StorageService
- setTruncateRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setTruncateRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
- setTruncateRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setTupleValue(int, TupleValue) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th 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(String) - Method in class org.apache.cassandra.tools.JMXTool.Attribute
- setType(String) - Method in class org.apache.cassandra.tools.JMXTool.Parameter
- 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
- setUDTValue(int, UDTValue) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th 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.utils.concurrent.AbstractFuture
- setUncancellable() - Method in class org.apache.cassandra.utils.concurrent.AsyncPromise
-
Prevent a future caller from cancelling this promise
- setUncancellable() - Method in class org.apache.cassandra.utils.concurrent.FutureCombiner
- setUncancellable() - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
-
Prevent a future caller from cancelling this promise
- setUncancellableExclusive() - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- setUncancellableExclusive() - Method in class org.apache.cassandra.utils.concurrent.AsyncPromise
-
Prevent a future caller from cancelling this promise
- setUncancellableExclusive() - Method in class org.apache.cassandra.utils.concurrent.FutureCombiner
- setUncancellableExclusive() - Method in interface org.apache.cassandra.utils.concurrent.Promise
-
Prevent a future caller from cancelling this promise
- setUncancellableExclusive() - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
-
Prevent a future caller from cancelling this promise
- setUncompressedTablesEnabled(boolean) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setUncompressedTablesEnabled(boolean) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setUncompressedTablesEnabled(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Sets whether users can disable compression on tables
- 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.AllowAllCIDRAuthorizer
- 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.CassandraCIDRAuthorizer
- setup() - Method in class org.apache.cassandra.auth.CassandraNetworkAuthorizer
- setup() - Method in class org.apache.cassandra.auth.CassandraRoleManager
- setup() - Method in class org.apache.cassandra.auth.CIDRGroupsMappingManager
- setup() - Method in class org.apache.cassandra.auth.CIDRPermissionsManager
- 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.ICIDRAuthorizer
- 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.MutualTlsAuthenticator
- setup() - Method in class org.apache.cassandra.auth.MutualTlsWithPasswordFallbackAuthenticator
- setup() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
- setup() - Method in class org.apache.cassandra.repair.state.CoordinatorState.Phase
- setup() - Method in class org.apache.cassandra.service.CassandraDaemon
-
This is a hook for concrete daemons to initialize themselves suitably.
- setup(boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- setup(SSTableReader, boolean, Collection<? extends AutoCloseable>) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.InstanceTidier
- SETUP - org.apache.cassandra.repair.state.CoordinatorState.State
- 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
- setupInstance(boolean) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- setupInstance(boolean) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- setupInstance(boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- setupInstance(boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderWithFilter
- setupInternode() - Method in interface org.apache.cassandra.auth.IInternodeAuthenticator
-
Setup is called once upon system startup to initialize the IAuthenticator.
- 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
- setupThread(T) - Method in class org.apache.cassandra.concurrent.NamedThreadFactory
- setupThread(T, int, ClassLoader, Thread.UncaughtExceptionHandler) - Static method in class org.apache.cassandra.concurrent.NamedThreadFactory
- setUptimeFn(LongSupplier) - Static method in class org.apache.cassandra.schema.MigrationCoordinator
- 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
- setUserTimestampsEnabled(boolean) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setUserTimestampsEnabled(boolean) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setUserTimestampsEnabled(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Sets whether user-provided timestamps are allowed.
- setUseStatementsEnabled(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setUseStatementsEnabled(boolean) - Method in class org.apache.cassandra.service.StorageProxy
- setUseStatementsEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setUUID(int, UUID) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th 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(ByteBuffer) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate.CounterMark
- setValue(RequestFailureReason) - Method in class org.apache.cassandra.service.FailureRecordingCallback.FailureResponses
- setValue(ColumnMetadata, CellPath, ByteBuffer) - Method in class org.apache.cassandra.db.rows.BTreeRow
- SetValue(Term.Raw) - Constructor for class org.apache.cassandra.cql3.Operation.SetValue
- setVarint(int, BigInteger) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th 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. - setVector(int, List<E>) - Method in interface org.apache.cassandra.cql3.functions.types.SettableByIndexData
-
Sets the
i
th value to the provided vector value. - setVector(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 vector value. - setVectorDimensionsThreshold(int, int) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setVectorDimensionsThreshold(int, int) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setVectorDimensionsThreshold(int, int) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- 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.schema.SystemDistributedKeyspace
- setWarnings(List<String>) - Method in class org.apache.cassandra.transport.Message.Response
- setWriteConsistencyLevel(ConsistencyLevel) - Method in class org.apache.cassandra.auth.AuthProperties
- setWriteConsistencyLevel(ConsistencyLevel) - Method in interface org.apache.cassandra.auth.AuthPropertiesMXBean
- setWriteConsistencyLevelsDisallowed(Set<String>) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setWriteConsistencyLevelsDisallowed(Set<String>) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setWriteConsistencyLevelsDisallowed(Set<ConsistencyLevel>) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setWriteConsistencyLevelsDisallowedCSV(String) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setWriteConsistencyLevelsDisallowedCSV(String) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setWriteConsistencyLevelsWarned(Set<String>) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setWriteConsistencyLevelsWarned(Set<String>) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setWriteConsistencyLevelsWarned(Set<ConsistencyLevel>) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setWriteConsistencyLevelsWarnedCSV(String) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setWriteConsistencyLevelsWarnedCSV(String) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
- setWriteRpcTimeout(long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- setWriteRpcTimeout(long) - Method in class org.apache.cassandra.service.StorageService
- setWriteRpcTimeout(long) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- setWriteRpcTimeout(Long) - Method in class org.apache.cassandra.service.StorageProxy
- setWriteRpcTimeout(Long) - Method in interface org.apache.cassandra.service.StorageProxyMBean
- setZeroTTLOnTWCSEnabled(boolean) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setZeroTTLOnTWCSEnabled(boolean) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setZeroTTLOnTWCSEnabled(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Sets whether users can use 0 default TTL on a table with TimeWindowCompactionStrategy.
- setZeroTTLOnTWCSEnabled(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Sets whether users can use 0 default TTL on a table with TimeWindowCompactionStrategy.
- setZeroTTLOnTWCSWarned(boolean) - Method in class org.apache.cassandra.config.GuardrailsOptions
- setZeroTTLOnTWCSWarned(boolean) - Method in class org.apache.cassandra.db.guardrails.Guardrails
- setZeroTTLOnTWCSWarned(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsConfig
-
Sets whether warnings will be emitted when usage of 0 default TTL on a table with TimeWindowCompactionStrategy is detected.
- setZeroTTLOnTWCSWarned(boolean) - Method in interface org.apache.cassandra.db.guardrails.GuardrailsMBean
-
Sets whether warnings will be emitted when usage of 0 default TTL on a table with TimeWindowCompactionStrategy is detected.
- severity(double) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- SEVERITY - org.apache.cassandra.gms.ApplicationState
- severity_during_decommission - Variable in class org.apache.cassandra.config.Config
- shadowable(DeletionTime) - Static method in class org.apache.cassandra.db.rows.Row.Deletion
-
Deprecated.See CAASSANDRA-10261
- shadowSources(DecoratedKey, boolean) - Method in class org.apache.cassandra.db.AbstractCompactionController
- shadowSources(DecoratedKey, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionController
- SHALLOW - org.apache.cassandra.schema.Difference
-
Two schema objects are considered to differ DEEP-ly if their direct structure is altered.
- shardAdjustedKeyCount(Set<SSTableReader>) - Method in interface org.apache.cassandra.db.compaction.ShardTracker
- ShardBoundaries - Class in org.apache.cassandra.db.memtable
-
Holds boundaries (tokens) used to map a particular token (so partition key) to a shard id.
- ShardBoundaries(List<Token>, long) - Constructor for class org.apache.cassandra.db.memtable.ShardBoundaries
- ShardBoundaries(Token[], long) - Constructor for class org.apache.cassandra.db.memtable.ShardBoundaries
- shardCount() - Method in class org.apache.cassandra.db.memtable.ShardBoundaries
-
The number of shards that this boundaries support, that is how many different shard ids
ShardBoundaries.getShardForToken(org.apache.cassandra.dht.Token)
might possibly return. - SHARDED_MEMTABLE_CONFIG_OBJECT_NAME - Static variable in class org.apache.cassandra.db.memtable.AbstractShardedMemtable
- ShardedCompactionWriter - Class in org.apache.cassandra.db.compaction.unified
-
A
CompactionAwareWriter
that splits the output sstable at the partition boundaries of the compaction shards used byUnifiedCompactionStrategy
. - ShardedCompactionWriter(ColumnFamilyStore, Directories, LifecycleTransaction, Set<SSTableReader>, boolean, ShardTracker) - Constructor for class org.apache.cassandra.db.compaction.unified.ShardedCompactionWriter
- ShardedMemtableConfigMXBean - Interface in org.apache.cassandra.db.memtable
- ShardedMultiWriter - Class in org.apache.cassandra.db.compaction.unified
-
A
SSTableMultiWriter
that splits the output sstable at the partition boundaries of the compaction shards used byUnifiedCompactionStrategy
. - ShardedMultiWriter(ColumnFamilyStore, Descriptor, long, long, TimeUUID, boolean, IntervalSet<CommitLogPosition>, SerializationHeader, Collection<Index.Group>, LifecycleNewTracker, ShardTracker) - Constructor for class org.apache.cassandra.db.compaction.unified.ShardedMultiWriter
- ShardedSkipListMemtable - Class in org.apache.cassandra.db.memtable
-
A proof-of-concept sharded memtable implementation.
- ShardedSkipListMemtable.MemtableUnfilteredPartitionIterator - Class in org.apache.cassandra.db.memtable
- shardEnd() - Method in class org.apache.cassandra.db.compaction.ShardManagerDiskAware.BoundaryTrackerDiskAware
- shardEnd() - Method in class org.apache.cassandra.db.compaction.ShardManagerNoDisks.BoundaryTracker
- shardEnd() - Method in interface org.apache.cassandra.db.compaction.ShardTracker
- shardIndex() - Method in class org.apache.cassandra.db.compaction.ShardManagerDiskAware.BoundaryTrackerDiskAware
- shardIndex() - Method in class org.apache.cassandra.db.compaction.ShardManagerNoDisks.BoundaryTracker
- shardIndex() - Method in interface org.apache.cassandra.db.compaction.ShardTracker
- ShardManager - Interface in org.apache.cassandra.db.compaction
- ShardManagerDiskAware - Class in org.apache.cassandra.db.compaction
- ShardManagerDiskAware(ColumnFamilyStore.VersionedLocalRanges, List<Token>) - Constructor for class org.apache.cassandra.db.compaction.ShardManagerDiskAware
- ShardManagerDiskAware.BoundaryTrackerDiskAware - Class in org.apache.cassandra.db.compaction
- ShardManagerNoDisks - Class in org.apache.cassandra.db.compaction
- ShardManagerNoDisks(ColumnFamilyStore.VersionedLocalRanges) - Constructor for class org.apache.cassandra.db.compaction.ShardManagerNoDisks
- ShardManagerNoDisks.BoundaryTracker - Class in org.apache.cassandra.db.compaction
- ShardManagerTrivial - Class in org.apache.cassandra.db.compaction
- ShardManagerTrivial(IPartitioner) - Constructor for class org.apache.cassandra.db.compaction.ShardManagerTrivial
- SHARDS_OPTION - Static variable in class org.apache.cassandra.db.memtable.AbstractShardedMemtable
- shardSetCoverage() - Method in interface org.apache.cassandra.db.compaction.ShardManager
-
The fraction of the token space covered by a shard set, i.e.
- shardSetCoverage() - Method in class org.apache.cassandra.db.compaction.ShardManagerDiskAware
- shardSetCoverage() - Method in class org.apache.cassandra.db.compaction.ShardManagerNoDisks
- shardSetCoverage() - Method in class org.apache.cassandra.db.compaction.ShardManagerTrivial
- shardSpan() - Method in class org.apache.cassandra.db.compaction.ShardManagerDiskAware.BoundaryTrackerDiskAware
- shardSpan() - Method in class org.apache.cassandra.db.compaction.ShardManagerNoDisks.BoundaryTracker
- shardSpan() - Method in interface org.apache.cassandra.db.compaction.ShardTracker
- shardSpanSize() - Method in class org.apache.cassandra.db.compaction.ShardManagerDiskAware.BoundaryTrackerDiskAware
- shardSpanSize() - Method in class org.apache.cassandra.db.compaction.ShardManagerNoDisks.BoundaryTracker
- shardSpanSize() - Method in interface org.apache.cassandra.db.compaction.ShardTracker
- shardStart() - Method in class org.apache.cassandra.db.compaction.ShardManagerDiskAware.BoundaryTrackerDiskAware
- shardStart() - Method in class org.apache.cassandra.db.compaction.ShardManagerNoDisks.BoundaryTracker
- shardStart() - Method in interface org.apache.cassandra.db.compaction.ShardTracker
- ShardTracker - Interface in org.apache.cassandra.db.compaction
- 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(String, int, ExecutorPlus.MaximumPoolSizeListener) - Method in interface org.apache.cassandra.concurrent.ExecutorFactory.LocalAwareSubFactoryWithJMX
- shared(ReplicaPlan.ForRangeRead) - Static method in interface org.apache.cassandra.locator.ReplicaPlan
- shared(ReplicaPlan.ForTokenRead) - Static method in interface org.apache.cassandra.locator.ReplicaPlan
- Shared - Annotation Type in org.apache.cassandra.utils
-
Tells jvm-dtest that a class should be shared across all
ClassLoader
s. - SHARED - Static variable in class org.apache.cassandra.concurrent.SharedExecutorPool
- SHARED_HEADER_BYTES - Static variable in interface org.apache.cassandra.index.sasi.disk.TokenTreeBuilder
- Shared.Recursive - Enum in org.apache.cassandra.utils
- Shared.Scope - Enum in org.apache.cassandra.utils
- 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
- SharedContext - Interface in org.apache.cassandra.repair
-
Access methods to shared resources and services.
- SharedContext.ForwardingSharedContext - Class in org.apache.cassandra.repair
- SharedContext.Global - Class in org.apache.cassandra.repair
- sharedCopy() - Method in class org.apache.cassandra.index.sai.SSTableContext
- sharedCopy() - Method in class org.apache.cassandra.io.compress.CompressionMetadata
- sharedCopy() - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex
- sharedCopy() - Method in class org.apache.cassandra.io.sstable.indexsummary.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.BloomFilter
- sharedCopy() - Method in interface org.apache.cassandra.utils.concurrent.SharedCloseable
- sharedCopy() - Method in interface org.apache.cassandra.utils.IFilter
- sharedCopyOrNull(T) - Static method in interface org.apache.cassandra.utils.concurrent.SharedCloseable
- 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
- SharedExecutorPool(ThreadGroup) - 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, Dispatcher.RequestTime) - 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
- shouldAppendDeletedOrdinal() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.VectorPostings
- 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.sai.StorageAttachedIndex
- shouldBuildBlocking() - Method in class org.apache.cassandra.index.sasi.SASIIndex
- shouldBuildBlocking() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- shouldClearLocal(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.context.CounterContext
- shouldClearSnapshot(String, long) - Static method in class org.apache.cassandra.service.snapshot.TableSnapshot
- shouldEncrypt(InetAddressAndPort) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
- shouldEstimateInitialConcurrency() - Method in interface org.apache.cassandra.index.Index.QueryPlan
-
Used to determine whether to estimate initial concurrency during remote range reads.
- shouldEstimateInitialConcurrency() - Method in class org.apache.cassandra.index.sai.plan.StorageAttachedIndexQueryPlan
- shouldHint(Replica) - Static method in class org.apache.cassandra.service.StorageProxy
- shouldHint(Replica, boolean) - Static method in class org.apache.cassandra.service.StorageProxy
-
Determines whether a hint should be stored or not.
- shouldIgnoreGcGrace() - Method in class org.apache.cassandra.db.partitions.PurgeFunction
- shouldIgnoreGcGraceForKey(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- shouldIgnoreStopTerms() - Method in class org.apache.cassandra.index.sasi.analyzer.StandardTokenizerOptions
- shouldInclude(long, PrimaryKeyMap) - Method in class org.apache.cassandra.index.sai.VectorQueryContext
- shouldInclude(PrimaryKey) - Method in class org.apache.cassandra.index.sai.VectorQueryContext
- 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
- shouldMask(int, int, int) - Method in enum org.apache.cassandra.cql3.functions.masking.PartialMaskingFunction.Kind
- shouldMigrateKeycacheOnCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- shouldPurge(long, long) - Method in interface org.apache.cassandra.db.DeletionPurger
- shouldPurge(DeletionTime) - Method in interface org.apache.cassandra.db.DeletionPurger
- shouldPurge(LivenessInfo, long) - Method in interface org.apache.cassandra.db.DeletionPurger
- shouldQuoteCQLLiterals() - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
- shouldQuoteCQLLiterals() - Method in class org.apache.cassandra.serializers.InetAddressSerializer
- shouldQuoteCQLLiterals() - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
- shouldQuoteCQLLiterals() - Method in class org.apache.cassandra.serializers.TimeSerializer
- shouldQuoteCQLLiterals() - Method in class org.apache.cassandra.serializers.TimestampSerializer
- shouldQuoteCQLLiterals() - Method in class org.apache.cassandra.serializers.TypeSerializer
- shouldReject(long) - Method in class org.apache.cassandra.cql3.selection.ResultSetBuilder
- shouldReload() - Method in class org.apache.cassandra.security.DisableSslContextFactory
- shouldReload() - Method in class org.apache.cassandra.security.FileBasedSslContextFactory
- shouldReload() - Method in interface org.apache.cassandra.security.ISslContextFactory
-
Returns if any changes require the reloading of the SSL context returned by this factory.
- shouldSendHints() - Method in class org.apache.cassandra.transport.Dispatcher.RequestTime
-
No request should survive native request deadline, but in order to err on the side of caution, we have this swtich that allows hints to be submitted to mutation stage when cluster is potentially overloaded.
- shouldSignal(long, int, int, boolean, AtomicLongFieldUpdater<T>, T) - Static method in class org.apache.cassandra.service.paxos.PaxosPropose
- 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
- shouldSwitch(ColumnFamilyStore.FlushReason) - Method in class org.apache.cassandra.db.memtable.AbstractAllocatorMemtable
- shouldSwitch(ColumnFamilyStore.FlushReason) - Method in interface org.apache.cassandra.db.memtable.Memtable
-
Decides whether the memtable should be switched/flushed for the passed reason.
- shouldSwitchWriterInCurrentLocation(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.unified.ShardedCompactionWriter
- shouldSwitchWriterInCurrentLocation(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
Returns true if the writer should be switched for reasons other than switching to a new data directory (e.g.
- shouldSwitchWriterInCurrentLocation(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
- shouldSwitchWriterInCurrentLocation(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.writers.MajorLeveledCompactionWriter
- shouldSwitchWriterInCurrentLocation(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.writers.MaxSSTableSizeWriter
- shouldSwitchWriterInCurrentLocation(DecoratedKey) - Method in class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
- 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
- shouldWarn(long) - Method in class org.apache.cassandra.cql3.selection.ResultSetBuilder
- shouldWarn(Throwable) - Static method in exception org.apache.cassandra.exceptions.RepairException
- shutdown() - Method in class org.apache.cassandra.auth.AuthCache
- shutdown() - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
- shutdown() - Method in class org.apache.cassandra.concurrent.InfiniteLoopExecutor
- shutdown() - Method in class org.apache.cassandra.concurrent.SEPExecutor
- shutdown() - Method in interface org.apache.cassandra.concurrent.Shutdownable
-
Shutdown once any remaining work has completed (however this is defined for the implementation).
- shutdown() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBase
- shutdown() - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- 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() - Method in class org.apache.cassandra.net.MessagingService
-
Wait for callbacks and don't allow anymore to be created (since they could require writing hints)
- shutdown() - Static method in class org.apache.cassandra.streaming.async.NettyStreamingChannel
-
Shutdown for in-JVM tests.
- shutdown() - Static method in class org.apache.cassandra.transport.Dispatcher
- shutdown() - Method in class org.apache.cassandra.utils.memory.MemtableCleanerThread
- shutdown(boolean) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- shutdown(boolean, Iterable<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
- shutdown(long, TimeUnit, boolean, boolean) - Method in class org.apache.cassandra.net.MessagingService
- shutdown(Iterable<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
- shutdown(ExecutorService...) - Static method in class org.apache.cassandra.utils.ExecutorUtils
- SHUTDOWN - Static variable in class org.apache.cassandra.gms.VersionedValue
- SHUTDOWN_ANNOUNCE_DELAY_IN_MS - org.apache.cassandra.config.CassandraRelevantProperties
- Shutdownable - Interface in org.apache.cassandra.concurrent
- shutdownAbrubtly() - Method in class org.apache.cassandra.net.MessagingService
- shutdownAllAndWait(long, TimeUnit) - Static method in class org.apache.cassandra.auth.AuthCache
- shutdownAndAwaitMutatingExecutors(boolean, long, TimeUnit) - Static method in enum org.apache.cassandra.concurrent.Stage
- shutdownAndWait(long, TimeUnit) - Method in class org.apache.cassandra.batchlog.BatchlogManager
- 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.indexsummary.IndexSummaryManager
- shutdownAndWait(long, TimeUnit) - Static method in class org.apache.cassandra.service.paxos.PaxosRepair
- shutdownAndWait(long, TimeUnit) - Static method in class org.apache.cassandra.service.paxos.uncommitted.UncommittedTableData
- shutdownAndWait(long, TimeUnit) - Method in class org.apache.cassandra.service.PendingRangeCalculatorService
- shutdownAndWait(long, TimeUnit) - Static method in class org.apache.cassandra.service.snapshot.SnapshotManager
- 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) - Method in class org.apache.cassandra.utils.memory.MemtablePool
- shutdownAndWait(long, TimeUnit, Object...) - Static method in class org.apache.cassandra.utils.ExecutorUtils
- shutdownAndWait(long, TimeUnit, Collection<?>) - Static method in class org.apache.cassandra.utils.ExecutorUtils
- shutdownBeforeCommitlog - Variable in enum org.apache.cassandra.concurrent.Stage
-
Set true if this executor should be gracefully shutdown before stopping the commitlog allocator.
- 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.auth.AuthCache
- 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.ScheduledThreadPoolExecutorPlus
- shutdownNow() - Method in class org.apache.cassandra.concurrent.SEPExecutor
- shutdownNow() - Method in interface org.apache.cassandra.concurrent.Shutdownable
-
Shutdown immediately, possibly interrupting ongoing work, and cancelling work that is queued.
- shutdownNow() - Static method in enum org.apache.cassandra.concurrent.Stage
-
This method shuts down all registered stages.
- shutdownNow() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBase
- shutdownNow() - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- shutdownNow() - Method in class org.apache.cassandra.net.SocketFactory
- shutdownNow() - Method in class org.apache.cassandra.utils.memory.MemtableCleanerThread
- 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) - Static method in class org.apache.cassandra.concurrent.ScheduledExecutors
- shutdownNowAndWait(long, TimeUnit) - Static method in class org.apache.cassandra.db.compaction.CompactionLogger
- shutdownNowAndWait(long, TimeUnit) - Static method in class org.apache.cassandra.metrics.Sampler
- shutdownNowAndWait(long, TimeUnit) - Method in class org.apache.cassandra.service.ActiveRepairService
- shutdownNowAndWait(long, TimeUnit, Object...) - Static method in class org.apache.cassandra.utils.ExecutorUtils
- shutdownNowAndWait(long, TimeUnit, Collection<?>) - 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
- SHUTTING_DOWN - org.apache.cassandra.concurrent.Interruptible.State
- SHUTTING_DOWN_NOW - org.apache.cassandra.concurrent.InfiniteLoopExecutor.InternalState
- 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.Awaitable.AsyncAwaitable
-
Signal any waiting threads;
Awaitable.AsyncAwaitable.isSignalled()
must returntrue
before this method is invoked. - signal() - Method in class org.apache.cassandra.utils.concurrent.Condition.Async
- signal() - Method in interface org.apache.cassandra.utils.concurrent.Condition
-
Signal the condition as met, and wake all waiting threads.
- signal() - Method in class org.apache.cassandra.utils.concurrent.Condition.Sync
- signal() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue
-
Signal one waiting thread
- signal() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue.Standard
-
Signal one waiting thread
- signalAll() - Method in interface org.apache.cassandra.utils.concurrent.Condition
-
Signal the condition as met, and wake all waiting threads.
- signalAll() - Method in interface org.apache.cassandra.utils.concurrent.WaitQueue
-
Signal all waiting threads
- signalAll() - Method in class org.apache.cassandra.utils.concurrent.WaitQueue.Standard
-
Signal all waiting threads
- signalFlushRequired(Memtable, ColumnFamilyStore.FlushReason) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- signalFlushRequired(Memtable, ColumnFamilyStore.FlushReason) - Method in interface org.apache.cassandra.db.memtable.Memtable.Owner
-
Signal to the owner that a flush is required (e.g.
- signedBytesToNativeLong(long) - Static method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- signedFixedLengthFloat(ValueAccessor<V>, V) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
Produce a source for a signed fixed-length floating-point number.
- SignedFixedLengthFloat(ValueAccessor<V>, V) - Constructor for class org.apache.cassandra.utils.bytecomparable.ByteSource.SignedFixedLengthFloat
- signedFixedLengthNumber(ValueAccessor<V>, V) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
Produce a source for a signed fixed-length number.
- SignedFixedLengthNumber(ValueAccessor<V>, V) - Constructor for class org.apache.cassandra.utils.bytecomparable.ByteSource.SignedFixedLengthNumber
- SIMILARITY_FUNCTION - Static variable in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- 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
- SIMPLE - org.apache.cassandra.cql3.statements.schema.IndexTarget.Type
- SIMPLE - org.apache.cassandra.db.filter.RowFilter.Expression.Kind
- SIMPLE - org.apache.cassandra.db.WriteType
- SIMPLE - org.apache.cassandra.index.sasi.disk.TokenTreeBuilder.EntryType
- SIMPLE_SELECTOR - org.apache.cassandra.cql3.selection.Selector.Kind
- SimpleBucket(UnifiedCompactionStrategy.Level, Collection<SSTableReader>) - Constructor for class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy.SimpleBucket
- 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) - 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, ProtocolVersion, EncryptionOptions) - 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.
- 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
- SimpleDataSet(TableMetadata, Comparator<DecoratedKey>) - Constructor for class org.apache.cassandra.db.virtual.SimpleDataSet
- SimpleDataSet.SerializationException - Exception in org.apache.cassandra.db.virtual
- 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
- SimpleGaugeProvider<T extends java.lang.Number,R extends SSTableReader> - Class in org.apache.cassandra.io.sstable
- SimpleGaugeProvider(Function<SSTableReader, R>, String, Function<Iterable<R>, T>) - Constructor for class org.apache.cassandra.io.sstable.SimpleGaugeProvider
- 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, long, 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
- simplestrategy_enabled - Variable in class org.apache.cassandra.config.Config
- simpleStrategyEnabled - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail disabling setting SimpleStrategy via keyspace creation or alteration
- 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
- Simulate - Annotation Type in org.apache.cassandra.utils
-
Enable certain features for a specific method or class.
- Simulate.With - Enum in org.apache.cassandra.utils
- SIMULATION - org.apache.cassandra.utils.Shared.Scope
- SINGLE - org.apache.cassandra.utils.Overlaps.InclusionMethod
- SINGLE_PARTITION - org.apache.cassandra.db.ReadCommand.Kind
- SINGLE_QUERY - Static variable in class org.apache.cassandra.fql.FullQueryLogger
- singleCellRow(Clustering<?>, Cell<?>) - Static method in class org.apache.cassandra.db.rows.BTreeRow
- SingleColumn(ColumnMetadata) - Constructor for class org.apache.cassandra.cql3.Ordering.SingleColumn
- SingleColumnRelation - Class in org.apache.cassandra.cql3
-
Relations encapsulate the relationship between an entity of some kind, and a value (term).
- SingleColumnRelation(ColumnIdentifier, Operator, Term.Raw) - Constructor for class org.apache.cassandra.cql3.SingleColumnRelation
-
Creates a new relation.
- SingleColumnRelation(ColumnIdentifier, Term.Raw, Operator, Term.Raw) - Constructor for class org.apache.cassandra.cql3.SingleColumnRelation
-
Creates a new relation.
- SingleColumnRestriction - Class in org.apache.cassandra.cql3.restrictions
- SingleColumnRestriction(ColumnMetadata) - Constructor for class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction
- SingleColumnRestriction.AnnRestriction - Class in org.apache.cassandra.cql3.restrictions
- 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, long, ColumnFilter, RowFilter, DataLimits, DecoratedKey, ClusteringIndexFilter, Index.QueryPlan, boolean) - Constructor for class org.apache.cassandra.db.SinglePartitionReadCommand
- SinglePartitionReadCommand.Group - Class in org.apache.cassandra.db
-
Groups multiple single partition read commands.
- SinglePartitionReadCommand.VirtualTableGroup - Class in org.apache.cassandra.db
- SinglePartitionReadCommand.VirtualTableSinglePartitionReadCommand - Class in org.apache.cassandra.db
- 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, ByteBuffer, 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, DecoratedKey, Row, 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
- SingleThreadExecutorPlus - Class in org.apache.cassandra.concurrent
- SingleThreadExecutorPlus.AtLeastOnce - Class in org.apache.cassandra.concurrent
- singleton(Object) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Create a BTree containing only the specified object
- singleton(Unfiltered, TableMetadata, DecoratedKey, DeletionTime, RegularAndStaticColumns, Row, boolean, EncodingStats) - Static method in class org.apache.cassandra.db.rows.UnfilteredRowIterators
- singleton(ByteComparable, T) - Static method in class org.apache.cassandra.db.tries.Trie
-
Returns a singleton trie mapping the given byte path to content.
- singleton(T, Comparator<? super T>) - Static method in class org.apache.cassandra.utils.FBUtilities
- SingletonIndexGroup - Class in org.apache.cassandra.index
-
An
Index.Group
containing a singleIndex
, to which it just delegates the calls. - SingletonIndexGroup(Index) - Constructor for class org.apache.cassandra.index.SingletonIndexGroup
- SingletonIndexQueryPlan - Class in org.apache.cassandra.index
- SingletonIndexQueryPlan(Index, RowFilter) - Constructor for class org.apache.cassandra.index.SingletonIndexQueryPlan
- 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 - Variable in class org.apache.cassandra.db.MultiCBuilder
-
The number of clustering elements that have been added.
- size - Variable in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.TermSize
- size - Variable in class org.apache.cassandra.io.util.Memory
- 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 - Variable in class org.apache.cassandra.net.AbstractMessageHandler.LargeMessage
- size - Variable in class org.apache.cassandra.utils.MerkleTree.RowHash
- 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 interface org.apache.cassandra.cql3.functions.Arguments
-
Returns the current number of arguments.
- size() - Method in class org.apache.cassandra.cql3.functions.FunctionArguments
- 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() - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
- size() - Method in class org.apache.cassandra.db.marshal.TupleType
- 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() - Method in class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable.ColumnValues
-
Returns the number of column values.
- size() - Method in class org.apache.cassandra.dht.Splitter.WeightedRange
-
A less precise version of the above, returning the size of the span as a double approximation.
- size() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.FilteringPostingList
- size() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.MergePostingList
- size() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.PackedLongsPostingList
- size() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.PostingsReader
- size() - Method in class org.apache.cassandra.index.sai.disk.v1.postings.VectorPostingList
- size() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.CompactionVectorValues
- size() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.ConcurrentVectorValues
- size() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.DiskAnn
- size() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.OnHeapGraph
- size() - Method in class org.apache.cassandra.index.sai.disk.v1.vector.VectorPostings
- size() - Method in class org.apache.cassandra.index.sai.memory.MemtableIndexManager
- size() - Method in class org.apache.cassandra.index.sai.postings.IntArrayPostingList
- size() - Method in class org.apache.cassandra.index.sai.postings.PeekablePostingList
- size() - Method in class org.apache.cassandra.index.sai.postings.PostingList.EmptyPostingList
- size() - Method in interface org.apache.cassandra.index.sai.postings.PostingList
-
Returns the upper bound of postings in the list.
- size() - Method in class org.apache.cassandra.index.sai.SSTableContextManager
- size() - Method in class org.apache.cassandra.index.sai.utils.PrimaryKeys
- size() - Method in class org.apache.cassandra.index.sai.view.View
- size() - Method in class org.apache.cassandra.io.sstable.format.bti.PartitionIndex
- size() - Method in class org.apache.cassandra.io.sstable.indexsummary.IndexSummary
- size() - Method in class org.apache.cassandra.io.util.ChannelProxy
- 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() - Method in class org.apache.cassandra.metrics.DecayingEstimatedHistogramReservoir
-
Returns the logical number of buckets where recorded values are stored.
- size() - Method in class org.apache.cassandra.metrics.ScalingReservoir
- size() - Method in class org.apache.cassandra.repair.asymmetric.RangeMap
- size() - Method in class org.apache.cassandra.schema.Indexes
- size() - Method in class org.apache.cassandra.schema.Keyspaces
- 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.UserFunctions
- size() - Method in class org.apache.cassandra.schema.Views
- size() - Method in class org.apache.cassandra.service.paxos.PaxosRepairHistory
- 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() - 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.BlockingQueues.Sync
- 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() - Method in class org.apache.cassandra.utils.DynamicList
- size() - Method in class org.apache.cassandra.utils.LockedDynamicList
- 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.streamhist.TombstoneHistogram
- size(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- size(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
- size(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- size(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CollectionType
- 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(FailureRecordingCallback.FailureResponses) - Static method in class org.apache.cassandra.service.FailureRecordingCallback.FailureResponses
- size(IntrusiveStack<?>) - Static method in class org.apache.cassandra.utils.concurrent.IntrusiveStack
- size(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- SIZE_RECORDER_INTERVAL - org.apache.cassandra.config.CassandraRelevantProperties
- sizeAllowingZero(long) - Static method in class org.apache.cassandra.io.util.SizedInts
-
Returns the number of bytes we need to store the given position.
- sizeComparator - Static variable in class org.apache.cassandra.io.sstable.format.SSTableReader
- SizedInts - Class in org.apache.cassandra.io.util
-
Utility class for sizing, writing and reading ints with length stored separately.
- SizedInts() - Constructor for class org.apache.cassandra.io.util.SizedInts
- 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
- sizeInBytes() - Static method in class org.apache.cassandra.utils.TimeUUID
- sizeof(boolean) - Static method in class org.apache.cassandra.db.TypeSizes
- sizeof(byte) - Static method in class org.apache.cassandra.db.TypeSizes
- sizeof(double) - Static method in class org.apache.cassandra.db.TypeSizes
- sizeof(float) - 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(short) - Static method in class org.apache.cassandra.db.TypeSizes
- sizeof(String) - Static method in class org.apache.cassandra.db.TypeSizes
-
assumes UTF8
- sizeof(UUID) - Static method in class org.apache.cassandra.db.TypeSizes
- sizeOf(String) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a String consumes
- sizeOf(AbstractType<?>) - Static method in class org.apache.cassandra.cql3.selection.Selector
- sizeOf(AbstractType<?>) - Static method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.TermSize
- sizeOf(Component) - Method in class org.apache.cassandra.db.streaming.ComponentManifest
- sizeOfArray(byte[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a byte array consumes
- sizeOfArray(int[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory an int array consumes
- sizeOfArray(long[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Memory a long 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() - 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
- sizeOffHeap() - Method in class org.apache.cassandra.db.tries.InMemoryTrie
-
Returns the off heap size of the memtable trie itself, not counting any space taken by referenced content.
- 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
- sizeofNode(SerializationNode<?>) - Method in class org.apache.cassandra.io.tries.TrieNode
-
Returns the size needed to serialize this node.
- sizeofNode(SerializationNode<VALUE>, long) - Method in interface org.apache.cassandra.io.tries.TrieSerializer
- sizeOfPerColumnComponents() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
- 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(byte[]) - Static method in class org.apache.cassandra.transport.CBUtil
- sizeOfValue(int) - Static method in class org.apache.cassandra.transport.CBUtil
- sizeOfValue(ByteBuffer) - Static method in class org.apache.cassandra.transport.CBUtil
- sizeOfValue(V, ValueAccessor<V>) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
- 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
- sizeOnDiskOfPerIndexComponent(IndexComponent, IndexIdentifier) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- sizeOnDiskOfPerIndexComponents(IndexTermType, IndexIdentifier) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- sizeOnDiskOfPerSSTableComponents() - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- sizeOnHeap() - Method in class org.apache.cassandra.db.tries.InMemoryTrie
-
Returns the on heap size of the memtable trie itself, not counting any space taken by referenced content.
- sizeOnHeapExcludingDataOf(ByteBuffer) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Measures the heap memory used by the specified byte buffer excluding the data.
- sizeOnHeapExcludingDataOf(ByteBuffer[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Amount of non-data heap memory consumed by the array of byte buffers.
- sizeOnHeapOf(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
- sizeOnHeapOf(ByteBuffer) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Measures the heap memory used by the specified byte buffer.
- sizeOnHeapOf(ByteBuffer[]) - Static method in class org.apache.cassandra.utils.ObjectSizes
-
Amount of heap memory consumed by the array of byte buffers.
- 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() - Constructor for class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
- SizeTieredCompactionStrategyOptions(Map<String, String>) - 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. - SKINNY - org.apache.cassandra.index.sai.utils.PrimaryKey.Kind
- SKINNY_PER_SSTABLE_COMPONENTS - Static variable in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- SkinnyPrimaryKeyMap - Class in org.apache.cassandra.index.sai.disk.v1
-
A
PrimaryKeyMap
for skinny tables (those with no clustering columns). - SkinnyPrimaryKeyMap(LongArray, LongArray, KeyLookup.Cursor, PrimaryKey.Factory) - Constructor for class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap
- SkinnyPrimaryKeyMap.Factory - Class in org.apache.cassandra.index.sai.disk.v1
- skip(long) - Method in class org.apache.cassandra.io.util.LengthAvailableInputStream
- skip(long) - Method in class org.apache.cassandra.io.util.TrackedInputStream
- skip(String) - Method in class org.apache.cassandra.repair.state.AbstractCompletable.BaseSkipPhase
- skip(String) - Static method in class org.apache.cassandra.repair.state.Completable.Result
- skip(DataInputPlus) - Method in class org.apache.cassandra.db.DeletionTime.LegacySerializer
- skip(DataInputPlus) - Method in class org.apache.cassandra.db.DeletionTime.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 interface org.apache.cassandra.io.sstable.format.SSTableFormat.KeyCacheValueSerializer
- skip(DataInputPlus) - Method in class org.apache.cassandra.io.sstable.IndexInfo.Serializer
- 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, Version) - Static method in class org.apache.cassandra.io.sstable.format.big.RowIndexEntry.Serializer
- skip_paxos_repair_on_topology_change - Variable in class org.apache.cassandra.config.Config
-
If true, paxos topology change repair will not run on a topology change - this option should only be used in rare operation circumstances e.g.
- SKIP_PAXOS_REPAIR_ON_TOPOLOGY_CHANGE - org.apache.cassandra.config.CassandraRelevantProperties
- skip_paxos_repair_on_topology_change_keyspaces - Variable in class org.apache.cassandra.config.Config
-
If necessary for operational purposes, permit certain keyspaces to be ignored for paxos topology repairs
- SKIP_PAXOS_REPAIR_ON_TOPOLOGY_CHANGE_KEYSPACES - org.apache.cassandra.config.CassandraRelevantProperties
-
If necessary for operational purposes, permit certain keyspaces to be ignored for paxos topology repairs.
- SKIP_PAXOS_REPAIR_VERSION_VALIDATION - org.apache.cassandra.config.CassandraRelevantProperties
- SKIP_PAXOS_STATE_REBUILD - org.apache.cassandra.config.CassandraRelevantProperties
- skip_stream_disk_space_check - Variable in class org.apache.cassandra.config.Config
- 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.TeeDataInputPlus
- skipBytes(int) - Method in class org.apache.cassandra.io.util.TrackedDataInputPlus
- skipBytes(long) - Method in class org.apache.cassandra.index.sai.disk.io.IndexOutputWriter
- skipBytes(long) - Method in class org.apache.cassandra.io.util.SequentialWriter
- skipBytesFully(int) - Method in interface org.apache.cassandra.io.util.DataInputPlus
- skipBytesFully(int) - Method in class org.apache.cassandra.io.util.TeeDataInputPlus
- skipChildren() - Method in interface org.apache.cassandra.db.tries.Trie.Cursor
-
Ignore the current node's children and advance to the next child of the closest node on the parent chain that has any.
- skipCorrupted - Variable in class org.apache.cassandra.io.sstable.IScrubber.Options
- skipCorrupted() - Method in class org.apache.cassandra.io.sstable.IScrubber.Options.Builder
- skipCorrupted(boolean) - Method in class org.apache.cassandra.io.sstable.IScrubber.Options.Builder
- skipDeletionTime(DataInputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
- skipForCache(DataInputPlus, Version) - Static method in class org.apache.cassandra.io.sstable.format.big.RowIndexEntry.Serializer
- SkipListMemIndex - Class in org.apache.cassandra.index.sasi.memory
- SkipListMemIndex(AbstractType<?>, ColumnIndex) - Constructor for class org.apache.cassandra.index.sasi.memory.SkipListMemIndex
- SkipListMemtable - Class in org.apache.cassandra.db.memtable
- SkipListMemtable(AtomicReference<CommitLogPosition>, TableMetadataRef, Memtable.Owner) - Constructor for class org.apache.cassandra.db.memtable.SkipListMemtable
- SkipListMemtableFactory - Class in org.apache.cassandra.db.memtable
-
This class makes better sense as an inner class to SkipListMemtable (which could be as simple as FACTORY = SkipListMemtable::new), but having it there causes the SkipListMemtable class to be initialized the first time it is referenced (e.g.
- SkipListMemtableFactory() - Constructor for class org.apache.cassandra.db.memtable.SkipListMemtableFactory
- 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.
- skipNotificationListeners - Variable in class org.apache.cassandra.service.StorageService
- skipPaxosRepairOnTopologyChange() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- skipPaxosRepairOnTopologyChangeKeyspaces() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- SKIPPED - org.apache.cassandra.repair.state.Completable.Result.Kind
- skippedRanges - Variable in class org.apache.cassandra.repair.CoordinatedRepairResult
- 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
- skipTo(PrimaryKey) - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator
-
When called, this iterator's current position will be skipped forwards until finding either: 1) an element equal to or bigger than nextKey 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(ByteBuffer) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
- skipValue(DataInputPlus) - Method in class org.apache.cassandra.db.marshal.AbstractType
- skipValue(V, ValueAccessor<V>, int) - 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 (1MiB) global regions and then doles them out to threads that + * request smaller sized (up to 128KiB) 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
- sleepQuietly(long) - Static method in class org.apache.cassandra.utils.FBUtilities
- slice(byte[], int, int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- 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(Object[], Comparator<? super K>, K, K, BTree.Dir) - Static method in class org.apache.cassandra.utils.btree.BTree
- 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(String, long, long) - Method in class org.apache.cassandra.index.sai.disk.io.IndexInputReader
- slice(ByteBuffer, int, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- 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(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(V, int, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
Returns a value with the contents of {@param input} from {@param offset} to {@param length}.
- Slice - Class in org.apache.cassandra.db
-
A slice represents the selection of a range of rows.
- SLICE - org.apache.cassandra.db.filter.ClusteringIndexFilter.Kind
- SLICE_SELECTOR - org.apache.cassandra.cql3.selection.Selector.Kind
- 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
- sliceDone - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableIterator.ForwardReader
- SlicedTrie<T> - Class in org.apache.cassandra.db.tries
-
Represents a sliced view of a trie, i.e.
- SlicedTrie(Trie<T>, ByteComparable, boolean, ByteComparable, boolean) - Constructor for class org.apache.cassandra.db.tries.SlicedTrie
- 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.io.sstable.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 on the argument passed toSlices.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) - slow_query_log_timeout - 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
- SMALL_MESSAGES - org.apache.cassandra.net.ConnectionType
- 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
. - SMALLINT - org.apache.cassandra.cql3.CQL3Type.Native
- SMALLINT - org.apache.cassandra.cql3.functions.types.DataType.Name
- SMALLINT - org.apache.cassandra.transport.DataType
- 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() - 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() - Method in class org.apache.cassandra.locator.RangesAtEndpoint.Builder
- 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() - Method in class org.apache.cassandra.repair.state.ParticipateState.Job
- snapshot() - Method in class org.apache.cassandra.service.reads.thresholds.WarnAbortCounter
- snapshot() - Method in class org.apache.cassandra.service.reads.thresholds.WarningContext
- snapshot() - Method in class org.apache.cassandra.utils.concurrent.Accumulator
- snapshot(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Take a snap shot of this columnfamily store.
- snapshot(String, boolean, DurationSpec.IntSecondsBound, RateLimiter, Instant) - 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, DurationSpec.IntSecondsBound, RateLimiter, Instant) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- snapshot(String, String) - Method in class org.apache.cassandra.db.Keyspace
-
Take a snapshot of the specific column family, or the entire set of column families if columnFamily is null with a given timestamp
- snapshot(String, String, boolean, DurationSpec.IntSecondsBound, RateLimiter, Instant) - 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(String, Collection<Range<Token>>, boolean) - Method in interface org.apache.cassandra.repair.TableRepairManager
-
For snapshot repairs.
- snapshot(String, DurationSpec.IntSecondsBound) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- snapshot(SnapshotCommand, List<Range<Token>>, InetAddressAndPort) - Static method in class org.apache.cassandra.utils.DiagnosticSnapshotService
- snapshot(AbstractReplicaCollection.ReplicaList) - Method in class org.apache.cassandra.locator.EndpointsForToken
- snapshot(AbstractReplicaCollection.ReplicaList) - Method in class org.apache.cassandra.locator.RangesAtEndpoint
- Snapshot - Class in org.apache.cassandra.tools.nodetool
- Snapshot() - Constructor for class org.apache.cassandra.tools.nodetool.Snapshot
- Snapshot(Ballot, Ballot, Commit.Accepted, Commit.Committed) - Constructor for class org.apache.cassandra.service.paxos.PaxosState.Snapshot
- SNAPSHOT - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- SNAPSHOT - org.apache.cassandra.repair.state.ParticipateState.Job.State
- snapshot_before_compaction - Variable in class org.apache.cassandra.config.Config
- SNAPSHOT_CLEANUP_INITIAL_DELAY_SECONDS - org.apache.cassandra.config.CassandraRelevantProperties
-
snapshots ttl cleanup initial delay in seconds
- SNAPSHOT_CLEANUP_PERIOD_SECONDS - org.apache.cassandra.config.CassandraRelevantProperties
-
snapshots ttl cleanup period in seconds
- SNAPSHOT_COMPLETE - org.apache.cassandra.repair.state.JobState.State
- 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_MIN_ALLOWED_TTL_SECONDS - org.apache.cassandra.config.CassandraRelevantProperties
-
minimum allowed TTL for snapshots
- SNAPSHOT_MSG - org.apache.cassandra.net.Verb
- 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_RANGES - org.apache.cassandra.net.ParamType
- SNAPSHOT_REQ - org.apache.cassandra.net.Verb
- SNAPSHOT_RSP - org.apache.cassandra.net.Verb
- SNAPSHOT_START - org.apache.cassandra.repair.state.JobState.State
- 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
- snapshotCommitLogPosition - Variable in class org.apache.cassandra.db.commitlog.CommitLogArchiver
- SnapshotDetailsTabularData - Class in org.apache.cassandra.db
- SnapshotDetailsTabularData() - Constructor for class org.apache.cassandra.db.SnapshotDetailsTabularData
- snapshotExecutor - Variable in class org.apache.cassandra.service.ActiveRepairService
- 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.
- SnapshotLoader - Class in org.apache.cassandra.service.snapshot
-
Loads snapshot metadata from data directories
- SnapshotLoader() - Constructor for class org.apache.cassandra.service.snapshot.SnapshotLoader
- SnapshotLoader(String[]) - Constructor for class org.apache.cassandra.service.snapshot.SnapshotLoader
- SnapshotLoader(Collection<Path>) - Constructor for class org.apache.cassandra.service.snapshot.SnapshotLoader
- SnapshotLoader(Directories) - Constructor for class org.apache.cassandra.service.snapshot.SnapshotLoader
- snapshotManager - Variable in class org.apache.cassandra.service.StorageService
- SnapshotManager - Class in org.apache.cassandra.service.snapshot
- SnapshotManager() - Constructor for class org.apache.cassandra.service.snapshot.SnapshotManager
- SnapshotManager(long, long) - Constructor for class org.apache.cassandra.service.snapshot.SnapshotManager
- SnapshotManifest - Class in org.apache.cassandra.service.snapshot
- SnapshotManifest(List<String>, DurationSpec.IntSecondsBound, Instant, boolean) - Constructor for class org.apache.cassandra.service.snapshot.SnapshotManifest
- 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
- snapshotsCompleted() - Method in class org.apache.cassandra.repair.state.JobState.Phase
- snapshotsSubmitted() - Method in class org.apache.cassandra.repair.state.JobState.Phase
- SnapshotsTable - Class in org.apache.cassandra.db.virtual
- 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
- SnapshottingReservoir - Interface in org.apache.cassandra.metrics
- SnapshottingTimer - Class in org.apache.cassandra.metrics
- SnapshottingTimer(SnapshottingReservoir) - Constructor for class org.apache.cassandra.metrics.SnapshottingTimer
- SnapshottingTimer(SnapshottingReservoir, Clock) - Constructor for class org.apache.cassandra.metrics.SnapshottingTimer
- SnapshotTrueSizeCalculator() - Constructor for class org.apache.cassandra.service.snapshot.TableSnapshot.SnapshotTrueSizeCalculator
- SnapshotVerbHandler - Class in org.apache.cassandra.service
- SnapshotVerbHandler() - Constructor for class org.apache.cassandra.service.SnapshotVerbHandler
- snapshotWithoutMemtable(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- snapshotWithoutMemtable(String, Predicate<SSTableReader>, boolean, DurationSpec.IntSecondsBound, RateLimiter, Instant) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- snapshotWithoutMemtable(String, Instant) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- snitch - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
- snitch() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- snitch() - Method in class org.apache.cassandra.repair.SharedContext.Global
- snitch() - Method in interface org.apache.cassandra.repair.SharedContext
- 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
- SnitchProperties(Properties) - Constructor for class org.apache.cassandra.locator.SnitchProperties
- SnitchProperties(Pair<String, String>...) - Constructor for class org.apache.cassandra.locator.SnitchProperties
- SnitchUtils - Class in org.apache.cassandra.locator
- 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
Channel
s. - 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".
- sort() - Method in class org.apache.cassandra.utils.btree.BTree.Builder
- sort(long[], int, int, LongTimSort.LongComparator) - Static method in class org.apache.cassandra.utils.LongTimSort
- sort(long[], LongTimSort.LongComparator) - Static method in class org.apache.cassandra.utils.LongTimSort
- sort(Collection<Range<T>>) - Static method in class org.apache.cassandra.dht.Range
- sorted() - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
Creates a CQLSSTableWriter that expects sorted inputs.
- sorted(Comparator<? super Replica>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
- sorted(Comparator<? super Replica>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
- sorted(Comparator<? super 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
- sortedList() - Method in class org.apache.cassandra.db.Directories.SSTableLister
-
Returns a sorted version of the
list
method. - sortedStream() - Method in class org.apache.cassandra.schema.Types
-
Returns a stream of user types sorted by dependencies
- SortedTablePartitionWriter - Class in org.apache.cassandra.io.sstable.format
- SortedTablePartitionWriter(SerializationHeader, SequentialWriter, Version) - Constructor for class org.apache.cassandra.io.sstable.format.SortedTablePartitionWriter
- SortedTableReaderLoadingBuilder<R extends SSTableReader,B extends SSTableReader.Builder<R,B>> - Class in org.apache.cassandra.io.sstable.format
- SortedTableReaderLoadingBuilder(SSTable.Builder<?, ?>) - Constructor for class org.apache.cassandra.io.sstable.format.SortedTableReaderLoadingBuilder
- SortedTableScrubber<R extends SSTableReaderWithFilter> - Class in org.apache.cassandra.io.sstable.format
- SortedTableScrubber(ColumnFamilyStore, LifecycleTransaction, OutputHandler, IScrubber.Options) - Constructor for class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- SortedTableScrubber.ScrubInfo - Class in org.apache.cassandra.io.sstable.format
- SortedTableVerifier<R extends SSTableReaderWithFilter> - Class in org.apache.cassandra.io.sstable.format
- SortedTableVerifier(ColumnFamilyStore, R, OutputHandler, boolean, IVerifier.Options) - Constructor for class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- SortedTableVerifier.RangeOwnHelper - Class in org.apache.cassandra.io.sstable.format
-
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.
- SortedTableVerifier.VerifyController - Class in org.apache.cassandra.io.sstable.format
- SortedTableVerifier.VerifyInfo - Class in org.apache.cassandra.io.sstable.format
- SortedTableWriter<P extends SortedTablePartitionWriter,I extends SortedTableWriter.AbstractIndexWriter> - Class in org.apache.cassandra.io.sstable.format
-
A generic implementation of a writer which assumes the existence of some partition index and bloom filter.
- SortedTableWriter(SortedTableWriter.Builder<P, I, ?, ?>, LifecycleNewTracker, SSTable.Owner) - Constructor for class org.apache.cassandra.io.sstable.format.SortedTableWriter
- SortedTableWriter.AbstractIndexWriter - Class in org.apache.cassandra.io.sstable.format
- SortedTableWriter.Builder<P extends SortedTablePartitionWriter,I extends SortedTableWriter.AbstractIndexWriter,W extends SortedTableWriter<P,I>,B extends SortedTableWriter.Builder<P,I,W,B>> - Class in org.apache.cassandra.io.sstable.format
- SortedTableWriter.TransactionalProxy - Class in org.apache.cassandra.io.sstable.format
- 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
- SOUTHEAST_ASIAN - org.apache.cassandra.index.sasi.analyzer.StandardAnalyzer.TokenType
- SpaceExhaustedException() - Constructor for exception org.apache.cassandra.db.tries.InMemoryTrie.SpaceExhaustedException
- 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
- SPACIOUS - org.apache.cassandra.service.disk.usage.DiskUsageState
-
Disk usage is below both
GuardrailsConfig.getDataDiskUsagePercentageWarnThreshold()
()} andGuardrailsConfig.getDataDiskUsagePercentageFailThreshold()
. - SPARSE - org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.Mode
- specForElementOrSlice(Selectable, ColumnSpecification, CollectionType.Kind, 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
- SPECULATIVE_RETRY - org.apache.cassandra.schema.TableParams.Option
- 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
- speculativeRetries - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- speculativeRetry - Variable in class org.apache.cassandra.schema.TableParams
- speculativeRetry(SpeculativeRetryPolicy) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- speculativeRetry(SpeculativeRetryPolicy) - Method in class org.apache.cassandra.schema.TableParams.Builder
- 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
- SpiffeCertificateValidator - Class in org.apache.cassandra.auth
-
This class assumes that the identity of a certificate is SPIFFE which is a URI that is present as part of the SAN of the client certificate.
- SpiffeCertificateValidator() - Constructor for class org.apache.cassandra.auth.SpiffeCertificateValidator
- spinning - org.apache.cassandra.config.Config.DiskOptimizationStrategy
- 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() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
- 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.VectorType
- split(Collection<Range<Token>>, int) - Method in class org.apache.cassandra.dht.Splitter
-
Splits the specified token ranges in at least
parts
subranges. - 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(ValueAccessor<V>, V) - Method in class org.apache.cassandra.db.marshal.TupleType
-
Split a tuple value into its component values.
- split(ValueAccessor<V>, V, int, TupleType) - Static method in class org.apache.cassandra.db.marshal.TupleType
-
Split a tuple value into its component values.
- 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.
- split(Token, Token, double) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
- 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.AbstractBounds
-
Given token T and AbstractBounds ?L,R?, returns Pair(?L,T], (T,R?), where ? means that the same type of AbstractBounds is returned as the original.
- split(T) - Method in class org.apache.cassandra.dht.Bounds
- split(T) - Method in class org.apache.cassandra.dht.ExcludingBounds
- split(T) - Method in class org.apache.cassandra.dht.IncludingExcludingBounds
- split(T) - Method in class org.apache.cassandra.dht.Range
- split(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.VectorType
- split(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.VectorType.VectorSerializer
- splitBlock() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
- splitCommaDelimited(String) - Static method in class org.apache.cassandra.config.Config
- SplitController(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.compaction.SSTableSplitter.SplitController
- spliterator() - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
- 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 50MiB, 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
- src - Variable in class org.apache.cassandra.repair.state.SyncState.Id
- ssd - org.apache.cassandra.config.Config.DiskOptimizationStrategy
- SsdDiskOptimizationStrategy - Class in org.apache.cassandra.io.util
- SsdDiskOptimizationStrategy(double) - Constructor for class org.apache.cassandra.io.util.SsdDiskOptimizationStrategy
- SSL - org.apache.cassandra.net.OutboundConnectionInitiator.SslFallbackConnectionType
- 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_context_factory - Variable in class org.apache.cassandra.config.EncryptionOptions
- SSL_ENABLE - org.apache.cassandra.config.CassandraRelevantProperties
- SSL_FACTORY_CONTEXT_DESCRIPTION - Static variable in class org.apache.cassandra.net.InternodeConnectionUtils
- SSL_FACTORY_CONTEXT_DESCRIPTION - Static variable in class org.apache.cassandra.transport.PipelineConfigurator
- SSL_HANDLER_NAME - Static variable in class org.apache.cassandra.net.InternodeConnectionUtils
- 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 - org.apache.cassandra.config.CassandraRelevantProperties
- SSL_STORAGE_PORT_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
Deprecated.See CASSANDRA-17602
- 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
- sslContextFactoryInstance - Variable in class org.apache.cassandra.config.EncryptionOptions
- sslEnabled() - Method in class org.apache.cassandra.transport.ConnectedClient
- SSLFactory - Class in org.apache.cassandra.security
-
A Factory for providing and setting up client
SSLSocket
s. - SSLFactory() - Constructor for class org.apache.cassandra.security.SSLFactory
- SSLFactory.LoggingCipherSuiteFilter - Class in org.apache.cassandra.security
- 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.config.Config
- sstable - Variable in class org.apache.cassandra.db.streaming.CassandraStreamWriter
- sstable - Variable in class org.apache.cassandra.index.sai.SSTableContext
- sstable - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableIterator
- sstable - Variable in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- sstable - Variable in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- sstable - Variable in class org.apache.cassandra.io.sstable.format.SSTableScanner
- sstable - Variable in class org.apache.cassandra.notifications.SSTableMetadataChanged
- sstable(SSTableReader) - Method in interface org.apache.cassandra.db.compaction.CompactionLogger.Strategy
- SSTable - Class in org.apache.cassandra.io.sstable
-
This class represents an abstract sstable on disk whose keys and corresponding partitions are stored in a
SSTableFormat.Components.DATA
file in order as imposed byDecoratedKey.comparator
. - SSTable(SSTable.Builder<?, ?>, SSTable.Owner) - Constructor for class org.apache.cassandra.io.sstable.SSTable
- SSTABLE - org.apache.cassandra.db.transform.RTBoundValidator.Stage
- SSTABLE_ACTIVITY_V2 - Static variable in class org.apache.cassandra.db.SystemKeyspace
- SSTABLE_FORMAT_DEFAULT - org.apache.cassandra.config.CassandraRelevantProperties
- SSTABLE_LOWER_BOUND - org.apache.cassandra.db.ClusteringPrefix.Kind
- SSTABLE_NAME - Static variable in class org.apache.cassandra.index.sai.virtual.SegmentsSystemView
- sstable_preemptive_open_interval - Variable in class org.apache.cassandra.config.Config
- sstable_read_rate_persistence_enabled - Variable in class org.apache.cassandra.config.Config
- SSTABLE_UPPER_BOUND - org.apache.cassandra.db.ClusteringPrefix.Kind
- SSTABLE_VERSIONS - org.apache.cassandra.gms.ApplicationState
-
The set of sstable versions on this node.
- SSTable.Builder<S extends SSTable,B extends SSTable.Builder<S,B>> - Class in org.apache.cassandra.io.sstable
-
A builder of this sstable representation.
- SSTable.Owner - Interface in org.apache.cassandra.io.sstable
- 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. - sstableBytesInEachLevel - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- SSTableComponentsWriter - Class in org.apache.cassandra.index.sai.disk.v1
- SSTableComponentsWriter(IndexDescriptor) - Constructor for class org.apache.cassandra.index.sai.disk.v1.SSTableComponentsWriter
- sstableCompressionRatio - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- SSTableConfig() - Constructor for class org.apache.cassandra.config.Config.SSTableConfig
- sstableContext - Variable in class org.apache.cassandra.index.sai.disk.SSTableIndex
- SSTableContext - Class in org.apache.cassandra.index.sai
-
An
SSTableContext
is created for an individual sstable and is shared across column indexes to track per-sstable index files. - sstableContextManager() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- SSTableContextManager - Class in org.apache.cassandra.index.sai
-
Manages per-sstable
SSTableContext
s forStorageAttachedIndexGroup
- SSTableContextManager() - Constructor for class org.apache.cassandra.index.sai.SSTableContextManager
- sstableCount - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- sstableCountPerTWCSBucket - 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
- sstableDescriptor - Variable in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- 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
-
Observer for events in the lifecycle of writing out an sstable.
- SSTableFormat<R extends SSTableReader,W extends SSTableWriter> - Interface in org.apache.cassandra.io.sstable.format
-
Provides the accessors to data on disk.
- SSTableFormat.Components - Class in org.apache.cassandra.io.sstable.format
- SSTableFormat.Components.Types - Class in org.apache.cassandra.io.sstable.format
- SSTableFormat.Factory - Interface in org.apache.cassandra.io.sstable.format
- SSTableFormat.KeyCacheValueSerializer<R extends SSTableReader,T extends AbstractRowIndexEntry> - Interface in org.apache.cassandra.io.sstable.format
- SSTableFormat.SSTableReaderFactory<R extends SSTableReader,B extends SSTableReader.Builder<R,B>> - Interface in org.apache.cassandra.io.sstable.format
- SSTableFormat.SSTableWriterFactory<W extends SSTableWriter,B extends SSTableWriter.Builder<W,B>> - Interface in org.apache.cassandra.io.sstable.format
- sstableGrowthModifier - Variable in class org.apache.cassandra.db.compaction.unified.Controller
- SSTableId - Interface in org.apache.cassandra.io.sstable
-
Represents a unique identifier in the sstable descriptor filename.
- SSTableId.Builder<T extends SSTableId> - Interface in org.apache.cassandra.io.sstable
-
Builder that can create instances of certain implementation of
SSTableId
. - SSTableIdentityIterator - Class in org.apache.cassandra.io.sstable
- SSTableIdentityIterator(SSTableReader, DecoratedKey, DeletionTime, String, SSTableSimpleIterator) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
- SSTableIdFactory - Class in org.apache.cassandra.io.sstable
- SSTableIdFactory() - Constructor for class org.apache.cassandra.io.sstable.SSTableIdFactory
- 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.sai.disk
-
A reference-counted container of a
SSTableReader
for each column index that: Manages references to the SSTable for each query Exposes a version agnostic searcher onto the column index Exposes the index metadata for the column index - SSTableIndex - Class in org.apache.cassandra.index.sasi
- SSTableIndex(SSTableContext, StorageAttachedIndex) - Constructor for class org.apache.cassandra.index.sai.disk.SSTableIndex
- SSTableIndex(ColumnIndex, File, SSTableReader) - Constructor for class org.apache.cassandra.index.sasi.SSTableIndex
- SSTableIndexesSystemView - Class in org.apache.cassandra.index.sai.virtual
-
A
VirtualTable
providing a system view of SSTable index metadata. - SSTableIndexesSystemView(String) - Constructor for class org.apache.cassandra.index.sai.virtual.SSTableIndexesSystemView
- SSTableIndexWriter - Class in org.apache.cassandra.index.sai.disk.v1
-
Column index writer that accumulates (on-heap) indexed data from a compacted SSTable as it's being flushed to disk.
- SSTableIndexWriter(IndexDescriptor, StorageAttachedIndex, NamedMemoryLimiter, BooleanSupplier) - Constructor for class org.apache.cassandra.index.sai.disk.v1.SSTableIndexWriter
- SSTableIntervalTree - Class in org.apache.cassandra.db.lifecycle
- SSTableIterator - Class in org.apache.cassandra.io.sstable.format.big
-
A Cell Iterator over SSTable
- SSTableIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry, Slices, ColumnFilter, FileHandle) - Constructor for class org.apache.cassandra.io.sstable.format.big.SSTableIterator
- sstableKeyCount() - Method in class org.apache.cassandra.db.compaction.unified.ShardedCompactionWriter
- sstableKeyCount() - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
Returns the key count with which created sstables should be set up.
- sstableKeyCount() - Method in class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
- sstableKeyCount() - Method in class org.apache.cassandra.db.compaction.writers.MajorLeveledCompactionWriter
- sstableKeyCount() - Method in class org.apache.cassandra.db.compaction.writers.MaxSSTableSizeWriter
- sstableKeyCount() - Method in class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
- 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 - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
- sstableLevel() - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
-
Returns the level that should be used when creating sstables.
- sstableLevel() - Method in class org.apache.cassandra.db.compaction.writers.DefaultCompactionWriter
- sstableLevel() - Method in class org.apache.cassandra.db.compaction.writers.MajorLeveledCompactionWriter
- sstableLevel() - Method in class org.apache.cassandra.db.compaction.writers.MaxSSTableSizeWriter
- sstableLevel() - Method in class org.apache.cassandra.db.compaction.writers.SplittingSizeTieredCompactionWriter
- sstableLevel(int) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- 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(File, SSTableLoader.Client, OutputHandler, int, String, 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
- SSTablePartitions - Class in org.apache.cassandra.tools
- SSTablePartitions() - Constructor for class org.apache.cassandra.tools.SSTablePartitions
- 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(SSTableReader.Builder<?, ?>, SSTable.Owner) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader
- SSTableReader.Builder<R extends SSTableReader,B extends SSTableReader.Builder<R,B>> - Class in org.apache.cassandra.io.sstable.format
-
A builder of this sstable reader.
- SSTableReader.IndexesBounds - Class in org.apache.cassandra.io.sstable.format
- SSTableReader.InstanceTidier - Class in org.apache.cassandra.io.sstable.format
-
One instance per SSTableReader we create.
- 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
- SSTableReaderLoadingBuilder<R extends SSTableReader,B extends SSTableReader.Builder<R,B>> - Class in org.apache.cassandra.io.sstable.format
- SSTableReaderLoadingBuilder(SSTable.Builder<?, ?>) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReaderLoadingBuilder
- SSTableReaderWithFilter - Class in org.apache.cassandra.io.sstable.format
- SSTableReaderWithFilter(SSTableReaderWithFilter.Builder<?, ?>, SSTable.Owner) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReaderWithFilter
- SSTableReaderWithFilter.Builder<R extends SSTableReaderWithFilter,B extends SSTableReaderWithFilter.Builder<R,B>> - Class in org.apache.cassandra.io.sstable.format
- SSTableReadsListener - Interface in org.apache.cassandra.io.sstable
-
Listener for receiving notifications associated with reading SSTables.
- SSTableReadsListener.SelectionReason - Enum in org.apache.cassandra.io.sstable
-
The reasons for selecting an SSTable
- SSTableReadsListener.SkippingReason - Enum in org.apache.cassandra.io.sstable
-
The reasons for skipping an SSTable
- SSTableRepairedAtSetter - Class in org.apache.cassandra.tools
- 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.io.sstable.format.big
-
A Cell Iterator in reversed clustering order over SSTable
- SSTableReversedIterator(SSTableReader, FileDataInput, DecoratedKey, RowIndexEntry, Slices, ColumnFilter, FileHandle) - Constructor for class org.apache.cassandra.io.sstable.format.big.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 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.See CASSANDRA-11148
- sstables - Variable in class org.apache.cassandra.db.ColumnFamilyStore.ViewFragment
- sstables - Variable in class org.apache.cassandra.db.compaction.LeveledManifest.CompactionCandidate
- sstables - Variable in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
- sstables - Variable in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- sstables - Variable in class org.apache.cassandra.db.streaming.CassandraStreamReceiver
- sstables - Variable in class org.apache.cassandra.notifications.SSTableRepairStatusChanged
- sstables(SSTableSet, Predicate<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.View
- SSTABLES - Static variable in class org.apache.cassandra.db.compaction.CompactionInfo
- SSTableScanner<S extends SSTableReader,E extends AbstractRowIndexEntry,I extends SSTableScanner.BaseKeyScanningIterator> - Class in org.apache.cassandra.io.sstable.format
- SSTableScanner(S, ColumnFilter, DataRange, Iterator<AbstractBounds<PartitionPosition>>, SSTableReadsListener) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableScanner
- SSTableScanner.BaseKeyScanningIterator - Class in org.apache.cassandra.io.sstable.format
- 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<?, ?>) - Constructor for class org.apache.cassandra.service.SSTablesGlobalTracker
- sstablesHit - Variable in class org.apache.cassandra.index.sai.QueryContext
- 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
- sstablesPerRangeReadHistogram - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Histogram of the number of sstable data files accessed per partition range read
- sstablesPerRangeReadHistogram - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Histogram of the number of sstable data files accessed per partition range read
- sstablesPerReadHistogram - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Histogram of the number of sstable data files accessed per single partition read
- sstablesPerReadHistogram - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Histogram of the number of sstable data files accessed per single partition 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, long, boolean, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Rewrites all SSTables according to specified parameters
- 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<Version>) - 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(Directories.DataDirectory, DecoratedKey) - Method in class org.apache.cassandra.db.compaction.unified.ShardedCompactionWriter
- sstableWriter(Directories.DataDirectory, DecoratedKey) - Method in class org.apache.cassandra.db.compaction.writers.CompactionAwareWriter
- SSTableWriter - Class in org.apache.cassandra.io.sstable.format
-
A root class for a writer implementation.
- SSTableWriter(SSTableWriter.Builder<?, ?>, LifecycleNewTracker, SSTable.Owner) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableWriter
- SSTableWriter.Builder<W extends SSTableWriter,B extends SSTableWriter.Builder<W,B>> - Class in org.apache.cassandra.io.sstable.format
-
A builder of this sstable writer.
- SSTableWriter.SSTableSizeParameters - Interface in org.apache.cassandra.io.sstable.format
-
Parameters for calculating the expected size of an SSTable.
- SSTableWriter.TransactionalProxy - Class in org.apache.cassandra.io.sstable.format
- SSTableZeroCopyWriter - Class in org.apache.cassandra.io.sstable
- SSTableZeroCopyWriter(SSTable.Builder<?, ?>, LifecycleNewTracker, SSTable.Owner) - Constructor for class org.apache.cassandra.io.sstable.SSTableZeroCopyWriter
- stack - Variable in class org.apache.cassandra.io.tries.IncrementalTrieWriterBase
- stack - Variable in class org.apache.cassandra.io.tries.ValueIterator
- StackTraceCombiner(boolean, String, String, String) - Constructor for class org.apache.cassandra.utils.concurrent.Threads.StackTraceCombiner
- stage - Variable in enum org.apache.cassandra.net.Verb
- stage() - Method in class org.apache.cassandra.transport.ConnectedClient
- Stage - Enum in org.apache.cassandra.concurrent
- Stage.ExecutorServiceInitialiser - Interface in org.apache.cassandra.concurrent
- StageConcurrency(int, int) - Constructor for class org.apache.cassandra.service.StorageServiceMBean.StageConcurrency
- stale(long, long, Ballot.Flag) - Method in class org.apache.cassandra.service.paxos.BallotGenerator.Default
- stale(long, long, Ballot.Flag) - Method in interface org.apache.cassandra.service.paxos.BallotGenerator
- staleBallot(long, long, Ballot.Flag) - Static method in class org.apache.cassandra.service.paxos.BallotGenerator.Global
- 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 - org.apache.cassandra.config.Config.DiskAccessMode
- standard() - Static method in interface org.apache.cassandra.concurrent.TaskFactory
- Standard() - Constructor for class org.apache.cassandra.concurrent.TaskFactory.Standard
- Standard() - Constructor for class org.apache.cassandra.utils.concurrent.WaitQueue.Standard
- Standard(int) - Constructor for class org.apache.cassandra.utils.concurrent.Semaphore.Standard
- Standard(int, boolean) - Constructor for class org.apache.cassandra.utils.concurrent.Semaphore.Standard
- Standard(ChannelProxy, CompressionMetadata, Supplier<Double>) - 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 - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableIterator.ForwardReader
- start - Variable in class org.apache.cassandra.repair.consistent.admin.RepairStats.Section
- start() - Method in class org.apache.cassandra.batchlog.BatchlogManager
- start() - Method in class org.apache.cassandra.db.commitlog.CommitLog
-
Tries to start the CommitLog if not already started.
- start() - Method in class org.apache.cassandra.db.Slice
- start() - Method in class org.apache.cassandra.db.Slices
- start() - Static method in class org.apache.cassandra.diag.DiagnosticEventPersistence
- start() - Method in interface org.apache.cassandra.index.transactions.IndexTransaction
- start() - Method in class org.apache.cassandra.repair.consistent.LocalSessions
-
Loads sessions out of the repairs table and sets state to started
- start() - Method in class org.apache.cassandra.repair.state.JobState.Phase
- start() - Method in class org.apache.cassandra.repair.state.SessionState.Phase
- start() - Method in class org.apache.cassandra.repair.state.SyncState.Phase
- start() - Method in class org.apache.cassandra.schema.DefaultSchemaUpdateHandler
- start() - Method in class org.apache.cassandra.schema.OfflineSchemaUpdateHandler
- start() - Method in interface org.apache.cassandra.schema.SchemaUpdateHandler
-
Starts actively synchronizing schema with the rest of the cluster.
- 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.service.paxos.AbstractPaxosRepair
- start() - Method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupLocalCoordinator
- start() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker
- start() - Method in class org.apache.cassandra.service.snapshot.SnapshotManager
- start() - Method in class org.apache.cassandra.streaming.StreamingState.Phase
- start() - Method in class org.apache.cassandra.streaming.StreamManager
- 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() - Method in class org.apache.cassandra.transport.Server
- start() - Method in class org.apache.cassandra.utils.concurrent.OpOrder
-
Start an operation against this OpOrder.
- start(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(long, long) - Method in class org.apache.cassandra.repair.state.ValidationState.Phase
- 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(String[]) - Method in class org.apache.cassandra.tools.nodetool.Sjk.Wrapper
- start(Consumer<DiskUsageState>) - Method in class org.apache.cassandra.service.disk.usage.DiskUsageMonitor
-
Start monitoring local disk usage and call notifier when local disk usage state changed.
- start(List<ColumnFamilyStore>, RepairCoordinator.NeighborsAndRanges) - Method in class org.apache.cassandra.repair.state.CoordinatorState.Phase
- start(ExecutorPlus) - Method in class org.apache.cassandra.repair.RepairSession
-
Start RepairJob on given ColumnFamilies.
- start(DecoratedKey, DeletionTime) - Method in class org.apache.cassandra.io.sstable.format.SortedTablePartitionWriter
- START - org.apache.cassandra.cql3.statements.Bound
- START - org.apache.cassandra.repair.state.CoordinatorState.State
- START - org.apache.cassandra.repair.state.JobState.State
- START - org.apache.cassandra.repair.state.SessionState.State
- START - org.apache.cassandra.repair.state.SyncState.State
- START - org.apache.cassandra.repair.state.ValidationState.State
- START - org.apache.cassandra.streaming.StreamingState.Status
- START - org.apache.cassandra.utils.progress.ProgressEventType
-
Fired first when progress starts.
- START_GOSSIP - org.apache.cassandra.config.CassandraRelevantProperties
- start_native_transport - Variable in class org.apache.cassandra.config.Config
- START_NATIVE_TRANSPORT - org.apache.cassandra.config.CassandraRelevantProperties
- START_TOKEN - Static variable in class org.apache.cassandra.index.sai.virtual.SegmentsSystemView
- startAsByteComparable() - Method in class org.apache.cassandra.db.DataRange
-
The start of the partition key range queried by this
DataRange
. - startAt(OnDiskBlock.SearchResult<OnDiskIndex.DataTerm>, boolean) - Method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndex.IteratorOrder
- startAt(OnDiskBlock<OnDiskIndex.DataTerm>, Expression) - Method in enum org.apache.cassandra.index.sasi.disk.OnDiskIndex.IteratorOrder
- startAutoRepairs() - Static method in class org.apache.cassandra.service.paxos.PaxosState
- startAutoRepairs() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker
- startBatchlogReplay() - Method in class org.apache.cassandra.batchlog.BatchlogManager
- startBootstrap(Collection<Token>) - Method in class org.apache.cassandra.service.StorageService
- startBootstrap(Collection<Token>, boolean) - Method in class org.apache.cassandra.service.StorageService
- startBroadcasting() - Method in class org.apache.cassandra.service.disk.usage.DiskUsageBroadcaster
- 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
- startedAtNanos() - Method in class org.apache.cassandra.transport.Dispatcher.RequestTime
- startedNanos() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosRepair
- 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
- STARTING - org.apache.cassandra.service.StorageService.Mode
- 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
- startOpenMarker - Variable in class org.apache.cassandra.io.sstable.format.SortedTablePartitionWriter
- startParentRepair(TimeUUID, String, String[], RepairOption) - Static method in class org.apache.cassandra.schema.SystemDistributedKeyspace
- startPartition() - Method in class org.apache.cassandra.index.sai.disk.v1.keystore.KeyStoreWriter
- startPartition(DecoratedKey) - Method in interface org.apache.cassandra.index.sai.disk.PerSSTableIndexWriter
- startPartition(DecoratedKey) - Method in class org.apache.cassandra.index.sai.disk.v1.SSTableComponentsWriter
- startPartition(DecoratedKey, long, long) - Method in class org.apache.cassandra.index.sai.disk.StorageAttachedIndexWriter
- startPartition(DecoratedKey, long, long) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
- startPartition(DecoratedKey, long, long) - Method in interface org.apache.cassandra.io.sstable.SSTableFlushObserver
-
Called when a new partition in being written to the sstable, but before any cells are processed (see
SSTableFlushObserver.nextUnfilteredCluster(Unfiltered)
). - startPosition - Variable in class org.apache.cassandra.io.sstable.format.SortedTablePartitionWriter
- 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.
- startRepairPaxosForTopologyChange(String) - Method in class org.apache.cassandra.service.StorageService
- startRepairs(TimeUUID, TimeUUID, String, String[], CommonRange) - Static method in class org.apache.cassandra.schema.SystemDistributedKeyspace
- starts() - Method in class org.apache.cassandra.db.commitlog.IntervalSet
- startSamplingPartitions(String, String, int, int, int, int, List<String>) - Method in class org.apache.cassandra.service.StorageService
- startSamplingPartitions(String, String, int, int, int, int, List<String>) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Start a scheduled sampling
- startScan - Variable in class org.apache.cassandra.io.sstable.format.SSTableScanner
- startSnapshotManager() - Method in class org.apache.cassandra.service.StorageService
- 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
- startSync() - Method in class org.apache.cassandra.schema.Schema
- startThread(String, Runnable) - Method in interface org.apache.cassandra.concurrent.ExecutorFactory
-
Create and start a new thread to execute
runnable
; this thread will be a daemon thread. - startThread(String, Runnable, InfiniteLoopExecutor.Daemon) - Method in class org.apache.cassandra.concurrent.ExecutorFactory.Default
- startThread(String, Runnable, InfiniteLoopExecutor.Daemon) - Method in interface org.apache.cassandra.concurrent.ExecutorFactory
-
Create and start a new thread to execute
runnable
- startTime - Variable in class org.apache.cassandra.repair.SyncTask
- startTimeNanos() - Method in class org.apache.cassandra.concurrent.DebuggableTask.RunningDebuggableTask
- startTimeNanos() - Method in interface org.apache.cassandra.concurrent.DebuggableTask
- startTimeNanos() - Method in class org.apache.cassandra.service.StorageProxy.LocalReadRunnable
- startTimeNanos() - Method in class org.apache.cassandra.transport.Dispatcher.RequestProcessor
- 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
- STARTUP - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- STARTUP - org.apache.cassandra.transport.Message.Type
- startup_checks - Variable in class org.apache.cassandra.config.Config
-
The configuration of startup checks.
- 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
- StartupChecks.StartupCheckType - Enum in org.apache.cassandra.service
- StartupChecksOptions - Class in org.apache.cassandra.config
- StartupChecksOptions() - Constructor for class org.apache.cassandra.config.StartupChecksOptions
- StartupChecksOptions(Map<StartupChecks.StartupCheckType, Map<String, Object>>) - Constructor for class org.apache.cassandra.config.StartupChecksOptions
- 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.schema.SystemDistributedKeyspace
- stat - Variable in class org.apache.cassandra.repair.SyncTask
- state - Variable in class org.apache.cassandra.cql3.statements.schema.AlterSchemaStatement
- state - Variable in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement
- state - Variable in class org.apache.cassandra.gms.GossipShutdown
- state - Variable in class org.apache.cassandra.repair.messages.StatusResponse
- state - Variable in class org.apache.cassandra.repair.RepairCoordinator
- state - Variable in class org.apache.cassandra.repair.RepairJob
- state - Variable in class org.apache.cassandra.repair.RepairSession
- state - Variable in class org.apache.cassandra.repair.Validator
- state - Variable in class org.apache.cassandra.streaming.SessionInfo
-
Current session state
- state - Variable in class org.apache.cassandra.utils.AbstractGuavaIterator
- state() - Method in class org.apache.cassandra.service.disk.usage.DiskUsageMonitor
- 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() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosRepair
- state() - Method in class org.apache.cassandra.streaming.StreamSession
- state() - Method in class org.apache.cassandra.utils.concurrent.Transactional.AbstractTransactional
- state(SSTableReader) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
- state(InetAddressAndPort) - Method in class org.apache.cassandra.service.disk.usage.DiskUsageBroadcaster
- state(StreamSession.State) - Method in class org.apache.cassandra.streaming.StreamSession
-
Set current state to
newState
. - State<T extends java.lang.Enum<T>,I> - Interface in org.apache.cassandra.repair.state
- State() - Constructor for class org.apache.cassandra.service.ClientWarn.State
- State() - Constructor for class org.apache.cassandra.service.paxos.AbstractPaxosRepair.State
- STATE - Static variable in class org.apache.cassandra.repair.consistent.LocalSessionInfo
- 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(ClientState, StatementType, TableMetadata, WhereClause, VariableSpecifications, List<Ordering>, boolean, boolean, boolean) - Constructor for class org.apache.cassandra.cql3.restrictions.StatementRestrictions
- StatementRestrictions(ClientState, StatementType, TableMetadata, WhereClause, VariableSpecifications, List<Ordering>, 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
- stateTimesMillis() - Method in class org.apache.cassandra.streaming.StreamingState
- stateTimesNanos - Variable in class org.apache.cassandra.repair.state.AbstractState
- stateType() - Method in class org.apache.cassandra.cql3.functions.UDAggregate
- STATIC - org.apache.cassandra.index.sai.utils.PrimaryKey.Kind
- STATIC - org.apache.cassandra.schema.ColumnMetadata.Kind
- STATIC_BUILDER - Static variable in class org.apache.cassandra.db.CBuilder
- STATIC_CLUSTERING - org.apache.cassandra.db.ClusteringPrefix.Kind
- STATIC_CLUSTERING - Static variable in interface org.apache.cassandra.db.Clustering
-
The special cased clustering used by all static rows.
- staticClustering() - Method in interface org.apache.cassandra.db.marshal.ValueAccessor.ObjectFactory
- staticColumn(String, String, String, AbstractType<?>) - Static method in class org.apache.cassandra.schema.ColumnMetadata
- staticColumn(TableMetadata, ByteBuffer, 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.rows.AbstractUnfilteredRowIterator
- staticRow - Variable in class org.apache.cassandra.db.rows.UnfilteredRowIteratorSerializer.Header
- staticRow - Variable in class org.apache.cassandra.index.sai.utils.PartitionInfo
- staticRow - Variable in class org.apache.cassandra.io.sstable.AbstractSSTableIterator
- staticRow() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
- staticRow() - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
- 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() - Method in class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
- staticRow() - Method in interface 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.AbstractSSTableIterator
- staticRow() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
- staticRow(Row) - Method in class org.apache.cassandra.index.sai.disk.StorageAttachedIndexWriter
- staticRow(Row) - Method in class org.apache.cassandra.index.sasi.disk.PerSSTableIndexWriter
- staticRow(Row) - Method in interface org.apache.cassandra.io.sstable.SSTableFlushObserver
-
Called when a static row is being written to the sstable.
- 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 byPerSSTableIndexWriter
are stitched together byPerSSTableIndexWriter.complete()
. - StaticTokenTreeBuilder(CombinedTerm) - Constructor for class org.apache.cassandra.index.sasi.disk.StaticTokenTreeBuilder
- statistics - Variable in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator.Builder
- statistics - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder
- Statistics() - Constructor for class org.apache.cassandra.index.sai.iterators.KeyRangeIterator.Builder.Statistics
- Statistics(RangeIterator.Builder.IteratorType) - Constructor for class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
- stats - Variable in class org.apache.cassandra.db.partitions.BTreePartitionData
- stats - Variable in class org.apache.cassandra.db.rows.AbstractUnfilteredRowIterator
- stats - Variable in class org.apache.cassandra.repair.RepairResult
- 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() - 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 interface 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() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator
- 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 - org.apache.cassandra.io.sstable.metadata.MetadataType
-
Metadata always keep in memory
- STATS - Static variable in class org.apache.cassandra.io.sstable.format.SSTableFormat.Components
- STATS - Static variable in class org.apache.cassandra.io.sstable.format.SSTableFormat.Components.Types
- statsCollector - Variable in class org.apache.cassandra.db.memtable.AbstractMemtable
- StatsCollector() - Constructor for class org.apache.cassandra.db.memtable.AbstractMemtable.StatsCollector
- StatsComponent - Class in org.apache.cassandra.io.sstable.format
- StatsComponent(Map<MetadataType, MetadataComponent>) - Constructor for class org.apache.cassandra.io.sstable.format.StatsComponent
- 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() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
- statsMetadata() - Method in class org.apache.cassandra.io.sstable.format.StatsComponent
- StatsMetadata - Class in org.apache.cassandra.io.sstable.metadata
-
SSTable metadata that always stay on heap.
- StatsMetadata(EstimatedHistogram, EstimatedHistogram, IntervalSet<CommitLogPosition>, long, long, long, long, int, int, double, TombstoneHistogram, int, List<AbstractType<?>>, Slice, boolean, long, long, long, double, UUID, TimeUUID, boolean, boolean, ByteBuffer, ByteBuffer) - 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 - Variable in class org.apache.cassandra.transport.Event.StatusChange
- status() - Method in class org.apache.cassandra.repair.state.AbstractState
- status() - Method in class org.apache.cassandra.repair.state.CoordinatorState
- status() - Method in class org.apache.cassandra.repair.state.SessionState
- status() - Method in class org.apache.cassandra.streaming.StreamingState
- Status - Class in org.apache.cassandra.tools.nodetool
- Status() - Constructor for class org.apache.cassandra.tools.nodetool.Status
- STATUS - org.apache.cassandra.gms.ApplicationState
-
Deprecated.See CASSANDRA-7544
- STATUS_BOOTSTRAPPING - Static variable in class org.apache.cassandra.gms.VersionedValue
- STATUS_BOOTSTRAPPING_REPLACE - Static variable in class org.apache.cassandra.gms.VersionedValue
- STATUS_CHANGE - org.apache.cassandra.transport.Event.Type
- STATUS_LEAVING - Static variable in class org.apache.cassandra.gms.VersionedValue
- STATUS_LEFT - Static variable in class org.apache.cassandra.gms.VersionedValue
- STATUS_MOVING - Static variable in class org.apache.cassandra.gms.VersionedValue
- STATUS_NORMAL - Static variable in class org.apache.cassandra.gms.VersionedValue
- STATUS_REJECTED - org.apache.cassandra.repair.state.ParticipateState.RegisterStatus
- STATUS_REQ - org.apache.cassandra.net.Verb
- STATUS_RSP - org.apache.cassandra.net.Verb
- STATUS_WITH_PORT - org.apache.cassandra.gms.ApplicationState
- 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(TimeUUID) - Constructor for class org.apache.cassandra.repair.messages.StatusRequest
- StatusResponse - Class in org.apache.cassandra.repair.messages
- StatusResponse(TimeUUID, 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 - org.apache.cassandra.config.Config.CommitFailurePolicy
- stop - org.apache.cassandra.config.Config.DiskFailurePolicy
- 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() - Method in class org.apache.cassandra.service.EmbeddedCassandraService
- stop() - Method in class org.apache.cassandra.service.NativeTransportService
-
Stops currently running native transport servers.
- stop() - Method in class org.apache.cassandra.service.snapshot.SnapshotManager
- stop() - Method in class org.apache.cassandra.streaming.StreamManager
- stop() - Method in class org.apache.cassandra.tracing.TraceState
- stop() - Method in class org.apache.cassandra.transport.Server
- 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
- stop() - Method in class org.apache.cassandra.utils.logging.VirtualTableAppender
- stop(boolean) - Method in class org.apache.cassandra.service.NativeTransportService
- stop(boolean) - Method in class org.apache.cassandra.transport.Server
- stop(String) - Method in class org.apache.cassandra.tools.NodeProbe
- stop(String[]) - Static method in class org.apache.cassandra.service.CassandraDaemon
- Stop - Class in org.apache.cassandra.tools.nodetool
- Stop() - Constructor for class org.apache.cassandra.tools.nodetool.Stop
- stop_commit - org.apache.cassandra.config.Config.CommitFailurePolicy
- stop_paranoid - org.apache.cassandra.config.Config.DiskFailurePolicy
- stopAsByteComparable() - Method in class org.apache.cassandra.db.DataRange
-
The end of the partition key range queried by this
DataRange
. - 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
-
Deprecated.
- stopNativeTransport() - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.
- stopNativeTransport(boolean) - Method in class org.apache.cassandra.service.CassandraDaemon
- stopNativeTransport(boolean) - Method in class org.apache.cassandra.service.StorageService
- stopNativeTransport(boolean) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- stopNativeTransport(boolean) - Method in class org.apache.cassandra.tools.NodeProbe
- STOPPED - org.apache.cassandra.tracing.TraceState.Status
- StoppingTransformation<I extends BaseRowIterator<?>> - Class in org.apache.cassandra.db.transform
- StoppingTransformation() - Constructor for class org.apache.cassandra.db.transform.StoppingTransformation
- stopSamplingPartitions(String, String) - Method in class org.apache.cassandra.service.StorageService
- stopSamplingPartitions(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Stop a scheduled sampling
- 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_compatibility_mode - Variable in class org.apache.cassandra.config.Config
- STORAGE_DIR - org.apache.cassandra.config.CassandraRelevantProperties
- STORAGE_HOOK - org.apache.cassandra.config.CassandraRelevantProperties
- storage_port - Variable in class org.apache.cassandra.config.Config
- STORAGE_PORT - org.apache.cassandra.config.CassandraRelevantProperties
- STORAGE_PORT_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
- StorageAttachedIndex - Class in org.apache.cassandra.index.sai
- StorageAttachedIndex(ColumnFamilyStore, IndexMetadata) - Constructor for class org.apache.cassandra.index.sai.StorageAttachedIndex
- StorageAttachedIndexBuilder - Class in org.apache.cassandra.index.sai
-
Multiple storage-attached indexes can start building concurrently.
- StorageAttachedIndexGroup - Class in org.apache.cassandra.index.sai
-
Orchestrates building of storage-attached indices, and manages lifecycle of resources shared between them.
- StorageAttachedIndexOptions - Class in org.apache.cassandra.config
- StorageAttachedIndexOptions() - Constructor for class org.apache.cassandra.config.StorageAttachedIndexOptions
- StorageAttachedIndexQueryPlan - Class in org.apache.cassandra.index.sai.plan
- StorageAttachedIndexSearcher - Class in org.apache.cassandra.index.sai.plan
- StorageAttachedIndexSearcher(ColumnFamilyStore, TableQueryMetrics, ReadCommand, RowFilter, long) - Constructor for class org.apache.cassandra.index.sai.plan.StorageAttachedIndexSearcher
- StorageAttachedIndexTables - Class in org.apache.cassandra.index.sai.virtual
- StorageAttachedIndexWriter - Class in org.apache.cassandra.index.sai.disk
-
Writes all on-disk index structures attached to a given SSTable.
- StorageCompatibilityMode - Enum in org.apache.cassandra.utils
-
The mode of compatibility with older Cassandra versions.
- 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
- StorageService.Mode - Enum in org.apache.cassandra.service
- 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
- store_type - Variable in class org.apache.cassandra.security.AbstractSslContextFactory
- STORE_TYPE - org.apache.cassandra.config.EncryptionOptions.ConfigKey
- StoredTopPartitions(List<TopPartitionTracker.TopPartition>, long) - Constructor for class org.apache.cassandra.metrics.TopPartitionTracker.StoredTopPartitions
- storePreparedStatement(String, String, QueryHandler.Prepared) - Static method in class org.apache.cassandra.cql3.QueryProcessor
- strategyLogger() - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
- strategyLogger() - Method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
- stream - Variable in class org.apache.cassandra.streaming.messages.IncomingStreamMessage
- stream - Variable in class org.apache.cassandra.streaming.messages.OutgoingStreamMessage
- stream() - Method in class org.apache.cassandra.cql3.UntypedResultSet
- stream() - 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.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.UserFunctions
- stream() - Method in class org.apache.cassandra.schema.Views
- stream() - Method in class org.apache.cassandra.service.RangeRelocator
- stream(Set<InetAddressAndPort>, StreamEventHandler...) - Method in class org.apache.cassandra.io.sstable.SSTableLoader
- stream(TableId) - Method in class org.apache.cassandra.schema.Views
- STREAM - org.apache.cassandra.db.compaction.OperationType
- STREAM - org.apache.cassandra.streaming.messages.StreamMessage.Type
- STREAM_COMPLETE - org.apache.cassandra.streaming.StreamEvent.Type
- stream_entire_sstables - Variable in class org.apache.cassandra.config.Config
- STREAM_HOOK - org.apache.cassandra.config.CassandraRelevantProperties
- STREAM_INIT - org.apache.cassandra.streaming.messages.StreamMessage.Type
- STREAM_PREPARED - org.apache.cassandra.streaming.StreamEvent.Type
- STREAM_START - org.apache.cassandra.repair.state.JobState.State
- stream_throughput_outbound - Variable in class org.apache.cassandra.config.Config
- stream_transfer_task_timeout - Variable in class org.apache.cassandra.config.Config
- streamable - Variable in class org.apache.cassandra.io.sstable.Component.Type
- 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, StreamingChannel.Factory, boolean, boolean, TimeUUID, PreviewKind) - Constructor for class org.apache.cassandra.streaming.StreamCoordinator
- StreamDeserializer(TableMetadata, DataInputPlus, Version, SerializationHeader) - Constructor for class org.apache.cassandra.db.streaming.CassandraStreamReader.StreamDeserializer
- StreamDeserializingTask - Class in org.apache.cassandra.streaming
-
The task that performs the actual deserialization.
- StreamDeserializingTask(StreamSession, StreamingChannel, int) - Constructor for class org.apache.cassandra.streaming.StreamDeserializingTask
- streamEntireSSTables() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- StreamEvent - Class in org.apache.cassandra.streaming
- StreamEvent(StreamEvent.Type, TimeUUID) - 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
- streamExecutor() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- streamExecutor() - Method in class org.apache.cassandra.repair.SharedContext.Global
- streamExecutor() - Method in interface org.apache.cassandra.repair.SharedContext
- StreamExecutor - Interface in org.apache.cassandra.repair
- streamFromMemtable() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- streamFromMemtable() - Method in interface org.apache.cassandra.db.memtable.Memtable.Factory
-
When we need to stream data, we usually flush and stream the resulting sstables.
- 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 - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- STREAMING - org.apache.cassandra.net.ConnectionCategory
- STREAMING - org.apache.cassandra.net.ConnectionType
- STREAMING - org.apache.cassandra.streaming.StreamSession.State
- streaming_connections_per_host - Variable in class org.apache.cassandra.config.Config
- STREAMING_HISTOGRAM_ROUND_SECONDS - org.apache.cassandra.config.CassandraRelevantProperties
- streaming_keep_alive_period - Variable in class org.apache.cassandra.config.Config
- STREAMING_SESSION_PARALLELTRANSFERS - org.apache.cassandra.config.CassandraRelevantProperties
- streaming_slow_events_log_timeout - Variable in class org.apache.cassandra.config.Config
- streaming_state_expires - Variable in class org.apache.cassandra.config.Config
- streaming_state_size - Variable in class org.apache.cassandra.config.Config
- streaming_stats_enabled - Variable in class org.apache.cassandra.config.Config
- StreamingChannel - Interface in org.apache.cassandra.streaming
- StreamingChannel.Factory - Interface in org.apache.cassandra.streaming
- StreamingChannel.Factory.Global - Class in org.apache.cassandra.streaming
- StreamingChannel.Kind - Enum in org.apache.cassandra.streaming
- StreamingChannel.Send - Interface in org.apache.cassandra.streaming
- StreamingDataInputPlus - Interface in org.apache.cassandra.streaming
- StreamingDataOutputPlus - Interface in org.apache.cassandra.streaming
- StreamingDataOutputPlus.BufferSupplier - Interface in org.apache.cassandra.streaming
- StreamingDataOutputPlus.RateLimiter - Interface in org.apache.cassandra.streaming
- StreamingDataOutputPlus.Write - Interface in org.apache.cassandra.streaming
- StreamingDataOutputPlusFixed - Class in org.apache.cassandra.streaming
- StreamingDataOutputPlusFixed(ByteBuffer) - Constructor for class org.apache.cassandra.streaming.StreamingDataOutputPlusFixed
- streamingFactory() - Static method in class org.apache.cassandra.streaming.StreamingChannel.Factory.Global
- StreamingMetrics - Class in org.apache.cassandra.metrics
-
Metrics for streaming.
- StreamingMetrics(InetAddressAndPort) - Constructor for class org.apache.cassandra.metrics.StreamingMetrics
- StreamingMultiplexedChannel - Class in org.apache.cassandra.streaming.async
-
Responsible for sending
StreamMessage
s to a given peer. - StreamingMultiplexedChannel(StreamSession, StreamingChannel.Factory, InetAddressAndPort, StreamingChannel, int) - Constructor for class org.apache.cassandra.streaming.async.StreamingMultiplexedChannel
- StreamingRepairTask - Class in org.apache.cassandra.repair
-
StreamingRepairTask performs data streaming between two remote replicas, neither of which is repair coordinator.
- StreamingRepairTask(SharedContext, SyncState, RepairJobDesc, InetAddressAndPort, InetAddressAndPort, InetAddressAndPort, Collection<Range<Token>>, TimeUUID, PreviewKind, boolean) - Constructor for class org.apache.cassandra.repair.StreamingRepairTask
- StreamingState - Class in org.apache.cassandra.streaming
- StreamingState(StreamResultFuture) - Constructor for class org.apache.cassandra.streaming.StreamingState
- StreamingState.Phase - Class in org.apache.cassandra.streaming
- StreamingState.Sessions - Class in org.apache.cassandra.streaming
- StreamingState.Status - Enum in org.apache.cassandra.streaming
- 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
- StreamingVirtualTable - Class in org.apache.cassandra.db.virtual
- StreamingVirtualTable(String) - Constructor for class org.apache.cassandra.db.virtual.StreamingVirtualTable
- StreamInitMessage - Class in org.apache.cassandra.streaming.messages
-
StreamInitMessage is first sent from the node where
StreamSession
is started, to initiate correspondingStreamSession
on the other side. - StreamInitMessage(InetAddressAndPort, int, TimeUUID, StreamOperation, TimeUUID, PreviewKind) - Constructor for class org.apache.cassandra.streaming.messages.StreamInitMessage
- StreamManager - Class in org.apache.cassandra.streaming
-
StreamManager manages currently running
StreamResultFuture
s and provides status of all operation invoked. - StreamManager() - Constructor for class org.apache.cassandra.streaming.StreamManager
- StreamManager.StreamListener - Interface in org.apache.cassandra.streaming
- 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, TimeUUID, boolean, int, int, long, TimeUUID) - 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 - Variable in class org.apache.cassandra.streaming.StreamResultFuture
- streamOperation - Variable in class org.apache.cassandra.streaming.StreamState
- streamOperation() - Method in class org.apache.cassandra.streaming.StreamPlan
- streamOperation() - Method in class org.apache.cassandra.streaming.StreamSession
- StreamOperation - Enum in org.apache.cassandra.streaming
- 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, TimeUUID, PreviewKind) - Constructor for class org.apache.cassandra.streaming.StreamPlan
- streamProxy - Variable in class org.apache.cassandra.tools.NodeProbe
- 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. - StreamResultFuture(TimeUUID, StreamOperation, StreamCoordinator) - Constructor for class org.apache.cassandra.streaming.StreamResultFuture
-
Create new StreamResult of given
planId
and streamOperation. - StreamResultFuture(TimeUUID, StreamOperation, TimeUUID, PreviewKind) - Constructor for class org.apache.cassandra.streaming.StreamResultFuture
- streams - Variable in class org.apache.cassandra.streaming.StreamTransferTask
- STREAMS_RECEIVED - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- 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, StreamingChannel.Factory, StreamingChannel, int, boolean, int, TimeUUID, 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.PrepareDirection - Enum 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(TimeUUID, 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
- streamSubmitted() - Method in class org.apache.cassandra.repair.state.JobState.Phase
- 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
- streamToMemtable() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- streamToMemtable() - Method in interface org.apache.cassandra.db.memtable.Memtable.Factory
-
Normally we can receive streamed sstables directly, skipping the memtable stage (zero-copy-streaming).
- 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
andright
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() - Static method in interface org.apache.cassandra.cql3.functions.FunctionParameter
- string(byte[]) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- string(byte[], Charset) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- string(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
- string(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- string(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- string(ByteBuffer, int, int, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- string(ByteBuffer, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Decode a String representation.
- STRING - org.apache.cassandra.cql3.Constants.Type
- STRING_LEN - Static variable in class org.apache.cassandra.io.sstable.UUIDBasedSSTableId
- 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
- stringifyTKeyValueParameters(Map<String, String>) - Static method in class org.apache.cassandra.db.marshal.TypeParser
- 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
- stringifyVectorParameters(AbstractType<?>, boolean, int) - Static method in class org.apache.cassandra.db.marshal.TypeParser
- StringToken(String) - Constructor for class org.apache.cassandra.dht.OrderPreservingPartitioner.StringToken
- StringType - Class in org.apache.cassandra.db.marshal
- StringType(AbstractType.ComparisonType) - Constructor for class org.apache.cassandra.db.marshal.StringType
- 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
- STUFFED - org.apache.cassandra.service.disk.usage.DiskUsageState
-
Disk usage exceeds
GuardrailsConfig.getDataDiskUsagePercentageWarnThreshold()
but is belowGuardrailsConfig.getDataDiskUsagePercentageFailThreshold()
. - 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(Runnable) - Method in interface org.apache.cassandra.concurrent.ExecutorPlus
-
Overrides
ExecutorService.submit(Runnable)
to return a CassandraFuture
- submit(Runnable) - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
- submit(Runnable) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- submit(Runnable) - Method in class org.apache.cassandra.concurrent.SEPExecutor
- submit(Runnable) - Method in enum org.apache.cassandra.concurrent.Stage
- submit(Runnable) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorPlus
- submit(Runnable) - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- submit(Runnable, T) - Method in interface org.apache.cassandra.concurrent.ExecutorPlus
-
Overrides
ExecutorService.submit(Runnable, Object)
to return a CassandraFuture
- submit(Runnable, T) - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
- submit(Runnable, T) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- submit(Runnable, T) - Method in class org.apache.cassandra.concurrent.SEPExecutor
- submit(Runnable, T) - Method in enum org.apache.cassandra.concurrent.Stage
- submit(Runnable, T) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorPlus
- submit(Runnable, T) - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- submit(Callable<T>) - Method in interface org.apache.cassandra.concurrent.ExecutorPlus
-
Overrides
ExecutorService.submit(Callable)
to return a CassandraFuture
- submit(Callable<T>) - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
- submit(Callable<T>) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- submit(Callable<T>) - Method in class org.apache.cassandra.concurrent.SEPExecutor
- submit(Callable<T>) - Method in enum org.apache.cassandra.concurrent.Stage
- submit(Callable<T>) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorPlus
- submit(Callable<T>) - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- submit(WithResources, Runnable) - Method in interface org.apache.cassandra.concurrent.ExecutorPlus
-
Invoke
task
, returning a future yieldingnull
if successful, or the abnormal termination oftask
otherwise. - submit(WithResources, Runnable) - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
- submit(WithResources, Runnable) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- submit(WithResources, Runnable) - Method in class org.apache.cassandra.concurrent.SEPExecutor
- submit(WithResources, Runnable) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorPlus
- submit(WithResources, Runnable) - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- submit(WithResources, Runnable, T) - Method in interface org.apache.cassandra.concurrent.ExecutorPlus
-
Invoke
task
, returning a future yieldingresult
if successful, or the abnormal termination oftask
otherwise. - submit(WithResources, Runnable, T) - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
- submit(WithResources, Runnable, T) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- submit(WithResources, Runnable, T) - Method in class org.apache.cassandra.concurrent.SEPExecutor
- submit(WithResources, Runnable, T) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorPlus
- submit(WithResources, Runnable, T) - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- submit(WithResources, Callable<T>) - Method in interface org.apache.cassandra.concurrent.ExecutorPlus
-
Invoke
task
, returning a future representing this computation. - submit(WithResources, Callable<T>) - Method in class org.apache.cassandra.concurrent.ImmediateExecutor
- submit(WithResources, Callable<T>) - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- submit(WithResources, Callable<T>) - Method in class org.apache.cassandra.concurrent.SEPExecutor
- submit(WithResources, Callable<T>) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorPlus
- submit(WithResources, Callable<T>) - Method in class org.apache.cassandra.concurrent.WrappedExecutorPlus
- 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
- 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, long, boolean) - Method in class org.apache.cassandra.db.compaction.CompactionManager
- submitMaximal(ColumnFamilyStore, long, boolean, OperationType) - Method in class org.apache.cassandra.db.compaction.CompactionManager
- submitPendingAntiCompaction(ColumnFamilyStore, RangesAtEndpoint, Refs<SSTableReader>, LifecycleTransaction, TimeUUID, 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(TimeUUID, CommonRange, String, RepairParallelism, boolean, boolean, PreviewKind, boolean, boolean, boolean, ExecutorPlus, Scheduler, 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>, long) - 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 interface org.apache.cassandra.repair.IValidationManager
- 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
- SubnetGroups - Class in org.apache.cassandra.config
-
When a group of subnets are needed, this class can be used to represent the group as if it was a single subnet.
- SubnetGroups() - Constructor for class org.apache.cassandra.config.SubnetGroups
- SubnetGroups(List<String>) - Constructor for class org.apache.cassandra.config.SubnetGroups
-
Used by SnakeYaml
- subnets - Variable in class org.apache.cassandra.config.SubnetGroups
- SubPool(long, float) - Constructor for class org.apache.cassandra.utils.memory.MemtablePool.SubPool
- 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
- subscribe(INotificationConsumer) - Method in class org.apache.cassandra.db.lifecycle.Tracker
- 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(String...) - Static method in class org.apache.cassandra.auth.DCPermissions
- subset(Set<String>) - Static method in class org.apache.cassandra.auth.CIDRPermissions
-
Generates CIDR permissions object with given CIDR groups
- subset(Set<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(Number, Number) - Method in class org.apache.cassandra.db.marshal.ByteType
- substract(Number, Number) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
- substract(Number, Number) - Method in class org.apache.cassandra.db.marshal.DecimalType
- substract(Number, Number) - Method in class org.apache.cassandra.db.marshal.DoubleType
- substract(Number, Number) - Method in class org.apache.cassandra.db.marshal.FloatType
- substract(Number, Number) - Method in class org.apache.cassandra.db.marshal.Int32Type
- substract(Number, Number) - Method in class org.apache.cassandra.db.marshal.IntegerType
- substract(Number, Number) - Method in class org.apache.cassandra.db.marshal.LongType
- substract(Number, Number) - Method in class org.apache.cassandra.db.marshal.NumberType
-
Substracts the left argument from the right one.
- substract(Number, Number) - Method in class org.apache.cassandra.db.marshal.ShortType
- substractDuration(Number, Duration) - Method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- substractDuration(Number, Duration) - Method in class org.apache.cassandra.db.marshal.TemporalType
-
Substract the duration from the specified value.
- 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(Collection<Range<T>>, Collection<Range<T>>) - Static method in class org.apache.cassandra.dht.Range
- subtract(Range<T>) - Method in class org.apache.cassandra.dht.Range
- subtract(InputPosition) - Method in interface org.apache.cassandra.hints.InputPosition
- 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
- subtractAll(Collection<Range<T>>) - Method in class org.apache.cassandra.dht.Range
- 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.
- subtrie(ByteComparable, boolean, ByteComparable, boolean) - Method in class org.apache.cassandra.db.tries.Trie
-
Returns a view of the subtrie containing everything in this trie whose keys fall between the given boundaries.
- subtrie(ByteComparable, ByteComparable) - Method in class org.apache.cassandra.db.tries.Trie
-
Returns a view of the subtrie containing everything in this trie whose keys fall between the given boundaries, left-inclusive and right-exclusive.
- subtype(int) - Method in class org.apache.cassandra.db.ClusteringComparator
-
Returns the type of the ith clustering column of the table.
- subtypeCodec - Variable in class org.apache.cassandra.cql3.functions.types.VectorCodec
- 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.CompositeType
- subTypes() - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType
- 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
- subTypes() - Method in class org.apache.cassandra.db.marshal.VectorType
- subTypes() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
- success - Variable in class org.apache.cassandra.db.TruncateResponse
- 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 - Variable in class org.apache.cassandra.streaming.StreamEvent.SessionCompleteEvent
- success() - Method in class org.apache.cassandra.net.OutboundConnectionInitiator.Result
- success() - Method in class org.apache.cassandra.repair.messages.ValidationResponse
- success() - Method in class org.apache.cassandra.repair.state.AbstractCompletable.BasePhase
- success() - Static method in class org.apache.cassandra.repair.state.Completable.Result
- success(String) - Method in class org.apache.cassandra.repair.state.AbstractCompletable.BasePhase
- success(String) - Static method in class org.apache.cassandra.repair.state.Completable.Result
- success(List<RepairSessionResult>) - Static method in class org.apache.cassandra.repair.CoordinatedRepairResult
-
Utility method for tests to produce a success result; should only be used by tests as syntaxtic sugar as all results must be present else an error is thrown.
- success(UUID) - Static method in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupResponse
- success(V) - Static method in class org.apache.cassandra.utils.concurrent.ImmediateFuture
- SUCCESS - org.apache.cassandra.net.ResourceLimits.Outcome
- SUCCESS - org.apache.cassandra.repair.state.Completable.Result.Kind
- SUCCESS - org.apache.cassandra.streaming.StreamingState.Status
- SUCCESS - org.apache.cassandra.utils.progress.ProgressEventType
-
When observing process completes successfully, this is sent once before COMPLETE.
- successful - Variable in class org.apache.cassandra.repair.consistent.admin.CleanupSummary
- SUCCESSFUL - org.apache.cassandra.db.compaction.CompactionManager.AllSSTableOpStatus
- successfulConnections() - Method in class org.apache.cassandra.net.OutboundConnection
- successfulOf(List<? extends Future<V>>) - Static method in class org.apache.cassandra.utils.concurrent.FutureCombiner
-
Waits for all futures to complete, returning a list containing values of all successful input futures.
- successfulParentRepair(TimeUUID, Collection<Range<Token>>) - Static method in class org.apache.cassandra.schema.SystemDistributedKeyspace
- successfulRanges - Variable in class org.apache.cassandra.repair.CoordinatedRepairResult
- successfulRepairJob(TimeUUID, String, String) - Static method in class org.apache.cassandra.schema.SystemDistributedKeyspace
- successfulViewBuild(String, String, UUID) - Static method in class org.apache.cassandra.schema.SystemDistributedKeyspace
- successMessage() - Method in class org.apache.cassandra.repair.PreviewRepairTask
- successMessage() - Method in interface org.apache.cassandra.repair.RepairTask
- successMessage() - Method in class org.apache.cassandra.streaming.StreamingState
- sufficientForStartupSafetyCheck(Map<InetAddressAndPort, EndpointState>) - Method in class org.apache.cassandra.gms.Gossiper
- sufficientLiveNodesForSelectStar(TableMetadata, ConsistencyLevel) - Static method in class org.apache.cassandra.service.reads.range.RangeCommands
-
Added specifically to check for sufficient nodes live to serve partition denylist queries
- SUFFIX - org.apache.cassandra.index.sasi.plan.Expression.Op
- SuffixSA - Class in org.apache.cassandra.index.sasi.sa
- SuffixSA(AbstractType<?>, OnDiskIndexBuilder.Mode) - Constructor for class org.apache.cassandra.index.sasi.sa.SuffixSA
- SUH_FACTORY_CLASS_PROPERTY - Static variable in class org.apache.cassandra.schema.SchemaUpdateHandlerFactoryProvider
-
Deprecated.Use CassandraRelevantProperties.SCHEMA_UPDATE_HANDLER_FACTORY_CLASS instead. See CASSANDRA-17797
- 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.format.big.BigFormat.Components
- SUMMARY - Static variable in class org.apache.cassandra.io.sstable.format.big.BigFormat.Components.Types
- summaryCount - Variable in class org.apache.cassandra.io.sstable.indexsummary.IndexSummaryBuilder.ReadableBoundary
- SUN_ARCH_DATA_MODEL - org.apache.cassandra.config.CassandraRelevantProperties
-
Platform word size sun.arch.data.model.
- SUN_JAVA_COMMAND - org.apache.cassandra.config.CassandraRelevantProperties
- SUN_RMI_TRANSPORT_TCP_THREADKEEPALIVETIME - org.apache.cassandra.config.CassandraRelevantProperties
-
Controls the JMX server threadpool keap-alive time.
- SUN_STDERR_ENCODING - org.apache.cassandra.config.CassandraRelevantProperties
- SUN_STDOUT_ENCODING - org.apache.cassandra.config.CassandraRelevantProperties
- SUPER - org.apache.cassandra.schema.TableMetadata.Flag
-
Deprecated.See CASSANDRA-16217
- SUPER_BLOCK_SIZE - Static variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder
- SUPER_COLUMN_COUNTING_LIMIT - org.apache.cassandra.db.filter.DataLimits.Kind
-
Deprecated.See CASSANDRA-16582
- superBlockCnt - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataLevel
- superBlocksOffset - Variable in class org.apache.cassandra.index.sasi.disk.OnDiskIndex.DataLevel
- supersededBy() - Method in class org.apache.cassandra.service.paxos.PaxosState.MaybePromise
- supersedes(DeletionTime) - Method in class org.apache.cassandra.db.DeletionTime
- supersedes(DeletionTime) - Method in class org.apache.cassandra.db.rows.Row.Deletion
- 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(Row.Deletion) - Method in class org.apache.cassandra.db.rows.Row.Deletion
- SUPERUSER - org.apache.cassandra.auth.IRoleManager.Option
- SUPERUSER_SETUP_DELAY - Static variable in class org.apache.cassandra.auth.AuthKeyspace
- SUPERUSER_SETUP_DELAY_MS - org.apache.cassandra.config.CassandraRelevantProperties
- supplier() - Method in class org.apache.cassandra.utils.concurrent.Threads.StackTraceCombiner
- 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 - org.apache.cassandra.transport.Message.Type
- SUPPORTED - Static variable in enum org.apache.cassandra.transport.ProtocolVersion
-
All supported versions, published as an enumset
- SUPPORTED_PRIVATE_KEY_ALGORITHMS - Static variable in class org.apache.cassandra.security.PEMReader
-
The private key can be with any of these algorithms in order for this read to successfully parse it.
- SUPPORTED_TYPES - Static variable in class org.apache.cassandra.index.sai.StorageAttachedIndex
- 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.net.MessagingService.Version
- 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.sai.utils.IndexTermType
- 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.sai.StorageAttachedIndex
- supportsExpression(ColumnMetadata, Operator) - Method in class org.apache.cassandra.index.sasi.SASIIndex
- supportsExpression(ColumnMetadata, Operator) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- supportsFreezing() - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
- supportsOperator(Operator) - Static method in class org.apache.cassandra.index.sai.plan.Expression
- 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
- supportsPreferredIp() - Method in interface org.apache.cassandra.streaming.StreamingChannel.Factory
-
Provide way to disable getPreferredIP() for tools without access to the system keyspace CASSANDRA-17663 moves calls to SystemKeyspace.getPreferredIP() outside of any threads that are regularly interrupted.
- supportsPreferredIp() - Method in class org.apache.cassandra.tools.BulkLoadConnectionFactory
- supportsReads() - Method in enum org.apache.cassandra.index.Index.LoadType
- supportsReplicaFilteringProtection(RowFilter) - Method in interface org.apache.cassandra.index.Index.QueryPlan
-
Tells whether this index supports replica fitering protection or not.
- supportsReplicaFilteringProtection(RowFilter) - Method in class org.apache.cassandra.index.sasi.plan.SASIIndexQueryPlan
- supportsRounding() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Indicates if the type encoding supports rounding of the raw value.
- 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
- survivalFactors - Variable in class org.apache.cassandra.db.compaction.unified.Controller
- switchCompactionWriter(Directories.DataDirectory, DecoratedKey) - 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.
- switchCompactionWriter(Directories.DataDirectory, DecoratedKey) - Method in class org.apache.cassandra.db.compaction.writers.MajorLeveledCompactionWriter
- switchMemtable() - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
- switchMemtable(boolean, Memtable) - Method in class org.apache.cassandra.db.lifecycle.Tracker
-
Switch the current memtable.
- switchMemtable(ColumnFamilyStore.FlushReason) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- switchMemtable(Memtable) - Method in class org.apache.cassandra.index.sasi.conf.ColumnIndex
- switchMemtableIfCurrent(Memtable, ColumnFamilyStore.FlushReason) - Method in class org.apache.cassandra.db.ColumnFamilyStore
-
Switches the memtable iff the live memtable is the one provided
- switchOut(OpOrder.Barrier, AtomicReference<CommitLogPosition>) - Method in class org.apache.cassandra.db.memtable.AbstractAllocatorMemtable
- switchOut(OpOrder.Barrier, AtomicReference<CommitLogPosition>) - Method in class org.apache.cassandra.db.memtable.AbstractMemtableWithCommitlog
- switchOut(OpOrder.Barrier, AtomicReference<CommitLogPosition>) - Method in interface org.apache.cassandra.db.memtable.Memtable
-
Called to tell the memtable that it is being switched out and will be flushed (or dropped) and discarded.
- 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(SharedContext, RepairJobDesc, InetAddressAndPort, InetAddressAndPort, List<Range<Token>>, PreviewKind) - Constructor for class org.apache.cassandra.repair.SymmetricRemoteSyncTask
- sync() - Method in interface org.apache.cassandra.concurrent.SequentialExecutorPlus.AtLeastOnceTrigger
-
Wait until all queued and executing jobs have completed
- sync() - Method in class org.apache.cassandra.concurrent.SingleThreadExecutorPlus.AtLeastOnce
- sync() - Method in class org.apache.cassandra.io.util.FileOutputStreamPlus
- 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.FutureDelegate
- sync() - Method in class org.apache.cassandra.utils.concurrent.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() - Method in interface org.apache.cassandra.utils.concurrent.Future
-
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() - Method in interface org.apache.cassandra.utils.concurrent.Promise
-
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() - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
-
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(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(FileDescriptor) - Static method in class org.apache.cassandra.utils.SyncUtil
- sync(FileOutputStream) - Static method in class org.apache.cassandra.utils.SyncUtil
- sync(RepairJobDesc, SyncState.Id) - Method in class org.apache.cassandra.repair.state.ParticipateState
- sync(SyncState.Id) - Method in class org.apache.cassandra.repair.state.ParticipateState.Job
- Sync() - Constructor for class org.apache.cassandra.utils.concurrent.Condition.Sync
- Sync(int) - Constructor for class org.apache.cassandra.utils.concurrent.CountDownLatch.Sync
- Sync(int, Queue<T>) - Constructor for class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- SYNC - org.apache.cassandra.repair.state.ParticipateState.Job.State
- SYNC_REQ - org.apache.cassandra.net.Verb
- SYNC_RSP - org.apache.cassandra.net.Verb
- SyncAwaitable() - Constructor for class org.apache.cassandra.utils.concurrent.Awaitable.SyncAwaitable
- 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(boolean, List<SessionSummary>) - Method in class org.apache.cassandra.repair.SymmetricRemoteSyncTask
- syncComplete(RepairJobDesc, Message<SyncResponse>) - Method in class org.apache.cassandra.repair.RepairSession
-
Notify this session that sync completed/failed with given
SyncNodePair
. - syncDataOnlyInternal() - Method in class org.apache.cassandra.io.util.SequentialWriter
- SyncFuture<V> - Class in org.apache.cassandra.utils.concurrent
-
Netty's DefaultPromise uses a mutex to coordinate notifiers AND waiters between the eventLoop and the other threads.
- SyncFuture() - Constructor for class org.apache.cassandra.utils.concurrent.SyncFuture
- SyncFuture(GenericFutureListener<? extends Future<? super V>>) - Constructor for class org.apache.cassandra.utils.concurrent.SyncFuture
- SyncFuture(Throwable) - Constructor for class org.apache.cassandra.utils.concurrent.SyncFuture
- SyncFuture(AbstractFuture.FailureHolder) - Constructor for class org.apache.cassandra.utils.concurrent.SyncFuture
- SyncFuture(AbstractFuture.FailureHolder, GenericFutureListener<? extends Future<? super V>>) - Constructor for class org.apache.cassandra.utils.concurrent.SyncFuture
- SyncFuture(V) - Constructor for class org.apache.cassandra.utils.concurrent.SyncFuture
- SyncFutureTask<T> - Class in org.apache.cassandra.concurrent
- SyncFutureTask(Callable<T>) - Constructor for class org.apache.cassandra.concurrent.SyncFutureTask
- SyncFutureTask(WithResources, Callable<T>) - Constructor for class org.apache.cassandra.concurrent.SyncFutureTask
- SYNCHRONIZED - org.apache.cassandra.concurrent.InfiniteLoopExecutor.Interrupts
- 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
- syncPaxosRepairHistory(PaxosRepairHistory, boolean) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- SyncPromise<V> - Class in org.apache.cassandra.utils.concurrent
-
Extends
SyncFuture
to implement thePromise
interface. - SyncPromise() - Constructor for class org.apache.cassandra.utils.concurrent.SyncPromise
- SyncPromise(GenericFutureListener<? extends Future<? super V>>) - Constructor for class org.apache.cassandra.utils.concurrent.SyncPromise
- SyncPromise.WithExecutor<V> - Class in org.apache.cassandra.utils.concurrent
- 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, InetAddressAndPort, InetAddressAndPort, boolean, List<SessionSummary>) - Constructor for class org.apache.cassandra.repair.messages.SyncResponse
- SyncResponse(RepairJobDesc, SyncNodePair, 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, Collection<Range<Token>>) - Constructor for class org.apache.cassandra.repair.SyncStat
- SyncStat(SyncNodePair, Collection<Range<Token>>, List<SessionSummary>) - Constructor for class org.apache.cassandra.repair.SyncStat
- SyncState - Class in org.apache.cassandra.repair.state
- SyncState(Clock, RepairJobDesc, InetAddressAndPort, InetAddressAndPort, InetAddressAndPort) - Constructor for class org.apache.cassandra.repair.state.SyncState
- SyncState.Id - Class in org.apache.cassandra.repair.state
- SyncState.Phase - Class in org.apache.cassandra.repair.state
- SyncState.State - Enum in org.apache.cassandra.repair.state
- 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(SharedContext, RepairJobDesc, InetAddressAndPort, InetAddressAndPort, List<Range<Token>>, PreviewKind) - Constructor for class org.apache.cassandra.repair.SyncTask
- syncThrowUncheckedOnInterrupt() - Method in interface org.apache.cassandra.utils.concurrent.Future
-
waits for completion; in case of failure rethrows the original exception without a new wrapping exception so may cause problems for reporting stack traces
- syncUninterruptibly() - Method in class org.apache.cassandra.net.AsyncChannelPromise
- syncUninterruptibly() - Method in class org.apache.cassandra.net.FutureDelegate
- syncUninterruptibly() - Method in class org.apache.cassandra.utils.concurrent.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
- syncUninterruptibly() - Method in interface org.apache.cassandra.utils.concurrent.Future
-
waits for completion; in case of failure rethrows the original exception without a new wrapping exception so may cause problems for reporting stack traces
- syncUninterruptibly() - Method in interface org.apache.cassandra.utils.concurrent.Promise
-
waits for completion; in case of failure rethrows the original exception without a new wrapping exception so may cause problems for reporting stack traces
- syncUninterruptibly() - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
-
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
- SYNTAX_ERROR - org.apache.cassandra.exceptions.ExceptionCode
- syntaxError(BaseRecognizer, String) - Method in class org.apache.cassandra.cql3.ErrorCollector
-
Invoked when a syntax error with a specified message occurs.
- syntaxError(BaseRecognizer, String) - Method in interface org.apache.cassandra.cql3.ErrorListener
-
Invoked when a syntax error with a specified message occurs.
- syntaxError(BaseRecognizer, String[], RecognitionException) - Method in class org.apache.cassandra.cql3.ErrorCollector
-
Invoked when a syntax error occurs.
- syntaxError(BaseRecognizer, String[], RecognitionException) - Method in interface org.apache.cassandra.cql3.ErrorListener
-
Invoked when a syntax error occurs.
- SyntaxException - Exception in org.apache.cassandra.exceptions
- SyntaxException(String) - Constructor for exception org.apache.cassandra.exceptions.SyntaxException
- synthetic(InetAddressAndPort, Verb, T) - Static method in class org.apache.cassandra.net.Message
- system() - Static method in class org.apache.cassandra.db.Keyspace
- SYSTEM_AUTH_DEFAULT_RF - org.apache.cassandra.config.CassandraRelevantProperties
- SYSTEM_DISTRIBUTED_DEFAULT_RF - org.apache.cassandra.config.CassandraRelevantProperties
- SYSTEM_KEYSPACE_NAME - Static variable in class org.apache.cassandra.schema.SchemaConstants
- SYSTEM_TRACES_DEFAULT_RF - org.apache.cassandra.config.CassandraRelevantProperties
- 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.schema
- SystemKeyspace - Class in org.apache.cassandra.db
- SystemKeyspace.AvailableRanges - Class in org.apache.cassandra.db
- SystemKeyspace.BootstrapState - Enum in org.apache.cassandra.db
- SystemKeyspace.TriFunction<A,B,C,D> - Interface in org.apache.cassandra.db
- SystemKeyspaceMigrator41 - Class in org.apache.cassandra.db
-
Migrate 3.0 versions of some tables to 4.1.
- 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
- SystemViewsKeyspace - Class in org.apache.cassandra.db.virtual
T
- t - Variable in class org.apache.cassandra.cql3.Operation
- table - org.apache.cassandra.config.Config.FlushCompression
- table - Variable in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
-
The Column Family meta data
- 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.index.sai.metrics.AbstractMetrics
- 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() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- table() - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement.Raw
- table() - Method in class org.apache.cassandra.cql3.statements.SelectStatement
- table() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- table() - Method in class org.apache.cassandra.service.paxos.uncommitted.UncommittedTableData
- table(String, String) - Static method in class org.apache.cassandra.auth.DataResource
-
Creates a DataResource instance representing a table.
- table(String, String) - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
-
Creates a
DescribeStatement
forDESCRIBE TABLE
. - TABLE - org.apache.cassandra.cql3.SchemaElement.SchemaElementType
- TABLE - org.apache.cassandra.transport.Event.SchemaChange.Target
- TABLE_ALTERED - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- TABLE_ALTERING - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- TABLE_COUNT_THRESHOLD_TO_GUARDRAIL - org.apache.cassandra.config.Converters
- TABLE_CREATED - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- TABLE_CREATING - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- TABLE_DOES_NOT_EXIST - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- TABLE_DROPPED - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- TABLE_DROPPING - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- 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
- TABLE_NAME - Static variable in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsCountsTable
- TABLE_NAME - Static variable in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsLatenciesTable
- TABLE_NAME - Static variable in class org.apache.cassandra.db.virtual.LogMessagesTable
- TABLE_NAME - Static variable in class org.apache.cassandra.index.sai.virtual.SegmentsSystemView
- TABLE_NAMES - Static variable in class org.apache.cassandra.auth.AuthKeyspace
- TABLE_NAMES - Static variable in class org.apache.cassandra.db.SystemKeyspace
- TABLE_NAMES - Static variable in class org.apache.cassandra.schema.SystemDistributedKeyspace
- TABLE_NAMES - Static variable in class org.apache.cassandra.tracing.TraceKeyspace
- table_properties_disallowed - Variable in class org.apache.cassandra.config.Config
- table_properties_ignored - Variable in class org.apache.cassandra.config.Config
- table_properties_warned - Variable in class org.apache.cassandra.config.Config
- TABLE_QUERY_METRIC_TYPE - Static variable in class org.apache.cassandra.index.sai.metrics.TableQueryMetrics
- TABLE_STATE_METRIC_TYPE - Static variable in class org.apache.cassandra.index.sai.metrics.TableStateMetrics
- 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
- 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 - Variable in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupRequest
- 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
- TableId - Class in org.apache.cassandra.schema
-
The unique identifier of a table.
- tableIds - Variable in class org.apache.cassandra.repair.consistent.ConsistentSession
- tableIds - Variable in class org.apache.cassandra.repair.messages.PrepareMessage
- tableIds - Variable in class org.apache.cassandra.repair.state.ParticipateState
- tableIds() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker
- 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 - Variable in class org.apache.cassandra.io.sstable.format.SSTableReaderLoadingBuilder
- 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, TableMetrics.ReleasableMetric) - 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.index.sai.utils.IndexIdentifier
- tableName - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- tableNameAndIdFromFilename(String) - Static method in class org.apache.cassandra.schema.TableId
- TableParams - Class in org.apache.cassandra.schema
- TableParams.Builder - Class in org.apache.cassandra.schema
- TableParams.Option - Enum in org.apache.cassandra.schema
- TablePaxosRepairHistory - Class in org.apache.cassandra.service.paxos
- tableProperties - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail warning about, ignoring or rejecting the usage of certain table properties.
- TableQueryMetrics - Class in org.apache.cassandra.index.sai.metrics
- TableQueryMetrics(TableMetadata) - Constructor for class org.apache.cassandra.index.sai.metrics.TableQueryMetrics
- TableQueryMetrics.PerQueryMetrics - Class in org.apache.cassandra.index.sai.metrics
- TableRepairManager - Interface in org.apache.cassandra.repair
-
Table level hook for repair
- tables - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the total number of tables on user keyspaces.
- tables - Variable in class org.apache.cassandra.schema.KeyspaceMetadata.KeyspaceDiff
- tables - Variable in class org.apache.cassandra.schema.KeyspaceMetadata
- tables - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsKeyspace
- tables - Variable in class org.apache.cassandra.utils.NativeSSTableLoaderClient
- tables() - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
-
Creates a
DescribeStatement
forDESCRIBE TABLES
. - tables() - Method in class org.apache.cassandra.db.virtual.VirtualKeyspace
- Tables - Class in org.apache.cassandra.schema
-
An immutable container for a keyspace's Tables.
- TABLES - Static variable in class org.apache.cassandra.repair.consistent.LocalSessionInfo
- TABLES - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
- tables_fail_threshold - Variable in class org.apache.cassandra.config.Config
- 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.
- tables_warn_threshold - Variable in class org.apache.cassandra.config.Config
- Tables.Builder - Class in org.apache.cassandra.schema
- Tables.TablesDiff - Class in org.apache.cassandra.schema
- tablesAndViews() - Method in class org.apache.cassandra.schema.KeyspaceMetadata
- TableSnapshot - Class in org.apache.cassandra.service.snapshot
- TableSnapshot(String, String, UUID, String, Instant, Instant, Set<File>, boolean) - Constructor for class org.apache.cassandra.service.snapshot.TableSnapshot
- TableSnapshot.SnapshotTrueSizeCalculator - Class in org.apache.cassandra.service.snapshot
- TableStateMetrics - Class in org.apache.cassandra.index.sai.metrics
- TableStateMetrics(TableMetadata, StorageAttachedIndexGroup) - Constructor for class org.apache.cassandra.index.sai.metrics.TableStateMetrics
- 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.
- tablesUsingFunction(Function) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
- 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
- tail() - Method in interface org.apache.cassandra.io.tries.IncrementalTrieWriter.PartialTail
-
Buffer containing in-memory representation of the tail.
- tailMap(K) - Method in class org.apache.cassandra.index.sasi.utils.trie.PatriciaTrie
- TailOverridingRebufferer - Class in org.apache.cassandra.io.util
-
Special rebufferer that replaces the tail of the file (from the specified cutoff point) with the given buffer.
- TailOverridingRebufferer(Rebufferer, long, ByteBuffer) - Constructor for class org.apache.cassandra.io.util.TailOverridingRebufferer
- tailSet(V) - Method in class org.apache.cassandra.utils.btree.BTreeSet
- 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
- take() - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- 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
-
Deprecated.use
StorageServiceMBean.takeSnapshot(String tag, Map options, String... entities)
instead. See CASSANDRA-10907 - 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, 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
-
Deprecated.use
StorageServiceMBean.takeSnapshot(String tag, Map options, String... entities)
instead. See CASSANDRA-10907 - 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.
- 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, Map<String, String>, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Takes the snapshot of a multiple column family from different keyspaces.
- 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
-
Deprecated.use
StorageServiceMBean.takeSnapshot(String tag, Map options, String... entities)
instead. See CASSANDRA-10907 - target - Variable in class org.apache.cassandra.transport.Event.SchemaChange
- TARGET_DIRECTORY - Static variable in class org.apache.cassandra.db.compaction.CompactionInfo
- 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
- TARGET_TABLE - Static variable in class org.apache.cassandra.tools.LoaderOptions
- targetDirectory() - Method in class org.apache.cassandra.db.compaction.CompactionInfo
- 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.metrics.SamplingManager.ResultBuilder
- targets - Variable in class org.apache.cassandra.service.paxos.v1.AbstractPaxosCallback
- targetSSTableSize - Variable in class org.apache.cassandra.db.compaction.unified.Controller
- targetTable - Variable in class org.apache.cassandra.tools.LoaderOptions
- Task() - Constructor for class org.apache.cassandra.index.sai.analyzer.filter.FilterPipeline.Task
- Task(Supplier<Future<T>>) - Constructor for class org.apache.cassandra.repair.Scheduler.Task
- 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
- TaskFactory - Interface in org.apache.cassandra.concurrent
-
A simple mechanism to impose our desired semantics on the execution of a task without requiring a specialised executor service.
- TaskFactory.LocalAware - Class in org.apache.cassandra.concurrent
- TaskFactory.Standard - Class in org.apache.cassandra.concurrent
- 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
- TeeDataInputPlus - Class in org.apache.cassandra.io.util
-
DataInput that also stores the raw inputs into an output buffer This is useful for storing serialized buffers as they are deserialized.
- TeeDataInputPlus(DataInputPlus, DataOutputPlus) - Constructor for class org.apache.cassandra.io.util.TeeDataInputPlus
- TeeDataInputPlus(DataInputPlus, DataOutputPlus, long) - Constructor for class org.apache.cassandra.io.util.TeeDataInputPlus
- TemporalConversionFunction(String, AbstractType<?>, AbstractType<?>...) - Constructor for class org.apache.cassandra.cql3.functions.TimeFcts.TemporalConversionFunction
- 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
- TEMPORARY - org.apache.cassandra.db.Directories.FileType
-
A temporary sstable file that will soon be deleted.
- 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
- 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
- term - Variable in class org.apache.cassandra.index.sai.utils.IndexEntry
- Term<T extends java.nio.Buffer> - Class in org.apache.cassandra.index.sasi.sa
- Term - Class in org.apache.cassandra.index.sasi
- Term - Interface in org.apache.cassandra.cql3
-
A CQL3 term, i.e.
- Term(int, T, TokenTreeBuilder) - Constructor for class org.apache.cassandra.index.sasi.sa.Term
- Term(ByteBuffer, AbstractType<?>) - Constructor for class org.apache.cassandra.index.sasi.conf.view.RangeTermTree.Term
- Term(MappedBuffer, OnDiskIndexBuilder.TermSize, boolean) - Constructor for class org.apache.cassandra.index.sasi.Term
- TERM_OVERSIZE_MESSAGE - Static variable in class org.apache.cassandra.index.sai.StorageAttachedIndex
- TERM_SELECTOR - org.apache.cassandra.cql3.selection.Selector.Kind
- 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(EstimatedHistogram, 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
- Terminal() - Constructor for class org.apache.cassandra.cql3.Term.Terminal
- terminate(Throwable) - Method in class org.apache.cassandra.repair.RepairSession
- terminated() - Method in class org.apache.cassandra.concurrent.ScheduledThreadPoolExecutorPlus
- terminated() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBase
- TERMINATED - org.apache.cassandra.concurrent.InfiniteLoopExecutor.InternalState
- TerminateException() - Constructor for exception org.apache.cassandra.concurrent.Interruptible.TerminateException
- terminateSessions() - Method in class org.apache.cassandra.service.ActiveRepairService
- TERMINATOR - Static variable in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- TermIterator - Class in org.apache.cassandra.index.sasi.sa
- TermIterator - Class in org.apache.cassandra.index.sasi
- TermIterator() - Constructor for class org.apache.cassandra.index.sasi.sa.TermIterator
- terms - Variable in class org.apache.cassandra.index.sasi.sa.SA
- Terms - Interface in org.apache.cassandra.cql3
-
A set of
Terms
- TERMS_DATA - org.apache.cassandra.index.sai.disk.format.IndexComponent
-
Term dictionary written by
TrieTermsDictionaryWriter
stores mappings of term and file pointer to posting block on posting file. - termsData() - Method in class org.apache.cassandra.index.sai.disk.v1.PerColumnIndexFiles
- TermSelector - Class in org.apache.cassandra.cql3.selection
-
Selector representing a simple term (literals or bound variables).
- TermsIterator - Interface in org.apache.cassandra.index.sai.utils
-
An iterator over the contents of an index that extends
Iterator
<IndexEntry
> that provides the min and max terms in the index. - 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
- termType() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- test(UserFunction) - Method in enum org.apache.cassandra.schema.UserFunctions.Filter
- 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_BBFAILHELPER_ENABLED - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_BLOB_SHARED_SEED - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_BYTEMAN_TRANSFORMATIONS_DEBUG - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_CASSANDRA_KEEPBRIEFBRIEF - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_CASSANDRA_RELEVANT_PROPERTIES - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_CASSANDRA_SKIP_SYNC - org.apache.cassandra.config.CassandraRelevantProperties
-
A property for various mechanisms for syncing files that makes it possible it intercept and skip syncing.
- TEST_CASSANDRA_SUITENAME - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_CASSANDRA_TESTTAG - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_COMPRESSION - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_COMPRESSION_ALGO - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_DEBUG_REF_COUNT - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_DRIVER_CONNECTION_TIMEOUT_MS - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_DRIVER_READ_TIMEOUT_MS - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_ENCRYPTION - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_FAIL_MV_LOCKS_COUNT - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_FAIL_WRITES_KS - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_FLUSH_LOCAL_SCHEMA_CHANGES - org.apache.cassandra.config.CassandraRelevantProperties
-
Flush changes of
SchemaKeyspace
after each schema modification. - TEST_IGNORE_SIGAR - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_INVALID_LEGACY_SSTABLE_ROOT - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_JVM_DTEST_DISABLE_SSL - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_LEGACY_SSTABLE_ROOT - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_ORG_CAFFINITAS_OHC_SEGMENTCOUNT - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_RANDOM_SEED - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_READ_ITERATION_DELAY_MS - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_REUSE_PREPARED - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_ROW_CACHE_SIZE - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_SERIALIZATION_WRITES - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_SIMULATOR_DEBUG - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_SIMULATOR_DETERMINISM_CHECK - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_SIMULATOR_LIVENESS_CHECK - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_SIMULATOR_PRINT_ASM - org.apache.cassandra.config.CassandraRelevantProperties
-
properties for debugging simulator ASM output
- TEST_SIMULATOR_PRINT_ASM_CLASSES - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_SIMULATOR_PRINT_ASM_OPTS - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_SIMULATOR_PRINT_ASM_TYPES - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_SKIP_CRYPTO_PROVIDER_INSTALLATION - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_SSTABLE_FORMAT_DEVELOPMENT - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_STORAGE_COMPATIBILITY_MODE - org.apache.cassandra.config.CassandraRelevantProperties
-
StorageCompatibilityMode
mode sets how the node will behave, sstable or messaging versions to use etc. - TEST_STRICT_LCS_CHECKS - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_STRICT_RUNTIME_CHECKS - org.apache.cassandra.config.CassandraRelevantProperties
-
Turns some warnings into exceptions for testing.
- TEST_UNSAFE_VERBOSE_DEBUG_CLIENT_PROTOCOL - org.apache.cassandra.config.CassandraRelevantProperties
-
Not to be used in production, this causes a Netty logging handler to be added to the pipeline, which will throttle a system under any normal load.
- TEST_USE_PREPARED - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_UTIL_ALLOW_TOOL_REINIT_FOR_TEST - org.apache.cassandra.config.CassandraRelevantProperties
- TEST_WRITE_SURVEY - org.apache.cassandra.config.CassandraRelevantProperties
-
Activate write survey mode.
- 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 class org.apache.cassandra.cql3.ArrayLiteral
- 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.WithArrayLiteral
- 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.selection.Selectable.WithVector
- 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(String, ColumnSpecification) - Method in class org.apache.cassandra.cql3.Vectors.Literal
- testAssignment(String, ColumnSpecification) - Method in class org.apache.cassandra.db.marshal.AbstractType
- 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.
- 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.
- 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.
- testVectorAssignment(ColumnSpecification, List<? extends AssignmentTestable>) - Static method in class org.apache.cassandra.cql3.Vectors
-
Tests that the vector with the specified elements can be assigned to the specified column.
- text() - Static method in class org.apache.cassandra.cql3.functions.types.DataType
-
Returns the TEXT type.
- TEXT - org.apache.cassandra.cql3.CQL3Type.Native
- TEXT - org.apache.cassandra.cql3.functions.types.DataType.Name
- TEXT - org.apache.cassandra.transport.DataType
- thisDatacenter() - Static method in class org.apache.cassandra.dht.Datacenters
- ThreadAwareSecurityManager - Class in org.apache.cassandra.security
-
Custom
SecurityManager
andPolicy
implementation that only performs access checks if explicitly enabled. - threadGroup - Variable in class org.apache.cassandra.concurrent.NamedThreadFactory.MetaFactory
- threadGroup - Variable in class org.apache.cassandra.concurrent.NamedThreadFactory
- threadId() - Method in class org.apache.cassandra.concurrent.DebuggableTask.RunningDebuggableTask
- 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
- ThreadLocals - Class in org.apache.cassandra.utils.concurrent
- threadName - Variable in class org.apache.cassandra.diag.DiagnosticEvent
-
Name of allocating thread.
- ThreadPoolExecutorBase - Class in org.apache.cassandra.concurrent
-
This class incorporates some Executor best practices for Cassandra.
- ThreadPoolExecutorBase(int, int, TimeUnit, BlockingQueue<Runnable>, NamedThreadFactory) - Constructor for class org.apache.cassandra.concurrent.ThreadPoolExecutorBase
- ThreadPoolExecutorBase(ThreadPoolExecutorBuilder<?>) - Constructor for class org.apache.cassandra.concurrent.ThreadPoolExecutorBase
- ThreadPoolExecutorBuilder<E extends ExecutorPlus> - Class in org.apache.cassandra.concurrent
-
Configure a
ThreadPoolExecutorPlus
, applying Cassandra's best practices by default Core threads may timeout, and use a defaultThreadPoolExecutorBuilder.keepAlive
time inThreadPoolExecutorBuilder.keepAliveUnits
Threads share the sameThreadGroup
, which may be configurably a child of a specifiedThreadGroup
descended from the same parent of theNamedThreadFactory.MetaFactory
By default queues are unbounded in length The defaultRejectedExecutionHandler
is implementation dependent, but may be overridden The defaultThread.UncaughtExceptionHandler
is inherited fromNamedThreadFactory.MetaFactory
, which in turn receives it from theExecutorBuilderFactory
- ThreadPoolExecutorBuilder(Function<ThreadPoolExecutorBuilder<E>, E>, ClassLoader, ThreadGroup, Thread.UncaughtExceptionHandler, String, int) - Constructor for class org.apache.cassandra.concurrent.ThreadPoolExecutorBuilder
- ThreadPoolExecutorJMXAdapter - Class in org.apache.cassandra.concurrent
-
A
ThreadPoolExecutorBase
adapter to expose it via JMX. - ThreadPoolExecutorPlus - Class in org.apache.cassandra.concurrent
-
This class inherits Executor best practices from
ThreadPoolExecutorBase
andThreadPoolExecutorBuilder
. - ThreadPoolMetrics - Class in org.apache.cassandra.metrics
-
Metrics for
ThreadPoolExecutor
. - ThreadPoolMetrics(ResizableThreadPool, String, String) - Constructor for class org.apache.cassandra.metrics.ThreadPoolMetrics
-
Create metrics for given ThreadPoolExecutor.
- Threads - Class in org.apache.cassandra.utils.concurrent
- Threads() - Constructor for class org.apache.cassandra.utils.concurrent.Threads
- Threads.StackTraceCombiner - Class in org.apache.cassandra.utils.concurrent
- THREE - org.apache.cassandra.db.ConsistencyLevel
- Threshold - Class in org.apache.cassandra.db.guardrails
-
A guardrail based on numeric threshold(s).
- Threshold(String, String, ToLongFunction<ClientState>, ToLongFunction<ClientState>, Threshold.ErrorMessageProvider) - Constructor for class org.apache.cassandra.db.guardrails.Threshold
-
Creates a new threshold guardrail.
- thresholdFromScalingParameter(int) - Static method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- THRIFT_LIMIT - org.apache.cassandra.db.filter.DataLimits.Kind
-
Deprecated.See CASSANDRA-16582
- throttle(UnfilteredPartitionIterator, int) - Static method in class org.apache.cassandra.db.rows.ThrottledUnfilteredIterator
-
Splits a
UnfilteredPartitionIterator
inUnfilteredRowIterator
batches with size no higher than maxBatchSize - THROTTLE_MBITS - Static variable in class org.apache.cassandra.tools.LoaderOptions
-
Deprecated.See CASSANDRA-17677
- THROTTLE_MEBIBYTES - Static variable in class org.apache.cassandra.tools.LoaderOptions
- throttleBytes - 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
UnfilteredRowIterator
into smaller chunks each having at mostThrottledUnfilteredIterator.throttle
+ 1 unfiltereds. - THROW - org.apache.cassandra.db.Directories.OnTxnErr
-
Throw the exception
- THROW - org.apache.cassandra.utils.MBeanWrapper.OnException
- 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.
- throwIfCannotContinue(DecoratedKey, Throwable) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScrubber
- throwIfCannotContinue(DecoratedKey, Throwable) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableScrubber
- throwIfCannotContinue(DecoratedKey, Throwable) - Method in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- throwIfFatal(Throwable) - Static method in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- throwingResolver() - Static method in class org.apache.cassandra.db.tries.Trie
-
Returns a resolver that throws whenever more than one of the merged nodes contains content.
- tidy() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader.InstanceTidier
- tidy() - Method in class org.apache.cassandra.io.util.MmappedRegions.Tidier
- tidy() - Method in interface org.apache.cassandra.utils.concurrent.RefCounted.Tidy
- time - Variable in class org.apache.cassandra.repair.consistent.admin.RepairStats.Section
- 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 - org.apache.cassandra.cql3.CQL3Type.Native
- TIME - org.apache.cassandra.cql3.functions.types.DataType.Name
- TIME - org.apache.cassandra.transport.DataType
- timedOut - Static variable in class org.apache.cassandra.metrics.ReadRepairMetrics
- TimeFcts - Class in org.apache.cassandra.cql3.functions
- TimeFcts() - Constructor for class org.apache.cassandra.cql3.functions.TimeFcts
- TimeFcts.FloorDateFunction - Class in org.apache.cassandra.cql3.functions
-
Function that rounds a date down to the closest multiple of a duration.
- TimeFcts.FloorTimestampFunction - Class in org.apache.cassandra.cql3.functions
-
Function that rounds a timestamp down to the closest multiple of a duration.
- TimeFcts.FloorTimeUuidFunction - Class in org.apache.cassandra.cql3.functions
-
Function that rounds a timeUUID down to the closest multiple of a duration.
- TimeFcts.TemporalConversionFunction - Class in org.apache.cassandra.cql3.functions
- timeInMillisToDay(long) - Static method in class org.apache.cassandra.serializers.SimpleDateSerializer
- timeout() - Method in class org.apache.cassandra.net.RequestCallbacks.CallbackInfo
- timeout(int) - Method in class org.apache.cassandra.streaming.StreamTransferTask
-
Received ACK for stream at
sequenceNumber
. - TIMEOUT - org.apache.cassandra.exceptions.RequestFailureReason
- TIMEOUT_SECONDS - Static variable in class org.apache.cassandra.transport.SimpleClient
- 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, TimeUnit) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
- timer(CassandraMetricsRegistry.MetricName, CassandraMetricsRegistry.MetricName) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
- timer(CassandraMetricsRegistry.MetricName, CassandraMetricsRegistry.MetricName, TimeUnit) - Method in class org.apache.cassandra.metrics.CassandraMetricsRegistry
- TimeSerializer - Class in org.apache.cassandra.serializers
- TimeSerializer() - Constructor for class org.apache.cassandra.serializers.TimeSerializer
- timeSpentInQueueNanos() - Method in class org.apache.cassandra.transport.Dispatcher.RequestTime
- timestamp - Variable in class org.apache.cassandra.cql3.Attributes.Raw
- timestamp - Variable in class org.apache.cassandra.db.LivenessInfo
- timestamp - Variable in class org.apache.cassandra.db.virtual.LogMessagesTable.LogMessage
- timestamp - Variable in class org.apache.cassandra.diag.DiagnosticEvent
-
Event creation time.
- timestamp - Variable in class org.apache.cassandra.index.internal.IndexEntry
- 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() - Method in class org.apache.cassandra.db.LivenessInfo
-
The timestamp for this liveness info.
- 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 class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.Raw
- 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(long) - Method in interface org.apache.cassandra.db.rows.Row.SimpleBuilder
-
Sets the timestamp to use for the following additions.
- TIMESTAMP - org.apache.cassandra.cql3.CQL3Type.Native
- TIMESTAMP - org.apache.cassandra.cql3.functions.types.DataType.Name
- TIMESTAMP - org.apache.cassandra.transport.DataType
- TIMESTAMP_COLUMN_NAME - Static variable in class org.apache.cassandra.db.virtual.LogMessagesTable
- TIMESTAMP_EPOCH - Static variable in class org.apache.cassandra.db.rows.EncodingStats
- TIMESTAMP_RESOLUTION_KEY - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
- TIMESTAMP_UUID_VERSION_IN_MSB - Static variable in class org.apache.cassandra.utils.TimeUUID
- timestampMicros() - Static method in class org.apache.cassandra.utils.FBUtilities
- timestampResolution - Variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
- timestampsClash(Ballot, Ballot) - Static method in class org.apache.cassandra.service.paxos.Commit
- timestampsClash(Commit, Ballot) - Static method in class org.apache.cassandra.service.paxos.Commit
-
unequal ballots with same timestamp
- 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
. - TimeUUID - Class in org.apache.cassandra.utils
- TimeUUID(long, long) - Constructor for class org.apache.cassandra.utils.TimeUUID
- TIMEUUID - org.apache.cassandra.cql3.CQL3Type.Native
- TIMEUUID - org.apache.cassandra.cql3.functions.types.DataType.Name
- TIMEUUID - org.apache.cassandra.transport.DataType
- TIMEUUID_SIZE - Static variable in class org.apache.cassandra.utils.TimeUUID
- TimeUUID.AbstractSerializer<T extends TimeUUID> - Class in org.apache.cassandra.utils
- TimeUUID.Generator - Class in org.apache.cassandra.utils
- TimeUUID.Serializer - Class in org.apache.cassandra.utils
- TimeUUIDType - Class in org.apache.cassandra.db.marshal
- TimeUUIDType() - Constructor for class org.apache.cassandra.db.marshal.TimeUUIDType
- TimeWindowCompactionController - Class in org.apache.cassandra.db.compaction
- TimeWindowCompactionController(ColumnFamilyStore, Set<SSTableReader>, long, 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() - Constructor for class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
- TimeWindowCompactionStrategyOptions(Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
- TimeWindowCompactionTask - Class in org.apache.cassandra.db.compaction
- TimeWindowCompactionTask(ColumnFamilyStore, LifecycleTransaction, long, 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
. - TINYINT - org.apache.cassandra.cql3.CQL3Type.Native
- TINYINT - org.apache.cassandra.cql3.functions.types.DataType.Name
- TinyPool() - Constructor for class org.apache.cassandra.utils.caching.TinyThreadLocalPool.TinyPool
- TinyThreadLocalPool<V> - Class in org.apache.cassandra.utils.caching
- TinyThreadLocalPool() - Constructor for class org.apache.cassandra.utils.caching.TinyThreadLocalPool
- TinyThreadLocalPool.TinyPool<V> - Class in org.apache.cassandra.utils.caching
- TLS_PROTOCOL_SUBSTITUTION - Static variable in class org.apache.cassandra.security.AbstractSslContextFactory
- tlsEncryptionPolicy - Variable in class org.apache.cassandra.transport.Server
- tlsEncryptionPolicy() - Method in class org.apache.cassandra.config.EncryptionOptions
- 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
- tmpFileFor(Component) - Method in class org.apache.cassandra.io.sstable.Descriptor
- tmpFileForStreaming(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
- to() - Method in interface org.apache.cassandra.db.memtable.Memtable.FlushablePartitionSet
- to(TimeUnit) - Method in class org.apache.cassandra.config.DurationSpec
- toAbsolute() - Method in class org.apache.cassandra.io.util.File
- toAbstractType() - Method in class org.apache.cassandra.cql3.functions.UDFDataType
-
Converts this type into the corresponding Cassandra type.
- toArray() - Method in class org.apache.cassandra.utils.btree.BTreeSet
- toArray() - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- toArray() - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
- 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(Object[], int, int, Object[], int) - Static method in class org.apache.cassandra.utils.btree.BTree
- 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(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- toArray(ByteBuffer, int, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- toArray(T[]) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
- toArray(T[]) - Method in class org.apache.cassandra.utils.btree.BTreeSet
- toArray(T[], int) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeDescRange
- toArray(T[], int) - Method in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
- toArray(T[], int) - Method in class org.apache.cassandra.utils.btree.BTreeSet
- toArray(T1[]) - Method in class org.apache.cassandra.utils.concurrent.BlockingQueues.Sync
- toArray(T1[]) - Method in class org.apache.cassandra.utils.concurrent.WeightedQueue
- toArray(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
returns a byte[] with the contents of {@param value} 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 {@param length} bytes copied from the contents of {@param value} starting at offset {@param offset}.
- toArrayCopy() - Method in class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- toBallot(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- toBallot(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- toBallot(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
returns a TimeUUID from offset 0
- toBigDecimal(Number) - Method in class org.apache.cassandra.db.marshal.DecimalType
-
Converts the specified number into a
BigDecimal
. - ToBlobFunction(CQL3Type) - Constructor for class org.apache.cassandra.cql3.functions.BytesConversionFcts.ToBlobFunction
- 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 {@param value} 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
- toBufferType() - Method in enum org.apache.cassandra.config.Config.MemtableAllocationType
- toByte(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- toByte(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- toByte(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Convert a byte buffer to a short.
- toByte(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
returns a byte from offset 0
- toByteArray() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
- toByteArray(Token) - Method in class org.apache.cassandra.dht.Token.TokenFactory
- toByteBuffer(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
- toByteComparable() - Method in class org.apache.cassandra.io.tries.Walker.TransitionBytesCollector
- toBytes() - Method in class org.apache.cassandra.config.DataStorageSpec.IntBytesBound
-
Returns the amount of data storage in bytes as an
int
- toBytes() - Method in class org.apache.cassandra.config.DataStorageSpec.IntKibibytesBound
-
Returns the amount of data storage in bytes as an
int
- toBytes() - Method in class org.apache.cassandra.config.DataStorageSpec.IntMebibytesBound
-
Returns the amount of data storage in bytes as an
int
- toBytes() - Method in class org.apache.cassandra.config.DataStorageSpec.LongBytesBound
- toBytes() - Method in class org.apache.cassandra.config.DataStorageSpec.LongMebibytesBound
- toBytes() - Method in class org.apache.cassandra.gms.VersionedValue
- toBytes() - Method in class org.apache.cassandra.utils.TimeUUID
- toBytes(long) - Method in enum org.apache.cassandra.config.DataStorageSpec.DataStorageUnit
- toBytes(long, long) - Static method in class org.apache.cassandra.utils.TimeUUID
- toBytes(PartitionUpdate, int) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
-
Serialize a partition update as a byte buffer.
- toBytesInLong() - Method in class org.apache.cassandra.config.DataStorageSpec.IntKibibytesBound
- toBytesInLong() - Method in class org.apache.cassandra.config.DataStorageSpec.IntMebibytesBound
-
Returns the amount of data storage in bytes as
long
- toBytesPerSecond() - Method in class org.apache.cassandra.config.DataRateSpec
- toBytesPerSecond(double) - Method in enum org.apache.cassandra.config.DataRateSpec.DataRateUnit
- toBytesPerSecondAsInt() - Method in class org.apache.cassandra.config.DataRateSpec
-
Returns the data rate in bytes per second as an
int
- toByteString(long) - Static method in class org.apache.cassandra.tools.SSTableMetadataViewer
- TOC - Static variable in class org.apache.cassandra.io.sstable.format.SSTableFormat.Components
- TOC - Static variable in class org.apache.cassandra.io.sstable.format.SSTableFormat.Components.Types
- toCanonical() - Method in class org.apache.cassandra.io.util.File
- toCanonicalPath(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
-
1) Convert to an absolute path without redundant path elements; 2) If the file exists, resolve any links to the underlying fille; 3) If the file does not exist, find the first ancestor that does and resolve the path from there
- TOCComponent - Class in org.apache.cassandra.io.sstable.format
- TOCComponent() - Constructor for class org.apache.cassandra.io.sstable.format.TOCComponent
- toComparableBytes(ByteBuffer, byte[]) - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Fills a byte array with the comparable bytes for a type.
- 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(AuditLogOptions) - Static method in class org.apache.cassandra.audit.AuditLogOptionsCompositeData
- toCompositeData(FullQueryLoggerOptions) - Static method in class org.apache.cassandra.fql.FullQueryLoggerOptionsCompositeData
- toCompositeData(StreamEvent.SessionCompleteEvent) - Static method in class org.apache.cassandra.streaming.management.SessionCompleteEventCompositeData
- toCompositeData(StreamState) - Static method in class org.apache.cassandra.streaming.management.StreamStateCompositeData
- toCompositeData(StreamSummary) - Static method in class org.apache.cassandra.streaming.management.StreamSummaryCompositeData
- toCompositeData(TimeUUID, ProgressInfo) - Static method in class org.apache.cassandra.streaming.management.ProgressInfoCompositeData
- toCompositeData(TimeUUID, SessionInfo) - Static method in class org.apache.cassandra.streaming.management.SessionInfoCompositeData
- toCQLLiteral(ByteBuffer) - Method in class org.apache.cassandra.cql3.CQL3Type.Collection
- toCQLLiteral(ByteBuffer) - Method in class org.apache.cassandra.cql3.CQL3Type.Custom
- toCQLLiteral(ByteBuffer) - 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 defaultTypeSerializer.toString(Object)
TypeSerializer.deserialize(ByteBuffer)
implementations. - toCQLLiteral(ByteBuffer) - Method in interface org.apache.cassandra.cql3.CQL3Type
-
Generates CQL literal from a binary value of this type.
- toCQLLiteral(ByteBuffer) - Method in class org.apache.cassandra.cql3.CQL3Type.Tuple
- toCQLLiteral(ByteBuffer) - Method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
- toCQLLiteral(ByteBuffer) - Method in class org.apache.cassandra.cql3.CQL3Type.Vector
- toCQLLiteral(ByteBuffer) - Method in class org.apache.cassandra.serializers.TypeSerializer
- toCQLLiteralNonNull(ByteBuffer) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
- toCQLLiteralNonNull(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
- toCQLLiteralNonNull(ByteBuffer) - Method in class org.apache.cassandra.serializers.TimestampSerializer
- toCQLLiteralNonNull(ByteBuffer) - Method in class org.apache.cassandra.serializers.TypeSerializer
- toCQLLiteralNoQuote(ByteBuffer) - Method in class org.apache.cassandra.serializers.TypeSerializer
- 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(boolean, boolean) - Method in interface org.apache.cassandra.cql3.SchemaElement
-
Returns a CQL representation of this element
- toCqlString(boolean, boolean) - Method in class org.apache.cassandra.db.marshal.UserType
- 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) - Method in class org.apache.cassandra.schema.ViewMetadata
- toCqlString(boolean, boolean, boolean) - Method in class org.apache.cassandra.schema.TableMetadata
- toCqlString(AbstractType<?>) - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
-
Converts the specified type into its CQL representation.
- toCqlString(TableMetadata, boolean) - Method in class org.apache.cassandra.schema.IndexMetadata
- 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() - 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() - 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() - 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() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
-
Returns a CQL representation of this expression.
- toCQLString() - Method in class org.apache.cassandra.db.filter.RowFilter
-
Returns a CQL representation of this row filter.
- toCQLString(Iterable<ColumnMetadata>) - Static method in class org.apache.cassandra.schema.ColumnMetadata
- toCQLString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
- toCQLString(Iterator<ColumnMetadata>) - Static method in class org.apache.cassandra.schema.ColumnMetadata
- toCQLString(TableMetadata) - Method in interface org.apache.cassandra.db.Clustering
- toCQLString(TableMetadata) - Method in class org.apache.cassandra.db.DecoratedKey
-
Returns a CQL representation of this key.
- toCQLString(TableMetadata, RowFilter) - Method in class org.apache.cassandra.db.DataRange
- toCQLString(TableMetadata, RowFilter) - Method in interface org.apache.cassandra.db.filter.ClusteringIndexFilter
- toCQLString(TableMetadata, RowFilter) - Method in class org.apache.cassandra.db.filter.ClusteringIndexNamesFilter
- toCQLString(TableMetadata, RowFilter) - Method in class org.apache.cassandra.db.filter.ClusteringIndexSliceFilter
- toCQLString(TableMetadata, RowFilter) - Method in class org.apache.cassandra.db.Slices
- toCqlType(AbstractType<?>) - Static method in class org.apache.cassandra.db.SchemaCQLHelper
-
Converts the type to a CQL type.
- toDataType() - Method in class org.apache.cassandra.cql3.functions.UDFDataType
-
Converts this type into the corresponding Java driver type.
- toDate(TemporalType<?>) - Static method in class org.apache.cassandra.cql3.functions.TimeFcts
-
Creates a function that converts a value of the specified type into a
DATE
. - toDateString(long, TimeUnit) - Static method in class org.apache.cassandra.tools.SSTableMetadataViewer
- toDebugString() - Method in class org.apache.cassandra.schema.TableMetadata
- 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.
- toDouble(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- toDouble(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- toDouble(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- toDouble(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
returns a double from offset 0
- 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
- toExecute(Runnable) - Method in class org.apache.cassandra.concurrent.TaskFactory.LocalAware
- toExecute(Runnable) - Method in class org.apache.cassandra.concurrent.TaskFactory.Standard
- toExecute(Runnable) - Method in interface org.apache.cassandra.concurrent.TaskFactory
- toExecute(WithResources, Runnable) - Method in class org.apache.cassandra.concurrent.TaskFactory.LocalAware
- toExecute(WithResources, Runnable) - Method in class org.apache.cassandra.concurrent.TaskFactory.Standard
- toExecute(WithResources, Runnable) - Method in interface org.apache.cassandra.concurrent.TaskFactory
- 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) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- toFloat(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
returns a float from offset 0
- toFloatArray(byte[], int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- toFloatArray(ByteBuffer, int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- toFloatArray(V, int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
returns a float[] from offset 0
- toFormatAndVersionString() - Method in class org.apache.cassandra.io.sstable.format.Version
- toGibibytes(long) - Method in enum org.apache.cassandra.config.DataStorageSpec.DataStorageUnit
- 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() - Method in class org.apache.cassandra.schema.TableId
- toHexString(byte[]) - Static method in class org.apache.cassandra.cql3.functions.types.utils.Bytes
-
Converts a blob to its CQL hex string representation.
- toHexString(ByteBuffer) - Static method in class org.apache.cassandra.cql3.functions.types.utils.Bytes
-
Converts a blob to its CQL hex string representation.
- 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
- toImmutableMap() - Static method in class org.apache.cassandra.utils.Collectors3
- toImmutableMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - 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(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- toInt(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- toInt(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Convert a byte buffer to an integer.
- toInt(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
returns an int from offset 0
- toJavaClass() - Method in class org.apache.cassandra.cql3.functions.UDFDataType
-
Converts this type into the corresponding Java class.
- toJavaIOFile() - Method in class org.apache.cassandra.io.util.File
- 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(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.DynamicCompositeType.FixedValueComparator
- 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
- toJSONString(ByteBuffer, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.VectorType
- toJSONString(V, ValueAccessor<V>, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.AbstractType
- toJSONString(V, ValueAccessor<V>, ProtocolVersion) - Method in class org.apache.cassandra.db.marshal.VectorType
- token - Variable in class org.apache.cassandra.dht.Murmur3Partitioner.LongToken
- token - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Leaf.LeafEntry
- token - Variable in class org.apache.cassandra.index.sasi.disk.Token
- token - Variable in class org.apache.cassandra.tools.nodetool.HostStat
- token - Variable in class org.apache.cassandra.utils.MerkleTree.RowHash
- token() - Method in interface org.apache.cassandra.index.sai.utils.PrimaryKey
-
Returns the
Token
component of thePrimaryKey
- 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 - Class in org.apache.cassandra.dht
- Token - Class in org.apache.cassandra.index.sasi.disk
- Token() - Constructor for class org.apache.cassandra.dht.Token
- Token(long) - Constructor for class org.apache.cassandra.index.sasi.disk.Token
- TOKEN - org.apache.cassandra.index.sai.utils.PrimaryKey.Kind
- 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
- tokenCollisionDetection(PrimaryKey, long) - Method in class org.apache.cassandra.index.sai.disk.v1.SkinnyPrimaryKeyMap
- tokenCount - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder
- tokenCount - Variable in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
- tokenCount() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
- tokenCount() - Method in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.Node
- 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 - Variable in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
-
Given a keyspace, return the set of local and pending token ranges.
- tokenLookup - Variable in class org.apache.cassandra.io.sstable.IVerifier.Options
- tokenLookup(Function<String, ? extends Collection<Range<Token>>>) - Method in class org.apache.cassandra.io.sstable.IVerifier.Options.Builder
- 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 - Variable in class org.apache.cassandra.index.sasi.disk.AbstractTokenTreeBuilder.InteriorNode
- tokens - Variable in class org.apache.cassandra.index.sasi.sa.Term
- tokens() - Method in class org.apache.cassandra.dht.tokenallocator.OfflineTokenAllocator.FakeNode
- tokens(Collection<Token>) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
- TOKENS - org.apache.cassandra.gms.ApplicationState
- 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 - Class in org.apache.cassandra.gms
- TokenSerializer() - Constructor for class org.apache.cassandra.dht.Token.TokenSerializer
- 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
- tokenSpaceCoverage - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- tokenSpaceCoverage - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
- tokenSpaceCoverage() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- tokenSpaceCoverage(double) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- TokenTree - Class in org.apache.cassandra.index.sasi.disk
- TokenTree(Descriptor, MappedBuffer) - Constructor for class org.apache.cassandra.index.sasi.disk.TokenTree
- TokenTree(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
- toKibibytes() - Method in class org.apache.cassandra.config.DataStorageSpec.IntKibibytesBound
-
Returns the amount of data storage in kibibytes as an
int
- toKibibytes() - Method in class org.apache.cassandra.config.DataStorageSpec.IntMebibytesBound
-
Returns the amount of data storage in kibibytes as an
int
- toKibibytes() - Method in class org.apache.cassandra.config.DataStorageSpec.LongMebibytesBound
- toKibibytes(long) - Method in enum org.apache.cassandra.config.DataStorageSpec.DataStorageUnit
- toKibibytesPerSecond() - Method in class org.apache.cassandra.config.DataRateSpec
- toKibibytesPerSecond(double) - Method in enum org.apache.cassandra.config.DataRateSpec.DataRateUnit
- toKibibytesPerSecondAsInt() - Method in class org.apache.cassandra.config.DataRateSpec
-
Returns the data rate in kibibytes per second as an
int
- TOLERATE_SSTABLE_SIZE - org.apache.cassandra.config.CassandraRelevantProperties
- toleratesErrorsInSection - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegmentReader.SyncSegment
- toLong(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- toLong(int) - Static method in class org.apache.cassandra.utils.CassandraUInt
-
Returns the long resulting from parsing the int as an unsigned integer
- toLong(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- toLong(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- toLong(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
returns a long from offset 0
- toMajorMinorString() - Method in class org.apache.cassandra.utils.CassandraVersion
- 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
- toMap(TableMetadata) - Method in class org.apache.cassandra.metrics.TopPartitionTracker.TopHolder
- tombstone(ColumnMetadata, long, long) - Static method in class org.apache.cassandra.db.rows.BufferCell
- tombstone(ColumnMetadata, long, long, CellPath) - Static method in class org.apache.cassandra.db.rows.BufferCell
- TOMBSTONE_COMPACTION - org.apache.cassandra.db.compaction.OperationType
- TOMBSTONE_COMPACTION_INTERVAL_OPTION - Static variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
- TOMBSTONE_FAIL - org.apache.cassandra.net.ParamType
- 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
- TOMBSTONE_WARNING - org.apache.cassandra.net.ParamType
- TombstoneAbortException - Exception in org.apache.cassandra.exceptions
- TombstoneAbortException(String, int, long, boolean, ConsistencyLevel, int, int, Map<InetAddressAndPort, RequestFailureReason>) - Constructor for exception org.apache.cassandra.exceptions.TombstoneAbortException
- tombstoneAbortMessage(int, long, String) - Static method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- tombstoneAborts - Variable in class org.apache.cassandra.metrics.ClientRequestMetrics
- tombstoneCompactionInterval - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
- TombstoneCounter(TopPartitionTracker.Collector, long) - Constructor for class org.apache.cassandra.metrics.TopPartitionTracker.TombstoneCounter
- 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
- TombstoneHistogram.LegacyHistogramSerializer - 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
- tombstones - Variable in exception org.apache.cassandra.exceptions.TombstoneAbortException
- tombstones - Variable in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- tombstonesAbort(ImmutableSet<InetAddressAndPort>, long) - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Builder
- tombstonesAbort(WarningsSnapshot.Counter) - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Builder
- 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
- tombstonesWarning(ImmutableSet<InetAddressAndPort>, long) - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Builder
- tombstonesWarning(WarningsSnapshot.Counter) - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Builder
- tombstoneThreshold - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
- tombstoneWarnings - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Number of tombstone read warnings
- tombstoneWarnMessage(int, long, String) - Static method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- toMebibytes() - Method in class org.apache.cassandra.config.DataStorageSpec.IntMebibytesBound
-
Returns the amount of data storage in mebibytes as an
int
- toMebibytes() - Method in class org.apache.cassandra.config.DataStorageSpec.LongMebibytesBound
- toMebibytes(long) - Method in enum org.apache.cassandra.config.DataStorageSpec.DataStorageUnit
- toMebibytesInt() - Method in class org.apache.cassandra.config.DataStorageSpec.LongBytesBound
- toMebibytesPerSecond() - Method in class org.apache.cassandra.config.DataRateSpec
- toMebibytesPerSecond(double) - Method in enum org.apache.cassandra.config.DataRateSpec.DataRateUnit
- toMebibytesPerSecondAsInt() - Method in class org.apache.cassandra.config.DataRateSpec
-
Returns the data rate in mebibytes per second as an
int
- toMegabitsPerSecond() - Method in class org.apache.cassandra.config.DataRateSpec
-
This method is required in order to support backward compatibility with the old unit used for a few Data Rate parameters before CASSANDRA-15234
- toMegabitsPerSecond(double) - Method in enum org.apache.cassandra.config.DataRateSpec.DataRateUnit
- toMegabitsPerSecondAsInt() - Method in class org.apache.cassandra.config.DataRateSpec
-
Returns the data rate in megabits per second as an
int
. - toMicroseconds() - Method in class org.apache.cassandra.config.DurationSpec.LongMicrosecondsBound
- toMilliseconds() - Method in class org.apache.cassandra.config.DurationSpec.IntMillisecondsBound
-
Returns this duration in number of milliseconds as an
int
- toMilliseconds() - Method in class org.apache.cassandra.config.DurationSpec.IntMinutesBound
-
Returns this duration in number of milliseconds as an
int
- toMilliseconds() - Method in class org.apache.cassandra.config.DurationSpec.IntSecondsBound
-
Returns this duration in number of milliseconds as an
int
- toMilliseconds() - Method in class org.apache.cassandra.config.DurationSpec.LongMillisecondsBound
- toMilliseconds() - Method in class org.apache.cassandra.config.DurationSpec.LongSecondsBound
- toMillisSinceEpoch(long) - Method in class org.apache.cassandra.utils.MonotonicClock.AbstractEpochSamplingClock.AlmostSameTime
- toMillisSinceEpoch(long) - Method in interface org.apache.cassandra.utils.MonotonicClockTranslation
-
accepts nanoTime in the related MonotinicClock, returns millis since epoch
- toMinutes() - Method in class org.apache.cassandra.config.DurationSpec.IntMinutesBound
-
Returns this duration in number of minutes as an
int
- toMutations(ClientState) - Method in interface org.apache.cassandra.cql3.statements.UpdatesCollector
- toNanoseconds() - Method in class org.apache.cassandra.config.DurationSpec.IntSecondsBound
-
Returns this duration in the number of nanoseconds as an
int
- toNanoseconds() - Method in class org.apache.cassandra.config.DurationSpec.LongNanosecondsBound
- TOO_MANY_REFERENCED_INDEXES_FAIL - org.apache.cassandra.net.ParamType
- TOO_MANY_REFERENCED_INDEXES_WARN - org.apache.cassandra.net.ParamType
- TOOK_PERMIT - org.apache.cassandra.concurrent.SEPExecutor.TakeTaskPermitResult
- TOOL_NAME - Static variable in class org.apache.cassandra.tools.LoaderOptions
- toolInitialization() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
-
Equivalent to
toolInitialization(true)
. - 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. - tooManyIndexesReadAbortMessage(int, long, String) - Static method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- tooManyIndexesReadWarnMessage(int, long, String) - Static method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- tooManySSTableIndexesReadAborts - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
- tooManySSTableIndexesReadAborts - Variable in class org.apache.cassandra.metrics.TableMetrics
- tooManySSTableIndexesReadWarnings - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
- tooManySSTableIndexesReadWarnings - Variable in class org.apache.cassandra.metrics.TableMetrics
- top - Variable in class org.apache.cassandra.metrics.TopPartitionTracker.TopHolder
- top - Variable in class org.apache.cassandra.tools.nodetool.stats.TableStatsHolder
- 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_PARTITIONS - Static variable in class org.apache.cassandra.db.SystemKeyspace
- top_partitions_enabled - Variable in class org.apache.cassandra.config.Config
- toParseableString() - Method in class org.apache.cassandra.locator.ReplicationFactor
- toPath() - Method in class org.apache.cassandra.io.util.File
- topCasPartitionContention - Variable in class org.apache.cassandra.metrics.TableMetrics
-
When sampler activated, will track the most frequent partitions with cas contention
- TOPK_AGGREGATION_ERROR - Static variable in class org.apache.cassandra.cql3.statements.SelectStatement
- TOPK_CONSISTENCY_LEVEL_ERROR - Static variable in class org.apache.cassandra.cql3.statements.SelectStatement
- TOPK_CONSISTENCY_LEVEL_WARNING - Static variable in class org.apache.cassandra.cql3.statements.SelectStatement
- TOPK_LIMIT_ERROR - Static variable in class org.apache.cassandra.cql3.statements.SelectStatement
- TOPK_PAGE_SIZE_WARNING - Static variable in class org.apache.cassandra.cql3.statements.SelectStatement
- TOPK_PARTITION_LIMIT_ERROR - Static variable in class org.apache.cassandra.cql3.statements.SelectStatement
- topKFor(int) - Method in enum org.apache.cassandra.index.sai.disk.v1.vector.OptimizeFor
- topLocalReadQueryTime - Variable in class org.apache.cassandra.metrics.TableMetrics
-
When sampler activated, will track the slowest local reads
- TOPOLOGY_CHANGE - org.apache.cassandra.transport.Event.Type
- TopPartition(DecoratedKey, long) - Constructor for class org.apache.cassandra.metrics.TopPartitionTracker.TopPartition
- topPartitionCollector - Variable in class org.apache.cassandra.repair.Validator
- topPartitions - Variable in class org.apache.cassandra.db.ColumnFamilyStore
- topPartitions - Variable in class org.apache.cassandra.metrics.TopPartitionTracker.StoredTopPartitions
- TopPartitions - Class in org.apache.cassandra.tools.nodetool
-
Deprecated.
- TopPartitions() - Constructor for class org.apache.cassandra.tools.nodetool.TopPartitions
-
Deprecated.
- topPartitionsEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- topPartitionsEnabled() - Method in class org.apache.cassandra.service.StorageService
- topPartitionsEnabled() - Method in interface org.apache.cassandra.service.StorageServiceMBean
- TopPartitionTracker - Class in org.apache.cassandra.metrics
-
Tracks top partitions, currently by size and by tombstone count Collects during full and preview (-vd) repair since then we read the full partition Note that since we can run sub range repair there might be windows where the top partitions are not correct - for example, assume we track the top 2 partitions for this node: tokens with size: (a, 100); (b, 40); (c, 10); (d, 100); (e, 50); (f, 10) - top2: a, d now a is deleted and we run a repair for keys [a, c] - top2: b, d and when we repair [d, f] - top2: d, e
- TopPartitionTracker(TableMetadata) - Constructor for class org.apache.cassandra.metrics.TopPartitionTracker
- TopPartitionTracker.Collector - Class in org.apache.cassandra.metrics
- TopPartitionTracker.StoredTopPartitions - Class in org.apache.cassandra.metrics
- TopPartitionTracker.TombstoneCounter - Class in org.apache.cassandra.metrics
- TopPartitionTracker.TopHolder - Class in org.apache.cassandra.metrics
- TopPartitionTracker.TopPartition - Class in org.apache.cassandra.metrics
- topReadPartitionFrequency - Variable in class org.apache.cassandra.metrics.TableMetrics
-
When sampler activated, will track the most frequently read partitions
- topReadPartitionRowCount - Variable in class org.apache.cassandra.metrics.TableMetrics
-
When sampler activated, will track partitions read with the most rows
- topReadPartitionSSTableCount - Variable in class org.apache.cassandra.metrics.TableMetrics
-
When sample activated, will track partitions read with the most merged sstables
- topReadPartitionTombstoneCount - Variable in class org.apache.cassandra.metrics.TableMetrics
-
When sampler activated, will track partitions read with the most tombstones
- toProperty(Property) - Method in class org.apache.cassandra.config.Replacement
- topSizePartitions - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- topSizePartitionsLastUpdate - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- topSizes() - Method in class org.apache.cassandra.metrics.TopPartitionTracker
- topTombstonePartitions - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- topTombstonePartitionsLastUpdate - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- topTombstones() - Method in class org.apache.cassandra.metrics.TopPartitionTracker
- 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() - Method in class org.apache.cassandra.cql3.Ordering.Ann
- toRestriction() - Method in class org.apache.cassandra.cql3.Ordering.Expression
- toRestriction(TableMetadata, VariableSpecifications) - Method in class org.apache.cassandra.cql3.Relation
-
Converts this
Relation
into aRestriction
. - 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
- toSeconds() - Method in class org.apache.cassandra.config.DurationSpec.IntMinutesBound
-
Returns this duration in number of seconds as an
int
- toSeconds() - Method in class org.apache.cassandra.config.DurationSpec.IntSecondsBound
-
Returns this duration in number of seconds as an
int
- toSeconds() - Method in class org.apache.cassandra.config.DurationSpec.LongMicrosecondsBound
- toSeconds() - Method in class org.apache.cassandra.config.DurationSpec.LongSecondsBound
- toSegmentRowId(long) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata
- toSelectables(List<RawSelector>, TableMetadata) - Static method in class org.apache.cassandra.cql3.selection.RawSelector
-
Converts the specified list of
RawSelector
s into a list ofSelectable
s. - toShort(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- toShort(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- toShort(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
-
Convert a byte buffer to a short.
- toShort(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
returns a short from offset 0
- toSilentException(ProtocolException) - Static method in exception org.apache.cassandra.transport.ProtocolException
- toSlices(ClusteringComparator, SortedSet<ClusteringBound<?>>, SortedSet<ClusteringBound<?>>) - Static method in class org.apache.cassandra.cql3.statements.ModificationStatement
- toSlices(TableMetadata, SortedSet<ClusteringBound<?>>, SortedSet<ClusteringBound<?>>) - Static method in class org.apache.cassandra.cql3.statements.ModificationStatement
- toStatic() - Method in interface org.apache.cassandra.index.sai.utils.PrimaryKey
- 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() - 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.concurrent.NamedThreadFactory
- toString() - Method in class org.apache.cassandra.concurrent.SingleThreadExecutorPlus.AtLeastOnce
- toString() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBase
- toString() - Method in class org.apache.cassandra.config.DataRateSpec
- toString() - Method in class org.apache.cassandra.config.DataStorageSpec
- toString() - Method in class org.apache.cassandra.config.DurationSpec
- toString() - Method in class org.apache.cassandra.config.InheritingClass
- toString() - Method in class org.apache.cassandra.config.ParameterizedClass
- toString() - Method in class org.apache.cassandra.config.RetrySpec.MaxAttempt
- toString() - Method in class org.apache.cassandra.config.RetrySpec
- toString() - Method in class org.apache.cassandra.config.SubnetGroups
- 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.CIDR
-
Constructs CIDR as string
- 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() - Method in class org.apache.cassandra.cql3.CQL3Type.UserDefined
- toString() - Method in class org.apache.cassandra.cql3.CQL3Type.Vector
- 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.FunctionFactory
- toString() - Method in class org.apache.cassandra.cql3.functions.FunctionName
- toString() - Method in class org.apache.cassandra.cql3.functions.masking.ColumnMask.Raw
- toString() - Method in class org.apache.cassandra.cql3.functions.masking.ColumnMask
- 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() - Method in class org.apache.cassandra.cql3.functions.types.VectorType
- 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.AnnRestriction
- 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.WithArrayLiteral
- 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.WithTypeHint
- toString() - Method in class org.apache.cassandra.cql3.selection.Selectable.WithVector
- 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.selection.VectorSelector
- 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() - Method in class org.apache.cassandra.db.ClusteringComparator
- toString() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- 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.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.unified.Controller
- toString() - Method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy.Level
- toString() - Method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- toString() - Method in class org.apache.cassandra.db.CounterMutation
- toString() - Method in class org.apache.cassandra.db.DecoratedKey
- toString() - Method in class org.apache.cassandra.db.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() - 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.ColumnSubselection
- toString() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
- toString() - Method in class org.apache.cassandra.db.filter.RowFilter
- 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() - Method in class org.apache.cassandra.db.marshal.AbstractType
-
This must be overriden by subclasses if necessary so that for any AbstractType, this == TypeParser.parse(toString()).
- toString() - Method in enum org.apache.cassandra.db.marshal.CollectionType.Kind
- 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() - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
- toString() - Method in class org.apache.cassandra.db.marshal.ReversedType
- toString() - Method in class org.apache.cassandra.db.marshal.TupleType
- toString() - Method in class org.apache.cassandra.db.marshal.TypeParser
- toString() - Method in class org.apache.cassandra.db.marshal.UserType
- toString() - Method in class org.apache.cassandra.db.marshal.VectorType
- toString() - Method in class org.apache.cassandra.db.memtable.AbstractAllocatorMemtable
- toString() - Method in class org.apache.cassandra.db.memtable.Flushing.FlushRunnable
- toString() - Method in class org.apache.cassandra.db.memtable.Memtable.MemoryUsage
- toString() - Method in class org.apache.cassandra.db.memtable.ShardBoundaries
- toString() - Method in class org.apache.cassandra.db.MutableDeletionInfo
- toString() - 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() - Method in class org.apache.cassandra.db.RegularAndStaticColumns
- toString() - Method in class org.apache.cassandra.db.rows.AbstractCell
- toString() - Method in class org.apache.cassandra.db.rows.AbstractRow
- toString() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
- toString() - Method in class org.apache.cassandra.db.rows.EncodingStats
- toString() - Method in class org.apache.cassandra.db.rows.Row.Deletion
- 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() - 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.streaming.ComponentManifest
- toString() - Method in class org.apache.cassandra.db.TruncateRequest
- toString() - Method in class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable.ColumnValue
- toString() - Method in class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable.ColumnValues
- toString() - Method in class org.apache.cassandra.db.virtual.AbstractVirtualTable
- 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() - 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.hints.PendingHintsInfo
- toString() - Method in class org.apache.cassandra.index.sai.analyzer.NonTokenizingAnalyzer
- toString() - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- toString() - Method in class org.apache.cassandra.index.sai.disk.format.Version
- toString() - Method in class org.apache.cassandra.index.sai.disk.io.IndexOutputWriter
- toString() - Method in class org.apache.cassandra.index.sai.disk.io.SeekingRandomAccessInput
- toString() - Method in class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- toString() - Method in class org.apache.cassandra.index.sai.disk.SSTableIndex
- toString() - Method in class org.apache.cassandra.index.sai.disk.v1.bbtree.NumericIndexWriter
- toString() - Method in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- toString() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.LiteralIndexSegmentSearcher
- toString() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.NumericIndexSegmentSearcher
- toString() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.Segment
- toString() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata.ComponentMetadata
- toString() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata.ComponentMetadataMap
- toString() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata
- toString() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.VectorIndexSegmentSearcher
- toString() - Method in class org.apache.cassandra.index.sai.plan.Expression
- toString() - Method in class org.apache.cassandra.index.sai.postings.IntArrayPostingList
- toString() - Method in class org.apache.cassandra.index.sai.SSTableContext
- toString() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- toString() - Method in class org.apache.cassandra.index.sai.utils.IndexIdentifier
- toString() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
- toString() - Method in class org.apache.cassandra.index.sai.view.RangeTermTree.Term
- toString() - Method in class org.apache.cassandra.index.sai.view.View
- 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.FSError
- toString() - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator.AbstractReader
- toString() - Method in class org.apache.cassandra.io.sstable.Component
- toString() - Method in class org.apache.cassandra.io.sstable.Component.Type
- toString() - Method in class org.apache.cassandra.io.sstable.Descriptor
- toString() - Method in class org.apache.cassandra.io.sstable.format.AbstractSSTableFormat
- toString() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableKeyReader
- toString() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScanner
- toString() - Method in class org.apache.cassandra.io.sstable.format.big.IndexState
- toString() - Method in class org.apache.cassandra.io.sstable.format.SSTableScanner
- toString() - Method in class org.apache.cassandra.io.sstable.format.Version
- toString() - Method in class org.apache.cassandra.io.sstable.IScrubber.Options
- toString() - Method in class org.apache.cassandra.io.sstable.IVerifier.Options
- toString() - Method in class org.apache.cassandra.io.sstable.SequenceBasedSSTableId
- toString() - Method in class org.apache.cassandra.io.sstable.SSTable
- toString() - Method in interface org.apache.cassandra.io.sstable.SSTableId
-
Creates a String format of the identifier that can be parsed by
SSTableId.Builder.fromString(String)
- toString() - Method in class org.apache.cassandra.io.sstable.UUIDBasedSSTableId
- toString() - Method in class org.apache.cassandra.io.tries.TrieNode
- toString() - Method in class org.apache.cassandra.io.tries.ValueIterator.IterationPosition
- toString() - Method in class org.apache.cassandra.io.tries.Walker
- toString() - Method in class org.apache.cassandra.io.tries.Walker.TransitionBytesCollector
- 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.File
- 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() - 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.io.util.TailOverridingRebufferer
- toString() - Method in class org.apache.cassandra.io.util.WrappingRebufferer
- toString() - Method in class org.apache.cassandra.locator.AbstractReplicaCollection
- toString() - Method in class org.apache.cassandra.locator.InetAddressAndPort
- 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.AbstractForRead
- 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.SnitchProperties
- 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.MinMaxAvgMetric
- toString() - Method in class org.apache.cassandra.metrics.Sampler.Sample
- toString() - Method in class org.apache.cassandra.metrics.TopPartitionTracker.Collector
- toString() - Method in class org.apache.cassandra.metrics.TopPartitionTracker.TopHolder
- toString() - Method in class org.apache.cassandra.metrics.TopPartitionTracker.TopPartition
- toString() - Method in class org.apache.cassandra.metrics.TopPartitionTracker
- 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.net.RequestCallbacks.CallbackInfo
- 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() - 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.state.AbstractState
- toString() - Method in class org.apache.cassandra.repair.state.Completable.Result
- toString() - Method in class org.apache.cassandra.repair.state.CoordinatorState
- toString() - Method in class org.apache.cassandra.repair.state.ParticipateState.Job
- toString() - Method in class org.apache.cassandra.repair.state.ParticipateState
- 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.Diff
- toString() - Method in class org.apache.cassandra.schema.DroppedColumn
- 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.KeyspaceDiff
- 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.KeyspacesDiff
- toString() - Method in class org.apache.cassandra.schema.Keyspaces
- toString() - Method in class org.apache.cassandra.schema.MemtableParams
- toString() - Method in class org.apache.cassandra.schema.ReplicationParams
- toString() - Method in class org.apache.cassandra.schema.SchemaTransformation.SchemaTransformationResult
- 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.UserFunctions
- toString() - Method in class org.apache.cassandra.schema.ViewMetadata
- toString() - Method in class org.apache.cassandra.schema.Views
- toString() - Method in class org.apache.cassandra.security.FileBasedSslContextFactory.HotReloadableFile
- toString() - Method in class org.apache.cassandra.service.ActiveRepairService.ParentRepairSession
- toString() - Method in enum org.apache.cassandra.service.CacheService.CacheType
- toString() - Method in enum org.apache.cassandra.service.disk.usage.DiskUsageState
- 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.AbstractPaxosRepair.Failure
- toString() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosRepair.Result
- toString() - Method in class org.apache.cassandra.service.paxos.Commit.Accepted
- toString() - Method in class org.apache.cassandra.service.paxos.Commit.Committed
- toString() - Method in class org.apache.cassandra.service.paxos.Commit.Proposal
- toString() - Method in class org.apache.cassandra.service.paxos.Commit
- toString() - Method in class org.apache.cassandra.service.paxos.PaxosRepair
- toString() - Method in class org.apache.cassandra.service.paxos.PaxosRepairHistory
- toString() - Method in class org.apache.cassandra.service.paxos.PrepareResponse
- toString() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosKeyState
- 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.reads.thresholds.WarningsSnapshot.Counter
- toString() - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot
- toString() - Method in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Warnings
- toString() - Method in class org.apache.cassandra.service.snapshot.TableSnapshot
- toString() - Method in class org.apache.cassandra.service.SSTablesVersionsInUseChangeNotification
- toString() - Method in class org.apache.cassandra.service.TokenRange.EndpointDetails
- toString() - 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() - Method in class org.apache.cassandra.streaming.StreamEvent.ProgressEvent
- toString() - Method in class org.apache.cassandra.streaming.StreamingState
- toString() - Method in class org.apache.cassandra.streaming.StreamSession
- 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.tools.nodetool.formatter.TableBuilder
- toString() - Method in class org.apache.cassandra.transport.ClientStat
- toString() - Method in class org.apache.cassandra.transport.Dispatcher.RequestProcessor
- 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.Message.Request
- toString() - Method in class org.apache.cassandra.transport.Message
- 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.transport.QueueBackpressure.Incident
- 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.concurrent.AbstractFuture
- toString() - Method in class org.apache.cassandra.utils.CounterId
- toString() - Method in class org.apache.cassandra.utils.ExpiringMemoizingSupplier
- toString() - Method in class org.apache.cassandra.utils.ExpMovingAverage
- 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
- toString() - Method in class org.apache.cassandra.utils.RecomputingSupplier
- toString() - Method in class org.apache.cassandra.utils.TimeUUID
- toString(boolean) - Method in class org.apache.cassandra.cql3.CQL3Type.Tuple
- toString(boolean) - Method in class org.apache.cassandra.db.CounterMutation
- toString(boolean) - Method in class org.apache.cassandra.db.filter.ColumnSubselection
- toString(boolean) - Method in class org.apache.cassandra.db.filter.RowFilter.CustomExpression
- toString(boolean) - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
- toString(boolean) - Method in class org.apache.cassandra.db.filter.RowFilter.SimpleExpression
- toString(boolean) - Method in interface org.apache.cassandra.db.IMutation
- toString(boolean) - Method in class org.apache.cassandra.db.marshal.AbstractType
- toString(boolean) - Method in class org.apache.cassandra.db.marshal.ListType
- toString(boolean) - Method in class org.apache.cassandra.db.marshal.MapType
- toString(boolean) - Method in class org.apache.cassandra.db.marshal.SetType
- toString(boolean) - Method in class org.apache.cassandra.db.marshal.UserType
- toString(boolean) - Method in class org.apache.cassandra.db.marshal.VectorType
- toString(boolean) - Method in class org.apache.cassandra.db.Mutation
- toString(boolean) - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
- toString(boolean) - Method in class org.apache.cassandra.db.virtual.VirtualMutation
- toString(boolean) - Method in class org.apache.cassandra.locator.InetAddressAndPort
- toString(boolean) - Method in class org.apache.cassandra.service.TokenRange.EndpointDetails
- toString(boolean) - Method in class org.apache.cassandra.service.TokenRange
- toString(boolean) - Method in class org.apache.cassandra.streaming.ProgressInfo
- toString(byte[], Charset) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- toString(long, long) - Static method in class org.apache.cassandra.io.util.Memory
- toString(Boolean) - Method in class org.apache.cassandra.serializers.BooleanSerializer
- toString(Byte) - Method in class org.apache.cassandra.serializers.ByteSerializer
- toString(Double) - Method in class org.apache.cassandra.serializers.DoubleSerializer
- toString(Float) - Method in class org.apache.cassandra.serializers.FloatSerializer
- toString(Integer) - Method in class org.apache.cassandra.serializers.Int32Serializer
- toString(Integer) - Method in class org.apache.cassandra.serializers.SimpleDateSerializer
- toString(Long) - Method in class org.apache.cassandra.serializers.LongSerializer
- toString(Long) - Method in class org.apache.cassandra.serializers.TimeSerializer
- toString(Object[]) - Static method in class org.apache.cassandra.utils.btree.BTree
- toString(Short) - Method in class org.apache.cassandra.serializers.ShortSerializer
- toString(String) - Method in class org.apache.cassandra.serializers.AbstractTextSerializer
- toString(String) - Method in class org.apache.cassandra.service.paxos.Commit
- toString(Void) - Method in class org.apache.cassandra.serializers.EmptySerializer
- toString(BigDecimal) - Method in class org.apache.cassandra.serializers.DecimalSerializer
- toString(BigInteger) - Method in class org.apache.cassandra.serializers.IntegerSerializer
- toString(InetAddress) - Method in class org.apache.cassandra.serializers.InetAddressSerializer
- toString(InetAddress, int) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
-
Format an InetAddressAndPort in the same style as InetAddress.toString.
- toString(InetSocketAddress) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
- toString(InetSocketAddress, boolean) - Static method in class org.apache.cassandra.locator.InetAddressAndPort
- toString(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
-
Human-readable String from context.
- toString(ByteBuffer) - Method in class org.apache.cassandra.serializers.BytesSerializer
- toString(ByteBuffer, Charset) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- toString(Date) - Method in class org.apache.cassandra.serializers.TimestampSerializer
- toString(List<T>) - Method in class org.apache.cassandra.db.marshal.VectorType.VectorSerializer
- toString(List<T>) - Method in class org.apache.cassandra.serializers.ListSerializer
- toString(Map<?, ?>) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Make straing out of the given
Map
. - toString(Map<K, V>) - Method in class org.apache.cassandra.serializers.MapSerializer
- toString(Set<T>) - Method in class org.apache.cassandra.serializers.SetSerializer
- toString(UUID) - Method in class org.apache.cassandra.serializers.UUIDSerializer
- 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(Duration) - Method in class org.apache.cassandra.serializers.DurationSerializer
- toString(ClusteringComparator) - Method in interface org.apache.cassandra.db.ClusteringBoundOrBoundary
- toString(ClusteringComparator) - Method in class org.apache.cassandra.db.RangeTombstone
- toString(ClusteringComparator) - Method in class org.apache.cassandra.db.Slice
- toString(CommitLogPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLogPosition.CommitLogPositionSerializer
- toString(Token) - Method in class org.apache.cassandra.dht.Token.TokenFactory
- toString(TableMetadata) - Method in interface org.apache.cassandra.db.Clustering
- toString(TableMetadata) - Method in interface org.apache.cassandra.db.ClusteringBoundOrBoundary
- toString(TableMetadata) - Method in interface org.apache.cassandra.db.ClusteringPrefix
-
Generates a proper string representation of the prefix.
- toString(TableMetadata) - Method in class org.apache.cassandra.db.DataRange.Paging
- toString(TableMetadata) - Method in class org.apache.cassandra.db.DataRange
- 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(TableMetadata) - Method in class org.apache.cassandra.db.rows.AbstractRow
- toString(TableMetadata) - Method in class org.apache.cassandra.db.rows.ArtificialBoundMarker
- toString(TableMetadata) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
- toString(TableMetadata) - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
- toString(TableMetadata) - Method in interface org.apache.cassandra.db.rows.Unfiltered
- toString(TableMetadata, boolean) - Method in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
- toString(TableMetadata, boolean) - Method in class org.apache.cassandra.db.rows.AbstractRow
- toString(TableMetadata, boolean) - Method in interface org.apache.cassandra.db.rows.Row
- toString(TableMetadata, boolean) - Method in interface org.apache.cassandra.db.rows.Unfiltered
- toString(TableMetadata, boolean, boolean) - Method in class org.apache.cassandra.db.rows.AbstractRangeTombstoneMarker
- toString(TableMetadata, boolean, boolean) - Method in class org.apache.cassandra.db.rows.AbstractRow
- toString(TableMetadata, boolean, boolean) - Method in interface org.apache.cassandra.db.rows.Unfiltered
- toString(PreviewKind) - Method in class org.apache.cassandra.repair.RepairJobDesc
- toString(TimeUUID) - Static method in class org.apache.cassandra.utils.TimeUUID
- toString(TimeUUID, String) - Static method in class org.apache.cassandra.utils.TimeUUID
- toString(T) - Method in class org.apache.cassandra.metrics.Sampler
- toString(T) - Method in class org.apache.cassandra.serializers.TypeSerializer
- toString(T) - Method in class org.apache.cassandra.utils.TimeUUID.AbstractSerializer
- toString(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- toString(V, Charset) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- toStringSet(Set<TableMetadata.Flag>) - Static method in enum org.apache.cassandra.schema.TableMetadata.Flag
- toStringUTC(Date) - Method in class org.apache.cassandra.serializers.TimestampSerializer
- toSubmit(Runnable) - Method in class org.apache.cassandra.concurrent.TaskFactory.LocalAware
- toSubmit(Runnable) - Method in class org.apache.cassandra.concurrent.TaskFactory.Standard
- toSubmit(Runnable) - Method in interface org.apache.cassandra.concurrent.TaskFactory
- toSubmit(Runnable, T) - Method in class org.apache.cassandra.concurrent.TaskFactory.LocalAware
- toSubmit(Runnable, T) - Method in class org.apache.cassandra.concurrent.TaskFactory.Standard
- toSubmit(Runnable, T) - Method in interface org.apache.cassandra.concurrent.TaskFactory
- toSubmit(Callable<T>) - Method in class org.apache.cassandra.concurrent.TaskFactory.LocalAware
- toSubmit(Callable<T>) - Method in class org.apache.cassandra.concurrent.TaskFactory.Standard
- toSubmit(Callable<T>) - Method in interface org.apache.cassandra.concurrent.TaskFactory
- toSubmit(WithResources, Runnable) - Method in class org.apache.cassandra.concurrent.TaskFactory.LocalAware
- toSubmit(WithResources, Runnable) - Method in class org.apache.cassandra.concurrent.TaskFactory.Standard
- toSubmit(WithResources, Runnable) - Method in interface org.apache.cassandra.concurrent.TaskFactory
- toSubmit(WithResources, Runnable, T) - Method in class org.apache.cassandra.concurrent.TaskFactory.LocalAware
- toSubmit(WithResources, Runnable, T) - Method in class org.apache.cassandra.concurrent.TaskFactory.Standard
- toSubmit(WithResources, Runnable, T) - Method in interface org.apache.cassandra.concurrent.TaskFactory
- toSubmit(WithResources, Callable<T>) - Method in class org.apache.cassandra.concurrent.TaskFactory.LocalAware
- toSubmit(WithResources, Callable<T>) - Method in class org.apache.cassandra.concurrent.TaskFactory.Standard
- toSubmit(WithResources, Callable<T>) - Method in interface org.apache.cassandra.concurrent.TaskFactory
- total - Variable in class org.apache.cassandra.repair.consistent.admin.PendingStats
- total(Cell<V>) - Method in class org.apache.cassandra.db.context.CounterContext
- total(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.context.CounterContext
-
Returns the aggregated count across all counter ids.
- TOTAL - Static variable in class org.apache.cassandra.db.compaction.CompactionInfo
- TOTAL_BLOCKED_TASKS - Static variable in class org.apache.cassandra.metrics.ThreadPoolMetrics
- TOTAL_FILES - Static variable in class org.apache.cassandra.hints.PendingHintsInfo
- 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
- totalBytesAllocated() - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder
- totalBytesCompacted - Static variable in class org.apache.cassandra.db.compaction.CompactionTask
- totalColumnsRead - Static variable in class org.apache.cassandra.metrics.ClientRequestSizeMetrics
- totalColumnsSet - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- totalColumnsSet - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
- totalColumnsWritten - Static variable in class org.apache.cassandra.metrics.ClientRequestSizeMetrics
- 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
- totalDiskSpace() - Static method in class org.apache.cassandra.service.disk.usage.DiskUsageMonitor
- totalDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
- 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
- totalDiskUsage() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- 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.
- totalFiles - Variable in class org.apache.cassandra.hints.PendingHintsInfo
- 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
- totalIndexBuildsInProgress() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- totalIndexCount() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- 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
- totalQueryableIndexCount() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- totalQueryTimeNs() - Method in class org.apache.cassandra.index.sai.QueryContext
- totalRows - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- totalRows - Variable in class org.apache.cassandra.io.sstable.metadata.StatsMetadata
- totalRowsRead - Static variable in class org.apache.cassandra.metrics.ClientRequestSizeMetrics
- totalRowsWritten - Static variable in class org.apache.cassandra.metrics.ClientRequestSizeMetrics
- totalSize - Variable in class org.apache.cassandra.streaming.StreamSummary
- 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
- totalSpace(FileStore) - Static method in class org.apache.cassandra.service.disk.usage.DiskUsageMonitor
- totalTokens(Splitter) - Method in class org.apache.cassandra.dht.Splitter.WeightedRange
- totalTombstones - Variable in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- 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 aTerm
. - 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 aTerm
s. - toTimeInMillis(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- 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
- toTimestamp(TemporalType<?>) - Static method in class org.apache.cassandra.cql3.functions.TimeFcts
-
Creates a function that converts a value of the specified type into a
TIMESTAMP
. - toTimeUUID(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- toTimeUUID(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- toTimeUUID(V) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
returns a TimeUUID from offset 0
- toTupleBufferList() - Method in class org.apache.cassandra.service.paxos.PaxosRepairHistory
- toType(Pair<DataType, Object>) - Static method in enum org.apache.cassandra.transport.DataType
- toUncommittedInfo(CloseableIterator<PaxosKeyState>) - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosKeyState
- toUnixTimestamp(TemporalType<?>) - Static method in class org.apache.cassandra.cql3.functions.TimeFcts
-
Creates a function that converts a value of the specified type into a 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) - Method in class org.apache.cassandra.tracing.TraceState
- trace(String) - Static method in class org.apache.cassandra.tracing.Tracing
- trace(String, Object) - Method in class org.apache.cassandra.tracing.TraceState
- trace(String, Object) - Static method in class org.apache.cassandra.tracing.Tracing
- trace(String, Object...) - Method in class org.apache.cassandra.tracing.TraceState
- trace(String, Object...) - Static method in class org.apache.cassandra.tracing.Tracing
- trace(String, Object, Object) - Method in class org.apache.cassandra.tracing.TraceState
- trace(String, Object, 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(Descriptor) - Method in enum org.apache.cassandra.io.sstable.SSTableReadsListener.SkippingReason
- trace(Descriptor, AbstractRowIndexEntry) - Method in enum org.apache.cassandra.io.sstable.SSTableReadsListener.SelectionReason
- TRACE_COMPLETE - org.apache.cassandra.transport.Event.Type
- TRACE_KEY - Static variable in class org.apache.cassandra.repair.messages.RepairOption
- TRACE_KEYSPACE_NAME - Static variable in class org.apache.cassandra.schema.SchemaConstants
- TRACE_SESSION - org.apache.cassandra.net.ParamType
- TRACE_TYPE - org.apache.cassandra.net.ParamType
- trace_type_query_ttl - Variable in class org.apache.cassandra.config.Config
- trace_type_repair_ttl - Variable in class org.apache.cassandra.config.Config
- 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, TimeUUID, 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, TimeUUID, Tracing.TraceType) - Constructor for class org.apache.cassandra.tracing.TraceStateImpl
- traceType - Variable in class org.apache.cassandra.tracing.TraceState
- traceType() - Method in class org.apache.cassandra.net.Message.Header
- traceType() - Method in class org.apache.cassandra.net.Message
- 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 - org.apache.cassandra.concurrent.Stage
- TRACING - org.apache.cassandra.transport.Envelope.Header.Flag
- Tracing.TraceType - Enum in org.apache.cassandra.tracing
- tracingId - Variable in class org.apache.cassandra.transport.Message.Response
- track(DecoratedKey, long) - Method in class org.apache.cassandra.metrics.TopPartitionTracker.TopHolder
- TRACK_REPAIRED_DATA - org.apache.cassandra.net.MessageFlag
-
track repaired data - see CASSANDRA-14145
- TRACK_WARNINGS - org.apache.cassandra.net.MessageFlag
-
allow creating warnings or aborting queries based off query - see CASSANDRA-16850
- tracked - Variable in class org.apache.cassandra.index.sai.metrics.AbstractMetrics
- 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
-
Create a TrackedDataInputPlus from given DataInput with no limit of bytes to read
- TrackedDataInputPlus(DataInput, long) - Constructor for class org.apache.cassandra.io.util.TrackedDataInputPlus
-
Create a TrackedDataInputPlus from given DataInput with limit of bytes to read.
- 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 - Variable in class org.apache.cassandra.transport.SimpleClient
- Tracker - Class in org.apache.cassandra.db.lifecycle
-
Tracker tracks live
View
of data store for a table. - Tracker(ColumnFamilyStore, Memtable, boolean) - Constructor for class org.apache.cassandra.db.lifecycle.Tracker
- trackInboundHandlers() - Static method in class org.apache.cassandra.streaming.async.NettyStreamingChannel
- 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
- trackPartitionSize(DecoratedKey, long) - Method in class org.apache.cassandra.metrics.TopPartitionTracker.Collector
- 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
- trackTombstoneCount(DecoratedKey, long) - Method in class org.apache.cassandra.metrics.TopPartitionTracker.Collector
- trackValidationCompletion(Pair<RepairJobDesc, InetAddressAndPort>, ValidationTask) - Method in class org.apache.cassandra.repair.RepairSession
- trackWarnings() - Method in class org.apache.cassandra.db.ReadCommand
- trackWarnings() - Method in interface org.apache.cassandra.db.ReadQuery
- trackWarnings() - Method in class org.apache.cassandra.db.SinglePartitionReadQuery.Group
- trackWarnings() - Method in class org.apache.cassandra.net.Message
- traffic() - Method in annotation type org.apache.cassandra.utils.Nemesis
- trans - Variable in class org.apache.cassandra.db.SystemKeyspace.AvailableRanges
- transaction - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionTask
- transaction - Variable in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- 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.util.ChecksummedSequentialWriter.TransactionalProxy
- TransactionalProxy() - Constructor for class org.apache.cassandra.io.util.SequentialWriter.TransactionalProxy
- TransactionalProxy(Supplier<ImmutableList<Transactional>>) - Constructor for class org.apache.cassandra.io.sstable.format.SortedTableWriter.TransactionalProxy
- TransactionalProxy(Supplier<ImmutableList<Transactional>>) - Constructor for class org.apache.cassandra.io.sstable.format.SSTableWriter.TransactionalProxy
- TransactionAlreadyCompletedException - Exception in org.apache.cassandra.db.lifecycle
- transEndpoints - Variable in class org.apache.cassandra.repair.CommonRange
- transfer_hints_on_decommission - Variable in class org.apache.cassandra.config.Config
- 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
underkeyspace
andranges
. - 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(Function<? super Cell<?>, ? extends Cell<?>>) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
- transform(Object[], Function<? super I, ? extends O>) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Takes a tree and transforms it using the provided function.
- transform(Function<ColumnData, ColumnData>) - Method in class org.apache.cassandra.db.rows.BTreeRow
- transform(SchemaTransformation) - Method in class org.apache.cassandra.schema.Schema
- transform(SchemaTransformation, boolean) - Method in class org.apache.cassandra.schema.Schema
- transformAndFilter(Function<? super Cell<?>, ? extends Cell<?>>) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
- transformAndFilter(Object[], BiFunction<? super I, ? super I2, ? extends O>, I2) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Takes a tree and transforms it using the provided function, filtering out any null results.
- transformAndFilter(Object[], Function<? super I, ? extends O>) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Takes a tree and transforms it using the provided function, filtering out any null results.
- transformAndFilter(Function<ColumnData, ColumnData>) - Method in class org.apache.cassandra.db.rows.BTreeRow
- transformAndFilter(Function<ColumnData, ColumnData>) - Method in interface org.apache.cassandra.db.rows.Row
-
Requires that
function
returns eithernull
orColumnData
for the same column. - transformAndFilter(DeletionTime, Function<? super Cell, ? extends Cell>) - Method in class org.apache.cassandra.db.rows.ComplexColumnData
- transformAndFilter(LivenessInfo, Row.Deletion, Function<ColumnData, ColumnData>) - Method in class org.apache.cassandra.db.rows.BTreeRow
- transformAndFilter(LivenessInfo, Row.Deletion, Function<ColumnData, ColumnData>) - Method in interface org.apache.cassandra.db.rows.Row
-
Requires that
function
returns eithernull
orColumnData
for the same column. - 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<? super Replica, ? extends K>) - Method in class org.apache.cassandra.locator.AbstractReplicaCollection.ReplicaList
- transformValue() - Method in class org.apache.cassandra.index.sai.analyzer.AbstractAnalyzer
- transformValue() - Method in class org.apache.cassandra.index.sai.analyzer.NonTokenizingAnalyzer
- transient_replication_enabled - Variable in class org.apache.cassandra.config.Config
- TRANSIENTLY_REPLICATED_KEYSPACE_NOT_SUPPORTED - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- 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 - Variable in class org.apache.cassandra.streaming.StreamRequest
- transientReplicas() - Method in class org.apache.cassandra.locator.Replicas.ReplicaCount
- transientReplicas() - Method in class org.apache.cassandra.locator.ReplicationFactor
- transition(int) - Method in interface org.apache.cassandra.io.tries.SerializationNode
-
The transition character for the child at position i.
- transition(int) - Method in class org.apache.cassandra.io.tries.Walker
- transition(ByteBuffer, int, long, int) - Method in class org.apache.cassandra.io.tries.TrieNode
-
Returns position of node to transition to for the given search index.
- transitionByte(int) - Method in class org.apache.cassandra.io.tries.Walker
- transitionByte(ByteBuffer, int, int) - Method in class org.apache.cassandra.io.tries.TrieNode
-
Returns the byte value for this child index, or Integer.MAX_VALUE if there are no transitions with this index or higher to permit listing the children without needing to call transitionRange.
- TransitionBytesCollector() - Constructor for class org.apache.cassandra.io.tries.Walker.TransitionBytesCollector
- transitionRange() - Method in class org.apache.cassandra.io.tries.Walker
- transitionRange(ByteBuffer, int) - Method in class org.apache.cassandra.io.tries.TrieNode
-
Returns the upper childIndex limit.
- TRANSITIVE - org.apache.cassandra.utils.Overlaps.InclusionMethod
- 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(boolean, String, String, ParameterizedClass) - Constructor for class org.apache.cassandra.config.TransparentDataEncryptionOptions
- TransparentDataEncryptionOptions(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. - traverse_auth_from_root - Variable in class org.apache.cassandra.config.Config
- 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
- 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 - Variable in class org.apache.cassandra.config.Config
- trickleFsync() - Method in class org.apache.cassandra.io.util.SequentialWriterOption
- trickleFsync(boolean) - Method in class org.apache.cassandra.io.util.SequentialWriterOption.Builder
- trickleFsyncByteInterval() - Method in class org.apache.cassandra.io.util.SequentialWriterOption
- trickleFsyncByteInterval(int) - Method in class org.apache.cassandra.io.util.SequentialWriterOption.Builder
- Trie<T> - Class in org.apache.cassandra.db.tries
-
Base class for tries.
- Trie<K,V> - Interface in org.apache.cassandra.index.sasi.utils.trie
-
Defines the interface for a prefix tree, an ordered tree data structure.
- Trie() - Constructor for class org.apache.cassandra.db.tries.Trie
- Trie.CollectionMergeResolver<T> - Interface in org.apache.cassandra.db.tries
-
Resolver of content of merged nodes.
- Trie.Cursor<T> - Interface in org.apache.cassandra.db.tries
-
A trie cursor.
- Trie.MergeResolver<T> - Interface in org.apache.cassandra.db.tries
-
Resolver of content of merged nodes, used for two-source merges (i.e.
- Trie.ResettingTransitionsReceiver - Interface in org.apache.cassandra.db.tries
-
Used by
Trie.Cursor.advanceToContent(org.apache.cassandra.db.tries.Trie.ResettingTransitionsReceiver)
to track the transitions and backtracking taken. - Trie.TransitionsReceiver - Interface in org.apache.cassandra.db.tries
-
Used by
Trie.Cursor.advanceMultiple(org.apache.cassandra.db.tries.Trie.TransitionsReceiver)
to feed the transitions taken. - Trie.ValueConsumer<T> - Interface in org.apache.cassandra.db.tries
-
Adapter interface providing the methods a
Trie.Walker
to aConsumer
, so that the latter can be used withTrie.process(org.apache.cassandra.db.tries.Trie.Walker<T, R>)
. - Trie.Walker<T,R> - Interface in org.apache.cassandra.db.tries
-
A push interface for walking over the trie.
- TrieEntriesIterator<T,V> - Class in org.apache.cassandra.db.tries
-
Convertor of trie entries to iterator where each entry is passed through
TrieEntriesIterator.mapContent(T, byte[], int)
(to be implemented by descendants). - TrieEntriesIterator(Trie<T>) - Constructor for class org.apache.cassandra.db.tries.TrieEntriesIterator
- TrieEntriesWalker<T,V> - Class in org.apache.cassandra.db.tries
-
Walker of trie entries, used with Trie.process to walk all content in order and provide the path through which values are reached.
- TrieEntriesWalker() - Constructor for class org.apache.cassandra.db.tries.TrieEntriesWalker
- TrieIndexMetrics(IndexIdentifier) - Constructor for class org.apache.cassandra.index.sai.metrics.ColumnQueryMetrics.TrieIndexMetrics
- 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
- TrieMemoryIndex - Class in org.apache.cassandra.index.sai.memory
-
This is an in-memory index using the
InMemoryTrie
to store aByteComparable
representation of the indexed values. - TrieMemoryIndex(StorageAttachedIndex) - Constructor for class org.apache.cassandra.index.sai.memory.TrieMemoryIndex
- TrieMemtable - Class in org.apache.cassandra.db.memtable
-
Trie memtable implementation.
- TrieMemtableMetricsView - Class in org.apache.cassandra.metrics
- TrieMemtableMetricsView(String, String) - Constructor for class org.apache.cassandra.metrics.TrieMemtableMetricsView
- TrieNode - Class in org.apache.cassandra.io.tries
-
Trie node types and manipulation mechanisms.
- TriePathReconstructor - Class in org.apache.cassandra.db.tries
- TriePathReconstructor() - Constructor for class org.apache.cassandra.db.tries.TriePathReconstructor
- triePostingsDecodes - Variable in class org.apache.cassandra.index.sai.QueryContext
- triePostingsSkips - Variable in class org.apache.cassandra.index.sai.QueryContext
- 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
- TrieSegmentBuilder(StorageAttachedIndex, NamedMemoryLimiter) - Constructor for class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder.TrieSegmentBuilder
- trieSegmentsHit - Variable in class org.apache.cassandra.index.sai.QueryContext
- trieSerializer - Static variable in class org.apache.cassandra.index.sai.disk.v1.trie.TrieTermsDictionaryReader
- TrieSerializer<VALUE,DEST> - Interface in org.apache.cassandra.io.tries
- TrieTermsDictionaryReader - Class in org.apache.cassandra.index.sai.disk.v1.trie
-
Page-aware random access reader for a trie terms dictionary written by
TrieTermsDictionaryWriter
. - TrieTermsDictionaryReader(Rebufferer, long) - Constructor for class org.apache.cassandra.index.sai.disk.v1.trie.TrieTermsDictionaryReader
- TrieTermsDictionaryWriter - Class in org.apache.cassandra.index.sai.disk.v1.trie
-
Writes terms dictionary to disk in a trie format (see
IncrementalTrieWriter
). - trigger() - Method in interface org.apache.cassandra.concurrent.SequentialExecutorPlus.AtLeastOnceTrigger
-
Ensure the job is run at least once in its entirety after this method is invoked (including any already queued)
- trigger() - Method in class org.apache.cassandra.concurrent.SingleThreadExecutorPlus.AtLeastOnce
- 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 - Variable in class org.apache.cassandra.schema.TableMetadata
- triggers(Triggers) - Method in class org.apache.cassandra.schema.TableMetadata.Builder
- Triggers - Class in org.apache.cassandra.schema
- TRIGGERS - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
- TRIGGERS_DIR - org.apache.cassandra.config.CassandraRelevantProperties
- Triggers.Builder - Class in org.apache.cassandra.schema
- triggersOn(long, ClientState) - Method in class org.apache.cassandra.db.guardrails.Threshold
-
Checks whether the provided value would trigger a warning or failure if passed to
Threshold.guard(long, java.lang.String, boolean, org.apache.cassandra.service.ClientState)
. - trim() - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
- trim(int) - Method in class org.apache.cassandra.cql3.ResultSet
- trivialReduceIsTrivial() - Method in class org.apache.cassandra.utils.MergeIterator.Reducer
- TRUE - Static variable in class org.apache.cassandra.serializers.BooleanSerializer
- trueSnapshotsSize - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Disk space used by snapshot files which
- 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() - 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() - Method in class org.apache.cassandra.db.virtual.AbstractVirtualTable
- truncate() - Method in class org.apache.cassandra.db.virtual.LogMessagesTable
- truncate() - Method in interface org.apache.cassandra.db.virtual.VirtualTable
-
Truncates data from the underlying source, if supported.
- truncate() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosBallotTracker
- truncate(long) - Method in class org.apache.cassandra.io.util.SequentialWriter
- truncate(String, long) - Static method in class org.apache.cassandra.io.util.FileUtils
- 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(File) - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosBallotTracker
- truncate(File) - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker
- TRUNCATE - org.apache.cassandra.audit.AuditLogEntryType
- TRUNCATE - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- TRUNCATE_BALLOT_METADATA - org.apache.cassandra.config.CassandraRelevantProperties
- TRUNCATE_ERROR - org.apache.cassandra.exceptions.ExceptionCode
- TRUNCATE_REQ - org.apache.cassandra.net.Verb
- truncate_request_timeout - Variable in class org.apache.cassandra.config.Config
- TRUNCATE_RSP - org.apache.cassandra.net.Verb
- truncateAllIndexesBlocking(long) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Truncate all indexes
- truncateBlocking() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- 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
- truncateBlocking(CommitLogPosition, long) - Method in class org.apache.cassandra.db.view.TableViews
- truncateBlockingWithoutSnapshot() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- truncatedAt - Variable in class org.apache.cassandra.notifications.TruncationNotification
- TruncateException - Exception in org.apache.cassandra.exceptions
- TruncateException(String) - Constructor for exception org.apache.cassandra.exceptions.TruncateException
- TruncateException(Throwable) - Constructor for exception org.apache.cassandra.exceptions.TruncateException
- truncateHints() - Method in class org.apache.cassandra.tools.NodeProbe
- truncateHints(String) - 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 - org.apache.cassandra.config.EncryptionOptions.ConfigKey
- truststore_password - Variable in class org.apache.cassandra.config.EncryptionOptions
- TRUSTSTORE_PASSWORD - org.apache.cassandra.config.EncryptionOptions.ConfigKey
- trustStoreContext - Variable in class org.apache.cassandra.security.FileBasedSslContextFactory
- tryAcquire(int) - Method in interface org.apache.cassandra.utils.concurrent.Semaphore
-
Try to take permits, returning immediately
- tryAcquire(int, long, TimeUnit) - Method in interface org.apache.cassandra.utils.concurrent.Semaphore
-
Try to take permits, waiting up to timeout
- tryAcquireUntil(int, long) - Method in class org.apache.cassandra.utils.concurrent.Semaphore.Standard
- tryAcquireUntil(int, long) - Method in interface org.apache.cassandra.utils.concurrent.Semaphore
-
Try to take permits, waiting until the deadline
- 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(DecoratedKey, DecoratedKey, SSTableRewriter) - Method in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- 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
andComponent
object. - tryComponentFromFilename(File, String, String) - Static method in class org.apache.cassandra.io.sstable.SSTable
-
Parse a sstable filename into both a
Descriptor
andComponent
object. - tryCreate(FunctionName, List<ColumnIdentifier>, List<AbstractType<?>>, AbstractType<?>, boolean, String, String) - Static method in class org.apache.cassandra.cql3.functions.UDFunction
- tryCreateDirectories() - Method in class org.apache.cassandra.io.util.File
-
Try to create a directory at this path, creating any parent directories as necessary.
- tryCreateDirectories(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- tryCreateDirectory() - Method in class org.apache.cassandra.io.util.File
-
Try to create a directory at this path.
- tryCreateDirectory(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- tryDelete() - Method in class org.apache.cassandra.io.util.File
-
Try to delete the file, returning true iff it was deleted by us.
- tryDelete(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- tryDescriptorFromFile(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.concurrent.FutureTask
- tryFailure(Throwable) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- tryFailure(Throwable) - Method in class org.apache.cassandra.utils.concurrent.AsyncPromise
-
Complete the promise abnormally if not already complete
- tryFailure(Throwable) - Method in class org.apache.cassandra.utils.concurrent.FutureCombiner
- tryFailure(Throwable) - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
-
Complete the promise abnormally if not already complete
- 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
- tryGetLastModified(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- tryGetLength(Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- tryGetSpace(FileStore, PathUtils.IOToLongFunction<FileStore>) - Static method in class org.apache.cassandra.io.util.FileStoreUtils
-
Try and get the total space of the given filestore
- tryGetSpace(FileStore, PathUtils.IOToLongFunction<FileStore>, Consumer<IOException>) - Static method in class org.apache.cassandra.io.util.FileStoreUtils
- tryGetSpace(Path, PathUtils.IOToLongFunction<FileStore>) - Static method in class org.apache.cassandra.io.util.PathUtils
-
Returns the number of bytes (determined by the provided MethodHandle) on the specified partition.
- tryGetSpace(Path, PathUtils.IOToLongFunction<FileStore>, Consumer<IOException>) - Static method in class org.apache.cassandra.io.util.PathUtils
- tryList() - Method in class org.apache.cassandra.io.util.File
- tryList(Path, Function<Stream<Path>, Stream<V>>, IntFunction<V[]>, ThrowingFunction<IOException, V[], T>) - Static method in class org.apache.cassandra.io.util.PathUtils
- tryList(BiPredicate<File, String>) - Method in class org.apache.cassandra.io.util.File
- tryList(Predicate<File>) - Method in class org.apache.cassandra.io.util.File
- tryListNames() - Method in class org.apache.cassandra.io.util.File
- tryListNames(BiPredicate<File, String>) - Method in class org.apache.cassandra.io.util.File
- tryListNames(BiPredicate<File, String>, ThrowingFunction<IOException, String[], T>) - Method in class org.apache.cassandra.io.util.File
- tryListNames(ThrowingFunction<IOException, String[], T>) - Method in class org.apache.cassandra.io.util.File
- tryMlockall() - Static method in class org.apache.cassandra.utils.NativeLibrary
- tryModify(Iterable<? extends SSTableReader>, OperationType) - Method in class org.apache.cassandra.db.lifecycle.Tracker
- tryModify(SSTableReader, OperationType) - Method in class org.apache.cassandra.db.lifecycle.Tracker
- tryMove(File) - Method in class org.apache.cassandra.io.util.File
-
Try to rename the file atomically, if the system supports it.
- 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
- tryRecycle(T) - Method in interface org.apache.cassandra.utils.concurrent.LightweightRecycler
- tryRef() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- tryRef() - Method in class org.apache.cassandra.utils.concurrent.Ref.DirectBufferRef
- tryRef() - Method in class org.apache.cassandra.utils.concurrent.Ref
- tryRef() - Method in interface org.apache.cassandra.utils.concurrent.RefCounted
- tryRef(Iterable<? extends T>) - Static method in class org.apache.cassandra.utils.concurrent.Refs
-
Acquire a reference to all of the provided objects, or none
- 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
- tryRename(Path, Path) - Static method in class org.apache.cassandra.io.util.PathUtils
- tryReserve() - Method in class org.apache.cassandra.utils.concurrent.NonBlockingRateLimiter
-
Reserves a single permit slot on the timeline, but only if one is available.
- tryResult(Completable.Result) - Method in class org.apache.cassandra.repair.state.AbstractCompletable
- trySet(Path, PosixFilePermission, boolean) - Static method in class org.apache.cassandra.io.util.PathUtils
- trySetExecutable(boolean) - Method in class org.apache.cassandra.io.util.File
-
Try to set if the path is executable by its owner
- trySetExecutable(Path, boolean) - Static method in class org.apache.cassandra.io.util.PathUtils
- trySetLastModified(long) - Method in class org.apache.cassandra.io.util.File
-
Try to set the last modified time in millis of the path
- trySetLastModified(Path, long) - Static method in class org.apache.cassandra.io.util.PathUtils
- trySetReadable(boolean) - Method in class org.apache.cassandra.io.util.File
-
Try to set if the path is readable by its owner
- trySetReadable(Path, boolean) - Static method in class org.apache.cassandra.io.util.PathUtils
- trySetWritable(boolean) - Method in class org.apache.cassandra.io.util.File
-
Try to set if the path is writable by its owner
- trySetWritable(Path, boolean) - Static method in class org.apache.cassandra.io.util.PathUtils
- trySkipCache(int, long, int, String) - Static method in class org.apache.cassandra.utils.NativeLibrary
- trySkipCache(int, long, long, String) - Static method in class org.apache.cassandra.utils.NativeLibrary
- trySkipCache(String, long, long) - Static method in class org.apache.cassandra.utils.NativeLibrary
- trySkipFileCacheBefore(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
- trySuccess() - Method in class org.apache.cassandra.net.AsyncChannelPromise
- trySuccess(T) - Method in class org.apache.cassandra.utils.concurrent.FutureCombiner
- trySuccess(V) - Method in class org.apache.cassandra.utils.concurrent.AbstractFuture
- trySuccess(V) - Method in class org.apache.cassandra.utils.concurrent.AsyncPromise
-
Complete the promise successfully if not already complete
- trySuccess(V) - Method in class org.apache.cassandra.utils.concurrent.SyncPromise
-
Complete the promise successfully if not already complete
- 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.RangeIterator
- tryToComputeNext() - Method in class org.apache.cassandra.utils.AbstractGuavaIterator
- tryUncacheRead() - Method in class org.apache.cassandra.hints.ChecksummedDataInput
- tryUnsafeSet(ExecutorFactory) - Static method in class org.apache.cassandra.concurrent.ExecutorFactory.Global
- tryUpcast(ByteBuffer, AbstractType<?>) - Static method in class org.apache.cassandra.index.sasi.utils.TypeUtil
- ttl - Variable in class org.apache.cassandra.tracing.TraceState
- 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() - 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.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(int) - Method in interface org.apache.cassandra.db.rows.Row.SimpleBuilder
-
Sets the ttl to use for the following additions.
- TTL - org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL.Kind
- 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.
- TUPLE - org.apache.cassandra.cql3.functions.types.DataType.Name
- TUPLE - org.apache.cassandra.transport.DataType
- TUPLE_SELECTOR - org.apache.cassandra.cql3.selection.Selector.Kind
- Tuples - Class in org.apache.cassandra.cql3
-
Static helper methods and classes for tuples.
- TUPLES_WITH_DURATIONS_NOT_SUPPORTED - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- Tuples.DelayedValue - Class in org.apache.cassandra.cql3
-
Similar to Value, but contains at least one NonTerminal, such as a non-pure functions or bind marker.
- Tuples.InMarker - Class in org.apache.cassandra.cql3
-
Represents a marker for a set of IN values that are tuples, like "SELECT ...
- Tuples.INRaw - Class in org.apache.cassandra.cql3
-
A raw marker for an IN list of tuples, like "SELECT ...
- Tuples.InValue - Class in org.apache.cassandra.cql3
-
A terminal value for a list of IN values that are tuples.
- Tuples.Literal - Class in org.apache.cassandra.cql3
-
A raw, literal tuple.
- Tuples.Marker - Class in org.apache.cassandra.cql3
-
Represents a marker for a single tuple, like "SELECT ... WHERE (a, b, c) > ?"
- 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(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. - tupleToString(List<?>) - Static method in class org.apache.cassandra.cql3.Tuples
-
Create a
String
representation of the tuple containing the specified 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 - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- twcs(Map<String, String>) - Static method in class org.apache.cassandra.schema.CompactionParams
- TWCS_BUCKET_COUNT_MAX - Static variable in class org.apache.cassandra.db.compaction.CompactionStrategyManager
- twcsDurationInMillis - Variable in class org.apache.cassandra.tools.nodetool.stats.StatsTable
- TWO - org.apache.cassandra.db.ConsistencyLevel
- 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
- TXN_LOG - org.apache.cassandra.db.Directories.FileType
-
A transaction log file (contains information on final and temporary files).
- txnProxy - Variable in class org.apache.cassandra.io.sstable.format.SSTableWriter
- txnProxy() - Method in class org.apache.cassandra.io.compress.CompressedSequentialWriter
- txnProxy() - Method in class org.apache.cassandra.io.sstable.format.SortedTableWriter
- txnProxy() - Method in class org.apache.cassandra.io.sstable.format.SSTableWriter
-
The implementing method should return an instance of
SSTableWriter.TransactionalProxy
initialized with a list of all transactional resources included in this writer. - txnProxy() - Method in class org.apache.cassandra.io.util.ChecksummedSequentialWriter
- txnProxy() - Method in class org.apache.cassandra.io.util.SequentialWriter
- type - Variable in class org.apache.cassandra.cql3.ColumnSpecification
- type - Variable in class org.apache.cassandra.cql3.functions.types.VectorCodec
- type - Variable in class org.apache.cassandra.cql3.statements.BatchStatement
- 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 class org.apache.cassandra.cql3.Vectors.Value
- type - Variable in enum org.apache.cassandra.db.compaction.OperationType
- type - Variable in class org.apache.cassandra.db.marshal.TypeParser.Vector
- type - Variable in class org.apache.cassandra.gms.GossiperEvent
- type - Variable in enum org.apache.cassandra.index.sai.disk.format.IndexComponent
- type - Variable in class org.apache.cassandra.io.sstable.Component
- type - Variable in class org.apache.cassandra.metrics.SamplingManager.ResultBuilder
- 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.audit.BinAuditLogger.Message
- type() - Method in class org.apache.cassandra.fql.FullQueryLogger.Batch
- type() - Method in class org.apache.cassandra.fql.FullQueryLogger.Query
- 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() - Method in class org.apache.cassandra.net.OutboundConnection
- type() - Method in class org.apache.cassandra.utils.binlog.BinLog.ReleaseableWriteMarshallable
- type(int) - Method in class org.apache.cassandra.db.marshal.TupleType
- type(String, String) - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
-
Creates a
DescribeStatement
forDESCRIBE TYPE
. - TYPE - org.apache.cassandra.cql3.SchemaElement.SchemaElementType
- TYPE - org.apache.cassandra.transport.Event.SchemaChange.Target
- TYPE - Static variable in class org.apache.cassandra.fql.FullQueryLogger
- TYPE - Static variable in class org.apache.cassandra.index.sai.metrics.AbstractMetrics
- 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
- TYPE_UDT_CONFLICT_BEHAVIOR - org.apache.cassandra.config.CassandraRelevantProperties
- 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
- TypeCodec(DataType, TypeToken<T>) - Constructor for class org.apache.cassandra.cql3.functions.types.TypeCodec
- 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.AbstractCollectionCodec<E,C extends java.util.Collection<E>> - Class in org.apache.cassandra.cql3.functions.types
- TypeCodec.AbstractMapCodec<K,V> - Class in org.apache.cassandra.cql3.functions.types
-
Base class for codecs mapping CQL
maps
to a JavaMap
. - 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.
- typeFor(SerializationNode<?>, long) - Static method in class org.apache.cassandra.io.tries.TrieNode
-
Returns a node type that is suitable to store the node.
- typeHashCode(List<AbstractType<?>>) - Static method in class org.apache.cassandra.schema.UserFunctions
- typeHashCode(AbstractType<?>) - Static method in class org.apache.cassandra.schema.UserFunctions
- 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
- TypeParser.Vector - Class in org.apache.cassandra.db.marshal
- types - Variable in class org.apache.cassandra.db.marshal.CompositeType.Serializer
- 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 method in class org.apache.cassandra.cql3.statements.DescribeStatement
-
Creates a
DescribeStatement
forDESCRIBE TYPES
. - Types - Class in org.apache.cassandra.schema
-
An immutable container for a keyspace's UDTs.
- Types() - Constructor for class org.apache.cassandra.io.sstable.format.big.BigFormat.Components.Types
- Types() - Constructor for class org.apache.cassandra.io.sstable.format.bti.BtiFormat.Components.Types
- Types() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableFormat.Components.Types
- TYPES - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
- 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<?>>) - Method in class org.apache.cassandra.cql3.functions.AbstractFunction
- TypeTokens - Class in org.apache.cassandra.cql3.functions.types
-
Utility methods to create
TypeToken
instances. - TypeUtil - Class in org.apache.cassandra.index.sasi.utils
- TypeUtil() - Constructor for class org.apache.cassandra.index.sasi.utils.TypeUtil
U
- ucs(Map<String, String>) - Static method in class org.apache.cassandra.schema.CompactionParams
- UCS_BASE_SHARD_COUNT - org.apache.cassandra.config.CassandraRelevantProperties
- UCS_MIN_SSTABLE_SIZE - org.apache.cassandra.config.CassandraRelevantProperties
- UCS_OVERLAP_INCLUSION_METHOD - org.apache.cassandra.config.CassandraRelevantProperties
- UCS_SCALING_PARAMETER - org.apache.cassandra.config.CassandraRelevantProperties
- UCS_SSTABLE_GROWTH - org.apache.cassandra.config.CassandraRelevantProperties
- UCS_SURVIVAL_FACTOR - org.apache.cassandra.config.CassandraRelevantProperties
- UCS_TARGET_SSTABLE_SIZE - org.apache.cassandra.config.CassandraRelevantProperties
- UDA - org.apache.cassandra.schema.UserFunctions.Filter
- 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 - Variable in class org.apache.cassandra.schema.KeyspaceMetadata.KeyspaceDiff
- udas() - Method in class org.apache.cassandra.schema.UserFunctions
- UDF - org.apache.cassandra.schema.UserFunctions.Filter
- UDF_EXECUTOR_THREAD_KEEPALIVE_MS - org.apache.cassandra.config.CassandraRelevantProperties
- 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 - Variable in class org.apache.cassandra.cql3.functions.UDFunction
- UDFContext - Interface in org.apache.cassandra.cql3.functions
-
Provides context information for a particular user defined function.
- UDFContextImpl - Class in org.apache.cassandra.cql3.functions
-
Package private implementation of
UDFContext
- UDFDataType - Class in org.apache.cassandra.cql3.functions
-
Represents a data type used within the UDF/UDA.
- udfs - Variable in class org.apache.cassandra.schema.KeyspaceMetadata.KeyspaceDiff
- udfs() - Method in class org.apache.cassandra.schema.UserFunctions
- udfType() - Method in class org.apache.cassandra.db.marshal.AbstractType
- udfType() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
- 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
- UDT - org.apache.cassandra.cql3.functions.types.DataType.Name
- UDT - org.apache.cassandra.transport.DataType
- 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.
- UDTS_WITH_DURATIONS_NOT_SUPPORTED - Static variable in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- UDTValue - Class in org.apache.cassandra.cql3.functions.types
-
A value for a User Defined Type.
- UNABLE_TO_CANCEL - org.apache.cassandra.db.compaction.CompactionManager.AllSSTableOpStatus
- UnaccessibleFieldException - Exception in org.apache.cassandra.exceptions
- UnaccessibleFieldException(String) - Constructor for exception org.apache.cassandra.exceptions.UnaccessibleFieldException
- UnaccessibleFieldException(String, Throwable) - Constructor for exception org.apache.cassandra.exceptions.UnaccessibleFieldException
- Unaligned(ChunkReader) - Constructor for class org.apache.cassandra.io.util.BufferManagingRebufferer.Unaligned
- UNAUTHORIZED - org.apache.cassandra.exceptions.ExceptionCode
- UNAUTHORIZED_ATTEMPT - org.apache.cassandra.audit.AuditLogEntryType
- 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
- UNAVAILABLE - org.apache.cassandra.exceptions.ExceptionCode
- 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
- unbind(String) - Method in class org.apache.cassandra.utils.JMXServerUtils.JmxRegistry
- 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
- unbuildTo(B, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
The method sets fields specific to this
SSTableReader
and the parentSSTable
on the providedSSTableReader.Builder
. - unbuildTo(B, boolean) - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderWithFilter
- unbuildTo(B, boolean) - Method in class org.apache.cassandra.io.sstable.SSTable
-
The method sets fields for this sstable representation on the provided
SSTable.Builder
. - unbuildTo(BigTableReader.Builder, boolean) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableReader
- unbuildTo(BtiTableReader.Builder, boolean) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableReader
- uncancellable() - Static method in class org.apache.cassandra.utils.concurrent.AsyncPromise
- uncancellable() - Static method in class org.apache.cassandra.utils.concurrent.SyncPromise
- uncancellable(GenericFutureListener<? extends Future<? super V>>) - Static method in class org.apache.cassandra.utils.concurrent.AsyncPromise
- uncancellable(GenericFutureListener<? extends Future<? super V>>) - Static method in class org.apache.cassandra.utils.concurrent.SyncPromise
- uncancellable(Executor) - Static method in class org.apache.cassandra.utils.concurrent.AsyncPromise
- uncancellable(Executor) - Static method in class org.apache.cassandra.utils.concurrent.SyncPromise
- UNCANCELLABLE - Static variable in class org.apache.cassandra.utils.concurrent.AbstractFuture
- uncaughtException(Thread, Throwable) - Static method in class org.apache.cassandra.utils.JVMStabilityInspector
- uncaughtExceptionHandler - Variable in class org.apache.cassandra.concurrent.NamedThreadFactory.MetaFactory
- 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
- UncheckedInterruptedException - Exception in org.apache.cassandra.utils.concurrent
-
Unchecked
InterruptedException
, to be thrown in places where an interrupt is unexpected - UncheckedInterruptedException() - Constructor for exception org.apache.cassandra.utils.concurrent.UncheckedInterruptedException
- UncheckedInterruptedException(InterruptedException) - Constructor for exception org.apache.cassandra.utils.concurrent.UncheckedInterruptedException
- uncheckedTombstoneCompaction - Variable in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
- uncommitted() - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosStateTracker
- UncommittedDataFile - Class in org.apache.cassandra.service.paxos.uncommitted
- uncommittedKeyIterator(TableId, Collection<Range<Token>>) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker
- UncommittedPaxosKey - Interface in org.apache.cassandra.service.paxos.uncommitted
- UncommittedTableData - Class in org.apache.cassandra.service.paxos.uncommitted
-
On memtable flush
- UncommittedTableData.FlushWriter - Interface in org.apache.cassandra.service.paxos.uncommitted
- uncommittedTracker() - Static method in class org.apache.cassandra.service.paxos.PaxosState
- uncompress(byte[], int, int, byte[], int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
- uncompress(byte[], int, int, byte[], int) - Method in interface org.apache.cassandra.io.compress.ICompressor
- uncompress(byte[], int, int, byte[], int) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
- uncompress(byte[], int, int, byte[], int) - Method in class org.apache.cassandra.io.compress.NoopCompressor
- uncompress(byte[], int, int, byte[], int) - 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(byte[], int, int, byte[], int, int) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
- uncompress(byte[], int, int, byte[], int, ICompressor) - Static method in class org.apache.cassandra.security.EncryptionUtils
- uncompress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
- uncompress(ByteBuffer, ByteBuffer) - Method in interface org.apache.cassandra.io.compress.ICompressor
-
Decompression for DirectByteBuffers.
- uncompress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.LZ4Compressor
- uncompress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.NoopCompressor
- uncompress(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.SnappyCompressor
- 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. - uncompressBuffer(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.compress.DeflateCompressor
- uncompressed_tables_enabled - Variable in class org.apache.cassandra.config.Config
- uncompressedLength() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Returns the length in bytes of the (uncompressed) data for this SSTable.
- uncompressedLiveDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Uncompressed/logical size of SSTables belonging to tables in this keyspace
- uncompressedLiveDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.TableMetrics
-
Uncompressed/logical disk space used by SSTables belonging to this table
- uncompressedLoad - Static variable in class org.apache.cassandra.metrics.StorageMetrics
- uncompressedTablesEnabled - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail disabling user's ability to turn off compression
- 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
- uncontendedPuts - Variable in class org.apache.cassandra.metrics.TrieMemtableMetricsView
- unconvert(Object) - Method in enum org.apache.cassandra.config.Converters
- unDoubleQuote(String) - Static method in class org.apache.cassandra.cql3.functions.types.ParseUtils
-
Unquote the given string if it is double quoted; double quotes are unescaped.
- UNENCRYPTED - org.apache.cassandra.config.EncryptionOptions.TlsEncryptionPolicy
- unescape(ByteSource.Peekable) - Static method in class org.apache.cassandra.utils.bytecomparable.ByteSourceInverse
-
As above, but converts the result to a ByteSource.
- 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() - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
- unfilteredIterator() - Method in interface org.apache.cassandra.db.partitions.Partition
-
Returns an UnfilteredRowIterator over all the rows/RT contained by this partition.
- unfilteredIterator(ColumnFilter, NavigableSet<Clustering<?>>, boolean) - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
- 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.
- unfilteredIterator(ColumnFilter, Slices, boolean) - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
- 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(BTreePartitionData, ColumnFilter, Slices, boolean) - Method in class org.apache.cassandra.db.partitions.AbstractBTreePartition
- unfilteredIterator(BTreePartitionData, ColumnFilter, Slices, boolean) - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
- 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) - Static method in class org.apache.cassandra.db.EmptyIterators
- unfilteredRow(TableMetadata, DecoratedKey, boolean, Row, DeletionTime) - 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
- UnfilteredRowIteratorWithLowerBound(DecoratedKey, SSTableReader, Slices, boolean, ColumnFilter, SSTableReadsListener) - Constructor for class org.apache.cassandra.db.rows.UnfilteredRowIteratorWithLowerBound
- unfilteredSerializer - Variable in class org.apache.cassandra.io.sstable.format.SortedTablePartitionWriter
- 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
- UnfilteredSource - Interface in org.apache.cassandra.db.rows
-
Common data access interface for sstables and memtables.
- 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
- unfreeze() - Method in class org.apache.cassandra.db.marshal.AbstractType
- unfreeze() - Method in class org.apache.cassandra.db.marshal.ListType
- unfreeze() - Method in class org.apache.cassandra.db.marshal.MapType
- unfreeze() - Method in class org.apache.cassandra.db.marshal.SetType
- unfreeze() - Method in class org.apache.cassandra.db.marshal.UserType
- UnifiedCompactionStrategy - Class in org.apache.cassandra.db.compaction
-
The design of the unified compaction strategy is described in the accompanying UnifiedCompactionStrategy.md.
- UnifiedCompactionStrategy(ColumnFamilyStore, Map<String, String>) - Constructor for class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- UnifiedCompactionStrategy(ColumnFamilyStore, Map<String, String>, Controller) - Constructor for class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- UnifiedCompactionStrategy.Level - Class in org.apache.cassandra.db.compaction
-
A level: index, sstables and some properties.
- UnifiedCompactionStrategy.MultiSetBucket - Class in org.apache.cassandra.db.compaction
- UnifiedCompactionStrategy.SimpleBucket - Class in org.apache.cassandra.db.compaction
- UnifiedCompactionTask - Class in org.apache.cassandra.db.compaction.unified
-
The sole purpose of this class is to currently create a
ShardedCompactionWriter
. - UnifiedCompactionTask(ColumnFamilyStore, UnifiedCompactionStrategy, LifecycleTransaction, long, ShardManager) - Constructor for class org.apache.cassandra.db.compaction.unified.UnifiedCompactionTask
- uninstall() - Method in class org.apache.cassandra.security.AbstractCryptoProvider
-
Uninstalls this crypto provider of name
AbstractCryptoProvider.getProviderName()
- union(OnDiskIndex...) - Static method in class org.apache.cassandra.index.sasi.utils.OnDiskIndexIterator
- UNION - org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.IteratorType
- UniqueIdentifier() - Constructor for class org.apache.cassandra.io.sstable.format.SSTableReader.UniqueIdentifier
- unit() - Method in class org.apache.cassandra.config.DataRateSpec
- unit() - Method in class org.apache.cassandra.config.DataStorageSpec
- unit() - Method in class org.apache.cassandra.config.DurationSpec
- unit() - Method in class org.apache.cassandra.utils.Backoff.ExponentialBackoff
- unit() - Method in enum org.apache.cassandra.utils.Backoff.None
- unit() - Method in interface org.apache.cassandra.utils.Backoff
- UNIT - Static variable in class org.apache.cassandra.db.compaction.CompactionInfo
- UNIT_TESTS - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- unix(TimeUnit) - Method in class org.apache.cassandra.utils.TimeUUID
-
The Cassandra internal micros-resolution timestamp of the TimeUUID, as of unix epoch
- unixMicros() - Method in class org.apache.cassandra.utils.TimeUUID
-
The Cassandra internal micros-resolution timestamp of the TimeUUID, as of unix epoch
- unixMicrosToRawTimestamp(long) - Static method in class org.apache.cassandra.utils.TimeUUID
- unixMillisToRawTimestamp(long, long) - Static method in class org.apache.cassandra.utils.TimeUUID
- UNKNOWN - org.apache.cassandra.db.compaction.OperationType
- UNKNOWN - org.apache.cassandra.exceptions.RequestFailureReason
- UNKNOWN - org.apache.cassandra.index.Index.Status
- UNKNOWN_GIT_SHA - Static variable in class org.apache.cassandra.utils.FBUtilities
- 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
- unload(boolean) - Method in class org.apache.cassandra.db.Keyspace
-
Unloads all column family stores and releases metrics.
- unloadCf() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- UnloadExecutionException(Object, Throwable) - Constructor for exception org.apache.cassandra.utils.concurrent.LoadingMap.UnloadExecutionException
- UNLOGGED - org.apache.cassandra.cql3.statements.BatchStatement.Type
- UNLOGGED_BATCH - org.apache.cassandra.db.WriteType
- 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
- unmask() - Method in class org.apache.cassandra.cql3.selection.Selector.InputRow
- UNMASK - org.apache.cassandra.auth.Permission
- unpauseConnection() - Method in class org.apache.cassandra.metrics.ClientMetrics
- UNPREPARED - org.apache.cassandra.exceptions.ExceptionCode
- UNPROTECTED - org.apache.cassandra.net.OutboundConnectionSettings.Framing
- UNREACHABLE - Static variable in class org.apache.cassandra.service.StorageProxy
- UNREADABLE_VERSION - Static variable in class org.apache.cassandra.utils.CassandraVersion
-
Used to indicate that there was a previous version written to the legacy (pre 1.2) system.Versions table, but that we cannot read it.
- UNRECOVERABLE_DESCRIPTOR_ERROR - org.apache.cassandra.db.commitlog.CommitLogReadHandler.CommitLogReadErrorReason
- UNRECOVERABLE_UNKNOWN_ERROR - org.apache.cassandra.db.commitlog.CommitLogReadHandler.CommitLogReadErrorReason
- 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(String, String) - Method in class org.apache.cassandra.metrics.SamplingManager
- unregister(AuthCache<?, ?>) - Method in class org.apache.cassandra.auth.AuthCacheService
- unregister(IEndpointStateChangeSubscriber) - Method in class org.apache.cassandra.gms.Gossiper
-
Unregister interest for state changes.
- unregister(IEndpointStateChangeSubscriber) - Method in interface org.apache.cassandra.gms.IGossiper
- unregister(IndexRegistry) - Method in interface org.apache.cassandra.index.Index
-
Unregister current index when it's removed from system
- unregister(IndexRegistry) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- 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
- unregisterComponents(Collection<Component>, Tracker) - Method in class org.apache.cassandra.io.sstable.SSTable
-
Unregisters custom components from sstable and update size tracking
- 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, Index.Group.Key) - Method in interface org.apache.cassandra.index.IndexRegistry
- unregisterIndex(Index, Index.Group.Key) - 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
- unregisterListener(SchemaChangeListener) - Method in class org.apache.cassandra.schema.SchemaChangeNotifier
- unregisterMBean() - Method in class org.apache.cassandra.auth.AuthCache
- unregisterMBean() - Method in class org.apache.cassandra.auth.CIDRPermissionsCache
- unregisterMBean() - Method in class org.apache.cassandra.auth.jmx.AuthorizationProxy.JmxPermissionsCache
- unregisterMBean() - Method in class org.apache.cassandra.auth.NetworkPermissionsCache
- unregisterMBean(String) - Method in interface org.apache.cassandra.utils.MBeanWrapper
- unregisterMBean(String, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.NoOpMBeanWrapper
- unregisterMBean(String, MBeanWrapper.OnException) - Method in interface org.apache.cassandra.utils.MBeanWrapper
- unregisterMBean(ObjectName) - Method in interface org.apache.cassandra.utils.MBeanWrapper
- unregisterMBean(ObjectName, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.DelegatingMbeanWrapper
- unregisterMBean(ObjectName, MBeanWrapper.OnException) - Method in class org.apache.cassandra.utils.MBeanWrapper.InstanceMBeanWrapper
- unregisterMBean(ObjectName, 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
- UNREPAIRED - org.apache.cassandra.streaming.PreviewKind
- UNREPAIRED_SSTABLE - Static variable in class org.apache.cassandra.service.ActiveRepairService
- unreplicatedLiveDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Disk space used by SSTables belonging to tables in this keyspace, scaled down by replication factor
- unreplicatedLoad - Static variable in class org.apache.cassandra.metrics.StorageMetrics
- unreplicatedUncompressedLiveDiskSpaceUsed - Variable in class org.apache.cassandra.metrics.KeyspaceMetrics
-
Uncompressed/logical size of SSTables belonging to tables in this keyspace, scaled down by replication factor
- unreplicatedUncompressedLoad - Static variable in class org.apache.cassandra.metrics.StorageMetrics
- UNRESOLVED - Static variable in interface org.apache.cassandra.cql3.functions.Function
-
A marker buffer used to represent function parameters that cannot be resolved at some stage of CQL processing.
- UNSAFE - org.apache.cassandra.concurrent.InfiniteLoopExecutor.SimulatorSafe
- UNSAFE_AGGRESSIVE_SSTABLE_EXPIRATION_KEY - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
- UNSAFE_SYSTEM - org.apache.cassandra.config.CassandraRelevantProperties
- unsafeAnnulEndpoint(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
- 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.
- unsafeCalculatePendingRanges(AbstractReplicationStrategy, String) - Method in class org.apache.cassandra.locator.TokenMetadata
- unsafeClear() - Method in class org.apache.cassandra.net.RequestCallbacks
- unsafeClearListeners() - Static method in class org.apache.cassandra.repair.consistent.LocalSessions
- unsafeClearRemoteState() - Method in class org.apache.cassandra.gms.Gossiper
- unsafeCloseControlChannel() - Method in class org.apache.cassandra.streaming.async.StreamingMultiplexedChannel
- unsafeConstruct(RegularAndStaticColumns, Object[], DeletionInfo, Row, EncodingStats) - Static method in class org.apache.cassandra.db.partitions.BTreePartitionData
- unsafeConstruct(ColumnMetadata, Object[], DeletionTime) - Static method in class org.apache.cassandra.db.rows.ComplexColumnData
- unsafeConstruct(TableMetadata, DecoratedKey, BTreePartitionData, MutableDeletionInfo, boolean) - Static method in class org.apache.cassandra.db.partitions.PartitionUpdate
- unsafeDeterministic(String, String) - Static method in class org.apache.cassandra.schema.TableId
- unsafeGetBufferAndFlip() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
-
Gets the underlying ByteBuffer and calls
ByteBuffer.flip()
. - unsafeGetEmpty() - Static method in class org.apache.cassandra.db.partitions.BTreePartitionData
- unsafeGetFilesystem() - Static method in class org.apache.cassandra.io.util.File
- unsafeGetHolder() - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
- unsafeGetIfPresent(DecoratedKey, TableMetadata) - Static method in class org.apache.cassandra.service.paxos.PaxosState
- unsafeGossipWith(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
- unsafeInitialize() - Method in class org.apache.cassandra.service.StorageService
- unsafeInvalidate(AtomicBTreePartition) - Static method in class org.apache.cassandra.db.partitions.BTreePartitionData
- unsafeMakeVersionedValue(String, int) - Static method in class org.apache.cassandra.gms.VersionedValue
- UnsafeOperations() - Constructor for class org.apache.cassandra.utils.FastByteOperations.UnsafeOperations
- unsafeReload() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
-
simulate index loading on restart with index file validation
- unsafeReset() - Static method in class org.apache.cassandra.metrics.RepairMetrics
- unsafeReset() - Static method in class org.apache.cassandra.service.paxos.PaxosState
- unsafeReset() - Method in class org.apache.cassandra.utils.memory.BufferPool
-
This is not thread safe and should only be used for unit testing.
- unsafeSendLocalEndpointStateTo(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
- unsafeSendShutdown(InetAddressAndPort) - Method in class org.apache.cassandra.gms.Gossiper
- unsafeSet(ExecutorFactory) - Static method in class org.apache.cassandra.concurrent.ExecutorFactory.Global
- unsafeSet(BallotGenerator) - Static method in class org.apache.cassandra.service.paxos.BallotGenerator.Global
- unsafeSet(StreamingChannel.Factory) - Static method in class org.apache.cassandra.streaming.StreamingChannel.Factory.Global
- unsafeSetClock(NoSpamLogger.Clock) - Static method in class org.apache.cassandra.utils.NoSpamLogger
- unsafeSetCodec(Message.Codec<?>) - Method in enum org.apache.cassandra.transport.Message.Type
- unsafeSetEnabled() - Method in class org.apache.cassandra.gms.Gossiper
- unsafeSetExecutor(ExecutorPlus) - Method in enum org.apache.cassandra.concurrent.Stage
- unsafeSetFilesystem(FileSystem) - Static method in class org.apache.cassandra.io.util.File
- unsafeSetHolder(BTreePartitionData) - Method in class org.apache.cassandra.db.partitions.AtomicBTreePartition
- unsafeSetSerializer(Supplier<? extends IVersionedAsymmetricSerializer<?, ?>>) - Method in enum org.apache.cassandra.net.Verb
- unsafeSetUpdateTimestamp(long) - Method in class org.apache.cassandra.gms.EndpointState
- UnsafeSnapshot(Commit) - Constructor for class org.apache.cassandra.service.paxos.PaxosState.UnsafeSnapshot
- UnsafeSnapshot(Commit.Committed) - Constructor for class org.apache.cassandra.service.paxos.PaxosState.UnsafeSnapshot
- unsafGetUpdateSupplier() - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker
- unsafSetUpdateSupplier(PaxosUncommittedTracker.UpdateSupplier) - Static method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedTracker
- UNSET - Static variable in class org.apache.cassandra.utils.concurrent.AbstractFuture
- 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
- unsetInitialized() - Static method in class org.apache.cassandra.db.Keyspace
-
Never use it in production code.
- UNSHARED_HEAP_SIZE - Static variable in class org.apache.cassandra.db.partitions.BTreePartitionData
- 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.partitions.PartitionUpdate
-
The size of the data contained in this update.
- 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.rows.ArrayCell
- unsharedHeapSize() - Method in class org.apache.cassandra.db.rows.BTreeRow
- unsharedHeapSize() - Method in class org.apache.cassandra.db.rows.BufferCell
- unsharedHeapSize() - Method in class org.apache.cassandra.db.rows.CellPath
- unsharedHeapSize() - Method in class org.apache.cassandra.db.rows.ColumnData
- unsharedHeapSize() - Method in class org.apache.cassandra.db.rows.ComplexColumnData
- unsharedHeapSize() - Method in class org.apache.cassandra.db.rows.EncodingStats
- unsharedHeapSize() - Method in class org.apache.cassandra.db.rows.NativeCell
- unsharedHeapSize() - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundaryMarker
- unsharedHeapSize() - Method in class org.apache.cassandra.db.rows.RangeTombstoneBoundMarker
- unsharedHeapSize() - Method in class org.apache.cassandra.db.rows.Row.Deletion
- unsharedHeapSize() - Method in interface org.apache.cassandra.db.rows.Row
- unsharedHeapSize() - Method in class org.apache.cassandra.index.sai.utils.PrimaryKeys
- unsharedHeapSize() - Method in class org.apache.cassandra.io.sstable.format.big.RowIndexEntry
- unsharedHeapSize() - Method in class org.apache.cassandra.io.sstable.IndexInfo
- unsharedHeapSize() - Method in class org.apache.cassandra.streaming.StreamingState
- 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
- unslabbed_heap_buffers - org.apache.cassandra.config.Config.MemtableAllocationType
- unslabbed_heap_buffers_logged - org.apache.cassandra.config.Config.MemtableAllocationType
- unsortedBuilder() - Static method in class org.apache.cassandra.db.rows.BTreeRow
- unsubscribe(Class<E>, Consumer<E>) - Method in class org.apache.cassandra.diag.DiagnosticEventService
-
De-registers event handler from receiving any further events.
- unsubscribe(Consumer<E>) - Method in class org.apache.cassandra.diag.DiagnosticEventService
-
De-registers event handler from receiving any further events.
- unsubscribe(INotificationConsumer) - Method in class org.apache.cassandra.db.lifecycle.Tracker
- 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
- UNSUPPORTED_NON_STRICT_OPERATOR - Static variable in class org.apache.cassandra.index.sai.plan.StorageAttachedIndexQueryPlan
- 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
- UNSYNCHRONIZED - org.apache.cassandra.concurrent.InfiniteLoopExecutor.Interrupts
- 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
- UNUSED_CUSTOM_VERB - org.apache.cassandra.net.Verb
- UNUSED1 - org.apache.cassandra.db.filter.RowFilter.Expression.Kind
- unusedReservedMemory() - Method in class org.apache.cassandra.db.memtable.TrieMemtable
- unusedReservedMemory() - Method in class org.apache.cassandra.db.tries.InMemoryTrie
- unvoid() - Method in class org.apache.cassandra.net.AsyncChannelPromise
- unwrap() - Method in class org.apache.cassandra.db.marshal.AbstractType
- 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.
- UP - org.apache.cassandra.transport.Event.StatusChange.Status
- update - Variable in class org.apache.cassandra.service.paxos.Commit
- update() - Method in class org.apache.cassandra.service.PendingRangeCalculatorService
- update(byte[], int, int) - Method in class org.apache.cassandra.db.Digest
- update(double) - Method in class org.apache.cassandra.utils.ExpMovingAverage
- update(double) - Method in interface org.apache.cassandra.utils.MovingAverage
- 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(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.MinMaxAvgMetric
- update(long) - Method in class org.apache.cassandra.metrics.ScalingReservoir
- update(long) - Method in class org.apache.cassandra.metrics.TableMetrics.TableHistogram
- update(long) - Method in class org.apache.cassandra.utils.streamhist.StreamingTombstoneHistogramBuilder
-
Adds new point to this histogram with a default value of 1.
- update(long, int) - Method in class org.apache.cassandra.utils.streamhist.StreamingTombstoneHistogramBuilder
-
Adds new point {@param point} with value {@param value} to this histogram.
- update(long, long) - Method in class org.apache.cassandra.index.sai.utils.AtomicRatio
- update(long, TimeUnit) - Method in class org.apache.cassandra.metrics.TableMetrics.TableTimer
- update(I) - Method in class org.apache.cassandra.utils.OverlapIterator
- update(Object[], Object[], Comparator<? super Compare>) - Static method in class org.apache.cassandra.utils.btree.BTree
- update(Object[], Object[], Comparator<? super Compare>, UpdateFunction<Insert, Existing>) - Static method in class org.apache.cassandra.utils.btree.BTree
-
Inserts
insert
intoupdate
, applyingupdateF
to each new item ininsert
, as well as any matched items inupdate
. - 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(String) - Method in class org.apache.cassandra.db.SimpleBuilders.MutationBuilder
- 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(Collection<SSTableReader>, boolean) - Method in interface org.apache.cassandra.db.lifecycle.ILifecycleTransaction
- update(Collection<SSTableReader>, boolean) - Method in class org.apache.cassandra.db.lifecycle.LifecycleTransaction
- update(Collection<SSTableReader>, boolean) - Method in class org.apache.cassandra.db.lifecycle.WrappedLifecycleTransaction
- update(Collection<SSTableReader>, Iterable<SSTableReader>, IndexValidation) - Method in class org.apache.cassandra.index.sai.SSTableContextManager
-
Initialize
SSTableContext
s if they are not already initialized. - update(Collection<SSTableReader>, Collection<SSTableContext>, IndexValidation) - Method in class org.apache.cassandra.index.sai.view.IndexViewManager
-
Replaces old SSTables with new by creating new immutable view.
- 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(Checksum, ByteBuffer) - Method in enum org.apache.cassandra.utils.ChecksumType
- update(DecoratedKey, Clustering<?>, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.index.sai.memory.MemoryIndex
- update(DecoratedKey, Clustering<?>, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.index.sai.memory.MemtableIndex
- update(DecoratedKey, Clustering<?>, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.index.sai.memory.TrieMemoryIndex
- update(DecoratedKey, Clustering<?>, ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.index.sai.memory.VectorMemoryIndex
- update(DecoratedKey, Row, Row, Memtable) - Method in class org.apache.cassandra.index.sai.memory.MemtableIndexManager
- update(DeletionTime) - Method in interface org.apache.cassandra.db.partitions.PartitionStatisticsCollector
- update(DeletionTime) - Method in class org.apache.cassandra.db.rows.EncodingStats.Collector
- update(DeletionTime) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- update(LivenessInfo) - Method in interface org.apache.cassandra.db.partitions.PartitionStatisticsCollector
- update(LivenessInfo) - Method in class org.apache.cassandra.db.rows.EncodingStats.Collector
- update(LivenessInfo) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- update(AbstractMemtable.ColumnsCollector) - Method in class org.apache.cassandra.db.memtable.AbstractMemtable.ColumnsCollector
- update(ReadCommand, WarningsSnapshot) - Static method in class org.apache.cassandra.service.reads.thresholds.CoordinatorWarnings
- update(RegularAndStaticColumns) - Method in class org.apache.cassandra.db.memtable.AbstractMemtable.ColumnsCollector
- update(Cell<?>) - Method in interface org.apache.cassandra.db.partitions.PartitionStatisticsCollector
- update(Cell<?>) - Method in class org.apache.cassandra.db.rows.EncodingStats.Collector
- update(Cell<?>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- update(EncodingStats) - Method in class org.apache.cassandra.db.memtable.AbstractMemtable.StatsCollector
- update(SimpleDataSet) - Method in class org.apache.cassandra.streaming.StreamingState.Sessions
- update(KeyRangeIterator) - Method in class org.apache.cassandra.index.sai.iterators.KeyRangeIterator.Builder.Statistics
- update(RangeIterator<K, D>) - Method in class org.apache.cassandra.index.sasi.utils.RangeIterator.Builder.Statistics
-
Update statistics information with the given range.
- update(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(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(TableMetadata) - Method in class org.apache.cassandra.db.SimpleBuilders.MutationBuilder
- update(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.Digest
- UPDATE - org.apache.cassandra.audit.AuditLogEntryType
- UPDATE - org.apache.cassandra.cql3.statements.StatementType
- UPDATE - org.apache.cassandra.index.transactions.IndexTransaction.Type
- 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 tonewTimestamp - 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 bynewTimestamp - 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 bynewTimestamp - 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 bynewTimestamp - 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.io.sstable.format.big.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) - Static method in class org.apache.cassandra.utils.FBUtilities
-
Updates checksum with the provided ByteBuffer.
- 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.
- updateChecksumInt(Checksum, int) - Static method in class org.apache.cassandra.utils.FBUtilities
- updateCidrGroup(String, List<String>) - Method in class org.apache.cassandra.auth.CIDRGroupsMappingManager
- updateCidrGroup(String, List<String>) - Method in interface org.apache.cassandra.auth.CIDRGroupsMappingManagerMBean
-
Insert/Update CIDR group to CIDRs mapping in the table
AuthKeyspace.CIDR_GROUPS
- updateCidrGroup(String, List<String>) - Method in class org.apache.cassandra.tools.NodeProbe
- UpdateCIDRGroup - Class in org.apache.cassandra.tools.nodetool
-
Nodetool command to insert/update a CIDR group and associated mapping in the table
AuthKeyspace.CIDR_GROUPS
- UpdateCIDRGroup() - Constructor for class org.apache.cassandra.tools.nodetool.UpdateCIDRGroup
- updateClusteringValues(Clustering<?>) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- updateClusteringValuesByBoundOrBoundary(ClusteringBoundOrBoundary<?>) - 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(TimeUUID, String, String, long[], long, long, Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.CompactionTask
- updateCompactionHistory(TimeUUID, String, String, long, long, long, Map<Integer, Long>, Map<String, String>) - Static method in class org.apache.cassandra.db.SystemKeyspace
- updateCounters(Map<ParamType, Object>, InetAddressAndPort) - Method in class org.apache.cassandra.service.reads.thresholds.WarningContext
- updated() - Method in class org.apache.cassandra.repair.state.AbstractCompletable
- UPDATED - org.apache.cassandra.db.lifecycle.LifecycleTransaction.ReaderState.Action
- UPDATED - org.apache.cassandra.transport.Event.SchemaChange.Change
- updatedColumns - Variable in class org.apache.cassandra.cql3.UpdateParameters
- updatedColumns() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- 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
- updatedProperties() - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
-
Returns the name of all the properties that are updated by this object.
- updatedViews(PartitionUpdate) - Method in class org.apache.cassandra.db.view.TableViews
-
Return the views that are potentially updated by the provided updates.
- updateEndTime(long) - Method in class org.apache.cassandra.metrics.Sampler
-
Update the end time for the sampler.
- updateEntireSSTableInterDCThroughput() - Static method in class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
- updateEntireSSTableThroughput() - Static method in class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
- updateFromMap(Map<String, ?>, boolean, T) - Static method in class org.apache.cassandra.config.YamlConfigurationLoader
- UpdateFunction<K,V> - Interface in org.apache.cassandra.utils.btree
-
An interface defining the method to be applied to the existing and replacing object in a BTree.
- UpdateFunction.Simple<V> - Class in org.apache.cassandra.utils.btree
- updateHandler - Variable in class org.apache.cassandra.schema.Schema
- 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, TimeUUID, 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.
- updateHostIds(Map<UUID, InetAddressAndPort>) - Method in class org.apache.cassandra.locator.TokenMetadata
- updateIndexTableMetadata(TableParams) - Method in class org.apache.cassandra.schema.TableMetadata
- updateInitialSSTableSize(Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.lifecycle.Tracker
- updateInterDCThroughput() - Static method in class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
- updateLastValidSegmentRowId(long) - Static method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder
- updateLeaves(Object[], Object[], Comparator<? super Compare>, UpdateFunction<Insert, Existing>) - Static method in class org.apache.cassandra.utils.btree.BTree
-
A fast tight-loop variant of updating one btree with another, when both are leaves.
- updateLiveDiskSpaceUsed(long) - Method in class org.apache.cassandra.db.lifecycle.Tracker
- updateLocalDeletionTime(long) - Method in class org.apache.cassandra.db.rows.EncodingStats.Collector
- updateLocalState(double, Consumer<DiskUsageState>) - Method in class org.apache.cassandra.service.disk.usage.DiskUsageMonitor
- updateLowBound(Ballot) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosBallotTracker
- updateMin(AtomicInteger, int) - Static method in class org.apache.cassandra.db.memtable.AbstractMemtable
- updateMin(AtomicLong, long) - Static method in class org.apache.cassandra.db.memtable.AbstractMemtable
- 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(Multimap<InetAddressAndPort, Token>) - Method in class org.apache.cassandra.locator.TokenMetadata
-
Update token map with a set of token/endpoint pairs in normal state.
- updateNormalTokens(Collection<Token>, InetAddressAndPort) - Method in class org.apache.cassandra.locator.TokenMetadata
- updateOpenMarker(RangeTombstoneMarker) - Method in class org.apache.cassandra.io.sstable.AbstractSSTableIterator.AbstractReader
- 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, ClientState, QueryOptions, long, long, int, Map<DecoratedKey, Partition>) - Constructor for class org.apache.cassandra.cql3.UpdateParameters
- updatePartitionDeletion(DeletionTime) - Method in interface org.apache.cassandra.db.partitions.PartitionStatisticsCollector
- updatePartitionDeletion(DeletionTime) - Method in class org.apache.cassandra.db.rows.EncodingStats.Collector
- updatePartitionDeletion(DeletionTime) - Method in class org.apache.cassandra.io.sstable.metadata.MetadataCollector
- 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
- updateScores() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
- 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
- updateSSTableIteratedInRangeRead(int) - Method in class org.apache.cassandra.metrics.TableMetrics
- updatesStaticRow() - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- updateState(S, I, AbstractPaxosRepair.StateUpdater<S, I, T>) - Method in class org.apache.cassandra.service.paxos.AbstractPaxosRepair
- updateState(T) - Method in class org.apache.cassandra.repair.state.AbstractState
- 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
- updateStateUnsafe(Function<PaxosState.Snapshot, PaxosState.Snapshot>) - Method in class org.apache.cassandra.service.paxos.PaxosState
- updateSystemKeyspace(KeyspaceMetadata, long) - Static method in class org.apache.cassandra.schema.SchemaTransformations
-
We have a set of non-local, distributed system keyspaces, e.g.
- 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
- updateThroughput() - Static method in class org.apache.cassandra.streaming.StreamManager.StreamRateLimiter
- 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(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
- updateTokens(InetAddressAndPort, Collection<Token>) - Static method in class org.apache.cassandra.db.SystemKeyspace
-
Record tokens being used by another node
- 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() - Method in class org.apache.cassandra.service.StorageService
- 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(InetAddressAndPort) - 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
- 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.TimeUUID.Generator
- upgrade(boolean) - Method in class org.apache.cassandra.db.compaction.Upgrader
- UPGRADE_SSTABLES - org.apache.cassandra.db.compaction.OperationType
- upgradeInput(ChecksummedDataInput, Cipher, ICompressor) - Static method in class org.apache.cassandra.hints.EncryptedChecksummedDataInput
- upgradeInput(ChecksummedDataInput, ICompressor) - Static method in class org.apache.cassandra.hints.CompressedChecksummedDataInput
- 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(PrintStream, String, boolean, long, int, String...) - Method in class org.apache.cassandra.tools.NodeProbe
- upgradeSSTables(String, boolean, int, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-16837
- upgradeSSTables(String, boolean, long, int, String...) - Method in class org.apache.cassandra.service.StorageService
- upgradeSSTables(String, boolean, long, int, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
- upgradeSSTables(String, boolean, long, int, String...) - Method in class org.apache.cassandra.tools.NodeProbe
- upgradeSSTables(String, boolean, String...) - Method in class org.apache.cassandra.service.StorageService
- upgradeSSTables(String, boolean, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Deprecated.See CASSANDRA-11179
- UPGRADING - org.apache.cassandra.utils.StorageCompatibilityMode
-
Use the storage formats of the current version, but disabling features that are not compatible with any not-upgraded nodes in the cluster.
- uploadComponents() - Method in class org.apache.cassandra.io.sstable.format.big.BigFormat
- uploadComponents() - Method in class org.apache.cassandra.io.sstable.format.bti.BtiFormat
- uploadComponents() - Method in interface org.apache.cassandra.io.sstable.format.SSTableFormat
-
Returns the components which should be selected for upload by the sstable loader.
- upper - Variable in class org.apache.cassandra.index.sai.plan.Expression
- upper - Variable in class org.apache.cassandra.index.sasi.plan.Expression
- upper() - Method in class org.apache.cassandra.index.sai.plan.Expression
- upper() - Method in class org.apache.cassandra.utils.IntegerInterval
- upperBound - Variable in class org.apache.cassandra.utils.btree.BTreeSet.BTreeRange
- upperBound() - Method in class org.apache.cassandra.db.commitlog.IntervalSet
- upperBound() - Method in class org.apache.cassandra.utils.IntegerInterval.Set
-
Returns an upper bound for the whole set.
- UpperCase() - Constructor for class org.apache.cassandra.index.sasi.analyzer.filter.BasicResultFilters.UpperCase
- UpperCase(Locale) - 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
- upperInclusive - Variable in class org.apache.cassandra.index.sai.plan.Expression
- 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
- URGENT_MESSAGES - org.apache.cassandra.net.ConnectionType
- 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
- usableSpace(FileStore) - Static method in class org.apache.cassandra.service.disk.usage.DiskUsageMonitor
- USAGE_WARNING - Static variable in class org.apache.cassandra.db.view.View
- USAGE_WARNING - Static variable in class org.apache.cassandra.index.sasi.SASIIndex
- usageExceedsLimit() - Method in class org.apache.cassandra.index.sai.utils.NamedMemoryLimiter
- USE_BETA - org.apache.cassandra.transport.Envelope.Header.Flag
- use_deterministic_table_id - Variable in class org.apache.cassandra.config.Config
- USE_HEAP_ALLOCATOR - Static variable in class org.apache.cassandra.transport.CBUtil
- USE_KEYSPACE - org.apache.cassandra.audit.AuditLogEntryType
- USE_NIX_RECURSIVE_DELETE - org.apache.cassandra.config.CassandraRelevantProperties
-
When enabled, recursive directory deletion will be executed using a unix command `rm -rf` instead of traversing and removing individual files.
- use_offheap_merkle_trees - Variable in class org.apache.cassandra.config.Config
- use_statements_enabled - 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
- used() - Method in class org.apache.cassandra.utils.memory.MemtablePool.SubPool
- useDeterministicTableID() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- useDeterministicTableID(boolean) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
- 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
- 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
- useNewPreparedStatementBehaviour() - Method in class org.apache.cassandra.cql3.QueryProcessor
- 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 - org.apache.cassandra.db.filter.RowFilter.Expression.Kind
- USER - Static variable in class org.apache.cassandra.transport.ConnectedClient
- user_defined_functions_enabled - Variable in class org.apache.cassandra.config.Config
- user_defined_functions_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_functions_threads_enabled - Variable in class org.apache.cassandra.config.Config
-
Optionally disable asynchronous UDF execution.
- user_defined_functions_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_FORCED - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- user_function_timeout_policy - Variable in class org.apache.cassandra.config.Config
-
Defines what to do when a UDF ran longer than user_defined_functions_fail_timeout.
- USER_HOME - org.apache.cassandra.config.CassandraRelevantProperties
-
User's home directory.
- USER_OPTION - Static variable in class org.apache.cassandra.tools.LoaderOptions
- user_timestamps_enabled - Variable in class org.apache.cassandra.config.Config
- USER_TYPE_SELECTOR - org.apache.cassandra.cql3.selection.Selector.Kind
- UserExpression(ColumnMetadata, Operator, ByteBuffer) - Constructor for class org.apache.cassandra.db.filter.RowFilter.UserExpression
- UserFunction - Class in org.apache.cassandra.cql3.functions
-
A non-native, user-defined function, like UDFs and UDAs.
- UserFunction(FunctionName, List<AbstractType<?>>, AbstractType<?>) - Constructor for class org.apache.cassandra.cql3.functions.UserFunction
- userFunctions - Variable in class org.apache.cassandra.schema.KeyspaceMetadata
- UserFunctions - Class in org.apache.cassandra.schema
-
An immutable container for a keyspace's UDAs and UDFs.
- UserFunctions.Builder - Class in org.apache.cassandra.schema
- UserFunctions.Filter - Enum in org.apache.cassandra.schema
- UserFunctions.FunctionsDiff<T extends Function> - Class in org.apache.cassandra.schema
- 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
- userTimestampsEnabled - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail disabling user-provided timestamps.
- 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(UTName) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
- 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. - 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.
- usesStrictFiltering() - Method in class org.apache.cassandra.index.sai.plan.QueryController
- UseStatement - Class in org.apache.cassandra.cql3.statements
- UseStatement(String) - Constructor for class org.apache.cassandra.cql3.statements.UseStatement
- useStatementsExecuted - Variable in class org.apache.cassandra.metrics.CQLMetrics
- useStrictConsistency - Static variable in class org.apache.cassandra.service.StorageService
- useV2() - Static method in class org.apache.cassandra.service.paxos.Paxos
- 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
- using(String) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
The INSERT, UPDATE, or DELETE statement defining the order of the values to add for a given CQL row.
- 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() - 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(String) - Static method in class org.apache.cassandra.cql3.Constants.Literal
- UUID - org.apache.cassandra.cql3.Constants.Type
- UUID - org.apache.cassandra.cql3.CQL3Type.Native
- UUID - org.apache.cassandra.cql3.functions.types.DataType.Name
- UUID - org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.TermSize
- UUID - org.apache.cassandra.transport.DataType
- UUID_EPOCH_UNIX_MILLIS - Static variable in class org.apache.cassandra.utils.TimeUUID
- UUID_LEN - Static variable in class org.apache.cassandra.utils.UUIDGen
- UUID_SIZE - Static variable in class org.apache.cassandra.db.TypeSizes
- uuid_sstable_identifiers_enabled - Variable in class org.apache.cassandra.config.Config
- UUID_VERSION_BITS_IN_MSB - Static variable in class org.apache.cassandra.utils.TimeUUID
- UUIDBasedSSTableId - Class in org.apache.cassandra.io.sstable
-
SSTable generation identifiers that can be stored across nodes in one directory/bucket
- UUIDBasedSSTableId(TimeUUID) - Constructor for class org.apache.cassandra.io.sstable.UUIDBasedSSTableId
- UUIDBasedSSTableId.Builder - Class in org.apache.cassandra.io.sstable
- 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.
- UUIDGen() - Constructor for class org.apache.cassandra.utils.UUIDGen
- UUIDSerializer - Class in org.apache.cassandra.serializers
- UUIDSerializer - Class in org.apache.cassandra.utils
- UUIDSerializer() - Constructor for class org.apache.cassandra.serializers.UUIDSerializer
- UUIDSerializer() - Constructor for class org.apache.cassandra.utils.UUIDSerializer
- uuidTimestamp() - Method in class org.apache.cassandra.utils.TimeUUID
-
The UUID-format timestamp, i.e.
- 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
- v1 - org.apache.cassandra.config.Config.PaxosVariant
-
v1 Paxos lacks most optimisations.
- V1 - org.apache.cassandra.transport.ProtocolVersion
- v1_without_linearizable_reads_or_rejected_writes - org.apache.cassandra.config.Config.PaxosVariant
-
v1 Paxos lacks most optimisations.
- V1OnDiskFormat - Class in org.apache.cassandra.index.sai.disk.v1
- V1OnDiskFormat() - Constructor for class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- V1SSTableIndex - Class in org.apache.cassandra.index.sai.disk.v1
-
A version specific implementation of the
SSTableIndex
where the index is segmented - V1SSTableIndex(SSTableContext, StorageAttachedIndex) - Constructor for class org.apache.cassandra.index.sai.disk.v1.V1SSTableIndex
- v2 - org.apache.cassandra.config.Config.PaxosVariant
-
v2 Paxos.
- V2 - org.apache.cassandra.transport.ProtocolVersion
- v2_without_linearizable_reads - org.apache.cassandra.config.Config.PaxosVariant
-
v2 Paxos.
- v2_without_linearizable_reads_or_rejected_writes - org.apache.cassandra.config.Config.PaxosVariant
-
v2 Paxos.
- V3 - org.apache.cassandra.transport.ProtocolVersion
- V4 - org.apache.cassandra.transport.ProtocolVersion
- V5 - org.apache.cassandra.transport.ProtocolVersion
- V6 - org.apache.cassandra.transport.ProtocolVersion
- validate() - Method in class org.apache.cassandra.auth.CIDRPermissions
-
Validates does this object contains valid CIDR groups
- 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() - Method in class org.apache.cassandra.config.StorageAttachedIndexOptions
- validate() - Method in class org.apache.cassandra.cql3.statements.BatchStatement
- 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() - Method in interface org.apache.cassandra.db.ClusteringPrefix
- validate() - Method in class org.apache.cassandra.db.DeletionTime.InvalidDeletionTime
- validate() - Method in class org.apache.cassandra.db.DeletionTime
-
Check if this deletion time is valid.
- 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() - 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() - Method in class org.apache.cassandra.io.sstable.format.SSTableReader
-
Perform any validation needed for the reader upon creation before returning it from the
SSTableReader.Builder
. - validate() - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.FileDigestValidator
- validate() - Method in class org.apache.cassandra.schema.CompactionParams
- validate() - Method in class org.apache.cassandra.schema.CompressionParams
- validate() - Method in class org.apache.cassandra.schema.KeyspaceMetadata
- validate() - Method in class org.apache.cassandra.schema.Keyspaces
- 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(byte[], int, int) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
- validate(int, ClusteringComparator) - Method in interface org.apache.cassandra.db.ClusteringPrefix
- validate(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
- validate(String) - Static method in class org.apache.cassandra.io.sstable.format.Version
- validate(String, ClientState) - Method in class org.apache.cassandra.schema.KeyspaceParams
- validate(String, ClientState) - Method in class org.apache.cassandra.schema.ReplicationParams
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.DynamicCompositeType.FixedValueComparator
- validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
- validate(ByteBuffer) - Method in class org.apache.cassandra.io.util.DataIntegrityMetadata.ChecksumValidator
-
validates the checksum with the bytes from the specified buffer.
- validate(ByteBuffer) - Method in class org.apache.cassandra.serializers.TypeSerializer
- validate(Collection<? extends AbstractBounds<?>>) - Static method in interface org.apache.cassandra.dht.IPartitioner
- 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(Set<String>, Set<String>) - Method in class org.apache.cassandra.cql3.statements.PropertyDefinitions
- 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(AuditLogOptions) - Static method in class org.apache.cassandra.audit.AuditLogOptions
- validate(ClusteringPrefix<T>) - Method in class org.apache.cassandra.db.ClusteringComparator
-
Validates the provided prefix for corrupted data.
- validate(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier.RangeOwnHelper
-
check if the given key is contained in any of the given ranges
- validate(PartitionUpdate, ClientState) - 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(PartitionUpdate, ClientState) - 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(PartitionUpdate, ClientState) - Method in class org.apache.cassandra.index.internal.CassandraIndex
- validate(PartitionUpdate, ClientState) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- validate(PartitionUpdate, ClientState) - Method in class org.apache.cassandra.index.sasi.SASIIndex
- validate(PartitionUpdate, ClientState) - 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(PartitionUpdate, ClientState) - Method in class org.apache.cassandra.service.paxos.uncommitted.PaxosUncommittedIndex
- validate(UnfilteredPartitionIterator, RTBoundValidator.Stage, boolean) - Static method in class org.apache.cassandra.db.transform.RTBoundValidator
- validate(ReadCommand) - Method in interface org.apache.cassandra.index.Index.QueryPlan
-
Used to validate the various parameters of a supplied
ReadCommand
against the indexes in this plan. - 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(ReadCommand) - Method in class org.apache.cassandra.index.internal.CassandraIndex
- validate(ReadCommand) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- validate(UnfilteredRowIterator, RTBoundValidator.Stage, boolean) - Static method in class org.apache.cassandra.db.transform.RTBoundValidator
- validate(AbstractBounds<?>) - Static method in interface org.apache.cassandra.dht.IPartitioner
- validate(TableMetadata) - Method in class org.apache.cassandra.schema.Indexes
- validate(TableMetadata) - Method in class org.apache.cassandra.schema.IndexMetadata
- 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.AddIdentityStatement
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.AlterRoleStatement
- 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.DropIdentityStatement
- 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(ClientState) - Method in class org.apache.cassandra.cql3.statements.RoleManagementStatement
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.AlterSchemaStatement
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement.MaskColumn
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.AlterTableStatement
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.AlterViewStatement
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateIndexStatement
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateKeyspaceStatement
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTableStatement
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateTypeStatement
- validate(ClientState) - Method in class org.apache.cassandra.cql3.statements.schema.CreateViewStatement
- 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(ClientState, String) - Method in class org.apache.cassandra.cql3.CQL3Type.Raw
- validate(IndexInput) - Static method in class org.apache.cassandra.index.sai.disk.v1.SAICodecUtils
- validate(IndexInput, long) - Static method in class org.apache.cassandra.index.sai.disk.v1.SAICodecUtils
- 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(T, ValueAccessor<T>) - Method in class org.apache.cassandra.serializers.MapSerializer
- validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.AbstractCompositeType
- validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.AbstractType
- validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.db.marshal.CollectionType
- 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(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.ListSerializer
- validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.LongSerializer
- validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.serializers.SetSerializer
- 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.TupleSerializer
- validate(V, ValueAccessor<V>) - 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
- validate(V, ValueAccessor<V>) - Method in class org.apache.cassandra.utils.TimeUUID.AbstractSerializer
- 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
- validateChecksum(IndexInput) - Static method in class org.apache.cassandra.index.sai.disk.v1.SAICodecUtils
-
See
CodecUtil.checksumEntireFile(org.apache.lucene.store.IndexInput)
. - 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
- validateCompatibility(TableMetadata) - Method in class org.apache.cassandra.schema.TableMetadata
- 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.AbstractCIDRAuthorizer
- 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.ICIDRAuthorizer
- 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.MutualTlsAuthenticator
- validateConfiguration() - Method in class org.apache.cassandra.auth.MutualTlsInternodeAuthenticator
- validateConfiguration() - Method in class org.apache.cassandra.auth.PasswordAuthenticator
- 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.
- validateDefaultTimeToLive(TableParams) - Method in class org.apache.cassandra.cql3.statements.schema.AlterSchemaStatement
- validateDiskUsage(QueryOptions, ClientState) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- validateDuration(Duration) - Method in class org.apache.cassandra.cql3.functions.TimeFcts.FloorDateFunction
- 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
- validateFooterAndResetPosition(IndexInput) - Static method in class org.apache.cassandra.index.sai.disk.v1.SAICodecUtils
- validateForCas() - Method in enum org.apache.cassandra.db.ConsistencyLevel
- validateForCasCommit(AbstractReplicationStrategy) - Method in enum org.apache.cassandra.db.ConsistencyLevel
- validateForGroupBy() - Method in class org.apache.cassandra.cql3.selection.Selector
-
Checks that this selector is valid for GROUP BY clause.
- validateForGroupBy() - Method in class org.apache.cassandra.cql3.selection.SimpleSelector
- validateForIndexing() - Method in class org.apache.cassandra.db.filter.RowFilter.Expression
-
Deprecated.See CASSANDRA-6377
- validateForRead() - Method in enum org.apache.cassandra.db.ConsistencyLevel
- validateForWrite() - Method in enum org.apache.cassandra.db.ConsistencyLevel
- validateIndexable(float[], VectorSimilarityFunction) - Static method in class org.apache.cassandra.index.sai.disk.v1.vector.OnHeapGraph
- validateIndexChecksum - Variable in class org.apache.cassandra.db.SSTableImporter.Options
- validateIndexedColumns(ClientState) - Method in interface org.apache.cassandra.db.IMutation
- validateIndexedColumns(ClientState) - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
- validateIndexedColumns(ClientState) - 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() - 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
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.LeveledCompactionStrategy
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategy
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategy
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.unified.Controller
- validateOptions(Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.UnifiedCompactionStrategy
- validateOptions(Map<String, String>, Map<String, String>) - Static method in class org.apache.cassandra.db.compaction.SizeTieredCompactionStrategyOptions
- 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.sai.StorageAttachedIndex
-
Used via reflection in
IndexMetadata
- validateOptions(Map<String, String>, TableMetadata) - Static method in class org.apache.cassandra.index.sasi.SASIIndex
- validatePartitioner(TableMetadata, ValidationMetadata) - Method in class org.apache.cassandra.io.sstable.format.SSTableReaderLoadingBuilder
-
Check if sstable is created using same partitioner.
- validatePassword(boolean, String) - Method in class org.apache.cassandra.security.FileBasedSslContextFactory
-
Validates the given keystore password.
- validatePeerCompatibility(SharedContext, TableMetadata, Collection<Range<Token>>) - Static method in class org.apache.cassandra.service.paxos.PaxosRepair
- validatePerColumnIndexComponents(IndexDescriptor, IndexTermType, IndexIdentifier, boolean) - Method in interface org.apache.cassandra.index.sai.disk.format.OnDiskFormat
-
Validate all the per-column on-disk components and throw if a component is not valid
- validatePerColumnIndexComponents(IndexDescriptor, IndexTermType, IndexIdentifier, boolean) - Method in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- validatePerIndexComponents(IndexTermType, IndexIdentifier, IndexValidation, boolean, boolean) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- validatePerSSTableComponents(IndexValidation, boolean, boolean) - Method in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- validatePerSSTableIndexComponents(IndexDescriptor, boolean) - Method in interface org.apache.cassandra.index.sai.disk.format.OnDiskFormat
-
Validate all the per-SSTable on-disk components and throw if a component is not valid
- validatePerSSTableIndexComponents(IndexDescriptor, boolean) - Method in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- validateReallocation(long) - Method in class org.apache.cassandra.io.util.SafeMemoryWriter
- validateRepairedMetadata(long, TimeUUID, 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>, ClientState) - 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
- validateSSTableAttachedIndexes(Collection<SSTableReader>, boolean, boolean) - Method in interface org.apache.cassandra.index.Index.Group
-
Validates all indexes in the group against the specified SSTables.
- validateSSTableAttachedIndexes(Collection<SSTableReader>, boolean, boolean) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndexGroup
- validateSSTableAttachedIndexes(Collection<SSTableReader>, boolean, boolean) - Method in class org.apache.cassandra.index.SecondaryIndexManager
-
Validates all index groups against the specified SSTables.
- validateSstableFormat(SSTableFormat<?, ?>) - Method in enum org.apache.cassandra.utils.StorageCompatibilityMode
- validateTable(String, String) - Method in class org.apache.cassandra.schema.Schema
- validateTermSize(DecoratedKey, ByteBuffer, boolean, ClientState) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- validateTermSizeForRow(DecoratedKey, Row, boolean, ClientState) - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
-
Validate maximum term size for given row
- validateTimestamp(QueryState, QueryOptions) - Method in class org.apache.cassandra.cql3.statements.ModificationStatement
- validateTimestampThreshold(DurationSpec.LongMicrosecondsBound, DurationSpec.LongMicrosecondsBound, String) - Static method in class org.apache.cassandra.config.GuardrailsOptions
- 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.
- validateType(FunctionName, AssignmentTestable, AbstractType<?>) - Method in interface org.apache.cassandra.cql3.functions.FunctionParameter
- validateUserTypeAssignableTo(ColumnSpecification, Map<FieldIdentifier, T>) - Static method in class org.apache.cassandra.cql3.UserTypes
- validation() - Method in class org.apache.cassandra.repair.state.ParticipateState.Job
- validation(UUID) - Method in class org.apache.cassandra.service.ActiveRepairService
- validation(RepairJobDesc) - Method in class org.apache.cassandra.repair.state.ParticipateState
- 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 - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- VALIDATION - org.apache.cassandra.db.compaction.OperationType
- VALIDATION - org.apache.cassandra.io.sstable.metadata.MetadataType
-
Metadata only used for SSTable validation
- VALIDATION - org.apache.cassandra.repair.state.ParticipateState.Job.State
- VALIDATION_COMPLETE - org.apache.cassandra.repair.state.JobState.State
- validation_preview_purge_head_start - 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
- VALIDATION_REQ - org.apache.cassandra.net.Verb
- VALIDATION_RSP - org.apache.cassandra.net.Verb
- VALIDATION_START - org.apache.cassandra.repair.state.JobState.State
- validationComplete(RepairJobDesc, Message<ValidationResponse>) - Method in class org.apache.cassandra.repair.RepairSession
-
Receive merkle tree response or failed response from
endpoint
for current repair job. - validationCompleted() - Method in class org.apache.cassandra.repair.state.JobState.Phase
- ValidationExecutor() - Constructor for class org.apache.cassandra.db.compaction.CompactionManager.ValidationExecutor
- validationIds() - Method in class org.apache.cassandra.repair.state.ParticipateState
- validationManager() - Method in class org.apache.cassandra.repair.SharedContext.ForwardingSharedContext
- validationManager() - Method in class org.apache.cassandra.repair.SharedContext.Global
- validationManager() - Method in interface org.apache.cassandra.repair.SharedContext
- ValidationManager - Class in org.apache.cassandra.repair
- validationMetadata() - Method in class org.apache.cassandra.io.sstable.format.StatsComponent
- 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, long) - 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
- validations() - Method in class org.apache.cassandra.repair.state.ParticipateState
- validations() - Method in class org.apache.cassandra.service.ActiveRepairService
- validationScheduler - Variable in class org.apache.cassandra.repair.RepairSession
- ValidationState - Class in org.apache.cassandra.repair.state
- ValidationState(Clock, RepairJobDesc, InetAddressAndPort) - Constructor for class org.apache.cassandra.repair.state.ValidationState
- ValidationState.Phase - Class in org.apache.cassandra.repair.state
- ValidationState.State - Enum in org.apache.cassandra.repair.state
- validationSubmitted() - Method in class org.apache.cassandra.repair.state.JobState.Phase
- ValidationTask - Class in org.apache.cassandra.repair
-
ValidationTask sends
ValidationRequest
to a replica. - ValidationTask(SharedContext, RepairJobDesc, InetAddressAndPort, long, 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(SharedContext, ValidationState, long, boolean, boolean, PreviewKind) - Constructor for class org.apache.cassandra.repair.Validator
- Validator(SharedContext, ValidationState, long, boolean, PreviewKind) - Constructor for class org.apache.cassandra.repair.Validator
- Validator(ValidationState, long, boolean, PreviewKind) - Constructor for class org.apache.cassandra.repair.Validator
- Validator(ValidationState, long, PreviewKind) - Constructor for class org.apache.cassandra.repair.Validator
- validKeywords() - Static method in class org.apache.cassandra.cql3.statements.schema.TableAttributes
- validSimilarityFunctions - Static variable in class org.apache.cassandra.index.sai.disk.v1.IndexWriterConfig
- validTimestampTimeUnits - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
- validWindowTimeUnits - Static variable in class org.apache.cassandra.db.compaction.TimeWindowCompactionStrategyOptions
- value - Variable in class org.apache.cassandra.config.RetrySpec.MaxAttempt
- value - Variable in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.EQRestriction
- value - Variable in class org.apache.cassandra.db.filter.RowFilter.Expression
- value - Variable in enum org.apache.cassandra.exceptions.ExceptionCode
- value - Variable in class org.apache.cassandra.gms.VersionedValue
- value - Variable in class org.apache.cassandra.index.sai.plan.Expression.Bound
- 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 class org.apache.cassandra.metrics.TopPartitionTracker.TopPartition
- value - Variable in enum org.apache.cassandra.net.MessagingService.Version
- value - Variable in class org.apache.cassandra.utils.ExpiringMemoizingSupplier.ReturnValue
- value - Variable in exception org.apache.cassandra.utils.vint.VIntCoding.VIntOutOfRangeException
- value() - Method in annotation type org.apache.cassandra.config.ReplacesList
- 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() - Method in class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable.ColumnValue
-
Returns the column value.
- value() - Method in annotation type org.apache.cassandra.utils.BreaksJMX
- value() - Method in exception org.apache.cassandra.utils.concurrent.LoadingMap.UnloadExecutionException
- value() - Method in class org.apache.cassandra.utils.DefaultValue
- value() - Method in class org.apache.cassandra.utils.ExpiringMemoizingSupplier.ReturnValue
- value(int) - Method in class org.apache.cassandra.db.virtual.AbstractMutableVirtualTable.ColumnValues
-
Returns the value for the specified column
- value(QueryOptions) - Method in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.AnnRestriction
- Value(ByteBuffer) - Constructor for class org.apache.cassandra.cql3.Constants.Value
- Value(ByteBuffer[]) - Constructor for class org.apache.cassandra.cql3.Tuples.Value
- Value(ByteBuffer, IndexTermType) - Constructor for class org.apache.cassandra.index.sai.plan.Expression.Value
- Value(List<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Lists.Value
- Value(SortedMap<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Maps.Value
- Value(SortedSet<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Sets.Value
- Value(UserType, ByteBuffer[]) - Constructor for class org.apache.cassandra.cql3.UserTypes.Value
- Value(VectorType<T>, List<ByteBuffer>) - Constructor for class org.apache.cassandra.cql3.Vectors.Value
- VALUE_COL - Static variable in class org.apache.cassandra.db.virtual.CIDRFilteringMetricsTable.CIDRFilteringMetricsCountsTable
- 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 - Variable in class org.apache.cassandra.index.sai.disk.v1.bitpack.NumericValuesMeta
- 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
- valueIterator() - Method in class org.apache.cassandra.db.tries.Trie
-
Returns the ordered set of values of this trie in an iterator.
- ValueIterator<CONCRETE extends ValueIterator<CONCRETE>> - Class in org.apache.cassandra.io.tries
-
Thread-unsafe value iterator for on-disk tries.
- ValueIterator(Rebufferer, long) - Constructor for class org.apache.cassandra.io.tries.ValueIterator
- ValueIterator(Rebufferer, long, boolean) - Constructor for class org.apache.cassandra.io.tries.ValueIterator
- ValueIterator(Rebufferer, long, ByteComparable, ByteComparable, boolean) - Constructor for class org.apache.cassandra.io.tries.ValueIterator
- ValueIterator(Rebufferer, long, ByteComparable, ByteComparable, boolean, boolean) - Constructor for class org.apache.cassandra.io.tries.ValueIterator
-
Constrained iterator.
- ValueIterator.IterationPosition - Class in org.apache.cassandra.io.tries
- valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.AbstractTimeUUIDType
- 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.UUIDType
- valueLengthIfFixed() - Method in class org.apache.cassandra.db.marshal.VectorType
- valueOf(boolean) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- valueOf(boolean) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- valueOf(boolean) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
return a value with the bytes from {@param v}
- valueOf(byte) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- valueOf(byte) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- valueOf(byte) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
return a value with the bytes from {@param v}
- valueOf(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- valueOf(byte[]) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- valueOf(byte[]) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
return a value containing the {@param bytes} Caller should assume that modifying the returned value will also modify the contents of {@param bytes}
- valueOf(double) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- valueOf(double) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- valueOf(double) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
return a value with the bytes from {@param v}
- valueOf(float) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- valueOf(float) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- valueOf(float) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
return a value with the bytes from {@param v}
- valueOf(int) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- valueOf(int) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- valueOf(int) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
return a value with the bytes from {@param v}
- valueOf(int) - Static method in enum org.apache.cassandra.repair.consistent.ConsistentSession.State
-
Returns the enum constant of this type with the specified name.
- valueOf(long) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- valueOf(long) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- valueOf(long) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
return a value with the bytes from {@param v}
- valueOf(short) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- valueOf(short) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- valueOf(short) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
return a value with the bytes from {@param v}
- 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.ICIDRAuthorizer.CIDRAuthorizerMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.auth.IInternodeAuthenticator.InternodeConnectionDirection
-
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.ExecutorFactory.SimulatorSemantics
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.concurrent.InfiniteLoopExecutor.Daemon
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.concurrent.InfiniteLoopExecutor.InternalState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.concurrent.InfiniteLoopExecutor.Interrupts
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.concurrent.InfiniteLoopExecutor.SimulatorSafe
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.concurrent.Interruptible.State
-
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.CQLStartTime
-
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.PaxosOnLinearizabilityViolation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.PaxosStatePurging
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.Config.PaxosVariant
-
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.Converters
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.DataRateSpec.DataRateUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.DataStorageSpec.DataStorageUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.config.EncryptionOptions.ConfigKey
-
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.masking.PartialMaskingFunction.Kind
-
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.Ordering.Direction
-
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.selection.Selectable.WritetimeOrTTL.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.cql3.selection.Selector.Kind
-
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.ColumnFamilyStore.FlushReason
-
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(String) - Static method in enum org.apache.cassandra.db.marshal.CollectionType.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.db.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.Index.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.sai.disk.format.IndexComponent
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.sai.disk.v1.vector.OnHeapGraph.InvalidVectorBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.sai.disk.v1.vector.OptimizeFor
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.sai.IndexValidation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.sai.plan.Expression.IndexOperator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.sai.plan.Operation.BooleanOperator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.index.sai.utils.PrimaryKey.Kind
-
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(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.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.format.SSTableReader.OpenReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.metadata.MetadataType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.SSTableReadsListener.SelectionReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.sstable.SSTableReadsListener.SkippingReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.io.util.File.WriteMode
-
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.OutboundConnectionInitiator.SslFallbackConnectionType
-
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(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.repair.state.AbstractCompletable.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.repair.state.AbstractState.UpdateType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.repair.state.Completable.Result.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.repair.state.CoordinatorState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.repair.state.JobState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.repair.state.ParticipateState.Job.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.repair.state.ParticipateState.RegisterStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.repair.state.SessionState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.repair.state.SyncState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.repair.state.ValidationState.State
-
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.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.schema.UserFunctions.Filter
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.security.ISslContextFactory.SocketType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.security.PEMBasedSslContextFactory.ConfigKey
-
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.disk.usage.DiskUsageState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.service.paxos.Ballot.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.service.paxos.ContentionStrategy.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.service.paxos.PaxosState.MaybePromise.Outcome
-
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.service.StartupChecks.StartupCheckType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.service.StorageService.Mode
-
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.StreamingChannel.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.streaming.StreamingState.Status
-
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.PrepareDirection
-
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.ClientResourceLimits.Overload
-
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.AbstractGuavaIterator.State
-
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.Backoff.None
-
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.bytecomparable.ByteComparable.Version
-
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.Nemesis.Traffic
-
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.Overlaps.InclusionMethod
-
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.Shared.Recursive
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.utils.Shared.Scope
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.utils.Simulate.With
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.cassandra.utils.StorageCompatibilityMode
-
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.
- valueOf(String, Charset) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- valueOf(String, Charset) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- 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(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- valueOf(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- valueOf(ByteBuffer) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
return a value containing the {@param bytes} {@param src} 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 {@param src}
- valueOf(UUID) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- valueOf(UUID) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- valueOf(UUID) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
return a value with the bytes from {@param v}
- valueOf(Operator) - Static method in enum org.apache.cassandra.index.sai.plan.Expression.IndexOperator
-
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
-
Returns the enum constant of this type with the specified name.
- valueOf(DecoratedKey, Row, long) - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Returns the cell value from the
DecoratedKey
orRow
for theIndexTermType
based on the kind of column thisIndexTermType
is based on. - valueRaw - Variable in class org.apache.cassandra.cql3.restrictions.CustomIndexExpression
- values - Variable in class org.apache.cassandra.cql3.restrictions.MultiColumnRestriction.InRestrictionWithValues
- values - Variable in class org.apache.cassandra.cql3.restrictions.SingleColumnRestriction.InRestrictionWithValues
- values - Variable in class org.apache.cassandra.db.AbstractOnHeapClusteringPrefix
- values - Variable in class org.apache.cassandra.serializers.MapSerializer
- values - Variable in class org.apache.cassandra.transport.messages.BatchMessage
- 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.ICIDRAuthorizer.CIDRAuthorizerMode
-
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.IInternodeAuthenticator.InternodeConnectionDirection
-
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.ExecutorFactory.SimulatorSemantics
-
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.InfiniteLoopExecutor.Daemon
-
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.InfiniteLoopExecutor.InternalState
-
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.InfiniteLoopExecutor.Interrupts
-
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.InfiniteLoopExecutor.SimulatorSafe
-
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.Interruptible.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.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.CQLStartTime
-
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.PaxosOnLinearizabilityViolation
-
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.PaxosStatePurging
-
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.PaxosVariant
-
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.Converters
-
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.DataRateSpec.DataRateUnit
-
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.DataStorageSpec.DataStorageUnit
-
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.ConfigKey
-
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.masking.PartialMaskingFunction.Kind
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.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() - Static method in enum org.apache.cassandra.cql3.Ordering.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.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.selection.Selectable.WritetimeOrTTL.Kind
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.selection.Selector.Kind
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.cassandra.cql3.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() - 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.ColumnFamilyStore.FlushReason
-
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() - Method in class org.apache.cassandra.db.tries.Trie
-
Returns the ordered set of values of this trie as an iterable.
- 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 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.Index.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.index.sai.disk.format.IndexComponent
-
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.sai.disk.v1.vector.OnHeapGraph.InvalidVectorBehavior
-
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.sai.disk.v1.vector.OptimizeFor
-
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.sai.IndexValidation
-
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.sai.plan.Expression.IndexOperator
-
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.sai.plan.Operation.BooleanOperator
-
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.sai.utils.PrimaryKey.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.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.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.format.SSTableReader.OpenReason
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.sstable.metadata.MetadataType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.cassandra.io.sstable.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.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.util.File.WriteMode
-
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.OutboundConnectionInitiator.SslFallbackConnectionType
-
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.repair.state.AbstractCompletable.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.repair.state.AbstractState.UpdateType
-
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.state.Completable.Result.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.repair.state.CoordinatorState.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.state.JobState.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.state.ParticipateState.Job.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.state.ParticipateState.RegisterStatus
-
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.state.SessionState.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.state.SyncState.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.state.ValidationState.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.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.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.schema.UserFunctions.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.security.ISslContextFactory.SocketType
-
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.PEMBasedSslContextFactory.ConfigKey
-
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.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.disk.usage.DiskUsageState
-
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.paxos.Ballot.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.service.paxos.ContentionStrategy.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.service.paxos.PaxosState.MaybePromise.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.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.service.StartupChecks.StartupCheckType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.cassandra.service.StorageService.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.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.StreamingChannel.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.StreamingState.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.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.PrepareDirection
-
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.ClientResourceLimits.Overload
-
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() - 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.AbstractGuavaIterator.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.utils.AsymmetricOrdering.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.utils.Backoff.None
-
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.bytecomparable.ByteComparable.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.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.Nemesis.Traffic
-
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.Overlaps.InclusionMethod
-
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.Shared.Recursive
-
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.Shared.Scope
-
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.Simulate.With
-
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.StorageCompatibilityMode
-
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.
- values(QueryOptions, ClientState) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.EQRestriction
- values(QueryOptions, ClientState) - Method in class org.apache.cassandra.cql3.restrictions.TokenRestriction.SliceRestriction
- Values<T> - Class in org.apache.cassandra.db.guardrails
-
A guardrail that warns about some specific values, warns about but ignores some other values, and/or rejects the use of some other values.
- Values(String, String, Function<ClientState, Set<T>>, Function<ClientState, Set<T>>, Function<ClientState, Set<T>>, String) - Constructor for class org.apache.cassandra.db.guardrails.Values
-
Creates a new values guardrail.
- VALUES - org.apache.cassandra.cql3.statements.schema.IndexTarget.Type
- VALUES - Static variable in class org.apache.cassandra.fql.FullQueryLogger
- valuesCount() - Method in class org.apache.cassandra.db.tries.InMemoryTrie
- 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
- valuesOf(Row, long) - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
-
Returns a value iterator for collection type
IndexTermType
s. - 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>) - Static method in class org.apache.cassandra.db.rows.Cells
- valueString(Cell<V>, AbstractType<?>) - Static method in class org.apache.cassandra.db.rows.Cells
- valuesUnordered() - Method in class org.apache.cassandra.db.tries.InMemoryTrie
- valuesUnordered() - Method in class org.apache.cassandra.db.tries.Trie
-
Returns the values in any order.
- 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
. - VARCHAR - org.apache.cassandra.cql3.CQL3Type.Native
- VARCHAR - org.apache.cassandra.cql3.functions.types.DataType.Name
- VARCHAR - org.apache.cassandra.transport.DataType
- VARIABLE - org.apache.cassandra.index.sasi.disk.OnDiskIndexBuilder.TermSize
- variableLengthInteger(long) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
Produce a source for a signed integer, stored using variable length encoding.
- VariableLengthInteger(long) - Constructor for class org.apache.cassandra.utils.bytecomparable.ByteSource.VariableLengthInteger
- VariableLengthUnsignedInteger(long) - Constructor for class org.apache.cassandra.utils.bytecomparable.ByteSource.VariableLengthUnsignedInteger
- 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
. - VARINT - org.apache.cassandra.cql3.CQL3Type.Native
- VARINT - org.apache.cassandra.cql3.functions.types.DataType.Name
- VARINT - org.apache.cassandra.transport.DataType
- vector(CQL3Type) - Static method in interface org.apache.cassandra.cql3.functions.FunctionParameter
- vector(CQL3Type.Raw, int) - Static method in class org.apache.cassandra.cql3.CQL3Type.Raw
- vector(DataType, int) - Static method in class org.apache.cassandra.cql3.functions.types.DataType
-
Returns the type of vector of
elementType
elements withdimensions
dimensions. - vector(VectorType, TypeCodec<E>) - Static method in class org.apache.cassandra.cql3.functions.types.TypeCodec
-
Return a newly-created codec for the given CQL vector type.
- Vector(AbstractType<?>, int) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Vector
- Vector(AbstractType<?>, int) - Constructor for class org.apache.cassandra.db.marshal.TypeParser.Vector
- Vector(VectorType<?>) - Constructor for class org.apache.cassandra.cql3.CQL3Type.Vector
- VECTOR - org.apache.cassandra.cql3.functions.types.DataType.Name
- VECTOR_1_DIMENSION_COSINE_ERROR - Static variable in class org.apache.cassandra.index.sai.StorageAttachedIndex
- VECTOR_COMPONENTS - Static variable in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- vector_dimensions_fail_threshold - Variable in class org.apache.cassandra.config.Config
- vector_dimensions_warn_threshold - Variable in class org.apache.cassandra.config.Config
- VECTOR_INDEXES_ANN_ONLY_MESSAGE - Static variable in class org.apache.cassandra.cql3.restrictions.StatementRestrictions
- VECTOR_MULTIPLE_DATA_DIRECTORY_ERROR - Static variable in class org.apache.cassandra.index.sai.StorageAttachedIndex
- VECTOR_NON_FLOAT_ERROR - Static variable in class org.apache.cassandra.index.sai.StorageAttachedIndex
- VECTOR_SELECTOR - org.apache.cassandra.cql3.selection.Selector.Kind
- VECTOR_USAGE_WARNING - Static variable in class org.apache.cassandra.index.sai.StorageAttachedIndex
- VectorCodec<E> - Class in org.apache.cassandra.cql3.functions.types
-
TypeCodec
for the CQL typevector
. - vectorContext() - Method in class org.apache.cassandra.index.sai.QueryContext
- vectorDimension() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
- vectorDimensions - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on the number of dimensions of vector columns.
- vectorElementType() - Method in class org.apache.cassandra.index.sai.utils.IndexTermType
- VectorFcts - Class in org.apache.cassandra.cql3.functions
- VectorFcts() - Constructor for class org.apache.cassandra.cql3.functions.VectorFcts
- VectorIndexSegmentSearcher - Class in org.apache.cassandra.index.sai.disk.v1.segment
-
Executes ANN search against a vector graph for an individual index segment.
- VectorMemoryIndex - Class in org.apache.cassandra.index.sai.memory
- VectorMemoryIndex(StorageAttachedIndex) - Constructor for class org.apache.cassandra.index.sai.memory.VectorMemoryIndex
- vectorOf(TypeToken<T>) - Static method in class org.apache.cassandra.cql3.functions.types.TypeTokens
-
Create a
TypeToken
that represents aTypeToken
whose elements are of the given type. - VectorPostingList - Class in org.apache.cassandra.index.sai.disk.v1.postings
-
A
PostingList
for ANN search results. - VectorPostingList(PrimitiveIterator.OfInt, int, int) - Constructor for class org.apache.cassandra.index.sai.disk.v1.postings.VectorPostingList
- VectorPostings<T> - Class in org.apache.cassandra.index.sai.disk.v1.vector
- VectorPostings(T) - Constructor for class org.apache.cassandra.index.sai.disk.v1.vector.VectorPostings
- VectorPostingsWriter<T> - Class in org.apache.cassandra.index.sai.disk.v1.vector
- VectorPostingsWriter() - Constructor for class org.apache.cassandra.index.sai.disk.v1.vector.VectorPostingsWriter
- VectorQueryContext - Class in org.apache.cassandra.index.sai
-
This represents the state of a vector query.
- VectorQueryContext(ReadCommand) - Constructor for class org.apache.cassandra.index.sai.VectorQueryContext
- Vectors - Class in org.apache.cassandra.cql3
- Vectors.DelayedValue<T> - 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.
- Vectors.Literal - Class in org.apache.cassandra.cql3
- Vectors.Value<T> - Class in org.apache.cassandra.cql3
- VectorSegmentBuilder(StorageAttachedIndex, NamedMemoryLimiter) - Constructor for class org.apache.cassandra.index.sai.disk.v1.segment.SegmentBuilder.VectorSegmentBuilder
- VectorSelector - Class in org.apache.cassandra.cql3.selection
- VectorSerializer() - Constructor for class org.apache.cassandra.db.marshal.VectorType.VectorSerializer
- VectorTopKProcessor - Class in org.apache.cassandra.index.sai.plan
-
Processor that scans all rows from given partitions and selects rows with top-k scores based on vector indexes.
- VectorTopKProcessor(ReadCommand) - Constructor for class org.apache.cassandra.index.sai.plan.VectorTopKProcessor
- VectorType - Class in org.apache.cassandra.cql3.functions.types
-
A vector type.
- VectorType<T> - Class in org.apache.cassandra.db.marshal
- VectorType.VectorSerializer - Class in org.apache.cassandra.db.marshal
- vectorValue(int) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.CompactionVectorValues
- vectorValue(int) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.ConcurrentVectorValues
- vectorValue(int) - Method in interface org.apache.cassandra.index.sai.disk.v1.vector.RamAwareVectorValues
- verb - Variable in class org.apache.cassandra.net.Message.Header
- 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() - 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
- verbHandler - Static variable in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupComplete
- verbHandler - Static variable in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupRequest
- verbHandler - Static variable in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupResponse
- verbHandler - Static variable in class org.apache.cassandra.service.paxos.cleanup.PaxosFinishPrepareCleanup
- verbHandler - Static variable in class org.apache.cassandra.service.paxos.cleanup.PaxosStartPrepareCleanup
- 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(ReadCommand) - Static method in interface org.apache.cassandra.service.reads.repair.RepairedDataVerifier
- verify() - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- verify() - Method in interface org.apache.cassandra.io.sstable.IVerifier
- verify() - Method in class org.apache.cassandra.service.reads.repair.RepairedDataTracker
- verify(boolean, boolean, boolean, boolean, boolean, boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
- 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(boolean, String, String...) - Method in class org.apache.cassandra.service.StorageService
-
Deprecated.See CASSANDRA-14201
- verify(boolean, String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
-
Verify (checksums of) the given keyspace.
- verify(PrintStream, boolean, boolean, boolean, boolean, boolean, boolean, String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
- verify(String, byte[]) - Method in class org.apache.cassandra.cql3.functions.UDFByteCodeVerifier
- verify(StartupChecksOptions) - Method in class org.apache.cassandra.service.StartupChecks
-
Run the configured tests and return a report detailing the results.
- verify(IVerifier.Options) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- 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 - Class in org.apache.cassandra.tools.nodetool
- Verify() - Constructor for class org.apache.cassandra.tools.nodetool.Verify
- VERIFY - org.apache.cassandra.db.compaction.OperationType
- verifyBloomFilter() - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- verifyCompactionsPendingThreshold(TimeUUID, PreviewKind) - Method in class org.apache.cassandra.service.ActiveRepairService
- verifyCompressionInfoExistenceIfApplicable(Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.format.CompressionInfoComponent
-
Best-effort checking to verify the expected compression info component exists, according to the TOC file.
- VerifyController(ColumnFamilyStore) - Constructor for class org.apache.cassandra.io.sstable.format.SortedTableVerifier.VerifyController
- verifyDigest() - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- verifyFullPermissions(File, String) - Static method in class org.apache.cassandra.db.Directories
-
Checks whether Cassandra has RWX permissions to the specified directory.
- verifyIndex() - Method in class org.apache.cassandra.io.sstable.format.big.BigTableVerifier
- verifyIndex() - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- verifyInfo - Variable in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- VerifyInfo(RandomAccessReader, SSTableReader, Lock) - Constructor for class org.apache.cassandra.io.sstable.format.SortedTableVerifier.VerifyInfo
- verifyNoHintsInProgress() - Method in class org.apache.cassandra.service.StorageProxy
- verifyOwnedRanges() - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- verifyPartition(DecoratedKey, UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableVerifier
- verifyPartition(DecoratedKey, UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableVerifier
- verifyPartition(DecoratedKey, UnfilteredRowIterator) - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- verifySSTable() - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- verifySSTableMetadata() - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- verifySSTableVersion() - Method in class org.apache.cassandra.io.sstable.format.SortedTableVerifier
- version - Variable in class org.apache.cassandra.db.rows.DeserializationHelper
- version - Variable in class org.apache.cassandra.db.streaming.CassandraStreamHeader
-
SSTable version
- version - Variable in class org.apache.cassandra.gms.VersionedValue
- version - Variable in class org.apache.cassandra.index.sai.disk.format.IndexDescriptor
- version - Variable in class org.apache.cassandra.index.sasi.disk.Descriptor
- 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 - Variable in class org.apache.cassandra.io.sstable.format.bti.RowIndexReader
- version - Variable in class org.apache.cassandra.io.sstable.format.Version
- 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.audit.BinAuditLogger.Message
- version() - Method in class org.apache.cassandra.utils.binlog.BinLog.ReleaseableWriteMarshallable
- Version - Class in org.apache.cassandra.index.sai.disk.format
-
Format version of indexing component, denoted as [major][minor].
- Version - Class in org.apache.cassandra.io.sstable.format
-
A set of feature flags associated with a SSTable format
- Version - Class in org.apache.cassandra.tools.nodetool
- Version() - Constructor for class org.apache.cassandra.tools.nodetool.Version
- Version(String) - Constructor for class org.apache.cassandra.index.sasi.disk.Descriptor.Version
- Version(SSTableFormat, String) - Constructor for class org.apache.cassandra.io.sstable.format.Version
- VERSION - Static variable in class org.apache.cassandra.fql.FullQueryLogger
- VERSION - Static variable in class org.apache.cassandra.transport.ConnectedClient
- VERSION - Static variable in class org.apache.cassandra.utils.binlog.BinLog
- VERSION_30 - org.apache.cassandra.net.MessagingService.Version
-
Deprecated.See CASSANDRA-18314
- VERSION_30 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
- VERSION_30 - Static variable in class org.apache.cassandra.net.MessagingService
-
Deprecated.See CASSANDRA-18816
- VERSION_3014 - org.apache.cassandra.net.MessagingService.Version
-
Deprecated.See CASSANDRA-18314
- VERSION_3014 - Static variable in class org.apache.cassandra.net.MessagingService
-
Deprecated.See CASSANDRA-18816
- VERSION_40 - org.apache.cassandra.net.MessagingService.Version
- VERSION_40 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
- VERSION_40 - Static variable in class org.apache.cassandra.net.MessagingService
- VERSION_50 - org.apache.cassandra.net.MessagingService.Version
- VERSION_50 - Static variable in class org.apache.cassandra.db.commitlog.CommitLogDescriptor
- VERSION_50 - 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
- VERSION_ANOUNCED - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- VERSION_UPDATED - org.apache.cassandra.schema.SchemaEvent.SchemaEventType
- Version.FileNameFormatter - Interface in org.apache.cassandra.index.sai.disk.format
- VersionedLocalRanges(long, int) - Constructor for class org.apache.cassandra.db.ColumnFamilyStore.VersionedLocalRanges
- 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 - 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.
- versionsInUse() - Method in class org.apache.cassandra.service.SSTablesGlobalTracker
-
The set of all sstable versions currently in use on this node.
- VERY_LONG_TIME_MS - org.apache.cassandra.config.CassandraRelevantProperties
-
Gossiper compute expiration timeout.
- view - Variable in class org.apache.cassandra.index.sai.plan.QueryViewBuilder.QueryView
- view() - Method in class org.apache.cassandra.index.sai.StorageAttachedIndex
- view() - Method in class org.apache.cassandra.index.sai.view.IndexViewManager
- view(String, String) - Static method in class org.apache.cassandra.cql3.statements.DescribeStatement
-
Creates a
DescribeStatement
forDESCRIBE 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 - Class in org.apache.cassandra.index.sai.view
-
The View is an immutable, point in time, view of the avalailable
SSTableIndex
es for an index. - View - Class in org.apache.cassandra.index.sasi.conf.view
- View(IndexTermType, Collection<SSTableIndex>) - Constructor for class org.apache.cassandra.index.sai.view.View
- View(ColumnIndex, Collection<SSTableIndex>, Collection<SSTableReader>, Set<SSTableIndex>) - Constructor for class org.apache.cassandra.index.sasi.conf.view.View
- View(ColumnIndex, Set<SSTableIndex>) - Constructor for class org.apache.cassandra.index.sasi.conf.view.View
- View(ViewMetadata, ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.view.View
- VIEW - org.apache.cassandra.db.WriteType
- VIEW - org.apache.cassandra.schema.TableMetadata.Kind
- VIEW_BUILD - org.apache.cassandra.db.compaction.OperationType
- VIEW_BUILD_STARTED - org.apache.cassandra.db.ColumnFamilyStore.FlushReason
- VIEW_BUILD_STATUS - Static variable in class org.apache.cassandra.schema.SystemDistributedKeyspace
- VIEW_BUILDS_IN_PROGRESS - Static variable in class org.apache.cassandra.db.SystemKeyspace
- VIEW_MUTATION - org.apache.cassandra.concurrent.Stage
- 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 singleColumnFamilyStore
. - 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 - Class in org.apache.cassandra.schema
- VIEWS - Static variable in class org.apache.cassandra.schema.SchemaKeyspaceTables
- Views.Builder - Class in org.apache.cassandra.schema
- viewStatus(String, String) - Static method in class org.apache.cassandra.schema.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, long) - 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 - Static variable in class org.apache.cassandra.metrics.ClientRequestsMetricsHolder
- 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
- VIntCoding.VIntOutOfRangeException - Exception in org.apache.cassandra.utils.vint
-
Throw when attempting to decode a vint and the output type doesn't have enough space to fit the value that was decoded
- virtual(String, Tables) - Static method in class org.apache.cassandra.schema.KeyspaceMetadata
- VIRTUAL - org.apache.cassandra.schema.KeyspaceMetadata.Kind
- VIRTUAL - org.apache.cassandra.schema.TableMetadata.Kind
- VIRTUAL_SCHEMA - Static variable in class org.apache.cassandra.schema.SchemaConstants
- VIRTUAL_SYSTEM_KEYSPACE_NAMES - 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(String, DecoratedKey, ImmutableMap<TableId, PartitionUpdate>) - Constructor for class org.apache.cassandra.db.virtual.VirtualMutation
- VirtualMutation(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.
- VirtualTableAppender - Class in org.apache.cassandra.utils.logging
-
Appends Cassandra logs to virtual table system_views.system_logs
- VirtualTableAppender() - Constructor for class org.apache.cassandra.utils.logging.VirtualTableAppender
- VirtualTableGroup(List<SinglePartitionReadCommand>, DataLimits) - Constructor for class org.apache.cassandra.db.SinglePartitionReadCommand.VirtualTableGroup
- VirtualTableSinglePartitionReadCommand(boolean, int, boolean, TableMetadata, long, ColumnFilter, RowFilter, DataLimits, DecoratedKey, ClusteringIndexFilter, Index.QueryPlan, boolean) - Constructor for class org.apache.cassandra.db.SinglePartitionReadCommand.VirtualTableSinglePartitionReadCommand
- 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
- VOID - org.apache.cassandra.transport.messages.ResultMessage.Kind
- VoidSerializer - Class in org.apache.cassandra.utils
W
- W - org.apache.cassandra.db.Directories.FileAction
- WAIT_COMPLETE - org.apache.cassandra.streaming.StreamSession.State
- WAIT_FOR_PENDING_EVENTS_TIMEOUT_SECS - Static variable in class org.apache.cassandra.tracing.TraceStateImpl
- WAIT_FOR_TRACING_EVENTS_TIMEOUT_SECS - org.apache.cassandra.config.CassandraRelevantProperties
- 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, 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.
- waiting() - Method in class org.apache.cassandra.utils.concurrent.Semaphore.Standard
-
Number of permits that have been acquired in excess of available.
- 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
- waitingOnFlush - Variable in class org.apache.cassandra.metrics.CommitLogMetrics
-
Time spent actually flushing the contents of a buffer to disk
- 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 interface 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 F>) - Static method in class org.apache.cassandra.utils.FBUtilities
- waitOnFirstFuture(Iterable<? extends F>, 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 - Interface in org.apache.cassandra.utils.concurrent
-
A relatively easy to use utility for general purpose thread signalling.
- 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).
- WaitQueue.Standard - Class in org.apache.cassandra.utils.concurrent
- WaitQueue.Standard.AbstractSignal - Class in org.apache.cassandra.utils.concurrent
-
An abstract signal implementation TODO: use intrusive linked list
- waitToSettle() - Static method in class org.apache.cassandra.gms.Gossiper
- waitUntil(long) - Static method in interface org.apache.cassandra.utils.Clock
- waitUntil(Object, long) - Static method in class org.apache.cassandra.utils.concurrent.Awaitable.SyncAwaitable
- waitUntilListening() - Method in class org.apache.cassandra.net.MessagingService
- waitUntilReady(Duration) - Method in class org.apache.cassandra.schema.DefaultSchemaUpdateHandler
- waitUntilReady(Duration) - Method in class org.apache.cassandra.schema.OfflineSchemaUpdateHandler
- waitUntilReady(Duration) - Method in class org.apache.cassandra.schema.Schema
- waitUntilReady(Duration) - Method in interface org.apache.cassandra.schema.SchemaUpdateHandler
-
Waits until the schema update handler is ready and returns the result.
- Walker<CONCRETE extends Walker<CONCRETE>> - Class in org.apache.cassandra.io.tries
-
Thread-unsafe trie walking helper.
- Walker(Rebufferer, long) - Constructor for class org.apache.cassandra.io.tries.Walker
-
Creates a walker.
- Walker.Extractor<RESULT,VALUE> - Interface in org.apache.cassandra.io.tries
- Walker.PayloadToString - Interface in org.apache.cassandra.io.tries
- Walker.TransitionBytesCollector - Class in org.apache.cassandra.io.tries
- warm() - Method in class org.apache.cassandra.auth.AuthCache
- warmCaches() - Method in class org.apache.cassandra.auth.AuthCacheService
- warn - org.apache.cassandra.config.Config.CorruptedTombstoneStrategy
- warn(long, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
- warn(long, String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
- warn(Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger.NoSpamLogStatement
- warn(String) - Method in class org.apache.cassandra.db.guardrails.Guardrail
- warn(String) - Static method in exception org.apache.cassandra.exceptions.RepairException
- warn(String) - Method in class org.apache.cassandra.service.ClientWarn
- warn(String) - Method in class org.apache.cassandra.utils.OutputHandler.LogOutput
- warn(String) - Method in class org.apache.cassandra.utils.OutputHandler.SystemOutput
- warn(String) - Method in interface org.apache.cassandra.utils.OutputHandler
- warn(String, Object...) - Method in class org.apache.cassandra.utils.NoSpamLogger
- warn(String, Object...) - Method in interface org.apache.cassandra.utils.OutputHandler
- warn(String, String) - Method in class org.apache.cassandra.db.guardrails.Guardrail
- warn(Throwable) - Method in interface org.apache.cassandra.utils.OutputHandler
- warn(Throwable, String) - Method in class org.apache.cassandra.utils.OutputHandler.LogOutput
- warn(Throwable, String) - Method in class org.apache.cassandra.utils.OutputHandler.SystemOutput
- warn(Throwable, String) - Method in interface org.apache.cassandra.utils.OutputHandler
- warn(Throwable, String, Object...) - Method in interface org.apache.cassandra.utils.OutputHandler
- warn(RepairJobDesc, PreviewKind, String) - Static method in exception org.apache.cassandra.exceptions.RepairException
- WARN - org.apache.cassandra.utils.NoSpamLogger.Level
- WARN_STDEV_GROWTH - Static variable in class org.apache.cassandra.dht.tokenallocator.TokenAllocation
- WarnAbortCounter - Class in org.apache.cassandra.service.reads.thresholds
- WarnAbortCounter() - Constructor for class org.apache.cassandra.service.reads.thresholds.WarnAbortCounter
- warnAboutUseWithPreparedStatements(MD5Digest, String) - Method in class org.apache.cassandra.service.ClientState
- warnIfRunningInDegradedMode() - Method in class org.apache.cassandra.utils.SigarLibrary
- WARNING - org.apache.cassandra.transport.Envelope.Header.Flag
- WarningContext - Class in org.apache.cassandra.service.reads.thresholds
- WarningContext() - Constructor for class org.apache.cassandra.service.reads.thresholds.WarningContext
- warnings - Variable in class org.apache.cassandra.service.reads.thresholds.WarningsSnapshot.Warnings
- warnings - Variable in class org.apache.cassandra.transport.Message.Response
- WarningsSnapshot - Class in org.apache.cassandra.service.reads.thresholds
- WarningsSnapshot.Builder - Class in org.apache.cassandra.service.reads.thresholds
- WarningsSnapshot.Counter - Class in org.apache.cassandra.service.reads.thresholds
- WarningsSnapshot.Warnings - Class in org.apache.cassandra.service.reads.thresholds
- warnOut - Variable in class org.apache.cassandra.utils.OutputHandler.SystemOutput
- warnsOn(long, ClientState) - Method in class org.apache.cassandra.db.guardrails.Threshold
- warnThreshold - Variable in class org.apache.cassandra.db.guardrails.Threshold
- warnValue(ClientState) - Method in class org.apache.cassandra.db.guardrails.MaxThreshold
- warnValue(ClientState) - Method in class org.apache.cassandra.db.guardrails.MinThreshold
- warnValue(ClientState) - Method in class org.apache.cassandra.db.guardrails.Threshold
- wasDecommissioned() - Static method in class org.apache.cassandra.db.SystemKeyspace
- wasSuccessful - Variable in class org.apache.cassandra.service.paxos.cleanup.PaxosCleanupResponse
- wasSuccessful() - Method in class org.apache.cassandra.service.paxos.AbstractPaxosRepair.Result
- 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
- WEAKLY_ASSIGNABLE - org.apache.cassandra.cql3.AssignmentTestable.TestResult
- 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.dht.Splitter.WeightedRange
- 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 - Variable in class org.apache.cassandra.schema.ViewMetadata
- WhereClause - Class in org.apache.cassandra.cql3
- WhereClause.Builder - Class in org.apache.cassandra.cql3
- WIDE - org.apache.cassandra.index.sai.utils.PrimaryKey.Kind
- WIDE_PER_SSTABLE_COMPONENTS - Static variable in class org.apache.cassandra.index.sai.disk.v1.V1OnDiskFormat
- WidePrimaryKeyMap - Class in org.apache.cassandra.index.sai.disk.v1
-
An extension of the
SkinnyPrimaryKeyMap
for wide tables (those with clustering columns). - WidePrimaryKeyMap.Factory - Class in org.apache.cassandra.index.sai.disk.v1
- 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
- wildcardWithGroupByOrMaskedColumns(TableMetadata, VariableSpecifications, Set<ColumnMetadata>, boolean, boolean) - Static method in class org.apache.cassandra.cql3.selection.Selection
- windows_timer_interval - Variable in class org.apache.cassandra.config.Config
-
Deprecated.See CASSANDRA-17404
- with() - Method in annotation type org.apache.cassandra.utils.Simulate
- with(ByteBuf) - Method in class org.apache.cassandra.transport.Envelope
- with(UserFunction) - Method in class org.apache.cassandra.schema.UserFunctions
-
Create a Functions instance with the provided function added
- with(ClusteringComparator, Slice) - Static method in class org.apache.cassandra.db.Slices
-
Creates a
Slices
object that contains a single slice. - with(UserType) - Method in class org.apache.cassandra.schema.Types
-
Create a Types instance with the provided type 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(ViewMetadata) - Method in class org.apache.cassandra.schema.Views
-
Create a MaterializedViews instance with the provided materialized view added
- 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
- withAddedOrReplaced(KeyspaceMetadata) - Method in class org.apache.cassandra.schema.Keyspaces
- withAddedOrReplaced(Keyspaces) - Method in class org.apache.cassandra.schema.Keyspaces
-
Calls
Keyspaces.withAddedOrReplaced(KeyspaceMetadata)
on all the keyspaces of the providedKeyspaces
. - withAddedOrUpdated(UserFunction) - Method in class org.apache.cassandra.schema.UserFunctions
- 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. - withAllSSTables(OperationType, Function<LifecycleTransaction, T>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- 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
- withArchiveCommand(String) - Method in class org.apache.cassandra.audit.AuditLogOptions.Builder
- WithArrayLiteral(List<Selectable>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithArrayLiteral
- withAuditLogDir(String) - Method in class org.apache.cassandra.audit.AuditLogOptions.Builder
- 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
- withBlock(Boolean) - Method in class org.apache.cassandra.audit.AuditLogOptions.Builder
- withBufferSizeInMB(int) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
Deprecated.This method is deprecated in favor of the new withBufferSizeInMiB(int size). See CASSANDRA-17675
- withBufferSizeInMiB(int) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
Deprecated.This method is deprecated in favor of the new withMaxSSTableSizeInMiB(int size)
- withBuildIndexes(boolean) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
Whether indexes should be built and serialized to disk along data.
- 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(String...) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
- withCipherSuites(String...) - Method in class org.apache.cassandra.config.EncryptionOptions
- withCipherSuites(List<String>) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
- withCipherSuites(List<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
- withConsistencyLevel(QueryOptions, ConsistencyLevel) - Static method in class org.apache.cassandra.cql3.QueryOptions
- withContacts(E) - Method in interface org.apache.cassandra.locator.ReplicaPlan
- withContacts(EndpointsForRange) - Method in class org.apache.cassandra.locator.ReplicaPlan.ForRangeRead
- withContacts(EndpointsForToken) - Method in class org.apache.cassandra.locator.ReplicaPlan.ForTokenRead
- withContacts(EndpointsForToken) - Method in class org.apache.cassandra.locator.ReplicaPlan.ForWrite
- withContext(SharedContext) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession.Builder
- withCrcCheckChance(Supplier<Double>) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
- withCreatedAt(long) - Method in class org.apache.cassandra.net.Message.Builder
- withCustomParam(String, byte[]) - Method in class org.apache.cassandra.net.Message.Builder
- withDebugCallbacks(OutboundDebugCallbacks) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
- withDecay(double, int) - Static method in class org.apache.cassandra.utils.ExpMovingAverage
-
Create a
ExpMovingAverage
where older values have less effect than the given ratio after the given number of samples. - withDefaultReserveLimits() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
- withDefaults() - Method in class org.apache.cassandra.net.InboundConnectionSettings
- withDefaults(RetrySpec) - Method in class org.apache.cassandra.config.RetrySpec.Partial
- withDefaults(ConnectionCategory) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
- withDefaultTests() - Method in class org.apache.cassandra.service.StartupChecks
- withDefaultThreadGroup() - Method in interface org.apache.cassandra.concurrent.ExecutorBuilder
-
Use the system default thread group for the threads we create.
- withDefaultThreadGroup() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBuilder
- withDefaultTTL(Commit) - Static method in class org.apache.cassandra.service.paxos.Commit.AcceptedWithTTL
- withDefaultTTL(Commit) - Static method in class org.apache.cassandra.service.paxos.Commit.CommittedWithTTL
- withEnabled(boolean) - Method in class org.apache.cassandra.audit.AuditLogOptions.Builder
- withEnabled(boolean) - Method in class org.apache.cassandra.config.EncryptionOptions
- withEncryption() - Method in class org.apache.cassandra.net.OutboundConnectionSettings
- withEncryption(EncryptionOptions.ServerEncryptionOptions) - Method in class org.apache.cassandra.net.InboundConnectionSettings
- 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
- withExcludedCategories(String) - Method in class org.apache.cassandra.audit.AuditLogOptions.Builder
- withExcludedKeyspaces(String) - Method in class org.apache.cassandra.audit.AuditLogOptions.Builder
- withExcludedUsers(String) - Method in class org.apache.cassandra.audit.AuditLogOptions.Builder
- withExecutor(Executor) - Static method in class org.apache.cassandra.utils.concurrent.AsyncPromise
- withExecutor(Executor) - Static method in class org.apache.cassandra.utils.concurrent.SyncPromise
- WithExecutor(Executor) - Constructor for class org.apache.cassandra.utils.concurrent.AsyncPromise.WithExecutor
- WithExecutor(Executor) - Constructor for class org.apache.cassandra.utils.concurrent.SyncPromise.WithExecutor
- WithExecutor(Executor, GenericFutureListener<? extends Future<? super V>>) - Constructor for class org.apache.cassandra.utils.concurrent.AsyncPromise.WithExecutor
- WithExecutor(Executor, GenericFutureListener<? extends Future<? super V>>) - Constructor for class org.apache.cassandra.utils.concurrent.SyncPromise.WithExecutor
- WithExecutor(Executor, AbstractFuture.FailureHolder) - Constructor for class org.apache.cassandra.utils.concurrent.AsyncPromise.WithExecutor
- WithExecutor(Executor, AbstractFuture.FailureHolder) - Constructor for class org.apache.cassandra.utils.concurrent.SyncPromise.WithExecutor
- withExpirationTime(long, int, long) - 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
- withFlag(MessageFlag) - Method in class org.apache.cassandra.net.Message
- withFlags(int) - Method in class org.apache.cassandra.net.Message.Builder
- 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.Message
- withFrom(InetAddressAndPort) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
- WithFunction(Function, List<Selectable>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithFunction
- 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
- withIncludedCategories(String) - Method in class org.apache.cassandra.audit.AuditLogOptions.Builder
- withIncludedKeyspaces(String) - Method in class org.apache.cassandra.audit.AuditLogOptions.Builder
- withIncludedUsers(String) - Method in class org.apache.cassandra.audit.AuditLogOptions.Builder
- withIndexes(String...) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
The schema (CREATE INDEX statement) for index to be created for the table.
- withInternalDetails() - Method in class org.apache.cassandra.cql3.statements.DescribeStatement
- withInternodeEncryption(EncryptionOptions.ServerEncryptionOptions.InternodeEncryption) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
- withJmx(String) - Method in interface org.apache.cassandra.concurrent.ExecutorBuilderFactory.Jmxable
- withJmx(String) - Method in class org.apache.cassandra.concurrent.ExecutorFactory.Default
- withJmx(String) - Method in interface org.apache.cassandra.concurrent.ExecutorFactory.LocalAwareSubFactory
- withJmxInternal() - Method in interface org.apache.cassandra.concurrent.ExecutorBuilderFactory.Jmxable
- withJmxInternal() - Method in interface org.apache.cassandra.concurrent.ExecutorFactory.LocalAwareSubFactory
- withKeepAlive() - Method in interface org.apache.cassandra.concurrent.ExecutorBuilder
-
Core threads for the executor built by this factory will never timeout (default for single threaded builders).
- withKeepAlive() - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBuilder
- withKeepAlive(long, TimeUnit) - Method in interface org.apache.cassandra.concurrent.ExecutorBuilder
-
Threads for the executor built by this factory will timeout (terminate) after the specified period.
- withKeepAlive(long, TimeUnit) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBuilder
- 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(long) - Method in class org.apache.cassandra.repair.consistent.LocalSession.Builder
- withLegacyName() - Method in class org.apache.cassandra.cql3.functions.AggregateFcts.CountRowsFunction
- withLegacyName() - Method in class org.apache.cassandra.cql3.functions.BytesConversionFcts.FromBlobFunction
- withLegacyName() - Method in class org.apache.cassandra.cql3.functions.BytesConversionFcts.ToBlobFunction
- withLegacyName() - Method in class org.apache.cassandra.cql3.functions.NativeFunction
-
Returns a copy of this function using its old pre-5.0 name before the adoption of snake-cased function names.
- withLegacySslStoragePort(boolean) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
- withLegacySslStoragePortDefaults() - Method in class org.apache.cassandra.net.InboundConnectionSettings
- withLengthOverride(long) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
-
Override the file length.
- 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
- withListener(Consumer<CoordinatorSession>) - Method in class org.apache.cassandra.repair.consistent.CoordinatorSession.Builder
- withLogger(String, Map<String, String>) - Method in class org.apache.cassandra.audit.AuditLogOptions.Builder
- WithMapOrUdt(TableMetadata, List<Pair<Selectable.Raw, Selectable.Raw>>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithMapOrUdt
- withMaxArchiveRetries(int) - Method in class org.apache.cassandra.audit.AuditLogOptions.Builder
- withMaxLogSize(long) - Method in class org.apache.cassandra.audit.AuditLogOptions.Builder
- withMaxQueueWeight(int) - Method in class org.apache.cassandra.audit.AuditLogOptions.Builder
- withMaxSSTableSizeInMiB(int) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
Defines the maximum SSTable size in mebibytes when using the sorted writer.
- withMessaging(MessageDelivery) - Method in interface org.apache.cassandra.repair.SharedContext
- withMmappedRegionsCache(MmappedRegionsCache) - Method in class org.apache.cassandra.io.util.FileHandle.Builder
- withNettyBufferBounds(WriteBufferWaterMark) - Method in class org.apache.cassandra.net.OutboundConnectionSettings
- withNewColumnMask(ColumnIdentifier, ColumnMask) - Method in class org.apache.cassandra.schema.ViewMetadata
- withNewExpressions(List<RowFilter.Expression>) - Method in class org.apache.cassandra.db.filter.RowFilter
- withNewMask(ColumnMask) - Method in class org.apache.cassandra.schema.ColumnMetadata
- 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(long) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
- withOnlyPresentColumns() - Method in class org.apache.cassandra.db.partitions.PartitionUpdate
- 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 (seeColumnFilter
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() - Method in annotation type org.apache.cassandra.utils.Simulate
- 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(String) - Method in class org.apache.cassandra.schema.Triggers
-
Creates a Triggers instance with the trigger with the provided name removed
- without(String) - Method in class org.apache.cassandra.schema.Views
-
Creates a MaterializedViews instance with the materializedView 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(Collection<String>) - Method in class org.apache.cassandra.schema.Keyspaces
- without(Set<InetAddressAndPort>) - Method in class org.apache.cassandra.locator.Endpoints
- without(Set<TableId>) - Method in class org.apache.cassandra.db.Mutation
- without(Function) - Method in class org.apache.cassandra.schema.UserFunctions
- without(FunctionName, List<AbstractType<?>>) - Method in class org.apache.cassandra.schema.UserFunctions
-
Creates a Functions instance with the function with the provided name and argument types removed
- without(RowFilter.Expression) - Method in class org.apache.cassandra.db.filter.RowFilter
-
Returns this filter but without the provided expression.
- without(UserType) - Method in class org.apache.cassandra.schema.Types
- without(ColumnMetadata) - Method in class org.apache.cassandra.db.Columns
-
Returns the equivalent of those columns but with the provided column removed.
- without(ColumnMetadata) - Method in class org.apache.cassandra.db.RegularAndStaticColumns
- without(ColumnMetadata, Operator, ByteBuffer) - Method in class org.apache.cassandra.db.filter.RowFilter
-
Returns a copy of this filter but without the provided expression.
- without(TableId) - Method in class org.apache.cassandra.db.Mutation
- without(TableMetadata) - Method in class org.apache.cassandra.schema.Tables
- withOutboundKeystore(String) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
- withOutboundKeystorePassword(String) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
- 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, TimeUUID) - Static method in class org.apache.cassandra.db.compaction.CompactionInfo
-
Special compaction info where we always need to cancel the compaction - for example ViewBuilderTask where we don't know the sstables at construction
- withoutSSTables(TableMetadata, OperationType, long, long, CompactionInfo.Unit, TimeUUID, String) - Static method in class org.apache.cassandra.db.compaction.CompactionInfo
-
Special compaction info where we always need to cancel the compaction - for example 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.
- withPageSize(QueryOptions, int) - Static method in class org.apache.cassandra.cql3.QueryOptions
- withPagingLimit(int) - Method in class org.apache.cassandra.db.AbstractReadCommandBuilder
- withParam(ParamType, Object) - Method in class org.apache.cassandra.net.Message.Builder
- withParam(ParamType, Object) - Method in class org.apache.cassandra.net.Message
- withParams(Map<ParamType, Object>) - Method in class org.apache.cassandra.net.Message.Builder
- withParams(Map<ParamType, Object>) - Method in class org.apache.cassandra.net.Message
- withPartitioner(IPartitioner) - Method in class org.apache.cassandra.io.sstable.CQLSSTableWriter.Builder
-
The partitioner to use.
- withPartitionKeyType(AbstractType<?>) - Method in class org.apache.cassandra.db.marshal.PartitionerDefinedOrder
- withPayload(T) - Method in class org.apache.cassandra.net.Message.Builder
- withPayload(V) - Method in class org.apache.cassandra.net.Message
- 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
- withQueueLimit(int) - Method in interface org.apache.cassandra.concurrent.ExecutorBuilder
-
The executor built by this factory will limit the number of queued tasks; default is unlimited.
- withQueueLimit(int) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBuilder
- withRejectedExecutionHandler(RejectedExecutionHandler) - Method in interface org.apache.cassandra.concurrent.ExecutorBuilder
-
Set the
RejectedExecutionHandler
for the executor built by this factory. - withRejectedExecutionHandler(RejectedExecutionHandler) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBuilder
- 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
- WithResources - Interface in org.apache.cassandra.utils
-
A generic interface for encapsulating a Runnable task with related work before and after execution, using the built-in try-with-resources functionality offered by
Closeable
. - WithResources.None - Class in org.apache.cassandra.utils
- withResultMetadata(ResultSet.ResultMetadata) - Method in class org.apache.cassandra.transport.messages.ResultMessage.Prepared
- withReversedType() - Method in class org.apache.cassandra.cql3.functions.masking.ColumnMask
- withRollCycle(String) - Method in class org.apache.cassandra.audit.AuditLogOptions.Builder
- 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
- withSslContextFactory(ParameterizedClass) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
- withSslContextFactory(ParameterizedClass) - Method in class org.apache.cassandra.config.EncryptionOptions
- withSSTableLevel(int) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.Builder
- withSSTablesForKey(String, boolean, Function<SSTableReader, T>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- withSSTableVersion(Version) - Method in class org.apache.cassandra.db.streaming.CassandraStreamHeader.Builder
- withStartedAt(long) - Method in class org.apache.cassandra.repair.consistent.LocalSession.Builder
- withStoreType(String) - Method in class org.apache.cassandra.config.EncryptionOptions.ServerEncryptionOptions
- withStoreType(String) - Method in class org.apache.cassandra.config.EncryptionOptions
- withSuffix(String) - Method in class org.apache.cassandra.io.util.File
- withSummaries(List<SessionSummary>) - Method in class org.apache.cassandra.repair.SyncStat
- withSwapped(Set<TableMetadata.Flag>) - Method in class org.apache.cassandra.schema.TableMetadata
- withSwapped(Indexes) - Method in class org.apache.cassandra.schema.TableMetadata
- withSwapped(KeyspaceParams) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
- withSwapped(TableMetadata) - Method in class org.apache.cassandra.schema.Tables
- withSwapped(TableParams) - Method in class org.apache.cassandra.schema.TableMetadata
- withSwapped(Tables) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
- withSwapped(Triggers) - Method in class org.apache.cassandra.schema.TableMetadata
- withSwapped(Types) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
- withSwapped(UserFunctions) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
- withSwapped(ViewMetadata) - Method in class org.apache.cassandra.schema.Views
- withSwapped(Views) - Method in class org.apache.cassandra.schema.KeyspaceMetadata
- 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
- withTerminator(int, ByteSource...) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
Combines a chain of sources, turning their weak-prefix-free byte-comparable representation into the combination's prefix-free byte-comparable representation, with the included terminator character.
- withTerminatorLegacy(int, ByteSource...) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
-
As above, but permits any separator.
- withTerminatorMaybeLegacy(ByteComparable.Version, int, ByteSource...) - Static method in interface org.apache.cassandra.utils.bytecomparable.ByteSource
- withTest(StartupCheck) - Method in class org.apache.cassandra.service.StartupChecks
-
Add system test to be run before schema is loaded during startup
- withThreadGroup(ThreadGroup) - Method in interface org.apache.cassandra.concurrent.ExecutorBuilder
-
Threads for the executor built by this factory will all be (transitively) members of
threadGroup
, but may directly reside in a child thread group. - withThreadGroup(ThreadGroup) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBuilder
- withThreadPriority(int) - Method in interface org.apache.cassandra.concurrent.ExecutorBuilder
-
Specify the priority of threads that service the executor built by this factory (default to
Thread.NORM_PRIORITY
) - withThreadPriority(int) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBuilder
- 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
- withUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in interface org.apache.cassandra.concurrent.ExecutorBuilder
-
Set the
Thread.UncaughtExceptionHandler
for threads that service executors built by this factory. - withUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.cassandra.concurrent.ThreadPoolExecutorBuilder
- 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.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. - withUpdatedTimestamp(long) - Method in class org.apache.cassandra.db.LivenessInfo
-
Returns a copy of this liveness info updated with the provided timestamp.
- withUpdatedTimestampAndLocalDeletionTime(long, long) - Method in class org.apache.cassandra.db.LivenessInfo
- withUpdatedTimestampAndLocalDeletionTime(long, long) - Method in class org.apache.cassandra.db.rows.ArrayCell
- withUpdatedTimestampAndLocalDeletionTime(long, long) - Method in class org.apache.cassandra.db.rows.BufferCell
- withUpdatedTimestampAndLocalDeletionTime(long, long) - Method in class org.apache.cassandra.db.rows.Cell
- withUpdatedTimestampAndLocalDeletionTime(long, long) - Method in class org.apache.cassandra.db.rows.NativeCell
- withUpdatedTimestampAndLocalDeletionTime(long, long, boolean) - Method in class org.apache.cassandra.db.LivenessInfo
- 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.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.UserFunctions
- 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.
- withValidation(UnfilteredRowIterator, String) - Method in class org.apache.cassandra.io.sstable.format.big.BigTableScrubber
- withValidation(UnfilteredRowIterator, String) - Method in class org.apache.cassandra.io.sstable.format.bti.BtiTableScrubber
- withValidation(UnfilteredRowIterator, String) - Method in class org.apache.cassandra.io.sstable.format.SortedTableScrubber
- WithVector(List<Selectable>) - Constructor for class org.apache.cassandra.cql3.selection.Selectable.WithVector
- withVersion(int) - Method in class org.apache.cassandra.gms.VersionedValue
- worthDroppingTombstones(SSTableReader, long) - Method in class org.apache.cassandra.db.compaction.AbstractCompactionStrategy
-
Check if given sstable is worth dropping tombstones at gcBefore.
- wrap(byte[]) - Static method in class org.apache.cassandra.utils.MD5Digest
- wrap(Object[], Comparator<? super V>) - Static method in class org.apache.cassandra.utils.btree.BTreeSet
- wrap(Throwable, int) - Static method in class org.apache.cassandra.transport.messages.ErrorMessage
- wrap(ByteBuffer) - Static method in class org.apache.cassandra.db.context.CounterContext.ContextState
- wrap(ByteBuffer) - Static method in class org.apache.cassandra.net.GlobalBufferPoolAllocator
- wrap(ByteBuffer) - Static method in class org.apache.cassandra.net.ShareableBytes
- wrap(ByteBuffer) - Static method in class org.apache.cassandra.utils.CounterId
- wrap(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.CounterId
- wrap(Iterator<T>) - Static method in interface org.apache.cassandra.utils.CloseableIterator
- wrap(List<AbstractType<?>>, boolean) - Static method in class org.apache.cassandra.cql3.functions.UDFDataType
-
Returns the
UDFDataType
s corresponding to the specified types. - wrap(AbstractType<?>, boolean) - Static method in class org.apache.cassandra.cql3.functions.UDFDataType
-
Returns the
UDFDataType
corresponding to the specified type. - wrap(IVersionedSerializer<T>) - Static method in class org.apache.cassandra.utils.NullableSerializer
- wrap(ChunkReader) - Method in class org.apache.cassandra.cache.ChunkCache
- 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.io.util.WrappingRebufferer
- wrapped() - Method in interface 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 - Exception in org.apache.cassandra.utils
-
Wrapped runtime exception for lambda functions
- WrappedException(Exception) - Constructor for exception org.apache.cassandra.utils.WrappedException
- WrappedException(Throwable, int) - Constructor for exception org.apache.cassandra.transport.messages.ErrorMessage.WrappedException
- WrappedExecutorPlus - Class in org.apache.cassandra.concurrent
- WrappedExecutorPlus(ExecutorPlus) - Constructor for class org.apache.cassandra.concurrent.WrappedExecutorPlus
- 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 - Variable in class org.apache.cassandra.db.marshal.NumberType.NumberArgumentDeserializer
- Wrapper() - Constructor for class org.apache.cassandra.tools.nodetool.Sjk.Wrapper
- WrappingRebufferer - Class in org.apache.cassandra.io.util
-
Instantiated once per RandomAccessReader, thread-unsafe.
- WrappingRebufferer(Rebufferer) - Constructor for class org.apache.cassandra.io.util.WrappingRebufferer
- WrappingUnfilteredRowIterator - Interface in org.apache.cassandra.db.rows
-
Abstract class to make writing unfiltered iterators that wrap another iterator easier.
- wrapQuiet(String, boolean) - Static method in class org.apache.cassandra.tools.Util
- write(byte[]) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
- 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.BufferedDataOutputStreamPlus
- write(byte[], int, int) - Method in class org.apache.cassandra.io.util.MemoryOutputStream
- write(byte[], int, int) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
-
Writes
count
bytes from the byte arraybuffer
starting atoffset
to this RandomAccessFile starting at the current file pointer.. - write(byte[], int, int) - Method in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
- write(byte[], ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- write(byte[], DataOutputPlus) - Method in class org.apache.cassandra.db.marshal.ByteArrayAccessor
- write(int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
- write(int) - Method in class org.apache.cassandra.io.util.MemoryOutputStream
- 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(int) - Method in class org.apache.cassandra.io.util.WrappedDataOutputStreamPlus
- write(JsonNode, CompactionLogger.StrategySummary, Object) - Method in interface org.apache.cassandra.db.compaction.CompactionLogger.Writer
- write(DEST, SerializationNode<VALUE>, long) - Method in interface org.apache.cassandra.io.tries.TrieSerializer
- write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.apache.cassandra.net.FrameEncoder
- write(String) - Method in class org.apache.cassandra.tools.AbstractJmxClient
- write(String, Object...) - Method in class org.apache.cassandra.tools.AbstractJmxClient
- write(ByteBuffer) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
- write(ByteBuffer) - Method in interface org.apache.cassandra.io.util.DataOutputPlus
- write(ByteBuffer) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
- write(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- write(ByteBuffer, DataOutputPlus) - Method in class org.apache.cassandra.db.marshal.ByteBufferAccessor
- 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(PartitionUpdate, WriteContext, boolean) - Method in class org.apache.cassandra.db.CassandraTableWriteHandler
- write(PartitionUpdate, WriteContext, boolean) - Method in interface org.apache.cassandra.db.TableWriteHandler
- write(MetadataWriter, List<SegmentMetadata>) - Static method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata
-
Writes disk metadata for the given segment list.
- write(PostingList) - Method in class org.apache.cassandra.index.sai.disk.v1.postings.PostingsWriter
-
Encodes, compresses and flushes given posting list to disk.
- write(IncrementalTrieWriterPageAware.Node<VALUE>) - Method in class org.apache.cassandra.io.tries.IncrementalDeepTrieWriterPageAware
- write(IncrementalTrieWriterPageAware.Node<VALUE>) - Method in class org.apache.cassandra.io.tries.IncrementalTrieWriterPageAware
- write(ChannelProxy, DataIntegrityMetadata.ChecksumValidator, StreamingDataOutputPlus, 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(DataOutputPlus) - Method in class org.apache.cassandra.cache.CounterCacheKey
- 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(DataOutputPlus, long, int) - Static method in class org.apache.cassandra.io.util.SizedInts
- 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(ReadableMemory, long, long) - Method in interface org.apache.cassandra.io.util.DataOutputPlus
- write(SequentialWriter) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.CompactionVectorValues
- write(StreamingDataOutputPlus) - Method in class org.apache.cassandra.db.streaming.CassandraCompressedStreamWriter
- write(StreamingDataOutputPlus) - Method in class org.apache.cassandra.db.streaming.CassandraEntireSSTableStreamWriter
-
Stream the entire file to given channel.
- write(StreamingDataOutputPlus) - Method in class org.apache.cassandra.db.streaming.CassandraStreamWriter
-
Stream file of specified sections to given channel.
- write(StreamingDataOutputPlus.BufferSupplier) - Method in interface org.apache.cassandra.streaming.StreamingDataOutputPlus.Write
-
Write to a buffer, and flush its contents to the channel.
- write(StreamSession, StreamingDataOutputPlus, int) - Method in class org.apache.cassandra.db.streaming.CassandraOutgoingFile
- write(StreamSession, StreamingDataOutputPlus, int) - Method in interface org.apache.cassandra.streaming.OutgoingStream
-
Write the streams data into the socket
- write(IndexOutput) - Method in class org.apache.cassandra.index.sai.disk.v1.segment.SegmentMetadata.ComponentMetadata
- write(IndexOutput, long, int) - Static method in class org.apache.cassandra.index.sai.disk.v1.keystore.KeyLookupMeta
- write(IndexOutput, long, int, long) - Static method in class org.apache.cassandra.index.sai.disk.v1.bitpack.NumericValuesMeta
- write(IndexOutput, Iterator<IndexEntry>, BlockBalancedTreeWriter.Callback) - Method in class org.apache.cassandra.index.sai.disk.v1.bbtree.BlockBalancedTreeWriter
-
Write the sorted values from an
Iterator
. - write(V, ByteBuffer) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
Write the contents of the given value into the ByteBuffer
- write(V, DataOutputPlus) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
-
Write the contents of the given value into the a DataOutputPlus
- WRITE - org.apache.cassandra.db.compaction.OperationType
- WRITE - org.apache.cassandra.index.Index.LoadType
- WRITE - org.apache.cassandra.service.paxos.ContentionStrategy.Type
- WRITE - org.apache.cassandra.utils.Throwables.FileOpType
- write_consistency_levels_disallowed - Variable in class org.apache.cassandra.config.Config
- write_consistency_levels_warned - Variable in class org.apache.cassandra.config.Config
- WRITE_FAILURE - org.apache.cassandra.exceptions.ExceptionCode
- write_request_timeout - Variable in class org.apache.cassandra.config.Config
- WRITE_SIZE - org.apache.cassandra.metrics.Sampler.SamplerType
- WRITE_TIME - org.apache.cassandra.cql3.selection.Selectable.WritetimeOrTTL.Kind
- WRITE_TIMEOUT - org.apache.cassandra.exceptions.ExceptionCode
- writeAll - Static variable in class org.apache.cassandra.locator.ReplicaPlans
-
Select all nodes, transient or otherwise, as targets for the operation.
- writeAndAddMemtableRanges(TimeUUID, Supplier<Collection<Range<PartitionPosition>>>, Refs<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
- writeAndFlush(ChannelHandlerContext, Object) - Static method in class org.apache.cassandra.net.AsyncChannelPromise
- writeAndFlush(ChannelHandlerContext, Object, GenericFutureListener<? extends Future<? super Void>>) - Static method in class org.apache.cassandra.net.AsyncChannelPromise
- writeAndFlush(Channel, Object) - 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
- writeAsciiString(String, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
-
Write US-ASCII strings.
- writeAsJsonBytes(Object) - Static method in class org.apache.cassandra.utils.JsonUtils
- writeAsJsonString(Object) - Static method in class org.apache.cassandra.utils.JsonUtils
- writeAsPrettyJsonString(Object) - Static method in class org.apache.cassandra.utils.JsonUtils
- 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(byte) - Method in class org.apache.cassandra.index.sai.disk.io.IndexOutputWriter
- writeByte(byte) - Method in class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- 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(byte[], int) - Method in class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- writeBytes(byte[], int, int) - Method in class org.apache.cassandra.index.sai.disk.io.IndexOutputWriter
- writeBytes(byte[], int, int) - Method in class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- writeBytes(byte[], ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
- 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.
- 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.
- writeCFS(DataOutputPlus, ColumnFamilyStore) - Method in class org.apache.cassandra.cache.AutoSavingCache.CacheSerializer
- 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) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
- writeCompleteSegment(Iterator<IndexEntry>) - Method in class org.apache.cassandra.index.sai.disk.v1.bbtree.NumericIndexWriter
- writeCompleteSegment(Iterator<IndexEntry>) - Method in interface org.apache.cassandra.index.sai.disk.v1.segment.SegmentWriter
-
Appends a set of terms and associated postings to their respective overall SSTable component files.
- writeCompleteSegment(Iterator<IndexEntry>) - Method in class org.apache.cassandra.index.sai.disk.v1.trie.LiteralIndexWriter
- writeComponent(Component, DataInputPlus, long) - Method in class org.apache.cassandra.io.sstable.SSTableZeroCopyWriter
- writeConsistencyLevel(ConsistencyLevel, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
- writeConsistencyLevels - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail on write consistency levels.
- 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
- writeCount() - Method in class org.apache.cassandra.index.sai.memory.MemtableIndex
- writeData(IndexDescriptor, IndexIdentifier, Function<T, Integer>) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.OnHeapGraph
- writeDeletionTime(DeletionTime, DataOutputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
- writeDirect(IndexDescriptor, IndexIdentifier, Function<PrimaryKey, Integer>) - Method in class org.apache.cassandra.index.sai.memory.MemoryIndex
- writeDirect(IndexDescriptor, IndexIdentifier, Function<PrimaryKey, Integer>) - Method in class org.apache.cassandra.index.sai.memory.MemtableIndex
- writeDirect(IndexDescriptor, IndexIdentifier, Function<PrimaryKey, Integer>) - Method in class org.apache.cassandra.index.sai.memory.TrieMemoryIndex
- writeDirect(IndexDescriptor, IndexIdentifier, Function<PrimaryKey, Integer>) - Method in class org.apache.cassandra.index.sai.memory.VectorMemoryIndex
- 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, StreamingDataOutputPlus.RateLimiter) - 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. - writeFileToChannel(FileChannel, StreamingDataOutputPlus.RateLimiter) - Method in interface org.apache.cassandra.streaming.StreamingDataOutputPlus
-
Writes all data in file channel to stream:
* For zero-copy-streaming, 1MiB at a time, with at most 2MiB in flight at once. - writeFileToChannel(FileChannel, StreamingDataOutputPlus.RateLimiter) - Method in class org.apache.cassandra.streaming.StreamingDataOutputPlusFixed
- 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.
- writeFooter(IndexOutput) - Static method in class org.apache.cassandra.index.sai.disk.v1.SAICodecUtils
- 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
- writeHeader(IndexOutput) - Static method in class org.apache.cassandra.index.sai.disk.v1.SAICodecUtils
- 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.index.sai.disk.ResettableByteBuffersIndexOutput
- 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(String) - Method in class org.apache.cassandra.tools.AbstractJmxClient
- writeln(String, Object...) - Method in class org.apache.cassandra.tools.AbstractJmxClient
- writeln(Throwable) - Method in class org.apache.cassandra.tools.AbstractJmxClient
- writeLocal(CounterId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
- writeLocalDeletionTime(long, DataOutputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
- writeLong(long) - Method in class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- 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
- writeMapOfStrings(Map<String, String>) - Method in class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- 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
- writeMetrics - Static variable in class org.apache.cassandra.metrics.ClientRequestsMetricsHolder
- writeMetricsForLevel(ConsistencyLevel) - Static method in class org.apache.cassandra.metrics.ClientRequestsMetricsHolder
- writeMetricsMap - Static variable in class org.apache.cassandra.metrics.ClientRequestsMetricsHolder
- writeMostSignificantBytes(long, int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
- writeMostSignificantBytes(long, int) - Method in interface org.apache.cassandra.io.util.DataOutputPlus
-
An efficient way to write the type
bytes
of a long - writeNodeOrdinalToRowIdMapping(SequentialWriter, RamAwareVectorValues, Map<float[], VectorPostings<T>>) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.VectorPostingsWriter
- 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
- writePartial(IncrementalTrieWriterPageAware.Node<VALUE>, DataOutputPlus, long) - Method in class org.apache.cassandra.io.tries.IncrementalDeepTrieWriterPageAware
- writePartial(IncrementalTrieWriterPageAware.Node<VALUE>, DataOutputPlus, long) - Method in class org.apache.cassandra.io.tries.IncrementalTrieWriterPageAware
- writePartition(CassandraStreamReader.StreamDeserializer, SSTableMultiWriter) - Method in class org.apache.cassandra.db.streaming.CassandraStreamReader
- writePostings(SequentialWriter, RamAwareVectorValues, Map<float[], VectorPostings<T>>, Set<Integer>) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.VectorPostingsWriter
- writePreparedStatement(String, MD5Digest, String) - Static method in class org.apache.cassandra.db.SystemKeyspace
- writeQuorum() - Method in class org.apache.cassandra.locator.ReplicaPlan.ForWrite
- Writer(int) - Constructor for class org.apache.cassandra.cache.AutoSavingCache.Writer
- writeReadRepair(ReplicaPlan<?, ?>) - 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.ForWrite, Runnable, WriteType, Supplier<Mutation>, Dispatcher.RequestTime) - Constructor for class org.apache.cassandra.service.WriteResponseHandler
- WriteResponseHandler(ReplicaPlan.ForWrite, WriteType, Supplier<Mutation>, Dispatcher.RequestTime) - Constructor for class org.apache.cassandra.service.WriteResponseHandler
- writerOptions - Variable in class org.apache.cassandra.io.sstable.IOOptions
- writeRowIdToNodeOrdinalMapping(SequentialWriter, RamAwareVectorValues, Map<float[], VectorPostings<T>>) - Method in class org.apache.cassandra.index.sai.disk.v1.vector.VectorPostingsWriter
- WRITES - org.apache.cassandra.metrics.Sampler.SamplerType
- writesAreDurable() - Method in interface org.apache.cassandra.db.memtable.Memtable.Factory
-
This should be true if the memtable can achieve write durability for crash recovery directly (i.e.
- writesData - Variable in enum org.apache.cassandra.db.compaction.OperationType
-
For purposes of calculating space for interim compactions in flight, whether or not this OperationType is expected to write data to disk
- writeSetOfStrings(Set<String>) - Method in class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- writeShort(int) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
- writeShort(int) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
-
Writes the specified 16-bit short to the OutputStream.
- writeShort(short) - Method in class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- writeShortLength(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- writesShouldSkipCommitLog() - Method in class org.apache.cassandra.db.ColumnFamilyStore
- writesShouldSkipCommitLog() - Method in interface org.apache.cassandra.db.memtable.Memtable.Factory
-
If the memtable can achieve write durability directly (i.e.
- 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) - Method in class org.apache.cassandra.index.sai.disk.ResettableByteBuffersIndexOutput
- 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.
- WRITETIME_OR_TTL_SELECTOR - org.apache.cassandra.cql3.selection.Selector.Kind
- WritetimeOrTTL(ColumnMetadata, Selectable, Selectable.WritetimeOrTTL.Kind) - 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(StreamingDataOutputPlus.Write, StreamingDataOutputPlus.RateLimiter) - 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.
- writeToChannel(StreamingDataOutputPlus.Write, StreamingDataOutputPlus.RateLimiter) - Method in interface org.apache.cassandra.streaming.StreamingDataOutputPlus
-
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.
- writeToChannel(StreamingDataOutputPlus.Write, StreamingDataOutputPlus.RateLimiter) - Method in class org.apache.cassandra.streaming.StreamingDataOutputPlusFixed
- writeTTL(int, DataOutputPlus) - Method in class org.apache.cassandra.db.SerializationHeader
- 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
- writeType(DataOutputPlus, AbstractType<?>) - Static method in class org.apache.cassandra.cql3.selection.Selector
- WriteType - Enum in org.apache.cassandra.db
- writeUnsignedVInt(int) - Method in interface org.apache.cassandra.io.util.DataOutputPlus
-
Deprecated.See CASSANDRA-18099
- writeUnsignedVInt(int, ByteBuffer) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
-
Deprecated.See CASSANDRA-18099
- writeUnsignedVInt(int, DataOutputPlus) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
-
Deprecated.See CASSANDRA-18099
- 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, ByteBuffer) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- writeUnsignedVInt(long, DataOutputPlus) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- writeUnsignedVInt(long, V, int, ValueAccessor<V>) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- writeUnsignedVInt32(int) - Method in interface org.apache.cassandra.io.util.DataOutputPlus
- writeUnsignedVInt32(int, ByteBuffer) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- writeUnsignedVInt32(int, DataOutputPlus) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- writeUnsignedVInt32(int, V, int, ValueAccessor<V>) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- writeUTF(String) - Method in class org.apache.cassandra.io.util.BufferedDataOutputStreamPlus
- writeUTF(String) - Method in class org.apache.cassandra.io.util.UnbufferedDataOutputStreamPlus
-
Writes the specified String out in UTF format.
- 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
- writeUUID(UUID, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
- writeUUID(TimeUUID, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
- writeValue(byte[], ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
- writeValue(Object, ByteBuf, ProtocolVersion) - Method in enum org.apache.cassandra.transport.DataType
- writeValue(ByteBuffer, 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(ByteBuffer, DataOutputPlus) - Method in class org.apache.cassandra.db.marshal.EmptyType
- writeValue(ByteBuffer, V, ValueAccessor<V>) - Static method in class org.apache.cassandra.serializers.CollectionSerializer
- writeValue(V, ValueAccessor<V>, DataOutputPlus) - Method in class org.apache.cassandra.db.marshal.AbstractType
- writeValueList(List<ByteBuffer>, ByteBuf) - Static method in class org.apache.cassandra.transport.CBUtil
- writeVInt(int) - Method in interface org.apache.cassandra.io.util.DataOutputPlus
-
Deprecated.See CASSANDRA-18099
- writeVInt(int, ByteBuffer) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
-
Deprecated.See CASSANDRA-18099
- writeVInt(int, DataOutputPlus) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
-
Deprecated.See CASSANDRA-18099
- writeVInt(long) - Method in interface org.apache.cassandra.io.util.DataOutputPlus
- writeVInt(long, ByteBuffer) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- writeVInt(long, DataOutputPlus) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- writeVInt(long, V, int, ValueAccessor<V>) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- writeVInt32(int) - Method in interface org.apache.cassandra.io.util.DataOutputPlus
- writeVInt32(int, ByteBuffer) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- writeVInt32(int, DataOutputPlus) - Static method in class org.apache.cassandra.utils.vint.VIntCoding
- writeVInt32(int, V, int, ValueAccessor<V>) - 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(byte[], DataOutputPlus) - Static method in class org.apache.cassandra.utils.ByteArrayUtil
- writeWithVIntLength(ByteBuffer, DataOutputPlus) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- writeWithVIntLength(V, DataOutputPlus) - Method in interface org.apache.cassandra.db.marshal.ValueAccessor
- writeZeroes(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
- written - Variable in class org.apache.cassandra.io.sstable.format.SortedTablePartitionWriter
- 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
X
- X - org.apache.cassandra.db.Directories.FileAction
- X_11_PADDING - org.apache.cassandra.gms.ApplicationState
- X1 - org.apache.cassandra.gms.ApplicationState
- X10 - org.apache.cassandra.gms.ApplicationState
- X2 - org.apache.cassandra.gms.ApplicationState
- X3 - org.apache.cassandra.gms.ApplicationState
- X4 - org.apache.cassandra.gms.ApplicationState
- X5 - org.apache.cassandra.gms.ApplicationState
- X6 - org.apache.cassandra.gms.ApplicationState
- X7 - org.apache.cassandra.gms.ApplicationState
- X8 - org.apache.cassandra.gms.ApplicationState
- X9 - org.apache.cassandra.gms.ApplicationState
- XR - org.apache.cassandra.db.Directories.FileAction
- XRW - org.apache.cassandra.db.Directories.FileAction
- XW - org.apache.cassandra.db.Directories.FileAction
Y
- yaml - org.apache.cassandra.tools.JMXTool.Diff.Format
- yaml - org.apache.cassandra.tools.JMXTool.Dump.Format
- 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
- zero_ttl_on_twcs_enabled - Variable in class org.apache.cassandra.config.Config
- zero_ttl_on_twcs_warned - Variable in class org.apache.cassandra.config.Config
- zeroTTLOnTWCSEnabled - Static variable in class org.apache.cassandra.db.guardrails.Guardrails
-
Guardrail to warn or fail a CREATE or ALTER TABLE statement when default_time_to_live is set to 0 and the table is using TimeWindowCompactionStrategy compaction or a subclass of it.
- ZONE_NAME_QUERY - Static variable in class org.apache.cassandra.locator.Ec2Snitch
- 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
_
- _SAMPLE - org.apache.cassandra.net.Verb
- _TEST_1 - org.apache.cassandra.net.Verb
- _TEST_2 - org.apache.cassandra.net.Verb
- _TRACE - org.apache.cassandra.net.Verb
All Classes All Packages